public class ScalaEitherSerializerSnapshot<L,R> extends CompositeTypeSerializerSnapshot<scala.util.Either<L,R>,org.apache.flink.api.scala.typeutils.EitherSerializer<L,R>>
Either
type,
containing configuration snapshots of the Left and Right serializers.Constructor and Description |
---|
ScalaEitherSerializerSnapshot()
Constructor for read instantiation.
|
ScalaEitherSerializerSnapshot(org.apache.flink.api.scala.typeutils.EitherSerializer<L,R> eitherSerializer)
Constructor to create the snapshot for writing.
|
Modifier and Type | Method and Description |
---|---|
protected org.apache.flink.api.scala.typeutils.EitherSerializer<L,R> |
createOuterSerializerWithNestedSerializers(TypeSerializer<?>[] nestedSerializers)
Creates an instance of the outer serializer with a given array of its nested serializers.
|
int |
getCurrentOuterSnapshotVersion()
Returns the version of the current outer snapshot's written binary format.
|
protected TypeSerializer<?>[] |
getNestedSerializers(org.apache.flink.api.scala.typeutils.EitherSerializer<L,R> outerSerializer)
Gets the nested serializers from the outer serializer.
|
getCurrentVersion, isOuterSnapshotCompatible, readOuterSnapshot, readSnapshot, resolveSchemaCompatibility, restoreSerializer, writeOuterSnapshot, writeSnapshot
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
readVersionedSnapshot, writeVersionedSnapshot
public ScalaEitherSerializerSnapshot()
public int getCurrentOuterSnapshotVersion()
CompositeTypeSerializerSnapshot
getCurrentOuterSnapshotVersion
in class CompositeTypeSerializerSnapshot<scala.util.Either<L,R>,org.apache.flink.api.scala.typeutils.EitherSerializer<L,R>>
protected org.apache.flink.api.scala.typeutils.EitherSerializer<L,R> createOuterSerializerWithNestedSerializers(TypeSerializer<?>[] nestedSerializers)
CompositeTypeSerializerSnapshot
createOuterSerializerWithNestedSerializers
in class CompositeTypeSerializerSnapshot<scala.util.Either<L,R>,org.apache.flink.api.scala.typeutils.EitherSerializer<L,R>>
nestedSerializers
- array of nested serializers to create the outer serializer with.protected TypeSerializer<?>[] getNestedSerializers(org.apache.flink.api.scala.typeutils.EitherSerializer<L,R> outerSerializer)
CompositeTypeSerializerSnapshot
getNestedSerializers
in class CompositeTypeSerializerSnapshot<scala.util.Either<L,R>,org.apache.flink.api.scala.typeutils.EitherSerializer<L,R>>
outerSerializer
- the outer serializer.Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.