Uses of Class
org.apache.flink.runtime.shuffle.NettyShuffleDescriptor
-
Packages that use NettyShuffleDescriptor Package Description org.apache.flink.runtime.io.network.partition.consumer org.apache.flink.runtime.shuffle -
-
Uses of NettyShuffleDescriptor in org.apache.flink.runtime.io.network.partition.consumer
Methods in org.apache.flink.runtime.io.network.partition.consumer with parameters of type NettyShuffleDescriptor Modifier and Type Method Description protected InputChannel
SingleInputGateFactory. createKnownInputChannel(SingleInputGate inputGate, int index, int buffersPerChannel, NettyShuffleDescriptor inputChannelDescriptor, ResultSubpartitionIndexSet subpartitionIndexSet, SingleInputGateFactory.ChannelStatistics channelStatistics, InputChannelMetrics metrics)
void
SingleInputGate. updateInputChannel(ResourceID localLocation, NettyShuffleDescriptor shuffleDescriptor)
-
Uses of NettyShuffleDescriptor in org.apache.flink.runtime.shuffle
Methods in org.apache.flink.runtime.shuffle that return types with arguments of type NettyShuffleDescriptor Modifier and Type Method Description CompletableFuture<NettyShuffleDescriptor>
NettyShuffleMaster. registerPartitionWithProducer(org.apache.flink.api.common.JobID jobID, PartitionDescriptor partitionDescriptor, ProducerDescriptor producerDescriptor)
-