Uses of Interface
org.apache.storm.state.KeyValueState
-
Packages that use KeyValueState Package Description org.apache.storm.flux.examples org.apache.storm.redis.state org.apache.storm.state org.apache.storm.streams.processors org.apache.storm.windowing.persistence -
-
Uses of KeyValueState in org.apache.storm.flux.examples
Methods in org.apache.storm.flux.examples with parameters of type KeyValueState Modifier and Type Method Description void
StatefulWordCounter. initState(KeyValueState<String,Long> state)
-
Uses of KeyValueState in org.apache.storm.redis.state
Classes in org.apache.storm.redis.state that implement KeyValueState Modifier and Type Class Description class
RedisKeyValueState<K,V>
A redis based implementation that persists the state in Redis. -
Uses of KeyValueState in org.apache.storm.state
Classes in org.apache.storm.state that implement KeyValueState Modifier and Type Class Description class
InMemoryKeyValueState<K,V>
An in-memory implementation of theState
. -
Uses of KeyValueState in org.apache.storm.streams.processors
Methods in org.apache.storm.streams.processors with parameters of type KeyValueState Modifier and Type Method Description void
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
Constructors in org.apache.storm.windowing.persistence with parameters of type KeyValueState Constructor Description WindowState(KeyValueState<Long,WindowState.WindowPartition<T>> windowPartitionsState, KeyValueState<String,Deque<Long>> partitionIdsState, KeyValueState<String,Optional<?>> windowSystemState, Supplier<Map<String,Optional<?>>> windowSystemStateSupplier, long maxEventsInMemory)
-