Uses of Interface
org.apache.flink.runtime.shuffle.ShuffleDescriptor
-
-
Uses of ShuffleDescriptor in org.apache.flink.runtime.deployment
Methods in org.apache.flink.runtime.deployment that return ShuffleDescriptor Modifier and Type Method Description static ShuffleDescriptor
TaskDeploymentDescriptorFactory. getConsumedPartitionShuffleDescriptor(IntermediateResultPartition consumedPartition, TaskDeploymentDescriptorFactory.PartitionLocationConstraint partitionDeploymentConstraint, boolean nonFinishedHybridPartitionShouldBeUnknown)
ShuffleDescriptor
ResultPartitionDeploymentDescriptor. getShuffleDescriptor()
ShuffleDescriptor
TaskDeploymentDescriptorFactory.ShuffleDescriptorAndIndex. getShuffleDescriptor()
ShuffleDescriptor[]
InputGateDeploymentDescriptor. getShuffleDescriptors()
Retrieves allShuffleDescriptor
s associated of this input gate deployment descriptor.Constructors in org.apache.flink.runtime.deployment with parameters of type ShuffleDescriptor Constructor Description ResultPartitionDeploymentDescriptor(PartitionDescriptor partitionDescriptor, ShuffleDescriptor shuffleDescriptor, int maxParallelism)
ShuffleDescriptorAndIndex(ShuffleDescriptor shuffleDescriptor, int index)
-
Uses of ShuffleDescriptor in org.apache.flink.runtime.executiongraph
Methods in org.apache.flink.runtime.executiongraph that return ShuffleDescriptor Modifier and Type Method Description ShuffleDescriptor
PartitionInfo. getShuffleDescriptor()
Methods in org.apache.flink.runtime.executiongraph that return types with arguments of type ShuffleDescriptor Modifier and Type Method Description List<ShuffleDescriptor>
DefaultExecutionGraph. getClusterPartitionShuffleDescriptors(IntermediateDataSetID intermediateDataSetID)
List<ShuffleDescriptor>
InternalExecutionGraphAccessor. getClusterPartitionShuffleDescriptors(IntermediateDataSetID intermediateResultPartition)
Get the shuffle descriptors of the cluster partitions ordered by partition number.ShuffleMaster<? extends ShuffleDescriptor>
InternalExecutionGraphAccessor. getShuffleMaster()
Methods in org.apache.flink.runtime.executiongraph with parameters of type ShuffleDescriptor Modifier and Type Method Description static ResultPartitionDeploymentDescriptor
Execution. createResultPartitionDeploymentDescriptor(IntermediateResultPartition partition, ShuffleDescriptor shuffleDescriptor)
Constructors in org.apache.flink.runtime.executiongraph with parameters of type ShuffleDescriptor Constructor Description PartitionInfo(IntermediateDataSetID intermediateResultPartitionID, ShuffleDescriptor shuffleDescriptor)
-
Uses of ShuffleDescriptor in org.apache.flink.runtime.io.network.partition
Methods in org.apache.flink.runtime.io.network.partition that return ShuffleDescriptor Modifier and Type Method Description ShuffleDescriptor
TaskExecutorPartitionInfo. getShuffleDescriptor()
Methods in org.apache.flink.runtime.io.network.partition that return types with arguments of type ShuffleDescriptor Modifier and Type Method Description List<ShuffleDescriptor>
JobMasterPartitionTracker. getClusterPartitionShuffleDescriptors(IntermediateDataSetID intermediateDataSetID)
Get the shuffle descriptors of the cluster partitions ordered by partition number.List<ShuffleDescriptor>
JobMasterPartitionTrackerImpl. getClusterPartitionShuffleDescriptors(IntermediateDataSetID intermediateDataSetID)
List<ShuffleDescriptor>
ResourceManagerPartitionTracker. getClusterPartitionShuffleDescriptors(IntermediateDataSetID dataSetID)
Returns all the shuffle descriptors of cluster partitions for the intermediate dataset.List<ShuffleDescriptor>
ResourceManagerPartitionTrackerImpl. getClusterPartitionShuffleDescriptors(IntermediateDataSetID dataSetID)
CompletableFuture<List<ShuffleDescriptor>>
ClusterPartitionManager. getClusterPartitionsShuffleDescriptors(IntermediateDataSetID intermediateDataSetID)
Get the shuffle descriptors of the cluster partitions ordered by partition number.Map<ResultPartitionID,ShuffleDescriptor>
DataSetMetaInfo. getShuffleDescriptors()
Methods in org.apache.flink.runtime.io.network.partition with parameters of type ShuffleDescriptor Modifier and Type Method Description ResultPartition
ResultPartitionFactory. create(String taskNameWithSubtaskAndId, int partitionIndex, ResultPartitionID id, ResultPartitionType type, int numberOfPartitions, int numberOfSubpartitions, int maxParallelism, boolean isBroadcast, ShuffleDescriptor shuffleDescriptor, org.apache.flink.util.function.SupplierWithException<BufferPool,IOException> bufferPoolFactory, boolean isNumberOfPartitionConsumerUndefined)
Method parameters in org.apache.flink.runtime.io.network.partition with type arguments of type ShuffleDescriptor Modifier and Type Method Description DataSetMetaInfo
DataSetMetaInfo. addShuffleDescriptors(Map<ResultPartitionID,ShuffleDescriptor> shuffleDescriptors)
Constructors in org.apache.flink.runtime.io.network.partition with parameters of type ShuffleDescriptor Constructor Description TaskExecutorPartitionInfo(ShuffleDescriptor shuffleDescriptor, IntermediateDataSetID intermediateDataSetId, int numberOfPartitions)
-
Uses of ShuffleDescriptor in org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle
Methods in org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle that return types with arguments of type ShuffleDescriptor Modifier and Type Method Description Optional<ShuffleDescriptor>
ShuffleDescriptorRetriever. getShuffleDescriptor(org.apache.flink.api.common.JobID jobID, ResultPartitionID resultPartitionID)
Get shuffle descriptor by JobID and ResultPartitionId.Map<ResultPartitionID,ShuffleDescriptor>
TieredInternalShuffleMasterSnapshot. getShuffleDescriptors()
Methods in org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle with parameters of type ShuffleDescriptor Modifier and Type Method Description void
TieredInternalShuffleMaster. releasePartition(ShuffleDescriptor shuffleDescriptor)
Constructor parameters in org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle with type arguments of type ShuffleDescriptor Constructor Description TieredInternalShuffleMasterSnapshot(Map<ResultPartitionID,ShuffleDescriptor> shuffleDescriptors, AllTieredShuffleMasterSnapshots allTierSnapshots)
-
Uses of ShuffleDescriptor in org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage
Methods in org.apache.flink.runtime.io.network.partition.hybrid.tiered.storage with parameters of type ShuffleDescriptor Modifier and Type Method Description void
TieredStorageMasterClient. releasePartition(ShuffleDescriptor shuffleDescriptor)
-
Uses of ShuffleDescriptor in org.apache.flink.runtime.resourcemanager
Methods in org.apache.flink.runtime.resourcemanager that return types with arguments of type ShuffleDescriptor Modifier and Type Method Description CompletableFuture<List<ShuffleDescriptor>>
ResourceManager. getClusterPartitionsShuffleDescriptors(IntermediateDataSetID intermediateDataSetID)
-
Uses of ShuffleDescriptor in org.apache.flink.runtime.shuffle
Classes in org.apache.flink.runtime.shuffle with type parameters of type ShuffleDescriptor Modifier and Type Interface Description interface
ShuffleMaster<T extends ShuffleDescriptor>
Intermediate result partition registry to use inJobMaster
.interface
ShuffleServiceFactory<SD extends ShuffleDescriptor,P extends ResultPartitionWriter,G extends IndexedInputGate>
Interface for shuffle service factory implementations.Classes in org.apache.flink.runtime.shuffle that implement ShuffleDescriptor Modifier and Type Class Description class
NettyShuffleDescriptor
Default implementation ofShuffleDescriptor
forNettyShuffleMaster
.class
UnknownShuffleDescriptor
UnknownShuffleDescriptor
for which the producer has not been deployed yet.Methods in org.apache.flink.runtime.shuffle with type parameters of type ShuffleDescriptor Modifier and Type Method Description static <T,SD extends ShuffleDescriptor>
TShuffleUtils. applyWithShuffleTypeCheck(Class<SD> shuffleDescriptorClass, ShuffleDescriptor shuffleDescriptor, Function<UnknownShuffleDescriptor,T> functionOfUnknownDescriptor, Function<SD,T> functionOfKnownDescriptor)
Apply different functions to known and unknownShuffleDescriptor
s.Methods in org.apache.flink.runtime.shuffle that return ShuffleDescriptor Modifier and Type Method Description ShuffleDescriptor
DefaultPartitionWithMetrics. getPartition()
ShuffleDescriptor
PartitionWithMetrics. getPartition()
Methods in org.apache.flink.runtime.shuffle that return types with arguments of type ShuffleDescriptor Modifier and Type Method Description Optional<ShuffleDescriptor>
NettyShuffleMaster. getShuffleDescriptor(org.apache.flink.api.common.JobID jobID, ResultPartitionID resultPartitionID)
Methods in org.apache.flink.runtime.shuffle with parameters of type ShuffleDescriptor Modifier and Type Method Description static <T,SD extends ShuffleDescriptor>
TShuffleUtils. applyWithShuffleTypeCheck(Class<SD> shuffleDescriptorClass, ShuffleDescriptor shuffleDescriptor, Function<UnknownShuffleDescriptor,T> functionOfUnknownDescriptor, Function<SD,T> functionOfKnownDescriptor)
Apply different functions to known and unknownShuffleDescriptor
s.void
NettyShuffleMaster. releasePartitionExternally(ShuffleDescriptor shuffleDescriptor)
void
ShuffleMaster. releasePartitionExternally(ShuffleDescriptor shuffleDescriptor)
Release any external resources occupied by the given partition.Constructors in org.apache.flink.runtime.shuffle with parameters of type ShuffleDescriptor Constructor Description DefaultPartitionWithMetrics(ShuffleDescriptor shuffleDescriptor, ShuffleMetrics partitionMetrics)
-
Uses of ShuffleDescriptor in org.apache.flink.runtime.taskexecutor.partition
Methods in org.apache.flink.runtime.taskexecutor.partition that return types with arguments of type ShuffleDescriptor Modifier and Type Method Description Map<ResultPartitionID,ShuffleDescriptor>
ClusterPartitionReport.ClusterPartitionReportEntry. getShuffleDescriptors()
Constructor parameters in org.apache.flink.runtime.taskexecutor.partition with type arguments of type ShuffleDescriptor Constructor Description ClusterPartitionReportEntry(IntermediateDataSetID dataSetId, int numTotalPartitions, Map<ResultPartitionID,ShuffleDescriptor> shuffleDescriptors)
-