@Internal
public class InternalTimerServiceSerializationProxy<K>
extends org.apache.flink.core.io.PostVersionedIOReadableWritable
Modifier and Type | Field and Description |
---|---|
static int |
VERSION |
Constructor and Description |
---|
InternalTimerServiceSerializationProxy(InternalTimeServiceManagerImpl<K> timerServicesManager,
ClassLoader userCodeClassLoader,
int keyGroupIdx)
Constructor to use when restoring timer services.
|
InternalTimerServiceSerializationProxy(InternalTimeServiceManagerImpl<K> timerServicesManager,
int keyGroupIdx)
Constructor to use when writing timer services.
|
Modifier and Type | Method and 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) |
public static final int VERSION
public InternalTimerServiceSerializationProxy(InternalTimeServiceManagerImpl<K> timerServicesManager, ClassLoader userCodeClassLoader, int keyGroupIdx)
public InternalTimerServiceSerializationProxy(InternalTimeServiceManagerImpl<K> timerServicesManager, int keyGroupIdx)
public int getVersion()
public int[] getCompatibleVersions()
getCompatibleVersions
in class org.apache.flink.core.io.VersionedIOReadableWritable
public void write(org.apache.flink.core.memory.DataOutputView out) throws IOException
write
in interface org.apache.flink.core.io.IOReadableWritable
write
in class org.apache.flink.core.io.PostVersionedIOReadableWritable
IOException
protected void read(org.apache.flink.core.memory.DataInputView in, boolean wasVersioned) throws IOException
read
in class org.apache.flink.core.io.PostVersionedIOReadableWritable
IOException
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.