Package | Description |
---|---|
org.apache.storm.cassandra.trident.state | |
org.apache.storm.hbase.trident.state | |
org.apache.storm.mongodb.trident.state | |
org.apache.storm.redis.trident.state |
Modifier and Type | Method and Description |
---|---|
MapStateFactoryBuilder<T> |
MapStateFactoryBuilder.withBinaryState(String stateField,
Serializer<T> serializer) |
CassandraBackingMap.Options<T> |
CassandraBackingMap.Options.withNonTransactionalBinaryState(String fieldName,
Serializer<T> serializer) |
CassandraBackingMap.Options<T> |
CassandraBackingMap.Options.withOpaqueBinaryState(String fieldName,
Serializer<OpaqueValue<T>> serializer) |
CassandraBackingMap.Options<T> |
CassandraBackingMap.Options.withTransactionalBinaryState(String fieldName,
Serializer<TransactionalValue<T>> serializer) |
Constructor and Description |
---|
SerializedStateMapper(String fieldName,
Serializer<T> serializer) |
Modifier and Type | Field and Description |
---|---|
Serializer<T> |
HBaseMapState.Options.serializer |
Modifier and Type | Field and Description |
---|---|
Serializer<T> |
MongoMapState.Options.serializer |
Modifier and Type | Field and Description |
---|---|
Serializer<T> |
Options.serializer |
Modifier and Type | Field and Description |
---|---|
static EnumMap<StateType,Serializer> |
AbstractRedisMapState.DEFAULT_SERIALIZERS |
Modifier and Type | Method and Description |
---|---|
protected Serializer |
RedisMapState.getSerializer()
Returns Serializer which is used for serializing tuple value and deserializing Redis value.
|
protected abstract Serializer |
AbstractRedisMapState.getSerializer()
Returns Serializer which is used for serializing tuple value and deserializing Redis value.
|
protected Serializer |
RedisClusterMapState.getSerializer()
Returns Serializer which is used for serializing tuple value and deserializing Redis value.
|
Constructor and Description |
---|
RedisClusterMapState(redis.clients.jedis.JedisCluster jedisCluster,
Options options,
Serializer<T> serializer,
KeyFactory keyFactory)
Constructor.
|
RedisMapState(redis.clients.jedis.JedisPool jedisPool,
Options options,
Serializer<T> serializer,
KeyFactory keyFactory)
Constructor.
|
Copyright © 2022 The Apache Software Foundation. All rights reserved.