@ExecNodeMetadata(name="stream-exec-global-window-aggregate", version=1, consumedOptions="table.local-time-zone", producedTransformations="global-window-aggregate", minPlanVersion=v1_15, minStateVersion=v1_15) public class StreamExecGlobalWindowAggregate extends StreamExecWindowAggregateBase
ExecNode
for window table-valued based global aggregate.Modifier and Type | Field and Description |
---|---|
static String |
FIELD_NAME_LOCAL_AGG_INPUT_ROW_TYPE |
static String |
GLOBAL_WINDOW_AGGREGATE_TRANSFORMATION |
FIELD_NAME_NAMED_WINDOW_PROPERTIES, FIELD_NAME_WINDOWING, WINDOW_AGG_MEMORY_RATIO
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 |
---|
StreamExecGlobalWindowAggregate(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 localAggInputRowType,
RowType outputType,
String description) |
StreamExecGlobalWindowAggregate(ReadableConfig tableConfig,
int[] grouping,
org.apache.calcite.rel.core.AggregateCall[] aggCalls,
WindowingStrategy windowing,
NamedWindowProperty[] namedWindowProperties,
Boolean needRetraction,
InputProperty inputProperty,
RowType localAggInputRowType,
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.
|
convertToLogicalTypes, createWindowAssigner, isAlignedWindow
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 GLOBAL_WINDOW_AGGREGATE_TRANSFORMATION
public static final String FIELD_NAME_LOCAL_AGG_INPUT_ROW_TYPE
public StreamExecGlobalWindowAggregate(ReadableConfig tableConfig, int[] grouping, org.apache.calcite.rel.core.AggregateCall[] aggCalls, WindowingStrategy windowing, NamedWindowProperty[] namedWindowProperties, Boolean needRetraction, InputProperty inputProperty, RowType localAggInputRowType, RowType outputType, String description)
public StreamExecGlobalWindowAggregate(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 localAggInputRowType, 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.