@ExecNodeMetadata(name="stream-exec-group-window-aggregate", version=1, consumedOptions={"table.local-time-zone","table.exec.mini-batch.enabled","table.exec.mini-batch.size"}, producedTransformations="group-window-aggregate", minPlanVersion=v1_15, minStateVersion=v1_15) public class StreamExecGroupWindowAggregate extends StreamExecAggregateBase
ExecNode
for either group window aggregate or group window table aggregate.
The differences between StreamExecWindowAggregate
and StreamExecGroupWindowAggregate
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.
Modifier and Type | Field and Description |
---|---|
static String |
FIELD_NAME_NAMED_WINDOW_PROPERTIES |
static String |
FIELD_NAME_WINDOW |
static String |
GROUP_WINDOW_AGGREGATE_TRANSFORMATION |
FIELD_NAME_AGG_CALL_NEED_RETRACTIONS, FIELD_NAME_AGG_CALLS, FIELD_NAME_GENERATE_UPDATE_BEFORE, FIELD_NAME_GROUPING, FIELD_NAME_NEED_RETRACTION
FIELD_NAME_CONFIGURATION, FIELD_NAME_DESCRIPTION, FIELD_NAME_ID, FIELD_NAME_INPUT_PROPERTIES, FIELD_NAME_OUTPUT_TYPE, FIELD_NAME_STATE, FIELD_NAME_TYPE
Constructor and Description |
---|
StreamExecGroupWindowAggregate(int id,
ExecNodeContext context,
ReadableConfig persistedConfig,
int[] grouping,
org.apache.calcite.rel.core.AggregateCall[] aggCalls,
org.apache.flink.table.planner.plan.logical.LogicalWindow window,
NamedWindowProperty[] namedWindowProperties,
boolean needRetraction,
List<InputProperty> inputProperties,
RowType outputType,
String description) |
StreamExecGroupWindowAggregate(ReadableConfig tableConfig,
int[] grouping,
org.apache.calcite.rel.core.AggregateCall[] aggCalls,
org.apache.flink.table.planner.plan.logical.LogicalWindow window,
NamedWindowProperty[] namedWindowProperties,
boolean needRetraction,
InputProperty inputProperty,
RowType outputType,
String description) |
Modifier and Type | Method and Description |
---|---|
protected Transformation<RowData> |
translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner,
ExecNodeConfig config)
Internal method, translates this node into a Flink operator.
|
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
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
accept, getDescription, getId, getInputEdges, getInputProperties, getOutputType, replaceInputEdge, setCompiled, setInputEdges
translateToPlan
supportFusionCodegen, translateToFusionCodegenSpec
public static final String GROUP_WINDOW_AGGREGATE_TRANSFORMATION
public static final String FIELD_NAME_WINDOW
public static final String FIELD_NAME_NAMED_WINDOW_PROPERTIES
public StreamExecGroupWindowAggregate(ReadableConfig tableConfig, int[] grouping, org.apache.calcite.rel.core.AggregateCall[] aggCalls, org.apache.flink.table.planner.plan.logical.LogicalWindow window, NamedWindowProperty[] namedWindowProperties, boolean needRetraction, InputProperty inputProperty, RowType outputType, String description)
public StreamExecGroupWindowAggregate(int id, ExecNodeContext context, ReadableConfig persistedConfig, int[] grouping, org.apache.calcite.rel.core.AggregateCall[] aggCalls, org.apache.flink.table.planner.plan.logical.LogicalWindow window, NamedWindowProperty[] namedWindowProperties, boolean needRetraction, List<InputProperty> inputProperties, RowType outputType, String description)
protected Transformation<RowData> translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
ExecNodeBase
translateToPlanInternal
in class ExecNodeBase<RowData>
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 the planner
. For more details check ExecNodeConfig
.Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.