Modifier and Type | Method and Description |
---|---|
void |
NetworkSequenceViewReader.notifySubpartitionsCreated(ResultPartition partition,
ResultSubpartitionIndexSet subpartitionIndexSet)
When the
ResultPartitionManager registers ResultPartition , it will get the
PartitionRequestListener via given ResultPartitionID , 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 a
PartitionRequestListener for given ResultPartitionID in ResultPartitionManager and notify the listener when the upstream task registers its
partition. |
Modifier and Type | Method and Description |
---|---|
ResultSubpartitionView |
ResultPartitionWriter.createSubpartitionView(ResultSubpartitionIndexSet indexSet,
BufferAvailabilityListener availabilityListener)
Returns a reader for the subpartition with the given index range.
|
Modifier and Type | Method and Description |
---|---|
void |
NettyPartitionRequestClient.requestSubpartition(ResultPartitionID partitionId,
ResultSubpartitionIndexSet subpartitionIndexSet,
RemoteInputChannel inputChannel,
int delayMs)
Requests a remote intermediate result partition queue.
|
Constructor and Description |
---|
NettyPartitionRequestListener(ResultPartitionProvider resultPartitionProvider,
NetworkSequenceViewReader reader,
ResultSubpartitionIndexSet subpartitionIndexSet,
ResultPartitionID resultPartitionId) |
NettyPartitionRequestListener(ResultPartitionProvider resultPartitionProvider,
NetworkSequenceViewReader reader,
ResultSubpartitionIndexSet subpartitionIndexSet,
ResultPartitionID resultPartitionId,
long createTimestamp) |
Modifier and Type | Method and Description |
---|---|
static ResultSubpartitionIndexSet |
ResultSubpartitionIndexSet.fromByteBuf(org.apache.flink.shaded.netty4.io.netty.buffer.ByteBuf source) |
Modifier and Type | Method and Description |
---|---|
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.
|
ResultSubpartitionView |
ResultPartition.createSubpartitionView(ResultSubpartitionIndexSet indexSet,
BufferAvailabilityListener availabilityListener) |
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) |
Modifier and Type | Field and Description |
---|---|
protected ResultSubpartitionIndexSet |
InputChannel.consumedSubpartitionIndexSet
The indexes of the subpartitions consumed by this channel.
|
Modifier and Type | Method and Description |
---|---|
ResultSubpartitionIndexSet |
InputChannel.getConsumedSubpartitionIndexSet() |
Modifier and Type | Method and Description |
---|---|
protected InputChannel |
SingleInputGateFactory.createKnownInputChannel(SingleInputGate inputGate,
int index,
int buffersPerChannel,
NettyShuffleDescriptor inputChannelDescriptor,
ResultSubpartitionIndexSet subpartitionIndexSet,
SingleInputGateFactory.ChannelStatistics channelStatistics,
InputChannelMetrics metrics) |
Constructor and 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) |
Modifier and Type | Method and Description |
---|---|
ResultSubpartitionIndexSet |
TieredStorageConsumerSpec.getSubpartitionIds() |
Modifier and Type | Method and 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.
|
Constructor and Description |
---|
TieredStorageConsumerSpec(int gateIndex,
TieredStoragePartitionId tieredStoragePartitionId,
TieredStorageInputChannelId tieredStorageInputChannelId,
ResultSubpartitionIndexSet tieredStorageSubpartitionIds) |
Modifier and Type | Method and 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.
|
Modifier and Type | Method and Description |
---|---|
int |
DiskTierConsumerAgent.peekNextBufferSubpartitionId(TieredStoragePartitionId partitionId,
ResultSubpartitionIndexSet indexSet) |
Modifier and Type | Method and Description |
---|---|
int |
MemoryTierConsumerAgent.peekNextBufferSubpartitionId(TieredStoragePartitionId partitionId,
ResultSubpartitionIndexSet indexSet) |
Modifier and Type | Method and Description |
---|---|
int |
RemoteTierConsumerAgent.peekNextBufferSubpartitionId(TieredStoragePartitionId partitionId,
ResultSubpartitionIndexSet indexSet) |
Constructor and Description |
---|
StatusWatermarkValve(ResultSubpartitionIndexSet[] subpartitionIndexSets) |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.