Uses of Interface
org.apache.storm.trident.state.StateFactory
-
-
Uses of StateFactory in org.apache.storm.hdfs.trident
Classes in org.apache.storm.hdfs.trident that implement StateFactory Modifier and Type Class Description class
HdfsStateFactory
-
Uses of StateFactory in org.apache.storm.hive.trident
Classes in org.apache.storm.hive.trident that implement StateFactory Modifier and Type Class Description class
HiveStateFactory
Deprecated, for removal: This API element is subject to removal in a future version. -
Uses of StateFactory in org.apache.storm.jdbc.trident.state
Classes in org.apache.storm.jdbc.trident.state that implement StateFactory Modifier and Type Class Description class
JdbcStateFactory
-
Uses of StateFactory in org.apache.storm.jms.trident
Classes in org.apache.storm.jms.trident that implement StateFactory Modifier and Type Class Description class
JmsStateFactory
-
Uses of StateFactory in org.apache.storm.kafka.trident
Classes in org.apache.storm.kafka.trident that implement StateFactory Modifier and Type Class Description class
TridentKafkaStateFactory<K,V>
-
Uses of StateFactory in org.apache.storm.redis.trident.state
Classes in org.apache.storm.redis.trident.state that implement StateFactory Modifier and Type Class Description protected static class
RedisClusterMapState.Factory
RedisClusterMapState.Factory provides Redis Cluster environment version of StateFactory.static class
RedisClusterState.Factory
RedisClusterState.Factory implements StateFactory for Redis Cluster environment.protected static class
RedisMapState.Factory
RedisMapState.Factory provides single Redis environment version of StateFactory.static class
RedisState.Factory
RedisState.Factory implements StateFactory for single Redis environment.Methods in org.apache.storm.redis.trident.state that return StateFactory Modifier and Type Method Description static StateFactory
RedisClusterMapState. nonTransactional(JedisClusterConfig jedisClusterConfig)
Provides StateFactory for non transactional.static StateFactory
RedisClusterMapState. nonTransactional(JedisClusterConfig jedisClusterConfig, RedisDataTypeDescription dataTypeDescription)
Provides StateFactory for non transactional.static StateFactory
RedisClusterMapState. nonTransactional(JedisClusterConfig jedisClusterConfig, KeyFactory factory)
Provides StateFactory for non transactional.static StateFactory
RedisClusterMapState. nonTransactional(JedisClusterConfig jedisClusterConfig, Options<Object> opts)
Provides StateFactory for non transactional.static StateFactory
RedisMapState. nonTransactional(JedisPoolConfig jedisPoolConfig)
Provides StateFactory for non transactional.static StateFactory
RedisMapState. nonTransactional(JedisPoolConfig jedisPoolConfig, RedisDataTypeDescription dataTypeDescription)
Provides StateFactory for non transactional.static StateFactory
RedisMapState. nonTransactional(JedisPoolConfig jedisPoolConfig, KeyFactory factory)
Provides StateFactory for non transactional.static StateFactory
RedisMapState. nonTransactional(JedisPoolConfig jedisPoolConfig, Options<Object> opts)
Provides StateFactory for non transactional.static StateFactory
RedisClusterMapState. opaque(JedisClusterConfig jedisClusterConfig)
Provides StateFactory for opaque transactional.static StateFactory
RedisClusterMapState. opaque(JedisClusterConfig jedisClusterConfig, RedisDataTypeDescription dataTypeDescription)
Provides StateFactory for opaque transactional.static StateFactory
RedisClusterMapState. opaque(JedisClusterConfig jedisClusterConfig, KeyFactory factory)
Provides StateFactory for opaque transactional.static StateFactory
RedisClusterMapState. opaque(JedisClusterConfig jedisClusterConfig, Options<OpaqueValue> opts)
Provides StateFactory for opaque transactional.static StateFactory
RedisMapState. opaque(JedisPoolConfig jedisPoolConfig)
Provides StateFactory for opaque transactional.static StateFactory
RedisMapState. opaque(JedisPoolConfig jedisPoolConfig, RedisDataTypeDescription dataTypeDescription)
Provides StateFactory for opaque transactional.static StateFactory
RedisMapState. opaque(JedisPoolConfig jedisPoolConfig, KeyFactory factory)
Provides StateFactory for opaque transactional.static StateFactory
RedisMapState. opaque(JedisPoolConfig jedisPoolConfig, Options<OpaqueValue> opts)
Provides StateFactory for opaque transactional.static StateFactory
RedisClusterMapState. transactional(JedisClusterConfig jedisClusterConfig)
Provides StateFactory for transactional.static StateFactory
RedisClusterMapState. transactional(JedisClusterConfig jedisClusterConfig, RedisDataTypeDescription dataTypeDescription)
Provides StateFactory for transactional.static StateFactory
RedisClusterMapState. transactional(JedisClusterConfig jedisClusterConfig, KeyFactory factory)
Provides StateFactory for transactional.static StateFactory
RedisClusterMapState. transactional(JedisClusterConfig jedisClusterConfig, Options<TransactionalValue> opts)
Provides StateFactory for transactional.static StateFactory
RedisMapState. transactional(JedisPoolConfig jedisPoolConfig)
Provides StateFactory for transactional.static StateFactory
RedisMapState. transactional(JedisPoolConfig jedisPoolConfig, RedisDataTypeDescription dataTypeDescription)
Provides StateFactory for transactional.static StateFactory
RedisMapState. transactional(JedisPoolConfig jedisPoolConfig, KeyFactory factory)
Provides StateFactory for transactional.static StateFactory
RedisMapState. transactional(JedisPoolConfig jedisPoolConfig, Options<TransactionalValue> opts)
Provides StateFactory for transactional. -
Uses of StateFactory in org.apache.storm.starter.trident
Classes in org.apache.storm.starter.trident that implement StateFactory Modifier and Type Class Description static class
DebugMemoryMapState.Factory
static class
TridentReach.StaticSingleKeyMapState.Factory
-
Uses of StateFactory in org.apache.storm.trident
-
Uses of StateFactory in org.apache.storm.trident.fluent
Methods in org.apache.storm.trident.fluent with parameters of type StateFactory Modifier and Type Method Description TridentState
GroupedStream. persistentAggregate(StateFactory stateFactory, CombinerAggregator agg, Fields functionFields)
TridentState
GroupedStream. persistentAggregate(StateFactory stateFactory, ReducerAggregator agg, Fields functionFields)
TridentState
GroupedStream. persistentAggregate(StateFactory stateFactory, Fields inputFields, CombinerAggregator agg, Fields functionFields)
TridentState
GroupedStream. persistentAggregate(StateFactory stateFactory, Fields inputFields, ReducerAggregator agg, Fields functionFields)
-
Uses of StateFactory in org.apache.storm.trident.state
Fields in org.apache.storm.trident.state declared as StateFactory Modifier and Type Field Description StateFactory
StateSpec. stateFactory
Constructors in org.apache.storm.trident.state with parameters of type StateFactory Constructor Description StateSpec(StateFactory stateFactory)
-
Uses of StateFactory in org.apache.storm.trident.testing
Classes in org.apache.storm.trident.testing that implement StateFactory Modifier and Type Class Description static class
LRUMemoryMapState.Factory
static class
MemoryMapState.Factory
-
Uses of StateFactory in org.apache.storm.trident.windowing
Classes in org.apache.storm.trident.windowing that implement StateFactory Modifier and Type Class Description class
WindowsStateFactory
StateFactory
instance for creatingWindowsState
instances.
-