Uses of Class
org.apache.flink.runtime.io.network.partition.ResultSubpartitionIndexSet
-
-
Uses of ResultSubpartitionIndexSet in org.apache.flink.runtime.io.network
Methods in org.apache.flink.runtime.io.network with parameters of type ResultSubpartitionIndexSet Modifier and Type Method Description void
NetworkSequenceViewReader. notifySubpartitionsCreated(ResultPartition partition, ResultSubpartitionIndexSet subpartitionIndexSet)
When theResultPartitionManager
registersResultPartition
, it will get thePartitionRequestListener
via givenResultPartitionID
, and create subpartition view reader for downstream task.void
PartitionRequestClient. requestSubpartition(ResultPartitionID partitionId, ResultSubpartitionIndexSet subpartitionIndexSet, RemoteInputChannel inputChannel, int delayMs)
Requests a range of remote sub partitions.void
NetworkSequenceViewReader. requestSubpartitionViewOrRegisterListener(ResultPartitionProvider partitionProvider, ResultPartitionID resultPartitionId, ResultSubpartitionIndexSet subpartitionIndexSet)
When the netty server receives the downstream task's partition request and the upstream task has registered its partition, it will process the partition request immediately, otherwise it will create aPartitionRequestListener
for givenResultPartitionID
inResultPartitionManager
and notify the listener when the upstream task registers its partition. -
Uses of ResultSubpartitionIndexSet in org.apache.flink.runtime.io.network.api.writer
Methods in org.apache.flink.runtime.io.network.api.writer with parameters of type ResultSubpartitionIndexSet Modifier and Type Method Description ResultSubpartitionView
ResultPartitionWriter. createSubpartitionView(ResultSubpartitionIndexSet indexSet, BufferAvailabilityListener availabilityListener)
Returns a reader for the subpartition with the given index range. -
Uses of ResultSubpartitionIndexSet in org.apache.flink.runtime.io.network.netty
Methods in org.apache.flink.runtime.io.network.netty with parameters of type ResultSubpartitionIndexSet Modifier and Type Method Description void
NettyPartitionRequestClient. requestSubpartition(ResultPartitionID partitionId, ResultSubpartitionIndexSet subpartitionIndexSet, RemoteInputChannel inputChannel, int delayMs)
Requests a remote intermediate result partition queue.Constructors in org.apache.flink.runtime.io.network.netty with parameters of type ResultSubpartitionIndexSet Constructor Description NettyPartitionRequestListener(ResultPartitionProvider resultPartitionProvider, NetworkSequenceViewReader reader, ResultSubpartitionIndexSet subpartitionIndexSet, ResultPartitionID resultPartitionId)
NettyPartitionRequestListener(ResultPartitionProvider resultPartitionProvider, NetworkSequenceViewReader reader, ResultSubpartitionIndexSet subpartitionIndexSet, ResultPartitionID resultPartitionId, long createTimestamp)
-
Uses of ResultSubpartitionIndexSet in org.apache.flink.runtime.io.network.partition
Methods in org.apache.flink.runtime.io.network.partition that return ResultSubpartitionIndexSet Modifier and Type Method Description static ResultSubpartitionIndexSet
ResultSubpartitionIndexSet. fromByteBuf(org.apache.flink.shaded.netty4.io.netty.buffer.ByteBuf source)
Methods in org.apache.flink.runtime.io.network.partition with parameters of type ResultSubpartitionIndexSet Modifier and Type Method Description ResultSubpartitionView
ResultPartition. createSubpartitionView(ResultSubpartitionIndexSet indexSet, BufferAvailabilityListener availabilityListener)
ResultSubpartitionView
ResultPartitionManager. createSubpartitionView(ResultPartitionID partitionId, ResultSubpartitionIndexSet subpartitionIndexSet, BufferAvailabilityListener availabilityListener)
ResultSubpartitionView
ResultPartitionProvider. createSubpartitionView(ResultPartitionID partitionId, ResultSubpartitionIndexSet indexSet, BufferAvailabilityListener availabilityListener)
Returns the requested intermediate result partition input view.Optional<ResultSubpartitionView>
ResultPartitionManager. createSubpartitionViewOrRegisterListener(ResultPartitionID partitionId, ResultSubpartitionIndexSet subpartitionIndexSet, BufferAvailabilityListener availabilityListener, PartitionRequestListener partitionRequestListener)
Optional<ResultSubpartitionView>
ResultPartitionProvider. createSubpartitionViewOrRegisterListener(ResultPartitionID partitionId, ResultSubpartitionIndexSet indexSet, BufferAvailabilityListener availabilityListener, PartitionRequestListener partitionRequestListener)
If the upstream task's partition has been registered, returns the result subpartition input view immediately, otherwise register the listener and return empty.static int
ResultSubpartitionIndexSet. getByteBufLength(ResultSubpartitionIndexSet indexSet)
-
Uses of ResultSubpartitionIndexSet in org.apache.flink.runtime.io.network.partition.consumer
Fields in org.apache.flink.runtime.io.network.partition.consumer declared as ResultSubpartitionIndexSet Modifier and Type Field Description protected ResultSubpartitionIndexSet
InputChannel. consumedSubpartitionIndexSet
The indexes of the subpartitions consumed by this channel.Methods in org.apache.flink.runtime.io.network.partition.consumer that return ResultSubpartitionIndexSet Modifier and Type Method Description ResultSubpartitionIndexSet
InputChannel. getConsumedSubpartitionIndexSet()
Methods in org.apache.flink.runtime.io.network.partition.consumer with parameters of type ResultSubpartitionIndexSet Modifier and Type Method Description protected InputChannel
SingleInputGateFactory. createKnownInputChannel(SingleInputGate inputGate, int index, int buffersPerChannel, NettyShuffleDescriptor inputChannelDescriptor, ResultSubpartitionIndexSet subpartitionIndexSet, SingleInputGateFactory.ChannelStatistics channelStatistics, InputChannelMetrics metrics)
Constructors in org.apache.flink.runtime.io.network.partition.consumer with parameters of type ResultSubpartitionIndexSet Constructor Description InputChannel(SingleInputGate inputGate, int channelIndex, ResultPartitionID partitionId, ResultSubpartitionIndexSet consumedSubpartitionIndexSet, int initialBackoff, int maxBackoff, Counter numBytesIn, Counter numBuffersIn)
LocalInputChannel(SingleInputGate inputGate, int channelIndex, ResultPartitionID partitionId, ResultSubpartitionIndexSet consumedSubpartitionIndexSet, ResultPartitionManager partitionManager, TaskEventPublisher taskEventPublisher, int initialBackoff, int maxBackoff, Counter numBytesIn, Counter numBuffersIn, ChannelStateWriter stateWriter)
RemoteInputChannel(SingleInputGate inputGate, int channelIndex, ResultPartitionID partitionId, ResultSubpartitionIndexSet consumedSubpartitionIndexSet, ConnectionID connectionId, ConnectionManager connectionManager, int initialBackOff, int maxBackoff, int partitionRequestListenerTimeout, int networkBuffersPerChannel, Counter numBytesIn, Counter numBuffersIn, ChannelStateWriter stateWriter)
-
Uses of ResultSubpartitionIndexSet in org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage
Methods in org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage that return ResultSubpartitionIndexSet Modifier and Type Method Description ResultSubpartitionIndexSet
TieredStorageConsumerSpec. getSubpartitionIds()
Methods in org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage with parameters of type ResultSubpartitionIndexSet Modifier and Type Method Description int
TieredStorageConsumerClient. peekNextBufferSubpartitionId(TieredStoragePartitionId partitionId, ResultSubpartitionIndexSet indexSet)
Returns the index of the subpartition where the next buffer locates, or -1 if there is no buffer available or the subpartition index does not belong to the specified indexSet.Constructors in org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage with parameters of type ResultSubpartitionIndexSet Constructor Description TieredStorageConsumerSpec(int gateIndex, TieredStoragePartitionId tieredStoragePartitionId, TieredStorageInputChannelId tieredStorageInputChannelId, ResultSubpartitionIndexSet tieredStorageSubpartitionIds)
-
Uses of ResultSubpartitionIndexSet in org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier
Methods in org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier with parameters of type ResultSubpartitionIndexSet Modifier and Type Method Description int
TierConsumerAgent. peekNextBufferSubpartitionId(TieredStoragePartitionId partitionId, ResultSubpartitionIndexSet indexSet)
Returns the index of the subpartition where the next buffer locates, or -1 if there is no buffer available or the subpartition index does not belong to the specified indexSet. -
Uses of ResultSubpartitionIndexSet in org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.disk
Methods in org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.disk with parameters of type ResultSubpartitionIndexSet Modifier and Type Method Description int
DiskTierConsumerAgent. peekNextBufferSubpartitionId(TieredStoragePartitionId partitionId, ResultSubpartitionIndexSet indexSet)
-
Uses of ResultSubpartitionIndexSet in org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.memory
Methods in org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.memory with parameters of type ResultSubpartitionIndexSet Modifier and Type Method Description int
MemoryTierConsumerAgent. peekNextBufferSubpartitionId(TieredStoragePartitionId partitionId, ResultSubpartitionIndexSet indexSet)
-
Uses of ResultSubpartitionIndexSet in org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.remote
Methods in org.apache.flink.runtime.io.network.partition.hybrid.tiered.tier.remote with parameters of type ResultSubpartitionIndexSet Modifier and Type Method Description int
RemoteTierConsumerAgent. peekNextBufferSubpartitionId(TieredStoragePartitionId partitionId, ResultSubpartitionIndexSet indexSet)
-
Uses of ResultSubpartitionIndexSet in org.apache.flink.streaming.runtime.watermarkstatus
Constructors in org.apache.flink.streaming.runtime.watermarkstatus with parameters of type ResultSubpartitionIndexSet Constructor Description StatusWatermarkValve(ResultSubpartitionIndexSet[] subpartitionIndexSets)
-