Uses of Class
org.apache.flink.runtime.executiongraph.IntermediateResultPartition
-
Packages that use IntermediateResultPartition Package Description org.apache.flink.runtime.deployment org.apache.flink.runtime.executiongraph org.apache.flink.runtime.shuffle -
-
Uses of IntermediateResultPartition in org.apache.flink.runtime.deployment
Methods in org.apache.flink.runtime.deployment with parameters of type IntermediateResultPartition Modifier and Type Method Description static ShuffleDescriptor
TaskDeploymentDescriptorFactory. getConsumedPartitionShuffleDescriptor(IntermediateResultPartition consumedPartition, TaskDeploymentDescriptorFactory.PartitionLocationConstraint partitionDeploymentConstraint, boolean nonFinishedHybridPartitionShouldBeUnknown)
void
CachedShuffleDescriptors. markPartitionFinished(IntermediateResultPartition resultPartition)
-
Uses of IntermediateResultPartition in org.apache.flink.runtime.executiongraph
Methods in org.apache.flink.runtime.executiongraph that return IntermediateResultPartition Modifier and Type Method Description IntermediateResultPartition
IntermediateResult. getPartitionById(IntermediateResultPartitionID resultPartitionId)
Returns the partition with the given ID.IntermediateResultPartition[]
IntermediateResult. getPartitions()
IntermediateResultPartition
DefaultExecutionGraph. getResultPartitionOrThrow(IntermediateResultPartitionID id)
IntermediateResultPartition
ExecutionGraph. getResultPartitionOrThrow(IntermediateResultPartitionID id)
Gets the intermediate result partition by the given partition ID, or throw an exception if the partition is not found.IntermediateResultPartition
InternalExecutionGraphAccessor. getResultPartitionOrThrow(IntermediateResultPartitionID id)
Methods in org.apache.flink.runtime.executiongraph that return types with arguments of type IntermediateResultPartition Modifier and Type Method Description List<IntermediateResultPartition>
ExecutionVertex. finishPartitionsIfNeeded()
Mark partition finished if needed.Map<IntermediateResultPartitionID,IntermediateResultPartition>
ExecutionVertex. getProducedPartitions()
Methods in org.apache.flink.runtime.executiongraph with parameters of type IntermediateResultPartition Modifier and Type Method Description static ResultPartitionDeploymentDescriptor
Execution. createResultPartitionDeploymentDescriptor(IntermediateResultPartition partition, ShuffleDescriptor shuffleDescriptor)
void
IntermediateResult. markPartitionFinished(ConsumedPartitionGroup consumedPartitionGroup, IntermediateResultPartition resultPartition)
void
IntermediateResult. setPartition(int partitionNumber, IntermediateResultPartition partition)
-
Uses of IntermediateResultPartition in org.apache.flink.runtime.shuffle
Methods in org.apache.flink.runtime.shuffle with parameters of type IntermediateResultPartition Modifier and Type Method Description static PartitionDescriptor
PartitionDescriptor. from(IntermediateResultPartition partition)
-