public abstract class SparkListener extends Object implements SparkListenerInterface
SparkListenerInterface
that has no-op implementations for
all callbacks.
Note that this is an internal interface which might change in different Spark releases.
Constructor and Description |
---|
SparkListener() |
Modifier and Type | Method and Description |
---|---|
void |
onApplicationEnd(SparkListenerApplicationEnd applicationEnd)
Called when the application ends
|
void |
onApplicationStart(SparkListenerApplicationStart applicationStart)
Called when the application starts
|
void |
onBlockManagerAdded(SparkListenerBlockManagerAdded blockManagerAdded)
Called when a new block manager has joined
|
void |
onBlockManagerRemoved(SparkListenerBlockManagerRemoved blockManagerRemoved)
Called when an existing block manager has been removed
|
void |
onBlockUpdated(SparkListenerBlockUpdated blockUpdated)
Called when the driver receives a block update info.
|
void |
onEnvironmentUpdate(SparkListenerEnvironmentUpdate environmentUpdate)
Called when environment properties have been updated
|
void |
onExecutorAdded(SparkListenerExecutorAdded executorAdded)
Called when the driver registers a new executor.
|
void |
onExecutorBlacklisted(SparkListenerExecutorBlacklisted executorBlacklisted)
Called when the driver excludes an executor for a Spark application.
|
void |
onExecutorBlacklistedForStage(SparkListenerExecutorBlacklistedForStage executorBlacklistedForStage)
Called when the driver excludes an executor for a stage.
|
void |
onExecutorExcluded(SparkListenerExecutorExcluded executorExcluded)
Called when the driver excludes an executor for a Spark application.
|
void |
onExecutorExcludedForStage(SparkListenerExecutorExcludedForStage executorExcludedForStage)
Called when the driver excludes an executor for a stage.
|
void |
onExecutorMetricsUpdate(SparkListenerExecutorMetricsUpdate executorMetricsUpdate)
Called when the driver receives task metrics from an executor in a heartbeat.
|
void |
onExecutorRemoved(SparkListenerExecutorRemoved executorRemoved)
Called when the driver removes an executor.
|
void |
onExecutorUnblacklisted(SparkListenerExecutorUnblacklisted executorUnblacklisted)
Called when the driver re-enables a previously excluded executor.
|
void |
onExecutorUnexcluded(SparkListenerExecutorUnexcluded executorUnexcluded)
Called when the driver re-enables a previously excluded executor.
|
void |
onJobEnd(SparkListenerJobEnd jobEnd)
Called when a job ends
|
void |
onJobStart(SparkListenerJobStart jobStart)
Called when a job starts
|
void |
onNodeBlacklisted(SparkListenerNodeBlacklisted nodeBlacklisted)
Called when the driver excludes a node for a Spark application.
|
void |
onNodeBlacklistedForStage(SparkListenerNodeBlacklistedForStage nodeBlacklistedForStage)
Called when the driver excludes a node for a stage.
|
void |
onNodeExcluded(SparkListenerNodeExcluded nodeExcluded)
Called when the driver excludes a node for a Spark application.
|
void |
onNodeExcludedForStage(SparkListenerNodeExcludedForStage nodeExcludedForStage)
Called when the driver excludes a node for a stage.
|
void |
onNodeUnblacklisted(SparkListenerNodeUnblacklisted nodeUnblacklisted)
Called when the driver re-enables a previously excluded node.
|
void |
onNodeUnexcluded(SparkListenerNodeUnexcluded nodeUnexcluded)
Called when the driver re-enables a previously excluded node.
|
void |
onOtherEvent(SparkListenerEvent event)
Called when other events like SQL-specific events are posted.
|
void |
onResourceProfileAdded(SparkListenerResourceProfileAdded event)
Called when a Resource Profile is added to the manager.
|
void |
onSpeculativeTaskSubmitted(SparkListenerSpeculativeTaskSubmitted speculativeTask)
Called when a speculative task is submitted
|
void |
onStageCompleted(SparkListenerStageCompleted stageCompleted)
Called when a stage completes successfully or fails, with information on the completed stage.
|
void |
onStageExecutorMetrics(SparkListenerStageExecutorMetrics executorMetrics)
Called with the peak memory metrics for a given (executor, stage) combination.
|
void |
onStageSubmitted(SparkListenerStageSubmitted stageSubmitted)
Called when a stage is submitted
|
void |
onTaskEnd(SparkListenerTaskEnd taskEnd)
Called when a task ends
|
void |
onTaskGettingResult(SparkListenerTaskGettingResult taskGettingResult)
Called when a task begins remotely fetching its result (will not be called for tasks that do
not need to fetch the result remotely).
|
void |
onTaskStart(SparkListenerTaskStart taskStart)
Called when a task starts
|
void |
onUnpersistRDD(SparkListenerUnpersistRDD unpersistRDD)
Called when an RDD is manually unpersisted by the application
|
void |
onUnschedulableTaskSetAdded(SparkListenerUnschedulableTaskSetAdded unschedulableTaskSetAdded)
Called when a taskset becomes unschedulable due to exludeOnFailure and dynamic allocation
is enabled.
|
void |
onUnschedulableTaskSetRemoved(SparkListenerUnschedulableTaskSetRemoved unschedulableTaskSetRemoved)
Called when an unschedulable taskset becomes schedulable and dynamic allocation
is enabled.
|
public void onApplicationEnd(SparkListenerApplicationEnd applicationEnd)
SparkListenerInterface
onApplicationEnd
in interface SparkListenerInterface
applicationEnd
- (undocumented)public void onApplicationStart(SparkListenerApplicationStart applicationStart)
SparkListenerInterface
onApplicationStart
in interface SparkListenerInterface
applicationStart
- (undocumented)public void onBlockManagerAdded(SparkListenerBlockManagerAdded blockManagerAdded)
SparkListenerInterface
onBlockManagerAdded
in interface SparkListenerInterface
blockManagerAdded
- (undocumented)public void onBlockManagerRemoved(SparkListenerBlockManagerRemoved blockManagerRemoved)
SparkListenerInterface
onBlockManagerRemoved
in interface SparkListenerInterface
blockManagerRemoved
- (undocumented)public void onBlockUpdated(SparkListenerBlockUpdated blockUpdated)
SparkListenerInterface
onBlockUpdated
in interface SparkListenerInterface
blockUpdated
- (undocumented)public void onEnvironmentUpdate(SparkListenerEnvironmentUpdate environmentUpdate)
SparkListenerInterface
onEnvironmentUpdate
in interface SparkListenerInterface
environmentUpdate
- (undocumented)public void onExecutorAdded(SparkListenerExecutorAdded executorAdded)
SparkListenerInterface
onExecutorAdded
in interface SparkListenerInterface
executorAdded
- (undocumented)public void onExecutorBlacklisted(SparkListenerExecutorBlacklisted executorBlacklisted)
SparkListenerInterface
onExecutorBlacklisted
in interface SparkListenerInterface
executorBlacklisted
- (undocumented)public void onExecutorBlacklistedForStage(SparkListenerExecutorBlacklistedForStage executorBlacklistedForStage)
SparkListenerInterface
onExecutorBlacklistedForStage
in interface SparkListenerInterface
executorBlacklistedForStage
- (undocumented)public void onExecutorExcluded(SparkListenerExecutorExcluded executorExcluded)
SparkListenerInterface
onExecutorExcluded
in interface SparkListenerInterface
executorExcluded
- (undocumented)public void onExecutorExcludedForStage(SparkListenerExecutorExcludedForStage executorExcludedForStage)
SparkListenerInterface
onExecutorExcludedForStage
in interface SparkListenerInterface
executorExcludedForStage
- (undocumented)public void onExecutorMetricsUpdate(SparkListenerExecutorMetricsUpdate executorMetricsUpdate)
SparkListenerInterface
onExecutorMetricsUpdate
in interface SparkListenerInterface
executorMetricsUpdate
- (undocumented)public void onExecutorRemoved(SparkListenerExecutorRemoved executorRemoved)
SparkListenerInterface
onExecutorRemoved
in interface SparkListenerInterface
executorRemoved
- (undocumented)public void onExecutorUnblacklisted(SparkListenerExecutorUnblacklisted executorUnblacklisted)
SparkListenerInterface
onExecutorUnblacklisted
in interface SparkListenerInterface
executorUnblacklisted
- (undocumented)public void onExecutorUnexcluded(SparkListenerExecutorUnexcluded executorUnexcluded)
SparkListenerInterface
onExecutorUnexcluded
in interface SparkListenerInterface
executorUnexcluded
- (undocumented)public void onJobEnd(SparkListenerJobEnd jobEnd)
SparkListenerInterface
onJobEnd
in interface SparkListenerInterface
jobEnd
- (undocumented)public void onJobStart(SparkListenerJobStart jobStart)
SparkListenerInterface
onJobStart
in interface SparkListenerInterface
jobStart
- (undocumented)public void onNodeBlacklisted(SparkListenerNodeBlacklisted nodeBlacklisted)
SparkListenerInterface
onNodeBlacklisted
in interface SparkListenerInterface
nodeBlacklisted
- (undocumented)public void onNodeBlacklistedForStage(SparkListenerNodeBlacklistedForStage nodeBlacklistedForStage)
SparkListenerInterface
onNodeBlacklistedForStage
in interface SparkListenerInterface
nodeBlacklistedForStage
- (undocumented)public void onNodeExcluded(SparkListenerNodeExcluded nodeExcluded)
SparkListenerInterface
onNodeExcluded
in interface SparkListenerInterface
nodeExcluded
- (undocumented)public void onNodeExcludedForStage(SparkListenerNodeExcludedForStage nodeExcludedForStage)
SparkListenerInterface
onNodeExcludedForStage
in interface SparkListenerInterface
nodeExcludedForStage
- (undocumented)public void onNodeUnblacklisted(SparkListenerNodeUnblacklisted nodeUnblacklisted)
SparkListenerInterface
onNodeUnblacklisted
in interface SparkListenerInterface
nodeUnblacklisted
- (undocumented)public void onNodeUnexcluded(SparkListenerNodeUnexcluded nodeUnexcluded)
SparkListenerInterface
onNodeUnexcluded
in interface SparkListenerInterface
nodeUnexcluded
- (undocumented)public void onOtherEvent(SparkListenerEvent event)
SparkListenerInterface
onOtherEvent
in interface SparkListenerInterface
event
- (undocumented)public void onResourceProfileAdded(SparkListenerResourceProfileAdded event)
SparkListenerInterface
onResourceProfileAdded
in interface SparkListenerInterface
event
- (undocumented)public void onSpeculativeTaskSubmitted(SparkListenerSpeculativeTaskSubmitted speculativeTask)
SparkListenerInterface
onSpeculativeTaskSubmitted
in interface SparkListenerInterface
speculativeTask
- (undocumented)public void onStageCompleted(SparkListenerStageCompleted stageCompleted)
SparkListenerInterface
onStageCompleted
in interface SparkListenerInterface
stageCompleted
- (undocumented)public void onStageExecutorMetrics(SparkListenerStageExecutorMetrics executorMetrics)
SparkListenerInterface
onStageExecutorMetrics
in interface SparkListenerInterface
executorMetrics
- (undocumented)public void onStageSubmitted(SparkListenerStageSubmitted stageSubmitted)
SparkListenerInterface
onStageSubmitted
in interface SparkListenerInterface
stageSubmitted
- (undocumented)public void onTaskEnd(SparkListenerTaskEnd taskEnd)
SparkListenerInterface
onTaskEnd
in interface SparkListenerInterface
taskEnd
- (undocumented)public void onTaskGettingResult(SparkListenerTaskGettingResult taskGettingResult)
SparkListenerInterface
onTaskGettingResult
in interface SparkListenerInterface
taskGettingResult
- (undocumented)public void onTaskStart(SparkListenerTaskStart taskStart)
SparkListenerInterface
onTaskStart
in interface SparkListenerInterface
taskStart
- (undocumented)public void onUnpersistRDD(SparkListenerUnpersistRDD unpersistRDD)
SparkListenerInterface
onUnpersistRDD
in interface SparkListenerInterface
unpersistRDD
- (undocumented)public void onUnschedulableTaskSetAdded(SparkListenerUnschedulableTaskSetAdded unschedulableTaskSetAdded)
SparkListenerInterface
onUnschedulableTaskSetAdded
in interface SparkListenerInterface
unschedulableTaskSetAdded
- (undocumented)public void onUnschedulableTaskSetRemoved(SparkListenerUnschedulableTaskSetRemoved unschedulableTaskSetRemoved)
SparkListenerInterface
onUnschedulableTaskSetRemoved
in interface SparkListenerInterface
unschedulableTaskSetRemoved
- (undocumented)