Interface Output<T>

    • Method Detail

      • emitWatermark

        void emitWatermark​(Watermark mark)
        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.

      • emitWatermarkStatus

        void emitWatermarkStatus​(WatermarkStatus watermarkStatus)
      • collect

        <X> void collect​(org.apache.flink.util.OutputTag<X> outputTag,
                         StreamRecord<X> record)
        Emits a record to the side output identified by the given OutputTag.
        Parameters:
        record - The record to collect.
      • emitLatencyMarker

        void emitLatencyMarker​(LatencyMarker latencyMarker)
      • emitRecordAttributes

        @Experimental
        void emitRecordAttributes​(RecordAttributes recordAttributes)
        Emits a RecordAttributes from an operator. This element is broadcast to all downstream operators.
      • emitWatermark

        @Experimental
        void emitWatermark​(WatermarkEvent watermark)
        Emits a Watermark from an operator, wrapped in a WatermarkEvent.