class SparkFirehoseListener extends SparkListenerInterface
Class that allows users to receive all SparkListener events. Users should override the onEvent method.
This is a concrete Java class in order to ensure that we don't forget to update it when adding new methods to SparkListener: forgetting to add a method will result in a compilation error (if this was a concrete Scala class, default implementations of new event handlers would be inherited from the SparkListener trait).
Please note until Spark 3.1.0 this was missing the DevelopApi annotation, this needs to be taken into account if changing this API before a major release.
- Annotations
- @DeveloperApi()
- Source
- SparkFirehoseListener.java
- Alphabetic
- By Inheritance
- SparkFirehoseListener
- SparkListenerInterface
- AnyRef
- Any
- Hide All
- Show All
- Public
- Protected
Instance Constructors
- new SparkFirehoseListener()
Value Members
- final def !=(arg0: Any): Boolean
- Definition Classes
- AnyRef → Any
- final def ##: Int
- Definition Classes
- AnyRef → Any
- final def ==(arg0: Any): Boolean
- Definition Classes
- AnyRef → Any
- final def asInstanceOf[T0]: T0
- Definition Classes
- Any
- def clone(): AnyRef
- Attributes
- protected[lang]
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.CloneNotSupportedException]) @IntrinsicCandidate() @native()
- final def eq(arg0: AnyRef): Boolean
- Definition Classes
- AnyRef
- def equals(arg0: AnyRef): Boolean
- Definition Classes
- AnyRef → Any
- final def getClass(): Class[_ <: AnyRef]
- Definition Classes
- AnyRef → Any
- Annotations
- @IntrinsicCandidate() @native()
- def hashCode(): Int
- Definition Classes
- AnyRef → Any
- Annotations
- @IntrinsicCandidate() @native()
- final def isInstanceOf[T0]: Boolean
- Definition Classes
- Any
- final def ne(arg0: AnyRef): Boolean
- Definition Classes
- AnyRef
- final def notify(): Unit
- Definition Classes
- AnyRef
- Annotations
- @IntrinsicCandidate() @native()
- final def notifyAll(): Unit
- Definition Classes
- AnyRef
- Annotations
- @IntrinsicCandidate() @native()
- final def onApplicationEnd(applicationEnd: SparkListenerApplicationEnd): Unit
Called when the application ends
Called when the application ends
- Definition Classes
- SparkFirehoseListener → SparkListenerInterface
- Annotations
- @Override()
- final def onApplicationStart(applicationStart: SparkListenerApplicationStart): Unit
Called when the application starts
Called when the application starts
- Definition Classes
- SparkFirehoseListener → SparkListenerInterface
- Annotations
- @Override()
- final def onBlockManagerAdded(blockManagerAdded: SparkListenerBlockManagerAdded): Unit
Called when a new block manager has joined
Called when a new block manager has joined
- Definition Classes
- SparkFirehoseListener → SparkListenerInterface
- Annotations
- @Override()
- final def onBlockManagerRemoved(blockManagerRemoved: SparkListenerBlockManagerRemoved): Unit
Called when an existing block manager has been removed
Called when an existing block manager has been removed
- Definition Classes
- SparkFirehoseListener → SparkListenerInterface
- Annotations
- @Override()
- def onBlockUpdated(blockUpdated: SparkListenerBlockUpdated): Unit
Called when the driver receives a block update info.
Called when the driver receives a block update info.
- Definition Classes
- SparkFirehoseListener → SparkListenerInterface
- Annotations
- @Override()
- final def onEnvironmentUpdate(environmentUpdate: SparkListenerEnvironmentUpdate): Unit
Called when environment properties have been updated
Called when environment properties have been updated
- Definition Classes
- SparkFirehoseListener → SparkListenerInterface
- Annotations
- @Override()
- def onEvent(event: SparkListenerEvent): Unit
- final def onExecutorAdded(executorAdded: SparkListenerExecutorAdded): Unit
Called when the driver registers a new executor.
Called when the driver registers a new executor.
- Definition Classes
- SparkFirehoseListener → SparkListenerInterface
- Annotations
- @Override()
- final def onExecutorBlacklisted(executorBlacklisted: SparkListenerExecutorBlacklisted): Unit
Called when the driver excludes an executor for a Spark application.
Called when the driver excludes an executor for a Spark application.
- Definition Classes
- SparkFirehoseListener → SparkListenerInterface
- Annotations
- @Override()
- def onExecutorBlacklistedForStage(executorBlacklistedForStage: SparkListenerExecutorBlacklistedForStage): Unit
Called when the driver excludes an executor for a stage.
Called when the driver excludes an executor for a stage.
- Definition Classes
- SparkFirehoseListener → SparkListenerInterface
- Annotations
- @Override()
- final def onExecutorExcluded(executorExcluded: SparkListenerExecutorExcluded): Unit
Called when the driver excludes an executor for a Spark application.
Called when the driver excludes an executor for a Spark application.
- Definition Classes
- SparkFirehoseListener → SparkListenerInterface
- Annotations
- @Override()
- def onExecutorExcludedForStage(executorExcludedForStage: SparkListenerExecutorExcludedForStage): Unit
Called when the driver excludes an executor for a stage.
Called when the driver excludes an executor for a stage.
- Definition Classes
- SparkFirehoseListener → SparkListenerInterface
- Annotations
- @Override()
- final def onExecutorMetricsUpdate(executorMetricsUpdate: SparkListenerExecutorMetricsUpdate): Unit
Called when the driver receives task metrics from an executor in a heartbeat.
Called when the driver receives task metrics from an executor in a heartbeat.
- Definition Classes
- SparkFirehoseListener → SparkListenerInterface
- Annotations
- @Override()
- final def onExecutorRemoved(executorRemoved: SparkListenerExecutorRemoved): Unit
Called when the driver removes an executor.
Called when the driver removes an executor.
- Definition Classes
- SparkFirehoseListener → SparkListenerInterface
- Annotations
- @Override()
- final def onExecutorUnblacklisted(executorUnblacklisted: SparkListenerExecutorUnblacklisted): Unit
Called when the driver re-enables a previously excluded executor.
Called when the driver re-enables a previously excluded executor.
- Definition Classes
- SparkFirehoseListener → SparkListenerInterface
- Annotations
- @Override()
- final def onExecutorUnexcluded(executorUnexcluded: SparkListenerExecutorUnexcluded): Unit
Called when the driver re-enables a previously excluded executor.
Called when the driver re-enables a previously excluded executor.
- Definition Classes
- SparkFirehoseListener → SparkListenerInterface
- Annotations
- @Override()
- final def onJobEnd(jobEnd: SparkListenerJobEnd): Unit
Called when a job ends
Called when a job ends
- Definition Classes
- SparkFirehoseListener → SparkListenerInterface
- Annotations
- @Override()
- final def onJobStart(jobStart: SparkListenerJobStart): Unit
Called when a job starts
Called when a job starts
- Definition Classes
- SparkFirehoseListener → SparkListenerInterface
- Annotations
- @Override()
- final def onNodeBlacklisted(nodeBlacklisted: SparkListenerNodeBlacklisted): Unit
Called when the driver excludes a node for a Spark application.
Called when the driver excludes a node for a Spark application.
- Definition Classes
- SparkFirehoseListener → SparkListenerInterface
- Annotations
- @Override()
- def onNodeBlacklistedForStage(nodeBlacklistedForStage: SparkListenerNodeBlacklistedForStage): Unit
Called when the driver excludes a node for a stage.
Called when the driver excludes a node for a stage.
- Definition Classes
- SparkFirehoseListener → SparkListenerInterface
- Annotations
- @Override()
- final def onNodeExcluded(nodeExcluded: SparkListenerNodeExcluded): Unit
Called when the driver excludes a node for a Spark application.
Called when the driver excludes a node for a Spark application.
- Definition Classes
- SparkFirehoseListener → SparkListenerInterface
- Annotations
- @Override()
- def onNodeExcludedForStage(nodeExcludedForStage: SparkListenerNodeExcludedForStage): Unit
Called when the driver excludes a node for a stage.
Called when the driver excludes a node for a stage.
- Definition Classes
- SparkFirehoseListener → SparkListenerInterface
- Annotations
- @Override()
- final def onNodeUnblacklisted(nodeUnblacklisted: SparkListenerNodeUnblacklisted): Unit
Called when the driver re-enables a previously excluded node.
Called when the driver re-enables a previously excluded node.
- Definition Classes
- SparkFirehoseListener → SparkListenerInterface
- Annotations
- @Override()
- final def onNodeUnexcluded(nodeUnexcluded: SparkListenerNodeUnexcluded): Unit
Called when the driver re-enables a previously excluded node.
Called when the driver re-enables a previously excluded node.
- Definition Classes
- SparkFirehoseListener → SparkListenerInterface
- Annotations
- @Override()
- def onOtherEvent(event: SparkListenerEvent): Unit
Called when other events like SQL-specific events are posted.
Called when other events like SQL-specific events are posted.
- Definition Classes
- SparkFirehoseListener → SparkListenerInterface
- Annotations
- @Override()
- def onResourceProfileAdded(event: SparkListenerResourceProfileAdded): Unit
Called when a Resource Profile is added to the manager.
Called when a Resource Profile is added to the manager.
- Definition Classes
- SparkFirehoseListener → SparkListenerInterface
- Annotations
- @Override()
- def onSpeculativeTaskSubmitted(speculativeTask: SparkListenerSpeculativeTaskSubmitted): Unit
Called when a speculative task is submitted
Called when a speculative task is submitted
- Definition Classes
- SparkFirehoseListener → SparkListenerInterface
- Annotations
- @Override()
- final def onStageCompleted(stageCompleted: SparkListenerStageCompleted): Unit
Called when a stage completes successfully or fails, with information on the completed stage.
Called when a stage completes successfully or fails, with information on the completed stage.
- Definition Classes
- SparkFirehoseListener → SparkListenerInterface
- Annotations
- @Override()
- final def onStageExecutorMetrics(executorMetrics: SparkListenerStageExecutorMetrics): Unit
Called with the peak memory metrics for a given (executor, stage) combination.
Called with the peak memory metrics for a given (executor, stage) combination. Note that this is only present when reading from the event log (as in the history server), and is never called in a live application.
- Definition Classes
- SparkFirehoseListener → SparkListenerInterface
- Annotations
- @Override()
- final def onStageSubmitted(stageSubmitted: SparkListenerStageSubmitted): Unit
Called when a stage is submitted
Called when a stage is submitted
- Definition Classes
- SparkFirehoseListener → SparkListenerInterface
- Annotations
- @Override()
- final def onTaskEnd(taskEnd: SparkListenerTaskEnd): Unit
Called when a task ends
Called when a task ends
- Definition Classes
- SparkFirehoseListener → SparkListenerInterface
- Annotations
- @Override()
- final def onTaskGettingResult(taskGettingResult: SparkListenerTaskGettingResult): Unit
Called when a task begins remotely fetching its result (will not be called for tasks that do not need to fetch the result remotely).
Called when a task begins remotely fetching its result (will not be called for tasks that do not need to fetch the result remotely).
- Definition Classes
- SparkFirehoseListener → SparkListenerInterface
- Annotations
- @Override()
- final def onTaskStart(taskStart: SparkListenerTaskStart): Unit
Called when a task starts
Called when a task starts
- Definition Classes
- SparkFirehoseListener → SparkListenerInterface
- Annotations
- @Override()
- final def onUnpersistRDD(unpersistRDD: SparkListenerUnpersistRDD): Unit
Called when an RDD is manually unpersisted by the application
Called when an RDD is manually unpersisted by the application
- Definition Classes
- SparkFirehoseListener → SparkListenerInterface
- Annotations
- @Override()
- def onUnschedulableTaskSetAdded(unschedulableTaskSetAdded: SparkListenerUnschedulableTaskSetAdded): Unit
Called when a taskset becomes unschedulable due to exludeOnFailure and dynamic allocation is enabled.
Called when a taskset becomes unschedulable due to exludeOnFailure and dynamic allocation is enabled.
- Definition Classes
- SparkFirehoseListener → SparkListenerInterface
- Annotations
- @Override()
- def onUnschedulableTaskSetRemoved(unschedulableTaskSetRemoved: SparkListenerUnschedulableTaskSetRemoved): Unit
Called when an unschedulable taskset becomes schedulable and dynamic allocation is enabled.
Called when an unschedulable taskset becomes schedulable and dynamic allocation is enabled.
- Definition Classes
- SparkFirehoseListener → SparkListenerInterface
- Annotations
- @Override()
- final def synchronized[T0](arg0: => T0): T0
- Definition Classes
- AnyRef
- def toString(): String
- Definition Classes
- AnyRef → Any
- final def wait(arg0: Long, arg1: Int): Unit
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.InterruptedException])
- final def wait(arg0: Long): Unit
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.InterruptedException]) @native()
- final def wait(): Unit
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.InterruptedException])
Deprecated Value Members
- def finalize(): Unit
- Attributes
- protected[lang]
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.Throwable]) @Deprecated
- Deprecated
(Since version 9)