Class BatchExecOverAggregateBase
- java.lang.Object
-
- org.apache.flink.table.planner.plan.nodes.exec.ExecNodeBase<RowData>
-
- org.apache.flink.table.planner.plan.nodes.exec.batch.BatchExecOverAggregateBase
-
- All Implemented Interfaces:
BatchExecNode<RowData>
,InputSortedExecNode<RowData>
,ExecNode<RowData>
,ExecNodeTranslator<RowData>
,FusionCodegenExecNode
,SingleTransformationTranslator<RowData>
- Direct Known Subclasses:
BatchExecOverAggregate
,BatchExecPythonOverAggregate
public abstract class BatchExecOverAggregateBase extends ExecNodeBase<RowData> implements InputSortedExecNode<RowData>, SingleTransformationTranslator<RowData>
BatchExecNode
base class for sort-based over window aggregate.
-
-
Nested Class Summary
Nested Classes Modifier and Type Class Description static class
BatchExecOverAggregateBase.OverWindowMode
OverWindowMode describes the mode of a group in over window.
-
Field Summary
Fields Modifier and Type Field Description protected OverSpec
overSpec
-
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
-
-
Constructor Summary
Constructors Constructor Description BatchExecOverAggregateBase(int id, ExecNodeContext context, ReadableConfig persistedConfig, OverSpec overSpec, InputProperty inputProperty, RowType outputType, String description)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description protected boolean
containSizeBasedWindowFunction(OverSpec.GroupSpec group)
protected List<org.apache.calcite.rex.RexLiteral>
getConstants()
protected RowType
getInputTypeWithConstants()
protected BatchExecOverAggregateBase.OverWindowMode
inferGroupMode(OverSpec.GroupSpec group)
Infer the over window mode based on given group info.protected boolean
isSlidingWindow(OverSpec.GroupSpec group)
protected boolean
isUnboundedFollowingWindow(OverSpec.GroupSpec group)
protected boolean
isUnboundedPrecedingWindow(OverSpec.GroupSpec group)
protected boolean
isUnboundedWindow(OverSpec.GroupSpec group)
-
Methods inherited from class org.apache.flink.table.planner.plan.nodes.exec.ExecNodeBase
accept, createFormattedTransformationDescription, createFormattedTransformationName, createTransformationDescription, createTransformationMeta, createTransformationMeta, createTransformationName, createTransformationUid, getContextFromAnnotation, getDescription, getId, getInputEdges, getInputProperties, getOutputType, getPersistedConfig, getSimplifiedName, getTransformation, inputsContainSingleton, replaceInputEdge, setCompiled, setInputEdges, supportFusionCodegen, translateToFusionCodegenSpec, translateToFusionCodegenSpecInternal, translateToPlan, translateToPlanInternal
-
Methods inherited from class java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
-
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
-
-
-
-
Field Detail
-
overSpec
protected final OverSpec overSpec
-
-
Constructor Detail
-
BatchExecOverAggregateBase
public BatchExecOverAggregateBase(int id, ExecNodeContext context, ReadableConfig persistedConfig, OverSpec overSpec, InputProperty inputProperty, RowType outputType, String description)
-
-
Method Detail
-
getInputTypeWithConstants
protected RowType getInputTypeWithConstants()
-
isUnboundedWindow
protected boolean isUnboundedWindow(OverSpec.GroupSpec group)
-
isUnboundedPrecedingWindow
protected boolean isUnboundedPrecedingWindow(OverSpec.GroupSpec group)
-
isUnboundedFollowingWindow
protected boolean isUnboundedFollowingWindow(OverSpec.GroupSpec group)
-
isSlidingWindow
protected boolean isSlidingWindow(OverSpec.GroupSpec group)
-
getConstants
protected List<org.apache.calcite.rex.RexLiteral> getConstants()
-
containSizeBasedWindowFunction
protected boolean containSizeBasedWindowFunction(OverSpec.GroupSpec group)
-
inferGroupMode
protected BatchExecOverAggregateBase.OverWindowMode inferGroupMode(OverSpec.GroupSpec group)
Infer the over window mode based on given group info.
-
-