Modifier and Type | Method and Description |
---|---|
void |
DirectedOutput.emitWatermark(Watermark mark) |
Modifier and Type | Method and Description |
---|---|
Watermark |
AssignerWithPunctuatedWatermarks.checkAndGetNextWatermark(T lastElement,
long extractedTimestamp)
Asks this implementation if it wants to emit a watermark.
|
Watermark |
IngestionTimeExtractor.getCurrentWatermark() |
Watermark |
AssignerWithPeriodicWatermarks.getCurrentWatermark()
Returns the current watermark.
|
Modifier and Type | Method and Description |
---|---|
void |
SourceFunction.SourceContext.emitWatermark(Watermark mark)
Emits the given
Watermark . |
void |
ContinuousFileReaderOperator.processWatermark(Watermark mark) |
Modifier and Type | Method and Description |
---|---|
Watermark |
AscendingTimestampExtractor.getCurrentWatermark() |
Watermark |
BoundedOutOfOrdernessTimestampExtractor.getCurrentWatermark() |
Modifier and Type | Method and Description |
---|---|
void |
InternalTimeServiceManager.advanceWatermark(Watermark watermark) |
void |
Output.emitWatermark(Watermark mark)
Emits a
Watermark from an operator. |
void |
AbstractStreamOperator.CountingOutput.emitWatermark(Watermark mark) |
void |
OnWatermarkCallback.onWatermark(KEY key,
Watermark watermark)
The action to be triggered upon reception of a watermark.
|
void |
ProcessOperator.processWatermark(Watermark mark) |
void |
StreamSink.processWatermark(Watermark mark) |
void |
OneInputStreamOperator.processWatermark(Watermark mark)
Processes a
Watermark . |
void |
AbstractStreamOperator.processWatermark(Watermark mark) |
void |
TwoInputStreamOperator.processWatermark1(Watermark mark)
Processes a
Watermark that arrived on the first input of this two-input operator. |
void |
AbstractStreamOperator.processWatermark1(Watermark mark) |
void |
TwoInputStreamOperator.processWatermark2(Watermark mark)
Processes a
Watermark that arrived on the second input of this two-input operator. |
void |
AbstractStreamOperator.processWatermark2(Watermark mark) |
Modifier and Type | Method and Description |
---|---|
void |
AsyncWaitOperator.processWatermark(Watermark mark) |
Modifier and Type | Method and Description |
---|---|
Watermark |
AsyncWatermarkResult.getWatermark()
Get the resulting watermark.
|
Watermark |
WatermarkQueueEntry.getWatermark() |
Modifier and Type | Method and Description |
---|---|
protected CompletableFuture<Watermark> |
WatermarkQueueEntry.getFuture() |
Constructor and Description |
---|
WatermarkQueueEntry(Watermark watermark) |
Modifier and Type | Method and Description |
---|---|
void |
CoProcessOperator.processWatermark(Watermark mark) |
void |
CoBroadcastWithNonKeyedOperator.processWatermark(Watermark mark) |
Modifier and Type | Field and Description |
---|---|
static Watermark |
Watermark.MAX_WATERMARK
The watermark that signifies end-of-event-time.
|
Modifier and Type | Method and Description |
---|---|
Watermark |
KafkaTopicPartitionStateWithPunctuatedWatermarks.checkAndGetNewWatermark(T record,
long timestamp) |
Modifier and Type | Method and Description |
---|---|
Watermark |
CustomWatermarkExtractor.getCurrentWatermark() |
Modifier and Type | Method and Description |
---|---|
void |
RecordWriterOutput.emitWatermark(Watermark mark) |
Modifier and Type | Method and Description |
---|---|
void |
ExtractTimestampsOperator.processWatermark(Watermark mark)
Deprecated.
|
void |
TimestampsAndPeriodicWatermarksOperator.processWatermark(Watermark mark)
Override the base implementation to completely ignore watermarks propagated from
upstream (we rely only on the
AssignerWithPeriodicWatermarks to emit
watermarks from here). |
void |
TimestampsAndPunctuatedWatermarksOperator.processWatermark(Watermark mark)
Override the base implementation to completely ignore watermarks propagated from
upstream (we rely only on the
AssignerWithPunctuatedWatermarks to emit
watermarks from here). |
Modifier and Type | Method and Description |
---|---|
Watermark |
StreamElement.asWatermark()
Casts this element into a Watermark.
|
Modifier and Type | Method and Description |
---|---|
void |
StatusWatermarkValve.ValveOutputHandler.handleWatermark(Watermark watermark) |
void |
StatusWatermarkValve.inputWatermark(Watermark watermark,
int channelIndex)
Feed a
Watermark into the valve. |
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.