Uses of Interface
org.apache.storm.state.KeyValueState
Package
Description
-
Uses of KeyValueState in org.apache.storm.flux.examples
Modifier and TypeMethodDescriptionvoid
StatefulWordCounter.initState
(KeyValueState<String, Long> state) -
Uses of KeyValueState in org.apache.storm.redis.state
Modifier and TypeClassDescriptionclass
RedisKeyValueState<K,
V> A redis based implementation that persists the state in Redis. -
Uses of KeyValueState in org.apache.storm.state
-
Uses of KeyValueState in org.apache.storm.streams.processors
Modifier and TypeMethodDescriptionvoid
StatefulProcessor.initState
(KeyValueState<K, V> keyValueState) Initialize the state of the processor with the givenKeyValueState
.void
StateQueryProcessor.initState
(KeyValueState<K, V> keyValueState) void
UpdateStateByKeyProcessor.initState
(KeyValueState<K, R> keyValueState) -
Uses of KeyValueState in org.apache.storm.windowing.persistence
ModifierConstructorDescriptionWindowState
(KeyValueState<Long, WindowState.WindowPartition<T>> windowPartitionsState, KeyValueState<String, Deque<Long>> partitionIdsState, KeyValueState<String, Optional<?>> windowSystemState, Supplier<Map<String, Optional<?>>> windowSystemStateSupplier, long maxEventsInMemory)