Class 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.
    • Constructor Detail

      • PostProcessAdaptiveJoinStrategy

        public PostProcessAdaptiveJoinStrategy()
    • 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)