Class 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 Detail

      • BoundedOutOfOrderTimestamps

        public BoundedOutOfOrderTimestamps​(long delay)
        Parameters:
        delay - The delay by which watermarks are behind the maximum observed timestamp.
    • Method Detail

      • toProperties

        public Map<String,​String> toProperties()
        Specified by:
        toProperties in interface org.apache.flink.table.legacy.descriptors.Descriptor
        Overrides:
        toProperties in class org.apache.flink.table.sources.wmstrategies.WatermarkStrategy
      • hashCode

        public int hashCode()
        Overrides:
        hashCode in class Object