Class AdaptiveBroadcastJoinOptimizationStrategy

  • All Implemented Interfaces:
    org.apache.flink.runtime.scheduler.adaptivebatch.StreamGraphOptimizationStrategy

    public class AdaptiveBroadcastJoinOptimizationStrategy
    extends BaseAdaptiveJoinOperatorOptimizationStrategy
    The stream graph optimization strategy of adaptive broadcast join.
    • Constructor Detail

      • AdaptiveBroadcastJoinOptimizationStrategy

        public AdaptiveBroadcastJoinOptimizationStrategy()
    • Method Detail

      • initialize

        public void initialize​(org.apache.flink.streaming.api.graph.StreamGraphContext context)
      • 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)