Package | Description |
---|---|
org.apache.flink.table.dataview | |
org.apache.flink.table.runtime.dataview | |
org.apache.flink.table.runtime.functions.aggregate |
Modifier and Type | Method and Description |
---|---|
MapView<K,V> |
MapViewSerializer.copy(MapView<K,V> from)
Deprecated.
|
MapView<K,V> |
MapViewSerializer.copy(MapView<K,V> from,
MapView<K,V> reuse)
Deprecated.
|
MapView<K,V> |
MapViewSerializer.createInstance()
Deprecated.
|
MapView<K,V> |
MapViewSerializer.deserialize(DataInputView source)
Deprecated.
|
MapView<K,V> |
MapViewSerializer.deserialize(MapView<K,V> reuse,
DataInputView source)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
TypeSerializer<MapView<K,V>> |
MapViewTypeInfo.createSerializer(ExecutionConfig config)
Deprecated.
|
TypeInformation<MapView<K,V>> |
MapViewTypeInfoFactory.createTypeInfo(Type t,
Map<String,TypeInformation<?>> genericParameters)
Deprecated.
|
TypeSerializer<MapView<K,V>> |
MapViewSerializer.duplicate()
Deprecated.
|
Class<MapView<K,V>> |
MapViewTypeInfo.getTypeClass()
Deprecated.
|
TypeSerializerSnapshot<MapView<K,V>> |
MapViewSerializer.snapshotConfiguration()
Deprecated.
|
<U> TypeSerializerSnapshot<MapView<K,V>> |
MapViewSerializer.transformLegacySerializerSnapshot(TypeSerializerSnapshot<U> legacySnapshot)
Deprecated.
We need to override this as a
LegacySerializerSnapshotTransformer because in Flink
1.6.x and below, this serializer was incorrectly returning directly the snapshot of the
nested map serializer as its own snapshot. |
Modifier and Type | Method and Description |
---|---|
MapView<K,V> |
MapViewSerializer.copy(MapView<K,V> from)
Deprecated.
|
MapView<K,V> |
MapViewSerializer.copy(MapView<K,V> from,
MapView<K,V> reuse)
Deprecated.
|
MapView<K,V> |
MapViewSerializer.copy(MapView<K,V> from,
MapView<K,V> reuse)
Deprecated.
|
MapView<K,V> |
MapViewSerializer.deserialize(MapView<K,V> reuse,
DataInputView source)
Deprecated.
|
void |
MapViewSerializer.serialize(MapView<K,V> record,
DataOutputView target)
Deprecated.
|
Modifier and Type | Class and Description |
---|---|
class |
StateMapView<N,EK,EV>
MapView which is implemented using state backends. |
static class |
StateMapView.KeyedStateMapViewWithKeysNotNull<N,EK,EV>
A state
MapView which does not support nullable keys and namespace. |
static class |
StateMapView.KeyedStateMapViewWithKeysNullable<N,EK,EV>
A state
MapView which supports nullable keys but does not support namespace. |
static class |
StateMapView.NamespacedStateMapViewWithKeysNotNull<N,EK,EV>
A state
MapView which supports namespace but does not support nullable keys. |
static class |
StateMapView.NamespacedStateMapViewWithKeysNullable<N,EK,EV>
A state
MapView which supports nullable keys and namespace. |
Modifier and Type | Field and Description |
---|---|
MapView<T,Integer> |
CollectAggFunction.CollectAccumulator.map |
MapView<T,Long> |
MinWithRetractAggFunction.MinWithRetractAccumulator.map |
MapView<StringData,StringData> |
JsonObjectAggFunction.Accumulator.map |
MapView<T,Long> |
MaxWithRetractAggFunction.MaxWithRetractAccumulator.map |
MapView<Long,List<T>> |
FirstValueWithRetractAggFunction.FirstValueWithRetractAccumulator.orderToValueMap |
MapView<Long,List<T>> |
LastValueWithRetractAggFunction.LastValueWithRetractAccumulator.orderToValueMap |
MapView<T,List<Long>> |
FirstValueWithRetractAggFunction.FirstValueWithRetractAccumulator.valueToOrderMap |
MapView<T,List<Long>> |
LastValueWithRetractAggFunction.LastValueWithRetractAccumulator.valueToOrderMap |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.