Interface TableAggsHandleFunction

  • All Superinterfaces:
    AggsHandleFunctionBase, org.apache.flink.api.common.functions.Function, Serializable

    public interface TableAggsHandleFunction
    extends AggsHandleFunctionBase
    The base class for handling table aggregate functions.

    It is code generated to handle all TableAggregateFunctions together in an aggregation.

    It is the entry point for aggregate operators to operate all TableAggregateFunctions.

    • Method Detail

      • emitValue

        void emitValue​(org.apache.flink.util.Collector<org.apache.flink.table.data.RowData> out,
                       org.apache.flink.table.data.RowData currentKey,
                       boolean isRetract)
                throws Exception
        Emit the result of the table aggregation through the collector.
        Parameters:
        out - the collector used to emit records.
        currentKey - the current group key.
        isRetract - the retraction flag which indicates whether emit retract values.
        Throws:
        Exception