Class InternalTimerServiceSerializationProxy<K>
- java.lang.Object
-
- org.apache.flink.core.io.VersionedIOReadableWritable
-
- org.apache.flink.core.io.PostVersionedIOReadableWritable
-
- org.apache.flink.streaming.api.operators.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.
-
-
Field Summary
Fields Modifier and Type Field Description static int
VERSION
-
Constructor Summary
Constructors Constructor Description InternalTimerServiceSerializationProxy(InternalTimeServiceManagerImpl<K> timerServicesManager, int keyGroupIdx)
Constructor to use when writing timer services.InternalTimerServiceSerializationProxy(InternalTimeServiceManagerImpl<K> timerServicesManager, ClassLoader userCodeClassLoader, int keyGroupIdx)
Constructor to use when restoring timer services.
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description int[]
getCompatibleVersions()
int
getVersion()
protected void
read(org.apache.flink.core.memory.DataInputView in, boolean wasVersioned)
void
write(org.apache.flink.core.memory.DataOutputView out)
-
-
-
Field Detail
-
VERSION
public static final int VERSION
- See Also:
- Constant Field Values
-
-
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 classorg.apache.flink.core.io.VersionedIOReadableWritable
-
write
public void write(org.apache.flink.core.memory.DataOutputView out) throws IOException
- Specified by:
write
in interfaceorg.apache.flink.core.io.IOReadableWritable
- Overrides:
write
in classorg.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 classorg.apache.flink.core.io.PostVersionedIOReadableWritable
- Throws:
IOException
-
-