Class PostProcessAdaptiveJoinStrategy
- java.lang.Object
-
- org.apache.flink.table.runtime.strategy.BaseAdaptiveJoinOperatorOptimizationStrategy
-
- org.apache.flink.table.runtime.strategy.PostProcessAdaptiveJoinStrategy
-
- All Implemented Interfaces:
org.apache.flink.runtime.scheduler.adaptivebatch.StreamGraphOptimizationStrategy
public class PostProcessAdaptiveJoinStrategy extends BaseAdaptiveJoinOperatorOptimizationStrategy
The post-processing phase of adaptive join optimization, which must be placed at the end of all adaptive join optimization strategies. This is necessary because certain operations, like 'reorder inputs', can influence how adaptive broadcast join or skewed join determine the left and right sides.
-
-
Field Summary
-
Fields inherited from class org.apache.flink.table.runtime.strategy.BaseAdaptiveJoinOperatorOptimizationStrategy
LEFT_INPUT_TYPE_NUMBER, RIGHT_INPUT_TYPE_NUMBER
-
-
Constructor Summary
Constructors Constructor Description PostProcessAdaptiveJoinStrategy()
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description boolean
onOperatorsFinished(org.apache.flink.runtime.scheduler.adaptivebatch.OperatorsFinished operatorsFinished, org.apache.flink.streaming.api.graph.StreamGraphContext context)
protected void
tryOptimizeAdaptiveJoin(org.apache.flink.runtime.scheduler.adaptivebatch.OperatorsFinished operatorsFinished, org.apache.flink.streaming.api.graph.StreamGraphContext context, org.apache.flink.streaming.api.graph.util.ImmutableStreamNode adaptiveJoinNode, List<org.apache.flink.streaming.api.graph.util.ImmutableStreamEdge> upstreamStreamEdges, AdaptiveJoin adaptiveJoin)
-
Methods inherited from class org.apache.flink.table.runtime.strategy.BaseAdaptiveJoinOperatorOptimizationStrategy
visitDownstreamAdaptiveJoinNode
-
-
-
-
Method Detail
-
onOperatorsFinished
public boolean onOperatorsFinished(org.apache.flink.runtime.scheduler.adaptivebatch.OperatorsFinished operatorsFinished, org.apache.flink.streaming.api.graph.StreamGraphContext context)
-
tryOptimizeAdaptiveJoin
protected void tryOptimizeAdaptiveJoin(org.apache.flink.runtime.scheduler.adaptivebatch.OperatorsFinished operatorsFinished, org.apache.flink.streaming.api.graph.StreamGraphContext context, org.apache.flink.streaming.api.graph.util.ImmutableStreamNode adaptiveJoinNode, List<org.apache.flink.streaming.api.graph.util.ImmutableStreamEdge> upstreamStreamEdges, AdaptiveJoin adaptiveJoin)
-
-