Uses of Interface
org.apache.storm.trident.state.State
-
-
Uses of State in org.apache.storm.hdfs.trident
Classes in org.apache.storm.hdfs.trident that implement State Modifier and Type Class Description class
HdfsState
Methods in org.apache.storm.hdfs.trident that return State Modifier and Type Method Description State
HdfsStateFactory. makeState(Map<String,Object> conf, IMetricsContext metrics, int partitionIndex, int numPartitions)
-
Uses of State in org.apache.storm.hive.trident
Classes in org.apache.storm.hive.trident that implement State Modifier and Type Class Description class
HiveState
Deprecated, for removal: This API element is subject to removal in a future version.Methods in org.apache.storm.hive.trident that return State Modifier and Type Method Description State
HiveStateFactory. makeState(Map<String,Object> conf, IMetricsContext metrics, int partitionIndex, int numPartitions)
Deprecated, for removal: This API element is subject to removal in a future version. -
Uses of State in org.apache.storm.jdbc.trident.state
Classes in org.apache.storm.jdbc.trident.state that implement State Modifier and Type Class Description class
JdbcState
Methods in org.apache.storm.jdbc.trident.state that return State Modifier and Type Method Description State
JdbcStateFactory. makeState(Map<String,Object> map, IMetricsContext metricsContext, int partitionIndex, int numPartitions)
-
Uses of State in org.apache.storm.jms.trident
Classes in org.apache.storm.jms.trident that implement State Modifier and Type Class Description class
JmsState
Methods in org.apache.storm.jms.trident that return State Modifier and Type Method Description State
JmsStateFactory. makeState(Map<String,Object> map, IMetricsContext metricsContext, int partitionIndex, int numPartitions)
-
Uses of State in org.apache.storm.kafka.trident
Classes in org.apache.storm.kafka.trident that implement State Modifier and Type Class Description class
TridentKafkaState<K,V>
Methods in org.apache.storm.kafka.trident that return State Modifier and Type Method Description State
TridentKafkaStateFactory. makeState(Map<String,Object> conf, IMetricsContext metrics, int partitionIndex, int numPartitions)
-
Uses of State in org.apache.storm.redis.trident.state
Classes in org.apache.storm.redis.trident.state with type parameters of type State Modifier and Type Class Description class
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.Classes in org.apache.storm.redis.trident.state that implement State Modifier and Type Class Description class
RedisClusterState
Implementation of State for Redis Cluster environment.class
RedisState
Implementation of State for single Redis environment.Methods in org.apache.storm.redis.trident.state that return State Modifier and Type Method Description State
RedisClusterMapState.Factory. makeState(Map<String,Object> conf, IMetricsContext metrics, int partitionIndex, int numPartitions)
State
RedisClusterState.Factory. makeState(Map<String,Object> conf, IMetricsContext metrics, int partitionIndex, int numPartitions)
State
RedisMapState.Factory. makeState(Map<String,Object> conf, IMetricsContext metrics, int partitionIndex, int numPartitions)
State
RedisState.Factory. makeState(Map<String,Object> conf, IMetricsContext metrics, int partitionIndex, int numPartitions)
-
Uses of State in org.apache.storm.starter.trident
Classes in org.apache.storm.starter.trident that implement State Modifier and Type Class Description class
DebugMemoryMapState<T>
static class
TridentReach.StaticSingleKeyMapState
Methods in org.apache.storm.starter.trident that return State Modifier and Type Method Description State
DebugMemoryMapState.Factory. makeState(Map<String,Object> conf, IMetricsContext metrics, int partitionIndex, int numPartitions)
State
TridentReach.StaticSingleKeyMapState.Factory. makeState(Map<String,Object> conf, IMetricsContext metrics, int partitionIndex, int numPartitions)
-
Uses of State in org.apache.storm.trident.operation.builtin
Methods in org.apache.storm.trident.operation.builtin with parameters of type State Modifier and Type Method Description List<Iterator<List<Object>>>
TupleCollectionGet. batchRetrieve(State state, List<TridentTuple> args)
-
Uses of State in org.apache.storm.trident.state
Classes in org.apache.storm.trident.state with type parameters of type State Modifier and Type Class Description class
BaseQueryFunction<S extends State,T>
class
BaseStateUpdater<S extends State>
interface
QueryFunction<S extends State,T>
interface
StateUpdater<S extends State>
Classes in org.apache.storm.trident.state that implement State Modifier and Type Class Description class
ReadOnlyState
Methods in org.apache.storm.trident.state that return State Modifier and Type Method Description State
StateFactory. makeState(Map<String,Object> conf, IMetricsContext metrics, int partitionIndex, int numPartitions)
-
Uses of State in org.apache.storm.trident.state.map
Subinterfaces of State in org.apache.storm.trident.state.map Modifier and Type Interface Description interface
MapState<T>
interface
ReadOnlyMapState<T>
interface
RemovableMapState<T>
Classes in org.apache.storm.trident.state.map that implement State Modifier and Type Class Description class
NonTransactionalMap<T>
class
OpaqueMap<T>
class
SnapshottableMap<T>
class
TransactionalMap<T>
-
Uses of State in org.apache.storm.trident.state.snapshot
Subinterfaces of State in org.apache.storm.trident.state.snapshot Modifier and Type Interface Description interface
ReadOnlySnapshottable<T>
interface
Snapshottable<T>
-
Uses of State in org.apache.storm.trident.testing
Classes in org.apache.storm.trident.testing that implement State Modifier and Type Class Description class
LRUMemoryMapState<T>
class
MemoryMapState<T>
Methods in org.apache.storm.trident.testing that return State Modifier and Type Method Description State
LRUMemoryMapState.Factory. makeState(Map<String,Object> conf, IMetricsContext metrics, int partitionIndex, int numPartitions)
State
MemoryMapState.Factory. makeState(Map<String,Object> conf, IMetricsContext metrics, int partitionIndex, int numPartitions)
-
Uses of State in org.apache.storm.trident.windowing
Classes in org.apache.storm.trident.windowing that implement State Modifier and Type Class Description class
WindowsState
State
implementation for windowing operation.Methods in org.apache.storm.trident.windowing that return State Modifier and Type Method Description State
WindowsStateFactory. makeState(Map<String,Object> conf, IMetricsContext metrics, int partitionIndex, int numPartitions)
-