case class Aggregator[K, V, C](createCombiner: (V) ⇒ C, mergeValue: (C, V) ⇒ C, mergeCombiners: (C, C) ⇒ C) extends Product with Serializable :: DeveloperApi :: A set of functions used to aggregate data.
case class ExceptionFailure(className: String, description: String, stackTrace: Array[StackTraceElement], fullStackTrace: String, exceptionWrapper: Option[ThrowableSerializationWrapper], accumUpdates: Seq[AccumulableInfo] = Seq.empty, accums: Seq[AccumulatorV2[_, _]] = Nil, metricPeaks: Seq[Long] = Seq.empty) extends TaskFailedReason with Product with Serializable :: DeveloperApi :: Task failed due to a runtime exception.
case class ExecutorLostFailure(execId: String, exitCausedByApp: Boolean = true, reason: Option[String]) extends TaskFailedReason with Product with Serializable :: DeveloperApi :: The task failed because the executor that it was running on was lost.
case class FetchFailed(bmAddress: BlockManagerId, shuffleId: Int, mapId: Long, mapIndex: Int, reduceId: Int, message: String) extends TaskFailedReason with Product with Serializable :: DeveloperApi :: Task failed to fetch shuffle data from a remote node.
trait FutureAction[T] extends Future[T] A future for the result of an action to support cancellation.
class InterruptibleIterator[+T] extends Iterator[T] :: DeveloperApi :: An iterator that wraps around an existing iterator to provide task killing functionality.
trait [JobSubmitter](JobSubmitter.html "Handle via which a "run" function passed to a ComplexFutureAction can submit jobs for execution.") extends AnyRef Handle via which a "run" function passed to a ComplexFutureActioncan submit jobs for execution.
abstract class NarrowDependency[T] extends Dependency[T] :: DeveloperApi :: Base class for dependencies where each partition of the child RDD depends on a small number of partitions of the parent RDD.
class OneToOneDependency[T] extends NarrowDependency[T] :: DeveloperApi :: Represents a one-to-one dependency between partitions of the parent and child RDDs.
trait Partition extends Serializable An identifier for a partition in an RDD.
class RangeDependency[T] extends NarrowDependency[T] :: DeveloperApi :: Represents a one-to-one dependency between ranges of partitions in the parent and child RDDs.
class ShuffleDependency[K, V, C] extends Dependency[Product2[K, V]] with Logging :: DeveloperApi :: Represents a dependency on the output of a shuffle stage.
class SparkConf extends Cloneable with Logging with Serializable Configuration for a Spark application.
class SparkContext extends Logging Main entry point for Spark functionality.
class SparkEnv extends Logging :: DeveloperApi :: Holds all the runtime environment objects for a running Spark instance (either master or worker), including the serializer, RpcEnv, block manager, map output tracker, etc.
case class TaskCommitDenied(jobID: Int, partitionID: Int, attemptNumber: Int) extends TaskFailedReason with Product with Serializable :: DeveloperApi :: Task requested the driver to commit, but was denied.
abstract class TaskContext extends Serializable Contextual information about a task which can be read or mutated during execution.
sealed trait TaskEndReason extends AnyRef :: DeveloperApi :: Various possible reasons why a task ended.
class TaskKilledException extends RuntimeException :: DeveloperApi :: Exception thrown when a task is explicitly killed (i.e., task failure is expected).