Package org.apache.flink.runtime.io.network.partition
-
Interface Summary Interface Description BufferAvailabilityListener Listener interface implemented by consumers ofResultSubpartitionView
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 theChannelStateWriter
.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 subpartitions can be appended to aDataBuffer
and after theDataBuffer
is full or finished, the appended data can be copied from it in subpartition 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.PartitionRequestListener When the netty server receives a downstream task's partition request event and finds its upstream task doesn't register its partition yet, the netty server will construct aPartitionRequestListener
and notify the listener when the task deploys itself and registers its partition toResultPartitionManager
.PartitionTracker<K,M> Utility for tracking partitions.PartitionTrackerFactory Factory forJobMasterPartitionTracker
.PartitionTrackerFactory.TaskExecutorGatewayLookup Lookup function forTaskExecutorGateway
.ResourceManagerPartitionTracker Utility for tracking and releasing partitions on the ResourceManager.ResourceManagerPartitionTrackerFactory Factory forResourceManagerPartitionTracker
.ResultPartitionProvider Interface for creating result partitions.ResultSubpartitionView A view to consume aResultSubpartition
instance.SubpartitionSelector<T> SubpartitionSelector
helps to choose from multiple available subpartitions when their output buffers should union into one stream.TaskExecutorClusterPartitionReleaser Interface for releasing cluster partitions on a task executor.TaskExecutorPartitionTracker Utility for tracking partitions. -
Class Summary 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 onFileRegion
.BufferReaderWriterUtil Putting and getting of a sequence of buffers to/from a FileChannel or a ByteBuffer.BufferWithSubpartition Buffer and the corresponding subpartition index.BufferWritingResultPartition AResultPartition
which writes buffers directly toResultSubpartition
s.DataSetMetaInfo Container for meta-data of a data set.DeduplicatedQueue<T> A basic queue with duplicated elements ignored duringDeduplicatedQueue.add(Object)
.HashBasedDataBuffer * ADataBuffer
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 theResultSubpartitionView
.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 generatePartitionedFile
.PartitionRequestListenerManager Manages partition request listener with input channel id.PartitionTrackerEntry<K,M> Encapsulates all information that aPartitionTracker
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 DefaultResourceManagerPartitionTracker
implementation.ResultPartition A result partition for data produced by a single task.ResultPartitionFactory Factory forResultPartition
to use inNettyShuffleEnvironment
.ResultPartitionID Runtime identifier of a producedIntermediateResultPartition
.ResultPartitionManager The result partition manager keeps track of all currently produced/consumed partitions of a task manager.ResultSubpartition A single subpartition of aResultPartition
instance.ResultSubpartition.BufferAndBacklog A combination of aBuffer
and the backlog length indicating how many non-event buffers are available in the subpartition.ResultSubpartitionIndexSet A collection of subpartition indexes.ResultSubpartitionView.AvailabilityWithBacklog Availability of theResultSubpartitionView
and the backlog in the correspondingResultSubpartition
.RoundRobinSubpartitionSelector<T> ASubpartitionSelector
that selects all subpartitions in round-robin order.SortBasedDataBuffer When getting buffers, TheSortBasedDataBuffer
should recycle the read target buffer with the givenBufferRecycler
.SortBuffer ADataBuffer
implementation which sorts all appended records only by subpartition index.SortMergeResultPartition SortMergeResultPartition
appends records and events toDataBuffer
and after theDataBuffer
is full, all data in theDataBuffer
will be copied and spilled to aPartitionedFile
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.UnionResultSubpartitionView A wrapper to union the output from multipleResultSubpartitionView
s. -
Enum Summary Enum Description BoundedBlockingSubpartitionType The type of the BoundedBlockingSubpartition.ResultPartitionType Type of a result partition. -
Exception Summary 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.