Class PunctuatedWatermarkAssigner

  • All Implemented Interfaces:
    Serializable, org.apache.flink.table.legacy.descriptors.Descriptor

    @PublicEvolving
    public abstract class PunctuatedWatermarkAssigner
    extends org.apache.flink.table.sources.wmstrategies.WatermarkStrategy
    A punctuated watermark assigner.
    See Also:
    Serialized Form
    • Constructor Detail

      • PunctuatedWatermarkAssigner

        public PunctuatedWatermarkAssigner()
    • Method Detail

      • getWatermark

        public abstract org.apache.flink.streaming.api.watermark.Watermark getWatermark​(org.apache.flink.types.Row row,
                                                                                        long timestamp)
        Returns the watermark for the current row or null if no watermark should be generated.
        Parameters:
        row - The current row.
        timestamp - The value of the timestamp attribute for the row.
        Returns:
        The watermark for this row or null if no watermark should be generated.