Uses of Class
org.apache.flink.runtime.executiongraph.IndexRange
-
-
Uses of IndexRange in org.apache.flink.runtime.deployment
Methods in org.apache.flink.runtime.deployment that return IndexRange Modifier and Type Method Description IndexRange
InputGateDeploymentDescriptor. getConsumedSubpartitionRange(int shuffleDescriptorIndex)
Methods in org.apache.flink.runtime.deployment that return types with arguments of type IndexRange Modifier and Type Method Description Collection<IndexRange>
InputGateDeploymentDescriptor. getConsumedShuffleDescriptorRanges()
Constructors in org.apache.flink.runtime.deployment with parameters of type IndexRange Constructor Description InputGateDeploymentDescriptor(IntermediateDataSetID consumedResultId, ResultPartitionType consumedPartitionType, IndexRange consumedSubpartitionIndexRange, int numberOfInputChannels, List<TaskDeploymentDescriptor.MaybeOffloaded<TaskDeploymentDescriptorFactory.ShuffleDescriptorGroup>> serializedInputChannels)
-
Uses of IndexRange in org.apache.flink.runtime.executiongraph
Methods in org.apache.flink.runtime.executiongraph that return types with arguments of type IndexRange Modifier and Type Method Description Map<IndexRange,IndexRange>
ExecutionVertexInputInfo. getConsumedSubpartitionGroups()
Get the subpartition groups this subtask should consume.Map<IndexRange,IndexRange>
ExecutionVertexInputInfo. getConsumedSubpartitionGroups()
Get the subpartition groups this subtask should consume.static List<IndexRange>
IndexRangeUtil. mergeIndexRanges(Collection<IndexRange> ranges)
Merges overlapping or consecutiveIndexRange
instances from the given collection.Method parameters in org.apache.flink.runtime.executiongraph with type arguments of type IndexRange Modifier and Type Method Description static List<IndexRange>
IndexRangeUtil. mergeIndexRanges(Collection<IndexRange> ranges)
Merges overlapping or consecutiveIndexRange
instances from the given collection.Constructors in org.apache.flink.runtime.executiongraph with parameters of type IndexRange Constructor Description ExecutionVertexInputInfo(int subtaskIndex, IndexRange partitionIndexRange, IndexRange subpartitionIndexRange)
Constructor parameters in org.apache.flink.runtime.executiongraph with type arguments of type IndexRange Constructor Description ExecutionVertexInputInfo(int subtaskIndex, Map<IndexRange,IndexRange> consumedSubpartitionGroups)
ExecutionVertexInputInfo(int subtaskIndex, Map<IndexRange,IndexRange> consumedSubpartitionGroups)
-
Uses of IndexRange in org.apache.flink.runtime.io.network.partition
Subclasses of IndexRange in org.apache.flink.runtime.io.network.partition Modifier and Type Class Description class
ResultSubpartitionIndexSet
A collection of subpartition indexes.Constructors in org.apache.flink.runtime.io.network.partition with parameters of type IndexRange Constructor Description ResultSubpartitionIndexSet(IndexRange indexRange)
-
Uses of IndexRange in org.apache.flink.runtime.scheduler.adaptivebatch
Methods in org.apache.flink.runtime.scheduler.adaptivebatch with parameters of type IndexRange Modifier and Type Method Description long
AllToAllBlockingResultInfo. getNumBytesProduced(IndexRange partitionIndexRange, IndexRange subpartitionIndexRange)
long
BlockingInputInfo. getNumBytesProduced(IndexRange partitionIndexRange, IndexRange subpartitionIndexRange)
long
BlockingResultInfo. getNumBytesProduced(IndexRange partitionIndexRange, IndexRange subpartitionIndexRange)
Return the aggregated num of bytes according to the index range for partition and subpartition. -
Uses of IndexRange in org.apache.flink.runtime.scheduler.adaptivebatch.util
Methods in org.apache.flink.runtime.scheduler.adaptivebatch.util that return IndexRange Modifier and Type Method Description IndexRange
SubpartitionSlice. getPartitionRange(int numPartitions)
SubpartitionSlice is used to describe a group of inputs with the same type number which may have different numbers of partitions, so we need to use the specific partitions number to get the correct partition range.IndexRange
SubpartitionSlice. getSubpartitionRange()
Methods in org.apache.flink.runtime.scheduler.adaptivebatch.util that return types with arguments of type IndexRange Modifier and Type Method Description static Optional<List<IndexRange>>
VertexParallelismAndInputInfosDeciderUtils. adjustToClosestLegalParallelism(long currentDataVolumeLimit, int currentParallelism, int minParallelism, int maxParallelism, long minLimit, long maxLimit, Function<Long,Integer> parallelismComputer, Function<Long,List<IndexRange>> subpartitionRangesComputer)
Adjust the parallelism to the closest legal parallelism and return the computed subpartition ranges.static Optional<List<IndexRange>>
VertexParallelismAndInputInfosDeciderUtils. tryComputeSubpartitionSliceRange(int minParallelism, int maxParallelism, long maxDataVolumePerTask, Map<Integer,List<SubpartitionSlice>> subpartitionSlices)
Attempts to compute the subpartition slice ranges to ensure even distribution of data across downstream tasks.Methods in org.apache.flink.runtime.scheduler.adaptivebatch.util with parameters of type IndexRange Modifier and Type Method Description static SubpartitionSlice
SubpartitionSlice. createSubpartitionSlice(IndexRange partitionRange, IndexRange subpartitionRange, long dataBytes)
static List<SubpartitionSlice>
SubpartitionSlice. createSubpartitionSlicesByMultiPartitionRanges(List<IndexRange> partitionRanges, IndexRange subpartitionRange, Map<Integer,long[]> subpartitionBytesByPartition)
Method parameters in org.apache.flink.runtime.scheduler.adaptivebatch.util with type arguments of type IndexRange Modifier and Type Method Description static JobVertexInputInfo
VertexParallelismAndInputInfosDeciderUtils. createdJobVertexInputInfoForNonBroadcast(BlockingInputInfo inputInfo, List<IndexRange> subpartitionSliceRanges, List<SubpartitionSlice> subpartitionSlices)
static List<SubpartitionSlice>
SubpartitionSlice. createSubpartitionSlicesByMultiPartitionRanges(List<IndexRange> partitionRanges, IndexRange subpartitionRange, Map<Integer,long[]> subpartitionBytesByPartition)
-