Uses of Interface
org.apache.storm.trident.state.StateFactory
Packages that use StateFactory
Package
Description
-
Uses of StateFactory in org.apache.storm.hdfs.trident
Classes in org.apache.storm.hdfs.trident that implement StateFactory -
Uses of StateFactory in org.apache.storm.jdbc.trident.state
Classes in org.apache.storm.jdbc.trident.state that implement StateFactory -
Uses of StateFactory in org.apache.storm.jms.trident
Classes in org.apache.storm.jms.trident that implement StateFactory -
Uses of StateFactory in org.apache.storm.kafka.trident
Classes in org.apache.storm.kafka.trident that implement StateFactory -
Uses of StateFactory in org.apache.storm.redis.trident.state
Classes in org.apache.storm.redis.trident.state that implement StateFactoryModifier and TypeClassDescriptionprotected static class
RedisClusterMapState.Factory provides Redis Cluster environment version of StateFactory.static class
RedisClusterState.Factory implements StateFactory for Redis Cluster environment.protected static class
RedisMapState.Factory provides single Redis environment version of StateFactory.static class
RedisState.Factory implements StateFactory for single Redis environment.Methods in org.apache.storm.redis.trident.state that return StateFactoryModifier and TypeMethodDescriptionstatic 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 StateFactoryModifier and TypeClassDescriptionstatic class
static class
-
Uses of StateFactory in org.apache.storm.trident
Methods in org.apache.storm.trident with parameters of type StateFactoryModifier and TypeMethodDescriptionTridentTopology.newStaticState
(StateFactory factory) Stream.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.persistentAggregate
(StateFactory stateFactory, CombinerAggregator agg, Fields functionFields) Stream.persistentAggregate
(StateFactory stateFactory, ReducerAggregator agg, Fields functionFields) Stream.persistentAggregate
(StateFactory stateFactory, Fields inputFields, CombinerAggregator agg, Fields functionFields) Stream.persistentAggregate
(StateFactory stateFactory, Fields inputFields, ReducerAggregator agg, Fields functionFields) -
Uses of StateFactory in org.apache.storm.trident.fluent
Methods in org.apache.storm.trident.fluent with parameters of type StateFactoryModifier and TypeMethodDescriptionGroupedStream.persistentAggregate
(StateFactory stateFactory, CombinerAggregator agg, Fields functionFields) GroupedStream.persistentAggregate
(StateFactory stateFactory, ReducerAggregator agg, Fields functionFields) GroupedStream.persistentAggregate
(StateFactory stateFactory, Fields inputFields, CombinerAggregator agg, Fields functionFields) 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 StateFactoryConstructors in org.apache.storm.trident.state with parameters of type StateFactory -
Uses of StateFactory in org.apache.storm.trident.testing
Classes in org.apache.storm.trident.testing that implement StateFactoryModifier and TypeClassDescriptionstatic class
static class
-
Uses of StateFactory in org.apache.storm.trident.windowing
Classes in org.apache.storm.trident.windowing that implement StateFactoryModifier and TypeClassDescriptionclass
StateFactory
instance for creatingWindowsState
instances.