Uses of Class
org.apache.flink.runtime.shuffle.PartitionDescriptor
-
Packages that use PartitionDescriptor Package Description org.apache.flink.runtime.deployment org.apache.flink.runtime.shuffle -
-
Uses of PartitionDescriptor in org.apache.flink.runtime.deployment
Constructors in org.apache.flink.runtime.deployment with parameters of type PartitionDescriptor Constructor Description ResultPartitionDeploymentDescriptor(PartitionDescriptor partitionDescriptor, ShuffleDescriptor shuffleDescriptor, int maxParallelism)
-
Uses of PartitionDescriptor in org.apache.flink.runtime.shuffle
Methods in org.apache.flink.runtime.shuffle that return PartitionDescriptor Modifier and Type Method Description static PartitionDescriptor
PartitionDescriptor. from(IntermediateResultPartition partition)
Methods in org.apache.flink.runtime.shuffle with parameters of type PartitionDescriptor Modifier and Type Method Description CompletableFuture<NettyShuffleDescriptor>
NettyShuffleMaster. registerPartitionWithProducer(org.apache.flink.api.common.JobID jobID, PartitionDescriptor partitionDescriptor, ProducerDescriptor producerDescriptor)
CompletableFuture<T>
ShuffleMaster. registerPartitionWithProducer(org.apache.flink.api.common.JobID jobID, PartitionDescriptor partitionDescriptor, ProducerDescriptor producerDescriptor)
Asynchronously register a partition and its producer with the shuffle service.
-