org.apache.spark

scheduler

package scheduler

Visibility
  1. Public
  2. All

Type Members

  1. class InputFormatInfo extends Logging

    Parses and holds information about inputFormat (and files) specified as a parameter.

  2. class JobLogger extends SparkListener with Logging

  3. case class RuntimePercentage(executorPct: Double, fetchPct: Option[Double], other: Double) extends Product with Serializable

  4. trait SparkListener extends AnyRef

  5. sealed trait SparkListenerEvents extends AnyRef

  6. case class SparkListenerJobEnd(job: ActiveJob, jobResult: JobResult) extends SparkListenerEvents with Product with Serializable

  7. case class SparkListenerJobStart(job: ActiveJob, properties: Properties) extends SparkListenerEvents with Product with Serializable

  8. case class SparkListenerStageSubmitted(stage: Stage, taskSize: Int, properties: Properties) extends SparkListenerEvents with Product with Serializable

  9. case class SparkListenerTaskEnd(task: org.apache.spark.scheduler.Task[_], reason: TaskEndReason, taskInfo: TaskInfo, taskMetrics: TaskMetrics) extends SparkListenerEvents with Product with Serializable

  10. case class SparkListenerTaskStart(task: org.apache.spark.scheduler.Task[_], taskInfo: TaskInfo) extends SparkListenerEvents with Product with Serializable

  11. class SplitInfo extends AnyRef

  12. case class StageCompleted(stageInfo: StageInfo) extends SparkListenerEvents with Product with Serializable

  13. case class StageInfo(stage: Stage, taskInfos: Buffer[(TaskInfo, TaskMetrics)]) extends Product with Serializable

  14. class StatsReportListener extends SparkListener with Logging

    Simple SparkListener that logs a few summary statistics when each stage completes

Value Members

  1. object InputFormatInfo extends AnyRef

  2. object RuntimePercentage extends Serializable

  3. object SplitInfo extends AnyRef

  4. object StatsReportListener extends Logging

  5. package cluster