public static final class NullableSerializerWrapper.NullableSerializerWrapperSnapshot<T> extends Object implements org.apache.flink.api.common.typeutils.TypeSerializerSnapshot<T>
Constructor and Description |
---|
NullableSerializerWrapperSnapshot() |
NullableSerializerWrapperSnapshot(org.apache.flink.api.common.typeutils.TypeSerializer<T> innerSerializer) |
Modifier and Type | Method and Description |
---|---|
int |
getCurrentVersion() |
void |
readSnapshot(int readVersion,
org.apache.flink.core.memory.DataInputView in,
ClassLoader classLoader) |
org.apache.flink.api.common.typeutils.TypeSerializerSchemaCompatibility<T> |
resolveSchemaCompatibility(org.apache.flink.api.common.typeutils.TypeSerializer<T> newSerializer) |
org.apache.flink.api.common.typeutils.TypeSerializer<T> |
restoreSerializer() |
void |
writeSnapshot(org.apache.flink.core.memory.DataOutputView out) |
public NullableSerializerWrapperSnapshot()
public NullableSerializerWrapperSnapshot(org.apache.flink.api.common.typeutils.TypeSerializer<T> innerSerializer)
public int getCurrentVersion()
getCurrentVersion
in interface org.apache.flink.api.common.typeutils.TypeSerializerSnapshot<T>
public void writeSnapshot(org.apache.flink.core.memory.DataOutputView out) throws IOException
writeSnapshot
in interface org.apache.flink.api.common.typeutils.TypeSerializerSnapshot<T>
IOException
public void readSnapshot(int readVersion, org.apache.flink.core.memory.DataInputView in, ClassLoader classLoader) throws IOException
readSnapshot
in interface org.apache.flink.api.common.typeutils.TypeSerializerSnapshot<T>
IOException
public org.apache.flink.api.common.typeutils.TypeSerializer<T> restoreSerializer()
restoreSerializer
in interface org.apache.flink.api.common.typeutils.TypeSerializerSnapshot<T>
public org.apache.flink.api.common.typeutils.TypeSerializerSchemaCompatibility<T> resolveSchemaCompatibility(org.apache.flink.api.common.typeutils.TypeSerializer<T> newSerializer)
resolveSchemaCompatibility
in interface org.apache.flink.api.common.typeutils.TypeSerializerSnapshot<T>
Copyright © 2024 The Apache Software Foundation. All rights reserved.