Uses of Interface
org.apache.storm.trident.state.StateUpdater
-
-
Uses of StateUpdater in org.apache.storm.hdfs.trident
Classes in org.apache.storm.hdfs.trident that implement StateUpdater Modifier and Type Class Description class
HdfsUpdater
-
Uses of StateUpdater in org.apache.storm.hive.trident
Classes in org.apache.storm.hive.trident that implement StateUpdater Modifier and Type Class Description class
HiveUpdater
Deprecated, for removal: This API element is subject to removal in a future version. -
Uses of StateUpdater in org.apache.storm.jdbc.trident.state
Classes in org.apache.storm.jdbc.trident.state that implement StateUpdater Modifier and Type Class Description class
JdbcUpdater
-
Uses of StateUpdater in org.apache.storm.jms.trident
Classes in org.apache.storm.jms.trident that implement StateUpdater Modifier and Type Class Description class
JmsUpdater
-
Uses of StateUpdater in org.apache.storm.kafka.trident
Classes in org.apache.storm.kafka.trident that implement StateUpdater Modifier and Type Class Description class
TridentKafkaStateUpdater<K,V>
-
Uses of StateUpdater in org.apache.storm.redis.trident.state
Classes in org.apache.storm.redis.trident.state that implement StateUpdater Modifier and Type Class Description class
AbstractRedisStateUpdater<T extends State>
AbstractRedisStateUpdater is base class of any RedisStateUpdater, which implements BaseStateUpdater.class
RedisClusterStateUpdater
BaseStateUpdater implementation for Redis Cluster environment.class
RedisStateUpdater
BaseStateUpdater implementation for single Redis environment. -
Uses of StateUpdater in org.apache.storm.trident
Methods in org.apache.storm.trident with parameters of type StateUpdater Modifier and Type Method Description TridentState
Stream. partitionPersist(StateFactory stateFactory, StateUpdater updater)
TridentState
Stream. partitionPersist(StateFactory stateFactory, StateUpdater updater, Fields functionFields)
TridentState
Stream. partitionPersist(StateFactory stateFactory, Fields inputFields, StateUpdater updater)
TridentState
Stream. partitionPersist(StateFactory stateFactory, Fields inputFields, StateUpdater updater, Fields functionFields)
TridentState
Stream. partitionPersist(StateSpec stateSpec, StateUpdater updater)
TridentState
Stream. partitionPersist(StateSpec stateSpec, StateUpdater updater, Fields functionFields)
TridentState
Stream. partitionPersist(StateSpec stateSpec, Fields inputFields, StateUpdater updater)
TridentState
Stream. partitionPersist(StateSpec stateSpec, Fields inputFields, StateUpdater updater, Fields functionFields)
-
Uses of StateUpdater in org.apache.storm.trident.operation.impl
Classes in org.apache.storm.trident.operation.impl that implement StateUpdater Modifier and Type Class Description class
CombinerAggStateUpdater
class
ReducerAggStateUpdater
-
Uses of StateUpdater in org.apache.storm.trident.planner.processor
Constructors in org.apache.storm.trident.planner.processor with parameters of type StateUpdater Constructor Description PartitionPersistProcessor(String stateId, Fields inputFields, StateUpdater updater)
-
Uses of StateUpdater in org.apache.storm.trident.state
Classes in org.apache.storm.trident.state that implement StateUpdater Modifier and Type Class Description class
BaseStateUpdater<S extends State>
-
Uses of StateUpdater in org.apache.storm.trident.state.map
Classes in org.apache.storm.trident.state.map that implement StateUpdater Modifier and Type Class Description class
MapCombinerAggStateUpdater
class
MapReducerAggStateUpdater
-
Uses of StateUpdater in org.apache.storm.trident.windowing
Classes in org.apache.storm.trident.windowing that implement StateUpdater Modifier and Type Class Description class
WindowsStateUpdater
StateUpdater<WindowState>
instance which removes successfully emitted triggers from store.
-