Interface | Description |
---|---|
BufferAvailabilityListener |
Listener interface implemented by consumers of
ResultSubpartitionView that want to be
notified of availability of further buffers. |
ChannelStateHolder |
Implemented by entities that hold any kind of channel state and need a reference to the
ChannelStateWriter . |
CheckpointedResultPartition |
Interface for partitions that are checkpointed, meaning they store data as part of unaligned
checkpoints.
|
ClusterPartitionManager |
Interface for components that manage cluster partitions.
|
DataBuffer |
Data of different channels can be appended to a
DataBuffer and after the DataBuffer is full or finished, the appended data can be copied from it in channel index order. |
JobMasterPartitionTracker |
Utility for tracking partitions and issuing release calls to task executors and shuffle masters.
|
PartitionProducerStateProvider |
Request execution state of partition producer, the response accepts state check callbacks.
|
PartitionProducerStateProvider.ResponseHandle |
Result of state query, accepts state check callbacks.
|
PartitionTracker<K,M> |
Utility for tracking partitions.
|
PartitionTrackerFactory |
Factory for
JobMasterPartitionTracker . |
PartitionTrackerFactory.TaskExecutorGatewayLookup |
Lookup function for
TaskExecutorGateway . |
ResourceManagerPartitionTracker |
Utility for tracking and releasing partitions on the ResourceManager.
|
ResourceManagerPartitionTrackerFactory |
Factory for
ResourceManagerPartitionTracker . |
ResultPartitionProvider |
Interface for creating result partitions.
|
ResultSubpartitionView |
A view to consume a
ResultSubpartition instance. |
TaskExecutorClusterPartitionReleaser |
Interface for releasing cluster partitions on a task executor.
|
TaskExecutorPartitionTracker |
Utility for tracking partitions.
|
Class | Description |
---|---|
AbstractPartitionTracker<K,M> |
Base partition tracker implementation, providing underlying data-structures for storing
partitions, their associated keys and meta-information.
|
BoundedBlockingResultPartition |
A output data result of an individual task (one partition of an intermediate result), produced
and communicated in a batch manner: The result must be produced completely before it can be
consumed.
|
BoundedBlockingSubpartitionDirectTransferReader |
The reader (read view) of a BoundedBlockingSubpartition based on
FileRegion . |
BufferReaderWriterUtil |
Putting and getting of a sequence of buffers to/from a FileChannel or a ByteBuffer.
|
BufferWithChannel |
Buffer and the corresponding channel index.
|
BufferWritingResultPartition |
A
ResultPartition which writes buffers directly to ResultSubpartition s. |
DataSetMetaInfo |
Container for meta-data of a data set.
|
HashBasedDataBuffer |
* A
DataBuffer implementation which sorts all appended records only by subpartition
index. |
JobMasterPartitionTrackerImpl |
Utility for tracking partitions and issuing release calls to task executors and shuffle masters.
|
NoOpResultSubpartitionView |
A dummy implementation of the
ResultSubpartitionView . |
PageSizeUtil |
Utility for accessing the system page size.
|
PartitionedFile |
PartitionedFile is the persistent file type of sort-merge based blocking shuffle. |
PartitionedFileWriter |
File writer which can write buffers and generate
PartitionedFile . |
PartitionTrackerEntry<K,M> |
Encapsulates all information that a
PartitionTracker keeps for a partition. |
PipelinedApproximateSubpartition |
A pipelined in-memory only subpartition, which allows to reconnect after failure.
|
PipelinedApproximateSubpartitionView |
View over a pipelined in-memory only subpartition allowing reconnecting.
|
PipelinedResultPartition |
A result output of a task, pipelined (streamed) to the receivers.
|
PipelinedSubpartition |
A pipelined in-memory only subpartition, which can be consumed once.
|
PipelinedSubpartitionView |
View over a pipelined in-memory only subpartition.
|
PrioritizedDeque<T> |
A deque-like data structure that supports prioritization of elements, such they will be polled
before any non-priority elements.
|
ResourceManagerPartitionTrackerImpl |
Default
ResourceManagerPartitionTracker implementation. |
ResultPartition |
A result partition for data produced by a single task.
|
ResultPartitionFactory |
Factory for
ResultPartition to use in NettyShuffleEnvironment . |
ResultPartitionID |
Runtime identifier of a produced
IntermediateResultPartition . |
ResultPartitionManager |
The result partition manager keeps track of all currently produced/consumed partitions of a task
manager.
|
ResultSubpartition |
A single subpartition of a
ResultPartition instance. |
ResultSubpartition.BufferAndBacklog |
A combination of a
Buffer and the backlog length indicating how many non-event
buffers are available in the subpartition. |
ResultSubpartitionView.AvailabilityWithBacklog |
Availability of the
ResultSubpartitionView and the backlog in the corresponding
ResultSubpartition . |
SortBasedDataBuffer |
When getting buffers, The
SortBasedDataBuffer should recycle the read target buffer with
the given BufferRecycler . |
SortBuffer |
A
DataBuffer implementation which sorts all appended records only by subpartition index. |
SortMergeResultPartition |
SortMergeResultPartition appends records and events to DataBuffer and after the
DataBuffer is full, all data in the DataBuffer will be copied and spilled to a
PartitionedFile in subpartition index order sequentially. |
TaskExecutorPartitionInfo |
Encapsulates meta-information the TaskExecutor requires to be kept for each partition.
|
TaskExecutorPartitionTrackerImpl |
Utility for tracking partitions and issuing release calls to task executors and shuffle masters.
|
Enum | Description |
---|---|
BoundedBlockingSubpartitionType |
The type of the BoundedBlockingSubpartition.
|
ResultPartitionType |
Type of a result partition.
|
Exception | Description |
---|---|
PartitionException |
Exception for covering all the scenarios of consuming partition failure which causes the consumer
task failed, and the job master would decide whether to restart the producer based on this
exception.
|
PartitionNotFoundException |
Exception for failed partition requests due to non-existing partitions.
|
ProducerFailedException |
Network-stack level Exception to notify remote receiver about a failed partition producer.
|
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.