Modifier and Type | Class and Description |
---|---|
class |
BackwardsCompatibleSerializerSnapshot<T>
A utility
TypeSerializerConfigSnapshot that is used for backwards compatibility purposes. |
static class |
CompositeSerializer.ConfigSnapshot
Deprecated.
this snapshot class is no longer in use by any serializers, and is only kept
around for backwards compatibility. All subclass serializers should have their own
serializer snapshot classes.
|
class |
CompositeTypeSerializerConfigSnapshot<T>
A
TypeSerializerConfigSnapshot for serializers that has multiple nested serializers. |
class |
CompositeTypeSerializerSnapshot<T,S extends TypeSerializer<T>>
A
CompositeTypeSerializerSnapshot is a convenient serializer snapshot class that can be
used by simple serializers which 1) delegates its serialization to multiple nested serializers,
and 2) may contain some extra static information that needs to be persisted as part of its
snapshot. |
class |
GenericTypeSerializerConfigSnapshot<T>
Configuration snapshot for serializers for generic types.
|
class |
GenericTypeSerializerSnapshot<T,S extends TypeSerializer>
Base
TypeSerializerSnapshot for serializers for generic types. |
class |
ParameterlessTypeSerializerConfig<T>
Deprecated.
this snapshot class is no longer used by any serializers, and is maintained only for
backward compatibility reasons. It is fully replaced by
SimpleTypeSerializerSnapshot . |
class |
SimpleTypeSerializerSnapshot<T>
A simple base class for TypeSerializerSnapshots, for serializers that have no parameters.
|
static class |
SingleThreadAccessCheckingTypeSerializer.SingleThreadAccessCheckingTypeSerializerSnapshot<T> |
class |
TypeSerializerConfigSnapshot<T>
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
TypeSerializerSnapshot<?>[] |
CompositeTypeSerializerSnapshot.getNestedSerializerSnapshots() |
TypeSerializerSnapshot<?>[] |
CompositeTypeSerializerConfigSnapshot.getNestedSerializerSnapshots() |
TypeSerializerSnapshot<?>[] |
NestedSerializersSnapshotDelegate.getNestedSerializerSnapshots()
Returns the snapshots of the nested serializers.
|
static <T> TypeSerializerSnapshot<T> |
TypeSerializerSnapshotSerializationUtil.readAndInstantiateSnapshotClass(DataInputView in,
ClassLoader cl) |
static <T> TypeSerializerSnapshot<T> |
TypeSerializerSnapshotSerializationUtil.readSerializerSnapshot(DataInputView in,
ClassLoader userCodeClassLoader,
TypeSerializer<T> existingPriorSerializer)
Reads from a data input view a
TypeSerializerSnapshot that was previously written
using TypeSerializerSnapshotSerializationUtil.writeSerializerSnapshot(DataOutputView,
TypeSerializerSnapshot, TypeSerializer) . |
static <T> TypeSerializerSnapshot<T> |
TypeSerializerSnapshot.readVersionedSnapshot(DataInputView in,
ClassLoader cl)
Reads a snapshot from the stream, performing resolving
|
static TypeSerializerSnapshot<?>[] |
TypeSerializerUtils.snapshotBackwardsCompatible(TypeSerializer<?>... originatingSerializers)
Takes snapshots of the given serializers.
|
static <T> TypeSerializerSnapshot<T> |
TypeSerializerUtils.snapshotBackwardsCompatible(TypeSerializer<T> originatingSerializer)
Takes a snapshot of the given serializer.
|
abstract TypeSerializerSnapshot<T> |
TypeSerializer.snapshotConfiguration()
Snapshots the configuration of this TypeSerializer.
|
TypeSerializerSnapshot<T> |
UnloadableDummyTypeSerializer.snapshotConfiguration() |
TypeSerializerSnapshot<T> |
SingleThreadAccessCheckingTypeSerializer.snapshotConfiguration() |
<U> TypeSerializerSnapshot<T> |
LegacySerializerSnapshotTransformer.transformLegacySerializerSnapshot(TypeSerializerSnapshot<U> legacySnapshot)
|
Modifier and Type | Method and Description |
---|---|
List<Tuple2<TypeSerializer<?>,TypeSerializerSnapshot<?>>> |
CompositeTypeSerializerConfigSnapshot.getNestedSerializersAndConfigs() |
Tuple2<TypeSerializer<?>,TypeSerializerSnapshot<?>> |
CompositeTypeSerializerConfigSnapshot.getSingleNestedSerializerAndConfig() |
static List<Tuple2<TypeSerializer<?>,TypeSerializerSnapshot<?>>> |
TypeSerializerSerializationUtil.readSerializersAndConfigsWithResilience(DataInputView in,
ClassLoader userCodeClassLoader)
Deprecated.
Reads from a data input view a list of serializers and their corresponding config snapshots
written using
TypeSerializerSerializationUtil.writeSerializersAndConfigsWithResilience(DataOutputView, List) . |
Modifier and Type | Method and Description |
---|---|
static <T> CompositeTypeSerializerUtil.IntermediateCompatibilityResult<T> |
CompositeTypeSerializerUtil.constructIntermediateCompatibilityResult(TypeSerializer<?>[] newNestedSerializers,
TypeSerializerSnapshot<?>[] nestedSerializerSnapshots)
Constructs an
CompositeTypeSerializerUtil.IntermediateCompatibilityResult with the given array of nested
serializers and their corresponding serializer snapshots. |
static <T> TypeSerializerSchemaCompatibility<T> |
CompositeTypeSerializerUtil.delegateCompatibilityCheckToNewSnapshot(TypeSerializer<T> newSerializer,
CompositeTypeSerializerSnapshot<T,? extends TypeSerializer> newCompositeSnapshot,
TypeSerializerSnapshot<?>... legacyNestedSnapshots)
Delegates compatibility checks to a
CompositeTypeSerializerSnapshot instance. |
static void |
CompositeTypeSerializerUtil.setNestedSerializersSnapshots(CompositeTypeSerializerSnapshot<?,?> compositeSnapshot,
TypeSerializerSnapshot<?>... nestedSnapshots)
Overrides the existing nested serializer's snapshots with the provided
nestedSnapshots . |
<U> TypeSerializerSnapshot<T> |
LegacySerializerSnapshotTransformer.transformLegacySerializerSnapshot(TypeSerializerSnapshot<U> legacySnapshot)
|
static <T> void |
TypeSerializerSnapshotSerializationUtil.writeSerializerSnapshot(DataOutputView out,
TypeSerializerSnapshot<T> serializerSnapshot,
TypeSerializer<T> serializer)
Writes a
TypeSerializerSnapshot to the provided data output view. |
static void |
TypeSerializerSnapshot.writeVersionedSnapshot(DataOutputView out,
TypeSerializerSnapshot<?> snapshot)
Writes the given snapshot to the out stream.
|
Modifier and Type | Method and Description |
---|---|
static void |
TypeSerializerSerializationUtil.writeSerializersAndConfigsWithResilience(DataOutputView out,
List<Tuple2<TypeSerializer<?>,TypeSerializerSnapshot<?>>> serializersAndConfigs)
Deprecated.
Write a list of serializers and their corresponding config snapshots to the provided data
output view.
|
Modifier and Type | Class and Description |
---|---|
static class |
BigDecSerializer.BigDecSerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
static class |
BigIntSerializer.BigIntSerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
static class |
BooleanSerializer.BooleanSerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
static class |
BooleanValueSerializer.BooleanValueSerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
static class |
ByteSerializer.ByteSerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
static class |
ByteValueSerializer.ByteValueSerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
static class |
CharSerializer.CharSerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
static class |
CharValueSerializer.CharValueSerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
class |
CollectionSerializerConfigSnapshot<C extends Collection<T>,T>
Deprecated.
this snapshot class should no longer be used by any serializers as their snapshot.
|
static class |
DateSerializer.DateSerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
static class |
DoubleSerializer.DoubleSerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
static class |
DoubleValueSerializer.DoubleValueSerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
static class |
EnumSerializer.EnumSerializerConfigSnapshot<T extends Enum<T>>
Deprecated.
|
static class |
EnumSerializer.EnumSerializerSnapshot<T extends Enum<T>>
|
static class |
FloatSerializer.FloatSerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
static class |
FloatValueSerializer.FloatValueSerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
class |
GenericArraySerializerConfigSnapshot<C>
Deprecated.
this is deprecated and no longer used by the
GenericArraySerializer . It has
been replaced by GenericArraySerializerSnapshot . |
class |
GenericArraySerializerSnapshot<C>
Point-in-time configuration of a
GenericArraySerializer . |
static class |
InstantSerializer.InstantSerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
static class |
IntSerializer.IntSerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
static class |
IntValueSerializer.IntValueSerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
class |
ListSerializerSnapshot<T>
Snapshot class for the
ListSerializer . |
static class |
LocalDateSerializer.LocalDateSerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
static class |
LocalDateTimeSerializer.LocalDateTimeSerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
static class |
LocalTimeSerializer.LocalTimeSerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
static class |
LongSerializer.LongSerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
static class |
LongValueSerializer.LongValueSerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
class |
MapSerializerConfigSnapshot<K,V>
Deprecated.
this snapshot class should not be used by any serializer anymore.
|
class |
MapSerializerSnapshot<K,V>
Snapshot class for the
MapSerializer . |
static class |
NullValueSerializer.NullValueSerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
static class |
ShortSerializer.ShortSerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
static class |
ShortValueSerializer.ShortValueSerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
static class |
SqlDateSerializer.SqlDateSerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
static class |
SqlTimeSerializer.SqlTimeSerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
static class |
SqlTimestampSerializer.SqlTimestampSerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
static class |
StringSerializer.StringSerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
static class |
StringValueSerializer.StringValueSerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
static class |
VoidSerializer.VoidSerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
Modifier and Type | Class and Description |
---|---|
static class |
BooleanPrimitiveArraySerializer.BooleanPrimitiveArraySerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
static class |
BytePrimitiveArraySerializer.BytePrimitiveArraySerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
static class |
CharPrimitiveArraySerializer.CharPrimitiveArraySerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
static class |
DoublePrimitiveArraySerializer.DoublePrimitiveArraySerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
static class |
FloatPrimitiveArraySerializer.FloatPrimitiveArraySerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
static class |
IntPrimitiveArraySerializer.IntPrimitiveArraySerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
static class |
LongPrimitiveArraySerializer.LongPrimitiveArraySerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
static class |
ShortPrimitiveArraySerializer.ShortPrimitiveArraySerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
static class |
StringArraySerializer.StringArraySerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
Modifier and Type | Method and Description |
---|---|
TypeSerializerSnapshot<boolean[]> |
BooleanPrimitiveArraySerializer.snapshotConfiguration() |
TypeSerializerSnapshot<String[]> |
StringArraySerializer.snapshotConfiguration() |
TypeSerializerSnapshot<int[]> |
IntPrimitiveArraySerializer.snapshotConfiguration() |
TypeSerializerSnapshot<double[]> |
DoublePrimitiveArraySerializer.snapshotConfiguration() |
TypeSerializerSnapshot<long[]> |
LongPrimitiveArraySerializer.snapshotConfiguration() |
TypeSerializerSnapshot<float[]> |
FloatPrimitiveArraySerializer.snapshotConfiguration() |
TypeSerializerSnapshot<short[]> |
ShortPrimitiveArraySerializer.snapshotConfiguration() |
TypeSerializerSnapshot<byte[]> |
BytePrimitiveArraySerializer.snapshotConfiguration() |
TypeSerializerSnapshot<char[]> |
CharPrimitiveArraySerializer.snapshotConfiguration() |
Modifier and Type | Class and Description |
---|---|
static class |
CopyableValueSerializer.CopyableValueSerializerConfigSnapshot<T extends CopyableValue<T>>
Deprecated.
|
static class |
CopyableValueSerializer.CopyableValueSerializerSnapshot<T extends CopyableValue<T>>
TypeSerializerSnapshot for the CopyableValueSerializer . |
class |
EitherSerializerConfigSnapshot<L,R>
Deprecated.
|
class |
EitherSerializerSnapshot<L,R>
Deprecated.
this snapshot class is no longer used by any serializers. Instead,
JavaEitherSerializerSnapshot is used. |
class |
JavaEitherSerializerSnapshot<L,R>
Snapshot class for the
EitherSerializer . |
class |
KryoRegistrationSerializerConfigSnapshot<T>
Configuration snapshot base class for serializers that use Kryo for serialization.
|
static class |
NullableSerializer.NullableSerializerConfigSnapshot<T>
Deprecated.
this snapshot class is no longer in use, and is maintained only for backwards
compatibility purposes. It is fully replaced by
NullableSerializer.NullableSerializerSnapshot . |
static class |
NullableSerializer.NullableSerializerSnapshot<T>
Snapshot for serializers of nullable types, containing the snapshot of its original
serializer.
|
static class |
PojoSerializer.PojoSerializerConfigSnapshot<T>
Deprecated.
This snapshot class is no longer being used. It has been fully replaced by
PojoSerializerSnapshot . |
class |
PojoSerializerSnapshot<T>
Snapshot class for the
PojoSerializer . |
static class |
RowSerializer.RowSerializerConfigSnapshot
Deprecated.
this snapshot class is no longer in use, and is maintained only for backwards
compatibility. It is fully replaced by
RowSerializer.RowSerializerSnapshot . |
static class |
RowSerializer.RowSerializerSnapshot
A
TypeSerializerSnapshot for RowSerializer. |
class |
Tuple0SerializerSnapshot
|
class |
TupleSerializerConfigSnapshot<T>
Snapshot of a tuple serializer's configuration.
|
class |
TupleSerializerSnapshot<T extends Tuple>
Snapshot of a tuple serializer's configuration.
|
static class |
ValueSerializer.ValueSerializerConfigSnapshot<T extends Value>
Deprecated.
|
static class |
ValueSerializer.ValueSerializerSnapshot<T extends Value>
ValueSerializer snapshot class. |
static class |
WritableSerializer.WritableSerializerConfigSnapshot<T extends org.apache.hadoop.io.Writable>
Deprecated.
This class is no longer used as a snapshot for any serializer. It is fully
replaced by
WritableSerializer.WritableSerializerSnapshot . |
static class |
WritableSerializer.WritableSerializerSnapshot<T extends org.apache.hadoop.io.Writable>
WritableSerializer snapshot class. |
Modifier and Type | Method and Description |
---|---|
TypeSerializerSnapshot<T> |
WritableSerializer.snapshotConfiguration() |
TypeSerializerSnapshot<T> |
NullableSerializer.snapshotConfiguration() |
TypeSerializerSnapshot<Tuple0> |
Tuple0Serializer.snapshotConfiguration() |
TypeSerializerSnapshot<Row> |
RowSerializer.snapshotConfiguration() |
TypeSerializerSnapshot<T> |
CopyableValueSerializer.snapshotConfiguration() |
TypeSerializerSnapshot<T> |
ValueSerializer.snapshotConfiguration() |
TypeSerializerSnapshot<T> |
TupleSerializer.snapshotConfiguration() |
Modifier and Type | Method and Description |
---|---|
LinkedHashMap<String,Tuple2<TypeSerializer<?>,TypeSerializerSnapshot<?>>> |
PojoSerializer.PojoSerializerConfigSnapshot.getFieldToSerializerConfigSnapshot()
Deprecated.
|
HashMap<Class<?>,Tuple2<TypeSerializer<?>,TypeSerializerSnapshot<?>>> |
PojoSerializer.PojoSerializerConfigSnapshot.getNonRegisteredSubclassesToSerializerConfigSnapshots()
Deprecated.
|
LinkedHashMap<Class<?>,Tuple2<TypeSerializer<?>,TypeSerializerSnapshot<?>>> |
PojoSerializer.PojoSerializerConfigSnapshot.getRegisteredSubclassesToSerializerConfigSnapshots()
Deprecated.
|
Constructor and Description |
---|
PojoSerializerConfigSnapshot(Class<T> pojoType,
LinkedHashMap<String,Tuple2<TypeSerializer<?>,TypeSerializerSnapshot<?>>> fieldToSerializerConfigSnapshot,
LinkedHashMap<Class<?>,Tuple2<TypeSerializer<?>,TypeSerializerSnapshot<?>>> registeredSubclassesToSerializerConfigSnapshots,
HashMap<Class<?>,Tuple2<TypeSerializer<?>,TypeSerializerSnapshot<?>>> nonRegisteredSubclassesToSerializerConfigSnapshots)
Deprecated.
|
PojoSerializerConfigSnapshot(Class<T> pojoType,
LinkedHashMap<String,Tuple2<TypeSerializer<?>,TypeSerializerSnapshot<?>>> fieldToSerializerConfigSnapshot,
LinkedHashMap<Class<?>,Tuple2<TypeSerializer<?>,TypeSerializerSnapshot<?>>> registeredSubclassesToSerializerConfigSnapshots,
HashMap<Class<?>,Tuple2<TypeSerializer<?>,TypeSerializerSnapshot<?>>> nonRegisteredSubclassesToSerializerConfigSnapshots)
Deprecated.
|
PojoSerializerConfigSnapshot(Class<T> pojoType,
LinkedHashMap<String,Tuple2<TypeSerializer<?>,TypeSerializerSnapshot<?>>> fieldToSerializerConfigSnapshot,
LinkedHashMap<Class<?>,Tuple2<TypeSerializer<?>,TypeSerializerSnapshot<?>>> registeredSubclassesToSerializerConfigSnapshots,
HashMap<Class<?>,Tuple2<TypeSerializer<?>,TypeSerializerSnapshot<?>>> nonRegisteredSubclassesToSerializerConfigSnapshots)
Deprecated.
|
PojoSerializerConfigSnapshot(Class<T> pojoType,
LinkedHashMap<String,Tuple2<TypeSerializer<?>,TypeSerializerSnapshot<?>>> fieldToSerializerConfigSnapshot,
LinkedHashMap<Class<?>,Tuple2<TypeSerializer<?>,TypeSerializerSnapshot<?>>> registeredSubclassesToSerializerConfigSnapshots,
HashMap<Class<?>,Tuple2<TypeSerializer<?>,TypeSerializerSnapshot<?>>> nonRegisteredSubclassesToSerializerConfigSnapshots,
boolean ignoreTypeSerializerSerialization)
Deprecated.
|
PojoSerializerConfigSnapshot(Class<T> pojoType,
LinkedHashMap<String,Tuple2<TypeSerializer<?>,TypeSerializerSnapshot<?>>> fieldToSerializerConfigSnapshot,
LinkedHashMap<Class<?>,Tuple2<TypeSerializer<?>,TypeSerializerSnapshot<?>>> registeredSubclassesToSerializerConfigSnapshots,
HashMap<Class<?>,Tuple2<TypeSerializer<?>,TypeSerializerSnapshot<?>>> nonRegisteredSubclassesToSerializerConfigSnapshots,
boolean ignoreTypeSerializerSerialization)
Deprecated.
|
PojoSerializerConfigSnapshot(Class<T> pojoType,
LinkedHashMap<String,Tuple2<TypeSerializer<?>,TypeSerializerSnapshot<?>>> fieldToSerializerConfigSnapshot,
LinkedHashMap<Class<?>,Tuple2<TypeSerializer<?>,TypeSerializerSnapshot<?>>> registeredSubclassesToSerializerConfigSnapshots,
HashMap<Class<?>,Tuple2<TypeSerializer<?>,TypeSerializerSnapshot<?>>> nonRegisteredSubclassesToSerializerConfigSnapshots,
boolean ignoreTypeSerializerSerialization)
Deprecated.
|
Modifier and Type | Class and Description |
---|---|
static class |
KryoSerializer.KryoSerializerConfigSnapshot<T>
Deprecated.
|
class |
KryoSerializerSnapshot<T>
|
Modifier and Type | Method and Description |
---|---|
TypeSerializerSnapshot<T> |
KryoSerializer.snapshotConfiguration() |
Modifier and Type | Class and Description |
---|---|
class |
ScalaCaseClassSerializerSnapshot<T extends scala.Product>
TypeSerializerSnapshot for ScalaCaseClassSerializer . |
class |
ScalaEitherSerializerSnapshot<L,R>
Configuration snapshot for serializers of Scala's
Either type, containing configuration
snapshots of the Left and Right serializers. |
class |
ScalaOptionSerializerConfigSnapshot<E>
Deprecated.
this snapshot class is no longer in use, and is maintained only for backwards
compatibility. It is fully replaced by
ScalaOptionSerializerSnapshot . |
class |
ScalaOptionSerializerSnapshot<E>
A
TypeSerializerSnapshot for the Scala OptionSerializer . |
class |
ScalaTrySerializerConfigSnapshot<E>
Deprecated.
|
class |
ScalaTrySerializerSnapshot<E>
A
TypeSerializerSnapshot for the Scala TrySerializer . |
class |
TraversableSerializerConfigSnapshot<T extends scala.collection.TraversableOnce<E>,E>
Deprecated.
This is being replaced with
TraversableSerializerSnapshot . |
class |
TraversableSerializerSnapshot<T extends scala.collection.TraversableOnce<E>,E>
A
TypeSerializerSnapshot for the Scala TraversableSerializer . |
class |
Tuple2CaseClassSerializerSnapshot<T1,T2>
TypeSerializerSnapshot for ScalaCaseClassSerializer . |
Modifier and Type | Class and Description |
---|---|
static class |
DeweyNumber.DeweyNumberSerializer.DeweyNumberSerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
static class |
NFA.MigratedNFASerializerSnapshot<T>
A
TypeSerializerSnapshot for the legacy NFA.NFASerializer . |
static class |
NFA.NFASerializerConfigSnapshot<T>
Deprecated.
This snapshot class is no longer in use, and only maintained for backwards
compatibility purposes. It is fully replaced by
NFA.MigratedNFASerializerSnapshot . |
class |
NFAStateSerializerSnapshot
Snapshot class for
NFAStateSerializer . |
static class |
SharedBuffer.SharedBufferSerializerConfigSnapshot<K,V>
Deprecated.
This snapshot class is no longer in use, and only maintained for backwards
compatibility purposes. It is fully replaced by
SharedBuffer.SharedBufferSerializerSnapshot . |
static class |
SharedBuffer.SharedBufferSerializerSnapshot<K,V>
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
TypeSerializerSnapshot<NFAState> |
NFAStateSerializer.snapshotConfiguration() |
TypeSerializerSnapshot<DeweyNumber> |
DeweyNumber.DeweyNumberSerializer.snapshotConfiguration() |
Modifier and Type | Class and Description |
---|---|
static class |
EventId.EventIdSerializer.EventIdSerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
class |
LockableTypeSerializerSnapshot<E>
|
static class |
NodeId.NodeIdSerializer.NodeIdSerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
static class |
SharedBufferEdge.SharedBufferEdgeSerializer.SharedBufferEdgeSerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
static class |
SharedBufferNode.SharedBufferNodeSerializer.SharedBufferNodeSerializerSnapshot
Deprecated.
Serializer configuration snapshot for compatibility and format evolution.
|
class |
SharedBufferNodeSerializerSnapshotV2
Serializer configuration snapshot for compatibility and format evolution.
|
Modifier and Type | Method and Description |
---|---|
TypeSerializerSnapshot<SharedBufferNode> |
SharedBufferNodeSerializer.snapshotConfiguration() |
TypeSerializerSnapshot<EventId> |
EventId.EventIdSerializer.snapshotConfiguration() |
TypeSerializerSnapshot<SharedBufferNode> |
SharedBufferNode.SharedBufferNodeSerializer.snapshotConfiguration()
Deprecated.
|
TypeSerializerSnapshot<NodeId> |
NodeId.NodeIdSerializer.snapshotConfiguration() |
TypeSerializerSnapshot<SharedBufferEdge> |
SharedBufferEdge.SharedBufferEdgeSerializer.snapshotConfiguration() |
TypeSerializerSnapshot<Lockable<E>> |
Lockable.LockableTypeSerializer.snapshotConfiguration() |
<U> TypeSerializerSnapshot<Lockable<E>> |
Lockable.LockableTypeSerializer.transformLegacySerializerSnapshot(TypeSerializerSnapshot<U> legacySnapshot) |
Modifier and Type | Method and Description |
---|---|
<U> TypeSerializerSnapshot<Lockable<E>> |
Lockable.LockableTypeSerializer.transformLegacySerializerSnapshot(TypeSerializerSnapshot<U> legacySnapshot) |
Modifier and Type | Class and Description |
---|---|
static class |
CheckpointAndXidSerializer.CheckpointAndXidSimpleTypeSerializerSnapshot
SImple
TypeSerializerSnapshot for CheckpointAndXidSerializer . |
static class |
XaSinkStateSerializer.XaSinkStateSimpleXaTypeSerializerSnapshot
Simple
TypeSerializerSnapshot for XaSinkStateSerializer . |
static class |
XidSerializer.XidSimpleTypeSerializerSnapshot
Simple
TypeSerializerSnapshot for XidSerializer . |
Modifier and Type | Field and Description |
---|---|
static TypeSerializerSnapshot<CheckpointAndXid> |
CheckpointAndXidSerializer.SNAPSHOT |
Modifier and Type | Method and Description |
---|---|
TypeSerializerSnapshot<CheckpointAndXid> |
CheckpointAndXidSerializer.snapshotConfiguration() |
TypeSerializerSnapshot<Xid> |
XidSerializer.snapshotConfiguration() |
TypeSerializerSnapshot<org.apache.flink.connector.jdbc.xa.JdbcXaSinkFunctionState> |
XaSinkStateSerializer.snapshotConfiguration() |
Modifier and Type | Class and Description |
---|---|
static class |
PulsarSchemaTypeSerializer.PulsarSchemaTypeSerializerSnapshot<T>
Snapshot for PulsarSchemaTypeSerializer, we only snapshot the SerializablePulsarSchema into
the state.
|
Modifier and Type | Method and Description |
---|---|
TypeSerializerSnapshot<T> |
PulsarSchemaTypeSerializer.snapshotConfiguration() |
Modifier and Type | Method and Description |
---|---|
TypeSerializerSnapshot<T> |
SimpleVersionedSerializerTypeSerializerProxy.snapshotConfiguration() |
Modifier and Type | Class and Description |
---|---|
static class |
AvroSerializer.AvroSchemaSerializerConfigSnapshot<T>
Deprecated.
|
class |
AvroSerializerSnapshot<T>
An
Avro specific implementation of a TypeSerializerSnapshot . |
Modifier and Type | Method and Description |
---|---|
TypeSerializerSnapshot<T> |
AvroSerializer.snapshotConfiguration() |
Modifier and Type | Class and Description |
---|---|
static class |
LongValueWithProperHashCode.LongValueWithProperHashCodeSerializer.LongValueWithProperHashCodeSerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
Modifier and Type | Method and Description |
---|---|
TypeSerializerSnapshot<LongValueWithProperHashCode> |
LongValueWithProperHashCode.LongValueWithProperHashCodeSerializer.snapshotConfiguration() |
Modifier and Type | Class and Description |
---|---|
static class |
ByteValueArraySerializer.ByteValueArraySerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
static class |
CharValueArraySerializer.CharValueArraySerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
static class |
DoubleValueArraySerializer.DoubleValueArraySerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
static class |
FloatValueArraySerializer.FloatValueArraySerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
static class |
IntValueArraySerializer.IntValueArraySerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
static class |
LongValueArraySerializer.LongValueArraySerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
static class |
NullValueArraySerializer.NullValueArraySerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
static class |
ShortValueArraySerializer.ShortValueArraySerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
static class |
StringValueArraySerializer.StringValueArraySerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
Modifier and Type | Method and Description |
---|---|
TypeSerializerSnapshot<NullValueArray> |
NullValueArraySerializer.snapshotConfiguration() |
TypeSerializerSnapshot<LongValueArray> |
LongValueArraySerializer.snapshotConfiguration() |
TypeSerializerSnapshot<IntValueArray> |
IntValueArraySerializer.snapshotConfiguration() |
TypeSerializerSnapshot<ByteValueArray> |
ByteValueArraySerializer.snapshotConfiguration() |
TypeSerializerSnapshot<CharValueArray> |
CharValueArraySerializer.snapshotConfiguration() |
TypeSerializerSnapshot<ShortValueArray> |
ShortValueArraySerializer.snapshotConfiguration() |
TypeSerializerSnapshot<DoubleValueArray> |
DoubleValueArraySerializer.snapshotConfiguration() |
TypeSerializerSnapshot<FloatValueArray> |
FloatValueArraySerializer.snapshotConfiguration() |
TypeSerializerSnapshot<StringValueArray> |
StringValueArraySerializer.snapshotConfiguration() |
Modifier and Type | Class and Description |
---|---|
class |
VoidNamespaceSerializer.VoidNamespaceSerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
Modifier and Type | Method and Description |
---|---|
TypeSerializerSnapshot<VoidNamespace> |
VoidNamespaceSerializer.snapshotConfiguration() |
Modifier and Type | Class and Description |
---|---|
class |
ArrayListSerializerSnapshot<T>
Snapshot class for the
ArrayListSerializer . |
static class |
JavaSerializer.JavaSerializerSnapshot<T extends Serializable>
Serializer configuration snapshot for compatibility and format evolution.
|
Modifier and Type | Method and Description |
---|---|
TypeSerializerSnapshot<K> |
KeyedBackendSerializationProxy.getKeySerializerSnapshot() |
TypeSerializerSnapshot<T> |
StateSerializerProvider.getPreviousSerializerSnapshot()
Gets the previous serializer snapshot.
|
TypeSerializerSnapshot<S> |
RegisteredKeyValueStateBackendMetaInfo.getPreviousStateSerializerSnapshot() |
TypeSerializerSnapshot<ArrayList<T>> |
ArrayListSerializer.snapshotConfiguration() |
TypeSerializerSnapshot<VoidNamespace> |
VoidNamespaceSerializer.snapshotConfiguration() |
TypeSerializerSnapshot<T> |
JavaSerializer.snapshotConfiguration() |
Modifier and Type | Method and Description |
---|---|
static <T> StateSerializerProvider<T> |
StateSerializerProvider.fromPreviousSerializerSnapshot(TypeSerializerSnapshot<T> stateSerializerSnapshot)
Creates a
StateSerializerProvider for restored state from the previous serializer's
snapshot. |
abstract TypeSerializerSchemaCompatibility<T> |
StateSerializerProvider.setPreviousSerializerSnapshotForRestoredState(TypeSerializerSnapshot<T> previousSerializerSnapshot)
For restored state, set the state's previous serializer's snapshot.
|
Modifier and Type | Method and Description |
---|---|
TypeSerializerSnapshot<?> |
StateMetaInfoSnapshot.getTypeSerializerSnapshot(StateMetaInfoSnapshot.CommonSerializerKeys key) |
TypeSerializerSnapshot<?> |
StateMetaInfoSnapshot.getTypeSerializerSnapshot(String key) |
Modifier and Type | Method and Description |
---|---|
Map<String,TypeSerializerSnapshot<?>> |
StateMetaInfoSnapshot.getSerializerSnapshotsImmutable() |
Constructor and Description |
---|
StateMetaInfoSnapshot(String name,
StateMetaInfoSnapshot.BackendStateType backendStateType,
Map<String,String> options,
Map<String,TypeSerializerSnapshot<?>> serializerSnapshots) |
StateMetaInfoSnapshot(String name,
StateMetaInfoSnapshot.BackendStateType backendStateType,
Map<String,String> options,
Map<String,TypeSerializerSnapshot<?>> serializerSnapshots,
Map<String,TypeSerializer<?>> serializers)
TODO this variant, which requires providing the serializers, TODO should actually be removed,
leaving only
StateMetaInfoSnapshot(String, BackendStateType, Map, Map) . |
Modifier and Type | Class and Description |
---|---|
static class |
TtlStateFactory.TtlSerializerSnapshot<T>
A
TypeSerializerSnapshot for TtlSerializer. |
Modifier and Type | Method and Description |
---|---|
TypeSerializerSnapshot<TtlValue<T>> |
TtlStateFactory.TtlSerializer.snapshotConfiguration() |
Modifier and Type | Class and Description |
---|---|
static class |
CoGroupedStreams.UnionSerializerConfigSnapshot<T1,T2>
Deprecated.
this snapshot class is no longer in use, and is maintained only for backwards
compatibility. It is fully replaced by
CoGroupedStreams.UnionSerializerSnapshot . |
static class |
CoGroupedStreams.UnionSerializerSnapshot<T1,T2>
The
TypeSerializerSnapshot for the CoGroupedStreams.UnionSerializer . |
Modifier and Type | Method and Description |
---|---|
TypeSerializerSnapshot<CoGroupedStreams.TaggedUnion<T1,T2>> |
CoGroupedStreams.UnionSerializer.snapshotConfiguration() |
Modifier and Type | Class and Description |
---|---|
static class |
TwoPhaseCommitSinkFunction.StateSerializerConfigSnapshot<TXN,CONTEXT>
Deprecated.
this snapshot class is no longer in use, and is maintained only for backwards
compatibility purposes. It is fully replaced by
TwoPhaseCommitSinkFunction.StateSerializerSnapshot . |
static class |
TwoPhaseCommitSinkFunction.StateSerializerSnapshot<TXN,CONTEXT>
Snapshot for the
TwoPhaseCommitSinkFunction.StateSerializer . |
Modifier and Type | Class and Description |
---|---|
static class |
TimerSerializer.TimerSerializerConfigSnapshot<K,N>
Deprecated.
this snapshot class is no longer in use, and is maintained only for backwards
compatibility purposes. It is fully replaced by
TimerSerializerSnapshot . |
class |
TimerSerializerSnapshot<K,N>
Snapshot class for the
TimerSerializer . |
Modifier and Type | Method and Description |
---|---|
TypeSerializerSnapshot<K> |
InternalTimersSnapshot.getKeySerializerSnapshot() |
TypeSerializerSnapshot<N> |
InternalTimersSnapshot.getNamespaceSerializerSnapshot() |
TypeSerializerSnapshot<TimerHeapInternalTimer<K,N>> |
InternalTimersSnapshotReaderWriters.LegacyTimerSerializer.snapshotConfiguration() |
Modifier and Type | Method and Description |
---|---|
void |
InternalTimersSnapshot.setKeySerializerSnapshot(TypeSerializerSnapshot<K> keySerializerConfigSnapshot) |
void |
InternalTimersSnapshot.setNamespaceSerializerSnapshot(TypeSerializerSnapshot<N> namespaceSerializerConfigSnapshot) |
Modifier and Type | Class and Description |
---|---|
static class |
IntervalJoinOperator.BufferEntrySerializerSnapshot<T>
|
static class |
IntervalJoinOperator.BufferSerializerConfigSnapshot<T>
Deprecated.
this snapshot class is no longer in use, and is maintained only for backwards
compatibility. It is fully replaced by
IntervalJoinOperator.BufferEntrySerializerSnapshot . |
Modifier and Type | Method and Description |
---|---|
TypeSerializerSnapshot<IntervalJoinOperator.BufferEntry<T>> |
IntervalJoinOperator.BufferEntrySerializer.snapshotConfiguration() |
Modifier and Type | Class and Description |
---|---|
static class |
ByteArrayWrapperSerializer.ByteArrayWrapperSerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
Modifier and Type | Method and Description |
---|---|
TypeSerializerSnapshot<ByteArrayWrapper> |
ByteArrayWrapperSerializer.snapshotConfiguration() |
Modifier and Type | Class and Description |
---|---|
static class |
GlobalWindow.Serializer.GlobalWindowSerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
static class |
TimeWindow.Serializer.TimeWindowSerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
Modifier and Type | Method and Description |
---|---|
TypeSerializerSnapshot<GlobalWindow> |
GlobalWindow.Serializer.snapshotConfiguration() |
TypeSerializerSnapshot<TimeWindow> |
TimeWindow.Serializer.snapshotConfiguration() |
Modifier and Type | Class and Description |
---|---|
static class |
FlinkKafkaProducer.ContextStateSerializer.ContextStateSerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
static class |
FlinkKafkaProducer.NextTransactionalIdHintSerializer.NextTransactionalIdHintSerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
static class |
FlinkKafkaProducer.TransactionStateSerializer.TransactionStateSerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
static class |
FlinkKafkaProducer011.ContextStateSerializer.ContextStateSerializerSnapshot |
static class |
FlinkKafkaProducer011.NextTransactionalIdHintSerializer.NextTransactionalIdHintSerializerSnapshot |
static class |
FlinkKafkaProducer011.TransactionStateSerializer.TransactionStateSerializerSnapshot |
Modifier and Type | Method and Description |
---|---|
TypeSerializerSnapshot<FlinkKafkaProducer.KafkaTransactionState> |
FlinkKafkaProducer.TransactionStateSerializer.snapshotConfiguration() |
TypeSerializerSnapshot<FlinkKafkaProducer.KafkaTransactionContext> |
FlinkKafkaProducer.ContextStateSerializer.snapshotConfiguration() |
TypeSerializerSnapshot<FlinkKafkaProducer.NextTransactionalIdHint> |
FlinkKafkaProducer.NextTransactionalIdHintSerializer.snapshotConfiguration() |
Modifier and Type | Class and Description |
---|---|
static class |
StreamElementSerializer.StreamElementSerializerConfigSnapshot<T>
Deprecated.
|
static class |
StreamElementSerializer.StreamElementSerializerSnapshot<T>
Configuration snapshot specific to the
StreamElementSerializer . |
Modifier and Type | Class and Description |
---|---|
static class |
StatefulComplexPayloadSerializer.Snapshot
Snapshot for the
StatefulComplexPayloadSerializer . |
Modifier and Type | Class and Description |
---|---|
static class |
ValueWithTs.ValueWithTsSerializerSnapshot
A
TypeSerializerSnapshot for ValueWithTs Serializer. |
Modifier and Type | Method and Description |
---|---|
TypeSerializerSnapshot<ValueWithTs<?>> |
ValueWithTs.Serializer.snapshotConfiguration() |
Modifier and Type | Class and Description |
---|---|
class |
ListViewSerializerSnapshot<T>
Deprecated.
|
class |
MapViewSerializerSnapshot<K,V>
Deprecated.
|
class |
NullAwareMapSerializerSnapshot<K,V>
Deprecated.
|
static class |
NullSerializer.NullSerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
Modifier and Type | Method and Description |
---|---|
TypeSerializerSnapshot<Object> |
NullSerializer.snapshotConfiguration() |
TypeSerializerSnapshot<Map<K,V>> |
NullAwareMapSerializer.snapshotConfiguration()
Deprecated.
|
TypeSerializerSnapshot<ListView<T>> |
ListViewSerializer.snapshotConfiguration()
Deprecated.
|
TypeSerializerSnapshot<MapView<K,V>> |
MapViewSerializer.snapshotConfiguration()
Deprecated.
|
<U> TypeSerializerSnapshot<ListView<T>> |
ListViewSerializer.transformLegacySerializerSnapshot(TypeSerializerSnapshot<U> legacySnapshot)
Deprecated.
We need to override this as a
LegacySerializerSnapshotTransformer because in Flink
1.6.x and below, this serializer was incorrectly returning directly the snapshot of the
nested list serializer as its own snapshot. |
<U> TypeSerializerSnapshot<MapView<K,V>> |
MapViewSerializer.transformLegacySerializerSnapshot(TypeSerializerSnapshot<U> legacySnapshot)
Deprecated.
We need to override this as a
LegacySerializerSnapshotTransformer because in Flink
1.6.x and below, this serializer was incorrectly returning directly the snapshot of the
nested map serializer as its own snapshot. |
Modifier and Type | Method and Description |
---|---|
<U> TypeSerializerSnapshot<ListView<T>> |
ListViewSerializer.transformLegacySerializerSnapshot(TypeSerializerSnapshot<U> legacySnapshot)
Deprecated.
We need to override this as a
LegacySerializerSnapshotTransformer because in Flink
1.6.x and below, this serializer was incorrectly returning directly the snapshot of the
nested list serializer as its own snapshot. |
<U> TypeSerializerSnapshot<MapView<K,V>> |
MapViewSerializer.transformLegacySerializerSnapshot(TypeSerializerSnapshot<U> legacySnapshot)
Deprecated.
We need to override this as a
LegacySerializerSnapshotTransformer because in Flink
1.6.x and below, this serializer was incorrectly returning directly the snapshot of the
nested map serializer as its own snapshot. |
Modifier and Type | Class and Description |
---|---|
static class |
CountWindow.Serializer.CountWindowSerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
Modifier and Type | Method and Description |
---|---|
TypeSerializerSnapshot<TimeWindow> |
TimeWindow.Serializer.snapshotConfiguration() |
TypeSerializerSnapshot<CountWindow> |
CountWindow.Serializer.snapshotConfiguration() |
Modifier and Type | Class and Description |
---|---|
static class |
MapDataSerializer.BaseMapSerializerSnapshot
|
static class |
TimeSerializer.TimeSerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
|
static class |
TimestampSerializer.TimestampSerializerSnapshot
|
Modifier and Type | Method and Description |
---|---|
TypeSerializerSnapshot<String> |
StringSerializer.snapshotConfiguration() |
TypeSerializerSnapshot<Date> |
DateSerializer.snapshotConfiguration() |
TypeSerializerSnapshot<MapData> |
MapDataSerializer.snapshotConfiguration() |
TypeSerializerSnapshot<BigDecimal> |
BigDecSerializer.snapshotConfiguration() |
TypeSerializerSnapshot<RowData> |
RowDataSerializer.snapshotConfiguration() |
TypeSerializerSnapshot<Timestamp> |
TimestampSerializer.snapshotConfiguration() |
TypeSerializerSnapshot<ArrayData> |
ArrayDataSerializer.snapshotConfiguration() |
TypeSerializerSnapshot<DecimalData> |
DecimalDataSerializer.snapshotConfiguration() |
TypeSerializerSnapshot<Time> |
TimeSerializer.snapshotConfiguration() |
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.