| BasicBlockReplicationPolicy | 
  | 
| BlockId | 
 :: DeveloperApi ::
 Identifies a particular Block of data, usually associated with a single file. 
 | 
| BlockInfoWrapper | 
  | 
| BlockManagerId | 
 :: DeveloperApi ::
 This class represent a unique identifier for a BlockManager. 
 | 
| BlockManagerMessages | 
  | 
| BlockManagerMessages.BlockLocationsAndStatus | 
 The response message of GetLocationsAndStatus request. 
 | 
| BlockManagerMessages.BlockLocationsAndStatus$ | 
  | 
| BlockManagerMessages.BlockManagerHeartbeat | 
  | 
| BlockManagerMessages.BlockManagerHeartbeat$ | 
  | 
| BlockManagerMessages.DecommissionBlockManager$ | 
  | 
| BlockManagerMessages.DecommissionBlockManagers | 
  | 
| BlockManagerMessages.DecommissionBlockManagers$ | 
  | 
| BlockManagerMessages.GetBlockStatus | 
  | 
| BlockManagerMessages.GetBlockStatus$ | 
  | 
| BlockManagerMessages.GetExecutorEndpointRef | 
  | 
| BlockManagerMessages.GetExecutorEndpointRef$ | 
  | 
| BlockManagerMessages.GetLocations | 
  | 
| BlockManagerMessages.GetLocations$ | 
  | 
| BlockManagerMessages.GetLocationsAndStatus | 
  | 
| BlockManagerMessages.GetLocationsAndStatus$ | 
  | 
| BlockManagerMessages.GetLocationsMultipleBlockIds | 
  | 
| BlockManagerMessages.GetLocationsMultipleBlockIds$ | 
  | 
| BlockManagerMessages.GetMatchingBlockIds | 
  | 
| BlockManagerMessages.GetMatchingBlockIds$ | 
  | 
| BlockManagerMessages.GetMemoryStatus$ | 
  | 
| BlockManagerMessages.GetPeers | 
  | 
| BlockManagerMessages.GetPeers$ | 
  | 
| BlockManagerMessages.GetRDDBlockVisibility | 
  | 
| BlockManagerMessages.GetRDDBlockVisibility$ | 
  | 
| BlockManagerMessages.GetReplicateInfoForRDDBlocks | 
  | 
| BlockManagerMessages.GetReplicateInfoForRDDBlocks$ | 
  | 
| BlockManagerMessages.GetShufflePushMergerLocations | 
  | 
| BlockManagerMessages.GetShufflePushMergerLocations$ | 
  | 
| BlockManagerMessages.GetStorageStatus$ | 
  | 
| BlockManagerMessages.IsExecutorAlive | 
  | 
| BlockManagerMessages.IsExecutorAlive$ | 
  | 
| BlockManagerMessages.MarkRDDBlockAsVisible | 
  | 
| BlockManagerMessages.MarkRDDBlockAsVisible$ | 
  | 
| 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.RemoveShufflePushMergerLocation | 
  | 
| BlockManagerMessages.RemoveShufflePushMergerLocation$ | 
  | 
| BlockManagerMessages.ReplicateBlock | 
  | 
| BlockManagerMessages.ReplicateBlock$ | 
  | 
| BlockManagerMessages.StopBlockManagerMaster$ | 
  | 
| BlockManagerMessages.TriggerHeapHistogram$ | 
 Driver to Executor message to get a heap histogram. 
 | 
| BlockManagerMessages.TriggerThreadDump$ | 
 Driver to Executor message to trigger a thread dump. 
 | 
| BlockManagerMessages.UpdateBlockInfo | 
  | 
| BlockManagerMessages.UpdateBlockInfo$ | 
  | 
| BlockManagerMessages.UpdateRDDBlockTaskInfo | 
  | 
| BlockManagerMessages.UpdateRDDBlockTaskInfo$ | 
  | 
| BlockManagerMessages.UpdateRDDBlockVisibility | 
  | 
| BlockManagerMessages.UpdateRDDBlockVisibility$ | 
  | 
| BlockReplicationUtils | 
  | 
| BlockStatus | 
  | 
| BlockUpdatedInfo | 
 :: DeveloperApi ::
 Stores information about a block status in a block manager. 
 | 
| BroadcastBlockId | 
  | 
| BufferReleasingInputStream | 
 Helper class that ensures a ManagedBuffer is released upon InputStream.close() and
 also detects stream corruption if streamCompressedOrEncrypted is true 
 | 
| CacheId | 
  | 
| CountingWritableChannel | 
  | 
| DefaultTopologyMapper | 
 A TopologyMapper that assumes all nodes are in the same rack 
 | 
| DiskBlockData | 
  | 
| FileBasedTopologyMapper | 
 A simple file based topology mapper. 
 | 
| PushBasedFetchHelper | 
 Helper class for ShuffleBlockFetcherIterator that encapsulates all the push-based
 functionality to fetch push-merged block meta and shuffle chunks. 
 | 
| RandomBlockReplicationPolicy | 
  | 
| RDDBlockId | 
  | 
| RDDInfo | 
  | 
| ReadableChannelFileRegion | 
  | 
| ShuffleBlockBatchId | 
  | 
| ShuffleBlockChunkId | 
  | 
| ShuffleBlockId | 
  | 
| ShuffleChecksumBlockId | 
  | 
| ShuffleDataBlockId | 
  | 
| ShuffleFetchCompletionListener | 
 A listener to be called at the completion of the ShuffleBlockFetcherIterator
 param:  data the ShuffleBlockFetcherIterator to process 
 | 
| ShuffleIndexBlockId | 
  | 
| ShuffleMergedBlockId | 
  | 
| ShuffleMergedDataBlockId | 
  | 
| ShuffleMergedIndexBlockId | 
  | 
| ShuffleMergedMetaBlockId | 
  | 
| ShufflePushBlockId | 
  | 
| StorageLevel | 
 :: DeveloperApi ::
 Flags for controlling the storage of an RDD. 
 | 
| StorageUtils | 
 Helper methods for storage-related objects. 
 | 
| StreamBlockId | 
  | 
| TaskResultBlockId | 
  | 
| TimeTrackingOutputStream | 
 Intercepts write calls and tracks total time spent writing in order to update shuffle write
 metrics. 
 | 
| TopologyMapper | 
 ::DeveloperApi::
 TopologyMapper provides topology information for a given host
 param:  conf SparkConf to get required properties, if needed 
 |