Modifier and Type | Method and Description |
---|---|
abstract List<Transformation<?>> |
Transformation.getInputs()
Returns the
transformations that are the immediate predecessors of the
current transformation in the transformation graph. |
List<Transformation<?>> |
Transformation.getTransitivePredecessors()
Returns all transitive predecessor
Transformation s of this Transformation . |
protected abstract List<Transformation<?>> |
Transformation.getTransitivePredecessorsInternal()
Returns all transitive predecessor
Transformation s of this Transformation . |
Modifier and Type | Method and Description |
---|---|
List<Transformation<?>> |
ExecutionEnvironmentImpl.getTransformations() |
Modifier and Type | Method and Description |
---|---|
void |
ExecutionEnvironmentImpl.addOperator(Transformation<?> transformation) |
Modifier and Type | Field and Description |
---|---|
protected Transformation<T> |
AbstractDataStream.transformation |
protected Transformation<T> |
ProcessConfigureHandle.transformation |
Modifier and Type | Method and Description |
---|---|
<X> Transformation<X> |
AbstractDataStream.getSideOutputTransform(OutputTag<X> outputTag) |
Transformation<T> |
AbstractDataStream.getTransformation()
This is only used for internal implementation.
|
Constructor and Description |
---|
AbstractDataStream(ExecutionEnvironmentImpl environment,
Transformation<T> transformation) |
BroadcastStreamImpl(ExecutionEnvironmentImpl environment,
Transformation<T> transformation) |
GlobalStreamImpl(ExecutionEnvironmentImpl environment,
Transformation<T> transformation) |
KeyedPartitionStreamImpl(AbstractDataStream<V> dataStream,
Transformation<V> partitionTransformation,
KeySelector<V,K> keySelector,
TypeInformation<K> keyType)
This can construct a keyed stream directly without partitionTransformation to avoid shuffle.
|
NonKeyedPartitionStreamImpl(ExecutionEnvironmentImpl environment,
Transformation<T> transformation) |
ProcessConfigureHandle(ExecutionEnvironmentImpl environment,
Transformation<T> transformation) |
Modifier and Type | Method and Description |
---|---|
static Transformation<?> |
PythonOperatorChainingOptimizer.apply(StreamExecutionEnvironment env,
Transformation<?> transformation)
Perform chaining optimization.
|
Modifier and Type | Method and Description |
---|---|
static List<Transformation<?>> |
PythonOperatorChainingOptimizer.optimize(List<Transformation<?>> transformations)
Perform chaining optimization.
|
static Tuple2<List<Transformation<?>>,Transformation<?>> |
PythonOperatorChainingOptimizer.optimize(List<Transformation<?>> transformations,
Transformation<?> targetTransformation)
Perform chaining optimization.
|
static Tuple2<List<Transformation<?>>,Transformation<?>> |
PythonOperatorChainingOptimizer.optimize(List<Transformation<?>> transformations,
Transformation<?> targetTransformation)
Perform chaining optimization.
|
Modifier and Type | Method and Description |
---|---|
static Transformation<?> |
PythonOperatorChainingOptimizer.apply(StreamExecutionEnvironment env,
Transformation<?> transformation)
Perform chaining optimization.
|
static Tuple2<List<Transformation<?>>,Transformation<?>> |
PythonOperatorChainingOptimizer.optimize(List<Transformation<?>> transformations,
Transformation<?> targetTransformation)
Perform chaining optimization.
|
Modifier and Type | Method and Description |
---|---|
static List<Transformation<?>> |
PythonOperatorChainingOptimizer.optimize(List<Transformation<?>> transformations)
Perform chaining optimization.
|
static Tuple2<List<Transformation<?>>,Transformation<?>> |
PythonOperatorChainingOptimizer.optimize(List<Transformation<?>> transformations,
Transformation<?> targetTransformation)
Perform chaining optimization.
|
Modifier and Type | Method and Description |
---|---|
static SingleOutputStreamOperator<?> |
PythonConfigUtil.createSingleOutputStreamOperator(StreamExecutionEnvironment env,
Transformation<?> transformation) |
static StreamOperatorFactory<?> |
PythonConfigUtil.getOperatorFactory(Transformation<?> transform) |
static boolean |
PythonConfigUtil.isPythonDataStreamOperator(Transformation<?> transform) |
Modifier and Type | Method and Description |
---|---|
static void |
PythonConfigUtil.setPartitionCustomOperatorNumPartitions(List<Transformation<?>> transformations) |
Modifier and Type | Field and Description |
---|---|
protected Transformation<T> |
DataStream.transformation |
Modifier and Type | Method and Description |
---|---|
Transformation<T> |
DataStream.getTransformation()
Returns the
Transformation that represents the operation that logically creates this
DataStream . |
Transformation<T> |
DataStreamSink.getTransformation()
Returns the transformation that contains the actual sink operator of this sink.
|
Transformation<T> |
BroadcastStream.getTransformation() |
Constructor and Description |
---|
CachedDataStream(StreamExecutionEnvironment environment,
Transformation<T> transformation)
Create a new
CachedDataStream in the given execution environment that wrap the given
physical transformation to indicates that the transformation should be cached. |
DataStream(StreamExecutionEnvironment environment,
Transformation<T> transformation)
Create a new
DataStream in the given execution environment with partitioning set to
forward by default. |
SingleOutputStreamOperator(StreamExecutionEnvironment environment,
Transformation<T> transformation) |
Modifier and Type | Field and Description |
---|---|
protected List<Transformation<?>> |
StreamExecutionEnvironment.transformations |
Modifier and Type | Method and Description |
---|---|
List<Transformation<?>> |
StreamExecutionEnvironment.getTransformations() |
Modifier and Type | Method and Description |
---|---|
void |
StreamExecutionEnvironment.addOperator(Transformation<?> transformation)
Adds an operator to the list of operators that should be executed when calling
StreamExecutionEnvironment.execute() . |
Modifier and Type | Method and Description |
---|---|
StreamGraph |
StreamExecutionEnvironment.generateStreamGraph(List<Transformation<?>> transformations)
Generates a
StreamGraph that consists of the given transformations and is configured with the configuration of this environment. |
Modifier and Type | Class and Description |
---|---|
class |
SimpleTransformationTranslator<OUT,T extends Transformation<OUT>>
A base class for all
TransformationTranslators who translate
Transformations that have a single operator in their runtime
implementation. |
interface |
TransformationTranslator<OUT,T extends Transformation<OUT>>
A
TransformationTranslator is responsible for translating a given Transformation
to its runtime implementation depending on the execution mode. |
Modifier and Type | Method and Description |
---|---|
Collection<Integer> |
TransformationTranslator.Context.getStreamNodeIds(Transformation<?> transformation)
Returns the ids of the nodes in the
StreamGraph corresponding to the provided
transformation. |
Collection<Integer> |
TransformationTranslator.Context.transform(Transformation<?> transformation)
Transforms the transformation and updates the current stream graph.
|
Constructor and Description |
---|
StreamGraphGenerator(List<Transformation<?>> transformations,
ExecutionConfig executionConfig,
CheckpointConfig checkpointConfig) |
StreamGraphGenerator(List<Transformation<?>> transformations,
ExecutionConfig executionConfig,
CheckpointConfig checkpointConfig,
Configuration configuration) |
Modifier and Type | Class and Description |
---|---|
class |
AbstractBroadcastStateTransformation<IN1,IN2,OUT>
Base class for Broadcast State transformations.
|
class |
AbstractMultipleInputTransformation<OUT>
Base class for transformations representing the application of a
MultipleInputStreamOperator to input Transformations . |
class |
BroadcastStateTransformation<IN1,IN2,OUT>
A non-keyed
AbstractBroadcastStateTransformation . |
class |
CacheTransformation<T>
When in batch mode, the
CacheTransformation represents the intermediate result of the
upper stream should be cached when it is computed at the first time. |
class |
CoFeedbackTransformation<F>
This represents a feedback point in a topology.
|
class |
DataStreamV2SinkTransformation<InputT,OutputT>
The
Transformation for DataStream V2 based sink. |
class |
FeedbackTransformation<T>
This represents a feedback point in a topology.
|
class |
KeyedBroadcastStateTransformation<KEY,IN1,IN2,OUT>
A keyed
AbstractBroadcastStateTransformation . |
class |
KeyedMultipleInputTransformation<OUT>
AbstractMultipleInputTransformation implementation for keyed streams. |
class |
LegacySinkTransformation<T>
This Transformation represents a stream Sink.
|
class |
LegacySourceTransformation<T>
This represents a Source.
|
class |
MultipleInputTransformation<OUT>
AbstractMultipleInputTransformation implementation for non-keyed streams. |
class |
OneInputTransformation<IN,OUT>
This Transformation represents the application of a
OneInputStreamOperator to one input Transformation . |
class |
PartitionTransformation<T>
This transformation represents a change of partitioning of the input elements.
|
class |
PhysicalTransformation<T>
A
Transformation that creates a physical operation. |
class |
ReduceTransformation<IN,K>
A
Transformation that describes a reduce operation on a KeyedStream . |
class |
SideOutputTransformation<T>
This transformation represents a selection of a side output of an upstream operation with a given
OutputTag . |
class |
SinkTransformation<InputT,OutputT>
A
Transformation for Sink . |
class |
SourceTransformation<OUT,SplitT extends SourceSplit,EnumChkT>
A
PhysicalTransformation for Source . |
class |
SourceTransformationWrapper<T>
This Transformation is a phantom transformation which is used to expose a default parallelism to
downstream.
|
class |
TimestampsAndWatermarksTransformation<IN>
|
class |
TwoInputTransformation<IN1,IN2,OUT>
This Transformation represents the application of a
TwoInputStreamOperator to two input
Transformations . |
class |
UnionTransformation<T>
This transformation represents a union of several input
Transformations . |
Modifier and Type | Field and Description |
---|---|
protected List<Transformation<?>> |
AbstractMultipleInputTransformation.inputs |
Modifier and Type | Method and Description |
---|---|
Transformation<IN2> |
AbstractBroadcastStateTransformation.getBroadcastInput() |
Transformation<T> |
SourceTransformationWrapper.getInput() |
Transformation<IN1> |
TwoInputTransformation.getInput1()
Returns the first input
Transformation of this TwoInputTransformation . |
Transformation<IN2> |
TwoInputTransformation.getInput2()
Returns the second input
Transformation of this TwoInputTransformation . |
Transformation<IN1> |
AbstractBroadcastStateTransformation.getRegularInput() |
Transformation<T> |
CacheTransformation.getTransformationToCache() |
Modifier and Type | Method and Description |
---|---|
List<Transformation<T>> |
FeedbackTransformation.getFeedbackEdges()
Returns the list of feedback
Transformations . |
List<Transformation<F>> |
CoFeedbackTransformation.getFeedbackEdges()
Returns the list of feedback
Transformations . |
List<Transformation<?>> |
DataStreamV2SinkTransformation.getInputs() |
List<Transformation<?>> |
SourceTransformationWrapper.getInputs() |
List<Transformation<?>> |
FeedbackTransformation.getInputs() |
List<Transformation<?>> |
LegacySinkTransformation.getInputs() |
List<Transformation<?>> |
OneInputTransformation.getInputs() |
List<Transformation<?>> |
PartitionTransformation.getInputs() |
List<Transformation<?>> |
UnionTransformation.getInputs() |
List<Transformation<?>> |
SourceTransformation.getInputs() |
List<Transformation<?>> |
CacheTransformation.getInputs() |
List<Transformation<?>> |
AbstractMultipleInputTransformation.getInputs() |
List<Transformation<?>> |
TwoInputTransformation.getInputs() |
List<Transformation<?>> |
CoFeedbackTransformation.getInputs() |
List<Transformation<?>> |
SideOutputTransformation.getInputs() |
List<Transformation<?>> |
SinkTransformation.getInputs() |
List<Transformation<?>> |
ReduceTransformation.getInputs() |
List<Transformation<?>> |
TimestampsAndWatermarksTransformation.getInputs() |
List<Transformation<?>> |
AbstractBroadcastStateTransformation.getInputs() |
List<Transformation<?>> |
LegacySourceTransformation.getInputs() |
protected List<Transformation<?>> |
DataStreamV2SinkTransformation.getTransitivePredecessorsInternal() |
protected List<Transformation<?>> |
SourceTransformationWrapper.getTransitivePredecessorsInternal() |
protected List<Transformation<?>> |
FeedbackTransformation.getTransitivePredecessorsInternal() |
protected List<Transformation<?>> |
LegacySinkTransformation.getTransitivePredecessorsInternal() |
protected List<Transformation<?>> |
OneInputTransformation.getTransitivePredecessorsInternal() |
protected List<Transformation<?>> |
PartitionTransformation.getTransitivePredecessorsInternal() |
protected List<Transformation<?>> |
UnionTransformation.getTransitivePredecessorsInternal() |
protected List<Transformation<?>> |
SourceTransformation.getTransitivePredecessorsInternal() |
protected List<Transformation<?>> |
CacheTransformation.getTransitivePredecessorsInternal() |
protected List<Transformation<?>> |
AbstractMultipleInputTransformation.getTransitivePredecessorsInternal() |
protected List<Transformation<?>> |
TwoInputTransformation.getTransitivePredecessorsInternal() |
protected List<Transformation<?>> |
CoFeedbackTransformation.getTransitivePredecessorsInternal() |
protected List<Transformation<?>> |
SideOutputTransformation.getTransitivePredecessorsInternal() |
protected List<Transformation<?>> |
SinkTransformation.getTransitivePredecessorsInternal() |
protected List<Transformation<?>> |
ReduceTransformation.getTransitivePredecessorsInternal() |
protected List<Transformation<?>> |
TimestampsAndWatermarksTransformation.getTransitivePredecessorsInternal() |
protected List<Transformation<?>> |
AbstractBroadcastStateTransformation.getTransitivePredecessorsInternal() |
protected List<Transformation<?>> |
LegacySourceTransformation.getTransitivePredecessorsInternal() |
Modifier and Type | Method and Description |
---|---|
void |
CoFeedbackTransformation.addFeedbackEdge(Transformation<F> transform)
Adds a feedback edge.
|
void |
FeedbackTransformation.addFeedbackEdge(Transformation<T> transform)
Adds a feedback edge.
|
MultipleInputTransformation<OUT> |
MultipleInputTransformation.addInput(Transformation<?> input) |
KeyedMultipleInputTransformation<OUT> |
KeyedMultipleInputTransformation.addInput(Transformation<?> input,
KeySelector<?,?> keySelector) |
Constructor and Description |
---|
AbstractBroadcastStateTransformation(String name,
Transformation<IN1> regularInput,
Transformation<IN2> broadcastInput,
List<MapStateDescriptor<?,?>> broadcastStateDescriptors,
TypeInformation<OUT> outTypeInfo,
int parallelism) |
AbstractBroadcastStateTransformation(String name,
Transformation<IN1> regularInput,
Transformation<IN2> broadcastInput,
List<MapStateDescriptor<?,?>> broadcastStateDescriptors,
TypeInformation<OUT> outTypeInfo,
int parallelism) |
AbstractBroadcastStateTransformation(String name,
Transformation<IN1> regularInput,
Transformation<IN2> broadcastInput,
List<MapStateDescriptor<?,?>> broadcastStateDescriptors,
TypeInformation<OUT> outTypeInfo,
int parallelism,
boolean parallelismConfigured) |
AbstractBroadcastStateTransformation(String name,
Transformation<IN1> regularInput,
Transformation<IN2> broadcastInput,
List<MapStateDescriptor<?,?>> broadcastStateDescriptors,
TypeInformation<OUT> outTypeInfo,
int parallelism,
boolean parallelismConfigured) |
BroadcastStateTransformation(String name,
Transformation<IN1> inputStream,
Transformation<IN2> broadcastStream,
BroadcastProcessFunction<IN1,IN2,OUT> userFunction,
List<MapStateDescriptor<?,?>> broadcastStateDescriptors,
TypeInformation<OUT> outTypeInfo,
int parallelism,
boolean parallelismConfigured) |
BroadcastStateTransformation(String name,
Transformation<IN1> inputStream,
Transformation<IN2> broadcastStream,
BroadcastProcessFunction<IN1,IN2,OUT> userFunction,
List<MapStateDescriptor<?,?>> broadcastStateDescriptors,
TypeInformation<OUT> outTypeInfo,
int parallelism,
boolean parallelismConfigured) |
CacheTransformation(Transformation<T> transformationToCache,
String name)
Creates a new
Transformation with the given name, output type and parallelism. |
FeedbackTransformation(Transformation<T> input,
Long waitTime)
Creates a new
FeedbackTransformation from the given input. |
KeyedBroadcastStateTransformation(String name,
Transformation<IN1> inputStream,
Transformation<IN2> broadcastStream,
KeyedBroadcastProcessFunction<KEY,IN1,IN2,OUT> userFunction,
List<MapStateDescriptor<?,?>> broadcastStateDescriptors,
TypeInformation<KEY> keyType,
KeySelector<IN1,KEY> keySelector,
TypeInformation<OUT> outTypeInfo,
int parallelism,
boolean parallelismConfigured) |
KeyedBroadcastStateTransformation(String name,
Transformation<IN1> inputStream,
Transformation<IN2> broadcastStream,
KeyedBroadcastProcessFunction<KEY,IN1,IN2,OUT> userFunction,
List<MapStateDescriptor<?,?>> broadcastStateDescriptors,
TypeInformation<KEY> keyType,
KeySelector<IN1,KEY> keySelector,
TypeInformation<OUT> outTypeInfo,
int parallelism,
boolean parallelismConfigured) |
LegacySinkTransformation(Transformation<T> input,
String name,
StreamOperatorFactory<Object> operatorFactory,
int parallelism) |
LegacySinkTransformation(Transformation<T> input,
String name,
StreamOperatorFactory<Object> operatorFactory,
int parallelism,
boolean parallelismConfigured) |
LegacySinkTransformation(Transformation<T> input,
String name,
StreamSink<T> operator,
int parallelism,
boolean parallelismConfigured)
Creates a new
LegacySinkTransformation from the given input Transformation . |
OneInputTransformation(Transformation<IN> input,
String name,
OneInputStreamOperator<IN,OUT> operator,
TypeInformation<OUT> outputType,
int parallelism)
Creates a new
OneInputTransformation from the given input and operator. |
OneInputTransformation(Transformation<IN> input,
String name,
OneInputStreamOperator<IN,OUT> operator,
TypeInformation<OUT> outputType,
int parallelism,
boolean parallelismConfigured) |
OneInputTransformation(Transformation<IN> input,
String name,
StreamOperatorFactory<OUT> operatorFactory,
TypeInformation<OUT> outputType,
int parallelism) |
OneInputTransformation(Transformation<IN> input,
String name,
StreamOperatorFactory<OUT> operatorFactory,
TypeInformation<OUT> outputType,
int parallelism,
boolean parallelismConfigured)
Creates a new
LegacySinkTransformation from the given input Transformation . |
PartitionTransformation(Transformation<T> input,
StreamPartitioner<T> partitioner)
Creates a new
PartitionTransformation from the given input and StreamPartitioner . |
PartitionTransformation(Transformation<T> input,
StreamPartitioner<T> partitioner,
StreamExchangeMode exchangeMode)
Creates a new
PartitionTransformation from the given input and StreamPartitioner . |
ReduceTransformation(String name,
int parallelism,
Transformation<IN> input,
ReduceFunction<IN> reducer,
KeySelector<IN,K> keySelector,
TypeInformation<K> keyTypeInfo,
boolean parallelismConfigured) |
SideOutputTransformation(Transformation<?> input,
OutputTag<T> tag) |
SourceTransformationWrapper(Transformation<T> input) |
TimestampsAndWatermarksTransformation(String name,
int parallelism,
Transformation<IN> input,
WatermarkStrategy<IN> watermarkStrategy,
boolean parallelismConfigured)
Creates a new
Transformation with the given name, output type and parallelism. |
TwoInputTransformation(Transformation<IN1> input1,
Transformation<IN2> input2,
String name,
StreamOperatorFactory<OUT> operatorFactory,
TypeInformation<OUT> outputType,
int parallelism) |
TwoInputTransformation(Transformation<IN1> input1,
Transformation<IN2> input2,
String name,
StreamOperatorFactory<OUT> operatorFactory,
TypeInformation<OUT> outputType,
int parallelism) |
TwoInputTransformation(Transformation<IN1> input1,
Transformation<IN2> input2,
String name,
StreamOperatorFactory<OUT> operatorFactory,
TypeInformation<OUT> outputType,
int parallelism,
boolean parallelismConfigured)
Creates a new
TwoInputTransformation from the given inputs and operator. |
TwoInputTransformation(Transformation<IN1> input1,
Transformation<IN2> input2,
String name,
StreamOperatorFactory<OUT> operatorFactory,
TypeInformation<OUT> outputType,
int parallelism,
boolean parallelismConfigured)
Creates a new
TwoInputTransformation from the given inputs and operator. |
TwoInputTransformation(Transformation<IN1> input1,
Transformation<IN2> input2,
String name,
TwoInputStreamOperator<IN1,IN2,OUT> operator,
TypeInformation<OUT> outputType,
int parallelism)
Creates a new
TwoInputTransformation from the given inputs and operator. |
TwoInputTransformation(Transformation<IN1> input1,
Transformation<IN2> input2,
String name,
TwoInputStreamOperator<IN1,IN2,OUT> operator,
TypeInformation<OUT> outputType,
int parallelism)
Creates a new
TwoInputTransformation from the given inputs and operator. |
TwoInputTransformation(Transformation<IN1> input1,
Transformation<IN2> input2,
String name,
TwoInputStreamOperator<IN1,IN2,OUT> operator,
TypeInformation<OUT> outputType,
int parallelism,
boolean parallelismConfigured) |
TwoInputTransformation(Transformation<IN1> input1,
Transformation<IN2> input2,
String name,
TwoInputStreamOperator<IN1,IN2,OUT> operator,
TypeInformation<OUT> outputType,
int parallelism,
boolean parallelismConfigured) |
Constructor and Description |
---|
UnionTransformation(List<Transformation<T>> inputs)
Creates a new
UnionTransformation from the given input Transformations . |
Modifier and Type | Class and Description |
---|---|
class |
PythonBroadcastStateTransformation<IN1,IN2,OUT>
A
Transformation representing a Python Co-Broadcast-Process operation, which will be
translated into different operations by PythonBroadcastStateTransformationTranslator . |
class |
PythonKeyedBroadcastStateTransformation<OUT>
A
Transformation representing a Python Keyed-Co-Broadcast-Process operation, which will
be translated into different operations by PythonKeyedBroadcastStateTransformationTranslator . |
Modifier and Type | Class and Description |
---|---|
class |
AbstractTwoInputTransformationTranslator<IN1,IN2,OUT,OP extends Transformation<OUT>>
A base class with functionality used during translating
transformations
with two inputs. |
Modifier and Type | Method and Description |
---|---|
protected Collection<Integer> |
AbstractTwoInputTransformationTranslator.translateInternal(Transformation<OUT> transformation,
Transformation<IN1> firstInputTransformation,
Transformation<IN2> secondInputTransformation,
StreamOperatorFactory<OUT> operatorFactory,
TypeInformation<?> keyTypeInfo,
KeySelector<IN1,?> firstKeySelector,
KeySelector<IN2,?> secondKeySelector,
TransformationTranslator.Context context) |
protected Collection<Integer> |
AbstractTwoInputTransformationTranslator.translateInternal(Transformation<OUT> transformation,
Transformation<IN1> firstInputTransformation,
Transformation<IN2> secondInputTransformation,
StreamOperatorFactory<OUT> operatorFactory,
TypeInformation<?> keyTypeInfo,
KeySelector<IN1,?> firstKeySelector,
KeySelector<IN2,?> secondKeySelector,
TransformationTranslator.Context context) |
protected Collection<Integer> |
AbstractTwoInputTransformationTranslator.translateInternal(Transformation<OUT> transformation,
Transformation<IN1> firstInputTransformation,
Transformation<IN2> secondInputTransformation,
StreamOperatorFactory<OUT> operatorFactory,
TypeInformation<?> keyTypeInfo,
KeySelector<IN1,?> firstKeySelector,
KeySelector<IN2,?> secondKeySelector,
TransformationTranslator.Context context) |
Modifier and Type | Method and Description |
---|---|
static <T> void |
StreamGraphUtils.configureBufferTimeout(StreamGraph streamGraph,
int nodeId,
Transformation<T> transformation,
long defaultBufferTimeout)
Configure a stream node's buffer timeout according to the given transformation.
|
static void |
StreamGraphUtils.validateTransformationUid(StreamGraph streamGraph,
Transformation<?> transformation)
Throw
IllegalStateException if the PhysicalTransformation 's uid or hash is
not set when auto generate uid is disabled. |
Modifier and Type | Method and Description |
---|---|
List<Transformation<?>> |
DQLCachedPlan.getTransformations() |
protected List<Transformation<?>> |
TableEnvironmentImpl.translate(List<ModifyOperation> modifyOperations) |
Modifier and Type | Method and Description |
---|---|
Pipeline |
TableEnvironmentImpl.generatePipelineFromQueryOperation(QueryOperation operation,
List<Transformation<?>> transformations)
generate execution
Pipeline from QueryOperation . |
Constructor and Description |
---|
DQLCachedPlan(QueryOperation queryOperation,
CollectModifyOperation sinkOperation,
List<Transformation<?>> transformations) |
Modifier and Type | Method and Description |
---|---|
List<Transformation<?>> |
Planner.translate(List<ModifyOperation> modifyOperations)
Converts a relational tree of
ModifyOperation s into a set of runnable Transformation s. |
List<Transformation<?>> |
Planner.translatePlan(InternalPlan plan) |
Modifier and Type | Method and Description |
---|---|
Pipeline |
Executor.createPipeline(List<Transformation<?>> transformations,
ReadableConfig tableConfiguration,
String defaultJobName)
Translates the given transformations to a
Pipeline . |
Pipeline |
Executor.createPipeline(List<Transformation<?>> transformations,
ReadableConfig tableConfiguration,
String defaultJobName,
List<JobStatusHook> jobStatusHookList)
Translates the given transformations with a list of
JobStatusHook s to a Pipeline . |
Modifier and Type | Method and Description |
---|---|
Pipeline |
ChainingOptimizingExecutor.createPipeline(List<Transformation<?>> transformations,
ReadableConfig configuration,
String defaultJobName) |
Pipeline |
ChainingOptimizingExecutor.createPipeline(List<Transformation<?>> transformations,
ReadableConfig configuration,
String defaultJobName,
List<JobStatusHook> jobStatusHookList) |
Modifier and Type | Method and Description |
---|---|
Transformation<RowData> |
TransformationScanProvider.createTransformation(ProviderContext providerContext)
Creates a
Transformation instance. |
Transformation<?> |
TransformationSinkProvider.createTransformation(TransformationSinkProvider.Context context)
Creates a transformation for transforming the input provided in the context.
|
Transformation<RowData> |
TransformationSinkProvider.Context.getInputTransformation()
Input transformation to transform.
|
Modifier and Type | Method and Description |
---|---|
Pipeline |
DefaultExecutor.createPipeline(List<Transformation<?>> transformations,
ReadableConfig tableConfiguration,
String defaultJobName) |
Pipeline |
DefaultExecutor.createPipeline(List<Transformation<?>> transformations,
ReadableConfig tableConfiguration,
String defaultJobName,
List<JobStatusHook> jobStatusHookList) |
Modifier and Type | Method and Description |
---|---|
Transformation<T> |
ExecNodeBase.getTransformation() |
Transformation<T> |
ExecNodeTranslator.translateToPlan(Planner planner)
Translates this node into a
Transformation . |
Transformation<?> |
ExecEdge.translateToPlan(Planner planner)
Translates this edge into a Flink operator.
|
Transformation<T> |
ExecNodeBase.translateToPlan(Planner planner) |
protected abstract Transformation<T> |
ExecNodeBase.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config)
Internal method, translates this node into a Flink operator.
|
Modifier and Type | Method and Description |
---|---|
protected Transformation<RowData> |
BatchExecSink.applyUpsertMaterialize(Transformation<RowData> inputTransform,
int[] primaryKeys,
int sinkParallelism,
ExecNodeConfig config,
ClassLoader classLoader,
RowType physicalRowType,
int[] inputUpsertKey) |
protected Transformation<RowData> |
BatchExecLegacyTableSourceScan.createConversionTransformationIfNeeded(StreamExecutionEnvironment streamExecEnv,
ExecNodeConfig config,
ClassLoader classLoader,
Transformation<?> sourceTransform,
org.apache.calcite.rex.RexNode rowtimeExpression) |
protected <IN> Transformation<IN> |
BatchExecLegacyTableSourceScan.createInput(StreamExecutionEnvironment env,
InputFormat<IN,? extends InputSplit> inputFormat,
TypeInformation<IN> typeInfo) |
Transformation<RowData> |
BatchExecTableSourceScan.createInputFormatTransformation(StreamExecutionEnvironment env,
InputFormat<RowData,?> inputFormat,
InternalTypeInfo<RowData> outputTypeInfo,
String operatorName) |
protected Transformation<RowData> |
BatchExecLookupJoin.createSyncLookupJoinWithState(Transformation<RowData> inputTransformation,
org.apache.calcite.plan.RelOptTable temporalTable,
ExecNodeConfig config,
ClassLoader classLoader,
Map<Integer,LookupJoinUtil.LookupKey> allLookupKeys,
TableFunction<?> syncLookupFunction,
RelBuilder relBuilder,
RowType inputRowType,
RowType tableSourceRowType,
RowType resultRowType,
boolean isLeftOuterJoin,
boolean isObjectReuseEnabled,
boolean lookupKeyContainsPrimaryKey) |
protected Transformation<RowData> |
BatchExecLegacyTableSourceScan.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
BatchExecBoundedStreamScan.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
BatchExecSortLimit.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
BatchExecPythonOverAggregate.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
BatchExecSortWindowAggregate.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
BatchExecSort.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
BatchExecPythonGroupWindowAggregate.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
BatchExecExecutionOrderEnforcer.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
BatchExecPythonGroupAggregate.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
BatchExecNestedLoopJoin.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<Object> |
BatchExecSink.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
BatchExecOverAggregate.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
BatchExecWindowTableFunction.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
BatchExecTableSourceScan.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
BatchExecValues.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
BatchExecRank.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
BatchExecSortAggregate.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
BatchExecScriptTransform.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
BatchExecInputAdapter.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
Transformation<RowData> |
BatchExecLookupJoin.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
BatchExecHashAggregate.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
BatchExecHashJoin.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
BatchExecSortMergeJoin.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
BatchExecHashWindowAggregate.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
BatchExecMultipleInput.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<Object> |
BatchExecDynamicFilteringDataCollector.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
BatchExecLimit.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
BatchExecExchange.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
BatchExecWindowTableFunction.translateWithUnalignedWindow(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config,
RowType inputRowType,
Transformation<RowData> inputTransform) |
Modifier and Type | Method and Description |
---|---|
protected Transformation<RowData> |
BatchExecSink.applyUpsertMaterialize(Transformation<RowData> inputTransform,
int[] primaryKeys,
int sinkParallelism,
ExecNodeConfig config,
ClassLoader classLoader,
RowType physicalRowType,
int[] inputUpsertKey) |
protected Transformation<RowData> |
BatchExecLegacyTableSourceScan.createConversionTransformationIfNeeded(StreamExecutionEnvironment streamExecEnv,
ExecNodeConfig config,
ClassLoader classLoader,
Transformation<?> sourceTransform,
org.apache.calcite.rex.RexNode rowtimeExpression) |
protected Transformation<RowData> |
BatchExecLookupJoin.createSyncLookupJoinWithState(Transformation<RowData> inputTransformation,
org.apache.calcite.plan.RelOptTable temporalTable,
ExecNodeConfig config,
ClassLoader classLoader,
Map<Integer,LookupJoinUtil.LookupKey> allLookupKeys,
TableFunction<?> syncLookupFunction,
RelBuilder relBuilder,
RowType inputRowType,
RowType tableSourceRowType,
RowType resultRowType,
boolean isLeftOuterJoin,
boolean isObjectReuseEnabled,
boolean lookupKeyContainsPrimaryKey) |
protected Transformation<RowData> |
BatchExecWindowTableFunction.translateWithUnalignedWindow(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config,
RowType inputRowType,
Transformation<RowData> inputTransform) |
Modifier and Type | Method and Description |
---|---|
protected Transformation<RowData> |
BatchExecRuntimeFilter.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
BatchExecLocalRuntimeFilterBuilder.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
BatchExecGlobalRuntimeFilterBuilder.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
Modifier and Type | Method and Description |
---|---|
protected abstract Transformation<RowData> |
CommonExecSink.applyUpsertMaterialize(Transformation<RowData> inputTransform,
int[] primaryKeys,
int sinkParallelism,
ExecNodeConfig config,
ClassLoader classLoader,
RowType physicalRowType,
int[] inputUpsertKey) |
protected abstract Transformation<RowData> |
CommonExecLegacyTableSourceScan.createConversionTransformationIfNeeded(StreamExecutionEnvironment streamExecEnv,
ExecNodeConfig config,
ClassLoader classLoader,
Transformation<?> sourceTransform,
org.apache.calcite.rex.RexNode rowtimeExpression) |
protected abstract <IN> Transformation<IN> |
CommonExecLegacyTableSourceScan.createInput(StreamExecutionEnvironment env,
InputFormat<IN,? extends InputSplit> inputFormat,
TypeInformation<IN> typeInfo) |
protected abstract Transformation<RowData> |
CommonExecTableSourceScan.createInputFormatTransformation(StreamExecutionEnvironment env,
InputFormat<RowData,?> inputFormat,
InternalTypeInfo<RowData> outputTypeInfo,
String operatorName)
Creates a
Transformation based on the given InputFormat . |
protected Transformation<RowData> |
CommonExecLookupJoin.createJoinTransformation(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config,
boolean upsertMaterialize,
boolean lookupKeyContainsPrimaryKey) |
protected Transformation<Object> |
CommonExecSink.createSinkTransformation(StreamExecutionEnvironment streamExecEnv,
ExecNodeConfig config,
ClassLoader classLoader,
Transformation<RowData> inputTransform,
DynamicTableSink tableSink,
int rowtimeFieldIndex,
boolean upsertMaterialize,
int[] inputUpsertKey) |
protected Transformation<RowData> |
CommonExecTableSourceScan.createSourceFunctionTransformation(StreamExecutionEnvironment env,
SourceFunction<RowData> function,
boolean isBounded,
String operatorName,
TypeInformation<RowData> outputTypeInfo,
int sourceParallelism,
boolean sourceParallelismConfigured)
Deprecated.
This method relies on the
SourceFunction API, which is due to be
removed. |
protected abstract Transformation<RowData> |
CommonExecLookupJoin.createSyncLookupJoinWithState(Transformation<RowData> inputTransformation,
org.apache.calcite.plan.RelOptTable temporalTable,
ExecNodeConfig config,
ClassLoader classLoader,
Map<Integer,LookupJoinUtil.LookupKey> allLookupKeys,
TableFunction<?> syncLookupFunction,
RelBuilder relBuilder,
RowType inputRowType,
RowType tableSourceRowType,
RowType resultRowType,
boolean isLeftOuterJoin,
boolean isObjectReuseEnabled,
boolean lookupKeyContainsPrimaryKey) |
protected Transformation<RowData> |
CommonExecMatch.translateOrder(Transformation<RowData> inputTransform,
RowType inputRowType,
ExecNodeConfig config) |
protected Transformation<RowData> |
CommonExecExpand.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
CommonExecLegacyTableSourceScan.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<T> |
CommonExecLegacySink.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
CommonExecCorrelate.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
CommonExecMatch.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
CommonExecPythonCorrelate.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
CommonExecCalc.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
CommonExecTableSourceScan.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
CommonExecPythonCalc.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
CommonExecUnion.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
CommonExecAsyncCalc.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
CommonExecWindowTableFunction.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
CommonExecValues.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected abstract Transformation<RowData> |
CommonExecWindowTableFunction.translateWithUnalignedWindow(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config,
RowType inputRowType,
Transformation<RowData> inputTransform) |
Modifier and Type | Method and Description |
---|---|
protected abstract Transformation<RowData> |
CommonExecSink.applyUpsertMaterialize(Transformation<RowData> inputTransform,
int[] primaryKeys,
int sinkParallelism,
ExecNodeConfig config,
ClassLoader classLoader,
RowType physicalRowType,
int[] inputUpsertKey) |
protected abstract Transformation<RowData> |
CommonExecLegacyTableSourceScan.createConversionTransformationIfNeeded(StreamExecutionEnvironment streamExecEnv,
ExecNodeConfig config,
ClassLoader classLoader,
Transformation<?> sourceTransform,
org.apache.calcite.rex.RexNode rowtimeExpression) |
protected Transformation<Object> |
CommonExecSink.createSinkTransformation(StreamExecutionEnvironment streamExecEnv,
ExecNodeConfig config,
ClassLoader classLoader,
Transformation<RowData> inputTransform,
DynamicTableSink tableSink,
int rowtimeFieldIndex,
boolean upsertMaterialize,
int[] inputUpsertKey) |
protected abstract Transformation<RowData> |
CommonExecLookupJoin.createSyncLookupJoinWithState(Transformation<RowData> inputTransformation,
org.apache.calcite.plan.RelOptTable temporalTable,
ExecNodeConfig config,
ClassLoader classLoader,
Map<Integer,LookupJoinUtil.LookupKey> allLookupKeys,
TableFunction<?> syncLookupFunction,
RelBuilder relBuilder,
RowType inputRowType,
RowType tableSourceRowType,
RowType resultRowType,
boolean isLeftOuterJoin,
boolean isObjectReuseEnabled,
boolean lookupKeyContainsPrimaryKey) |
protected Transformation<RowData> |
CommonExecMatch.translateOrder(Transformation<RowData> inputTransform,
RowType inputRowType,
ExecNodeConfig config) |
protected abstract Transformation<RowData> |
CommonExecWindowTableFunction.translateWithUnalignedWindow(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config,
RowType inputRowType,
Transformation<RowData> inputTransform) |
Modifier and Type | Method and Description |
---|---|
protected Transformation<RowData> |
StreamExecSink.applyUpsertMaterialize(Transformation<RowData> inputTransform,
int[] primaryKeys,
int sinkParallelism,
ExecNodeConfig config,
ClassLoader classLoader,
RowType physicalRowType,
int[] inputUpsertKey) |
protected Transformation<RowData> |
StreamExecLegacyTableSourceScan.createConversionTransformationIfNeeded(StreamExecutionEnvironment streamExecEnv,
ExecNodeConfig config,
ClassLoader classLoader,
Transformation<?> sourceTransform,
org.apache.calcite.rex.RexNode rowtimeExpression) |
protected <IN> Transformation<IN> |
StreamExecLegacyTableSourceScan.createInput(StreamExecutionEnvironment env,
InputFormat<IN,? extends InputSplit> format,
TypeInformation<IN> typeInfo) |
Transformation<RowData> |
StreamExecTableSourceScan.createInputFormatTransformation(StreamExecutionEnvironment env,
InputFormat<RowData,?> inputFormat,
InternalTypeInfo<RowData> outputTypeInfo,
String operatorName) |
protected Transformation<RowData> |
StreamExecLookupJoin.createSyncLookupJoinWithState(Transformation<RowData> inputTransformation,
org.apache.calcite.plan.RelOptTable temporalTable,
ExecNodeConfig config,
ClassLoader classLoader,
Map<Integer,LookupJoinUtil.LookupKey> allLookupKeys,
TableFunction<?> syncLookupFunction,
RelBuilder relBuilder,
RowType inputRowType,
RowType tableSourceRowType,
RowType resultRowType,
boolean isLeftOuterJoin,
boolean isObjectReuseEnabled,
boolean lookupKeyContainsPrimaryKey) |
Transformation<RowData> |
StreamExecMatch.translateOrder(Transformation<RowData> inputTransform,
RowType inputRowType,
ExecNodeConfig config) |
protected Transformation<RowData> |
StreamExecOverAggregate.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
StreamExecWindowJoin.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
StreamExecIntervalJoin.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
StreamExecGlobalGroupAggregate.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
StreamExecMiniBatchAssigner.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
StreamExecDropUpdateBefore.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
StreamExecPythonGroupAggregate.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
StreamExecJoin.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
StreamExecDataStreamScan.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
StreamExecLocalWindowAggregate.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
StreamExecGroupAggregate.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
StreamExecIncrementalGroupAggregate.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
StreamExecWatermarkAssigner.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
StreamExecMultipleInput.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
StreamExecGroupTableAggregate.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
Transformation<RowData> |
StreamExecLookupJoin.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
StreamExecPythonOverAggregate.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
StreamExecExchange.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
StreamExecTemporalSort.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
StreamExecGlobalWindowAggregate.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
StreamExecTemporalJoin.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
StreamExecGroupWindowAggregate.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
StreamExecWindowRank.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
StreamExecWindowAggregate.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
StreamExecSortLimit.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
StreamExecRank.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
StreamExecPythonGroupWindowAggregate.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<Object> |
StreamExecSink.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
StreamExecLocalGroupAggregate.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
StreamExecChangelogNormalize.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
StreamExecLimit.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
StreamExecPythonGroupTableAggregate.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
StreamExecSort.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
StreamExecDeduplicate.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
StreamExecWindowDeduplicate.translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config) |
protected Transformation<RowData> |
StreamExecWindowTableFunction.translateWithUnalignedWindow(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config,
RowType inputRowType,
Transformation<RowData> inputTransform) |
Modifier and Type | Method and Description |
---|---|
protected Transformation<RowData> |
StreamExecSink.applyUpsertMaterialize(Transformation<RowData> inputTransform,
int[] primaryKeys,
int sinkParallelism,
ExecNodeConfig config,
ClassLoader classLoader,
RowType physicalRowType,
int[] inputUpsertKey) |
protected Transformation<RowData> |
StreamExecLegacyTableSourceScan.createConversionTransformationIfNeeded(StreamExecutionEnvironment streamExecEnv,
ExecNodeConfig config,
ClassLoader classLoader,
Transformation<?> sourceTransform,
org.apache.calcite.rex.RexNode rowtimeExpression) |
protected Transformation<RowData> |
StreamExecLookupJoin.createSyncLookupJoinWithState(Transformation<RowData> inputTransformation,
org.apache.calcite.plan.RelOptTable temporalTable,
ExecNodeConfig config,
ClassLoader classLoader,
Map<Integer,LookupJoinUtil.LookupKey> allLookupKeys,
TableFunction<?> syncLookupFunction,
RelBuilder relBuilder,
RowType inputRowType,
RowType tableSourceRowType,
RowType resultRowType,
boolean isLeftOuterJoin,
boolean isObjectReuseEnabled,
boolean lookupKeyContainsPrimaryKey) |
Transformation<RowData> |
StreamExecMatch.translateOrder(Transformation<RowData> inputTransform,
RowType inputRowType,
ExecNodeConfig config) |
protected Transformation<RowData> |
StreamExecWindowTableFunction.translateWithUnalignedWindow(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config,
RowType inputRowType,
Transformation<RowData> inputTransform) |
Modifier and Type | Method and Description |
---|---|
<T extends Transformation<?>> |
TransformationMetadata.fill(T transformation)
Fill a transformation with this meta.
|
Modifier and Type | Method and Description |
---|---|
static <I,O> OneInputTransformation<I,O> |
ExecNodeUtil.createOneInputTransformation(Transformation<I> input,
String name,
String desc,
StreamOperator<O> operator,
TypeInformation<O> outputType,
int parallelism,
boolean parallelismConfigured)
Create a
OneInputTransformation . |
static <I,O> OneInputTransformation<I,O> |
ExecNodeUtil.createOneInputTransformation(Transformation<I> input,
String name,
String desc,
StreamOperatorFactory<O> operatorFactory,
TypeInformation<O> outputType,
int parallelism,
boolean parallelismConfigured)
Create a
OneInputTransformation . |
static <I,O> OneInputTransformation<I,O> |
ExecNodeUtil.createOneInputTransformation(Transformation<I> input,
String name,
String desc,
StreamOperatorFactory<O> operatorFactory,
TypeInformation<O> outputType,
int parallelism,
long memoryBytes,
boolean parallelismConfigured)
Create a
OneInputTransformation with memoryBytes. |
static <I,O> OneInputTransformation<I,O> |
ExecNodeUtil.createOneInputTransformation(Transformation<I> input,
TransformationMetadata transformationMeta,
StreamOperator<O> operator,
TypeInformation<O> outputType,
int parallelism,
boolean parallelismConfigured)
Create a
OneInputTransformation . |
static <I,O> OneInputTransformation<I,O> |
ExecNodeUtil.createOneInputTransformation(Transformation<I> input,
TransformationMetadata transformationMeta,
StreamOperator<O> operator,
TypeInformation<O> outputType,
int parallelism,
long memoryBytes,
boolean parallelismConfigured)
Create a
OneInputTransformation with memoryBytes. |
static <I,O> OneInputTransformation<I,O> |
ExecNodeUtil.createOneInputTransformation(Transformation<I> input,
TransformationMetadata transformationMeta,
StreamOperatorFactory<O> operatorFactory,
TypeInformation<O> outputType,
int parallelism,
boolean parallelismConfigured)
Create a
OneInputTransformation . |
static <I,O> OneInputTransformation<I,O> |
ExecNodeUtil.createOneInputTransformation(Transformation<I> input,
TransformationMetadata transformationMeta,
StreamOperatorFactory<O> operatorFactory,
TypeInformation<O> outputType,
int parallelism,
long memoryBytes,
boolean parallelismConfigured)
Create a
OneInputTransformation with memoryBytes. |
static <I1,I2,O> TwoInputTransformation<I1,I2,O> |
ExecNodeUtil.createTwoInputTransformation(Transformation<I1> input1,
Transformation<I2> input2,
String name,
String desc,
StreamOperatorFactory<O> operatorFactory,
TypeInformation<O> outputType,
int parallelism,
long memoryBytes,
boolean parallelismConfigured)
Create a
TwoInputTransformation with memoryBytes. |
static <I1,I2,O> TwoInputTransformation<I1,I2,O> |
ExecNodeUtil.createTwoInputTransformation(Transformation<I1> input1,
Transformation<I2> input2,
String name,
String desc,
StreamOperatorFactory<O> operatorFactory,
TypeInformation<O> outputType,
int parallelism,
long memoryBytes,
boolean parallelismConfigured)
Create a
TwoInputTransformation with memoryBytes. |
static <I1,I2,O> TwoInputTransformation<I1,I2,O> |
ExecNodeUtil.createTwoInputTransformation(Transformation<I1> input1,
Transformation<I2> input2,
TransformationMetadata transformationMeta,
StreamOperatorFactory<O> operatorFactory,
TypeInformation<O> outputType,
int parallelism,
long memoryBytes)
Create a
TwoInputTransformation with memoryBytes. |
static <I1,I2,O> TwoInputTransformation<I1,I2,O> |
ExecNodeUtil.createTwoInputTransformation(Transformation<I1> input1,
Transformation<I2> input2,
TransformationMetadata transformationMeta,
StreamOperatorFactory<O> operatorFactory,
TypeInformation<O> outputType,
int parallelism,
long memoryBytes)
Create a
TwoInputTransformation with memoryBytes. |
static <I1,I2,O> TwoInputTransformation<I1,I2,O> |
ExecNodeUtil.createTwoInputTransformation(Transformation<I1> input1,
Transformation<I2> input2,
TransformationMetadata transformationMeta,
StreamOperatorFactory<O> operatorFactory,
TypeInformation<O> outputType,
int parallelism,
long memoryBytes,
boolean parallelismConfigured) |
static <I1,I2,O> TwoInputTransformation<I1,I2,O> |
ExecNodeUtil.createTwoInputTransformation(Transformation<I1> input1,
Transformation<I2> input2,
TransformationMetadata transformationMeta,
StreamOperatorFactory<O> operatorFactory,
TypeInformation<O> outputType,
int parallelism,
long memoryBytes,
boolean parallelismConfigured) |
static <IN1,IN2,O> |
ExecNodeUtil.createTwoInputTransformation(Transformation<IN1> input1,
Transformation<IN2> input2,
String name,
String desc,
TwoInputStreamOperator<IN1,IN2,O> operator,
TypeInformation<O> outputType,
int parallelism)
Create a
TwoInputTransformation with memoryBytes. |
static <IN1,IN2,O> |
ExecNodeUtil.createTwoInputTransformation(Transformation<IN1> input1,
Transformation<IN2> input2,
String name,
String desc,
TwoInputStreamOperator<IN1,IN2,O> operator,
TypeInformation<O> outputType,
int parallelism)
Create a
TwoInputTransformation with memoryBytes. |
static <IN1,IN2,O> |
ExecNodeUtil.createTwoInputTransformation(Transformation<IN1> input1,
Transformation<IN2> input2,
String name,
String desc,
TwoInputStreamOperator<IN1,IN2,O> operator,
TypeInformation<O> outputType,
int parallelism,
long memoryBytes)
Create a
TwoInputTransformation with memoryBytes. |
static <IN1,IN2,O> |
ExecNodeUtil.createTwoInputTransformation(Transformation<IN1> input1,
Transformation<IN2> input2,
String name,
String desc,
TwoInputStreamOperator<IN1,IN2,O> operator,
TypeInformation<O> outputType,
int parallelism,
long memoryBytes)
Create a
TwoInputTransformation with memoryBytes. |
static <IN1,IN2,O> |
ExecNodeUtil.createTwoInputTransformation(Transformation<IN1> input1,
Transformation<IN2> input2,
TransformationMetadata transformationMeta,
TwoInputStreamOperator<IN1,IN2,O> operator,
TypeInformation<O> outputType,
int parallelism,
boolean parallelismConfigured)
Create a
TwoInputTransformation with memoryBytes. |
static <IN1,IN2,O> |
ExecNodeUtil.createTwoInputTransformation(Transformation<IN1> input1,
Transformation<IN2> input2,
TransformationMetadata transformationMeta,
TwoInputStreamOperator<IN1,IN2,O> operator,
TypeInformation<O> outputType,
int parallelism,
boolean parallelismConfigured)
Create a
TwoInputTransformation with memoryBytes. |
static <IN1,IN2,O> |
ExecNodeUtil.createTwoInputTransformation(Transformation<IN1> input1,
Transformation<IN2> input2,
TransformationMetadata transformationMeta,
TwoInputStreamOperator<IN1,IN2,O> operator,
TypeInformation<O> outputType,
int parallelism,
long memoryBytes)
Create a
TwoInputTransformation with memoryBytes. |
static <IN1,IN2,O> |
ExecNodeUtil.createTwoInputTransformation(Transformation<IN1> input1,
Transformation<IN2> input2,
TransformationMetadata transformationMeta,
TwoInputStreamOperator<IN1,IN2,O> operator,
TypeInformation<O> outputType,
int parallelism,
long memoryBytes)
Create a
TwoInputTransformation with memoryBytes. |
static <IN1,IN2,O> |
ExecNodeUtil.createTwoInputTransformation(Transformation<IN1> input1,
Transformation<IN2> input2,
TransformationMetadata transformationMeta,
TwoInputStreamOperator<IN1,IN2,O> operator,
TypeInformation<O> outputType,
int parallelism,
long memoryBytes,
boolean parallelismConfigured) |
static <IN1,IN2,O> |
ExecNodeUtil.createTwoInputTransformation(Transformation<IN1> input1,
Transformation<IN2> input2,
TransformationMetadata transformationMeta,
TwoInputStreamOperator<IN1,IN2,O> operator,
TypeInformation<O> outputType,
int parallelism,
long memoryBytes,
boolean parallelismConfigured) |
static void |
ExecNodeUtil.makeLegacySourceTransformationsBounded(Transformation<?> transformation)
The planner might have more information than expressed in legacy source transformations.
|
static <T> void |
ExecNodeUtil.setManagedMemoryWeight(Transformation<T> transformation,
long memoryBytes)
Sets {Transformation#declareManagedMemoryUseCaseAtOperatorScope(ManagedMemoryUseCase, int)}
using the given bytes for
ManagedMemoryUseCase.OPERATOR . |
Modifier and Type | Method and Description |
---|---|
List<org.apache.commons.lang3.tuple.Pair<Transformation<?>,InputSpec>> |
TableOperatorWrapperGenerator.getInputTransformAndInputSpecPairs() |
Constructor and Description |
---|
TableOperatorWrapperGenerator(List<Transformation<?>> inputTransforms,
Transformation<?> tailTransform) |
TableOperatorWrapperGenerator(List<Transformation<?>> inputTransforms,
Transformation<?> tailTransform,
int[] readOrders) |
Constructor and Description |
---|
TableOperatorWrapperGenerator(List<Transformation<?>> inputTransforms,
Transformation<?> tailTransform) |
TableOperatorWrapperGenerator(List<Transformation<?>> inputTransforms,
Transformation<?> tailTransform,
int[] readOrders) |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.