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 booleanequals(Object o)org.apache.flink.streaming.api.watermark.WatermarkgetWatermark()Returns the current watermark.inthashCode()voidnextTimestamp(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:PeriodicWatermarkAssignerUpdates the assigner with the next timestamp.- Specified by:
nextTimestampin classPeriodicWatermarkAssigner- Parameters:
timestamp- The next timestamp to update the assigner.
-
getWatermark
public org.apache.flink.streaming.api.watermark.Watermark getWatermark()
Description copied from class:PeriodicWatermarkAssignerReturns the current watermark.- Specified by:
getWatermarkin classPeriodicWatermarkAssigner- Returns:
- The current watermark.
-
toProperties
public Map<String,String> toProperties()
- Specified by:
toPropertiesin interfaceorg.apache.flink.table.legacy.descriptors.Descriptor- Overrides:
toPropertiesin classorg.apache.flink.table.sources.wmstrategies.WatermarkStrategy
-
-