Uses of Interface
org.apache.storm.trident.state.State
Package
Description
ElasticSearch Trident example classes.
-
Uses of State in org.apache.storm.elasticsearch.trident
-
Uses of State in org.apache.storm.hdfs.trident
-
Uses of State in org.apache.storm.hive.trident
-
Uses of State in org.apache.storm.jdbc.trident.state
-
Uses of State in org.apache.storm.jms.trident
-
Uses of State in org.apache.storm.kafka.trident
-
Uses of State in org.apache.storm.redis.trident.state
Modifier and TypeClassDescriptionclass
AbstractRedisStateQuerier<T extends State>
AbstractRedisStateQuerier is base class of any RedisStateQuerier, which implements BaseQueryFunction.class
AbstractRedisStateUpdater<T extends State>
AbstractRedisStateUpdater is base class of any RedisStateUpdater, which implements BaseStateUpdater.Modifier and TypeClassDescriptionclass
Implementation of State for Redis Cluster environment.class
Implementation of State for single Redis environment.Modifier and TypeMethodDescriptionRedisClusterMapState.Factory.makeState
(Map<String, Object> conf, IMetricsContext metrics, int partitionIndex, int numPartitions) RedisClusterState.Factory.makeState
(Map<String, Object> conf, IMetricsContext metrics, int partitionIndex, int numPartitions) RedisMapState.Factory.makeState
(Map<String, Object> conf, IMetricsContext metrics, int partitionIndex, int numPartitions) RedisState.Factory.makeState
(Map<String, Object> conf, IMetricsContext metrics, int partitionIndex, int numPartitions) -
Uses of State in org.apache.storm.starter.trident
Modifier and TypeClassDescriptionclass
static class
Modifier and TypeMethodDescriptionDebugMemoryMapState.Factory.makeState
(Map<String, Object> conf, IMetricsContext metrics, int partitionIndex, int numPartitions) TridentReach.StaticSingleKeyMapState.Factory.makeState
(Map<String, Object> conf, IMetricsContext metrics, int partitionIndex, int numPartitions) -
Uses of State in org.apache.storm.trident.operation.builtin
Modifier and TypeMethodDescriptionTupleCollectionGet.batchRetrieve
(State state, List<TridentTuple> args) -
Uses of State in org.apache.storm.trident.state
Modifier and TypeClassDescriptionclass
BaseQueryFunction<S extends State,
T> class
BaseStateUpdater<S extends State>
interface
QueryFunction<S extends State,
T> interface
StateUpdater<S extends State>
-
Uses of State in org.apache.storm.trident.state.map
-
Uses of State in org.apache.storm.trident.state.snapshot
Modifier and TypeInterfaceDescriptioninterface
interface
-
Uses of State in org.apache.storm.trident.testing
-
Uses of State in org.apache.storm.trident.windowing
Modifier and TypeClassDescriptionclass
State
implementation for windowing operation.