JavaEitherSerializerSnapshot
is used.@Internal @Deprecated public final class EitherSerializerSnapshot<L,R> extends Object implements TypeSerializerSnapshot<Either<L,R>>
EitherSerializer
.Constructor and Description |
---|
EitherSerializerSnapshot()
Deprecated.
Constructor for read instantiation.
|
EitherSerializerSnapshot(TypeSerializer<L> leftSerializer,
TypeSerializer<R> rightSerializer)
Deprecated.
Constructor to create the snapshot for writing.
|
Modifier and Type | Method and Description |
---|---|
int |
getCurrentVersion()
Deprecated.
Returns the version of the current snapshot's written binary format.
|
TypeSerializerSnapshot<?>[] |
getNestedSerializerSnapshots()
Deprecated.
|
void |
readSnapshot(int readVersion,
DataInputView in,
ClassLoader classLoader)
Deprecated.
Reads the serializer snapshot from the provided
DataInputView . |
EitherSerializer<L,R> |
restoreSerializer()
Deprecated.
Recreates a serializer instance from this snapshot.
|
void |
writeSnapshot(DataOutputView out)
Deprecated.
Writes the serializer snapshot to the provided
DataOutputView . |
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
readVersionedSnapshot, resolveSchemaCompatibility, resolveSchemaCompatibility, writeVersionedSnapshot
public EitherSerializerSnapshot()
public EitherSerializerSnapshot(TypeSerializer<L> leftSerializer, TypeSerializer<R> rightSerializer)
public int getCurrentVersion()
TypeSerializerSnapshot
getCurrentVersion
in interface TypeSerializerSnapshot<Either<L,R>>
public void writeSnapshot(DataOutputView out) throws IOException
TypeSerializerSnapshot
DataOutputView
. The current version of
the written serializer snapshot's binary format is specified by the TypeSerializerSnapshot.getCurrentVersion()
method.writeSnapshot
in interface TypeSerializerSnapshot<Either<L,R>>
out
- the DataOutputView
to write the snapshot to.IOException
- Thrown if the snapshot data could not be written.TypeSerializerSnapshot.writeVersionedSnapshot(DataOutputView, TypeSerializerSnapshot)
public void readSnapshot(int readVersion, DataInputView in, ClassLoader classLoader) throws IOException
TypeSerializerSnapshot
DataInputView
. The version of the
binary format that the serializer snapshot was written with is provided. This version can be
used to determine how the serializer snapshot should be read.readSnapshot
in interface TypeSerializerSnapshot<Either<L,R>>
readVersion
- version of the serializer snapshot's written binary formatin
- the DataInputView
to read the snapshot from.classLoader
- the user code classloaderIOException
- Thrown if the snapshot data could be read or parsed.TypeSerializerSnapshot.readVersionedSnapshot(DataInputView, ClassLoader)
public EitherSerializer<L,R> restoreSerializer()
TypeSerializerSnapshot
restoreSerializer
in interface TypeSerializerSnapshot<Either<L,R>>
@Nullable public TypeSerializerSnapshot<?>[] getNestedSerializerSnapshots()
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.