Class TimeWindow.Serializer

  • All Implemented Interfaces:
    Serializable
    Enclosing class:
    TimeWindow

    public static class TimeWindow.Serializer
    extends org.apache.flink.api.common.typeutils.base.TypeSerializerSingleton<TimeWindow>
    The serializer used to write the TimeWindow type.
    See Also:
    Serialized Form
    • Constructor Detail

      • Serializer

        public Serializer()
    • Method Detail

      • isImmutableType

        public boolean isImmutableType()
        Specified by:
        isImmutableType in class org.apache.flink.api.common.typeutils.TypeSerializer<TimeWindow>
      • createInstance

        public TimeWindow createInstance()
        Specified by:
        createInstance in class org.apache.flink.api.common.typeutils.TypeSerializer<TimeWindow>
      • getLength

        public int getLength()
        Specified by:
        getLength in class org.apache.flink.api.common.typeutils.TypeSerializer<TimeWindow>
      • serialize

        public void serialize​(TimeWindow record,
                              org.apache.flink.core.memory.DataOutputView target)
                       throws IOException
        Specified by:
        serialize in class org.apache.flink.api.common.typeutils.TypeSerializer<TimeWindow>
        Throws:
        IOException
      • deserialize

        public TimeWindow deserialize​(org.apache.flink.core.memory.DataInputView source)
                               throws IOException
        Specified by:
        deserialize in class org.apache.flink.api.common.typeutils.TypeSerializer<TimeWindow>
        Throws:
        IOException
      • deserialize

        public TimeWindow deserialize​(TimeWindow reuse,
                                      org.apache.flink.core.memory.DataInputView source)
                               throws IOException
        Specified by:
        deserialize in class org.apache.flink.api.common.typeutils.TypeSerializer<TimeWindow>
        Throws:
        IOException
      • copy

        public void copy​(org.apache.flink.core.memory.DataInputView source,
                         org.apache.flink.core.memory.DataOutputView target)
                  throws IOException
        Specified by:
        copy in class org.apache.flink.api.common.typeutils.TypeSerializer<TimeWindow>
        Throws:
        IOException
      • snapshotConfiguration

        public org.apache.flink.api.common.typeutils.TypeSerializerSnapshot<TimeWindow> snapshotConfiguration()
        Specified by:
        snapshotConfiguration in class org.apache.flink.api.common.typeutils.TypeSerializer<TimeWindow>