Uses of Class
org.apache.flink.api.common.eventtime.Watermark
-
Packages that use Watermark Package Description org.apache.flink.api.common.eventtime org.apache.flink.api.connector.sink2 org.apache.flink.api.connector.source org.apache.flink.connector.testutils.source.reader org.apache.flink.runtime.source.coordinator org.apache.flink.streaming.api.functions.sink.legacy org.apache.flink.streaming.api.operators.source org.apache.flink.streaming.runtime.operators This package contains the operators that perform the stream transformations. -
-
Uses of Watermark in org.apache.flink.api.common.eventtime
Fields in org.apache.flink.api.common.eventtime declared as Watermark Modifier and Type Field Description static Watermark
Watermark. MAX_WATERMARK
The watermark that signifies end-of-event-time.Methods in org.apache.flink.api.common.eventtime with parameters of type Watermark Modifier and Type Method Description void
WatermarkOutput. emitWatermark(Watermark watermark)
Emits the given watermark. -
Uses of Watermark in org.apache.flink.api.connector.sink2
Methods in org.apache.flink.api.connector.sink2 with parameters of type Watermark Modifier and Type Method Description default void
SinkWriter. writeWatermark(Watermark watermark)
Adds a watermark to the writer. -
Uses of Watermark in org.apache.flink.api.connector.source
Methods in org.apache.flink.api.connector.source with parameters of type Watermark Modifier and Type Method Description void
ReaderOutput. emitWatermark(Watermark watermark)
Emits the given watermark. -
Uses of Watermark in org.apache.flink.connector.testutils.source.reader
Methods in org.apache.flink.connector.testutils.source.reader with parameters of type Watermark Modifier and Type Method Description void
SourceReaderTestBase.ValidatingSourceOutput. emitWatermark(Watermark watermark)
void
TestingReaderOutput. emitWatermark(Watermark watermark)
-
Uses of Watermark in org.apache.flink.runtime.source.coordinator
Constructors in org.apache.flink.runtime.source.coordinator with parameters of type Watermark Constructor Description WatermarkElement(Watermark watermark)
-
Uses of Watermark in org.apache.flink.streaming.api.functions.sink.legacy
Methods in org.apache.flink.streaming.api.functions.sink.legacy with parameters of type Watermark Modifier and Type Method Description default void
SinkFunction. writeWatermark(Watermark watermark)
Deprecated.Writes the given watermark to the sink. -
Uses of Watermark in org.apache.flink.streaming.api.operators.source
Methods in org.apache.flink.streaming.api.operators.source with parameters of type Watermark Modifier and Type Method Description void
SourceOutputWithWatermarks. emitWatermark(Watermark watermark)
void
WatermarkToDataOutput. emitWatermark(Watermark watermark)
-
Uses of Watermark in org.apache.flink.streaming.runtime.operators
Methods in org.apache.flink.streaming.runtime.operators with parameters of type Watermark Modifier and Type Method Description void
TimestampsAndWatermarksOperator.WatermarkEmitter. emitWatermark(Watermark watermark)
-