ArrayValues |
|
BlockId |
:: DeveloperApi ::
Identifies a particular Block of data, usually associated with a single file.
|
BlockInfo |
|
BlockManager |
Manager running on every node (driver and executors) which provides interfaces for putting and
retrieving blocks both locally and remotely into various stores (memory, disk, and off-heap).
|
BlockManagerId |
:: DeveloperApi ::
This class represent an unique identifier for a BlockManager.
|
BlockManagerInfo |
|
BlockManagerMaster |
|
BlockManagerMasterActor |
BlockManagerMasterActor is an actor on the master node to track statuses of
all slaves' block managers.
|
BlockManagerMessages |
|
BlockManagerMessages.BlockManagerHeartbeat |
|
BlockManagerMessages.BlockManagerHeartbeat$ |
|
BlockManagerMessages.ExpireDeadHosts$ |
|
BlockManagerMessages.GetActorSystemHostPortForExecutor |
|
BlockManagerMessages.GetActorSystemHostPortForExecutor$ |
|
BlockManagerMessages.GetBlockStatus |
|
BlockManagerMessages.GetBlockStatus$ |
|
BlockManagerMessages.GetLocations |
|
BlockManagerMessages.GetLocations$ |
|
BlockManagerMessages.GetLocationsMultipleBlockIds |
|
BlockManagerMessages.GetLocationsMultipleBlockIds$ |
|
BlockManagerMessages.GetMatchingBlockIds |
|
BlockManagerMessages.GetMatchingBlockIds$ |
|
BlockManagerMessages.GetMemoryStatus$ |
|
BlockManagerMessages.GetPeers |
|
BlockManagerMessages.GetPeers$ |
|
BlockManagerMessages.GetStorageStatus$ |
|
BlockManagerMessages.RegisterBlockManager |
|
BlockManagerMessages.RegisterBlockManager$ |
|
BlockManagerMessages.RemoveBlock |
|
BlockManagerMessages.RemoveBlock$ |
|
BlockManagerMessages.RemoveBroadcast |
|
BlockManagerMessages.RemoveBroadcast$ |
|
BlockManagerMessages.RemoveExecutor |
|
BlockManagerMessages.RemoveExecutor$ |
|
BlockManagerMessages.RemoveRdd |
|
BlockManagerMessages.RemoveRdd$ |
|
BlockManagerMessages.RemoveShuffle |
|
BlockManagerMessages.RemoveShuffle$ |
|
BlockManagerMessages.StopBlockManagerMaster$ |
|
BlockManagerMessages.UpdateBlockInfo |
|
BlockManagerMessages.UpdateBlockInfo$ |
|
BlockManagerSlaveActor |
An actor to take commands from the master to execute options.
|
BlockManagerSource |
|
BlockObjectWriter |
An interface for writing JVM objects to some underlying storage.
|
BlockResult |
|
BlockStatus |
|
BlockStore |
Abstract class to store blocks.
|
BroadcastBlockId |
|
ByteBufferValues |
|
DiskBlockManager |
Creates and maintains the logical mapping between logical blocks and physical on-disk
locations.
|
DiskBlockObjectWriter |
BlockObjectWriter which writes directly to a file on disk.
|
DiskStore |
Stores BlockManager blocks on disk.
|
FileSegment |
References a particular segment of a file (potentially the entire file),
based off an offset and a length.
|
IteratorValues |
|
MemoryEntry |
|
MemoryStore |
Stores blocks in memory, either as Arrays of deserialized Java objects or as
serialized ByteBuffers.
|
PutResult |
Result of adding a block into a BlockStore.
|
RDDBlockId |
|
RDDInfo |
|
ResultWithDroppedBlocks |
|
ShuffleBlockFetcherIterator |
An iterator that fetches multiple blocks.
|
ShuffleBlockFetcherIterator.FailureFetchResult |
Result of a fetch from a remote block unsuccessfully.
|
ShuffleBlockFetcherIterator.FailureFetchResult$ |
|
ShuffleBlockFetcherIterator.FetchRequest |
A request to fetch blocks from a remote BlockManager.
|
ShuffleBlockFetcherIterator.FetchRequest$ |
|
ShuffleBlockFetcherIterator.SuccessFetchResult |
Result of a fetch from a remote block successfully.
|
ShuffleBlockFetcherIterator.SuccessFetchResult$ |
|
ShuffleBlockId |
|
ShuffleDataBlockId |
|
ShuffleIndexBlockId |
|
StorageLevel |
:: DeveloperApi ::
Flags for controlling the storage of an RDD.
|
StorageStatus |
:: DeveloperApi ::
Storage information for each BlockManager.
|
StorageStatusListener |
:: DeveloperApi ::
A SparkListener that maintains executor storage status.
|
StorageUtils |
Helper methods for storage-related objects.
|
StreamBlockId |
|
TachyonBlockManager |
Creates and maintains the logical mapping between logical blocks and tachyon fs locations.
|
TachyonFileSegment |
References a particular segment of a file (potentially the entire file), based off an offset and
a length.
|
TachyonStore |
Stores BlockManager blocks on Tachyon.
|
TaskResultBlockId |
|
TempLocalBlockId |
Id associated with temporary local data managed as blocks.
|
TempShuffleBlockId |
Id associated with temporary shuffle data managed as blocks.
|
TestBlockId |
|