Class WatermarkEvent

  • All Implemented Interfaces:
    org.apache.flink.core.io.IOReadableWritable

    @Internal
    public class WatermarkEvent
    extends RuntimeEvent
    This event wraps the Watermark, it is used in propagate Watermark between shuffle components, and should not be visible to operators and functions.
    • Constructor Detail

      • WatermarkEvent

        public WatermarkEvent()
      • WatermarkEvent

        public WatermarkEvent​(org.apache.flink.api.common.watermark.Watermark watermark,
                              boolean isAligned)
    • Method Detail

      • write

        public void write​(org.apache.flink.core.memory.DataOutputView out)
                   throws IOException
        Throws:
        IOException
      • read

        public void read​(org.apache.flink.core.memory.DataInputView in)
                  throws IOException
        Throws:
        IOException
      • getWatermark

        public org.apache.flink.api.common.watermark.Watermark getWatermark()
      • isAligned

        public boolean isAligned()
      • hashCode

        public int hashCode()
        Overrides:
        hashCode in class Object