Uses of Class
org.apache.storm.redis.common.config.JedisPoolConfig
-
-
Uses of JedisPoolConfig in org.apache.storm.redis.bolt
Constructors in org.apache.storm.redis.bolt with parameters of type JedisPoolConfig Constructor Description AbstractRedisBolt(JedisPoolConfig config)
Constructor for single Redis environment (JedisPool).RedisFilterBolt(JedisPoolConfig config, RedisFilterMapper filterMapper)
Constructor for single Redis environment (JedisPool).RedisLookupBolt(JedisPoolConfig config, RedisLookupMapper lookupMapper)
Constructor for single Redis environment (JedisPool).RedisStoreBolt(JedisPoolConfig config, RedisStoreMapper storeMapper)
Constructor for single Redis environment (JedisPool). -
Uses of JedisPoolConfig in org.apache.storm.redis.common.config
Methods in org.apache.storm.redis.common.config that return JedisPoolConfig Modifier and Type Method Description JedisPoolConfig
JedisPoolConfig.Builder. build()
Builds JedisPoolConfig. -
Uses of JedisPoolConfig in org.apache.storm.redis.common.container
Methods in org.apache.storm.redis.common.container with parameters of type JedisPoolConfig Modifier and Type Method Description static JedisCommandsContainer
JedisCommandsContainerBuilder. build(JedisPoolConfig config)
Builds container for single Redis environment.static RedisCommandsInstanceContainer
RedisCommandsContainerBuilder. build(JedisPoolConfig config)
Builds container for single Redis environment. -
Uses of JedisPoolConfig in org.apache.storm.redis.state
Fields in org.apache.storm.redis.state declared as JedisPoolConfig Modifier and Type Field Description JedisPoolConfig
RedisKeyValueStateProvider.StateConfig. jedisPoolConfig
Constructors in org.apache.storm.redis.state with parameters of type JedisPoolConfig Constructor Description RedisKeyValueState(String namespace, JedisPoolConfig poolConfig)
RedisKeyValueState(String namespace, JedisPoolConfig poolConfig, Serializer<K> keySerializer, Serializer<V> valueSerializer)
-
Uses of JedisPoolConfig in org.apache.storm.redis.tools
Constructors in org.apache.storm.redis.tools with parameters of type JedisPoolConfig Constructor Description Base64ToBinaryStateMigrationUtil(JedisPoolConfig poolConfig)
-
Uses of JedisPoolConfig in org.apache.storm.redis.trident.state
Methods in org.apache.storm.redis.trident.state with parameters of type JedisPoolConfig Modifier and Type Method Description 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
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
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.Constructors in org.apache.storm.redis.trident.state with parameters of type JedisPoolConfig Constructor Description Factory(JedisPoolConfig jedisPoolConfig, StateType type, Options options)
Constructor.Factory(JedisPoolConfig config)
Constructor.
-