Interface SingleTransformationTranslator<T>
-
- Type Parameters:
T
- The type of the elements that result from this translator.
- All Superinterfaces:
ExecNodeTranslator<T>
- All Known Implementing Classes:
BatchExecCalc
,BatchExecCorrelate
,BatchExecExchange
,BatchExecExpand
,BatchExecHashAggregate
,BatchExecHashJoin
,BatchExecHashWindowAggregate
,BatchExecInputAdapter
,BatchExecLimit
,BatchExecLookupJoin
,BatchExecMultipleInput
,BatchExecNestedLoopJoin
,BatchExecOverAggregate
,BatchExecOverAggregateBase
,BatchExecPythonCalc
,BatchExecPythonCorrelate
,BatchExecPythonGroupAggregate
,BatchExecPythonGroupWindowAggregate
,BatchExecPythonOverAggregate
,BatchExecRank
,BatchExecScriptTransform
,BatchExecSort
,BatchExecSortAggregate
,BatchExecSortLimit
,BatchExecSortMergeJoin
,BatchExecSortWindowAggregate
,BatchExecUnion
,BatchExecValues
,BatchExecWindowTableFunction
,CommonExecAsyncCalc
,CommonExecCalc
,CommonExecCorrelate
,CommonExecExchange
,CommonExecExpand
,CommonExecPythonCalc
,CommonExecPythonCorrelate
,CommonExecUnion
,CommonExecValues
,CommonExecWindowTableFunction
,StreamExecAggregateBase
,StreamExecAsyncCalc
,StreamExecCalc
,StreamExecChangelogNormalize
,StreamExecCorrelate
,StreamExecDeduplicate
,StreamExecDropUpdateBefore
,StreamExecExchange
,StreamExecExpand
,StreamExecGlobalGroupAggregate
,StreamExecGlobalWindowAggregate
,StreamExecGroupAggregate
,StreamExecGroupTableAggregate
,StreamExecGroupWindowAggregate
,StreamExecIncrementalGroupAggregate
,StreamExecJoin
,StreamExecLimit
,StreamExecLocalGroupAggregate
,StreamExecLocalWindowAggregate
,StreamExecMiniBatchAssigner
,StreamExecOverAggregate
,StreamExecPythonCalc
,StreamExecPythonCorrelate
,StreamExecPythonGroupAggregate
,StreamExecPythonGroupTableAggregate
,StreamExecPythonGroupWindowAggregate
,StreamExecPythonOverAggregate
,StreamExecRank
,StreamExecSortLimit
,StreamExecTemporalJoin
,StreamExecUnion
,StreamExecValues
,StreamExecWatermarkAssigner
,StreamExecWindowAggregate
,StreamExecWindowAggregateBase
,StreamExecWindowDeduplicate
,StreamExecWindowJoin
,StreamExecWindowRank
,StreamExecWindowTableFunction
@Internal public interface SingleTransformationTranslator<T> extends ExecNodeTranslator<T>
AnExecNodeTranslator
that will generate only ONETransformation
.This interface is just an convention that this translator will always return one Transformation, while the planner does not check the result.
-
-
Method Summary
-
Methods inherited from interface org.apache.flink.table.planner.plan.nodes.exec.ExecNodeTranslator
translateToPlan
-
-