Package org.apache.spark.scheduler

Spark's DAG scheduler.

See:
          Description

Interface Summary
JobResult :: DeveloperApi :: A result of a job in the DAGScheduler.
OutputCommitCoordinationMessage  
SparkListener :: DeveloperApi :: Interface for listening to events from the Spark scheduler.
SparkListenerEvent  
 

Class Summary
AccumulableInfo :: DeveloperApi :: Information about an Accumulable modified during a task or stage.
AskPermissionToCommitOutput  
InputFormatInfo :: DeveloperApi :: Parses and holds information about inputFormat (and files) specified as a parameter.
JobLogger :: DeveloperApi :: A logger class to record runtime information for jobs in Spark.
JobSucceeded  
RuntimePercentage  
SchedulingMode "FAIR" and "FIFO" determines which policy is used to order tasks amongst a Schedulable's sub-queues "NONE" is used when the a Schedulable has no sub-queues.
SparkListenerApplicationEnd  
SparkListenerApplicationStart  
SparkListenerBlockManagerAdded  
SparkListenerBlockManagerRemoved  
SparkListenerEnvironmentUpdate  
SparkListenerExecutorAdded  
SparkListenerExecutorMetricsUpdate Periodic updates from executors.
SparkListenerExecutorRemoved  
SparkListenerJobEnd  
SparkListenerJobStart  
SparkListenerStageCompleted  
SparkListenerStageSubmitted  
SparkListenerTaskEnd  
SparkListenerTaskGettingResult  
SparkListenerTaskStart  
SparkListenerUnpersistRDD  
SplitInfo  
StageInfo :: DeveloperApi :: Stores information about a stage to pass from the scheduler to SparkListeners.
StatsReportListener :: DeveloperApi :: Simple SparkListener that logs a few summary statistics when each stage completes
StopCoordinator  
TaskInfo :: DeveloperApi :: Information about a running task attempt inside a TaskSet.
TaskLocality  
 

Package org.apache.spark.scheduler Description

Spark's DAG scheduler.