public class PythonOperatorChainingOptimizer extends Object
An operator could be chained to it's predecessor if all of the following conditions are met:
The properties of the generated chained operator are as following:
Constructor and Description |
---|
PythonOperatorChainingOptimizer() |
Modifier and Type | Method and Description |
---|---|
static void |
apply(org.apache.flink.streaming.api.environment.StreamExecutionEnvironment env)
Perform chaining optimization.
|
static org.apache.flink.api.dag.Transformation<?> |
apply(org.apache.flink.streaming.api.environment.StreamExecutionEnvironment env,
org.apache.flink.api.dag.Transformation<?> transformation)
Perform chaining optimization.
|
static List<org.apache.flink.api.dag.Transformation<?>> |
optimize(List<org.apache.flink.api.dag.Transformation<?>> transformations)
Perform chaining optimization.
|
static org.apache.flink.api.java.tuple.Tuple2<List<org.apache.flink.api.dag.Transformation<?>>,org.apache.flink.api.dag.Transformation<?>> |
optimize(List<org.apache.flink.api.dag.Transformation<?>> transformations,
org.apache.flink.api.dag.Transformation<?> targetTransformation)
Perform chaining optimization.
|
public static void apply(org.apache.flink.streaming.api.environment.StreamExecutionEnvironment env) throws Exception
Exception
public static org.apache.flink.api.dag.Transformation<?> apply(org.apache.flink.streaming.api.environment.StreamExecutionEnvironment env, org.apache.flink.api.dag.Transformation<?> transformation) throws Exception
Exception
public static List<org.apache.flink.api.dag.Transformation<?>> optimize(List<org.apache.flink.api.dag.Transformation<?>> transformations)
public static org.apache.flink.api.java.tuple.Tuple2<List<org.apache.flink.api.dag.Transformation<?>>,org.apache.flink.api.dag.Transformation<?>> optimize(List<org.apache.flink.api.dag.Transformation<?>> transformations, org.apache.flink.api.dag.Transformation<?> targetTransformation)
Copyright © 2014–2022 The Apache Software Foundation. All rights reserved.