Modifier and Type | Method and Description |
---|---|
static <T> TypeSerializerSchemaCompatibility<T> |
TypeSerializerSchemaCompatibility.compatibleAfterMigration()
Returns a result that indicates that the new serializer can be used after migrating the written bytes, i.e.
|
static <T> TypeSerializerSchemaCompatibility<T> |
TypeSerializerSchemaCompatibility.compatibleAsIs()
Returns a result that indicates that the new serializer is compatible and no migration is required.
|
static <T> TypeSerializerSchemaCompatibility<T> |
TypeSerializerSchemaCompatibility.compatibleWithReconfiguredSerializer(TypeSerializer<T> reconfiguredSerializer)
Returns a result that indicates a reconfigured version of the new serializer is compatible, and should be
used instead of the original new serializer.
|
static <T> TypeSerializerSchemaCompatibility<T> |
CompositeTypeSerializerUtil.delegateCompatibilityCheckToNewSnapshot(TypeSerializer<T> newSerializer,
CompositeTypeSerializerSnapshot<T,? extends TypeSerializer> newCompositeSnapshot,
TypeSerializerSnapshot<?>... legacyNestedSnapshots)
Delegates compatibility checks to a
CompositeTypeSerializerSnapshot instance. |
TypeSerializerSchemaCompatibility<T> |
CompositeTypeSerializerUtil.IntermediateCompatibilityResult.getFinalResult() |
static <T> TypeSerializerSchemaCompatibility<T> |
TypeSerializerSchemaCompatibility.incompatible()
Returns a result that indicates there is no possible way for the new serializer to be use-able.
|
<T> TypeSerializerSchemaCompatibility<T> |
NestedSerializersSnapshotDelegate.resolveCompatibilityWithNested(TypeSerializerSchemaCompatibility<?> outerCompatibility,
TypeSerializer<?>... newNestedSerializers)
Deprecated.
this no method will be removed in the future. Resolving compatibility for nested
serializers is now handled by
CompositeTypeSerializerSnapshot . |
TypeSerializerSchemaCompatibility<T> |
TypeSerializerConfigSnapshot.resolveSchemaCompatibility(TypeSerializer<T> newSerializer)
Deprecated.
|
TypeSerializerSchemaCompatibility<T> |
ParameterlessTypeSerializerConfig.resolveSchemaCompatibility(TypeSerializer<T> newSerializer)
Deprecated.
|
TypeSerializerSchemaCompatibility<T> |
GenericTypeSerializerSnapshot.resolveSchemaCompatibility(TypeSerializer<T> newSerializer) |
TypeSerializerSchemaCompatibility<T> |
SimpleTypeSerializerSnapshot.resolveSchemaCompatibility(TypeSerializer<T> newSerializer) |
TypeSerializerSchemaCompatibility<T> |
TypeSerializerSnapshot.resolveSchemaCompatibility(TypeSerializer<T> newSerializer)
Checks a new serializer's compatibility to read data written by the prior serializer.
|
TypeSerializerSchemaCompatibility<T> |
BackwardsCompatibleSerializerSnapshot.resolveSchemaCompatibility(TypeSerializer<T> newSerializer) |
TypeSerializerSchemaCompatibility<T> |
CompositeTypeSerializerSnapshot.resolveSchemaCompatibility(TypeSerializer<T> newSerializer) |
TypeSerializerSchemaCompatibility<E> |
TypeSerializerConfigSnapshot.SelfResolvingTypeSerializer.resolveSchemaCompatibilityViaRedirectingToNewSnapshotClass(TypeSerializerConfigSnapshot<E> deprecatedConfigSnapshot)
Resolve Schema Compatibility.
|
Modifier and Type | Method and Description |
---|---|
<T> TypeSerializerSchemaCompatibility<T> |
NestedSerializersSnapshotDelegate.resolveCompatibilityWithNested(TypeSerializerSchemaCompatibility<?> outerCompatibility,
TypeSerializer<?>... newNestedSerializers)
Deprecated.
this no method will be removed in the future. Resolving compatibility for nested
serializers is now handled by
CompositeTypeSerializerSnapshot . |
Modifier and Type | Method and Description |
---|---|
TypeSerializerSchemaCompatibility<C[]> |
GenericArraySerializerConfigSnapshot.resolveSchemaCompatibility(TypeSerializer<C[]> newSerializer)
Deprecated.
|
TypeSerializerSchemaCompatibility<C> |
CollectionSerializerConfigSnapshot.resolveSchemaCompatibility(TypeSerializer<C> newSerializer)
Deprecated.
|
TypeSerializerSchemaCompatibility<Map<K,V>> |
MapSerializerConfigSnapshot.resolveSchemaCompatibility(TypeSerializer<Map<K,V>> newSerializer)
Deprecated.
|
TypeSerializerSchemaCompatibility<T> |
EnumSerializer.EnumSerializerSnapshot.resolveSchemaCompatibility(TypeSerializer<T> newSerializer) |
TypeSerializerSchemaCompatibility<T> |
EnumSerializer.EnumSerializerConfigSnapshot.resolveSchemaCompatibility(TypeSerializer<T> newSerializer)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
TypeSerializerSchemaCompatibility<T> |
KryoSerializerSnapshot.resolveSchemaCompatibility(TypeSerializer<T> newSerializer) |
TypeSerializerSchemaCompatibility<T> |
KryoSerializer.KryoSerializerConfigSnapshot.resolveSchemaCompatibility(TypeSerializer<T> newSerializer)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
TypeSerializerSchemaCompatibility<scala.Option<E>> |
ScalaOptionSerializerConfigSnapshot.resolveSchemaCompatibility(TypeSerializer<scala.Option<E>> newSerializer)
Deprecated.
|
TypeSerializerSchemaCompatibility<T> |
TraversableSerializerConfigSnapshot.resolveSchemaCompatibility(TypeSerializer<T> newSerializer)
Deprecated.
|
TypeSerializerSchemaCompatibility<scala.util.Try<E>> |
ScalaTrySerializerConfigSnapshot.resolveSchemaCompatibility(TypeSerializer<scala.util.Try<E>> newSerializer)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
TypeSerializerSchemaCompatibility<NFA.MigratedNFA<T>> |
NFA.NFASerializerConfigSnapshot.resolveSchemaCompatibility(TypeSerializer<NFA.MigratedNFA<T>> newSerializer)
Deprecated.
|
TypeSerializerSchemaCompatibility<SharedBuffer<V>> |
SharedBuffer.SharedBufferSerializerConfigSnapshot.resolveSchemaCompatibility(TypeSerializer<SharedBuffer<V>> newSerializer)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
TypeSerializerSchemaCompatibility<T> |
AvroSerializerSnapshot.resolveSchemaCompatibility(TypeSerializer<T> newSerializer) |
Modifier and Type | Method and Description |
---|---|
abstract TypeSerializerSchemaCompatibility<T> |
StateSerializerProvider.registerNewSerializerForRestoredState(TypeSerializer<T> newSerializer)
For restored state, register a new serializer that potentially has a new serialization schema.
|
TypeSerializerSchemaCompatibility<ArrayList<T>> |
ArrayListSerializer.resolveSchemaCompatibilityViaRedirectingToNewSnapshotClass(TypeSerializerConfigSnapshot<ArrayList<T>> deprecatedConfigSnapshot)
We need to implement this method as a
TypeSerializerConfigSnapshot.SelfResolvingTypeSerializer
because this serializer was previously returning a shared CollectionSerializerConfigSnapshot
as its snapshot. |
abstract TypeSerializerSchemaCompatibility<T> |
StateSerializerProvider.setPreviousSerializerSnapshotForRestoredState(TypeSerializerSnapshot<T> previousSerializerSnapshot)
For restored state, set the state's previous serializer's snapshot.
|
TypeSerializerSchemaCompatibility<T> |
RegisteredPriorityQueueStateBackendMetaInfo.updateElementSerializer(TypeSerializer<T> newElementSerializer) |
TypeSerializerSchemaCompatibility<K> |
RegisteredBroadcastStateBackendMetaInfo.updateKeySerializer(TypeSerializer<K> newKeySerializer) |
TypeSerializerSchemaCompatibility<N> |
RegisteredKeyValueStateBackendMetaInfo.updateNamespaceSerializer(TypeSerializer<N> newNamespaceSerializer) |
TypeSerializerSchemaCompatibility<S> |
RegisteredOperatorStateBackendMetaInfo.updatePartitionStateSerializer(TypeSerializer<S> newPartitionStateSerializer) |
TypeSerializerSchemaCompatibility<S> |
RegisteredKeyValueStateBackendMetaInfo.updateStateSerializer(TypeSerializer<S> newStateSerializer) |
TypeSerializerSchemaCompatibility<V> |
RegisteredBroadcastStateBackendMetaInfo.updateValueSerializer(TypeSerializer<V> newValueSerializer) |
Modifier and Type | Method and Description |
---|---|
TypeSerializerSchemaCompatibility<TtlValue<T>> |
TtlStateFactory.TtlSerializer.resolveSchemaCompatibilityViaRedirectingToNewSnapshotClass(TypeSerializerConfigSnapshot<TtlValue<T>> deprecatedConfigSnapshot) |
Modifier and Type | Method and Description |
---|---|
TypeSerializerSchemaCompatibility<CoGroupedStreams.TaggedUnion<T1,T2>> |
CoGroupedStreams.UnionSerializerConfigSnapshot.resolveSchemaCompatibility(TypeSerializer<CoGroupedStreams.TaggedUnion<T1,T2>> newSerializer)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
TypeSerializerSchemaCompatibility<TwoPhaseCommitSinkFunction.State<TXN,CONTEXT>> |
TwoPhaseCommitSinkFunction.StateSerializerConfigSnapshot.resolveSchemaCompatibility(TypeSerializer<TwoPhaseCommitSinkFunction.State<TXN,CONTEXT>> newSerializer)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
TypeSerializerSchemaCompatibility<TimerHeapInternalTimer<K,N>> |
TimerSerializer.TimerSerializerConfigSnapshot.resolveSchemaCompatibility(TypeSerializer<TimerHeapInternalTimer<K,N>> newSerializer)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
TypeSerializerSchemaCompatibility<org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntry<T>> |
IntervalJoinOperator.BufferSerializerConfigSnapshot.resolveSchemaCompatibility(TypeSerializer<org.apache.flink.streaming.api.operators.co.IntervalJoinOperator.BufferEntry<T>> newSerializer)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
TypeSerializerSchemaCompatibility<StreamElement> |
StreamElementSerializer.StreamElementSerializerConfigSnapshot.resolveSchemaCompatibility(TypeSerializer<StreamElement> newSerializer)
Deprecated.
|
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.