Interface Output<T>
-
- Type Parameters:
T
- The type of the elements that can be emitted.
- All Superinterfaces:
org.apache.flink.util.Collector<T>
- All Known Subinterfaces:
OutputWithChainingCheck<OUT>
,WatermarkGaugeExposingOutput<T>
- All Known Implementing Classes:
CountingOutput
,FinishedOnRestoreMainOperatorOutput
,RecordWriterOutput
,TimestampedCollector
@PublicEvolving public interface Output<T> extends org.apache.flink.util.Collector<T>
AStreamOperator
is supplied with an object of this interface that can be used to emit elements and other messages, such as barriers and watermarks, from an operator.
-
-
Method Summary
All Methods Instance Methods Abstract Methods Modifier and Type Method Description <X> void
collect(org.apache.flink.util.OutputTag<X> outputTag, StreamRecord<X> record)
Emits a record to the side output identified by the givenOutputTag
.void
emitLatencyMarker(LatencyMarker latencyMarker)
void
emitRecordAttributes(RecordAttributes recordAttributes)
Emits aRecordAttributes
from an operator.void
emitWatermark(Watermark mark)
Emits aWatermark
from an operator.void
emitWatermarkStatus(WatermarkStatus watermarkStatus)
-
-
-
Method Detail
-
emitWatermark
void emitWatermark(Watermark mark)
Emits aWatermark
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 givenOutputTag
.- Parameters:
record
- The record to collect.
-
emitLatencyMarker
void emitLatencyMarker(LatencyMarker latencyMarker)
-
emitRecordAttributes
@Experimental void emitRecordAttributes(RecordAttributes recordAttributes)
Emits aRecordAttributes
from an operator. This element is broadcast to all downstream operators.
-
-