Interface | Description |
---|---|
JobResult |
:: DeveloperApi ::
A result of a job in the DAGScheduler.
|
OutputCommitCoordinationMessage | |
SparkListenerEvent |
Class | Description |
---|---|
AccumulableInfo |
:: DeveloperApi ::
Information about an
Accumulable modified during a task or stage. |
AllJobsCancelled | |
AskPermissionToCommitOutput | |
ExecutorKilled | |
InputFormatInfo |
:: DeveloperApi ::
Parses and holds information about inputFormat (and files) specified as a parameter.
|
JobSucceeded | |
LossReasonPending |
A loss reason that means we don't yet know why the executor exited.
|
ResubmitFailedStages | |
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.
|
SparkListener |
:: DeveloperApi ::
A default implementation for
SparkListenerInterface that has no-op implementations for
all callbacks. |
SparkListenerApplicationEnd | |
SparkListenerApplicationStart | |
SparkListenerBlockManagerAdded | |
SparkListenerBlockManagerRemoved | |
SparkListenerBlockUpdated | |
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 |