org.apache.spark

storage

package storage

Visibility
  1. Public
  2. All

Type Members

  1. sealed abstract class BlockId extends AnyRef

    :: DeveloperApi :: Identifies a particular Block of data, usually associated with a single file.

  2. class BlockManagerId extends Externalizable

    :: DeveloperApi :: This class represent an unique identifier for a BlockManager.

  3. class BlockNotFoundException extends Exception

  4. case class BlockStatus(storageLevel: StorageLevel, memSize: Long, diskSize: Long, tachyonSize: Long) extends Product with Serializable

    Annotations
    @DeveloperApi()
  5. case class BroadcastBlockId(broadcastId: Long, field: String = "") extends BlockId with Product with Serializable

    Annotations
    @DeveloperApi()
  6. case class RDDBlockId(rddId: Int, splitIndex: Int) extends BlockId with Product with Serializable

    Annotations
    @DeveloperApi()
  7. class RDDInfo extends Ordered[RDDInfo]

    Annotations
    @DeveloperApi()
  8. case class ShuffleBlockId(shuffleId: Int, mapId: Int, reduceId: Int) extends BlockId with Product with Serializable

    Annotations
    @DeveloperApi()
  9. case class ShuffleDataBlockId(shuffleId: Int, mapId: Int, reduceId: Int) extends BlockId with Product with Serializable

    Annotations
    @DeveloperApi()
  10. case class ShuffleIndexBlockId(shuffleId: Int, mapId: Int, reduceId: Int) extends BlockId with Product with Serializable

    Annotations
    @DeveloperApi()
  11. class StorageLevel extends Externalizable

    :: DeveloperApi :: Flags for controlling the storage of an RDD.

  12. class StorageStatus extends AnyRef

    :: DeveloperApi :: Storage information for each BlockManager.

  13. class StorageStatusListener extends SparkListener

    :: DeveloperApi :: A SparkListener that maintains executor storage status.

  14. case class StreamBlockId(streamId: Int, uniqueId: Long) extends BlockId with Product with Serializable

    Annotations
    @DeveloperApi()
  15. case class TaskResultBlockId(taskId: Long) extends BlockId with Product with Serializable

    Annotations
    @DeveloperApi()

Value Members

  1. object BlockId

    Annotations
    @DeveloperApi()
  2. object BlockStatus extends Serializable

    Annotations
    @DeveloperApi()
  3. object StorageLevel extends Serializable

    Various org.apache.spark.storage.StorageLevel defined and utility functions for creating new storage levels.

Ungrouped