I
- internal data structureE
- external data structurepublic static final class ExternalSerializer.ExternalSerializerSnapshot<I,E> extends CompositeTypeSerializerSnapshot<E,ExternalSerializer<I,E>>
CompositeTypeSerializerSnapshot.OuterSchemaCompatibility
Constructor and Description |
---|
ExternalSerializerSnapshot() |
ExternalSerializerSnapshot(ExternalSerializer<I,E> externalSerializer) |
Modifier and Type | Method and Description |
---|---|
protected ExternalSerializer<I,E> |
createOuterSerializerWithNestedSerializers(TypeSerializer<?>[] nestedSerializers)
Creates an instance of the outer serializer with a given array of its nested serializers.
|
protected int |
getCurrentOuterSnapshotVersion()
Returns the version of the current outer snapshot's written binary format.
|
protected TypeSerializer<?>[] |
getNestedSerializers(ExternalSerializer<I,E> outerSerializer)
Gets the nested serializers from the outer serializer.
|
protected void |
readOuterSnapshot(int readOuterSnapshotVersion,
DataInputView in,
ClassLoader userCodeClassLoader)
Reads the outer snapshot, i.e.
|
protected void |
writeOuterSnapshot(DataOutputView out)
Writes the outer snapshot, i.e.
|
getCurrentVersion, getNestedSerializerSnapshots, isOuterSnapshotCompatible, readSnapshot, resolveOuterSchemaCompatibility, resolveSchemaCompatibility, restoreSerializer, writeSnapshot
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
readVersionedSnapshot, writeVersionedSnapshot
public ExternalSerializerSnapshot()
public ExternalSerializerSnapshot(ExternalSerializer<I,E> externalSerializer)
protected int getCurrentOuterSnapshotVersion()
CompositeTypeSerializerSnapshot
getCurrentOuterSnapshotVersion
in class CompositeTypeSerializerSnapshot<E,ExternalSerializer<I,E>>
protected void writeOuterSnapshot(DataOutputView out) throws IOException
CompositeTypeSerializerSnapshot
The base implementation of this methods writes nothing, i.e. it assumes that the outer
serializer only has nested serializers and no extra information. Otherwise, if the outer
serializer contains some extra information that needs to be persisted as part of the
serializer snapshot, this must be overridden. Note that this method and the corresponding
methods CompositeTypeSerializerSnapshot.readOuterSnapshot(int, DataInputView, ClassLoader)
, CompositeTypeSerializerSnapshot.resolveOuterSchemaCompatibility(TypeSerializer)
needs to be implemented.
writeOuterSnapshot
in class CompositeTypeSerializerSnapshot<E,ExternalSerializer<I,E>>
out
- the DataOutputView
to write the outer snapshot to.IOException
protected void readOuterSnapshot(int readOuterSnapshotVersion, DataInputView in, ClassLoader userCodeClassLoader) throws IOException
CompositeTypeSerializerSnapshot
The base implementation of this methods reads nothing, i.e. it assumes that the outer
serializer only has nested serializers and no extra information. Otherwise, if the outer
serializer contains some extra information that has been persisted as part of the serializer
snapshot, this must be overridden. Note that this method and the corresponding methods CompositeTypeSerializerSnapshot.writeOuterSnapshot(DataOutputView)
, CompositeTypeSerializerSnapshot.resolveOuterSchemaCompatibility(TypeSerializer)
needs to be implemented.
readOuterSnapshot
in class CompositeTypeSerializerSnapshot<E,ExternalSerializer<I,E>>
readOuterSnapshotVersion
- the read version of the outer snapshot.in
- the DataInputView
to read the outer snapshot from.userCodeClassLoader
- the user code class loader.IOException
protected TypeSerializer<?>[] getNestedSerializers(ExternalSerializer<I,E> outerSerializer)
CompositeTypeSerializerSnapshot
getNestedSerializers
in class CompositeTypeSerializerSnapshot<E,ExternalSerializer<I,E>>
outerSerializer
- the outer serializer.protected ExternalSerializer<I,E> createOuterSerializerWithNestedSerializers(TypeSerializer<?>[] nestedSerializers)
CompositeTypeSerializerSnapshot
createOuterSerializerWithNestedSerializers
in class CompositeTypeSerializerSnapshot<E,ExternalSerializer<I,E>>
nestedSerializers
- array of nested serializers to create the outer serializer with.Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.