Class BoundedOutOfOrderTimestamps
- java.lang.Object
-
- org.apache.flink.table.sources.wmstrategies.WatermarkStrategy
-
- org.apache.flink.table.sources.wmstrategies.PeriodicWatermarkAssigner
-
- org.apache.flink.table.sources.wmstrategies.BoundedOutOfOrderTimestamps
-
- All Implemented Interfaces:
Serializable
,org.apache.flink.table.legacy.descriptors.Descriptor
@PublicEvolving public final class BoundedOutOfOrderTimestamps extends PeriodicWatermarkAssigner
A watermark strategy for rowtime attributes which are out-of-order by a bounded time interval.Emits watermarks which are the maximum observed timestamp minus the specified delay.
- See Also:
- Serialized Form
-
-
Constructor Summary
Constructors Constructor Description BoundedOutOfOrderTimestamps(long delay)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description boolean
equals(Object o)
org.apache.flink.streaming.api.watermark.Watermark
getWatermark()
Returns the current watermark.int
hashCode()
void
nextTimestamp(long timestamp)
Updates the assigner with the next timestamp.Map<String,String>
toProperties()
-
-
-
Method Detail
-
nextTimestamp
public void nextTimestamp(long timestamp)
Description copied from class:PeriodicWatermarkAssigner
Updates the assigner with the next timestamp.- Specified by:
nextTimestamp
in classPeriodicWatermarkAssigner
- Parameters:
timestamp
- The next timestamp to update the assigner.
-
getWatermark
public org.apache.flink.streaming.api.watermark.Watermark getWatermark()
Description copied from class:PeriodicWatermarkAssigner
Returns the current watermark.- Specified by:
getWatermark
in classPeriodicWatermarkAssigner
- Returns:
- The current watermark.
-
toProperties
public Map<String,String> toProperties()
- Specified by:
toProperties
in interfaceorg.apache.flink.table.legacy.descriptors.Descriptor
- Overrides:
toProperties
in classorg.apache.flink.table.sources.wmstrategies.WatermarkStrategy
-
-