Class StreamExecPythonGroupAggregate

    • Field Detail

      • PYTHON_GROUP_AGGREGATE_TRANSFORMATION

        public static final String PYTHON_GROUP_AGGREGATE_TRANSFORMATION
        See Also:
        Constant Field Values
    • Constructor Detail

      • StreamExecPythonGroupAggregate

        public StreamExecPythonGroupAggregate​(ReadableConfig tableConfig,
                                              int[] grouping,
                                              org.apache.calcite.rel.core.AggregateCall[] aggCalls,
                                              boolean[] aggCallNeedRetractions,
                                              boolean generateUpdateBefore,
                                              boolean needRetraction,
                                              InputProperty inputProperty,
                                              RowType outputType,
                                              String description)
      • StreamExecPythonGroupAggregate

        public StreamExecPythonGroupAggregate​(int id,
                                              ExecNodeContext context,
                                              ReadableConfig persistedConfig,
                                              int[] grouping,
                                              org.apache.calcite.rel.core.AggregateCall[] aggCalls,
                                              boolean[] aggCallNeedRetractions,
                                              boolean generateUpdateBefore,
                                              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 class ExecNodeBase<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 the planner. For more details check ExecNodeConfig.