class SparkFirehoseListener extends SparkListenerInterface
- Alphabetic
- By Inheritance
- SparkFirehoseListener
- SparkListenerInterface
- AnyRef
- Any
- Hide All
- Show All
- Public
- All
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[java.lang]
- Definition Classes
- AnyRef
- Annotations
- @native() @throws( ... )
-
final
def
eq(arg0: AnyRef): Boolean
- Definition Classes
- AnyRef
-
def
equals(arg0: Any): Boolean
- Definition Classes
- AnyRef → Any
-
def
finalize(): Unit
- Attributes
- protected[java.lang]
- Definition Classes
- AnyRef
- Annotations
- @throws( classOf[java.lang.Throwable] )
-
final
def
getClass(): Class[_]
- Definition Classes
- AnyRef → Any
- Annotations
- @native()
-
def
hashCode(): Int
- Definition Classes
- AnyRef → Any
- Annotations
- @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
- @native()
-
final
def
notifyAll(): Unit
- Definition Classes
- AnyRef
- Annotations
- @native()
-
final
def
onApplicationEnd(applicationEnd: SparkListenerApplicationEnd): Unit
Called when the application ends
Called when the application ends
- Definition Classes
- SparkFirehoseListener → SparkListenerInterface
-
final
def
onApplicationStart(applicationStart: SparkListenerApplicationStart): Unit
Called when the application starts
Called when the application starts
- Definition Classes
- SparkFirehoseListener → SparkListenerInterface
-
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
-
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
-
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
-
final
def
onEnvironmentUpdate(environmentUpdate: SparkListenerEnvironmentUpdate): Unit
Called when environment properties have been updated
Called when environment properties have been updated
- Definition Classes
- SparkFirehoseListener → SparkListenerInterface
- 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
-
final
def
onExecutorBlacklisted(executorBlacklisted: SparkListenerExecutorBlacklisted): Unit
Called when the driver blacklists an executor for a Spark application.
Called when the driver blacklists an executor for a Spark application.
- Definition Classes
- SparkFirehoseListener → SparkListenerInterface
-
def
onExecutorBlacklistedForStage(executorBlacklistedForStage: SparkListenerExecutorBlacklistedForStage): Unit
Called when the driver blacklists an executor for a stage.
Called when the driver blacklists an executor for a stage.
- Definition Classes
- SparkFirehoseListener → SparkListenerInterface
-
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
-
final
def
onExecutorRemoved(executorRemoved: SparkListenerExecutorRemoved): Unit
Called when the driver removes an executor.
Called when the driver removes an executor.
- Definition Classes
- SparkFirehoseListener → SparkListenerInterface
-
final
def
onExecutorUnblacklisted(executorUnblacklisted: SparkListenerExecutorUnblacklisted): Unit
Called when the driver re-enables a previously blacklisted executor.
Called when the driver re-enables a previously blacklisted executor.
- Definition Classes
- SparkFirehoseListener → SparkListenerInterface
-
final
def
onJobEnd(jobEnd: SparkListenerJobEnd): Unit
Called when a job ends
Called when a job ends
- Definition Classes
- SparkFirehoseListener → SparkListenerInterface
-
final
def
onJobStart(jobStart: SparkListenerJobStart): Unit
Called when a job starts
Called when a job starts
- Definition Classes
- SparkFirehoseListener → SparkListenerInterface
-
final
def
onNodeBlacklisted(nodeBlacklisted: SparkListenerNodeBlacklisted): Unit
Called when the driver blacklists a node for a Spark application.
Called when the driver blacklists a node for a Spark application.
- Definition Classes
- SparkFirehoseListener → SparkListenerInterface
-
def
onNodeBlacklistedForStage(nodeBlacklistedForStage: SparkListenerNodeBlacklistedForStage): Unit
Called when the driver blacklists a node for a stage.
Called when the driver blacklists a node for a stage.
- Definition Classes
- SparkFirehoseListener → SparkListenerInterface
-
final
def
onNodeUnblacklisted(nodeUnblacklisted: SparkListenerNodeUnblacklisted): Unit
Called when the driver re-enables a previously blacklisted node.
Called when the driver re-enables a previously blacklisted node.
- Definition Classes
- SparkFirehoseListener → SparkListenerInterface
-
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
-
def
onSpeculativeTaskSubmitted(speculativeTask: SparkListenerSpeculativeTaskSubmitted): Unit
Called when a speculative task is submitted
Called when a speculative task is submitted
- Definition Classes
- SparkFirehoseListener → SparkListenerInterface
-
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
-
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
-
final
def
onStageSubmitted(stageSubmitted: SparkListenerStageSubmitted): Unit
Called when a stage is submitted
Called when a stage is submitted
- Definition Classes
- SparkFirehoseListener → SparkListenerInterface
-
final
def
onTaskEnd(taskEnd: SparkListenerTaskEnd): Unit
Called when a task ends
Called when a task ends
- Definition Classes
- SparkFirehoseListener → SparkListenerInterface
-
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
-
final
def
onTaskStart(taskStart: SparkListenerTaskStart): Unit
Called when a task starts
Called when a task starts
- Definition Classes
- SparkFirehoseListener → SparkListenerInterface
-
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
-
final
def
synchronized[T0](arg0: ⇒ T0): T0
- Definition Classes
- AnyRef
-
def
toString(): String
- Definition Classes
- AnyRef → Any
-
final
def
wait(): Unit
- Definition Classes
- AnyRef
- Annotations
- @throws( ... )
-
final
def
wait(arg0: Long, arg1: Int): Unit
- Definition Classes
- AnyRef
- Annotations
- @throws( ... )
-
final
def
wait(arg0: Long): Unit
- Definition Classes
- AnyRef
- Annotations
- @native() @throws( ... )