Package | Description |
---|---|
org.apache.flink.runtime.deployment | |
org.apache.flink.runtime.shuffle |
Constructor and Description |
---|
ResultPartitionDeploymentDescriptor(PartitionDescriptor partitionDescriptor,
ShuffleDescriptor shuffleDescriptor,
int maxParallelism) |
Modifier and Type | Method and Description |
---|---|
static PartitionDescriptor |
PartitionDescriptor.from(IntermediateResultPartition partition) |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<NettyShuffleDescriptor> |
NettyShuffleMaster.registerPartitionWithProducer(JobID jobID,
PartitionDescriptor partitionDescriptor,
ProducerDescriptor producerDescriptor) |
CompletableFuture<T> |
ShuffleMaster.registerPartitionWithProducer(JobID jobID,
PartitionDescriptor partitionDescriptor,
ProducerDescriptor producerDescriptor)
Asynchronously register a partition and its producer with the shuffle service.
|
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.