Uses of Interface
org.apache.storm.trident.state.StateUpdater
Package
Description
ElasticSearch Trident example classes.
-
Uses of StateUpdater in org.apache.storm.elasticsearch.trident
-
Uses of StateUpdater in org.apache.storm.hdfs.trident
-
Uses of StateUpdater in org.apache.storm.hive.trident
-
Uses of StateUpdater in org.apache.storm.jdbc.trident.state
-
Uses of StateUpdater in org.apache.storm.jms.trident
-
Uses of StateUpdater in org.apache.storm.kafka.trident
-
Uses of StateUpdater in org.apache.storm.redis.trident.state
Modifier and TypeClassDescriptionclass
AbstractRedisStateUpdater<T extends State>
AbstractRedisStateUpdater is base class of any RedisStateUpdater, which implements BaseStateUpdater.class
BaseStateUpdater implementation for Redis Cluster environment.class
BaseStateUpdater implementation for single Redis environment. -
Uses of StateUpdater in org.apache.storm.trident
Modifier and TypeMethodDescriptionStream.partitionPersist
(StateFactory stateFactory, StateUpdater updater) Stream.partitionPersist
(StateFactory stateFactory, StateUpdater updater, Fields functionFields) Stream.partitionPersist
(StateFactory stateFactory, Fields inputFields, StateUpdater updater) Stream.partitionPersist
(StateFactory stateFactory, Fields inputFields, StateUpdater updater, Fields functionFields) Stream.partitionPersist
(StateSpec stateSpec, StateUpdater updater) Stream.partitionPersist
(StateSpec stateSpec, StateUpdater updater, Fields functionFields) Stream.partitionPersist
(StateSpec stateSpec, Fields inputFields, StateUpdater updater) Stream.partitionPersist
(StateSpec stateSpec, Fields inputFields, StateUpdater updater, Fields functionFields) -
Uses of StateUpdater in org.apache.storm.trident.operation.impl
-
Uses of StateUpdater in org.apache.storm.trident.planner.processor
ModifierConstructorDescriptionPartitionPersistProcessor
(String stateId, Fields inputFields, StateUpdater updater) -
Uses of StateUpdater in org.apache.storm.trident.state
-
Uses of StateUpdater in org.apache.storm.trident.state.map
Modifier and TypeClassDescriptionclass
class
-
Uses of StateUpdater in org.apache.storm.trident.windowing
Modifier and TypeClassDescriptionclass
StateUpdater<WindowState>
instance which removes successfully emitted triggers from store.