Class VertexInputInfoComputationUtils
- java.lang.Object
-
- org.apache.flink.runtime.executiongraph.VertexInputInfoComputationUtils
-
public class VertexInputInfoComputationUtils extends Object
Util to computeJobVertexInputInfo
s for execution job vertex.
-
-
Method Summary
All Methods Static Methods Concrete Methods Modifier and Type Method Description static JobVertexInputInfo
computeVertexInputInfoForAllToAll(int sourceCount, int targetCount, Function<Integer,Integer> numOfSubpartitionsRetriever, boolean isDynamicGraph, boolean isBroadcast, boolean isSingleSubpartitionContainsAllData)
Compute theJobVertexInputInfo
for aDistributionPattern.ALL_TO_ALL
edge.static JobVertexInputInfo
computeVertexInputInfoForPointwise(int sourceCount, int targetCount, Function<Integer,Integer> numOfSubpartitionsRetriever, boolean isDynamicGraph)
Compute theJobVertexInputInfo
for aDistributionPattern.POINTWISE
edge.static Map<IntermediateDataSetID,JobVertexInputInfo>
computeVertexInputInfos(int parallelism, List<? extends IntermediateResultInfo> inputs, boolean isDynamicGraph)
static Map<IntermediateDataSetID,JobVertexInputInfo>
computeVertexInputInfos(ExecutionJobVertex ejv, Function<IntermediateDataSetID,IntermediateResult> intermediateResultRetriever)
-
-
-
Method Detail
-
computeVertexInputInfos
public static Map<IntermediateDataSetID,JobVertexInputInfo> computeVertexInputInfos(ExecutionJobVertex ejv, Function<IntermediateDataSetID,IntermediateResult> intermediateResultRetriever) throws JobException
- Throws:
JobException
-
computeVertexInputInfos
public static Map<IntermediateDataSetID,JobVertexInputInfo> computeVertexInputInfos(int parallelism, List<? extends IntermediateResultInfo> inputs, boolean isDynamicGraph)
-
computeVertexInputInfoForPointwise
public static JobVertexInputInfo computeVertexInputInfoForPointwise(int sourceCount, int targetCount, Function<Integer,Integer> numOfSubpartitionsRetriever, boolean isDynamicGraph)
Compute theJobVertexInputInfo
for aDistributionPattern.POINTWISE
edge. This computation algorithm will evenly distribute subpartitions to downstream subtasks according to the number of subpartitions. Different downstream subtasks consume roughly the same number of subpartitions.- Parameters:
sourceCount
- the parallelism of upstreamtargetCount
- the parallelism of downstreamnumOfSubpartitionsRetriever
- a retriever to get the number of subpartitionsisDynamicGraph
- whether is dynamic graph- Returns:
- the computed
JobVertexInputInfo
-
computeVertexInputInfoForAllToAll
public static JobVertexInputInfo computeVertexInputInfoForAllToAll(int sourceCount, int targetCount, Function<Integer,Integer> numOfSubpartitionsRetriever, boolean isDynamicGraph, boolean isBroadcast, boolean isSingleSubpartitionContainsAllData)
Compute theJobVertexInputInfo
for aDistributionPattern.ALL_TO_ALL
edge. This computation algorithm will evenly distribute subpartitions to downstream subtasks according to the number of subpartitions. Different downstream subtasks consume roughly the same number of subpartitions.- Parameters:
sourceCount
- the parallelism of upstreamtargetCount
- the parallelism of downstreamnumOfSubpartitionsRetriever
- a retriever to get the number of subpartitionsisDynamicGraph
- whether is dynamic graphisBroadcast
- whether the edge is broadcastisSingleSubpartitionContainsAllData
- whether single subpartition contains all data- Returns:
- the computed
JobVertexInputInfo
-
-