org.apache.spark

scheduler

package scheduler

Spark's scheduling components. This includes the org.apache.spark.scheduler.DAGScheduler and lower level org.apache.spark.scheduler.TaskScheduler.

Linear Supertypes
AnyRef, Any
Ordering
  1. Alphabetic
  2. By inheritance
Inherited
  1. scheduler
  2. AnyRef
  3. Any
  1. Hide All
  2. Show all
Learn more about member selection
Visibility
  1. Public
  2. All

Type Members

  1. class AccumulableInfo extends AnyRef

    :: DeveloperApi :: Information about an org.apache.spark.Accumulable modified during a task or stage.

  2. class InputFormatInfo extends Logging

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

  3. sealed trait JobResult extends AnyRef

    :: DeveloperApi :: A result of a job in the DAGScheduler.

  4. trait SparkListener extends AnyRef

    :: DeveloperApi :: Interface for listening to events from the Spark scheduler.

  5. case class SparkListenerApplicationEnd(time: Long) extends SparkListenerEvent with Product with Serializable

    Annotations
    @DeveloperApi()
  6. case class SparkListenerApplicationStart(appName: String, appId: Option[String], time: Long, sparkUser: String, appAttemptId: Option[String], driverLogs: Option[Map[String, String]] = scala.None) extends SparkListenerEvent with Product with Serializable

    Annotations
    @DeveloperApi()
  7. case class SparkListenerBlockManagerAdded(time: Long, blockManagerId: BlockManagerId, maxMem: Long) extends SparkListenerEvent with Product with Serializable

    Annotations
    @DeveloperApi()
  8. case class SparkListenerBlockManagerRemoved(time: Long, blockManagerId: BlockManagerId) extends SparkListenerEvent with Product with Serializable

    Annotations
    @DeveloperApi()
  9. case class SparkListenerBlockUpdated(blockUpdatedInfo: BlockUpdatedInfo) extends SparkListenerEvent with Product with Serializable

    Annotations
    @DeveloperApi()
  10. case class SparkListenerEnvironmentUpdate(environmentDetails: Map[String, Seq[(String, String)]]) extends SparkListenerEvent with Product with Serializable

    Annotations
    @DeveloperApi()
  11. sealed trait SparkListenerEvent extends AnyRef

    Annotations
    @DeveloperApi()
  12. case class SparkListenerExecutorAdded(time: Long, executorId: String, executorInfo: ExecutorInfo) extends SparkListenerEvent with Product with Serializable

    Annotations
    @DeveloperApi()
  13. case class SparkListenerExecutorMetricsUpdate(execId: String, taskMetrics: Seq[(Long, Int, Int, TaskMetrics)]) extends SparkListenerEvent with Product with Serializable

    Periodic updates from executors.

  14. case class SparkListenerExecutorRemoved(time: Long, executorId: String, reason: String) extends SparkListenerEvent with Product with Serializable

    Annotations
    @DeveloperApi()
  15. case class SparkListenerJobEnd(jobId: Int, time: Long, jobResult: JobResult) extends SparkListenerEvent with Product with Serializable

    Annotations
    @DeveloperApi()
  16. case class SparkListenerJobStart(jobId: Int, time: Long, stageInfos: Seq[StageInfo], properties: Properties = null) extends SparkListenerEvent with Product with Serializable

    Annotations
    @DeveloperApi()
  17. case class SparkListenerStageCompleted(stageInfo: StageInfo) extends SparkListenerEvent with Product with Serializable

    Annotations
    @DeveloperApi()
  18. case class SparkListenerStageSubmitted(stageInfo: StageInfo, properties: Properties = null) extends SparkListenerEvent with Product with Serializable

    Annotations
    @DeveloperApi()
  19. case class SparkListenerTaskEnd(stageId: Int, stageAttemptId: Int, taskType: String, reason: TaskEndReason, taskInfo: TaskInfo, taskMetrics: TaskMetrics) extends SparkListenerEvent with Product with Serializable

    Annotations
    @DeveloperApi()
  20. case class SparkListenerTaskGettingResult(taskInfo: TaskInfo) extends SparkListenerEvent with Product with Serializable

    Annotations
    @DeveloperApi()
  21. case class SparkListenerTaskStart(stageId: Int, stageAttemptId: Int, taskInfo: TaskInfo) extends SparkListenerEvent with Product with Serializable

    Annotations
    @DeveloperApi()
  22. case class SparkListenerUnpersistRDD(rddId: Int) extends SparkListenerEvent with Product with Serializable

    Annotations
    @DeveloperApi()
  23. class SplitInfo extends AnyRef

    Annotations
    @DeveloperApi()
  24. class StageInfo extends AnyRef

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

  25. class StatsReportListener extends SparkListener with Logging

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

  26. class TaskInfo extends AnyRef

    :: DeveloperApi :: Information about a running task attempt inside a TaskSet.

  27. class JobLogger extends SparkListener with Logging

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

Value Members

  1. object AccumulableInfo

  2. object InputFormatInfo

  3. object JobSucceeded extends JobResult with Product with Serializable

    Annotations
    @DeveloperApi()
  4. 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.

  5. object SplitInfo

  6. object TaskLocality extends Enumeration

    Annotations
    @DeveloperApi()
  7. package cluster

Inherited from AnyRef

Inherited from Any

Ungrouped