Class StreamExecWindowAggregateBase
- java.lang.Object
-
- org.apache.flink.table.planner.plan.nodes.exec.ExecNodeBase<RowData>
-
- org.apache.flink.table.planner.plan.nodes.exec.stream.StreamExecAggregateBase
-
- org.apache.flink.table.planner.plan.nodes.exec.stream.StreamExecWindowAggregateBase
-
- All Implemented Interfaces:
ExecNode<RowData>
,ExecNodeTranslator<RowData>
,FusionCodegenExecNode
,SingleTransformationTranslator<RowData>
,StreamExecNode<RowData>
- Direct Known Subclasses:
StreamExecGlobalWindowAggregate
,StreamExecLocalWindowAggregate
,StreamExecWindowAggregate
public abstract class StreamExecWindowAggregateBase extends StreamExecAggregateBase
The base class for window aggregateExecNode
.
-
-
Field Summary
Fields Modifier and Type Field Description static String
FIELD_NAME_NAMED_WINDOW_PROPERTIES
static String
FIELD_NAME_WINDOWING
static long
WINDOW_AGG_MEMORY_RATIO
-
Fields inherited from class org.apache.flink.table.planner.plan.nodes.exec.stream.StreamExecAggregateBase
FIELD_NAME_AGG_CALL_NEED_RETRACTIONS, FIELD_NAME_AGG_CALLS, FIELD_NAME_GENERATE_UPDATE_BEFORE, FIELD_NAME_GROUPING, FIELD_NAME_NEED_RETRACTION
-
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 Modifier Constructor Description protected
StreamExecWindowAggregateBase(int id, ExecNodeContext context, ReadableConfig persistedConfig, List<InputProperty> inputProperties, LogicalType outputType, String description)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description protected LogicalType[]
convertToLogicalTypes(DataType[] dataTypes)
protected WindowAssigner
createWindowAssigner(WindowingStrategy windowingStrategy, ZoneId shiftTimeZone)
protected boolean
isAlignedWindow(WindowSpec window)
-
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
-
WINDOW_AGG_MEMORY_RATIO
public static final long WINDOW_AGG_MEMORY_RATIO
- See Also:
- Constant Field Values
-
FIELD_NAME_WINDOWING
public static final String FIELD_NAME_WINDOWING
- See Also:
- Constant Field Values
-
FIELD_NAME_NAMED_WINDOW_PROPERTIES
public static final String FIELD_NAME_NAMED_WINDOW_PROPERTIES
- See Also:
- Constant Field Values
-
-
Constructor Detail
-
StreamExecWindowAggregateBase
protected StreamExecWindowAggregateBase(int id, ExecNodeContext context, ReadableConfig persistedConfig, List<InputProperty> inputProperties, LogicalType outputType, String description)
-
-
Method Detail
-
createWindowAssigner
protected WindowAssigner createWindowAssigner(WindowingStrategy windowingStrategy, ZoneId shiftTimeZone)
-
isAlignedWindow
protected boolean isAlignedWindow(WindowSpec window)
-
convertToLogicalTypes
protected LogicalType[] convertToLogicalTypes(DataType[] dataTypes)
-
-