Class CountingOutput<OUT>

    • Method Detail

      • emitWatermark

        public void emitWatermark​(Watermark mark)
        Description copied from interface: Output
        Emits a Watermark from an operator. This watermark is broadcast to all downstream operators.

        A watermark specifies that no element with a timestamp lower or equal to the watermark timestamp will be emitted in the future.

        Specified by:
        emitWatermark in interface Output<OUT>
      • collect

        public void collect​(StreamRecord<OUT> record)
        Specified by:
        collect in interface org.apache.flink.util.Collector<OUT>
      • collect

        public <X> void collect​(org.apache.flink.util.OutputTag<X> outputTag,
                                StreamRecord<X> record)
        Description copied from interface: Output
        Emits a record to the side output identified by the given OutputTag.
        Specified by:
        collect in interface Output<OUT>
        record - The record to collect.
      • close

        public void close()
        Specified by:
        close in interface AutoCloseable
        Specified by:
        close in interface Closeable
        Specified by:
        close in interface org.apache.flink.util.Collector<OUT>