Uses of Class
org.apache.flink.streaming.api.watermark.Watermark
-
-
Uses of Watermark in org.apache.flink.connector.file.table.stream
Methods in org.apache.flink.connector.file.table.stream with parameters of type Watermark Modifier and Type Method Description void
AbstractStreamingWriter. processWatermark(Watermark mark)
void
PartitionCommitter. processWatermark(Watermark mark)
-
Uses of Watermark in org.apache.flink.runtime.asyncprocessing.operators
Methods in org.apache.flink.runtime.asyncprocessing.operators with parameters of type Watermark Modifier and Type Method Description void
AbstractAsyncStateStreamOperator. processWatermark(Watermark mark)
void
AbstractAsyncStateStreamOperatorV2. processWatermark(Watermark mark)
-
Uses of Watermark in org.apache.flink.state.api.output.operators
Methods in org.apache.flink.state.api.output.operators with parameters of type Watermark Modifier and Type Method Description void
StateBootstrapWrapperOperator. processWatermark(Watermark mark)
-
Uses of Watermark in org.apache.flink.streaming.api.functions.source
Methods in org.apache.flink.streaming.api.functions.source with parameters of type Watermark Modifier and Type Method Description void
ContinuousFileReaderOperator. processWatermark(Watermark mark)
-
Uses of Watermark in org.apache.flink.streaming.api.functions.source.legacy
Methods in org.apache.flink.streaming.api.functions.source.legacy with parameters of type Watermark Modifier and Type Method Description void
SourceFunction.SourceContext. emitWatermark(Watermark mark)
Emits the givenWatermark
. -
Uses of Watermark in org.apache.flink.streaming.api.functions.timestamps
Methods in org.apache.flink.streaming.api.functions.timestamps that return Watermark Modifier and Type Method Description Watermark
AscendingTimestampExtractor. getCurrentWatermark()
Deprecated.Watermark
BoundedOutOfOrdernessTimestampExtractor. getCurrentWatermark()
-
Uses of Watermark in org.apache.flink.streaming.api.operators
Methods in org.apache.flink.streaming.api.operators with parameters of type Watermark Modifier and Type Method Description void
InternalTimeServiceManager. advanceWatermark(Watermark watermark)
Advances the Watermark of all managedtimer services
, potentially firing event time timers.void
InternalTimeServiceManagerImpl. advanceWatermark(Watermark watermark)
void
CountingOutput. emitWatermark(Watermark mark)
void
Output. emitWatermark(Watermark mark)
Emits aWatermark
from an operator.void
TimestampedCollector. emitWatermark(Watermark mark)
void
MailboxWatermarkProcessor. emitWatermarkInsideMailbox(Watermark mark)
void
OnWatermarkCallback. onWatermark(KEY key, Watermark watermark)
The action to be triggered upon reception of a watermark.void
AbstractInput. processWatermark(Watermark mark)
void
AbstractStreamOperator. processWatermark(Watermark mark)
void
AbstractStreamOperatorV2. processWatermark(Watermark mark)
void
Input. processWatermark(Watermark mark)
Processes aWatermark
that arrived on the first input of this two-input operator.void
ProcessOperator. processWatermark(Watermark mark)
void
StreamSink. processWatermark(Watermark mark)
void
AbstractStreamOperator. processWatermark1(Watermark mark)
void
TwoInputStreamOperator. processWatermark1(Watermark mark)
Processes aWatermark
that arrived on the first input of this two-input operator.void
AbstractStreamOperator. processWatermark2(Watermark mark)
void
TwoInputStreamOperator. processWatermark2(Watermark mark)
Processes aWatermark
that arrived on the second input of this two-input operator.protected void
AbstractStreamOperatorV2. reportWatermark(Watermark mark, int inputId)
boolean
InternalTimeServiceManager. tryAdvanceWatermark(Watermark watermark, InternalTimeServiceManager.ShouldStopAdvancingFn shouldStopAdvancingFn)
Try toInternalTimeServiceManager.advanceWatermark(Watermark)
, but ifInternalTimeServiceManager.ShouldStopAdvancingFn
returnstrue
, stop the advancement and return as soon as possible.boolean
InternalTimeServiceManagerImpl. tryAdvanceWatermark(Watermark watermark, InternalTimeServiceManager.ShouldStopAdvancingFn shouldStopAdvancingFn)
-
Uses of Watermark in org.apache.flink.streaming.api.operators.async
Methods in org.apache.flink.streaming.api.operators.async with parameters of type Watermark Modifier and Type Method Description void
AsyncWaitOperator. processWatermark(Watermark mark)
-
Uses of Watermark in org.apache.flink.streaming.api.operators.co
Methods in org.apache.flink.streaming.api.operators.co with parameters of type Watermark Modifier and Type Method Description void
CoBroadcastWithNonKeyedOperator. processWatermark(Watermark mark)
void
CoProcessOperator. processWatermark(Watermark mark)
-
Uses of Watermark in org.apache.flink.streaming.api.operators.python
Methods in org.apache.flink.streaming.api.operators.python with parameters of type Watermark Modifier and Type Method Description void
AbstractPythonFunctionOperator. processWatermark(Watermark mark)
-
Uses of Watermark in org.apache.flink.streaming.api.operators.python.embedded
Methods in org.apache.flink.streaming.api.operators.python.embedded with parameters of type Watermark Modifier and Type Method Description void
EmbeddedPythonCoProcessOperator. processWatermark(Watermark mark)
void
EmbeddedPythonProcessOperator. processWatermark(Watermark mark)
-
Uses of Watermark in org.apache.flink.streaming.api.operators.python.process
Methods in org.apache.flink.streaming.api.operators.python.process with parameters of type Watermark Modifier and Type Method Description void
ExternalPythonCoProcessOperator. processWatermark(Watermark mark)
void
ExternalPythonProcessOperator. processWatermark(Watermark mark)
-
Uses of Watermark in org.apache.flink.streaming.api.operators.sorted.state
Methods in org.apache.flink.streaming.api.operators.sorted.state with parameters of type Watermark Modifier and Type Method Description void
BatchExecutionInternalTimeServiceManager. advanceWatermark(Watermark watermark)
boolean
BatchExecutionInternalTimeServiceManager. tryAdvanceWatermark(Watermark watermark, InternalTimeServiceManager.ShouldStopAdvancingFn shouldStopAdvancingFn)
-
Uses of Watermark in org.apache.flink.streaming.api.watermark
Subclasses of Watermark in org.apache.flink.streaming.api.watermark Modifier and Type Class Description class
InternalWatermark
TheWatermark
that contains extra information to be used internally.Fields in org.apache.flink.streaming.api.watermark declared as Watermark Modifier and Type Field Description static Watermark
Watermark. MAX_WATERMARK
The watermark that signifies end-of-event-time.static Watermark
Watermark. UNINITIALIZED
The watermark that signifies is used before any actual watermark has been generated. -
Uses of Watermark in org.apache.flink.streaming.runtime.io
Methods in org.apache.flink.streaming.runtime.io with parameters of type Watermark Modifier and Type Method Description void
FinishedDataOutput. emitWatermark(Watermark watermark)
void
PushingAsyncDataInput.DataOutput. emitWatermark(Watermark watermark)
void
RecordWriterOutput. emitWatermark(Watermark mark)
-
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. processWatermark(Watermark mark)
Override the base implementation to completely ignore watermarks propagated from upstream, except for the "end of time" watermark. -
Uses of Watermark in org.apache.flink.streaming.runtime.operators.util
Methods in org.apache.flink.streaming.runtime.operators.util that return Watermark Modifier and Type Method Description Watermark
WatermarkStrategyWithPunctuatedWatermarks. checkAndGetNextWatermark(T lastElement, long extractedTimestamp)
Asks this implementation if it wants to emit a watermark.Watermark
WatermarkStrategyWithPeriodicWatermarks. getCurrentWatermark()
Returns the current watermark. -
Uses of Watermark in org.apache.flink.streaming.runtime.streamrecord
Methods in org.apache.flink.streaming.runtime.streamrecord that return Watermark Modifier and Type Method Description Watermark
StreamElement. asWatermark()
Casts this element into a Watermark. -
Uses of Watermark in org.apache.flink.streaming.runtime.tasks
Methods in org.apache.flink.streaming.runtime.tasks with parameters of type Watermark Modifier and Type Method Description void
FinishedOnRestoreMainOperatorOutput. emitWatermark(Watermark mark)
void
SourceOperatorStreamTask.AsyncDataOutputToOutput. emitWatermark(Watermark watermark)
void
FinishedOnRestoreInput. processWatermark(Watermark watermark)
-
Uses of Watermark in org.apache.flink.streaming.runtime.watermarkstatus
Methods in org.apache.flink.streaming.runtime.watermarkstatus with parameters of type Watermark Modifier and Type Method Description void
StatusWatermarkValve. inputWatermark(Watermark watermark, int channelIndex, PushingAsyncDataInput.DataOutput<?> output)
Feed aWatermark
into the valve. -
Uses of Watermark in org.apache.flink.table.runtime.operators
Methods in org.apache.flink.table.runtime.operators with parameters of type Watermark Modifier and Type Method Description void
TableStreamOperator. processWatermark(Watermark mark)
-
Uses of Watermark in org.apache.flink.table.runtime.operators.aggregate.window
Methods in org.apache.flink.table.runtime.operators.aggregate.window with parameters of type Watermark Modifier and Type Method Description void
LocalSlicingWindowAggOperator. processWatermark(Watermark mark)
-
Uses of Watermark in org.apache.flink.table.runtime.operators.bundle
Methods in org.apache.flink.table.runtime.operators.bundle with parameters of type Watermark Modifier and Type Method Description void
AbstractMapBundleOperator. processWatermark(Watermark mark)
-
Uses of Watermark in org.apache.flink.table.runtime.operators.join
Methods in org.apache.flink.table.runtime.operators.join with parameters of type Watermark Modifier and Type Method Description void
KeyedCoProcessOperatorWithWatermarkDelay. processWatermark(Watermark mark)
-
Uses of Watermark in org.apache.flink.table.runtime.operators.join.stream
Methods in org.apache.flink.table.runtime.operators.join.stream with parameters of type Watermark Modifier and Type Method Description void
MiniBatchStreamingJoinOperator. processWatermark1(Watermark mark)
void
MiniBatchStreamingJoinOperator. processWatermark2(Watermark mark)
-
Uses of Watermark in org.apache.flink.table.runtime.operators.multipleinput.input
Methods in org.apache.flink.table.runtime.operators.multipleinput.input with parameters of type Watermark Modifier and Type Method Description void
FirstInputOfTwoInput. processWatermark(Watermark mark)
void
OneInput. processWatermark(Watermark mark)
void
SecondInputOfTwoInput. processWatermark(Watermark mark)
-
Uses of Watermark in org.apache.flink.table.runtime.operators.multipleinput.output
Methods in org.apache.flink.table.runtime.operators.multipleinput.output with parameters of type Watermark Modifier and Type Method Description void
BroadcastingOutput. emitWatermark(Watermark mark)
void
CopyingSecondInputOfTwoInputStreamOperatorOutput. emitWatermark(Watermark mark)
void
FirstInputOfTwoInputStreamOperatorOutput. emitWatermark(Watermark mark)
void
OneInputStreamOperatorOutput. emitWatermark(Watermark mark)
void
SecondInputOfTwoInputStreamOperatorOutput. emitWatermark(Watermark mark)
-
Uses of Watermark in org.apache.flink.table.runtime.operators.sink
Methods in org.apache.flink.table.runtime.operators.sink with parameters of type Watermark Modifier and Type Method Description void
SinkOperator. processWatermark(Watermark mark)
-
Uses of Watermark in org.apache.flink.table.runtime.operators.source
Methods in org.apache.flink.table.runtime.operators.source with parameters of type Watermark Modifier and Type Method Description void
InputConversionOperator. processWatermark(Watermark mark)
-
Uses of Watermark in org.apache.flink.table.runtime.operators.window.tvf.common
Methods in org.apache.flink.table.runtime.operators.window.tvf.common with parameters of type Watermark Modifier and Type Method Description void
WindowAggOperator. processWatermark(Watermark mark)
-
Uses of Watermark in org.apache.flink.table.runtime.operators.wmassigners
Methods in org.apache.flink.table.runtime.operators.wmassigners that return Watermark Modifier and Type Method Description Watermark
PunctuatedWatermarkStrategyWrapper. checkAndGetNextWatermark(RowData row, long extractedTimestamp)
Watermark
PeriodicWatermarkAssignerWrapper. getCurrentWatermark()
Methods in org.apache.flink.table.runtime.operators.wmassigners with parameters of type Watermark Modifier and Type Method Description void
ProcTimeMiniBatchAssignerOperator. processWatermark(Watermark mark)
Override the base implementation to completely ignore watermarks propagated from upstream (we rely only on theWatermarkStrategyWithPeriodicWatermarks
to emit watermarks from here).void
RowTimeMiniBatchAssginerOperator. processWatermark(Watermark mark)
void
WatermarkAssignerOperator. processWatermark(Watermark mark)
Override the base implementation to completely ignore watermarks propagated from upstream (we rely only on theWatermarkGenerator
to emit watermarks from here). -
Uses of Watermark in org.apache.flink.table.sources.wmstrategies
Methods in org.apache.flink.table.sources.wmstrategies that return Watermark Modifier and Type Method Description Watermark
AscendingTimestamps. getWatermark()
Watermark
BoundedOutOfOrderTimestamps. getWatermark()
abstract Watermark
PeriodicWatermarkAssigner. getWatermark()
Returns the current watermark.abstract Watermark
PunctuatedWatermarkAssigner. getWatermark(Row row, long timestamp)
Returns the watermark for the current row or null if no watermark should be generated.
-