Interface FusionCodegenExecNode
-
- All Known Subinterfaces:
BatchExecNode<T>
,ExecNode<T>
,InputSortedExecNode<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
public interface FusionCodegenExecNode
AExecNode
which support operator fusion codegen.
-
-
Method Summary
All Methods Instance Methods Abstract Methods Modifier and Type Method Description boolean
supportFusionCodegen()
Whether this ExecNode supports OFCG or not.OpFusionCodegenSpecGenerator
translateToFusionCodegenSpec(Planner planner, org.apache.flink.table.planner.codegen.CodeGeneratorContext parentCtx)
Translates this node into aOpFusionCodegenSpecGenerator
.
-
-
-
Method Detail
-
supportFusionCodegen
boolean supportFusionCodegen()
Whether this ExecNode supports OFCG or not.
-
translateToFusionCodegenSpec
OpFusionCodegenSpecGenerator translateToFusionCodegenSpec(Planner planner, org.apache.flink.table.planner.codegen.CodeGeneratorContext parentCtx)
Translates this node into aOpFusionCodegenSpecGenerator
.NOTE: This method should return same spec generator result if called multiple times.
- Parameters:
planner
- ThePlanner
of the translated graph.parentCtx
- Parent CodeGeneratorContext.
-
-