Modifier and Type | Method and Description |
---|---|
void |
SerializedListAccumulator.add(T value,
TypeSerializer<T> serializer) |
static <T> List<T> |
SerializedListAccumulator.deserializeList(ArrayList<byte[]> data,
TypeSerializer<T> serializer) |
Constructor and Description |
---|
CopyingIterator(Iterator<E> source,
TypeSerializer<E> serializer) |
CopyingListCollector(List<T> list,
TypeSerializer<T> serializer) |
Constructor and Description |
---|
SimpleListIterable(List<IN> values,
TypeComparator<IN> comparator,
TypeSerializer<IN> serializer) |
SimpleListIterator(List<IN> values,
TypeSerializer<IN> serializer) |
Modifier and Type | Method and Description |
---|---|
TypeSerializer<BT> |
JoinHashMap.getBuildSerializer() |
Constructor and Description |
---|
JoinHashMap(TypeSerializer<BT> buildSerializer,
TypeComparator<BT> buildComparator) |
ListKeyGroupedIterator(List<E> input,
TypeSerializer<E> serializer,
TypeComparator<E> comparator)
Initializes the ListKeyGroupedIterator..
|
Constructor and Description |
---|
TypeInformationSerializationSchema(TypeInformation<T> typeInfo,
TypeSerializer<T> serializer)
Creates a new de-/serialization schema for the given type.
|
Modifier and Type | Method and Description |
---|---|
TypeSerializer<T> |
ListStateDescriptor.getElementSerializer()
Gets the serializer for the elements contained in the list.
|
TypeSerializer<UK> |
MapStateDescriptor.getKeySerializer()
Gets the serializer for the keys in the state.
|
TypeSerializer<T> |
StateDescriptor.getSerializer()
Returns the
TypeSerializer that can be used to serialize the value in the state. |
TypeSerializer<UV> |
MapStateDescriptor.getValueSerializer()
Gets the serializer for the values in the state.
|
Constructor and Description |
---|
AggregatingStateDescriptor(String name,
AggregateFunction<IN,ACC,OUT> aggFunction,
TypeSerializer<ACC> typeSerializer)
Creates a new
ValueStateDescriptor with the given name and default value. |
ListStateDescriptor(String name,
TypeSerializer<T> typeSerializer)
Creates a new
ListStateDescriptor with the given name and list element type. |
MapStateDescriptor(String name,
TypeSerializer<UK> keySerializer,
TypeSerializer<UV> valueSerializer)
Create a new
MapStateDescriptor with the given name and the given type serializers. |
MapStateDescriptor(String name,
TypeSerializer<UK> keySerializer,
TypeSerializer<UV> valueSerializer)
Create a new
MapStateDescriptor with the given name and the given type serializers. |
ReducingStateDescriptor(String name,
ReduceFunction<T> reduceFunction,
TypeSerializer<T> typeSerializer)
Creates a new
ValueStateDescriptor with the given name and default value. |
StateDescriptor(String name,
TypeSerializer<T> serializer,
T defaultValue)
Create a new
StateDescriptor with the given name and the given type serializer. |
ValueStateDescriptor(String name,
TypeSerializer<T> typeSerializer)
Creates a new
ValueStateDescriptor with the given name and the specific serializer. |
ValueStateDescriptor(String name,
TypeSerializer<T> typeSerializer,
T defaultValue)
Deprecated.
Use
ValueStateDescriptor(String, TypeSerializer) instead and manually
manage the default value by checking whether the contents of the state is null . |
Modifier and Type | Method and Description |
---|---|
TypeSerializer<T> |
SqlTimeTypeInfo.createSerializer(ExecutionConfig executionConfig) |
abstract TypeSerializer<T> |
TypeInformation.createSerializer(ExecutionConfig config)
Creates a serializer for the type.
|
TypeSerializer<Nothing> |
NothingTypeInfo.createSerializer(ExecutionConfig executionConfig) |
TypeSerializer<T> |
LocalTimeTypeInfo.createSerializer(ExecutionConfig executionConfig) |
TypeSerializer<T> |
PrimitiveArrayTypeInfo.createSerializer(ExecutionConfig executionConfig) |
TypeSerializer<T> |
BasicTypeInfo.createSerializer(ExecutionConfig executionConfig) |
TypeSerializer<T> |
BasicArrayTypeInfo.createSerializer(ExecutionConfig executionConfig) |
Constructor and Description |
---|
BasicTypeInfo(Class<T> clazz,
Class<?>[] possibleCastTargetTypes,
TypeSerializer<T> serializer,
Class<? extends TypeComparator<T>> comparatorClass) |
FractionalTypeInfo(Class<T> clazz,
Class<?>[] possibleCastTargetTypes,
TypeSerializer<T> serializer,
Class<? extends TypeComparator<T>> comparatorClass) |
IntegerTypeInfo(Class<T> clazz,
Class<?>[] possibleCastTargetTypes,
TypeSerializer<T> serializer,
Class<? extends TypeComparator<T>> comparatorClass) |
LocalTimeTypeInfo(Class<T> clazz,
TypeSerializer<T> serializer,
Class<? extends TypeComparator<T>> comparatorClass) |
NumericTypeInfo(Class<T> clazz,
Class<?>[] possibleCastTargetTypes,
TypeSerializer<T> serializer,
Class<? extends TypeComparator<T>> comparatorClass) |
SqlTimeTypeInfo(Class<T> clazz,
TypeSerializer<T> serializer,
Class<? extends TypeComparator<T>> comparatorClass) |
Modifier and Type | Class and Description |
---|---|
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 |
GenericTypeSerializerSnapshot<T,S extends TypeSerializer>
Base
TypeSerializerSnapshot for serializers for generic types. |
Modifier and Type | Class and Description |
---|---|
class |
CompositeSerializer<T>
Base class for composite serializers.
|
class |
SingleThreadAccessCheckingTypeSerializer<T> |
class |
UnloadableDummyTypeSerializer<T>
Dummy TypeSerializer to avoid that data is lost when checkpointing again a serializer for which
we encountered a
ClassNotFoundException or InvalidClassException . |
Modifier and Type | Field and Description |
---|---|
protected TypeSerializer<Object>[] |
CompositeSerializer.fieldSerializers
Serializers for fields which constitute T.
|
Modifier and Type | Method and Description |
---|---|
protected abstract TypeSerializer<T> |
GenericTypeSerializerSnapshot.createSerializer(Class<T> typeClass)
Create a serializer that is able to serialize the generic type
typeClass . |
abstract TypeSerializer<T> |
TypeSerializer.duplicate()
Creates a deep copy of this serializer if it is necessary, i.e.
|
TypeSerializer<T> |
SingleThreadAccessCheckingTypeSerializer.duplicate() |
TypeSerializer<T> |
UnloadableDummyTypeSerializer.duplicate() |
TypeSerializer<?>[] |
CompositeTypeSerializerUtil.IntermediateCompatibilityResult.getNestedSerializers() |
protected abstract TypeSerializer<?>[] |
CompositeTypeSerializerSnapshot.getNestedSerializers(S outerSerializer)
Gets the nested serializers from the outer serializer.
|
protected TypeSerializer<?>[] |
SingleThreadAccessCheckingTypeSerializer.SingleThreadAccessCheckingTypeSerializerSnapshot.getNestedSerializers(SingleThreadAccessCheckingTypeSerializer<T> outerSerializer) |
TypeSerializer<T> |
TypeSerializerSchemaCompatibility.getReconfiguredSerializer()
Gets the reconfigured serializer.
|
<T> TypeSerializer<T> |
NestedSerializersSnapshotDelegate.getRestoredNestedSerializer(int pos)
Creates the restore serializer from the pos-th config snapshot.
|
TypeSerializer<?>[] |
NestedSerializersSnapshotDelegate.getRestoredNestedSerializers()
Produces a restore serializer from each contained serializer configuration snapshot.
|
TypeSerializer<T> |
TypeSerializerFactory.getSerializer() |
TypeSerializer<T> |
TypeSerializerSerializationUtil.TypeSerializerSerializationProxy.getTypeSerializer() |
TypeSerializer<T> |
SimpleTypeSerializerSnapshot.restoreSerializer() |
TypeSerializer<T> |
GenericTypeSerializerSnapshot.restoreSerializer() |
TypeSerializer<T> |
CompositeTypeSerializerSnapshot.restoreSerializer() |
TypeSerializer<T> |
TypeSerializerConfigSnapshot.restoreSerializer()
Deprecated.
Creates a serializer using this configuration, that is capable of reading data written by the
serializer described by this configuration.
|
TypeSerializer<T> |
BackwardsCompatibleSerializerSnapshot.restoreSerializer() |
TypeSerializer<T> |
TypeSerializerSnapshot.restoreSerializer()
Recreates a serializer instance from this snapshot.
|
static <T> TypeSerializer<T> |
TypeSerializerSerializationUtil.tryReadSerializer(DataInputView in,
ClassLoader userCodeClassLoader)
Deprecated.
Reads from a data input view a
TypeSerializer that was previously written using
TypeSerializerSerializationUtil.writeSerializer(DataOutputView, TypeSerializer) . |
static <T> TypeSerializer<T> |
TypeSerializerSerializationUtil.tryReadSerializer(DataInputView in,
ClassLoader userCodeClassLoader,
boolean useDummyPlaceholder)
Deprecated.
Reads from a data input view a
TypeSerializer that was previously written using
TypeSerializerSerializationUtil.writeSerializer(DataOutputView, TypeSerializer) . |
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> 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> 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. |
protected SingleThreadAccessCheckingTypeSerializer<T> |
SingleThreadAccessCheckingTypeSerializer.SingleThreadAccessCheckingTypeSerializerSnapshot.createOuterSerializerWithNestedSerializers(TypeSerializer<?>[] nestedSerializers) |
protected abstract S |
CompositeTypeSerializerSnapshot.createOuterSerializerWithNestedSerializers(TypeSerializer<?>[] nestedSerializers)
Creates an instance of the outer serializer with a given array of its nested serializers.
|
protected abstract CompositeSerializer<T> |
CompositeSerializer.createSerializerInstance(CompositeSerializer.PrecomputedParameters precomputed,
TypeSerializer<?>... originalSerializers)
Factory for concrete serializer.
|
static <T> TypeSerializerSchemaCompatibility<T> |
CompositeTypeSerializerUtil.delegateCompatibilityCheckToNewSnapshot(TypeSerializer<T> newSerializer,
CompositeTypeSerializerSnapshot<T,? extends TypeSerializer> newCompositeSnapshot,
TypeSerializerSnapshot<?>... legacyNestedSnapshots)
Delegates compatibility checks to a
CompositeTypeSerializerSnapshot instance. |
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) . |
<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> |
SimpleTypeSerializerSnapshot.resolveSchemaCompatibility(TypeSerializer<T> newSerializer) |
TypeSerializerSchemaCompatibility<T> |
GenericTypeSerializerSnapshot.resolveSchemaCompatibility(TypeSerializer<T> newSerializer) |
TypeSerializerSchemaCompatibility<T> |
CompositeTypeSerializerSnapshot.resolveSchemaCompatibility(TypeSerializer<T> newSerializer) |
TypeSerializerSchemaCompatibility<T> |
ParameterlessTypeSerializerConfig.resolveSchemaCompatibility(TypeSerializer<T> newSerializer)
Deprecated.
|
TypeSerializerSchemaCompatibility<T> |
TypeSerializerConfigSnapshot.resolveSchemaCompatibility(TypeSerializer<T> newSerializer)
Deprecated.
|
TypeSerializerSchemaCompatibility<T> |
BackwardsCompatibleSerializerSnapshot.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.
|
void |
TypeSerializerConfigSnapshot.setPriorSerializer(TypeSerializer<T> serializer)
Deprecated.
Set the originating serializer of this configuration snapshot.
|
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.
|
static <T> void |
TypeSerializerSerializationUtil.writeSerializer(DataOutputView out,
TypeSerializer<T> serializer)
Deprecated.
Writes a
TypeSerializer to the provided data output view. |
static <T> void |
TypeSerializerSnapshotSerializationUtil.writeSerializerSnapshot(DataOutputView out,
TypeSerializerSnapshot<T> serializerSnapshot,
TypeSerializer<T> serializer)
Writes a
TypeSerializerSnapshot to the provided data output view. |
Modifier and Type | Method and Description |
---|---|
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 |
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.
|
Constructor and Description |
---|
BackwardsCompatibleSerializerSnapshot(TypeSerializer<T> serializerInstance) |
CompositeSerializer(boolean immutableTargetType,
TypeSerializer<?>... fieldSerializers)
Can be used for user facing constructor.
|
CompositeSerializer(CompositeSerializer.PrecomputedParameters precomputed,
TypeSerializer<?>... fieldSerializers)
Can be used in createSerializerInstance for internal operations.
|
CompositeTypeSerializerConfigSnapshot(TypeSerializer<?>... nestedSerializers) |
NestedSerializersSnapshotDelegate(TypeSerializer<?>... serializers)
Constructor to create a snapshot for writing.
|
SingleThreadAccessCheckingTypeSerializer(TypeSerializer<T> originalSerializer) |
TypeSerializerSerializationProxy(TypeSerializer<T> typeSerializer) |
Constructor and Description |
---|
CompositeTypeSerializerSnapshot(Class<? extends TypeSerializer> correspondingSerializerClass)
Constructor to be used for read instantiation.
|
SimpleTypeSerializerSnapshot(java.util.function.Supplier<? extends TypeSerializer<T>> serializerSupplier)
Constructor to create snapshot from serializer (writing the snapshot).
|
Modifier and Type | Class and Description |
---|---|
class |
BigDecSerializer
Serializer for serializing/deserializing BigDecimal values including null values.
|
class |
BigIntSerializer
Serializer for serializing/deserializing BigInteger values including null values.
|
class |
BooleanSerializer
Type serializer for
Boolean . |
class |
BooleanValueSerializer |
class |
ByteSerializer
Type serializer for
Byte . |
class |
ByteValueSerializer |
class |
CharSerializer
Type serializer for
Character . |
class |
CharValueSerializer |
class |
DateSerializer |
class |
DoubleSerializer
Type serializer for
Double . |
class |
DoubleValueSerializer |
class |
EnumSerializer<T extends Enum<T>>
TypeSerializer for Java enums. |
class |
FloatSerializer
Type serializer for
Float . |
class |
FloatValueSerializer |
class |
GenericArraySerializer<C>
A serializer for arrays of objects.
|
class |
InstantSerializer
Serializer for serializing/deserializing Instant values including null values.
|
class |
IntSerializer
Type serializer for
Integer (and int , via auto-boxing). |
class |
IntValueSerializer |
class |
ListSerializer<T>
A serializer for
Lists . |
class |
LocalDateSerializer |
class |
LocalDateTimeSerializer |
class |
LocalTimeSerializer |
class |
LongSerializer
Type serializer for
Long . |
class |
LongValueSerializer |
class |
MapSerializer<K,V>
A serializer for
Map . |
class |
NullValueSerializer |
class |
ShortSerializer
Type serializer for
Byte . |
class |
ShortValueSerializer |
class |
SqlDateSerializer |
class |
SqlTimeSerializer |
class |
SqlTimestampSerializer |
class |
StringSerializer
Type serializer for
String . |
class |
StringValueSerializer |
class |
TypeSerializerSingleton<T> |
class |
VoidSerializer
Serializer for
Void . |
Modifier and Type | Method and Description |
---|---|
TypeSerializer<Map<K,V>> |
MapSerializer.duplicate() |
TypeSerializer<List<T>> |
ListSerializer.duplicate() |
TypeSerializer<C> |
GenericArraySerializer.getComponentSerializer() |
TypeSerializer<T> |
ListSerializer.getElementSerializer()
Gets the serializer for the elements of the list.
|
TypeSerializer<K> |
MapSerializer.getKeySerializer() |
protected TypeSerializer<?>[] |
GenericArraySerializerSnapshot.getNestedSerializers(GenericArraySerializer<C> outerSerializer) |
protected TypeSerializer<?>[] |
ListSerializerSnapshot.getNestedSerializers(ListSerializer<T> outerSerializer) |
protected TypeSerializer<?>[] |
MapSerializerSnapshot.getNestedSerializers(MapSerializer<K,V> outerSerializer) |
TypeSerializer<V> |
MapSerializer.getValueSerializer() |
TypeSerializer<T> |
EnumSerializer.EnumSerializerSnapshot.restoreSerializer() |
Constructor and Description |
---|
CollectionSerializerConfigSnapshot(TypeSerializer<T> elementSerializer)
Deprecated.
|
GenericArraySerializer(Class<C> componentClass,
TypeSerializer<C> componentSerializer) |
ListSerializer(TypeSerializer<T> elementSerializer)
Creates a list serializer that uses the given serializer to serialize the list's elements.
|
MapSerializer(TypeSerializer<K> keySerializer,
TypeSerializer<V> valueSerializer)
Creates a map serializer that uses the given serializers to serialize the key-value pairs in
the map.
|
MapSerializer(TypeSerializer<K> keySerializer,
TypeSerializer<V> valueSerializer)
Creates a map serializer that uses the given serializers to serialize the key-value pairs in
the map.
|
MapSerializerConfigSnapshot(TypeSerializer<K> keySerializer,
TypeSerializer<V> valueSerializer)
Deprecated.
|
MapSerializerConfigSnapshot(TypeSerializer<K> keySerializer,
TypeSerializer<V> valueSerializer)
Deprecated.
|
Modifier and Type | Class and Description |
---|---|
class |
BooleanPrimitiveArraySerializer
A serializer for boolean arrays.
|
class |
BytePrimitiveArraySerializer
A serializer for byte arrays.
|
class |
CharPrimitiveArraySerializer
A serializer for char arrays.
|
class |
DoublePrimitiveArraySerializer
A serializer for double arrays.
|
class |
FloatPrimitiveArraySerializer
A serializer for float arrays.
|
class |
IntPrimitiveArraySerializer
A serializer for int arrays.
|
class |
LongPrimitiveArraySerializer
A serializer for long arrays.
|
class |
ShortPrimitiveArraySerializer
A serializer for short arrays.
|
class |
StringArraySerializer
A serializer for String arrays.
|
Constructor and Description |
---|
CollectHelper(String id,
TypeSerializer<T> serializer) |
Modifier and Type | Method and Description |
---|---|
void |
TypeSerializerOutputFormat.setSerializer(TypeSerializer<T> serializer) |
Constructor and Description |
---|
CollectionInputFormat(Collection<T> dataSet,
TypeSerializer<T> serializer) |
Modifier and Type | Class and Description |
---|---|
class |
CopyableValueSerializer<T extends CopyableValue<T>> |
class |
EitherSerializer<L,R>
A
TypeSerializer for the Either type of the Java class. |
class |
NullableSerializer<T>
Serializer wrapper to add support of
null value serialization. |
class |
PojoSerializer<T> |
class |
RowSerializer
Serializer for
Row . |
class |
Tuple0Serializer |
class |
TupleSerializer<T extends Tuple> |
class |
TupleSerializerBase<T> |
class |
ValueSerializer<T extends Value>
Serializer for
Value types. |
class |
WritableSerializer<T extends org.apache.hadoop.io.Writable>
A
TypeSerializer for Writable . |
Modifier and Type | Field and Description |
---|---|
protected TypeSerializer<Object>[] |
TupleSerializerBase.fieldSerializers |
protected TypeSerializer[] |
TupleComparatorBase.serializers
serializers to deserialize the first n fields for comparison
|
Modifier and Type | Method and Description |
---|---|
protected TypeSerializer<T> |
WritableSerializer.WritableSerializerSnapshot.createSerializer(Class<T> typeClass) |
protected TypeSerializer<T> |
CopyableValueSerializer.CopyableValueSerializerSnapshot.createSerializer(Class<T> typeClass) |
protected TypeSerializer<T> |
ValueSerializer.ValueSerializerSnapshot.createSerializer(Class<T> typeClass) |
TypeSerializer<Row> |
RowSerializer.duplicate() |
TypeSerializer<T> |
NullableSerializer.duplicate() |
TypeSerializer<Either<L,R>> |
EitherSerializer.duplicate() |
TypeSerializer<Object>[] |
TupleSerializerBase.getFieldSerializers() |
TypeSerializer<L> |
EitherSerializer.getLeftSerializer() |
protected TypeSerializer<?>[] |
JavaEitherSerializerSnapshot.getNestedSerializers(EitherSerializer<L,R> outerSerializer) |
protected TypeSerializer<?>[] |
NullableSerializer.NullableSerializerSnapshot.getNestedSerializers(NullableSerializer<T> outerSerializer) |
protected TypeSerializer<?>[] |
RowSerializer.RowSerializerSnapshot.getNestedSerializers(RowSerializer outerSerializer) |
protected TypeSerializer<?>[] |
TupleSerializerSnapshot.getNestedSerializers(TupleSerializer<T> outerSerializer) |
TypeSerializer<R> |
EitherSerializer.getRightSerializer() |
TypeSerializer<T> |
RuntimeSerializerFactory.getSerializer() |
TypeSerializer<T> |
PojoSerializerSnapshot.restoreSerializer() |
static <T> TypeSerializer<T> |
NullableSerializer.wrap(TypeSerializer<T> originalSerializer,
boolean padNullValueIfFixedLen)
This method wraps the
originalSerializer with the NullableSerializer if not
already wrapped. |
static <T> TypeSerializer<T> |
NullableSerializer.wrapIfNullIsNotSupported(TypeSerializer<T> originalSerializer,
boolean padNullValueIfFixedLen)
This method tries to serialize
null value with the originalSerializer and
wraps it in case of NullPointerException , otherwise it returns the originalSerializer . |
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.
|
Modifier and Type | Method and Description |
---|---|
static <T> boolean |
NullableSerializer.checkIfNullSupported(TypeSerializer<T> serializer)
This method checks if
serializer supports null value. |
static <T> T |
KryoUtils.copy(T from,
com.esotericsoftware.kryo.Kryo kryo,
TypeSerializer<T> serializer)
Tries to copy the given record from using the provided Kryo instance.
|
static <T> T |
KryoUtils.copy(T from,
T reuse,
com.esotericsoftware.kryo.Kryo kryo,
TypeSerializer<T> serializer)
Tries to copy the given record from using the provided Kryo instance.
|
protected EitherSerializer<L,R> |
JavaEitherSerializerSnapshot.createOuterSerializerWithNestedSerializers(TypeSerializer<?>[] nestedSerializers) |
protected TupleSerializer<T> |
TupleSerializerSnapshot.createOuterSerializerWithNestedSerializers(TypeSerializer<?>[] nestedSerializers) |
protected RowSerializer |
RowSerializer.RowSerializerSnapshot.createOuterSerializerWithNestedSerializers(TypeSerializer<?>[] nestedSerializers) |
protected NullableSerializer<T> |
NullableSerializer.NullableSerializerSnapshot.createOuterSerializerWithNestedSerializers(TypeSerializer<?>[] nestedSerializers) |
TypeSerializerSchemaCompatibility<Either<L,R>> |
EitherSerializerSnapshot.resolveSchemaCompatibility(TypeSerializer<Either<L,R>> newSerializer)
Deprecated.
|
TypeSerializerSchemaCompatibility<Either<L,R>> |
EitherSerializerConfigSnapshot.resolveSchemaCompatibility(TypeSerializer<Either<L,R>> newSerializer)
Deprecated.
|
TypeSerializerSchemaCompatibility<Row> |
RowSerializer.RowSerializerConfigSnapshot.resolveSchemaCompatibility(TypeSerializer<Row> newSerializer)
Deprecated.
|
TypeSerializerSchemaCompatibility<T> |
WritableSerializer.WritableSerializerConfigSnapshot.resolveSchemaCompatibility(TypeSerializer<T> newSerializer)
Deprecated.
|
TypeSerializerSchemaCompatibility<T> |
PojoSerializer.PojoSerializerConfigSnapshot.resolveSchemaCompatibility(TypeSerializer<T> newSerializer)
Deprecated.
This legacy snapshot delegates compatibility checks to the
PojoSerializerSnapshot . |
TypeSerializerSchemaCompatibility<T> |
CopyableValueSerializer.CopyableValueSerializerConfigSnapshot.resolveSchemaCompatibility(TypeSerializer<T> newSerializer)
Deprecated.
|
TypeSerializerSchemaCompatibility<T> |
PojoSerializerSnapshot.resolveSchemaCompatibility(TypeSerializer<T> newSerializer) |
TypeSerializerSchemaCompatibility<T> |
ValueSerializer.ValueSerializerConfigSnapshot.resolveSchemaCompatibility(TypeSerializer<T> newSerializer)
Deprecated.
|
TypeSerializerSchemaCompatibility<T> |
NullableSerializer.NullableSerializerConfigSnapshot.resolveSchemaCompatibility(TypeSerializer<T> newSerializer)
Deprecated.
|
static <T> TypeSerializer<T> |
NullableSerializer.wrap(TypeSerializer<T> originalSerializer,
boolean padNullValueIfFixedLen)
This method wraps the
originalSerializer with the NullableSerializer if not
already wrapped. |
static <T> TypeSerializer<T> |
NullableSerializer.wrapIfNullIsNotSupported(TypeSerializer<T> originalSerializer,
boolean padNullValueIfFixedLen)
This method tries to serialize
null value with the originalSerializer and
wraps it in case of NullPointerException , otherwise it returns the originalSerializer . |
Constructor and Description |
---|
EitherSerializer(TypeSerializer<L> leftSerializer,
TypeSerializer<R> rightSerializer) |
EitherSerializer(TypeSerializer<L> leftSerializer,
TypeSerializer<R> rightSerializer) |
EitherSerializerSnapshot(TypeSerializer<L> leftSerializer,
TypeSerializer<R> rightSerializer)
Deprecated.
Constructor to create the snapshot for writing.
|
EitherSerializerSnapshot(TypeSerializer<L> leftSerializer,
TypeSerializer<R> rightSerializer)
Deprecated.
Constructor to create the snapshot for writing.
|
GenericTypeComparator(boolean ascending,
TypeSerializer<T> serializer,
Class<T> type) |
PojoComparator(Field[] keyFields,
TypeComparator<?>[] comparators,
TypeSerializer<T> serializer,
Class<T> type) |
PojoSerializer(Class<T> clazz,
TypeSerializer<?>[] fieldSerializers,
Field[] fields,
ExecutionConfig executionConfig)
Constructor to create a new
PojoSerializer . |
RowComparator(int arity,
int[] keyPositions,
TypeComparator<Object>[] comparators,
TypeSerializer<Object>[] serializers,
boolean[] orders)
General constructor for RowComparator.
|
RowSerializer(TypeSerializer<?>[] fieldSerializers) |
RowSerializer(TypeSerializer<?>[] fieldSerializers,
LinkedHashMap<String,Integer> positionByName) |
RowSerializer(TypeSerializer<?>[] fieldSerializers,
LinkedHashMap<String,Integer> positionByName,
boolean legacyModeEnabled) |
RowSerializerConfigSnapshot(TypeSerializer<?>[] fieldSerializers)
Deprecated.
|
RuntimeSerializerFactory(TypeSerializer<T> serializer,
Class<T> clazz) |
TupleComparator(int[] keyPositions,
TypeComparator<?>[] comparators,
TypeSerializer<?>[] serializers) |
TupleComparatorBase(int[] keyPositions,
TypeComparator<?>[] comparators,
TypeSerializer<?>[] serializers) |
TupleSerializer(Class<T> tupleClass,
TypeSerializer<?>[] fieldSerializers) |
TupleSerializerBase(Class<T> tupleClass,
TypeSerializer<?>[] fieldSerializers) |
TupleSerializerConfigSnapshot(Class<T> tupleClass,
TypeSerializer<?>[] fieldSerializers) |
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 |
---|---|
class |
KryoSerializer<T>
A type serializer that serializes its type using the Kryo serialization framework
(https://github.com/EsotericSoftware/kryo).
|
Modifier and Type | Method and Description |
---|---|
TypeSerializer<T> |
KryoSerializerSnapshot.restoreSerializer() |
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 |
---|---|
protected TypeSerializer<?>[] |
ScalaEitherSerializerSnapshot.getNestedSerializers(org.apache.flink.api.scala.typeutils.EitherSerializer<L,R> outerSerializer) |
protected TypeSerializer<?>[] |
ScalaOptionSerializerSnapshot.getNestedSerializers(org.apache.flink.api.scala.typeutils.OptionSerializer<E> outerSerializer) |
protected TypeSerializer<?>[] |
ScalaCaseClassSerializerSnapshot.getNestedSerializers(org.apache.flink.api.scala.typeutils.ScalaCaseClassSerializer<T> outerSerializer) |
protected TypeSerializer<?>[] |
Tuple2CaseClassSerializerSnapshot.getNestedSerializers(org.apache.flink.api.scala.typeutils.ScalaCaseClassSerializer<scala.Tuple2<T1,T2>> outerSerializer) |
protected TypeSerializer<?>[] |
TraversableSerializerSnapshot.getNestedSerializers(org.apache.flink.api.scala.typeutils.TraversableSerializer<T,E> outerSerializer) |
protected TypeSerializer<?>[] |
ScalaTrySerializerSnapshot.getNestedSerializers(org.apache.flink.api.scala.typeutils.TrySerializer<E> outerSerializer) |
Modifier and Type | Method and Description |
---|---|
protected org.apache.flink.api.scala.typeutils.EitherSerializer<L,R> |
ScalaEitherSerializerSnapshot.createOuterSerializerWithNestedSerializers(TypeSerializer<?>[] nestedSerializers) |
protected org.apache.flink.api.scala.typeutils.ScalaCaseClassSerializer<T> |
ScalaCaseClassSerializerSnapshot.createOuterSerializerWithNestedSerializers(TypeSerializer<?>[] nestedSerializers) |
protected org.apache.flink.api.scala.typeutils.ScalaCaseClassSerializer<scala.Tuple2<T1,T2>> |
Tuple2CaseClassSerializerSnapshot.createOuterSerializerWithNestedSerializers(TypeSerializer<?>[] nestedSerializers) |
protected org.apache.flink.api.scala.typeutils.TrySerializer<E> |
ScalaTrySerializerSnapshot.createOuterSerializerWithNestedSerializers(TypeSerializer<?>[] nestedSerializers) |
protected org.apache.flink.api.scala.typeutils.TraversableSerializer<T,E> |
TraversableSerializerSnapshot.createOuterSerializerWithNestedSerializers(TypeSerializer<?>[] nestedSerializers) |
protected org.apache.flink.api.scala.typeutils.OptionSerializer<E> |
ScalaOptionSerializerSnapshot.createOuterSerializerWithNestedSerializers(TypeSerializer<?>[] nestedSerializers) |
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.
|
Constructor and Description |
---|
ScalaOptionSerializerConfigSnapshot(TypeSerializer<E> elementSerializer)
Deprecated.
|
ScalaTrySerializerConfigSnapshot(TypeSerializer<E> elementSerializer,
TypeSerializer<Throwable> throwableSerializer)
Deprecated.
|
ScalaTrySerializerConfigSnapshot(TypeSerializer<E> elementSerializer,
TypeSerializer<Throwable> throwableSerializer)
Deprecated.
|
TraversableSerializerConfigSnapshot(TypeSerializer<E> elementSerializer)
Deprecated.
|
Modifier and Type | Class and Description |
---|---|
static class |
DeweyNumber.DeweyNumberSerializer
A
TypeSerializer for the DeweyNumber which serves as a version number. |
static class |
NFA.NFASerializer<T>
Deprecated.
|
class |
NFAStateSerializer
A
TypeSerializer for NFAState . |
static class |
SharedBuffer.SharedBufferSerializer<K,V>
Deprecated.
A
TypeSerializer for the SharedBuffer . |
Modifier and Type | Method and Description |
---|---|
TypeSerializer<K> |
SharedBuffer.SharedBufferSerializer.getKeySerializer() |
protected TypeSerializer<?>[] |
NFA.MigratedNFASerializerSnapshot.getNestedSerializers(NFA.NFASerializer<T> outerSerializer) |
protected TypeSerializer<?>[] |
NFAStateSerializerSnapshot.getNestedSerializers(NFAStateSerializer outerSerializer) |
protected TypeSerializer<?>[] |
SharedBuffer.SharedBufferSerializerSnapshot.getNestedSerializers(SharedBuffer.SharedBufferSerializer<K,V> outerSerializer) |
TypeSerializer<V> |
SharedBuffer.SharedBufferSerializer.getValueSerializer() |
TypeSerializer<DeweyNumber> |
SharedBuffer.SharedBufferSerializer.getVersionSerializer() |
Modifier and Type | Method and Description |
---|---|
protected NFAStateSerializer |
NFAStateSerializerSnapshot.createOuterSerializerWithNestedSerializers(TypeSerializer<?>[] nestedSerializers) |
protected SharedBuffer.SharedBufferSerializer<K,V> |
SharedBuffer.SharedBufferSerializerSnapshot.createOuterSerializerWithNestedSerializers(TypeSerializer<?>[] nestedSerializers) |
protected NFA.NFASerializer<T> |
NFA.MigratedNFASerializerSnapshot.createOuterSerializerWithNestedSerializers(TypeSerializer<?>[] nestedSerializers) |
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 | Class and Description |
---|---|
static class |
EventId.EventIdSerializer
TypeSerializer for EventId . |
static class |
Lockable.LockableTypeSerializer<E>
Serializer for
Lockable . |
static class |
NodeId.NodeIdSerializer
Serializer for
NodeId . |
static class |
SharedBufferEdge.SharedBufferEdgeSerializer
Serializer for
SharedBufferEdge . |
static class |
SharedBufferNode.SharedBufferNodeSerializer
Deprecated.
was used in <= 1.12, use
SharedBufferNodeSerializer instead. |
class |
SharedBufferNodeSerializer
Serializer for
SharedBufferNode . |
Modifier and Type | Method and Description |
---|---|
TypeSerializer<SharedBufferEdge> |
SharedBufferNodeSerializer.getEdgeSerializer() |
protected TypeSerializer<?>[] |
LockableTypeSerializerSnapshot.getNestedSerializers(Lockable.LockableTypeSerializer<E> outerSerializer) |
protected TypeSerializer<?>[] |
NodeId.NodeIdSerializer.NodeIdSerializerSnapshot.getNestedSerializers(NodeId.NodeIdSerializer outerSerializer) |
protected TypeSerializer<?>[] |
SharedBufferEdge.SharedBufferEdgeSerializer.SharedBufferEdgeSerializerSnapshot.getNestedSerializers(SharedBufferEdge.SharedBufferEdgeSerializer outerSerializer) |
protected TypeSerializer<?>[] |
SharedBufferNode.SharedBufferNodeSerializer.SharedBufferNodeSerializerSnapshot.getNestedSerializers(SharedBufferNode.SharedBufferNodeSerializer outerSerializer) |
protected TypeSerializer<?>[] |
SharedBufferNodeSerializerSnapshotV2.getNestedSerializers(SharedBufferNodeSerializer outerSerializer) |
Modifier and Type | Method and Description |
---|---|
protected Lockable.LockableTypeSerializer<E> |
LockableTypeSerializerSnapshot.createOuterSerializerWithNestedSerializers(TypeSerializer<?>[] nestedSerializers) |
protected SharedBufferNode.SharedBufferNodeSerializer |
SharedBufferNode.SharedBufferNodeSerializer.SharedBufferNodeSerializerSnapshot.createOuterSerializerWithNestedSerializers(TypeSerializer<?>[] nestedSerializers) |
protected SharedBufferNodeSerializer |
SharedBufferNodeSerializerSnapshotV2.createOuterSerializerWithNestedSerializers(TypeSerializer<?>[] nestedSerializers) |
protected SharedBufferEdge.SharedBufferEdgeSerializer |
SharedBufferEdge.SharedBufferEdgeSerializer.SharedBufferEdgeSerializerSnapshot.createOuterSerializerWithNestedSerializers(TypeSerializer<?>[] nestedSerializers) |
protected NodeId.NodeIdSerializer |
NodeId.NodeIdSerializer.NodeIdSerializerSnapshot.createOuterSerializerWithNestedSerializers(TypeSerializer<?>[] nestedSerializers) |
Constructor and Description |
---|
LockableTypeSerializer(TypeSerializer<E> elementSerializer) |
SharedBuffer(KeyedStateStore stateStore,
TypeSerializer<V> valueSerializer) |
Constructor and Description |
---|
CepOperator(TypeSerializer<IN> inputSerializer,
boolean isProcessingTime,
NFACompiler.NFAFactory<IN> nfaFactory,
EventComparator<IN> comparator,
AfterMatchSkipStrategy afterMatchSkipStrategy,
PatternProcessFunction<IN,OUT> function,
OutputTag<IN> lateDataOutputTag) |
Modifier and Type | Class and Description |
---|---|
class |
CheckpointAndXidSerializer
CheckpointAndXid serializer. |
class |
XaSinkStateSerializer
XaSinkStateSerializer.
|
class |
XidSerializer
Xid serializer. |
Modifier and Type | Method and Description |
---|---|
TypeSerializer<CheckpointAndXid> |
CheckpointAndXidSerializer.duplicate() |
TypeSerializer<Xid> |
XidSerializer.duplicate() |
TypeSerializer<org.apache.flink.connector.jdbc.xa.JdbcXaSinkFunctionState> |
XaSinkStateSerializer.duplicate() |
Modifier and Type | Method and Description |
---|---|
TypeSerializer<T> |
HiveTableSource.HiveContinuousPartitionFetcherContext.getTypeSerializer() |
Modifier and Type | Method and Description |
---|---|
<T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>> |
RocksDBKeyedStateBackend.create(String stateName,
TypeSerializer<T> byteOrderedElementSerializer) |
<T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>> |
RocksDBPriorityQueueSetFactory.create(String stateName,
TypeSerializer<T> byteOrderedElementSerializer) |
<N,SV,SEV,S extends State,IS extends S> |
RocksDBKeyedStateBackend.createInternalState(TypeSerializer<N> namespaceSerializer,
StateDescriptor<S,SV> stateDesc,
StateSnapshotTransformer.StateSnapshotTransformFactory<SEV> snapshotTransformFactory) |
<K> AbstractKeyedStateBackend<K> |
RocksDBStateBackend.createKeyedStateBackend(Environment env,
JobID jobID,
String operatorIdentifier,
TypeSerializer<K> keySerializer,
int numberOfKeyGroups,
KeyGroupRange keyGroupRange,
TaskKvStateRegistry kvStateRegistry,
TtlTimeProvider ttlTimeProvider,
MetricGroup metricGroup,
Collection<KeyedStateHandle> stateHandles,
CloseableRegistry cancelStreamRegistry)
Deprecated.
|
<K> AbstractKeyedStateBackend<K> |
EmbeddedRocksDBStateBackend.createKeyedStateBackend(Environment env,
JobID jobID,
String operatorIdentifier,
TypeSerializer<K> keySerializer,
int numberOfKeyGroups,
KeyGroupRange keyGroupRange,
TaskKvStateRegistry kvStateRegistry,
TtlTimeProvider ttlTimeProvider,
MetricGroup metricGroup,
Collection<KeyedStateHandle> stateHandles,
CloseableRegistry cancelStreamRegistry) |
<K> AbstractKeyedStateBackend<K> |
RocksDBStateBackend.createKeyedStateBackend(Environment env,
JobID jobID,
String operatorIdentifier,
TypeSerializer<K> keySerializer,
int numberOfKeyGroups,
KeyGroupRange keyGroupRange,
TaskKvStateRegistry kvStateRegistry,
TtlTimeProvider ttlTimeProvider,
MetricGroup metricGroup,
Collection<KeyedStateHandle> stateHandles,
CloseableRegistry cancelStreamRegistry,
double managedMemoryFraction)
Deprecated.
|
<K> AbstractKeyedStateBackend<K> |
EmbeddedRocksDBStateBackend.createKeyedStateBackend(Environment env,
JobID jobID,
String operatorIdentifier,
TypeSerializer<K> keySerializer,
int numberOfKeyGroups,
KeyGroupRange keyGroupRange,
TaskKvStateRegistry kvStateRegistry,
TtlTimeProvider ttlTimeProvider,
MetricGroup metricGroup,
Collection<KeyedStateHandle> stateHandles,
CloseableRegistry cancelStreamRegistry,
double managedMemoryFraction) |
byte[] |
AbstractRocksDBState.getSerializedValue(byte[] serializedKeyAndNamespace,
TypeSerializer<K> safeKeySerializer,
TypeSerializer<N> safeNamespaceSerializer,
TypeSerializer<V> safeValueSerializer) |
byte[] |
AbstractRocksDBState.getSerializedValue(byte[] serializedKeyAndNamespace,
TypeSerializer<K> safeKeySerializer,
TypeSerializer<N> safeNamespaceSerializer,
TypeSerializer<V> safeValueSerializer) |
byte[] |
AbstractRocksDBState.getSerializedValue(byte[] serializedKeyAndNamespace,
TypeSerializer<K> safeKeySerializer,
TypeSerializer<N> safeNamespaceSerializer,
TypeSerializer<V> safeValueSerializer) |
void |
AbstractRocksDBState.migrateSerializedValue(DataInputDeserializer serializedOldValueInput,
DataOutputSerializer serializedMigratedValueOutput,
TypeSerializer<V> priorSerializer,
TypeSerializer<V> newSerializer) |
void |
AbstractRocksDBState.migrateSerializedValue(DataInputDeserializer serializedOldValueInput,
DataOutputSerializer serializedMigratedValueOutput,
TypeSerializer<V> priorSerializer,
TypeSerializer<V> newSerializer) |
Constructor and Description |
---|
AbstractRocksDBState(org.rocksdb.ColumnFamilyHandle columnFamily,
TypeSerializer<N> namespaceSerializer,
TypeSerializer<V> valueSerializer,
V defaultValue,
RocksDBKeyedStateBackend<K> backend)
Creates a new RocksDB backed state.
|
AbstractRocksDBState(org.rocksdb.ColumnFamilyHandle columnFamily,
TypeSerializer<N> namespaceSerializer,
TypeSerializer<V> valueSerializer,
V defaultValue,
RocksDBKeyedStateBackend<K> backend)
Creates a new RocksDB backed state.
|
RocksDBKeyedStateBackend(ClassLoader userCodeClassLoader,
File instanceBasePath,
RocksDBResourceContainer optionsContainer,
java.util.function.Function<String,org.rocksdb.ColumnFamilyOptions> columnFamilyOptionsFactory,
TaskKvStateRegistry kvStateRegistry,
TypeSerializer<K> keySerializer,
ExecutionConfig executionConfig,
TtlTimeProvider ttlTimeProvider,
LatencyTrackingStateConfig latencyTrackingStateConfig,
org.rocksdb.RocksDB db,
LinkedHashMap<String,RocksDBKeyedStateBackend.RocksDbKvStateInfo> kvStateInformation,
Map<String,HeapPriorityQueueSnapshotRestoreWrapper<?>> registeredPQStates,
int keyGroupPrefixBytes,
CloseableRegistry cancelStreamRegistry,
StreamCompressionDecorator keyGroupCompressionDecorator,
ResourceGuard rocksDBResourceGuard,
RocksDBSnapshotStrategyBase<K,?> checkpointSnapshotStrategy,
RocksDBWriteBatchWrapper writeBatchWrapper,
org.rocksdb.ColumnFamilyHandle defaultColumnFamilyHandle,
RocksDBNativeMetricMonitor nativeMetricMonitor,
SerializedCompositeKeyBuilder<K> sharedRocksKeyBuilder,
PriorityQueueSetFactory priorityQueueFactory,
RocksDbTtlCompactFiltersManager ttlCompactFiltersManager,
InternalKeyContext<K> keyContext,
long writeBatchSize) |
RocksDBKeyedStateBackendBuilder(String operatorIdentifier,
ClassLoader userCodeClassLoader,
File instanceBasePath,
RocksDBResourceContainer optionsContainer,
java.util.function.Function<String,org.rocksdb.ColumnFamilyOptions> columnFamilyOptionsFactory,
TaskKvStateRegistry kvStateRegistry,
TypeSerializer<K> keySerializer,
int numberOfKeyGroups,
KeyGroupRange keyGroupRange,
ExecutionConfig executionConfig,
LocalRecoveryConfig localRecoveryConfig,
EmbeddedRocksDBStateBackend.PriorityQueueStateType priorityQueueStateType,
TtlTimeProvider ttlTimeProvider,
LatencyTrackingStateConfig latencyTrackingStateConfig,
MetricGroup metricGroup,
Collection<KeyedStateHandle> stateHandles,
StreamCompressionDecorator keyGroupCompressionDecorator,
CloseableRegistry cancelStreamRegistry) |
Modifier and Type | Field and Description |
---|---|
protected TypeSerializer<K> |
AbstractRocksStateKeysIterator.keySerializer |
Constructor and Description |
---|
AbstractRocksStateKeysIterator(RocksIteratorWrapper iterator,
String state,
TypeSerializer<K> keySerializer,
int keyGroupPrefixBytes,
boolean ambiguousKeyPossible) |
RocksStateKeysAndNamespaceIterator(RocksIteratorWrapper iterator,
String state,
TypeSerializer<K> keySerializer,
TypeSerializer<N> namespaceSerializer,
int keyGroupPrefixBytes,
boolean ambiguousKeyPossible) |
RocksStateKeysAndNamespaceIterator(RocksIteratorWrapper iterator,
String state,
TypeSerializer<K> keySerializer,
TypeSerializer<N> namespaceSerializer,
int keyGroupPrefixBytes,
boolean ambiguousKeyPossible) |
RocksStateKeysIterator(RocksIteratorWrapper iterator,
String state,
TypeSerializer<K> keySerializer,
int keyGroupPrefixBytes,
boolean ambiguousKeyPossible,
byte[] namespaceBytes) |
Modifier and Type | Field and Description |
---|---|
protected TypeSerializer<K> |
RocksDBSnapshotStrategyBase.keySerializer
The key serializer of the backend.
|
Modifier and Type | Method and Description |
---|---|
TypeSerializer<K> |
RocksDBFullSnapshotResources.getKeySerializer() |
Modifier and Type | Method and Description |
---|---|
static <K> RocksDBFullSnapshotResources<K> |
RocksDBFullSnapshotResources.create(LinkedHashMap<String,RocksDBKeyedStateBackend.RocksDbKvStateInfo> kvStateInformation,
Map<String,HeapPriorityQueueSnapshotRestoreWrapper<?>> registeredPQStates,
org.rocksdb.RocksDB db,
ResourceGuard rocksDBResourceGuard,
KeyGroupRange keyGroupRange,
TypeSerializer<K> keySerializer,
int keyGroupPrefixBytes,
StreamCompressionDecorator keyGroupCompressionDecorator) |
Constructor and Description |
---|
RocksDBFullSnapshotResources(ResourceGuard.Lease lease,
org.rocksdb.Snapshot snapshot,
List<RocksDBKeyedStateBackend.RocksDbKvStateInfo> metaDataCopy,
List<HeapPriorityQueueStateSnapshot<?>> heapPriorityQueuesSnapshots,
List<StateMetaInfoSnapshot> stateMetaInfoSnapshots,
org.rocksdb.RocksDB db,
int keyGroupPrefixBytes,
KeyGroupRange keyGroupRange,
TypeSerializer<K> keySerializer,
StreamCompressionDecorator streamCompressionDecorator) |
RocksDBSnapshotStrategyBase(String description,
org.rocksdb.RocksDB db,
ResourceGuard rocksDBResourceGuard,
TypeSerializer<K> keySerializer,
LinkedHashMap<String,RocksDBKeyedStateBackend.RocksDbKvStateInfo> kvStateInformation,
KeyGroupRange keyGroupRange,
int keyGroupPrefixBytes,
LocalRecoveryConfig localRecoveryConfig) |
RocksFullSnapshotStrategy(org.rocksdb.RocksDB db,
ResourceGuard rocksDBResourceGuard,
TypeSerializer<K> keySerializer,
LinkedHashMap<String,RocksDBKeyedStateBackend.RocksDbKvStateInfo> kvStateInformation,
LinkedHashMap<String,HeapPriorityQueueSnapshotRestoreWrapper<?>> registeredPQStates,
KeyGroupRange keyGroupRange,
int keyGroupPrefixBytes,
LocalRecoveryConfig localRecoveryConfig,
StreamCompressionDecorator keyGroupCompressionDecorator) |
RocksIncrementalSnapshotStrategy(org.rocksdb.RocksDB db,
ResourceGuard rocksDBResourceGuard,
TypeSerializer<K> keySerializer,
LinkedHashMap<String,RocksDBKeyedStateBackend.RocksDbKvStateInfo> kvStateInformation,
KeyGroupRange keyGroupRange,
int keyGroupPrefixBytes,
LocalRecoveryConfig localRecoveryConfig,
CloseableRegistry cancelStreamRegistry,
File instanceBasePath,
UUID backendUID,
SortedMap<Long,Set<StateHandleID>> materializedSstFiles,
RocksDBStateUploader rocksDBStateUploader,
long lastCompletedCheckpointId) |
Modifier and Type | Method and Description |
---|---|
void |
RocksDbTtlCompactFiltersManager.configCompactFilter(StateDescriptor<?,?> stateDesc,
TypeSerializer<?> stateSerializer) |
Modifier and Type | Class and Description |
---|---|
class |
SimpleVersionedSerializerTypeSerializerProxy<T>
A
TypeSerializer that delegates to an underlying SimpleVersionedSerializer . |
Modifier and Type | Method and Description |
---|---|
TypeSerializer<T> |
SimpleVersionedSerializerTypeSerializerProxy.duplicate() |
Modifier and Type | Class and Description |
---|---|
class |
AvroSerializer<T>
A serializer that serializes types via Avro.
|
Modifier and Type | Method and Description |
---|---|
TypeSerializer<T> |
AvroTypeInfo.createSerializer(ExecutionConfig config) |
TypeSerializer<org.apache.avro.generic.GenericRecord> |
GenericRecordAvroTypeInfo.createSerializer(ExecutionConfig config) |
TypeSerializer<T> |
AvroSerializer.duplicate() |
TypeSerializer<T> |
AvroSerializerSnapshot.restoreSerializer() |
Modifier and Type | Method and Description |
---|---|
TypeSerializerSchemaCompatibility<T> |
AvroSerializerSnapshot.resolveSchemaCompatibility(TypeSerializer<T> newSerializer) |
Modifier and Type | Method and Description |
---|---|
<T> TypeSerializer<T> |
AvroKryoSerializerUtils.createAvroSerializer(Class<T> type) |
Modifier and Type | Class and Description |
---|---|
static class |
LongValueWithProperHashCode.LongValueWithProperHashCodeSerializer
Serializer for
LongValueWithProperHashCode . |
Modifier and Type | Method and Description |
---|---|
TypeSerializer<LongValueWithProperHashCode> |
LongValueWithProperHashCode.LongValueWithProperHashCodeTypeInfo.createSerializer(ExecutionConfig executionConfig) |
Modifier and Type | Class and Description |
---|---|
class |
ByteValueArraySerializer
Specialized serializer for
ByteValueArray . |
class |
CharValueArraySerializer
Specialized serializer for
CharValueArray . |
class |
DoubleValueArraySerializer
Specialized serializer for
DoubleValueArray . |
class |
FloatValueArraySerializer
Specialized serializer for
FloatValueArray . |
class |
IntValueArraySerializer
Specialized serializer for
IntValueArray . |
class |
LongValueArraySerializer
Specialized serializer for
LongValueArray . |
class |
NullValueArraySerializer
Specialized serializer for
NullValueArray . |
class |
ShortValueArraySerializer
Specialized serializer for
ShortValueArray . |
class |
StringValueArraySerializer
Specialized serializer for
StringValueArray . |
Modifier and Type | Method and Description |
---|---|
TypeSerializer<ValueArray<T>> |
ValueArrayTypeInfo.createSerializer(ExecutionConfig executionConfig) |
Constructor and Description |
---|
HadoopTupleUnwrappingIterator(TypeSerializer<KEY> keySerializer) |
Modifier and Type | Class and Description |
---|---|
class |
VoidNamespaceSerializer
Serializer for
VoidNamespace . |
Modifier and Type | Method and Description |
---|---|
TypeSerializer<VoidNamespace> |
VoidNamespaceTypeInfo.createSerializer(ExecutionConfig config) |
Modifier and Type | Method and Description |
---|---|
static <K,N> Tuple2<K,N> |
KvStateSerializer.deserializeKeyAndNamespace(byte[] serializedKeyAndNamespace,
TypeSerializer<K> keySerializer,
TypeSerializer<N> namespaceSerializer)
Deserializes the key and namespace into a
Tuple2 . |
static <K,N> Tuple2<K,N> |
KvStateSerializer.deserializeKeyAndNamespace(byte[] serializedKeyAndNamespace,
TypeSerializer<K> keySerializer,
TypeSerializer<N> namespaceSerializer)
Deserializes the key and namespace into a
Tuple2 . |
static <T> List<T> |
KvStateSerializer.deserializeList(byte[] serializedValue,
TypeSerializer<T> serializer)
Deserializes all values with the given serializer.
|
static <UK,UV> Map<UK,UV> |
KvStateSerializer.deserializeMap(byte[] serializedValue,
TypeSerializer<UK> keySerializer,
TypeSerializer<UV> valueSerializer)
Deserializes all kv pairs with the given serializer.
|
static <UK,UV> Map<UK,UV> |
KvStateSerializer.deserializeMap(byte[] serializedValue,
TypeSerializer<UK> keySerializer,
TypeSerializer<UV> valueSerializer)
Deserializes all kv pairs with the given serializer.
|
static <T> T |
KvStateSerializer.deserializeValue(byte[] serializedValue,
TypeSerializer<T> serializer)
Deserializes the value with the given serializer.
|
static <K,N> byte[] |
KvStateSerializer.serializeKeyAndNamespace(K key,
TypeSerializer<K> keySerializer,
N namespace,
TypeSerializer<N> namespaceSerializer)
Serializes the key and namespace into a
ByteBuffer . |
static <K,N> byte[] |
KvStateSerializer.serializeKeyAndNamespace(K key,
TypeSerializer<K> keySerializer,
N namespace,
TypeSerializer<N> namespaceSerializer)
Serializes the key and namespace into a
ByteBuffer . |
static <UK,UV> byte[] |
KvStateSerializer.serializeMap(Iterable<Map.Entry<UK,UV>> entries,
TypeSerializer<UK> keySerializer,
TypeSerializer<UV> valueSerializer)
Serializes all values of the Iterable with the given serializer.
|
static <UK,UV> byte[] |
KvStateSerializer.serializeMap(Iterable<Map.Entry<UK,UV>> entries,
TypeSerializer<UK> keySerializer,
TypeSerializer<UV> valueSerializer)
Serializes all values of the Iterable with the given serializer.
|
static <T> byte[] |
KvStateSerializer.serializeValue(T value,
TypeSerializer<T> serializer)
Serializes the value with the given serializer.
|
Constructor and Description |
---|
ChannelReaderInputViewIterator(AbstractChannelReaderInputView inView,
List<MemorySegment> freeMemTarget,
TypeSerializer<E> accessors) |
ChannelReaderInputViewIterator(BlockChannelReader<MemorySegment> reader,
LinkedBlockingQueue<MemorySegment> returnQueue,
List<MemorySegment> segments,
List<MemorySegment> freeMemTarget,
TypeSerializer<E> accessors,
int numBlocks) |
ChannelReaderInputViewIterator(IOManager ioAccess,
FileIOChannel.ID channel,
LinkedBlockingQueue<MemorySegment> returnQueue,
List<MemorySegment> segments,
List<MemorySegment> freeMemTarget,
TypeSerializer<E> accessors,
int numBlocks) |
ChannelReaderInputViewIterator(IOManager ioAccess,
FileIOChannel.ID channel,
List<MemorySegment> segments,
List<MemorySegment> freeMemTarget,
TypeSerializer<E> accessors,
int numBlocks) |
InputViewIterator(DataInputView inputView,
TypeSerializer<E> serializer) |
Constructor and Description |
---|
HashPartitionIterator(Iterator<HashPartition<BT,PT>> partitions,
TypeSerializer<BT> serializer) |
WorksetUpdateOutputCollector(DataOutputView outputView,
TypeSerializer<T> serializer) |
WorksetUpdateOutputCollector(DataOutputView outputView,
TypeSerializer<T> serializer,
Collector<T> delegate) |
Modifier and Type | Field and Description |
---|---|
protected TypeSerializer<BT> |
MutableHashTable.buildSideSerializer
The utilities to serialize the build side data types.
|
protected TypeSerializer<T> |
AbstractMutableHashTable.buildSideSerializer
The utilities to serialize the build side data types.
|
protected TypeSerializer<PT> |
MutableHashTable.probeSideSerializer
The utilities to serialize the probe side data types.
|
protected TypeSerializer<V1> |
ReusingBuildSecondHashJoinIterator.probeSideSerializer |
protected TypeSerializer<V1> |
NonReusingBuildSecondHashJoinIterator.probeSideSerializer |
protected TypeSerializer<V2> |
NonReusingBuildFirstHashJoinIterator.probeSideSerializer |
protected TypeSerializer<V2> |
ReusingBuildFirstHashJoinIterator.probeSideSerializer |
Modifier and Type | Method and Description |
---|---|
TypeSerializer<T> |
AbstractMutableHashTable.getBuildSideSerializer() |
Modifier and Type | Method and Description |
---|---|
<BT,PT> MutableHashTable<BT,PT> |
NonReusingBuildFirstReOpenableHashJoinIterator.getHashJoin(TypeSerializer<BT> buildSideSerializer,
TypeComparator<BT> buildSideComparator,
TypeSerializer<PT> probeSideSerializer,
TypeComparator<PT> probeSideComparator,
TypePairComparator<PT,BT> pairComparator,
MemoryManager memManager,
IOManager ioManager,
AbstractInvokable ownerTask,
double memoryFraction,
boolean useBitmapFilters) |
<BT,PT> MutableHashTable<BT,PT> |
NonReusingBuildFirstReOpenableHashJoinIterator.getHashJoin(TypeSerializer<BT> buildSideSerializer,
TypeComparator<BT> buildSideComparator,
TypeSerializer<PT> probeSideSerializer,
TypeComparator<PT> probeSideComparator,
TypePairComparator<PT,BT> pairComparator,
MemoryManager memManager,
IOManager ioManager,
AbstractInvokable ownerTask,
double memoryFraction,
boolean useBitmapFilters) |
<BT,PT> MutableHashTable<BT,PT> |
NonReusingBuildSecondReOpenableHashJoinIterator.getHashJoin(TypeSerializer<BT> buildSideSerializer,
TypeComparator<BT> buildSideComparator,
TypeSerializer<PT> probeSideSerializer,
TypeComparator<PT> probeSideComparator,
TypePairComparator<PT,BT> pairComparator,
MemoryManager memManager,
IOManager ioManager,
AbstractInvokable ownerTask,
double memoryFraction,
boolean useBitmapFilters) |
<BT,PT> MutableHashTable<BT,PT> |
NonReusingBuildSecondReOpenableHashJoinIterator.getHashJoin(TypeSerializer<BT> buildSideSerializer,
TypeComparator<BT> buildSideComparator,
TypeSerializer<PT> probeSideSerializer,
TypeComparator<PT> probeSideComparator,
TypePairComparator<PT,BT> pairComparator,
MemoryManager memManager,
IOManager ioManager,
AbstractInvokable ownerTask,
double memoryFraction,
boolean useBitmapFilters) |
<BT,PT> MutableHashTable<BT,PT> |
ReusingBuildSecondReOpenableHashJoinIterator.getHashJoin(TypeSerializer<BT> buildSideSerializer,
TypeComparator<BT> buildSideComparator,
TypeSerializer<PT> probeSideSerializer,
TypeComparator<PT> probeSideComparator,
TypePairComparator<PT,BT> pairComparator,
MemoryManager memManager,
IOManager ioManager,
AbstractInvokable ownerTask,
double memoryFraction,
boolean useBitmapFilters) |
<BT,PT> MutableHashTable<BT,PT> |
ReusingBuildSecondReOpenableHashJoinIterator.getHashJoin(TypeSerializer<BT> buildSideSerializer,
TypeComparator<BT> buildSideComparator,
TypeSerializer<PT> probeSideSerializer,
TypeComparator<PT> probeSideComparator,
TypePairComparator<PT,BT> pairComparator,
MemoryManager memManager,
IOManager ioManager,
AbstractInvokable ownerTask,
double memoryFraction,
boolean useBitmapFilters) |
<BT,PT> MutableHashTable<BT,PT> |
ReusingBuildFirstReOpenableHashJoinIterator.getHashJoin(TypeSerializer<BT> buildSideSerializer,
TypeComparator<BT> buildSideComparator,
TypeSerializer<PT> probeSideSerializer,
TypeComparator<PT> probeSideComparator,
TypePairComparator<PT,BT> pairComparator,
MemoryManager memManager,
IOManager ioManager,
AbstractInvokable ownerTask,
double memoryFraction,
boolean useBitmapFilters) |
<BT,PT> MutableHashTable<BT,PT> |
ReusingBuildFirstReOpenableHashJoinIterator.getHashJoin(TypeSerializer<BT> buildSideSerializer,
TypeComparator<BT> buildSideComparator,
TypeSerializer<PT> probeSideSerializer,
TypeComparator<PT> probeSideComparator,
TypePairComparator<PT,BT> pairComparator,
MemoryManager memManager,
IOManager ioManager,
AbstractInvokable ownerTask,
double memoryFraction,
boolean useBitmapFilters) |
<BT,PT> MutableHashTable<BT,PT> |
HashJoinIteratorBase.getHashJoin(TypeSerializer<BT> buildSideSerializer,
TypeComparator<BT> buildSideComparator,
TypeSerializer<PT> probeSideSerializer,
TypeComparator<PT> probeSideComparator,
TypePairComparator<PT,BT> pairComparator,
MemoryManager memManager,
IOManager ioManager,
AbstractInvokable ownerTask,
double memoryFraction,
boolean useBloomFilters) |
<BT,PT> MutableHashTable<BT,PT> |
HashJoinIteratorBase.getHashJoin(TypeSerializer<BT> buildSideSerializer,
TypeComparator<BT> buildSideComparator,
TypeSerializer<PT> probeSideSerializer,
TypeComparator<PT> probeSideComparator,
TypePairComparator<PT,BT> pairComparator,
MemoryManager memManager,
IOManager ioManager,
AbstractInvokable ownerTask,
double memoryFraction,
boolean useBloomFilters) |
Constructor and Description |
---|
AbstractMutableHashTable(TypeSerializer<T> buildSideSerializer,
TypeComparator<T> buildSideComparator) |
CompactingHashTable(TypeSerializer<T> buildSideSerializer,
TypeComparator<T> buildSideComparator,
List<MemorySegment> memorySegments) |
CompactingHashTable(TypeSerializer<T> buildSideSerializer,
TypeComparator<T> buildSideComparator,
List<MemorySegment> memorySegments,
int avgRecordLen) |
InMemoryPartition(TypeSerializer<T> serializer,
int partitionNumber,
ListMemorySegmentSource memSource,
int pageSize,
int pageSizeInBits)
Creates a new partition, in memory, with one buffer.
|
InPlaceMutableHashTable(TypeSerializer<T> serializer,
TypeComparator<T> comparator,
List<MemorySegment> memory) |
MutableHashTable(TypeSerializer<BT> buildSideSerializer,
TypeSerializer<PT> probeSideSerializer,
TypeComparator<BT> buildSideComparator,
TypeComparator<PT> probeSideComparator,
TypePairComparator<PT,BT> comparator,
List<MemorySegment> memorySegments,
IOManager ioManager) |
MutableHashTable(TypeSerializer<BT> buildSideSerializer,
TypeSerializer<PT> probeSideSerializer,
TypeComparator<BT> buildSideComparator,
TypeComparator<PT> probeSideComparator,
TypePairComparator<PT,BT> comparator,
List<MemorySegment> memorySegments,
IOManager ioManager) |
MutableHashTable(TypeSerializer<BT> buildSideSerializer,
TypeSerializer<PT> probeSideSerializer,
TypeComparator<BT> buildSideComparator,
TypeComparator<PT> probeSideComparator,
TypePairComparator<PT,BT> comparator,
List<MemorySegment> memorySegments,
IOManager ioManager,
boolean useBloomFilters) |
MutableHashTable(TypeSerializer<BT> buildSideSerializer,
TypeSerializer<PT> probeSideSerializer,
TypeComparator<BT> buildSideComparator,
TypeComparator<PT> probeSideComparator,
TypePairComparator<PT,BT> comparator,
List<MemorySegment> memorySegments,
IOManager ioManager,
boolean useBloomFilters) |
MutableHashTable(TypeSerializer<BT> buildSideSerializer,
TypeSerializer<PT> probeSideSerializer,
TypeComparator<BT> buildSideComparator,
TypeComparator<PT> probeSideComparator,
TypePairComparator<PT,BT> comparator,
List<MemorySegment> memorySegments,
IOManager ioManager,
int avgRecordLen,
boolean useBloomFilters) |
MutableHashTable(TypeSerializer<BT> buildSideSerializer,
TypeSerializer<PT> probeSideSerializer,
TypeComparator<BT> buildSideComparator,
TypeComparator<PT> probeSideComparator,
TypePairComparator<PT,BT> comparator,
List<MemorySegment> memorySegments,
IOManager ioManager,
int avgRecordLen,
boolean useBloomFilters) |
NonReusingBuildFirstHashJoinIterator(MutableObjectIterator<V1> firstInput,
MutableObjectIterator<V2> secondInput,
TypeSerializer<V1> serializer1,
TypeComparator<V1> comparator1,
TypeSerializer<V2> serializer2,
TypeComparator<V2> comparator2,
TypePairComparator<V2,V1> pairComparator,
MemoryManager memManager,
IOManager ioManager,
AbstractInvokable ownerTask,
double memoryFraction,
boolean probeSideOuterJoin,
boolean buildSideOuterJoin,
boolean useBitmapFilters) |
NonReusingBuildFirstHashJoinIterator(MutableObjectIterator<V1> firstInput,
MutableObjectIterator<V2> secondInput,
TypeSerializer<V1> serializer1,
TypeComparator<V1> comparator1,
TypeSerializer<V2> serializer2,
TypeComparator<V2> comparator2,
TypePairComparator<V2,V1> pairComparator,
MemoryManager memManager,
IOManager ioManager,
AbstractInvokable ownerTask,
double memoryFraction,
boolean probeSideOuterJoin,
boolean buildSideOuterJoin,
boolean useBitmapFilters) |
NonReusingBuildFirstReOpenableHashJoinIterator(MutableObjectIterator<V1> firstInput,
MutableObjectIterator<V2> secondInput,
TypeSerializer<V1> serializer1,
TypeComparator<V1> comparator1,
TypeSerializer<V2> serializer2,
TypeComparator<V2> comparator2,
TypePairComparator<V2,V1> pairComparator,
MemoryManager memManager,
IOManager ioManager,
AbstractInvokable ownerTask,
double memoryFraction,
boolean probeSideOuterJoin,
boolean buildSideOuterJoin,
boolean useBitmapFilters) |
NonReusingBuildFirstReOpenableHashJoinIterator(MutableObjectIterator<V1> firstInput,
MutableObjectIterator<V2> secondInput,
TypeSerializer<V1> serializer1,
TypeComparator<V1> comparator1,
TypeSerializer<V2> serializer2,
TypeComparator<V2> comparator2,
TypePairComparator<V2,V1> pairComparator,
MemoryManager memManager,
IOManager ioManager,
AbstractInvokable ownerTask,
double memoryFraction,
boolean probeSideOuterJoin,
boolean buildSideOuterJoin,
boolean useBitmapFilters) |
NonReusingBuildSecondHashJoinIterator(MutableObjectIterator<V1> firstInput,
MutableObjectIterator<V2> secondInput,
TypeSerializer<V1> serializer1,
TypeComparator<V1> comparator1,
TypeSerializer<V2> serializer2,
TypeComparator<V2> comparator2,
TypePairComparator<V1,V2> pairComparator,
MemoryManager memManager,
IOManager ioManager,
AbstractInvokable ownerTask,
double memoryFraction,
boolean probeSideOuterJoin,
boolean buildSideOuterJoin,
boolean useBitmapFilters) |
NonReusingBuildSecondHashJoinIterator(MutableObjectIterator<V1> firstInput,
MutableObjectIterator<V2> secondInput,
TypeSerializer<V1> serializer1,
TypeComparator<V1> comparator1,
TypeSerializer<V2> serializer2,
TypeComparator<V2> comparator2,
TypePairComparator<V1,V2> pairComparator,
MemoryManager memManager,
IOManager ioManager,
AbstractInvokable ownerTask,
double memoryFraction,
boolean probeSideOuterJoin,
boolean buildSideOuterJoin,
boolean useBitmapFilters) |
NonReusingBuildSecondReOpenableHashJoinIterator(MutableObjectIterator<V1> firstInput,
MutableObjectIterator<V2> secondInput,
TypeSerializer<V1> serializer1,
TypeComparator<V1> comparator1,
TypeSerializer<V2> serializer2,
TypeComparator<V2> comparator2,
TypePairComparator<V1,V2> pairComparator,
MemoryManager memManager,
IOManager ioManager,
AbstractInvokable ownerTask,
double memoryFraction,
boolean probeSideOuterJoin,
boolean buildSideOuterJoin,
boolean useBitmapFilters) |
NonReusingBuildSecondReOpenableHashJoinIterator(MutableObjectIterator<V1> firstInput,
MutableObjectIterator<V2> secondInput,
TypeSerializer<V1> serializer1,
TypeComparator<V1> comparator1,
TypeSerializer<V2> serializer2,
TypeComparator<V2> comparator2,
TypePairComparator<V1,V2> pairComparator,
MemoryManager memManager,
IOManager ioManager,
AbstractInvokable ownerTask,
double memoryFraction,
boolean probeSideOuterJoin,
boolean buildSideOuterJoin,
boolean useBitmapFilters) |
ReOpenableMutableHashTable(TypeSerializer<BT> buildSideSerializer,
TypeSerializer<PT> probeSideSerializer,
TypeComparator<BT> buildSideComparator,
TypeComparator<PT> probeSideComparator,
TypePairComparator<PT,BT> comparator,
List<MemorySegment> memorySegments,
IOManager ioManager,
boolean useBitmapFilters) |
ReOpenableMutableHashTable(TypeSerializer<BT> buildSideSerializer,
TypeSerializer<PT> probeSideSerializer,
TypeComparator<BT> buildSideComparator,
TypeComparator<PT> probeSideComparator,
TypePairComparator<PT,BT> comparator,
List<MemorySegment> memorySegments,
IOManager ioManager,
boolean useBitmapFilters) |
ReusingBuildFirstHashJoinIterator(MutableObjectIterator<V1> firstInput,
MutableObjectIterator<V2> secondInput,
TypeSerializer<V1> serializer1,
TypeComparator<V1> comparator1,
TypeSerializer<V2> serializer2,
TypeComparator<V2> comparator2,
TypePairComparator<V2,V1> pairComparator,
MemoryManager memManager,
IOManager ioManager,
AbstractInvokable ownerTask,
double memoryFraction,
boolean probeSideOuterJoin,
boolean buildSideOuterJoin,
boolean useBitmapFilters) |
ReusingBuildFirstHashJoinIterator(MutableObjectIterator<V1> firstInput,
MutableObjectIterator<V2> secondInput,
TypeSerializer<V1> serializer1,
TypeComparator<V1> comparator1,
TypeSerializer<V2> serializer2,
TypeComparator<V2> comparator2,
TypePairComparator<V2,V1> pairComparator,
MemoryManager memManager,
IOManager ioManager,
AbstractInvokable ownerTask,
double memoryFraction,
boolean probeSideOuterJoin,
boolean buildSideOuterJoin,
boolean useBitmapFilters) |
ReusingBuildFirstReOpenableHashJoinIterator(MutableObjectIterator<V1> firstInput,
MutableObjectIterator<V2> secondInput,
TypeSerializer<V1> serializer1,
TypeComparator<V1> comparator1,
TypeSerializer<V2> serializer2,
TypeComparator<V2> comparator2,
TypePairComparator<V2,V1> pairComparator,
MemoryManager memManager,
IOManager ioManager,
AbstractInvokable ownerTask,
double memoryFraction,
boolean probeSideOuterJoin,
boolean buildSideOuterJoin,
boolean useBitmapFilters) |
ReusingBuildFirstReOpenableHashJoinIterator(MutableObjectIterator<V1> firstInput,
MutableObjectIterator<V2> secondInput,
TypeSerializer<V1> serializer1,
TypeComparator<V1> comparator1,
TypeSerializer<V2> serializer2,
TypeComparator<V2> comparator2,
TypePairComparator<V2,V1> pairComparator,
MemoryManager memManager,
IOManager ioManager,
AbstractInvokable ownerTask,
double memoryFraction,
boolean probeSideOuterJoin,
boolean buildSideOuterJoin,
boolean useBitmapFilters) |
ReusingBuildSecondHashJoinIterator(MutableObjectIterator<V1> firstInput,
MutableObjectIterator<V2> secondInput,
TypeSerializer<V1> serializer1,
TypeComparator<V1> comparator1,
TypeSerializer<V2> serializer2,
TypeComparator<V2> comparator2,
TypePairComparator<V1,V2> pairComparator,
MemoryManager memManager,
IOManager ioManager,
AbstractInvokable ownerTask,
double memoryFraction,
boolean probeSideOuterJoin,
boolean buildSideOuterJoin,
boolean useBitmapFilters) |
ReusingBuildSecondHashJoinIterator(MutableObjectIterator<V1> firstInput,
MutableObjectIterator<V2> secondInput,
TypeSerializer<V1> serializer1,
TypeComparator<V1> comparator1,
TypeSerializer<V2> serializer2,
TypeComparator<V2> comparator2,
TypePairComparator<V1,V2> pairComparator,
MemoryManager memManager,
IOManager ioManager,
AbstractInvokable ownerTask,
double memoryFraction,
boolean probeSideOuterJoin,
boolean buildSideOuterJoin,
boolean useBitmapFilters) |
ReusingBuildSecondReOpenableHashJoinIterator(MutableObjectIterator<V1> firstInput,
MutableObjectIterator<V2> secondInput,
TypeSerializer<V1> serializer1,
TypeComparator<V1> comparator1,
TypeSerializer<V2> serializer2,
TypeComparator<V2> comparator2,
TypePairComparator<V1,V2> pairComparator,
MemoryManager memManager,
IOManager ioManager,
AbstractInvokable ownerTask,
double memoryFraction,
boolean probeSideOuterJoin,
boolean buildSideOuterJoin,
boolean useBitmapFilters) |
ReusingBuildSecondReOpenableHashJoinIterator(MutableObjectIterator<V1> firstInput,
MutableObjectIterator<V2> secondInput,
TypeSerializer<V1> serializer1,
TypeComparator<V1> comparator1,
TypeSerializer<V2> serializer2,
TypeComparator<V2> comparator2,
TypePairComparator<V1,V2> pairComparator,
MemoryManager memManager,
IOManager ioManager,
AbstractInvokable ownerTask,
double memoryFraction,
boolean probeSideOuterJoin,
boolean buildSideOuterJoin,
boolean useBitmapFilters) |
Modifier and Type | Field and Description |
---|---|
protected TypeSerializer<T> |
SpillingResettableIterator.serializer |
protected TypeSerializer<T> |
SpillingResettableMutableObjectIterator.serializer |
Constructor and Description |
---|
OutputCollector(List<RecordWriter<SerializationDelegate<T>>> writers,
TypeSerializer<T> serializer)
Initializes the output collector with a set of writers.
|
Modifier and Type | Field and Description |
---|---|
protected TypeSerializer<T1> |
AbstractMergeIterator.serializer1 |
protected TypeSerializer<T2> |
AbstractMergeIterator.serializer2 |
Modifier and Type | Method and Description |
---|---|
protected abstract <T> T |
AbstractMergeIterator.createCopy(TypeSerializer<T> serializer,
T value,
T reuse)
Copies an instance of the given type, potentially reusing the object passed as the reuse
parameter, which may be null.
|
protected <T> T |
ReusingMergeInnerJoinIterator.createCopy(TypeSerializer<T> serializer,
T value,
T reuse) |
protected <T> T |
NonReusingMergeOuterJoinIterator.createCopy(TypeSerializer<T> serializer,
T value,
T reuse) |
protected <T> T |
ReusingMergeOuterJoinIterator.createCopy(TypeSerializer<T> serializer,
T value,
T reuse) |
protected <T> T |
NonReusingMergeInnerJoinIterator.createCopy(TypeSerializer<T> serializer,
T value,
T reuse) |
protected abstract <T> KeyGroupedIterator<T> |
AbstractMergeIterator.createKeyGroupedIterator(MutableObjectIterator<T> input,
TypeSerializer<T> serializer,
TypeComparator<T> comparator) |
protected <T> KeyGroupedIterator<T> |
ReusingMergeInnerJoinIterator.createKeyGroupedIterator(MutableObjectIterator<T> input,
TypeSerializer<T> serializer,
TypeComparator<T> comparator) |
protected <T> KeyGroupedIterator<T> |
NonReusingMergeOuterJoinIterator.createKeyGroupedIterator(MutableObjectIterator<T> input,
TypeSerializer<T> serializer,
TypeComparator<T> comparator) |
protected <T> KeyGroupedIterator<T> |
ReusingMergeOuterJoinIterator.createKeyGroupedIterator(MutableObjectIterator<T> input,
TypeSerializer<T> serializer,
TypeComparator<T> comparator) |
protected <T> KeyGroupedIterator<T> |
NonReusingMergeInnerJoinIterator.createKeyGroupedIterator(MutableObjectIterator<T> input,
TypeSerializer<T> serializer,
TypeComparator<T> comparator) |
static <E> ExternalSorterBuilder<E> |
ExternalSorter.newBuilder(MemoryManager memoryManager,
AbstractInvokable parentTask,
TypeSerializer<E> serializer,
TypeComparator<E> comparator)
Creates a builder for the
ExternalSorter . |
Constructor and Description |
---|
ReaderIterator(MutableReader<DeserializationDelegate<T>> reader,
TypeSerializer<T> serializer)
Creates a new iterator, wrapping the given reader.
|
Constructor and Description |
---|
NonReusingDeserializationDelegate(TypeSerializer<T> serializer) |
ReusingDeserializationDelegate(TypeSerializer<T> serializer) |
SerializationDelegate(TypeSerializer<T> serializer) |
Modifier and Type | Method and Description |
---|---|
TypeSerializer<K> |
KvStateInfo.getKeySerializer() |
TypeSerializer<N> |
KvStateInfo.getNamespaceSerializer() |
TypeSerializer<V> |
KvStateInfo.getStateValueSerializer() |
Constructor and Description |
---|
KvStateInfo(TypeSerializer<K> keySerializer,
TypeSerializer<N> namespaceSerializer,
TypeSerializer<V> stateValueSerializer) |
KvStateInfo(TypeSerializer<K> keySerializer,
TypeSerializer<N> namespaceSerializer,
TypeSerializer<V> stateValueSerializer) |
KvStateInfo(TypeSerializer<K> keySerializer,
TypeSerializer<N> namespaceSerializer,
TypeSerializer<V> stateValueSerializer) |
Modifier and Type | Class and Description |
---|---|
class |
ArrayListSerializer<T> |
class |
JavaSerializer<T extends Serializable>
A
TypeSerializer that uses Java serialization. |
Modifier and Type | Field and Description |
---|---|
protected TypeSerializer<K> |
AbstractKeyedStateBackend.keySerializer
The key serializer.
|
Modifier and Type | Method and Description |
---|---|
TypeSerializer<VoidNamespace> |
VoidNamespaceTypeInfo.createSerializer(ExecutionConfig config) |
TypeSerializer<T> |
StateSerializerProvider.currentSchemaSerializer()
Gets the serializer that recognizes the current serialization schema of the state.
|
TypeSerializer<ArrayList<T>> |
ArrayListSerializer.duplicate() |
TypeSerializer<T> |
ArrayListSerializer.getElementSerializer() |
TypeSerializer<T> |
RegisteredPriorityQueueStateBackendMetaInfo.getElementSerializer() |
TypeSerializer<K> |
RegisteredBroadcastStateBackendMetaInfo.getKeySerializer() |
TypeSerializer<K> |
KeyedStateBackend.getKeySerializer() |
TypeSerializer<K> |
AbstractKeyedStateBackend.getKeySerializer() |
TypeSerializer<K> |
FullSnapshotResources.getKeySerializer()
Returns key
TypeSerializer . |
TypeSerializer<N> |
RegisteredKeyValueStateBackendMetaInfo.getNamespaceSerializer() |
protected TypeSerializer<?>[] |
ArrayListSerializerSnapshot.getNestedSerializers(ArrayListSerializer<T> outerSerializer) |
TypeSerializer<S> |
RegisteredOperatorStateBackendMetaInfo.getPartitionStateSerializer() |
TypeSerializer<T> |
RegisteredPriorityQueueStateBackendMetaInfo.getPreviousElementSerializer() |
TypeSerializer<K> |
RegisteredBroadcastStateBackendMetaInfo.getPreviousKeySerializer() |
TypeSerializer<N> |
RegisteredKeyValueStateBackendMetaInfo.getPreviousNamespaceSerializer() |
TypeSerializer<S> |
RegisteredOperatorStateBackendMetaInfo.getPreviousPartitionStateSerializer() |
TypeSerializer<S> |
RegisteredKeyValueStateBackendMetaInfo.getPreviousStateSerializer() |
TypeSerializer<V> |
RegisteredBroadcastStateBackendMetaInfo.getPreviousValueSerializer() |
TypeSerializer<S> |
RegisteredKeyValueStateBackendMetaInfo.getStateSerializer() |
TypeSerializer<V> |
RegisteredBroadcastStateBackendMetaInfo.getValueSerializer() |
TypeSerializer<T> |
StateSerializerProvider.previousSchemaSerializer()
Gets the serializer that recognizes the previous serialization schema of the state.
|
Modifier and Type | Method and Description |
---|---|
<N,S extends State,T> |
KeyedStateBackend.applyToAllKeys(N namespace,
TypeSerializer<N> namespaceSerializer,
StateDescriptor<S,T> stateDescriptor,
KeyedStateFunction<K,S> function)
Applies the provided
KeyedStateFunction to the state with the provided StateDescriptor of all the currently active keys. |
<N,S extends State,T> |
AbstractKeyedStateBackend.applyToAllKeys(N namespace,
TypeSerializer<N> namespaceSerializer,
StateDescriptor<S,T> stateDescriptor,
KeyedStateFunction<K,S> function) |
<N,S extends State,T> |
AbstractKeyedStateBackend.applyToAllKeys(N namespace,
TypeSerializer<N> namespaceSerializer,
StateDescriptor<S,T> stateDescriptor,
KeyedStateFunction<K,S> function,
AbstractKeyedStateBackend.PartitionStateFactory partitionStateFactory) |
<N> byte[] |
SerializedCompositeKeyBuilder.buildCompositeKeyNamespace(N namespace,
TypeSerializer<N> namespaceSerializer)
Returns a serialized composite key, from the key and key-group provided in a previous call to
SerializedCompositeKeyBuilder.setKeyAndKeyGroup(Object, int) and the given namespace. |
<N,UK> byte[] |
SerializedCompositeKeyBuilder.buildCompositeKeyNamesSpaceUserKey(N namespace,
TypeSerializer<N> namespaceSerializer,
UK userKey,
TypeSerializer<UK> userKeySerializer)
Returns a serialized composite key, from the key and key-group provided in a previous call to
SerializedCompositeKeyBuilder.setKeyAndKeyGroup(Object, int) and the given namespace, followed by the given
user-key. |
<N,UK> byte[] |
SerializedCompositeKeyBuilder.buildCompositeKeyNamesSpaceUserKey(N namespace,
TypeSerializer<N> namespaceSerializer,
UK userKey,
TypeSerializer<UK> userKeySerializer)
Returns a serialized composite key, from the key and key-group provided in a previous call to
SerializedCompositeKeyBuilder.setKeyAndKeyGroup(Object, int) and the given namespace, followed by the given
user-key. |
<UK> byte[] |
SerializedCompositeKeyBuilder.buildCompositeKeyUserKey(UK userKey,
TypeSerializer<UK> userKeySerializer)
Returns a serialized composite key, from the key and key-group provided in a previous call to
SerializedCompositeKeyBuilder.setKeyAndKeyGroup(Object, int) and the namespace provided in SerializedCompositeKeyBuilder.setNamespace(Object, TypeSerializer) , followed by the given user-key. |
<T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>> |
PriorityQueueSetFactory.create(String stateName,
TypeSerializer<T> byteOrderedElementSerializer)
Creates a
KeyGroupedInternalPriorityQueue . |
default <N,SV,S extends State,IS extends S> |
KeyedStateFactory.createInternalState(TypeSerializer<N> namespaceSerializer,
StateDescriptor<S,SV> stateDesc)
Creates and returns a new
InternalKvState . |
<N,SV,SEV,S extends State,IS extends S> |
KeyedStateFactory.createInternalState(TypeSerializer<N> namespaceSerializer,
StateDescriptor<S,SV> stateDesc,
StateSnapshotTransformer.StateSnapshotTransformFactory<SEV> snapshotTransformFactory)
Creates and returns a new
InternalKvState . |
<K> CheckpointableKeyedStateBackend<K> |
StateBackend.createKeyedStateBackend(Environment env,
JobID jobID,
String operatorIdentifier,
TypeSerializer<K> keySerializer,
int numberOfKeyGroups,
KeyGroupRange keyGroupRange,
TaskKvStateRegistry kvStateRegistry,
TtlTimeProvider ttlTimeProvider,
MetricGroup metricGroup,
Collection<KeyedStateHandle> stateHandles,
CloseableRegistry cancelStreamRegistry)
Creates a new
CheckpointableKeyedStateBackend that is responsible for holding
keyed state and checkpointing it. |
abstract <K> AbstractKeyedStateBackend<K> |
AbstractStateBackend.createKeyedStateBackend(Environment env,
JobID jobID,
String operatorIdentifier,
TypeSerializer<K> keySerializer,
int numberOfKeyGroups,
KeyGroupRange keyGroupRange,
TaskKvStateRegistry kvStateRegistry,
TtlTimeProvider ttlTimeProvider,
MetricGroup metricGroup,
Collection<KeyedStateHandle> stateHandles,
CloseableRegistry cancelStreamRegistry) |
default <K> CheckpointableKeyedStateBackend<K> |
StateBackend.createKeyedStateBackend(Environment env,
JobID jobID,
String operatorIdentifier,
TypeSerializer<K> keySerializer,
int numberOfKeyGroups,
KeyGroupRange keyGroupRange,
TaskKvStateRegistry kvStateRegistry,
TtlTimeProvider ttlTimeProvider,
MetricGroup metricGroup,
Collection<KeyedStateHandle> stateHandles,
CloseableRegistry cancelStreamRegistry,
double managedMemoryFraction)
Creates a new
CheckpointableKeyedStateBackend with the given managed memory fraction. |
abstract <K> AbstractKeyedStateBackend<K> |
AbstractManagedMemoryStateBackend.createKeyedStateBackend(Environment env,
JobID jobID,
String operatorIdentifier,
TypeSerializer<K> keySerializer,
int numberOfKeyGroups,
KeyGroupRange keyGroupRange,
TaskKvStateRegistry kvStateRegistry,
TtlTimeProvider ttlTimeProvider,
MetricGroup metricGroup,
Collection<KeyedStateHandle> stateHandles,
CloseableRegistry cancelStreamRegistry,
double managedMemoryFraction) |
<T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>> |
HeapPriorityQueuesManager.createOrUpdate(String stateName,
TypeSerializer<T> byteOrderedElementSerializer) |
protected ArrayListSerializer<T> |
ArrayListSerializerSnapshot.createOuterSerializerWithNestedSerializers(TypeSerializer<?>[] nestedSerializers) |
<T> List<T> |
ListDelimitedSerializer.deserializeList(byte[] valueBytes,
TypeSerializer<T> elementSerializer) |
static <T> T |
ListDelimitedSerializer.deserializeNextElement(DataInputDeserializer in,
TypeSerializer<T> elementSerializer)
Deserializes a single element from a serialized list.
|
static <T> StateSerializerProvider<T> |
StateSerializerProvider.fromNewRegisteredSerializer(TypeSerializer<T> registeredStateSerializer)
Creates a
StateSerializerProvider from the registered state serializer. |
<N,S extends State> |
AbstractKeyedStateBackend.PartitionStateFactory.get(N namespace,
TypeSerializer<N> namespaceSerializer,
StateDescriptor<S,?> stateDescriptor) |
<N,S extends State,T> |
KeyedStateBackend.getOrCreateKeyedState(TypeSerializer<N> namespaceSerializer,
StateDescriptor<S,T> stateDescriptor)
Creates or retrieves a keyed state backed by this state backend.
|
<N,S extends State,V> |
AbstractKeyedStateBackend.getOrCreateKeyedState(TypeSerializer<N> namespaceSerializer,
StateDescriptor<S,V> stateDescriptor) |
<N,S extends State> |
KeyedStateBackend.getPartitionedState(N namespace,
TypeSerializer<N> namespaceSerializer,
StateDescriptor<S,?> stateDescriptor)
Creates or retrieves a partitioned state backed by this state backend.
|
<N,S extends State> |
AbstractKeyedStateBackend.getPartitionedState(N namespace,
TypeSerializer<N> namespaceSerializer,
StateDescriptor<S,?> stateDescriptor)
TODO: NOTE: This method does a lot of work caching / retrieving states just to update the
namespace.
|
static boolean |
CompositeKeySerializationUtils.isAmbiguousKeyPossible(TypeSerializer keySerializer,
TypeSerializer namespaceSerializer) |
static boolean |
CompositeKeySerializationUtils.isAmbiguousKeyPossible(TypeSerializer keySerializer,
TypeSerializer namespaceSerializer) |
static boolean |
CompositeKeySerializationUtils.isSerializerTypeVariableSized(TypeSerializer<?> serializer) |
static <K> K |
CompositeKeySerializationUtils.readKey(TypeSerializer<K> keySerializer,
DataInputDeserializer inputView,
boolean ambiguousKeyPossible) |
static <N> N |
CompositeKeySerializationUtils.readNamespace(TypeSerializer<N> namespaceSerializer,
DataInputDeserializer inputView,
boolean ambiguousKeyPossible) |
abstract TypeSerializerSchemaCompatibility<T> |
StateSerializerProvider.registerNewSerializerForRestoredState(TypeSerializer<T> newSerializer)
For restored state, register a new serializer that potentially has a new serialization
schema.
|
<T> byte[] |
ListDelimitedSerializer.serializeList(List<T> valueList,
TypeSerializer<T> elementSerializer) |
<N> void |
SerializedCompositeKeyBuilder.setNamespace(N namespace,
TypeSerializer<N> namespaceSerializer) |
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) |
static <K> void |
CompositeKeySerializationUtils.writeKey(K key,
TypeSerializer<K> keySerializer,
DataOutputSerializer keySerializationDataOutputView,
boolean ambiguousKeyPossible) |
static <N> void |
CompositeKeySerializationUtils.writeNameSpace(N namespace,
TypeSerializer<N> namespaceSerializer,
DataOutputSerializer keySerializationDataOutputView,
boolean ambiguousKeyPossible) |
Modifier and Type | Method and Description |
---|---|
<K> AbstractKeyedStateBackend<K> |
FsStateBackend.createKeyedStateBackend(Environment env,
JobID jobID,
String operatorIdentifier,
TypeSerializer<K> keySerializer,
int numberOfKeyGroups,
KeyGroupRange keyGroupRange,
TaskKvStateRegistry kvStateRegistry,
TtlTimeProvider ttlTimeProvider,
MetricGroup metricGroup,
Collection<KeyedStateHandle> stateHandles,
CloseableRegistry cancelStreamRegistry)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
<K> AbstractKeyedStateBackend<K> |
HashMapStateBackend.createKeyedStateBackend(Environment env,
JobID jobID,
String operatorIdentifier,
TypeSerializer<K> keySerializer,
int numberOfKeyGroups,
KeyGroupRange keyGroupRange,
TaskKvStateRegistry kvStateRegistry,
TtlTimeProvider ttlTimeProvider,
MetricGroup metricGroup,
Collection<KeyedStateHandle> stateHandles,
CloseableRegistry cancelStreamRegistry) |
Modifier and Type | Field and Description |
---|---|
protected TypeSerializer<K> |
StateTable.keySerializer
The serializer of the key.
|
protected TypeSerializer<K> |
AbstractHeapState.keySerializer |
protected TypeSerializer<N> |
AbstractHeapState.namespaceSerializer |
protected TypeSerializer<S> |
CopyOnWriteStateMap.stateSerializer
The serializer of the state.
|
protected TypeSerializer<SV> |
AbstractHeapState.valueSerializer |
Modifier and Type | Method and Description |
---|---|
TypeSerializer<K> |
StateTable.getKeySerializer() |
TypeSerializer<N> |
StateTable.getNamespaceSerializer() |
TypeSerializer<S> |
StateTable.getStateSerializer() |
TypeSerializer<S> |
CopyOnWriteStateMap.getStateSerializer() |
Modifier and Type | Method and Description |
---|---|
<N,S extends State,T> |
HeapKeyedStateBackend.applyToAllKeys(N namespace,
TypeSerializer<N> namespaceSerializer,
StateDescriptor<S,T> stateDescriptor,
KeyedStateFunction<K,S> function,
AbstractKeyedStateBackend.PartitionStateFactory partitionStateFactory) |
<T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>> |
HeapKeyedStateBackend.create(String stateName,
TypeSerializer<T> byteOrderedElementSerializer) |
<T extends HeapPriorityQueueElement & PriorityComparable<? super T> & Keyed<?>> |
HeapPriorityQueueSetFactory.create(String stateName,
TypeSerializer<T> byteOrderedElementSerializer) |
<N,SV,SEV,S extends State,IS extends S> |
HeapKeyedStateBackend.createInternalState(TypeSerializer<N> namespaceSerializer,
StateDescriptor<S,SV> stateDesc,
StateSnapshotTransformer.StateSnapshotTransformFactory<SEV> snapshotTransformFactory) |
HeapPriorityQueueSnapshotRestoreWrapper<T> |
HeapPriorityQueueSnapshotRestoreWrapper.forUpdatedSerializer(TypeSerializer<T> updatedSerializer)
Returns a deep copy of the snapshot, where the serializer is changed to the given serializer.
|
Iterator<StateEntry<K,N,S>> |
CopyOnWriteSkipListStateMapSnapshot.getIterator(TypeSerializer<K> keySerializer,
TypeSerializer<N> namespaceSerializer,
TypeSerializer<S> stateSerializer,
StateSnapshotTransformer<S> stateSnapshotTransformer) |
Iterator<StateEntry<K,N,S>> |
CopyOnWriteSkipListStateMapSnapshot.getIterator(TypeSerializer<K> keySerializer,
TypeSerializer<N> namespaceSerializer,
TypeSerializer<S> stateSerializer,
StateSnapshotTransformer<S> stateSnapshotTransformer) |
Iterator<StateEntry<K,N,S>> |
CopyOnWriteSkipListStateMapSnapshot.getIterator(TypeSerializer<K> keySerializer,
TypeSerializer<N> namespaceSerializer,
TypeSerializer<S> stateSerializer,
StateSnapshotTransformer<S> stateSnapshotTransformer) |
Iterator<StateEntry<K,N,S>> |
NestedStateMapSnapshot.getIterator(TypeSerializer<K> keySerializer,
TypeSerializer<N> namespaceSerializer,
TypeSerializer<S> stateSerializer,
StateSnapshotTransformer<S> stateSnapshotTransformer) |
Iterator<StateEntry<K,N,S>> |
NestedStateMapSnapshot.getIterator(TypeSerializer<K> keySerializer,
TypeSerializer<N> namespaceSerializer,
TypeSerializer<S> stateSerializer,
StateSnapshotTransformer<S> stateSnapshotTransformer) |
Iterator<StateEntry<K,N,S>> |
NestedStateMapSnapshot.getIterator(TypeSerializer<K> keySerializer,
TypeSerializer<N> namespaceSerializer,
TypeSerializer<S> stateSerializer,
StateSnapshotTransformer<S> stateSnapshotTransformer) |
abstract Iterator<StateEntry<K,N,S>> |
StateMapSnapshot.getIterator(TypeSerializer<K> keySerializer,
TypeSerializer<N> namespaceSerializer,
TypeSerializer<S> stateSerializer,
StateSnapshotTransformer<S> stateSnapshotTransformer) |
abstract Iterator<StateEntry<K,N,S>> |
StateMapSnapshot.getIterator(TypeSerializer<K> keySerializer,
TypeSerializer<N> namespaceSerializer,
TypeSerializer<S> stateSerializer,
StateSnapshotTransformer<S> stateSnapshotTransformer) |
abstract Iterator<StateEntry<K,N,S>> |
StateMapSnapshot.getIterator(TypeSerializer<K> keySerializer,
TypeSerializer<N> namespaceSerializer,
TypeSerializer<S> stateSerializer,
StateSnapshotTransformer<S> stateSnapshotTransformer) |
org.apache.flink.runtime.state.heap.CopyOnWriteStateMapSnapshot.SnapshotIterator<K,N,S> |
CopyOnWriteStateMapSnapshot.getIterator(TypeSerializer<K> keySerializer,
TypeSerializer<N> namespaceSerializer,
TypeSerializer<S> stateSerializer,
StateSnapshotTransformer<S> stateSnapshotTransformer) |
org.apache.flink.runtime.state.heap.CopyOnWriteStateMapSnapshot.SnapshotIterator<K,N,S> |
CopyOnWriteStateMapSnapshot.getIterator(TypeSerializer<K> keySerializer,
TypeSerializer<N> namespaceSerializer,
TypeSerializer<S> stateSerializer,
StateSnapshotTransformer<S> stateSnapshotTransformer) |
org.apache.flink.runtime.state.heap.CopyOnWriteStateMapSnapshot.SnapshotIterator<K,N,S> |
CopyOnWriteStateMapSnapshot.getIterator(TypeSerializer<K> keySerializer,
TypeSerializer<N> namespaceSerializer,
TypeSerializer<S> stateSerializer,
StateSnapshotTransformer<S> stateSnapshotTransformer) |
byte[] |
AbstractHeapState.getSerializedValue(byte[] serializedKeyAndNamespace,
TypeSerializer<K> safeKeySerializer,
TypeSerializer<N> safeNamespaceSerializer,
TypeSerializer<SV> safeValueSerializer) |
byte[] |
AbstractHeapState.getSerializedValue(byte[] serializedKeyAndNamespace,
TypeSerializer<K> safeKeySerializer,
TypeSerializer<N> safeNamespaceSerializer,
TypeSerializer<SV> safeValueSerializer) |
byte[] |
AbstractHeapState.getSerializedValue(byte[] serializedKeyAndNamespace,
TypeSerializer<K> safeKeySerializer,
TypeSerializer<N> safeNamespaceSerializer,
TypeSerializer<SV> safeValueSerializer) |
void |
CopyOnWriteSkipListStateMapSnapshot.writeState(TypeSerializer<K> keySerializer,
TypeSerializer<N> namespaceSerializer,
TypeSerializer<S> stateSerializer,
DataOutputView dov,
StateSnapshotTransformer<S> stateSnapshotTransformer) |
void |
CopyOnWriteSkipListStateMapSnapshot.writeState(TypeSerializer<K> keySerializer,
TypeSerializer<N> namespaceSerializer,
TypeSerializer<S> stateSerializer,
DataOutputView dov,
StateSnapshotTransformer<S> stateSnapshotTransformer) |
void |
CopyOnWriteSkipListStateMapSnapshot.writeState(TypeSerializer<K> keySerializer,
TypeSerializer<N> namespaceSerializer,
TypeSerializer<S> stateSerializer,
DataOutputView dov,
StateSnapshotTransformer<S> stateSnapshotTransformer) |
void |
NestedStateMapSnapshot.writeState(TypeSerializer<K> keySerializer,
TypeSerializer<N> namespaceSerializer,
TypeSerializer<S> stateSerializer,
DataOutputView dov,
StateSnapshotTransformer<S> stateSnapshotTransformer) |
void |
NestedStateMapSnapshot.writeState(TypeSerializer<K> keySerializer,
TypeSerializer<N> namespaceSerializer,
TypeSerializer<S> stateSerializer,
DataOutputView dov,
StateSnapshotTransformer<S> stateSnapshotTransformer) |
void |
NestedStateMapSnapshot.
|