| Modifier and Type | Class and Description | 
|---|---|
| class  | CassandraStateFactory | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | DruidBeamStateFactory<E>Deprecated. 
 the preferred way to ingest streaming events to druid is through Kafka, as such storm-druid is deprecated and will be removed in 2.x releases of storm. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | EsStateFactoryStateFactory for providing EsState. | 
| Modifier and Type | Class and Description | 
|---|---|
| protected static class  | HBaseMapState.Factory | 
| class  | HBaseStateFactory | 
| Modifier and Type | Method and Description | 
|---|---|
| static StateFactory | HBaseMapState. nonTransactional() | 
| static StateFactory | HBaseMapState. nonTransactional(HBaseMapState.Options<Object> opts) | 
| static StateFactory | HBaseMapState. opaque() | 
| static StateFactory | HBaseMapState. opaque(HBaseMapState.Options<OpaqueValue> opts) | 
| static StateFactory | HBaseMapState. transactional() | 
| static StateFactory | HBaseMapState. transactional(HBaseMapState.Options<TransactionalValue> opts) | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | HdfsStateFactory | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | HiveStateFactory | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | JdbcStateFactory | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | JmsStateFactory | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | TridentKafkaStateFactory | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | MongoStateFactory | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | OpenTsdbStateFactoryTrident  StateFactoryimplementation for OpenTSDB. | 
| Modifier and Type | Class and Description | 
|---|---|
| protected static class  | RedisClusterMapState.FactoryRedisClusterMapState.Factory provides Redis Cluster environment version of StateFactory. | 
| static class  | RedisClusterState.FactoryRedisClusterState.Factory implements StateFactory for Redis Cluster environment. | 
| protected static class  | RedisMapState.FactoryRedisMapState.Factory provides single Redis environment version of StateFactory. | 
| static class  | RedisState.FactoryRedisState.Factory implements StateFactory for single Redis environment. | 
| Modifier and Type | Method and Description | 
|---|---|
| static StateFactory | RedisClusterMapState. nonTransactional(JedisClusterConfig jedisClusterConfig)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 | RedisClusterMapState. nonTransactional(JedisClusterConfig jedisClusterConfig,
                RedisDataTypeDescription dataTypeDescription)Provides StateFactory for non transactional. | 
| static StateFactory | RedisMapState. nonTransactional(JedisPoolConfig jedisPoolConfig)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 | RedisMapState. nonTransactional(JedisPoolConfig jedisPoolConfig,
                RedisDataTypeDescription dataTypeDescription)Provides StateFactory for non transactional. | 
| static StateFactory | RedisClusterMapState. opaque(JedisClusterConfig jedisClusterConfig)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 | RedisClusterMapState. opaque(JedisClusterConfig jedisClusterConfig,
      RedisDataTypeDescription dataTypeDescription)Provides StateFactory for opaque transactional. | 
| static StateFactory | RedisMapState. opaque(JedisPoolConfig jedisPoolConfig)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 | RedisMapState. opaque(JedisPoolConfig jedisPoolConfig,
      RedisDataTypeDescription dataTypeDescription)Provides StateFactory for opaque transactional. | 
| static StateFactory | RedisClusterMapState. transactional(JedisClusterConfig jedisClusterConfig)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 | RedisClusterMapState. transactional(JedisClusterConfig jedisClusterConfig,
             RedisDataTypeDescription dataTypeDescription)Provides StateFactory for transactional. | 
| static StateFactory | RedisMapState. transactional(JedisPoolConfig jedisPoolConfig)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. | 
| static StateFactory | RedisMapState. transactional(JedisPoolConfig jedisPoolConfig,
             RedisDataTypeDescription dataTypeDescription)Provides StateFactory for transactional. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | SolrStateFactory | 
| Modifier and Type | Method and Description | 
|---|---|
| StateFactory | SimpleSqlTridentConsumer. getStateFactory() | 
| StateFactory | ISqlTridentDataSource.SqlTridentConsumer. getStateFactory() | 
| Constructor and Description | 
|---|
| SimpleSqlTridentConsumer(StateFactory stateFactory,
                        StateUpdater stateUpdater) | 
| Modifier and Type | Class and Description | 
|---|---|
| static class  | SocketState.Factory | 
| Modifier and Type | Class and Description | 
|---|---|
| static class  | DebugMemoryMapState.Factory | 
| static class  | TridentReach.StaticSingleKeyMapState.Factory | 
| Modifier and Type | Method and Description | 
|---|---|
| TridentState | GroupedStream. persistentAggregate(StateFactory stateFactory,
                   CombinerAggregator 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) | 
| TridentState | GroupedStream. persistentAggregate(StateFactory stateFactory,
                   ReducerAggregator agg,
                   Fields functionFields) | 
| Modifier and Type | Field and Description | 
|---|---|
| StateFactory | StateSpec. stateFactory | 
| Constructor and Description | 
|---|
| StateSpec(StateFactory stateFactory) | 
| Modifier and Type | Class and Description | 
|---|---|
| static class  | LRUMemoryMapState.Factory | 
| static class  | MemoryMapState.Factory | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | WindowsStateFactoryStateFactoryinstance for creatingWindowsStateinstances. | 
Copyright © 2022 The Apache Software Foundation. All Rights Reserved.