Interface TableAggregateFunction.RetractableCollector<T>

  • All Superinterfaces:
    org.apache.flink.util.Collector<T>
    Enclosing class:
    TableAggregateFunction<T,​ACC>

    @PublicEvolving
    public static interface TableAggregateFunction.RetractableCollector<T>
    extends org.apache.flink.util.Collector<T>
    Collects a record and forwards it. The collector can output retract messages with the retract method. Note: This collector can only be used in the emitUpdateWithRetract() method.
    • Method Summary

      All Methods Instance Methods Abstract Methods 
      Modifier and Type Method Description
      void retract​(T record)
      Retract a record.
      • Methods inherited from interface org.apache.flink.util.Collector

        close, collect
    • Method Detail

      • retract

        void retract​(T record)
        Retract a record.
        Parameters:
        record - The record to retract.