Class InternalTimerServiceSerializationProxy<K>

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

    @Internal
    public class InternalTimerServiceSerializationProxy<K>
    extends org.apache.flink.core.io.PostVersionedIOReadableWritable
    Serialization proxy for the timer services for a given key-group.
    • Constructor Detail

      • InternalTimerServiceSerializationProxy

        public InternalTimerServiceSerializationProxy​(InternalTimeServiceManagerImpl<K> timerServicesManager,
                                                      ClassLoader userCodeClassLoader,
                                                      int keyGroupIdx)
        Constructor to use when restoring timer services.
      • InternalTimerServiceSerializationProxy

        public InternalTimerServiceSerializationProxy​(InternalTimeServiceManagerImpl<K> timerServicesManager,
                                                      int keyGroupIdx)
        Constructor to use when writing timer services.
    • Method Detail

      • getVersion

        public int getVersion()
      • getCompatibleVersions

        public int[] getCompatibleVersions()
        Overrides:
        getCompatibleVersions in class org.apache.flink.core.io.VersionedIOReadableWritable
      • write

        public void write​(org.apache.flink.core.memory.DataOutputView out)
                   throws IOException
        Specified by:
        write in interface org.apache.flink.core.io.IOReadableWritable
        Overrides:
        write in class org.apache.flink.core.io.PostVersionedIOReadableWritable
        Throws:
        IOException
      • read

        protected void read​(org.apache.flink.core.memory.DataInputView in,
                            boolean wasVersioned)
                     throws IOException
        Specified by:
        read in class org.apache.flink.core.io.PostVersionedIOReadableWritable
        Throws:
        IOException