Package org.apache.spark.scheduler
package org.apache.spark.scheduler
Spark's DAG scheduler.
- 
ClassDescription:: DeveloperApi :: Information about anAccumulatorV2modified during a task or stage.An asynchronous queue for events.Types of events that can be handled by the DAGScheduler.A cluster manager interface to plugin external scheduler.:: DeveloperApi :: Parses and holds information about inputFormat (and files) specified as a parameter.Interface used to listen for job completion or failure events after submitting a job to the DAGScheduler.:: DeveloperApi :: A result of a job in the DAGScheduler.A loss reason that means we don't yet know why the executor exited.Result returned by a ShuffleMapTask to a scheduler.:: DeveloperApi :: Stores information about an Miscellaneous Process to pass from the scheduler to SparkListeners.An interface for schedulable entities.An interface to build Schedulable tree buildPools: build the tree nodes(pools) addTaskSetManager: build the leaf nodes(TaskSetManagers)A backend interface for scheduling systems that allows plugging in different ones under TaskSchedulerImpl.An interface for sort algorithm FIFO: FIFO algorithm between TaskSetManagers FS: FS algorithm between Pools, and FIFO or FS within Pools"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.A common trait betweenMapStatusandMergeStatus.:: DeveloperApi :: A default implementation forSparkListenerInterfacethat has no-op implementations for all callbacks.ASparkListenerEventbus that relaysSparkListenerEvents to its listenersDeprecated.use SparkListenerExecutorExcluded instead.Deprecated.use SparkListenerExecutorExcludedForStage instead.Periodic updates from executors.Deprecated.use SparkListenerExecutorUnexcluded instead.Interface for listening to events from the Spark scheduler.An internal class that describes the metadata of an event log.Deprecated.use SparkListenerNodeExcluded instead.Deprecated.use SparkListenerNodeExcludedForStage instead.Deprecated.use SparkListenerNodeUnexcluded instead.Peak metric values for the executor for the stage, written to the history log at stage completion.:: DeveloperApi :: Stores information about a stage to pass from the scheduler to SparkListeners.:: DeveloperApi :: Simple SparkListener that logs a few summary statistics when each stage completes.:: DeveloperApi :: Information about a running task attempt inside a TaskSet.A location where a task should run.TaskResult<T>Low-level task scheduler interface, currently implemented exclusively byTaskSchedulerImpl.