public final class ProtobufTypeSerializerSnapshot<M extends com.google.protobuf.Message>
extends java.lang.Object
implements org.apache.flink.api.common.typeutils.TypeSerializerSnapshot<M>
Constructor and Description |
---|
ProtobufTypeSerializerSnapshot() |
Modifier and Type | Method and Description |
---|---|
int |
getCurrentVersion() |
void |
readSnapshot(int readVersion,
org.apache.flink.core.memory.DataInputView in,
java.lang.ClassLoader userCodeClassLoader) |
org.apache.flink.api.common.typeutils.TypeSerializerSchemaCompatibility<M> |
resolveSchemaCompatibility(org.apache.flink.api.common.typeutils.TypeSerializer<M> newSerializer) |
org.apache.flink.api.common.typeutils.TypeSerializer<M> |
restoreSerializer() |
void |
writeSnapshot(org.apache.flink.core.memory.DataOutputView out) |
public int getCurrentVersion()
getCurrentVersion
in interface org.apache.flink.api.common.typeutils.TypeSerializerSnapshot<M extends com.google.protobuf.Message>
public void writeSnapshot(org.apache.flink.core.memory.DataOutputView out) throws java.io.IOException
writeSnapshot
in interface org.apache.flink.api.common.typeutils.TypeSerializerSnapshot<M extends com.google.protobuf.Message>
java.io.IOException
public void readSnapshot(int readVersion, org.apache.flink.core.memory.DataInputView in, java.lang.ClassLoader userCodeClassLoader) throws java.io.IOException
readSnapshot
in interface org.apache.flink.api.common.typeutils.TypeSerializerSnapshot<M extends com.google.protobuf.Message>
java.io.IOException
public org.apache.flink.api.common.typeutils.TypeSerializer<M> restoreSerializer()
restoreSerializer
in interface org.apache.flink.api.common.typeutils.TypeSerializerSnapshot<M extends com.google.protobuf.Message>
public org.apache.flink.api.common.typeutils.TypeSerializerSchemaCompatibility<M> resolveSchemaCompatibility(org.apache.flink.api.common.typeutils.TypeSerializer<M> newSerializer)
resolveSchemaCompatibility
in interface org.apache.flink.api.common.typeutils.TypeSerializerSnapshot<M extends com.google.protobuf.Message>
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.