Interface InputSortedExecNode<T>
-
- All Superinterfaces:
BatchExecNode<T>
,ExecNode<T>
,ExecNodeTranslator<T>
,FusionCodegenExecNode
- All Known Implementing Classes:
BatchExecOverAggregate
,BatchExecOverAggregateBase
,BatchExecPythonOverAggregate
,BatchExecRank
,BatchExecSortAggregate
,BatchExecSortWindowAggregate
@Internal public interface InputSortedExecNode<T> extends BatchExecNode<T>
ABatchExecNode
which does not sort the input data within the operator, but requires the input data is already sorted.
-
-
Field Summary
-
Fields inherited from interface org.apache.flink.table.planner.plan.nodes.exec.ExecNode
FIELD_NAME_CONFIGURATION, FIELD_NAME_DESCRIPTION, FIELD_NAME_ID, FIELD_NAME_INPUT_PROPERTIES, FIELD_NAME_OUTPUT_TYPE, FIELD_NAME_STATE, FIELD_NAME_TYPE
-
-
Method Summary
-
Methods inherited from interface org.apache.flink.table.planner.plan.nodes.exec.ExecNode
accept, getDescription, getId, getInputEdges, getInputProperties, getOutputType, replaceInputEdge, setCompiled, setInputEdges
-
Methods inherited from interface org.apache.flink.table.planner.plan.nodes.exec.ExecNodeTranslator
translateToPlan
-
Methods inherited from interface org.apache.flink.table.planner.plan.nodes.exec.FusionCodegenExecNode
supportFusionCodegen, translateToFusionCodegenSpec
-
-