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. trait SparkListener extends AnyRef

    Interface for listening to events from the Spark scheduler.

  4. sealed trait SparkListenerEvents extends AnyRef

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

  6. case class SparkListenerJobStart(job: ActiveJob, stageIds: Array[Int], properties: Properties = null) extends SparkListenerEvents with Product with Serializable

  7. case class SparkListenerStageCompleted(stage: StageInfo) 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: Task[_], reason: TaskEndReason, taskInfo: TaskInfo, taskMetrics: TaskMetrics) extends SparkListenerEvents with Product with Serializable

  10. case class SparkListenerTaskGettingResult(task: Task[_], taskInfo: TaskInfo) extends SparkListenerEvents with Product with Serializable

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

  12. class SplitInfo extends AnyRef

  13. class StageInfo extends AnyRef

    Stores information about a stage to pass from the scheduler to SparkListeners.

  14. class StatsReportListener extends SparkListener with Logging

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

Value Members

  1. object InputFormatInfo

  2. 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.

  3. object SplitInfo

Ungrouped