Interface ChangelogApplierFactory
-
@Internal public interface ChangelogApplierFactory
StateChangeApplier
factory. It's purpose is to decouple restore/apply logic from state logic.
-
-
Method Summary
All Methods Instance Methods Abstract Methods Modifier and Type Method Description <K,N,IN,SV,OUT>
org.apache.flink.state.changelog.restore.KvStateChangeApplier<K,N>forAggregating(InternalAggregatingState<K,N,IN,SV,OUT> aggregating, InternalKeyContext<K> keyContext)
<K,N,T>
org.apache.flink.state.changelog.restore.KvStateChangeApplier<K,N>forList(InternalListState<K,N,T> list, InternalKeyContext<K> keyContext)
<K,N,UK,UV>
org.apache.flink.state.changelog.restore.KvStateChangeApplier<K,N>forMap(InternalMapState<K,N,UK,UV> map, InternalKeyContext<K> keyContext)
<T> StateChangeApplier
forPriorityQueue(KeyGroupedInternalPriorityQueue<T> priorityQueue, TypeSerializer<T> serializer)
<K,N,T>
org.apache.flink.state.changelog.restore.KvStateChangeApplier<K,N>forReducing(InternalReducingState<K,N,T> reducing, InternalKeyContext<K> keyContext)
<K,N,T>
org.apache.flink.state.changelog.restore.KvStateChangeApplier<K,N>forValue(InternalValueState<K,N,T> value, InternalKeyContext<K> keyContext)
-
-
-
Method Detail
-
forMap
<K,N,UK,UV> org.apache.flink.state.changelog.restore.KvStateChangeApplier<K,N> forMap(InternalMapState<K,N,UK,UV> map, InternalKeyContext<K> keyContext)
-
forValue
<K,N,T> org.apache.flink.state.changelog.restore.KvStateChangeApplier<K,N> forValue(InternalValueState<K,N,T> value, InternalKeyContext<K> keyContext)
-
forList
<K,N,T> org.apache.flink.state.changelog.restore.KvStateChangeApplier<K,N> forList(InternalListState<K,N,T> list, InternalKeyContext<K> keyContext)
-
forReducing
<K,N,T> org.apache.flink.state.changelog.restore.KvStateChangeApplier<K,N> forReducing(InternalReducingState<K,N,T> reducing, InternalKeyContext<K> keyContext)
-
forAggregating
<K,N,IN,SV,OUT> org.apache.flink.state.changelog.restore.KvStateChangeApplier<K,N> forAggregating(InternalAggregatingState<K,N,IN,SV,OUT> aggregating, InternalKeyContext<K> keyContext)
-
forPriorityQueue
<T> StateChangeApplier forPriorityQueue(KeyGroupedInternalPriorityQueue<T> priorityQueue, TypeSerializer<T> serializer)
-
-