org.apache.spark

executor

package executor

Executor components used with various cluster managers. See org.apache.spark.executor.Executor.

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

Type Members

  1. case class InputMetrics(readMethod: DataReadMethod.Value) extends Product with Serializable

    :: DeveloperApi :: Metrics about reading input data.

    :: DeveloperApi :: Metrics about reading input data.

    Annotations
    @DeveloperApi()
  2. case class OutputMetrics(writeMethod: DataWriteMethod.Value) extends Product with Serializable

    :: DeveloperApi :: Metrics about writing output data.

    :: DeveloperApi :: Metrics about writing output data.

    Annotations
    @DeveloperApi()
  3. class ShuffleReadMetrics extends Serializable

    :: DeveloperApi :: Metrics pertaining to shuffle data read in a given task.

    :: DeveloperApi :: Metrics pertaining to shuffle data read in a given task.

    Annotations
    @DeveloperApi()
  4. class ShuffleWriteMetrics extends Serializable

    :: DeveloperApi :: Metrics pertaining to shuffle data written in a given task.

    :: DeveloperApi :: Metrics pertaining to shuffle data written in a given task.

    Annotations
    @DeveloperApi()
  5. class TaskMetrics extends Serializable

    :: DeveloperApi :: Metrics tracked during the execution of a task.

    :: DeveloperApi :: Metrics tracked during the execution of a task.

    This class is used to house metrics both for in-progress and completed tasks. In executors, both the task thread and the heartbeat thread write to the TaskMetrics. The heartbeat thread reads it to send in-progress metrics, and the task thread reads it to send metrics along with the completed task.

    So, when adding new fields, take into consideration that the whole object can be serialized for shipping off at any time to consumers of the SparkListener interface.

    Annotations
    @DeveloperApi()

Value Members

  1. object DataReadMethod extends Enumeration with Serializable

    :: DeveloperApi :: Method by which input data was read.

    :: DeveloperApi :: Method by which input data was read. Network means that the data was read over the network from a remote block manager (which may have stored the data on-disk or in-memory).

    Annotations
    @DeveloperApi()
  2. object DataWriteMethod extends Enumeration with Serializable

    :: DeveloperApi :: Method by which output data was written.

    :: DeveloperApi :: Method by which output data was written.

    Annotations
    @DeveloperApi()
  3. object ExecutorEndpoint

Inherited from AnyRef

Inherited from Any

Ungrouped