package
scheduler
Type Members
-
-
class
JobLogger extends SparkListener with Logging
-
case class
RuntimePercentage(executorPct: Double, fetchPct: Option[Double], other: Double) extends Product with Serializable
-
-
-
case class
SparkListenerJobEnd(job: ActiveJob, jobResult: JobResult) extends SparkListenerEvents with Product with Serializable
-
case class
SparkListenerJobStart(job: ActiveJob, properties: Properties) extends SparkListenerEvents with Product with Serializable
-
case class
SparkListenerStageSubmitted(stage: StageInfo, properties: Properties) extends SparkListenerEvents with Product with Serializable
-
case class
SparkListenerTaskEnd(task: org.apache.spark.scheduler.Task[_], reason: TaskEndReason, taskInfo: TaskInfo, taskMetrics: TaskMetrics) extends SparkListenerEvents with Product with Serializable
-
case class
SparkListenerTaskGettingResult(task: org.apache.spark.scheduler.Task[_], taskInfo: TaskInfo) extends SparkListenerEvents with Product with Serializable
-
case class
SparkListenerTaskStart(task: org.apache.spark.scheduler.Task[_], taskInfo: TaskInfo) extends SparkListenerEvents with Product with Serializable
-
class
SplitInfo extends AnyRef
-
case class
StageCompleted(stage: StageInfo) extends SparkListenerEvents with Product with Serializable
-
class
StageInfo extends AnyRef
-
class
StatsReportListener extends SparkListener with Logging
Value Members
-
-
-
-
object
SplitInfo extends AnyRef
-
-