Class StreamExecWindowAggregate
- 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
-
- org.apache.flink.table.planner.plan.nodes.exec.stream.StreamExecWindowAggregate
-
- All Implemented Interfaces:
ExecNode<RowData>
,ExecNodeTranslator<RowData>
,FusionCodegenExecNode
,SingleTransformationTranslator<RowData>
,StreamExecNode<RowData>
@ExecNodeMetadata(name="stream-exec-window-aggregate", version=1, consumedOptions="table.local-time-zone", producedTransformations="window-aggregate", minPlanVersion=v1_15, minStateVersion=v1_15) public class StreamExecWindowAggregate extends StreamExecWindowAggregateBase
StreamExecNode
for window table-valued based aggregate.The differences between
StreamExecWindowAggregate
andStreamExecGroupWindowAggregate
is that, this node is translated from window TVF syntax, but the other is from the legacy GROUP WINDOW FUNCTION syntax. In the long future,StreamExecGroupWindowAggregate
will be dropped.
-
-
Field Summary
Fields Modifier and Type Field Description static String
FIELD_NAME_NAMED_WINDOW_PROPERTIES
static String
FIELD_NAME_WINDOWING
static String
WINDOW_AGGREGATE_TRANSFORMATION
-
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 Constructor Description StreamExecWindowAggregate(int id, ExecNodeContext context, ReadableConfig persistedConfig, int[] grouping, org.apache.calcite.rel.core.AggregateCall[] aggCalls, WindowingStrategy windowing, NamedWindowProperty[] namedWindowProperties, Boolean needRetraction, List<InputProperty> inputProperties, RowType outputType, String description)
StreamExecWindowAggregate(ReadableConfig tableConfig, int[] grouping, org.apache.calcite.rel.core.AggregateCall[] aggCalls, WindowingStrategy windowing, NamedWindowProperty[] namedWindowProperties, Boolean needRetraction, InputProperty inputProperty, RowType outputType, String description)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description protected Transformation<RowData>
translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
Internal method, translates this node into a Flink operator.-
Methods inherited from class org.apache.flink.table.planner.plan.nodes.exec.stream.StreamExecWindowAggregateBase
convertToLogicalTypes, createWindowAssigner, isAlignedWindow
-
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
-
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_AGGREGATE_TRANSFORMATION
public static final String WINDOW_AGGREGATE_TRANSFORMATION
- 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
-
StreamExecWindowAggregate
public StreamExecWindowAggregate(ReadableConfig tableConfig, int[] grouping, org.apache.calcite.rel.core.AggregateCall[] aggCalls, WindowingStrategy windowing, NamedWindowProperty[] namedWindowProperties, Boolean needRetraction, InputProperty inputProperty, RowType outputType, String description)
-
StreamExecWindowAggregate
public StreamExecWindowAggregate(int id, ExecNodeContext context, ReadableConfig persistedConfig, int[] grouping, org.apache.calcite.rel.core.AggregateCall[] aggCalls, WindowingStrategy windowing, NamedWindowProperty[] namedWindowProperties, @Nullable Boolean needRetraction, List<InputProperty> inputProperties, RowType outputType, String description)
-
-
Method Detail
-
translateToPlanInternal
protected Transformation<RowData> translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
Description copied from class:ExecNodeBase
Internal method, translates this node into a Flink operator.- Specified by:
translateToPlanInternal
in classExecNodeBase<RowData>
- Parameters:
planner
- The planner.config
- per-ExecNode
configuration that contains the merged configuration from various layers which all the nodes implementing this method should use, instead of retrieving configuration from theplanner
. For more details checkExecNodeConfig
.
-
-