Interface ExecNodeTranslator<T>
-
- Type Parameters:
T
- The type of the elements that result from this translator.
- All Known Subinterfaces:
BatchExecNode<T>
,ExecNode<T>
,InputSortedExecNode<T>
,MultipleTransformationTranslator<T>
,SingleTransformationTranslator<T>
,StreamExecNode<T>
- All Known Implementing Classes:
BatchExecBoundedStreamScan
,BatchExecCalc
,BatchExecCorrelate
,BatchExecDynamicFilteringDataCollector
,BatchExecExchange
,BatchExecExecutionOrderEnforcer
,BatchExecExpand
,BatchExecGlobalRuntimeFilterBuilder
,BatchExecHashAggregate
,BatchExecHashJoin
,BatchExecHashWindowAggregate
,BatchExecInputAdapter
,BatchExecLegacySink
,BatchExecLegacyTableSourceScan
,BatchExecLimit
,BatchExecLocalRuntimeFilterBuilder
,BatchExecLookupJoin
,BatchExecMatch
,BatchExecMultipleInput
,BatchExecNestedLoopJoin
,BatchExecOverAggregate
,BatchExecOverAggregateBase
,BatchExecPythonCalc
,BatchExecPythonCorrelate
,BatchExecPythonGroupAggregate
,BatchExecPythonGroupWindowAggregate
,BatchExecPythonOverAggregate
,BatchExecRank
,BatchExecRuntimeFilter
,BatchExecScriptTransform
,BatchExecSink
,BatchExecSort
,BatchExecSortAggregate
,BatchExecSortLimit
,BatchExecSortMergeJoin
,BatchExecSortWindowAggregate
,BatchExecTableSourceScan
,BatchExecUnion
,BatchExecValues
,BatchExecWindowTableFunction
,CommonExecAsyncCalc
,CommonExecCalc
,CommonExecCorrelate
,CommonExecExchange
,CommonExecExpand
,CommonExecLegacySink
,CommonExecLegacyTableSourceScan
,CommonExecLookupJoin
,CommonExecMatch
,CommonExecPythonCalc
,CommonExecPythonCorrelate
,CommonExecSink
,CommonExecTableSourceScan
,CommonExecUnion
,CommonExecValues
,CommonExecWindowTableFunction
,ExecNodeBase
,StreamExecAggregateBase
,StreamExecAsyncCalc
,StreamExecCalc
,StreamExecChangelogNormalize
,StreamExecCorrelate
,StreamExecDataStreamScan
,StreamExecDeduplicate
,StreamExecDropUpdateBefore
,StreamExecExchange
,StreamExecExpand
,StreamExecGlobalGroupAggregate
,StreamExecGlobalWindowAggregate
,StreamExecGroupAggregate
,StreamExecGroupTableAggregate
,StreamExecGroupWindowAggregate
,StreamExecIncrementalGroupAggregate
,StreamExecIntervalJoin
,StreamExecJoin
,StreamExecLegacySink
,StreamExecLegacyTableSourceScan
,StreamExecLimit
,StreamExecLocalGroupAggregate
,StreamExecLocalWindowAggregate
,StreamExecLookupJoin
,StreamExecMatch
,StreamExecMiniBatchAssigner
,StreamExecMultipleInput
,StreamExecOverAggregate
,StreamExecPythonCalc
,StreamExecPythonCorrelate
,StreamExecPythonGroupAggregate
,StreamExecPythonGroupTableAggregate
,StreamExecPythonGroupWindowAggregate
,StreamExecPythonOverAggregate
,StreamExecRank
,StreamExecSink
,StreamExecSort
,StreamExecSortLimit
,StreamExecTableSourceScan
,StreamExecTemporalJoin
,StreamExecTemporalSort
,StreamExecUnion
,StreamExecValues
,StreamExecWatermarkAssigner
,StreamExecWindowAggregate
,StreamExecWindowAggregateBase
,StreamExecWindowDeduplicate
,StreamExecWindowJoin
,StreamExecWindowRank
,StreamExecWindowTableFunction
@Internal public interface ExecNodeTranslator<T>
-
-
Method Summary
All Methods Instance Methods Abstract Methods Modifier and Type Method Description Transformation<T>
translateToPlan(Planner planner)
Translates this node into aTransformation
.
-
-
-
Method Detail
-
translateToPlan
Transformation<T> translateToPlan(Planner planner)
Translates this node into aTransformation
.NOTE: This method should return same translate result if called multiple times.
- Parameters:
planner
- ThePlanner
of the translated graph.
-
-