Class NoOpTimestampsAndWatermarks<T>
- java.lang.Object
-
- org.apache.flink.streaming.api.operators.source.NoOpTimestampsAndWatermarks<T>
-
- Type Parameters:
T
- The type of the emitted records.
- All Implemented Interfaces:
TimestampsAndWatermarks<T>
@Internal public class NoOpTimestampsAndWatermarks<T> extends Object implements TimestampsAndWatermarks<T>
An implementation ofTimestampsAndWatermarks
where all watermarking/event-time operations are no-ops. This should be used in execution contexts where no watermarks are needed, for example in BATCH execution mode.
-
-
Nested Class Summary
-
Nested classes/interfaces inherited from interface org.apache.flink.streaming.api.operators.source.TimestampsAndWatermarks
TimestampsAndWatermarks.TimestampsAndWatermarksContextProvider, TimestampsAndWatermarks.WatermarkUpdateListener
-
-
Constructor Summary
Constructors Constructor Description NoOpTimestampsAndWatermarks(TimestampAssigner<T> timestamps)
Creates a newNoOpTimestampsAndWatermarks
with the given TimestampAssigner.
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description ReaderOutput<T>
createMainOutput(PushingAsyncDataInput.DataOutput<T> output, TimestampsAndWatermarks.WatermarkUpdateListener watermarkEmitted)
Creates the ReaderOutput for the source reader, than internally runs the timestamp extraction and watermark generation.void
emitImmediateWatermark(long wallClockTimestamp)
Emit a watermark immediately.void
pauseOrResumeSplits(Collection<String> splitsToPause, Collection<String> splitsToResume)
void
startPeriodicWatermarkEmits()
Starts emitting periodic watermarks, if this implementation produces watermarks, and if periodic watermarks are configured.void
stopPeriodicWatermarkEmits()
Stops emitting periodic watermarks.
-
-
-
Constructor Detail
-
NoOpTimestampsAndWatermarks
public NoOpTimestampsAndWatermarks(TimestampAssigner<T> timestamps)
Creates a newNoOpTimestampsAndWatermarks
with the given TimestampAssigner.
-
-
Method Detail
-
createMainOutput
public ReaderOutput<T> createMainOutput(PushingAsyncDataInput.DataOutput<T> output, TimestampsAndWatermarks.WatermarkUpdateListener watermarkEmitted)
Description copied from interface:TimestampsAndWatermarks
Creates the ReaderOutput for the source reader, than internally runs the timestamp extraction and watermark generation.- Specified by:
createMainOutput
in interfaceTimestampsAndWatermarks<T>
-
startPeriodicWatermarkEmits
public void startPeriodicWatermarkEmits()
Description copied from interface:TimestampsAndWatermarks
Starts emitting periodic watermarks, if this implementation produces watermarks, and if periodic watermarks are configured.Periodic watermarks are produced by periodically calling the
WatermarkGenerator.onPeriodicEmit(WatermarkOutput)
method of the underlying Watermark Generators.- Specified by:
startPeriodicWatermarkEmits
in interfaceTimestampsAndWatermarks<T>
-
stopPeriodicWatermarkEmits
public void stopPeriodicWatermarkEmits()
Description copied from interface:TimestampsAndWatermarks
Stops emitting periodic watermarks.- Specified by:
stopPeriodicWatermarkEmits
in interfaceTimestampsAndWatermarks<T>
-
emitImmediateWatermark
public void emitImmediateWatermark(long wallClockTimestamp)
Description copied from interface:TimestampsAndWatermarks
Emit a watermark immediately.- Specified by:
emitImmediateWatermark
in interfaceTimestampsAndWatermarks<T>
-
pauseOrResumeSplits
public void pauseOrResumeSplits(Collection<String> splitsToPause, Collection<String> splitsToResume)
- Specified by:
pauseOrResumeSplits
in interfaceTimestampsAndWatermarks<T>
-
-