public interface SparkListenerInterface
Note that this is an internal interface which might change in different Spark releases.
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)
Deprecated.
use onExecutorExcluded instead. Since 3.1.0.
|
void |
onExecutorBlacklistedForStage(SparkListenerExecutorBlacklistedForStage executorBlacklistedForStage)
Deprecated.
use onExecutorExcludedForStage instead. Since 3.1.0.
|
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)
Deprecated.
use onExecutorUnexcluded instead. Since 3.1.0.
|
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)
Deprecated.
use onNodeExcluded instead. Since 3.1.0.
|
void |
onNodeBlacklistedForStage(SparkListenerNodeBlacklistedForStage nodeBlacklistedForStage)
Deprecated.
use onNodeExcludedForStage instead. Since 3.1.0.
|
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)
Deprecated.
use onNodeUnexcluded instead. Since 3.1.0.
|
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.
|
void onApplicationEnd(SparkListenerApplicationEnd applicationEnd)
applicationEnd
- (undocumented)void onApplicationStart(SparkListenerApplicationStart applicationStart)
applicationStart
- (undocumented)void onBlockManagerAdded(SparkListenerBlockManagerAdded blockManagerAdded)
blockManagerAdded
- (undocumented)void onBlockManagerRemoved(SparkListenerBlockManagerRemoved blockManagerRemoved)
blockManagerRemoved
- (undocumented)void onBlockUpdated(SparkListenerBlockUpdated blockUpdated)
blockUpdated
- (undocumented)void onEnvironmentUpdate(SparkListenerEnvironmentUpdate environmentUpdate)
environmentUpdate
- (undocumented)void onExecutorAdded(SparkListenerExecutorAdded executorAdded)
executorAdded
- (undocumented)void onExecutorBlacklisted(SparkListenerExecutorBlacklisted executorBlacklisted)
executorBlacklisted
- (undocumented)void onExecutorBlacklistedForStage(SparkListenerExecutorBlacklistedForStage executorBlacklistedForStage)
executorBlacklistedForStage
- (undocumented)void onExecutorExcluded(SparkListenerExecutorExcluded executorExcluded)
executorExcluded
- (undocumented)void onExecutorExcludedForStage(SparkListenerExecutorExcludedForStage executorExcludedForStage)
executorExcludedForStage
- (undocumented)void onExecutorMetricsUpdate(SparkListenerExecutorMetricsUpdate executorMetricsUpdate)
executorMetricsUpdate
- (undocumented)void onExecutorRemoved(SparkListenerExecutorRemoved executorRemoved)
executorRemoved
- (undocumented)void onExecutorUnblacklisted(SparkListenerExecutorUnblacklisted executorUnblacklisted)
executorUnblacklisted
- (undocumented)void onExecutorUnexcluded(SparkListenerExecutorUnexcluded executorUnexcluded)
executorUnexcluded
- (undocumented)void onJobEnd(SparkListenerJobEnd jobEnd)
jobEnd
- (undocumented)void onJobStart(SparkListenerJobStart jobStart)
jobStart
- (undocumented)void onNodeBlacklisted(SparkListenerNodeBlacklisted nodeBlacklisted)
nodeBlacklisted
- (undocumented)void onNodeBlacklistedForStage(SparkListenerNodeBlacklistedForStage nodeBlacklistedForStage)
nodeBlacklistedForStage
- (undocumented)void onNodeExcluded(SparkListenerNodeExcluded nodeExcluded)
nodeExcluded
- (undocumented)void onNodeExcludedForStage(SparkListenerNodeExcludedForStage nodeExcludedForStage)
nodeExcludedForStage
- (undocumented)void onNodeUnblacklisted(SparkListenerNodeUnblacklisted nodeUnblacklisted)
nodeUnblacklisted
- (undocumented)void onNodeUnexcluded(SparkListenerNodeUnexcluded nodeUnexcluded)
nodeUnexcluded
- (undocumented)void onOtherEvent(SparkListenerEvent event)
event
- (undocumented)void onResourceProfileAdded(SparkListenerResourceProfileAdded event)
event
- (undocumented)void onSpeculativeTaskSubmitted(SparkListenerSpeculativeTaskSubmitted speculativeTask)
speculativeTask
- (undocumented)void onStageCompleted(SparkListenerStageCompleted stageCompleted)
stageCompleted
- (undocumented)void onStageExecutorMetrics(SparkListenerStageExecutorMetrics executorMetrics)
executorMetrics
- (undocumented)void onStageSubmitted(SparkListenerStageSubmitted stageSubmitted)
stageSubmitted
- (undocumented)void onTaskEnd(SparkListenerTaskEnd taskEnd)
taskEnd
- (undocumented)void onTaskGettingResult(SparkListenerTaskGettingResult taskGettingResult)
taskGettingResult
- (undocumented)void onTaskStart(SparkListenerTaskStart taskStart)
taskStart
- (undocumented)void onUnpersistRDD(SparkListenerUnpersistRDD unpersistRDD)
unpersistRDD
- (undocumented)void onUnschedulableTaskSetAdded(SparkListenerUnschedulableTaskSetAdded unschedulableTaskSetAdded)
unschedulableTaskSetAdded
- (undocumented)void onUnschedulableTaskSetRemoved(SparkListenerUnschedulableTaskSetRemoved unschedulableTaskSetRemoved)
unschedulableTaskSetRemoved
- (undocumented)