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

    A logger class to record runtime information for jobs in Spark.

  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: StageInfo, 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 SparkListenerTaskGettingResult(task: org.apache.spark.scheduler.Task[_], taskInfo: TaskInfo) extends SparkListenerEvents with Product with Serializable

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

  12. class SplitInfo extends AnyRef

  13. case class StageCompleted(stage: StageInfo) extends SparkListenerEvents with Product with Serializable

  14. class StageInfo extends AnyRef

  15. 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 SchedulingMode extends Enumeration

    "FAIR" and "FIFO" determines which policy is used to order tasks amongst a Schedulable's sub-queues "NONE" is used when the a Schedulable has no sub-queues.

  4. object SplitInfo extends AnyRef

  5. object StatsReportListener extends Logging

  6. package cluster