- AbsentByteBufferResponse(I) - Constructor for class org.springframework.data.redis.connection.ReactiveRedisConnection.AbsentByteBufferResponse
-
- AbstractBitFieldSubCommand() - Constructor for class org.springframework.data.redis.connection.BitFieldSubCommands.AbstractBitFieldSubCommand
-
- AbstractRedisCollection<E> - Class in org.springframework.data.redis.support.collections
-
- AbstractRedisCollection(String, RedisOperations<String, E>) - Constructor for class org.springframework.data.redis.support.collections.AbstractRedisCollection
-
- AbstractRedisConnection - Class in org.springframework.data.redis.connection
-
- AbstractRedisConnection() - Constructor for class org.springframework.data.redis.connection.AbstractRedisConnection
-
- AbstractSubscription - Class in org.springframework.data.redis.connection.util
-
Base implementation for a subscription handling the channel/pattern registration so subclasses only have to deal with
the actual registration/unregistration.
- AbstractSubscription(MessageListener) - Constructor for class org.springframework.data.redis.connection.util.AbstractSubscription
-
- AbstractSubscription(MessageListener, byte[][], byte[][]) - Constructor for class org.springframework.data.redis.connection.util.AbstractSubscription
-
Constructs a new AbstractSubscription
instance.
- accumulateAndGet(double, DoubleBinaryOperator) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicDouble
-
- accumulateAndGet(int, IntBinaryOperator) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicInteger
-
- accumulateAndGet(long, LongBinaryOperator) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicLong
-
- acknowledge(String, String...) - Method in interface org.springframework.data.redis.core.BoundStreamOperations
-
Acknowledge one or more records as processed.
- acknowledge(K, String, String...) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
-
Acknowledge one or more records as processed.
- acknowledge(K, String, RecordId...) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
-
Acknowledge one or more records as processed.
- acknowledge(String, Record<K, ?>) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
-
Acknowledge the given record as processed.
- acknowledge(K, String, String...) - Method in interface org.springframework.data.redis.core.StreamOperations
-
Acknowledge one or more records as processed.
- acknowledge(K, String, RecordId...) - Method in interface org.springframework.data.redis.core.StreamOperations
-
Acknowledge one or more records as processed.
- acknowledge(String, Record<K, ?>) - Method in interface org.springframework.data.redis.core.StreamOperations
-
Acknowledge the given record as processed.
- add(ByteArrayWrapper) - Method in class org.springframework.data.redis.connection.util.ByteArraySet
-
- add(byte[]) - Method in class org.springframework.data.redis.connection.util.ByteArraySet
-
- add(Point, M) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
-
Add
Point
with given member name to key.
- add(RedisGeoCommands.GeoLocation<M>) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
-
- add(Map<M, Point>) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
-
- add(Iterable<RedisGeoCommands.GeoLocation<M>>) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
-
- add(V...) - Method in interface org.springframework.data.redis.core.BoundSetOperations
-
Add given values
to set at the bound key.
- add(Map<HK, HV>) - Method in interface org.springframework.data.redis.core.BoundStreamOperations
-
Append a record to the stream key
.
- add(V, double) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Add value
to a sorted set at the bound key, or update its score
if it already exists.
- add(Set<ZSetOperations.TypedTuple<V>>) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Add tuples
to a sorted set at the bound key, or update its score
if it already exists.
- add(K, Point, M) - Method in interface org.springframework.data.redis.core.GeoOperations
-
Add
Point
with given member name to key.
- add(K, RedisGeoCommands.GeoLocation<M>) - Method in interface org.springframework.data.redis.core.GeoOperations
-
- add(K, Map<M, Point>) - Method in interface org.springframework.data.redis.core.GeoOperations
-
- add(K, Iterable<RedisGeoCommands.GeoLocation<M>>) - Method in interface org.springframework.data.redis.core.GeoOperations
-
- add(K, V...) - Method in interface org.springframework.data.redis.core.HyperLogLogOperations
-
Adds the given values to the key.
- add(K, Point, M) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
-
Add
Point
with given member name to key.
- add(K, RedisGeoCommands.GeoLocation<M>) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
-
- add(K, Map<M, Point>) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
-
- add(K, Iterable<RedisGeoCommands.GeoLocation<M>>) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
-
- add(K, Publisher<? extends Collection<RedisGeoCommands.GeoLocation<M>>>) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
-
- add(K, V...) - Method in interface org.springframework.data.redis.core.ReactiveHyperLogLogOperations
-
Adds the given values to the key.
- add(K, V...) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
-
Add given values
to set at key
.
- add(K, Publisher<? extends Map<? extends HK, ? extends HV>>) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
-
Append one or more records to the stream key
.
- add(K, Map<? extends HK, ? extends HV>) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
-
Append a record to the stream key
.
- add(MapRecord<K, ? extends HK, ? extends HV>) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
-
Append a record, backed by a
Map
holding the field/value pairs, to the stream.
- add(Record<K, ?>) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
-
Append the record, backed by the given value, to the stream.
- add(K, V, double) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Add value
to a sorted set at key
, or update its score
if it already exists.
- add(K, V...) - Method in interface org.springframework.data.redis.core.SetOperations
-
Add given values
to set at key
.
- add(K, Map<? extends HK, ? extends HV>) - Method in interface org.springframework.data.redis.core.StreamOperations
-
Append a record to the stream key
.
- add(MapRecord<K, ? extends HK, ? extends HV>) - Method in interface org.springframework.data.redis.core.StreamOperations
-
Append a record, backed by a
Map
holding the field/value pairs, to the stream.
- add(Record<K, ?>) - Method in interface org.springframework.data.redis.core.StreamOperations
-
Append the record, backed by the given value, to the stream.
- add(K, V, double) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Add value
to a sorted set at key
, or update its score
if it already exists.
- add(K, Set<ZSetOperations.TypedTuple<V>>) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Add tuples
to a sorted set at key
, or update its score
if it already exists.
- add(E) - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
-
- add(int, E) - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
-
- add(E) - Method in class org.springframework.data.redis.support.collections.DefaultRedisSet
-
- add(E) - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
-
- add(E, double) - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
-
- add(E, double) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
-
Adds an element to the set with the given score, or updates the score if the element exists.
- add(E) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
-
Adds an element to the set with a default score.
- addAll(Collection<? extends ByteArrayWrapper>) - Method in class org.springframework.data.redis.connection.util.ByteArraySet
-
- addAll(Iterable<byte[]>) - Method in class org.springframework.data.redis.connection.util.ByteArraySet
-
- addAll(K, Collection<? extends ZSetOperations.TypedTuple<V>>) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Add tuples
to a sorted set at key
, or update their score if it already exists.
- addAll(Collection<? extends E>) - Method in class org.springframework.data.redis.support.collections.AbstractRedisCollection
-
- addAll(int, Collection<? extends E>) - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
-
- addAndGet(double) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicDouble
-
Atomically add the given value to current value.
- addAndGet(int) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicInteger
-
Atomically add the given value to current value.
- addAndGet(long) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicLong
-
Atomically add the given value to current value.
- addCacheKeyConverter(Converter<?, String>) - Method in class org.springframework.data.redis.cache.RedisCacheConfiguration
-
- addClusterNode(RedisNode) - Method in class org.springframework.data.redis.connection.RedisClusterConfiguration
-
Add a cluster node to configuration.
- addCondition(IndexDefinition.Condition<?>) - Method in class org.springframework.data.redis.core.index.RedisIndexDefinition
-
- addFirst(E) - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
-
- addGetPattern(byte[]) - Method in class org.springframework.data.redis.connection.DefaultSortParameters
-
- addIfAbsent(V, double) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Add value
to a sorted set at key
if it does not already exists.
- addIfAbsent(Set<ZSetOperations.TypedTuple<V>>) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Add tuples
to a sorted set at key
if it does not already exists.
- addIfAbsent(K, V, double) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Add value
to a sorted set at key
if it does not already exists.
- addIfAbsent(K, Set<ZSetOperations.TypedTuple<V>>) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Add tuples
to a sorted set at key
if it does not already exists.
- addIfAbsent(E, double) - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
-
- addIfAbsent(E) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
-
Adds an element to the set using the
default score
if the element does not already exists.
- addIfAbsent(E, double) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
-
Adds an element to the set with the given score if the element does not already exists.
- addIndexDefinition(IndexDefinition) - Method in class org.springframework.data.redis.core.index.IndexConfiguration
-
- addIndexDefinition(IndexDefinition) - Method in interface org.springframework.data.redis.core.index.IndexDefinitionRegistry
-
Add given RedisIndexSetting
.
- addIndexedData(IndexedData) - Method in class org.springframework.data.redis.core.convert.RedisData
-
- addIndexedData(Collection<IndexedData>) - Method in class org.springframework.data.redis.core.convert.RedisData
-
- addKeyspaceSettings(KeyspaceConfiguration.KeyspaceSettings) - Method in class org.springframework.data.redis.core.convert.KeyspaceConfiguration
-
- addLast(E) - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
-
- addMessageListener(MessageListener, Collection<? extends Topic>) - Method in class org.springframework.data.redis.listener.RedisMessageListenerContainer
-
Adds a message listener to the (potentially running) container.
- addMessageListener(MessageListener, Topic) - Method in class org.springframework.data.redis.listener.RedisMessageListenerContainer
-
Adds a message listener to the (potentially running) container.
- addNode(String, int) - Method in class org.springframework.data.redis.connection.RedisStaticMasterReplicaConfiguration
-
Add a
node
to the list of nodes given
hostName
.
- addSentinel(RedisNode) - Method in class org.springframework.data.redis.connection.RedisSentinelConfiguration
-
Add sentinel.
- addSlots(RedisClusterNode, int...) - Method in interface org.springframework.data.redis.core.ClusterOperations
-
Add slots to given node;
- addSlots(RedisClusterNode, RedisClusterNode.SlotRange) - Method in interface org.springframework.data.redis.core.ClusterOperations
-
- after(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveListCommands.LInsertCommand
-
Applies the after pivot.
- afterPropertiesSet() - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
-
- afterPropertiesSet() - Method in class org.springframework.data.redis.connection.lettuce.DefaultLettucePool
-
Deprecated.
- afterPropertiesSet() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
- afterPropertiesSet() - Method in class org.springframework.data.redis.core.convert.MappingRedisConverter
-
- afterPropertiesSet() - Method in class org.springframework.data.redis.core.RedisAccessor
-
- afterPropertiesSet() - Method in class org.springframework.data.redis.core.RedisKeyValueAdapter
-
- afterPropertiesSet() - Method in class org.springframework.data.redis.core.RedisTemplate
-
- afterPropertiesSet() - Method in class org.springframework.data.redis.core.script.DefaultRedisScript
-
- afterPropertiesSet() - Method in class org.springframework.data.redis.listener.adapter.MessageListenerAdapter
-
- afterPropertiesSet() - Method in class org.springframework.data.redis.listener.KeyspaceEventMessageListener
-
- afterPropertiesSet() - Method in class org.springframework.data.redis.listener.RedisMessageListenerContainer
-
- afterPropertiesSet() - Method in class org.springframework.data.redis.serializer.OxmSerializer
-
- afterPropertiesSet() - Method in class org.springframework.data.redis.support.collections.RedisCollectionFactoryBean
-
- aggregateUsing(RedisZSetCommands.Aggregate) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZInterStoreCommand
-
- aggregateUsing(RedisZSetCommands.Aggregate) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZUnionStoreCommand
-
- all() - Static method in class org.springframework.data.redis.connection.ReactiveListCommands.LRemCommand
-
- alpha() - Method in class org.springframework.data.redis.connection.DefaultSortParameters
-
- alphabetical(boolean) - Method in interface org.springframework.data.redis.core.query.SortCriterion
-
- and() - Method in class org.springframework.data.redis.connection.jedis.JedisClientConfiguration.DefaultJedisClientConfigurationBuilder
-
- and() - Method in interface org.springframework.data.redis.connection.jedis.JedisClientConfiguration.JedisPoolingClientConfigurationBuilder
-
- and() - Method in interface org.springframework.data.redis.connection.jedis.JedisClientConfiguration.JedisSslClientConfigurationBuilder
-
- and() - Method in class org.springframework.data.redis.connection.lettuce.LettuceClientConfiguration.LettuceSslClientConfigurationBuilder
-
- and() - Method in class org.springframework.data.redis.connection.lettuce.LettucePoolingClientConfiguration.LettucePoolingSslClientConfigurationBuilder
-
- and(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoDistCommand
-
Applies the to member.
- and(Part, RedisOperationChain, Iterator<Object>) - Method in class org.springframework.data.redis.repository.query.RedisQueryCreator
-
- andSaveAs(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveStringCommands.BitOpCommand
-
Applies the key to store the result at.
- append(byte[], byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
- append(byte[], byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- append(String, String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- append(ByteBuffer, ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
-
Append a value to key.
- append(Publisher<ReactiveStringCommands.AppendCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
-
- append(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveStringCommands.AppendCommand
-
Applies the value to append.
- append(byte[], byte[]) - Method in interface org.springframework.data.redis.connection.RedisStringCommands
-
Append a value
to key
.
- append(String, String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Append a value
to key
.
- append(String) - Method in interface org.springframework.data.redis.core.BoundValueOperations
-
Append a value
to the bound key.
- append(K, String) - Method in interface org.springframework.data.redis.core.ReactiveValueOperations
-
Append a value
to key
.
- append(K, String) - Method in interface org.springframework.data.redis.core.ValueOperations
-
Append a value
to key
.
- apply(Function<Double, Double>) - Method in class org.springframework.data.redis.connection.RedisZSetCommands.Weights
-
- applyWeights(List<Double>) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZInterStoreCommand
-
- applyWeights(RedisZSetCommands.Weights) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZInterStoreCommand
-
- applyWeights(List<Double>) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZUnionStoreCommand
-
Applies the
List
of weights.
- applyWeights(RedisZSetCommands.Weights) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZUnionStoreCommand
-
- approximate() - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.TrimCommand
-
Applies approximate trimming.
- approximate(boolean) - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.TrimCommand
-
Applies approximateTrimming
.
- as(Consumer) - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.ReadCommand
-
- asc() - Method in class org.springframework.data.redis.connection.DefaultSortParameters
-
- asMap() - Method in class org.springframework.data.redis.core.convert.Bucket
-
Key/value pairs contained in the
Bucket
.
- asRawSet() - Method in class org.springframework.data.redis.connection.util.ByteArraySet
-
- asString() - Method in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldType
-
Get the Redis Command representation.
- asString() - Method in class org.springframework.data.redis.connection.BitFieldSubCommands.Offset
-
- asString() - Method in class org.springframework.data.redis.connection.RedisNode
-
- at(ReadOffset) - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.GroupCommand
-
- atLeast(String) - Static method in class org.springframework.data.redis.connection.jedis.JedisVersionUtil
-
Compares given version string against current jedis version.
- atLeastJedis24() - Static method in class org.springframework.data.redis.connection.jedis.JedisVersionUtil
-
- atMost(String) - Static method in class org.springframework.data.redis.connection.jedis.JedisVersionUtil
-
Compares given version string against current jedis version.
- atOffset(long) - Method in class org.springframework.data.redis.connection.ReactiveStringCommands.GetBitCommand
-
Applies the offset index.
- atOffset(long) - Method in class org.springframework.data.redis.connection.ReactiveStringCommands.SetBitCommand
-
Applies the offset index.
- atPosition(long) - Method in class org.springframework.data.redis.connection.ReactiveStringCommands.SetRangeCommand
-
Applies the index.
- AuthenticatingRedisClient - Class in org.springframework.data.redis.connection.lettuce
-
- AuthenticatingRedisClient(String, int, String) - Constructor for class org.springframework.data.redis.connection.lettuce.AuthenticatingRedisClient
-
Deprecated.
- AuthenticatingRedisClient(String, String) - Constructor for class org.springframework.data.redis.connection.lettuce.AuthenticatingRedisClient
-
Deprecated.
- autoAck(boolean) - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.ConsumerStreamReadRequestBuilder
-
- autoAcknowledge() - Method in class org.springframework.data.redis.connection.stream.StreamReadOptions
-
Enable auto-acknowledgement by setting the NOACK
flag when reading in the context of a consumer group.
- autoAcknowledge(boolean) - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.ConsumerStreamReadRequestBuilder
-
Configure auto-acknowledgement for stream message consumption.
- autoGenerate() - Static method in class org.springframework.data.redis.connection.stream.RecordId
-
Obtain the
RecordId
signalling the server to auto generate an entry-id on insert (
XADD
).
- await(Duration) - Method in interface org.springframework.data.redis.stream.Subscription
-
- awaitStart(Duration) - Method in interface org.springframework.data.redis.stream.Task
-
Synchronous,
blocking call that awaits until this
Task
becomes active.
- BasicRedisPersistentEntity<T> - Class in org.springframework.data.redis.core.mapping
-
- BasicRedisPersistentEntity(TypeInformation<T>, KeySpaceResolver, TimeToLiveAccessor) - Constructor for class org.springframework.data.redis.core.mapping.BasicRedisPersistentEntity
-
- batchSize(int) - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamMessageListenerContainerOptionsBuilder
-
Configure a batch size for the COUNT
option during reading.
- batchSize(int) - Method in class org.springframework.data.redis.stream.StreamReceiver.StreamReceiverOptionsBuilder
-
Configure a batch size for the COUNT
option during reading.
- beanManager - Variable in class org.springframework.data.redis.repository.cdi.CdiBean
-
- BeanUtilsHashMapper<T> - Class in org.springframework.data.redis.hash
-
HashMapper based on Apache Commons BeanUtils project.
- BeanUtilsHashMapper(Class<T>) - Constructor for class org.springframework.data.redis.hash.BeanUtilsHashMapper
-
- before(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveListCommands.LInsertCommand
-
Applies the before pivot.
- between(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoDistCommand
-
Applies the from member.
- bgReWriteAof(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.DefaultedRedisClusterConnection
-
- bgReWriteAof() - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
- bgReWriteAof() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- bgReWriteAof(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.ReactiveClusterServerCommands
-
Start an Append Only File rewrite process on the specific server.
- bgReWriteAof() - Method in interface org.springframework.data.redis.connection.ReactiveServerCommands
-
Start an Append Only File rewrite process on server.
- bgReWriteAof(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.RedisClusterServerCommands
-
- bgReWriteAof() - Method in interface org.springframework.data.redis.connection.RedisServerCommands
-
Start an Append Only File rewrite process on server.
- bgReWriteAof(RedisClusterNode) - Method in interface org.springframework.data.redis.core.ClusterOperations
-
Start an Append Only File rewrite process on given node.
- bgSave(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.DefaultedRedisClusterConnection
-
- bgSave() - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
- bgSave() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- bgSave(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.ReactiveClusterServerCommands
-
Start background saving of db on server.
- bgSave() - Method in interface org.springframework.data.redis.connection.ReactiveServerCommands
-
Start background saving of db on server.
- bgSave(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.RedisClusterServerCommands
-
- bgSave() - Method in interface org.springframework.data.redis.connection.RedisServerCommands
-
Start background saving of db on server.
- bgSave(RedisClusterNode) - Method in interface org.springframework.data.redis.core.ClusterOperations
-
Start background saving of db on given node.
- bgWriteAof() - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
- bgWriteAof() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- bgWriteAof() - Method in interface org.springframework.data.redis.connection.RedisServerCommands
-
- bindConnection(RedisConnectionFactory) - Static method in class org.springframework.data.redis.core.RedisConnectionUtils
-
- bindConnection(RedisConnectionFactory, boolean) - Static method in class org.springframework.data.redis.core.RedisConnectionUtils
-
- bit(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveStringCommands.GetBitCommand
-
- bit(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveStringCommands.SetBitCommand
-
- bitCount(byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
- bitCount(byte[], long, long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
- bitCount(byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- bitCount(byte[], long, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- bitCount(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- bitCount(String, long, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- bitCount(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
-
Count the number of set bits (population counting) in value stored at key.
- bitCount(ByteBuffer, long, long) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
-
Count the number of set bits (population counting) of value stored at key between start and
end.
- bitCount(Publisher<ReactiveStringCommands.BitCountCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
-
Count the number of set bits (population counting) of value stored at key between start and
end.
- bitCount(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveStringCommands.BitCountCommand
-
- bitCount(byte[]) - Method in interface org.springframework.data.redis.connection.RedisStringCommands
-
Count the number of set bits (population counting) in value stored at key
.
- bitCount(byte[], long, long) - Method in interface org.springframework.data.redis.connection.RedisStringCommands
-
Count the number of set bits (population counting) of value stored at key
between start
and
end
.
- bitCount(String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Count the number of set bits (population counting) in value stored at key
.
- bitCount(String, long, long) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Count the number of set bits (population counting) of value stored at key
between start
and
end
.
- bitField(byte[], BitFieldSubCommands) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
- bitField(byte[], BitFieldSubCommands) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- bitfield(String, BitFieldSubCommands) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- bitField(ByteBuffer, BitFieldSubCommands) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
-
Get / Manipulate specific integer fields of varying bit widths and arbitrary non (necessary) aligned offset stored
at a given key
.
- bitField(Publisher<ReactiveStringCommands.BitFieldCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
-
Get / Manipulate specific integer fields of varying bit widths and arbitrary non (necessary) aligned offset stored
at a given key
.
- bitField(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveStringCommands.BitFieldCommand
-
- bitField(byte[], BitFieldSubCommands) - Method in interface org.springframework.data.redis.connection.RedisStringCommands
-
Get / Manipulate specific integer fields of varying bit widths and arbitrary non (necessary) aligned offset stored
at a given key
.
- bitfield(String, BitFieldSubCommands) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get / Manipulate specific integer fields of varying bit widths and arbitrary non (necessary) aligned offset stored
at a given key
.
- bitField(K, BitFieldSubCommands) - Method in interface org.springframework.data.redis.core.ReactiveValueOperations
-
Get / Manipulate specific integer fields of varying bit widths and arbitrary non (necessary) aligned offset stored
at a given key
.
- bitField(K, BitFieldSubCommands) - Method in interface org.springframework.data.redis.core.ValueOperations
-
Get / Manipulate specific integer fields of varying bit widths and arbitrary non (necessary) aligned offset stored
at a given key
.
- BitFieldGet() - Constructor for class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldGet
-
- BitFieldIncrBy() - Constructor for class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldIncrBy
-
- BitFieldSet() - Constructor for class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldSet
-
- BitFieldSubCommands - Class in org.springframework.data.redis.connection
-
- BitFieldSubCommands.AbstractBitFieldSubCommand - Class in org.springframework.data.redis.connection
-
- BitFieldSubCommands.BitFieldGet - Class in org.springframework.data.redis.connection
-
- BitFieldSubCommands.BitFieldGetBuilder - Class in org.springframework.data.redis.connection
-
- BitFieldSubCommands.BitFieldIncrBy - Class in org.springframework.data.redis.connection
-
- BitFieldSubCommands.BitFieldIncrBy.Overflow - Enum in org.springframework.data.redis.connection
-
- BitFieldSubCommands.BitFieldIncrByBuilder - Class in org.springframework.data.redis.connection
-
- BitFieldSubCommands.BitFieldSet - Class in org.springframework.data.redis.connection
-
- BitFieldSubCommands.BitFieldSetBuilder - Class in org.springframework.data.redis.connection
-
- BitFieldSubCommands.BitFieldSubCommand - Interface in org.springframework.data.redis.connection
-
- BitFieldSubCommands.BitFieldType - Class in org.springframework.data.redis.connection
-
- BitFieldSubCommands.Offset - Class in org.springframework.data.redis.connection
-
- bitOp(RedisStringCommands.BitOperation, byte[], byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
- bitOp(RedisStringCommands.BitOperation, byte[], byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- bitOp(RedisStringCommands.BitOperation, String, String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- bitOp(Collection<ByteBuffer>, RedisStringCommands.BitOperation, ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
-
Perform bitwise operations between strings.
- bitOp(Publisher<ReactiveStringCommands.BitOpCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
-
Perform bitwise operations between strings.
- bitOp(RedisStringCommands.BitOperation, byte[], byte[]...) - Method in interface org.springframework.data.redis.connection.RedisStringCommands
-
Perform bitwise operations between strings.
- bitOp(RedisStringCommands.BitOperation, String, String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Perform bitwise operations between strings.
- bitPos(byte[], boolean, Range<Long>) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
- bitPos(byte[], boolean, Range<Long>) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- bitPos(String, boolean, Range<Long>) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- bitPos(ByteBuffer, boolean) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
-
Return the position of the first bit set to given bit
in a string.
- bitPos(ByteBuffer, boolean, Range<Long>) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
-
Return the position of the first bit set to given bit
in a string.
- bitPos(Publisher<ReactiveStringCommands.BitPosCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
-
Emmit the the position of the first bit set to given bit
in a string.
- bitPos(byte[], boolean) - Method in interface org.springframework.data.redis.connection.RedisStringCommands
-
Return the position of the first bit set to given bit
in a string.
- bitPos(byte[], boolean, Range<Long>) - Method in interface org.springframework.data.redis.connection.RedisStringCommands
-
Return the position of the first bit set to given bit
in a string.
- bitPos(String, boolean) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Return the position of the first bit set to given bit
in a string.
- bitPos(String, boolean, Range<Long>) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Return the position of the first bit set to given bit
in a string.
- block(Duration) - Method in class org.springframework.data.redis.connection.stream.StreamReadOptions
-
Use a blocking read and supply the
timeout
after which the call will terminate if no message was
read.
- blockingFor(Duration) - Method in class org.springframework.data.redis.connection.ReactiveListCommands.BPopCommand
-
- blockingFor(Duration) - Method in class org.springframework.data.redis.connection.ReactiveListCommands.BRPopLPushCommand
-
- bLPop(int, byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
- bLPop(int, byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- bLPop(int, String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- blPop(List<ByteBuffer>, Duration) - Method in interface org.springframework.data.redis.connection.ReactiveListCommands
-
Removes and returns first element from lists stored at keys.
- bLPop(int, byte[]...) - Method in interface org.springframework.data.redis.connection.RedisListCommands
-
Removes and returns first element from lists stored at keys
.
- bLPop(int, String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
- body(Map<ByteBuffer, ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveStreamCommands.AddStreamRecord
-
- BooleanResponse(I, Boolean) - Constructor for class org.springframework.data.redis.connection.ReactiveRedisConnection.BooleanResponse
-
- boundaryToBytesForZRange(RedisZSetCommands.Range.Boundary, byte[]) - Static method in class org.springframework.data.redis.connection.jedis.JedisConverters
-
- boundaryToBytesForZRange(RedisZSetCommands.Range.Boundary, byte[]) - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
-
Deprecated.
- boundaryToBytesForZRangeByLex(RedisZSetCommands.Range.Boundary, byte[]) - Static method in class org.springframework.data.redis.connection.jedis.JedisConverters
-
- boundaryToBytesForZRangeByLex(RedisZSetCommands.Range.Boundary, byte[]) - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
-
Deprecated.
- boundaryToStringForZRange(RedisZSetCommands.Range.Boundary, String) - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
-
Deprecated.
- BoundGeoOperations<K,M> - Interface in org.springframework.data.redis.core
-
- boundGeoOps(K) - Method in interface org.springframework.data.redis.core.RedisOperations
-
Returns geospatial specific operations interface bound to the given key.
- boundGeoOps(K) - Method in class org.springframework.data.redis.core.RedisTemplate
-
- BoundHashOperations<H,HK,HV> - Interface in org.springframework.data.redis.core
-
Hash operations bound to a certain key.
- boundHashOps(K) - Method in interface org.springframework.data.redis.core.RedisOperations
-
Returns the operations performed on hash values bound to the given key. * @param hash key (or field) type
- boundHashOps(K) - Method in class org.springframework.data.redis.core.RedisTemplate
-
- BoundKeyOperations<K> - Interface in org.springframework.data.redis.core
-
Operations over a Redis key.
- BoundListOperations<K,V> - Interface in org.springframework.data.redis.core
-
List operations bound to a certain key.
- boundListOps(K) - Method in interface org.springframework.data.redis.core.RedisOperations
-
Returns the operations performed on list values bound to the given key.
- boundListOps(K) - Method in class org.springframework.data.redis.core.RedisTemplate
-
- BoundSetOperations<K,V> - Interface in org.springframework.data.redis.core
-
Set operations bound to a certain key.
- boundSetOps(K) - Method in interface org.springframework.data.redis.core.RedisOperations
-
Returns the operations performed on set values bound to the given key.
- boundSetOps(K) - Method in class org.springframework.data.redis.core.RedisTemplate
-
- BoundStreamOperations<K,HK,HV> - Interface in org.springframework.data.redis.core
-
Redis stream specific operations bound to a certain key.
- boundStreamOps(K) - Method in interface org.springframework.data.redis.core.RedisOperations
-
Returns the operations performed on Streams bound to the given key.
- boundStreamOps(K) - Method in class org.springframework.data.redis.core.RedisTemplate
-
- BoundValueOperations<K,V> - Interface in org.springframework.data.redis.core
-
Value (or String in Redis terminology) operations bound to a certain key.
- boundValueOps(K) - Method in interface org.springframework.data.redis.core.RedisOperations
-
Returns the operations performed on simple values (or Strings in Redis terminology) bound to the given key.
- boundValueOps(K) - Method in class org.springframework.data.redis.core.RedisTemplate
-
- BoundZSetOperations<K,V> - Interface in org.springframework.data.redis.core
-
ZSet (or SortedSet) operations bound to a certain key.
- boundZSetOps(K) - Method in interface org.springframework.data.redis.core.RedisOperations
-
Returns the operations performed on zset values (also known as sorted sets) bound to the given key.
- boundZSetOps(K) - Method in class org.springframework.data.redis.core.RedisTemplate
-
- bPop(Publisher<ReactiveListCommands.BPopCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveListCommands
-
- bRPop(int, byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
- bRPop(int, byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- bRPop(int, String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- brPop(List<ByteBuffer>, Duration) - Method in interface org.springframework.data.redis.connection.ReactiveListCommands
-
Removes and returns last element from lists stored at keys.
- bRPop(int, byte[]...) - Method in interface org.springframework.data.redis.connection.RedisListCommands
-
Removes and returns last element from lists stored at keys
.
- bRPop(int, String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
- bRPopLPush(int, byte[], byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
- bRPopLPush(int, byte[], byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- bRPopLPush(int, String, String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- bRPopLPush(ByteBuffer, ByteBuffer, Duration) - Method in interface org.springframework.data.redis.connection.ReactiveListCommands
-
Remove the last element from list at source, append it to destination and return its value.
- bRPopLPush(Publisher<ReactiveListCommands.BRPopLPushCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveListCommands
-
- bRPopLPush(int, byte[], byte[]) - Method in interface org.springframework.data.redis.connection.RedisListCommands
-
Remove the last element from list at srcKey
, append it to dstKey
and return its value.
- bRPopLPush(int, String, String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
- Bucket - Class in org.springframework.data.redis.core.convert
-
Bucket is the data bag for Redis hash structures to be used with
RedisData
.
- Bucket() - Constructor for class org.springframework.data.redis.core.convert.Bucket
-
Creates a new empty bucket.
- Bucket.BucketPropertyPath - Class in org.springframework.data.redis.core.convert
-
Value object representing a path within a
Bucket
.
- buffered(int) - Static method in interface org.springframework.data.redis.connection.lettuce.LettuceConnection.PipeliningFlushPolicy
-
Return a policy to buffer commands and to flush once reaching the configured bufferSize
.
- build() - Method in class org.springframework.data.redis.cache.RedisCacheManager.RedisCacheManagerBuilder
-
- build() - Method in class org.springframework.data.redis.connection.jedis.JedisClientConfiguration.DefaultJedisClientConfigurationBuilder
-
- build() - Method in interface org.springframework.data.redis.connection.jedis.JedisClientConfiguration.JedisClientConfigurationBuilder
-
- build() - Method in interface org.springframework.data.redis.connection.jedis.JedisClientConfiguration.JedisPoolingClientConfigurationBuilder
-
- build() - Method in interface org.springframework.data.redis.connection.jedis.JedisClientConfiguration.JedisSslClientConfigurationBuilder
-
- build() - Method in class org.springframework.data.redis.connection.lettuce.LettuceClientConfiguration.LettuceClientConfigurationBuilder
-
- build() - Method in class org.springframework.data.redis.connection.lettuce.LettuceClientConfiguration.LettuceSslClientConfigurationBuilder
-
- build() - Method in class org.springframework.data.redis.connection.lettuce.LettucePoolingClientConfiguration.LettucePoolingClientConfigurationBuilder
-
- build() - Method in class org.springframework.data.redis.connection.lettuce.LettucePoolingClientConfiguration.LettucePoolingSslClientConfigurationBuilder
-
- build() - Method in class org.springframework.data.redis.connection.RedisClusterNode.RedisClusterNodeBuilder
-
- build() - Method in class org.springframework.data.redis.connection.RedisNode.RedisNodeBuilder
-
- build() - Method in interface org.springframework.data.redis.core.query.SortCriterion
-
- build() - Method in class org.springframework.data.redis.core.ScanOptions.ScanOptionsBuilder
-
- build() - Method in interface org.springframework.data.redis.serializer.RedisSerializationContext.RedisSerializationContextBuilder
-
- build() - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.ConsumerStreamReadRequestBuilder
-
- build() - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamMessageListenerContainerOptionsBuilder
-
- build() - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamReadRequestBuilder
-
- build() - Method in class org.springframework.data.redis.stream.StreamReceiver.StreamReceiverOptionsBuilder
-
- builder() - Static method in class org.springframework.data.redis.cache.RedisCacheManager
-
- builder(RedisConnectionFactory) - Static method in class org.springframework.data.redis.cache.RedisCacheManager
-
- builder(RedisCacheWriter) - Static method in class org.springframework.data.redis.cache.RedisCacheManager
-
- builder() - Static method in interface org.springframework.data.redis.connection.jedis.JedisClientConfiguration
-
- builder() - Static method in interface org.springframework.data.redis.connection.lettuce.LettuceClientConfiguration
-
- builder() - Static method in interface org.springframework.data.redis.connection.lettuce.LettucePoolingClientConfiguration
-
- builder() - Static method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamMessageListenerContainerOptions
-
- builder(StreamOffset<K>) - Static method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamReadRequest
-
- builder() - Static method in class org.springframework.data.redis.stream.StreamReceiver.StreamReceiverOptions
-
- builder(HashMapper<T, byte[], byte[]>) - Static method in class org.springframework.data.redis.stream.StreamReceiver.StreamReceiverOptions
-
- BulkMapper<T,V> - Interface in org.springframework.data.redis.core
-
Mapper translating Redis bulk value responses (typically returned by a sort query) to actual objects.
- by(long) - Method in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldIncrByBuilder
-
Set the value used for increasing.
- by(byte[]) - Method in class org.springframework.data.redis.connection.DefaultSortParameters
-
- by(T) - Method in class org.springframework.data.redis.connection.ReactiveNumberCommands.DecrByCommand
-
Applies the numeric value.
- by(T) - Method in class org.springframework.data.redis.connection.ReactiveNumberCommands.HIncrByCommand
-
Applies the numeric value.
- by(T) - Method in class org.springframework.data.redis.connection.ReactiveNumberCommands.IncrByCommand
-
Applies the numeric value.
- by(Number) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZIncrByCommand
-
Applies the numeric increment.
- by(String) - Method in class org.springframework.data.redis.core.query.SortQueryBuilder
-
- byteArray() - Static method in interface org.springframework.data.redis.serializer.RedisSerializationContext
-
- byteArray() - Static method in interface org.springframework.data.redis.serializer.RedisSerializationContext.SerializationPair
-
- byteArray() - Static method in interface org.springframework.data.redis.serializer.RedisSerializer
-
- ByteArraySet - Class in org.springframework.data.redis.connection.util
-
- ByteArraySet() - Constructor for class org.springframework.data.redis.connection.util.ByteArraySet
-
- ByteArraySet(Collection<byte[]>) - Constructor for class org.springframework.data.redis.connection.util.ByteArraySet
-
- ByteArrayWrapper - Class in org.springframework.data.redis.connection.util
-
Simple wrapper class used for wrapping arrays so they can be used as keys inside maps.
- ByteArrayWrapper(byte[]) - Constructor for class org.springframework.data.redis.connection.util.ByteArrayWrapper
-
- byteBuffer() - Static method in interface org.springframework.data.redis.serializer.RedisSerializationContext
-
- byteBuffer() - Static method in interface org.springframework.data.redis.serializer.RedisSerializationContext.SerializationPair
-
- ByteBufferRecord - Interface in org.springframework.data.redis.connection.stream
-
A
Record
within the stream backed by a collection of binary field/value paris.
- ByteBufferResponse(I, ByteBuffer) - Constructor for class org.springframework.data.redis.connection.ReactiveRedisConnection.ByteBufferResponse
-
- ByteRecord - Interface in org.springframework.data.redis.connection.stream
-
A
Record
within the stream backed by a collection of binary field/value paris.
- bytesCollectionToBytesList() - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
-
Deprecated.
- bytesListToBytesSet() - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
-
Deprecated.
- bytesListToMapConverter() - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
-
Deprecated.
- bytesListToStringListConverter() - Static method in class org.springframework.data.redis.connection.jedis.JedisConverters
-
- bytesListToTupleListConverter() - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
-
Deprecated.
- bytesSetToBytesList() - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
-
Deprecated.
- bytesSetToGeoResultsConverter() - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
-
- bytesToString() - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
-
Deprecated.
- ByteUtils - Class in org.springframework.data.redis.util
-
Some handy methods for dealing with byte
arrays.
- cacheDefaults(RedisCacheConfiguration) - Method in class org.springframework.data.redis.cache.RedisCacheManager.RedisCacheManagerBuilder
-
- CacheKeyPrefix - Interface in org.springframework.data.redis.cache
-
CacheKeyPrefix
provides a hook for creating custom prefixes prepended to the actual key stored in
Redis.
- CacheStatistics - Interface in org.springframework.data.redis.cache
-
- CacheStatisticsCollector - Interface in org.springframework.data.redis.cache
-
The statistics collector supports capturing of relevant
RedisCache
operations such as
hits & misses.
- CacheStatisticsProvider - Interface in org.springframework.data.redis.cache
-
Interface to be implemented by objects that expose
CacheStatistics
identified by
cacheName
.
- cacheWriter(RedisCacheWriter) - Method in class org.springframework.data.redis.cache.RedisCacheManager.RedisCacheManagerBuilder
-
- calculateSlot(String) - Static method in class org.springframework.data.redis.connection.ClusterSlotHashUtil
-
Calculate the slot from the given key.
- calculateSlot(byte[]) - Static method in class org.springframework.data.redis.connection.ClusterSlotHashUtil
-
Calculate the slot from the given key.
- cancel() - Method in interface org.springframework.data.redis.connection.ReactiveSubscription
-
- cancel() - Method in interface org.springframework.data.redis.stream.Cancelable
-
Abort and free resources.
- Cancelable - Interface in org.springframework.data.redis.stream
-
Cancelable allows stopping long running tasks and freeing underlying resources.
- cancelOnError(Predicate<Throwable>) - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.ConsumerStreamReadRequestBuilder
-
- cancelOnError(Predicate<Throwable>) - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamReadRequestBuilder
-
- canEqual(Object) - Method in class org.springframework.data.redis.connection.RedisGeoCommands.GeoLocation
-
- canEqual(Object) - Method in class org.springframework.data.redis.core.convert.GeoIndexedPropertyValue
-
- canSerialize(Class<?>) - Method in interface org.springframework.data.redis.serializer.RedisSerializer
-
- CdiBean<T> - Class in org.springframework.data.redis.repository.cdi
-
Base class for Bean
wrappers.
- CdiBean(Set<Annotation>, Class<T>, BeanManager) - Constructor for class org.springframework.data.redis.repository.cdi.CdiBean
-
- CdiBean(Set<Annotation>, Set<Type>, Class<T>, BeanManager) - Constructor for class org.springframework.data.redis.repository.cdi.CdiBean
-
- ch() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZAddCommand
-
Applies ch mode (Modify the return value from the number of new elements added, to the total number of
elements changed).
- ch() - Method in class org.springframework.data.redis.connection.RedisZSetCommands.ZAddArgs
-
Only update elements that already exist.
- ChannelMessage(C, M) - Constructor for class org.springframework.data.redis.connection.ReactiveSubscription.ChannelMessage
-
- ChannelTopic - Class in org.springframework.data.redis.listener
-
Channel topic implementation (maps to a Redis channel).
- ChannelTopic(String) - Constructor for class org.springframework.data.redis.listener.ChannelTopic
-
- CHARSET - Static variable in class org.springframework.data.redis.core.convert.Bucket
-
Encoding used for converting
Byte
to and from
String
.
- checkResult(Object) - Method in class org.springframework.data.redis.support.collections.AbstractRedisCollection
-
- clean(String, byte[]) - Method in interface org.springframework.data.redis.cache.RedisCacheWriter
-
Remove all keys following the given pattern.
- clear() - Method in class org.springframework.data.redis.cache.RedisCache
-
- clear() - Method in class org.springframework.data.redis.connection.util.ByteArraySet
-
- clear() - Method in class org.springframework.data.redis.core.RedisKeyValueAdapter
-
- clear() - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
-
- clear() - Method in class org.springframework.data.redis.support.collections.DefaultRedisMap
-
- clear() - Method in class org.springframework.data.redis.support.collections.DefaultRedisSet
-
- clear() - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
-
- clear() - Method in class org.springframework.data.redis.support.collections.RedisProperties
-
- clearStatistics() - Method in class org.springframework.data.redis.cache.RedisCache
-
Reset all statistics counters and gauges for this cache.
- clearStatistics(String) - Method in interface org.springframework.data.redis.cache.RedisCacheWriter
-
Reset all statistics counters and gauges for this cache.
- clientName(String) - Method in class org.springframework.data.redis.connection.jedis.JedisClientConfiguration.DefaultJedisClientConfigurationBuilder
-
- clientName(String) - Method in interface org.springframework.data.redis.connection.jedis.JedisClientConfiguration.JedisClientConfigurationBuilder
-
Configure a clientName
to be set with CLIENT SETNAME
.
- clientName(String) - Method in class org.springframework.data.redis.connection.lettuce.LettuceClientConfiguration.LettuceClientConfigurationBuilder
-
Configure a clientName
to be set with CLIENT SETNAME
.
- clientName(String) - Method in class org.springframework.data.redis.connection.lettuce.LettucePoolingClientConfiguration.LettucePoolingClientConfigurationBuilder
-
- clientOptions(ClientOptions) - Method in class org.springframework.data.redis.connection.lettuce.LettuceClientConfiguration.LettuceClientConfigurationBuilder
-
Configure ClientOptions
.
- clientOptions(ClientOptions) - Method in class org.springframework.data.redis.connection.lettuce.LettucePoolingClientConfiguration.LettucePoolingClientConfigurationBuilder
-
- clientResources(ClientResources) - Method in class org.springframework.data.redis.connection.lettuce.LettuceClientConfiguration.LettuceClientConfigurationBuilder
-
Configure ClientResources
.
- clientResources(ClientResources) - Method in class org.springframework.data.redis.connection.lettuce.LettucePoolingClientConfiguration.LettucePoolingClientConfigurationBuilder
-
- clone() - Method in class org.springframework.data.redis.connection.RedisGeoCommands.GeoRadiusCommandArgs
-
- clone() - Method in class org.springframework.data.redis.support.collections.RedisProperties
-
- close() - Method in class org.springframework.data.redis.connection.AbstractRedisConnection
-
- close() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- close() - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
-
- close() - Method in class org.springframework.data.redis.connection.jedis.JedisConnection
-
- close() - Method in class org.springframework.data.redis.connection.jedis.JedisSentinelConnection
-
- close() - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
-
- close() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
-
- close() - Method in class org.springframework.data.redis.connection.lettuce.LettuceSentinelConnection
-
- close() - Method in interface org.springframework.data.redis.connection.ReactiveRedisConnection
-
- close() - Method in interface org.springframework.data.redis.connection.RedisConnection
-
Closes (or quits) the connection.
- close() - Method in interface org.springframework.data.redis.connection.Subscription
-
Shutdown the subscription and free any resources held.
- close() - Method in class org.springframework.data.redis.connection.util.AbstractSubscription
-
- close() - Method in class org.springframework.data.redis.core.ConvertingCursor
-
- close() - Method in class org.springframework.data.redis.core.ScanCursor
-
- closeLater() - Method in interface org.springframework.data.redis.connection.ReactiveRedisConnection
-
Asynchronously close the connection and release associated resources.
- closePipeline() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- closePipeline() - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
-
- closePipeline() - Method in class org.springframework.data.redis.connection.jedis.JedisConnection
-
- closePipeline() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
-
- closePipeline() - Method in interface org.springframework.data.redis.connection.RedisConnection
-
Executes the commands in the pipeline and returns their result.
- clusterAddSlots(RedisClusterNode, int...) - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
-
- clusterAddSlots(RedisClusterNode, RedisClusterNode.SlotRange) - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
-
- clusterAddSlots(RedisClusterNode, int...) - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
-
- clusterAddSlots(RedisClusterNode, RedisClusterNode.SlotRange) - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
-
- clusterAddSlots(RedisClusterNode, int...) - Method in interface org.springframework.data.redis.connection.ReactiveClusterCommands
-
- clusterAddSlots(RedisClusterNode, RedisClusterNode.SlotRange) - Method in interface org.springframework.data.redis.connection.ReactiveClusterCommands
-
- clusterAddSlots(RedisClusterNode, int...) - Method in interface org.springframework.data.redis.connection.RedisClusterCommands
-
- clusterAddSlots(RedisClusterNode, RedisClusterNode.SlotRange) - Method in interface org.springframework.data.redis.connection.RedisClusterCommands
-
- ClusterCommandExecutionFailureException - Exception in org.springframework.data.redis.connection
-
Exception thrown when at least one call to a clustered redis environment fails.
- ClusterCommandExecutionFailureException(Throwable) - Constructor for exception org.springframework.data.redis.connection.ClusterCommandExecutionFailureException
-
- ClusterCommandExecutionFailureException(List<? extends Throwable>) - Constructor for exception org.springframework.data.redis.connection.ClusterCommandExecutionFailureException
-
- ClusterCommandExecutor - Class in org.springframework.data.redis.connection
-
- ClusterCommandExecutor(ClusterTopologyProvider, ClusterNodeResourceProvider, ExceptionTranslationStrategy) - Constructor for class org.springframework.data.redis.connection.ClusterCommandExecutor
-
- ClusterCommandExecutor(ClusterTopologyProvider, ClusterNodeResourceProvider, ExceptionTranslationStrategy, AsyncTaskExecutor) - Constructor for class org.springframework.data.redis.connection.ClusterCommandExecutor
-
- ClusterCommandExecutor.ClusterCommandCallback<T,S> - Interface in org.springframework.data.redis.connection
-
Callback interface for Redis 'low level' code using the cluster client directly.
- ClusterCommandExecutor.MultiKeyClusterCommandCallback<T,S> - Interface in org.springframework.data.redis.connection
-
Callback interface for Redis 'low level' code using the cluster client to execute multi key commands.
- ClusterCommandExecutor.MultiNodeResult<T> - Class in org.springframework.data.redis.connection
-
- ClusterCommandExecutor.NodeResult<T> - Class in org.springframework.data.redis.connection
-
- clusterCountKeysInSlot(int) - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
-
- clusterCountKeysInSlot(int) - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
-
- clusterCountKeysInSlot(int) - Method in interface org.springframework.data.redis.connection.ReactiveClusterCommands
-
Count the number of keys assigned to one slot.
- clusterCountKeysInSlot(int) - Method in interface org.springframework.data.redis.connection.RedisClusterCommands
-
Count the number of keys assigned to one slot.
- clusterDeleteSlots(RedisClusterNode, int...) - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
-
- clusterDeleteSlots(RedisClusterNode, int...) - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
-
- clusterDeleteSlots(RedisClusterNode, int...) - Method in interface org.springframework.data.redis.connection.ReactiveClusterCommands
-
- clusterDeleteSlots(RedisClusterNode, int...) - Method in interface org.springframework.data.redis.connection.RedisClusterCommands
-
- clusterDeleteSlotsInRange(RedisClusterNode, RedisClusterNode.SlotRange) - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
-
- clusterDeleteSlotsInRange(RedisClusterNode, RedisClusterNode.SlotRange) - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
-
- clusterDeleteSlotsInRange(RedisClusterNode, RedisClusterNode.SlotRange) - Method in interface org.springframework.data.redis.connection.ReactiveClusterCommands
-
- clusterDeleteSlotsInRange(RedisClusterNode, RedisClusterNode.SlotRange) - Method in interface org.springframework.data.redis.connection.RedisClusterCommands
-
- clusterForget(RedisClusterNode) - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
-
- clusterForget(RedisClusterNode) - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
-
- clusterForget(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.ReactiveClusterCommands
-
Remove given node from cluster.
- clusterForget(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.RedisClusterCommands
-
Remove given node from cluster.
- clusterGetClusterInfo() - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
-
- clusterGetClusterInfo() - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
-
- clusterGetClusterInfo() - Method in interface org.springframework.data.redis.connection.ReactiveClusterCommands
-
Get cluster information.
- clusterGetClusterInfo() - Method in interface org.springframework.data.redis.connection.RedisClusterCommands
-
Get cluster information.
- clusterGetKeysInSlot(int, Integer) - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
-
- clusterGetKeysInSlot(int, Integer) - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
-
- clusterGetKeysInSlot(int, int) - Method in interface org.springframework.data.redis.connection.ReactiveClusterCommands
-
Get keys served by slot.
- clusterGetKeysInSlot(int, Integer) - Method in interface org.springframework.data.redis.connection.RedisClusterCommands
-
Get keys served by slot.
- clusterGetMasterSlaveMap() - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
-
- clusterGetMasterSlaveMap() - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
-
- clusterGetMasterSlaveMap() - Method in interface org.springframework.data.redis.connection.ReactiveClusterCommands
-
Retrieve information about masters and their connected slaves.
- clusterGetMasterSlaveMap() - Method in interface org.springframework.data.redis.connection.RedisClusterCommands
-
Retrieve information about masters and their connected slaves.
- clusterGetNodeForKey(byte[]) - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
-
- clusterGetNodeForKey(byte[]) - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
-
- clusterGetNodeForKey(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveClusterCommands
-
- clusterGetNodeForKey(byte[]) - Method in interface org.springframework.data.redis.connection.RedisClusterCommands
-
- clusterGetNodeForSlot(int) - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
-
- clusterGetNodeForSlot(int) - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
-
- clusterGetNodeForSlot(int) - Method in interface org.springframework.data.redis.connection.ReactiveClusterCommands
-
- clusterGetNodeForSlot(int) - Method in interface org.springframework.data.redis.connection.RedisClusterCommands
-
- clusterGetNodes() - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
-
- clusterGetNodes() - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
-
- clusterGetNodes() - Method in interface org.springframework.data.redis.connection.ReactiveClusterCommands
-
Retrieve cluster node information such as id, host, port and slots.
- clusterGetNodes() - Method in interface org.springframework.data.redis.connection.RedisClusterCommands
-
Retrieve cluster node information such as id, host, port and slots.
- clusterGetSlaves(RedisClusterNode) - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
-
- clusterGetSlaves(RedisClusterNode) - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
-
- clusterGetSlaves(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.ReactiveClusterCommands
-
Retrieve information about connected slaves for given master node.
- clusterGetSlaves(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.RedisClusterCommands
-
Retrieve information about connected slaves for given master node.
- clusterGetSlotForKey(byte[]) - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
-
- clusterGetSlotForKey(byte[]) - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
-
- clusterGetSlotForKey(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveClusterCommands
-
Find the slot for a given key
.
- clusterGetSlotForKey(byte[]) - Method in interface org.springframework.data.redis.connection.RedisClusterCommands
-
Find the slot for a given key
.
- ClusterInfo - Class in org.springframework.data.redis.connection
-
ClusterInfo
gives access to cluster information such as
cluster_state
and
cluster_slots_assigned
provided by the
CLUSTER INFO
command.
- ClusterInfo(Properties) - Constructor for class org.springframework.data.redis.connection.ClusterInfo
-
- ClusterInfo.Info - Enum in org.springframework.data.redis.connection
-
- clusterMeet(RedisClusterNode) - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
-
- clusterMeet(RedisClusterNode) - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
-
- clusterMeet(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.ReactiveClusterCommands
-
Add given node to cluster.
- clusterMeet(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.RedisClusterCommands
-
Add given node to cluster.
- clusterNode(RedisNode) - Method in class org.springframework.data.redis.connection.RedisClusterConfiguration
-
- clusterNode(String, Integer) - Method in class org.springframework.data.redis.connection.RedisClusterConfiguration
-
- ClusterNodeResourceProvider - Interface in org.springframework.data.redis.connection
-
- ClusterOperations<K,V> - Interface in org.springframework.data.redis.core
-
Redis operations for cluster specific operations.
- ClusterRedirectException - Exception in org.springframework.data.redis
-
ClusterRedirectException
indicates that a requested slot is not served by the targeted server but can be
obtained on another one.
- ClusterRedirectException(int, String, int, Throwable) - Constructor for exception org.springframework.data.redis.ClusterRedirectException
-
- clusterReplicate(RedisClusterNode, RedisClusterNode) - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
-
- clusterReplicate(RedisClusterNode, RedisClusterNode) - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
-
- clusterReplicate(RedisClusterNode, RedisClusterNode) - Method in interface org.springframework.data.redis.connection.ReactiveClusterCommands
-
Assign a slave to given master.
- clusterReplicate(RedisClusterNode, RedisClusterNode) - Method in interface org.springframework.data.redis.connection.RedisClusterCommands
-
Assign a slave to given master.
- clusterSetSlot(RedisClusterNode, int, RedisClusterCommands.AddSlots) - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
-
- clusterSetSlot(RedisClusterNode, int, RedisClusterCommands.AddSlots) - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
-
- clusterSetSlot(RedisClusterNode, int, ReactiveClusterCommands.AddSlots) - Method in interface org.springframework.data.redis.connection.ReactiveClusterCommands
-
- clusterSetSlot(RedisClusterNode, int, RedisClusterCommands.AddSlots) - Method in interface org.springframework.data.redis.connection.RedisClusterCommands
-
- ClusterSlotHashUtil - Class in org.springframework.data.redis.connection
-
- ClusterStateFailureException - Exception in org.springframework.data.redis
-
- ClusterStateFailureException(String) - Constructor for exception org.springframework.data.redis.ClusterStateFailureException
-
- ClusterStateFailureException(String, Throwable) - Constructor for exception org.springframework.data.redis.ClusterStateFailureException
-
- ClusterTopology - Class in org.springframework.data.redis.connection
-
- ClusterTopology(Set<RedisClusterNode>) - Constructor for class org.springframework.data.redis.connection.ClusterTopology
-
- ClusterTopologyProvider - Interface in org.springframework.data.redis.connection
-
- code() - Method in enum org.springframework.data.redis.connection.DataType
-
Returns the code associated with the current enum.
- CommandResponse(I, O) - Constructor for class org.springframework.data.redis.connection.ReactiveRedisConnection.CommandResponse
-
- commands(BitFieldSubCommands) - Method in class org.springframework.data.redis.connection.ReactiveStringCommands.BitFieldCommand
-
- commandTimeout(Duration) - Method in class org.springframework.data.redis.connection.lettuce.LettuceClientConfiguration.LettuceClientConfigurationBuilder
-
Configure a command timeout.
- commandTimeout(Duration) - Method in class org.springframework.data.redis.connection.lettuce.LettucePoolingClientConfiguration.LettucePoolingClientConfigurationBuilder
-
- compareAndSet(double, double) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicDouble
-
Atomically set the value to the given updated value if the current value ==
the expected value.
- compareAndSet(int, int) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicInteger
-
Atomically set the value to the given updated value if the current value ==
the expected value.
- compareAndSet(long, long) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicLong
-
Atomically set the value to the given updated value if the current value ==
the expected value.
- compareTo(Double) - Method in class org.springframework.data.redis.connection.DefaultTuple
-
- compareTo(Double) - Method in class org.springframework.data.redis.core.DefaultTypedTuple
-
- compareTo(ZSetOperations.TypedTuple<V>) - Method in class org.springframework.data.redis.core.DefaultTypedTuple
-
- compareTo(Version) - Method in class org.springframework.data.redis.Version
-
Deprecated.
- complete(RedisOperationChain, Sort) - Method in class org.springframework.data.redis.repository.query.RedisQueryCreator
-
- CompositeIndexResolver - Class in org.springframework.data.redis.core.convert
-
- CompositeIndexResolver(Collection<IndexResolver>) - Constructor for class org.springframework.data.redis.core.convert.CompositeIndexResolver
-
- CompositeValueTransformer(Collection<IndexValueTransformer>) - Constructor for class org.springframework.data.redis.core.index.RedisIndexDefinition.CompositeValueTransformer
-
- compute(String) - Method in interface org.springframework.data.redis.cache.CacheKeyPrefix
-
Compute the prefix for the actual key stored in Redis.
- computePrefixWith(CacheKeyPrefix) - Method in class org.springframework.data.redis.cache.RedisCacheConfiguration
-
Use the given
CacheKeyPrefix
to compute the prefix for the actual Redis key given the
cache name as function input.
- concat(byte[], byte[]) - Static method in class org.springframework.data.redis.util.ByteUtils
-
Concatenate the given byte
arrays into one, with overlapping array elements included twice.
- concatAll(byte[]...) - Static method in class org.springframework.data.redis.util.ByteUtils
-
Concatenate the given byte
arrays into one, with overlapping array elements included twice.
- ConfigurableIndexDefinitionProvider - Interface in org.springframework.data.redis.core.index
-
- configureKeyConverters(Consumer<ConverterRegistry>) - Method in class org.springframework.data.redis.cache.RedisCacheConfiguration
-
Configure the underlying conversion system used to extract the cache key.
- connect(RedisCodec<K, V>) - Method in class org.springframework.data.redis.connection.lettuce.AuthenticatingRedisClient
-
Deprecated.
- ConnectionUtils - Class in org.springframework.data.redis.connection
-
- ConnectionUtils() - Constructor for class org.springframework.data.redis.connection.ConnectionUtils
-
- connectPubSub(RedisCodec<K, V>) - Method in class org.springframework.data.redis.connection.lettuce.AuthenticatingRedisClient
-
Deprecated.
- connectTimeout(Duration) - Method in class org.springframework.data.redis.connection.jedis.JedisClientConfiguration.DefaultJedisClientConfigurationBuilder
-
- connectTimeout(Duration) - Method in interface org.springframework.data.redis.connection.jedis.JedisClientConfiguration.JedisClientConfigurationBuilder
-
Configure a connection timeout.
- consumer(String) - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.PendingRecordsCommand
-
Append given consumer.
- consumer(String) - Method in class org.springframework.data.redis.connection.RedisStreamCommands.XPendingOptions
-
Append given consumer.
- Consumer - Class in org.springframework.data.redis.connection.stream
-
Value object representing a Stream consumer within a consumer group.
- consumer(Consumer) - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.ConsumerStreamReadRequestBuilder
-
Configure a
Consumer
to consume stream messages within a consumer group.
- consumer(Consumer) - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamReadRequestBuilder
-
Configure a
Consumer
to consume stream messages within a consumer group.
- consumerCount() - Method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoGroup
-
The total number of consumers in the consumer group.
- consumerName() - Method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoConsumer
-
The consumer name.
- consumers(K, String) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
-
Obtain information about every consumer in a specific consumer group for the stream stored at the
specified key.
- consumers(K, String) - Method in interface org.springframework.data.redis.core.StreamOperations
-
Obtain information about every consumer in a specific consumer group for the stream stored at the
specified key.
- consumersIn(String) - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.XInfoCommand
-
- contains(int) - Method in class org.springframework.data.redis.connection.RedisClusterNode.SlotRange
-
- contains(RedisZSetCommands.ZAddArgs.Flag) - Method in class org.springframework.data.redis.connection.RedisZSetCommands.ZAddArgs
-
Only update elements that already exist.
- contains(Object) - Method in class org.springframework.data.redis.connection.util.ByteArraySet
-
- contains(Object, String) - Method in class org.springframework.data.redis.core.RedisKeyValueAdapter
-
- contains(Object) - Method in class org.springframework.data.redis.support.collections.DefaultRedisSet
-
- contains(Object) - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
-
- contains(Object) - Method in class org.springframework.data.redis.support.collections.RedisProperties
-
- containsAll(Collection<?>) - Method in class org.springframework.data.redis.connection.util.ByteArraySet
-
- containsAll(Collection<?>) - Method in class org.springframework.data.redis.support.collections.AbstractRedisCollection
-
- containsKey(Object) - Method in class org.springframework.data.redis.support.collections.DefaultRedisMap
-
- containsKey(Object) - Method in class org.springframework.data.redis.support.collections.RedisProperties
-
- containsValue(Object) - Method in class org.springframework.data.redis.support.collections.DefaultRedisMap
-
- containsValue(Object) - Method in class org.springframework.data.redis.support.collections.RedisProperties
-
- conversionRequired() - Method in class org.springframework.data.redis.connection.FutureResult
-
Indicate whether or not the actual result needs to be
converted
before handing over.
- convert(List<S>) - Method in class org.springframework.data.redis.connection.convert.ListConverter
-
- convert(Long) - Method in class org.springframework.data.redis.connection.convert.LongToBooleanConverter
-
- convert(Map<S, S>) - Method in class org.springframework.data.redis.connection.convert.MapConverter
-
- convert(Map<?, ?>) - Method in enum org.springframework.data.redis.connection.convert.MapToPropertiesConverter
-
- convert(Set<S>) - Method in class org.springframework.data.redis.connection.convert.SetConverter
-
- convert(String) - Method in class org.springframework.data.redis.connection.convert.StringToDataTypeConverter
-
- convert(String) - Method in class org.springframework.data.redis.connection.convert.StringToPropertiesConverter
-
- convert(String[]) - Method in class org.springframework.data.redis.connection.convert.StringToRedisClientInfoConverter
-
- convert(List<Object>) - Method in class org.springframework.data.redis.connection.convert.TransactionResultConverter
-
- convert(Object) - Method in class org.springframework.data.redis.connection.FutureResult
-
Converts the given result if a converter is specified, else returns the result
- convert(Exception) - Method in class org.springframework.data.redis.connection.jedis.JedisExceptionConverter
-
- convert(Object) - Method in class org.springframework.data.redis.connection.jedis.JedisScriptReturnConverter
-
- convert(Exception) - Method in class org.springframework.data.redis.connection.lettuce.LettuceExceptionConverter
-
- convert(Object) - Method in class org.springframework.data.redis.core.index.RedisIndexDefinition.CompositeValueTransformer
-
- convert(Object) - Method in enum org.springframework.data.redis.core.index.RedisIndexDefinition.LowercaseIndexValueTransformer
-
- convert(Object) - Method in enum org.springframework.data.redis.core.index.RedisIndexDefinition.NoOpValueTransformer
-
- convertAndSend(String, V) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
-
Publishes the given message to the given channel.
- convertAndSend(String, V) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
-
- convertAndSend(String, Object) - Method in interface org.springframework.data.redis.core.RedisOperations
-
Publishes the given message to the given channel.
- convertAndSend(String, Object) - Method in class org.springframework.data.redis.core.RedisTemplate
-
- converter - Variable in class org.springframework.data.redis.connection.FutureResult
-
- Converters - Class in org.springframework.data.redis.connection.convert
-
Common type converters
- Converters() - Constructor for class org.springframework.data.redis.connection.convert.Converters
-
- ConvertingCursor<S,T> - Class in org.springframework.data.redis.core
-
- ConvertingCursor(Cursor<S>, Converter<S, T>) - Constructor for class org.springframework.data.redis.core.ConvertingCursor
-
- convertJedisAccessException(Exception) - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
-
- convertJedisAccessException(Exception) - Method in class org.springframework.data.redis.connection.jedis.JedisConnection
-
- convertJedisAccessException(JedisException) - Static method in class org.springframework.data.redis.connection.jedis.JedisUtils
-
Deprecated.
Converts the given, native Jedis exception to Spring's DAO hierarchy.
- convertJedisAccessException(RuntimeException) - Static method in class org.springframework.data.redis.connection.jedis.JedisUtils
-
Deprecated.
Converts the given, native, runtime Jedis exception to Spring's DAO hierarchy.
- convertKey(Object) - Method in class org.springframework.data.redis.cache.RedisCache
-
Convert
key
to a
String
representation used for cache key creation.
- convertLettuceAccessException(Exception) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
-
- convertQuery(SortQuery<K>, RedisSerializer<String>) - Static method in class org.springframework.data.redis.core.query.QueryUtils
-
- convertToList(Collection<String>) - Static method in class org.springframework.data.redis.connection.util.DecodeUtils
-
- convertToSet(Collection<String>) - Static method in class org.springframework.data.redis.connection.util.DecodeUtils
-
- count(Integer) - Method in class org.springframework.data.redis.connection.ReactiveListCommands.LPosCommand
-
Applies the count parameter specifying the number of matches to return.
- count(int) - Method in class org.springframework.data.redis.connection.RedisZSetCommands.Limit
-
- count(long) - Method in class org.springframework.data.redis.connection.stream.StreamReadOptions
-
Limit the number of messages returned per stream.
- count(double, double) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Count number of elements within sorted set with scores between min
and max
.
- count(K, Range<Double>) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Count number of elements within sorted set with scores between min
and max
.
- count(String) - Method in class org.springframework.data.redis.core.RedisKeyValueAdapter
-
- count(long) - Method in class org.springframework.data.redis.core.ScanOptions.ScanOptionsBuilder
-
- count(K, double, double) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Count number of elements within sorted set with scores between min
and max
.
- count(Example<S>) - Method in class org.springframework.data.redis.repository.support.QueryByExampleRedisExecutor
-
- countExistingKeys(Collection<K>) - Method in interface org.springframework.data.redis.core.RedisOperations
-
Count the number of keys
that exist.
- countExistingKeys(Collection<K>) - Method in class org.springframework.data.redis.core.RedisTemplate
-
- create() - Static method in interface org.springframework.data.redis.cache.CacheStatisticsCollector
-
- create(RedisConnectionFactory) - Static method in class org.springframework.data.redis.cache.RedisCacheManager
-
- create() - Static method in class org.springframework.data.redis.connection.BitFieldSubCommands
-
- create(S, Map<K, V>) - Static method in interface org.springframework.data.redis.connection.stream.MapRecord
-
- create(S, V) - Static method in interface org.springframework.data.redis.connection.stream.ObjectRecord
-
Creates a new
ObjectRecord
associated with the
stream
key and
value
.
- create(K, ReadOffset) - Static method in class org.springframework.data.redis.connection.stream.StreamOffset
-
- create(CreationalContext<RedisKeyValueAdapter>) - Method in class org.springframework.data.redis.repository.cdi.RedisKeyValueAdapterBean
-
- create(CreationalContext<KeyValueOperations>) - Method in class org.springframework.data.redis.repository.cdi.RedisKeyValueTemplateBean
-
- create(CreationalContext<T>, Class<T>) - Method in class org.springframework.data.redis.repository.cdi.RedisRepositoryBean
-
- create(Part, Iterator<Object>) - Method in class org.springframework.data.redis.repository.query.RedisQueryCreator
-
- create(RedisConnectionFactory) - Static method in interface org.springframework.data.redis.stream.StreamMessageListenerContainer
-
- create(RedisConnectionFactory, StreamMessageListenerContainer.StreamMessageListenerContainerOptions<K, V>) - Static method in interface org.springframework.data.redis.stream.StreamMessageListenerContainer
-
- create(ReactiveRedisConnectionFactory) - Static method in interface org.springframework.data.redis.stream.StreamReceiver
-
- create(ReactiveRedisConnectionFactory, StreamReceiver.StreamReceiverOptions<K, V>) - Static method in interface org.springframework.data.redis.stream.StreamReceiver
-
- createCacheKey(Object) - Method in class org.springframework.data.redis.cache.RedisCache
-
Customization hook for creating cache key before it gets serialized.
- createClient() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
- createCluster(RedisClusterConfiguration, GenericObjectPoolConfig<Jedis>) - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
-
- createDefaultTaskExecutor() - Method in class org.springframework.data.redis.listener.RedisMessageListenerContainer
-
Creates a default TaskExecutor.
- createFlux(ReactiveRedisCallback<T>) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
-
- createGroup(String) - Static method in class org.springframework.data.redis.connection.ReactiveStreamCommands.GroupCommand
-
- createGroup(ReadOffset, String) - Method in interface org.springframework.data.redis.core.BoundStreamOperations
-
Create a consumer group.
- createGroup(K, String) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
-
- createGroup(K, ReadOffset, String) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
-
Create a consumer group.
- createGroup(K, String) - Method in interface org.springframework.data.redis.core.StreamOperations
-
- createGroup(K, ReadOffset, String) - Method in interface org.springframework.data.redis.core.StreamOperations
-
Create a consumer group.
- createKey(String, String) - Method in class org.springframework.data.redis.core.RedisKeyValueAdapter
-
- createMono(ReactiveRedisCallback<T>) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
-
- createPersistentEntity(TypeInformation<T>) - Method in class org.springframework.data.redis.core.mapping.RedisMappingContext
-
- createPersistentProperty(Property, RedisPersistentEntity<?>, SimpleTypeHolder) - Method in class org.springframework.data.redis.core.mapping.RedisMappingContext
-
- createRedisCache(String, RedisCacheConfiguration) - Method in class org.springframework.data.redis.cache.RedisCacheManager
-
Configuration hook for creating
RedisCache
with given name and
cacheConfig
.
- createRedisConnectionProxy(ReactiveRedisConnection) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
-
- createRedisConnectionProxy(RedisConnection) - Method in class org.springframework.data.redis.core.RedisTemplate
-
- createRedisPool() - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
-
Creates JedisPool
.
- createRedisSentinelPool(RedisSentinelConfiguration) - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
-
Creates JedisSentinelPool
.
- createRepositoryFactory(KeyValueOperations, Class<? extends AbstractQueryCreator<?, ?>>, Class<? extends RepositoryQuery>) - Method in class org.springframework.data.redis.repository.support.RedisRepositoryFactoryBean
-
- createSubscription() - Method in interface org.springframework.data.redis.connection.ReactivePubSubCommands
-
Creates a subscription for this connection.
- createTopologyProvider(JedisCluster) - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
-
- Cursor<T> - Interface in org.springframework.data.redis.core
-
Cursor abstraction to scan over the keyspace or elements within a data structure using a variant of a SCAN
command.
- CustomConversions - Class in org.springframework.data.redis.core.convert
-
- CustomConversions() - Constructor for class org.springframework.data.redis.core.convert.CustomConversions
-
Deprecated.
- CustomConversions(List<?>) - Constructor for class org.springframework.data.redis.core.convert.CustomConversions
-
Deprecated.
- DataType - Enum in org.springframework.data.redis.connection
-
Enumeration of the Redis data types.
- dateToLong() - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
-
Deprecated.
- dbSize(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.DefaultedRedisClusterConnection
-
- dbSize() - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
- dbSize() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- dbSize(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.ReactiveClusterServerCommands
-
Get the total number of available keys in currently selected database.
- dbSize() - Method in interface org.springframework.data.redis.connection.ReactiveServerCommands
-
Get the total number of available keys in currently selected database.
- dbSize(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.RedisClusterServerCommands
-
- dbSize() - Method in interface org.springframework.data.redis.connection.RedisServerCommands
-
Get the total number of available keys in currently selected database.
- decode(byte[]) - Static method in class org.springframework.data.redis.connection.util.DecodeUtils
-
- decodeMap(Map<byte[], byte[]>) - Static method in class org.springframework.data.redis.connection.util.DecodeUtils
-
- decodeMultiple(byte[]...) - Static method in class org.springframework.data.redis.connection.util.DecodeUtils
-
- DecodeUtils - Class in org.springframework.data.redis.connection.util
-
Simple class containing various decoding utilities.
- DecodeUtils() - Constructor for class org.springframework.data.redis.connection.util.DecodeUtils
-
- DecoratedRedisConnection - Interface in org.springframework.data.redis.connection
-
- DecoratingStringHashMapper<T> - Class in org.springframework.data.redis.hash
-
Delegating hash mapper used for flattening objects into Strings.
- DecoratingStringHashMapper(HashMapper<T, ?, ?>) - Constructor for class org.springframework.data.redis.hash.DecoratingStringHashMapper
-
- decr(byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
- decr(byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- decr(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- decr(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveNumberCommands
-
Decrement value of key by 1.
- decr(Publisher<ReactiveRedisConnection.KeyCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveNumberCommands
-
Decrement value of key by 1.
- decr(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveNumberCommands.DecrByCommand
-
- decr(byte[]) - Method in interface org.springframework.data.redis.connection.RedisStringCommands
-
Decrement an integer value stored as string value of key
by 1.
- decr(String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Decrement an integer value stored as string value of key
by 1.
- decrBy(byte[], long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
- decrBy(byte[], long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- decrBy(String, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- decrBy(ByteBuffer, T) - Method in interface org.springframework.data.redis.connection.ReactiveNumberCommands
-
Decrement value of key by value.
- decrBy(Publisher<ReactiveNumberCommands.DecrByCommand<T>>) - Method in interface org.springframework.data.redis.connection.ReactiveNumberCommands
-
Decrement value of key by value.
- decrBy(byte[], long) - Method in interface org.springframework.data.redis.connection.RedisStringCommands
-
Decrement an integer value stored as string value of key
by value
.
- decrBy(String, long) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Decrement an integer value stored as string value of key
by value
.
- decrement() - Method in interface org.springframework.data.redis.core.BoundValueOperations
-
Decrement an integer value stored as string value under the bound key by one.
- decrement(long) - Method in interface org.springframework.data.redis.core.BoundValueOperations
-
Decrement an integer value stored as string value under the bound key by delta
.
- decrement(K) - Method in interface org.springframework.data.redis.core.ReactiveValueOperations
-
Decrements the number stored at key
by one.
- decrement(K, long) - Method in interface org.springframework.data.redis.core.ReactiveValueOperations
-
Decrements the number stored at key
by delta
.
- decrement(K) - Method in interface org.springframework.data.redis.core.ValueOperations
-
Decrement an integer value stored as string value under key
by one.
- decrement(K, long) - Method in interface org.springframework.data.redis.core.ValueOperations
-
Decrement an integer value stored as string value under key
by delta
.
- decrementAndGet() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicDouble
-
Atomically decrement by one the current value.
- decrementAndGet() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicInteger
-
Atomically decrement by one the current value.
- decrementAndGet() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicLong
-
Atomically decrement by one the current value.
- DEFAULT_CHARSET - Static variable in class org.springframework.data.redis.serializer.Jackson2JsonRedisSerializer
-
- DEFAULT_RECOVERY_INTERVAL - Static variable in class org.springframework.data.redis.listener.RedisMessageListenerContainer
-
The default recovery interval: 5000 ms = 5 seconds.
- DEFAULT_SUBSCRIPTION_REGISTRATION_WAIT_TIME - Static variable in class org.springframework.data.redis.listener.RedisMessageListenerContainer
-
The default subscription wait time: 2000 ms = 2 seconds.
- DEFAULT_THREAD_NAME_PREFIX - Static variable in class org.springframework.data.redis.listener.RedisMessageListenerContainer
-
Default thread name prefix: "RedisListeningContainer-".
- DEFAULT_TYPE_HINTS - Static variable in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoObject
-
- DEFAULT_TYPE_KEY - Static variable in class org.springframework.data.redis.core.convert.DefaultRedisTypeMapper
-
- defaultCacheConfig() - Static method in class org.springframework.data.redis.cache.RedisCacheConfiguration
-
- defaultCacheConfig(ClassLoader) - Static method in class org.springframework.data.redis.cache.RedisCacheConfiguration
-
- defaultConfiguration() - Static method in interface org.springframework.data.redis.connection.jedis.JedisClientConfiguration
-
- defaultConfiguration() - Static method in interface org.springframework.data.redis.connection.lettuce.LettuceClientConfiguration
-
Creates a default
LettuceClientConfiguration
with:
SSL
no
Peer Verification
yes
Start TLS
no
Client Options
ClientOptions
with enabled
TimeoutOptions
Client Resources
none
Client name
none
Read From
none
Connect Timeout
60 Seconds
Shutdown Timeout
100 Milliseconds
Shutdown Quiet Period
100 Milliseconds
- defaultConfiguration() - Static method in interface org.springframework.data.redis.connection.lettuce.LettucePoolingClientConfiguration
-
Creates a default
LettucePoolingClientConfiguration
with
SSL
no
Peer Verification
yes
Start TLS
no
Client Options
ClientOptions
with enabled
TimeoutOptions
Client Resources
none
Client name
none
Read From
none
Connect Timeout
60 Seconds
Shutdown Timeout
100 Milliseconds
Shutdown Quiet Period
100 Milliseconds
pool config
default
GenericObjectPoolConfig
- DefaultedRedisClusterConnection - Interface in org.springframework.data.redis.connection
-
- DefaultedRedisConnection - Interface in org.springframework.data.redis.connection
-
- DefaultLettucePool - Class in org.springframework.data.redis.connection.lettuce
-
- DefaultLettucePool() - Constructor for class org.springframework.data.redis.connection.lettuce.DefaultLettucePool
-
Deprecated.
Constructs a new DefaultLettucePool
instance with default settings.
- DefaultLettucePool(String, int) - Constructor for class org.springframework.data.redis.connection.lettuce.DefaultLettucePool
-
Deprecated.
Uses the Config
and RedisClient
defaults for configuring the connection pool
- DefaultLettucePool(RedisSentinelConfiguration) - Constructor for class org.springframework.data.redis.connection.lettuce.DefaultLettucePool
-
Deprecated.
- DefaultLettucePool(String, int, GenericObjectPoolConfig) - Constructor for class org.springframework.data.redis.connection.lettuce.DefaultLettucePool
-
Deprecated.
Uses the RedisClient
defaults for configuring the connection pool
- DefaultMessage - Class in org.springframework.data.redis.connection
-
Default message implementation.
- DefaultMessage(byte[], byte[]) - Constructor for class org.springframework.data.redis.connection.DefaultMessage
-
- DefaultReactiveScriptExecutor<K> - Class in org.springframework.data.redis.core.script
-
- DefaultReactiveScriptExecutor(ReactiveRedisConnectionFactory, RedisSerializationContext<K, ?>) - Constructor for class org.springframework.data.redis.core.script.DefaultReactiveScriptExecutor
-
- DefaultRedisList<E> - Class in org.springframework.data.redis.support.collections
-
- DefaultRedisList(String, RedisOperations<String, E>) - Constructor for class org.springframework.data.redis.support.collections.DefaultRedisList
-
- DefaultRedisList(BoundListOperations<String, E>) - Constructor for class org.springframework.data.redis.support.collections.DefaultRedisList
-
- DefaultRedisList(BoundListOperations<String, E>, int) - Constructor for class org.springframework.data.redis.support.collections.DefaultRedisList
-
- DefaultRedisMap<K,V> - Class in org.springframework.data.redis.support.collections
-
- DefaultRedisMap(String, RedisOperations<String, ?>) - Constructor for class org.springframework.data.redis.support.collections.DefaultRedisMap
-
- DefaultRedisMap(BoundHashOperations<String, K, V>) - Constructor for class org.springframework.data.redis.support.collections.DefaultRedisMap
-
- DefaultRedisScript<T> - Class in org.springframework.data.redis.core.script
-
- DefaultRedisScript() - Constructor for class org.springframework.data.redis.core.script.DefaultRedisScript
-
- DefaultRedisScript(String) - Constructor for class org.springframework.data.redis.core.script.DefaultRedisScript
-
- DefaultRedisScript(String, Class<T>) - Constructor for class org.springframework.data.redis.core.script.DefaultRedisScript
-
- DefaultRedisSet<E> - Class in org.springframework.data.redis.support.collections
-
- DefaultRedisSet(String, RedisOperations<String, E>) - Constructor for class org.springframework.data.redis.support.collections.DefaultRedisSet
-
- DefaultRedisSet(BoundSetOperations<String, E>) - Constructor for class org.springframework.data.redis.support.collections.DefaultRedisSet
-
- DefaultRedisTypeMapper - Class in org.springframework.data.redis.core.convert
-
- DefaultRedisTypeMapper() - Constructor for class org.springframework.data.redis.core.convert.DefaultRedisTypeMapper
-
- DefaultRedisTypeMapper(String) - Constructor for class org.springframework.data.redis.core.convert.DefaultRedisTypeMapper
-
- DefaultRedisTypeMapper(String, MappingContext<? extends PersistentEntity<?, ?>, ?>) - Constructor for class org.springframework.data.redis.core.convert.DefaultRedisTypeMapper
-
- DefaultRedisTypeMapper(String, List<? extends TypeInformationMapper>) - Constructor for class org.springframework.data.redis.core.convert.DefaultRedisTypeMapper
-
- DefaultRedisZSet<E> - Class in org.springframework.data.redis.support.collections
-
- DefaultRedisZSet(String, RedisOperations<String, E>) - Constructor for class org.springframework.data.redis.support.collections.DefaultRedisZSet
-
- DefaultRedisZSet(String, RedisOperations<String, E>, double) - Constructor for class org.springframework.data.redis.support.collections.DefaultRedisZSet
-
- DefaultRedisZSet(BoundZSetOperations<String, E>) - Constructor for class org.springframework.data.redis.support.collections.DefaultRedisZSet
-
- DefaultRedisZSet(BoundZSetOperations<String, E>, double) - Constructor for class org.springframework.data.redis.support.collections.DefaultRedisZSet
-
- DefaultScriptExecutor<K> - Class in org.springframework.data.redis.core.script
-
- DefaultScriptExecutor(RedisTemplate<K, ?>) - Constructor for class org.springframework.data.redis.core.script.DefaultScriptExecutor
-
- DefaultSortParameters - Class in org.springframework.data.redis.connection
-
- DefaultSortParameters() - Constructor for class org.springframework.data.redis.connection.DefaultSortParameters
-
Constructs a new DefaultSortParameters
instance.
- DefaultSortParameters(SortParameters.Range, SortParameters.Order, Boolean) - Constructor for class org.springframework.data.redis.connection.DefaultSortParameters
-
Constructs a new DefaultSortParameters
instance.
- DefaultSortParameters(byte[], SortParameters.Range, byte[][], SortParameters.Order, Boolean) - Constructor for class org.springframework.data.redis.connection.DefaultSortParameters
-
Constructs a new DefaultSortParameters
instance.
- DefaultStringRedisConnection - Class in org.springframework.data.redis.connection
-
- DefaultStringRedisConnection(RedisConnection) - Constructor for class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
Constructs a new DefaultStringRedisConnection
instance.
- DefaultStringRedisConnection(RedisConnection, RedisSerializer<String>) - Constructor for class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
Constructs a new DefaultStringRedisConnection
instance.
- DefaultStringTuple - Class in org.springframework.data.redis.connection
-
- DefaultStringTuple(byte[], String, Double) - Constructor for class org.springframework.data.redis.connection.DefaultStringTuple
-
Constructs a new DefaultStringTuple
instance.
- DefaultStringTuple(RedisZSetCommands.Tuple, String) - Constructor for class org.springframework.data.redis.connection.DefaultStringTuple
-
Constructs a new DefaultStringTuple
instance.
- DefaultTuple - Class in org.springframework.data.redis.connection
-
- DefaultTuple(byte[], Double) - Constructor for class org.springframework.data.redis.connection.DefaultTuple
-
Constructs a new DefaultTuple
instance.
- DefaultTypedTuple<V> - Class in org.springframework.data.redis.core
-
Default implementation of TypedTuple.
- DefaultTypedTuple(V, Double) - Constructor for class org.springframework.data.redis.core.DefaultTypedTuple
-
Constructs a new DefaultTypedTuple
instance.
- del(byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
- del(byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- del(String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- del(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
-
Delete key.
- del(Publisher<ReactiveRedisConnection.KeyCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
-
Delete keys one by one.
- del(byte[]...) - Method in interface org.springframework.data.redis.connection.RedisKeyCommands
-
Delete given keys
.
- del(String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Delete given keys
.
- del(String) - Method in class org.springframework.data.redis.core.PartialUpdate
-
Remove the value reachable via given path.
- delete(Object...) - Method in interface org.springframework.data.redis.core.BoundHashOperations
-
Delete given hash keys
at the bound key.
- delete(String...) - Method in interface org.springframework.data.redis.core.BoundStreamOperations
-
Removes the specified entries from the stream.
- delete(H, Object...) - Method in interface org.springframework.data.redis.core.HashOperations
-
Delete given hash hashKeys
.
- delete(K) - Method in interface org.springframework.data.redis.core.HyperLogLogOperations
-
Removes the given key.
- delete(K) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
-
Removes the given key.
- delete(H) - Method in interface org.springframework.data.redis.core.ReactiveHashOperations
-
Removes the given key.
- delete(K) - Method in interface org.springframework.data.redis.core.ReactiveHyperLogLogOperations
-
Removes the given key.
- delete(K) - Method in interface org.springframework.data.redis.core.ReactiveListOperations
-
Removes the given key.
- delete(K...) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
-
Delete given key
.
- delete(Publisher<K>) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
-
Delete given keys
.
- delete(K...) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
-
- delete(Publisher<K>) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
-
- delete(K) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
-
Removes the given key.
- delete(K, String...) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
-
Removes the specified records from the stream.
- delete(Record<K, ?>) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
-
Removes a given
Record
from the stream.
- delete(K, RecordId...) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
-
Removes the specified records from the stream.
- delete(K) - Method in interface org.springframework.data.redis.core.ReactiveValueOperations
-
Removes the given key.
- delete(K) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Removes the given key.
- delete(Object, String) - Method in class org.springframework.data.redis.core.RedisKeyValueAdapter
-
- delete(Object, String, Class<T>) - Method in class org.springframework.data.redis.core.RedisKeyValueAdapter
-
- delete(K) - Method in interface org.springframework.data.redis.core.RedisOperations
-
Delete given key
.
- delete(Collection<K>) - Method in interface org.springframework.data.redis.core.RedisOperations
-
Delete given keys
.
- delete(K) - Method in class org.springframework.data.redis.core.RedisTemplate
-
- delete(Collection<K>) - Method in class org.springframework.data.redis.core.RedisTemplate
-
- delete(K, String...) - Method in interface org.springframework.data.redis.core.StreamOperations
-
Removes the specified records from the stream.
- delete(Record<K, ?>) - Method in interface org.springframework.data.redis.core.StreamOperations
-
Removes a given
Record
from the stream.
- delete(K, RecordId...) - Method in interface org.springframework.data.redis.core.StreamOperations
-
Removes the specified records from the stream.
- deleteAllOf(String) - Method in class org.springframework.data.redis.core.RedisKeyValueAdapter
-
- deleteConsumer(String) - Static method in class org.springframework.data.redis.connection.ReactiveStreamCommands.GroupCommand
-
- deleteConsumer(Consumer) - Static method in class org.springframework.data.redis.connection.ReactiveStreamCommands.GroupCommand
-
- deleteConsumer(Consumer) - Method in interface org.springframework.data.redis.core.BoundStreamOperations
-
Delete a consumer from a consumer group.
- deleteConsumer(K, Consumer) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
-
Delete a consumer from a consumer group.
- deleteConsumer(K, Consumer) - Method in interface org.springframework.data.redis.core.StreamOperations
-
Delete a consumer from a consumer group.
- DELIMITTER - Static variable in class org.springframework.data.redis.core.convert.MappingRedisConverter.BinaryKeyspaceIdentifier
-
- DELIMITTER - Static variable in class org.springframework.data.redis.core.convert.MappingRedisConverter.KeyspaceIdentifier
-
- desc() - Method in class org.springframework.data.redis.connection.DefaultSortParameters
-
- descendingIterator() - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
-
- deserialize(RedisSerializer<T>) - Method in interface org.springframework.data.redis.connection.stream.ByteBufferRecord
-
- deserialize(RedisSerializer<? extends K>, RedisSerializer<? extends HK>, RedisSerializer<? extends HV>) - Method in interface org.springframework.data.redis.connection.stream.ByteBufferRecord
-
Deserialize
key
with the streamSerializer, field names with the
fieldSerializer and values with the valueSerializer.
- deserialize(RedisSerializer<T>) - Method in interface org.springframework.data.redis.connection.stream.ByteRecord
-
- deserialize(RedisSerializer<? extends K>, RedisSerializer<? extends HK>, RedisSerializer<? extends HV>) - Method in interface org.springframework.data.redis.connection.stream.ByteRecord
-
Deserialize
key
with the streamSerializer, field names with the
fieldSerializer and values with the valueSerializer.
- deserialize(byte[]) - Method in class org.springframework.data.redis.serializer.GenericJackson2JsonRedisSerializer
-
- deserialize(byte[], Class<T>) - Method in class org.springframework.data.redis.serializer.GenericJackson2JsonRedisSerializer
-
- deserialize(byte[]) - Method in class org.springframework.data.redis.serializer.GenericToStringSerializer
-
- deserialize(byte[]) - Method in class org.springframework.data.redis.serializer.Jackson2JsonRedisSerializer
-
- deserialize(byte[]) - Method in class org.springframework.data.redis.serializer.JdkSerializationRedisSerializer
-
- deserialize(byte[]) - Method in class org.springframework.data.redis.serializer.OxmSerializer
-
- deserialize(byte[]) - Method in interface org.springframework.data.redis.serializer.RedisSerializer
-
Deserialize an object from the given binary data.
- deserialize(Set<byte[]>, RedisSerializer<T>) - Static method in class org.springframework.data.redis.serializer.SerializationUtils
-
- deserialize(List<byte[]>, RedisSerializer<T>) - Static method in class org.springframework.data.redis.serializer.SerializationUtils
-
- deserialize(Collection<byte[]>, RedisSerializer<T>) - Static method in class org.springframework.data.redis.serializer.SerializationUtils
-
- deserialize(Map<byte[], byte[]>, RedisSerializer<T>) - Static method in class org.springframework.data.redis.serializer.SerializationUtils
-
- deserialize(Map<byte[], byte[]>, RedisSerializer<HK>, RedisSerializer<HV>) - Static method in class org.springframework.data.redis.serializer.SerializationUtils
-
- deserialize(byte[]) - Method in class org.springframework.data.redis.serializer.StringRedisSerializer
-
- deserializeCacheValue(byte[]) - Method in class org.springframework.data.redis.cache.RedisCache
-
Deserialize the given value to the actual cache value.
- deserializeRecord(ByteBufferRecord) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
-
- deserializeRecord(ByteRecord) - Method in interface org.springframework.data.redis.core.StreamOperations
-
- deserializeResult(RedisElementReader<T>, Flux<T>) - Method in class org.springframework.data.redis.core.script.DefaultReactiveScriptExecutor
-
- deserializeResult(RedisSerializer<T>, Object) - Method in class org.springframework.data.redis.core.script.DefaultScriptExecutor
-
- deserializingGeoResultsConverter(RedisSerializer<V>) - Static method in class org.springframework.data.redis.connection.convert.Converters
-
- destroy() - Method in class org.springframework.data.redis.connection.ClusterCommandExecutor
-
- destroy() - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
-
- destroy() - Method in class org.springframework.data.redis.connection.lettuce.DefaultLettucePool
-
Deprecated.
- destroy() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
- destroy() - Method in interface org.springframework.data.redis.connection.Pool
-
Destroys the pool
- destroy() - Method in class org.springframework.data.redis.core.RedisKeyValueAdapter
-
- destroy() - Method in class org.springframework.data.redis.listener.KeyspaceEventMessageListener
-
- destroy() - Method in class org.springframework.data.redis.listener.ReactiveRedisMessageListenerContainer
-
- destroy() - Method in class org.springframework.data.redis.listener.RedisMessageListenerContainer
-
- destroy(T, CreationalContext<T>) - Method in class org.springframework.data.redis.repository.cdi.CdiBean
-
- destroy(RedisKeyValueAdapter, CreationalContext<RedisKeyValueAdapter>) - Method in class org.springframework.data.redis.repository.cdi.RedisKeyValueAdapterBean
-
- destroy(KeyValueOperations, CreationalContext<KeyValueOperations>) - Method in class org.springframework.data.redis.repository.cdi.RedisKeyValueTemplateBean
-
- destroyGroup(String) - Static method in class org.springframework.data.redis.connection.ReactiveStreamCommands.GroupCommand
-
- destroyGroup(String) - Method in interface org.springframework.data.redis.core.BoundStreamOperations
-
Destroy a consumer group.
- destroyGroup(K, String) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
-
Destroy a consumer group.
- destroyGroup(K, String) - Method in interface org.springframework.data.redis.core.StreamOperations
-
Destroy a consumer group.
- destroyLater() - Method in class org.springframework.data.redis.listener.ReactiveRedisMessageListenerContainer
-
- diff(K) - Method in interface org.springframework.data.redis.core.BoundSetOperations
-
Diff all sets for given the bound key and key
.
- diff(Collection<K>) - Method in interface org.springframework.data.redis.core.BoundSetOperations
-
Diff all sets for given the bound key and keys
.
- diff(RedisSet<?>) - Method in class org.springframework.data.redis.support.collections.DefaultRedisSet
-
- diff(Collection<? extends RedisSet<?>>) - Method in class org.springframework.data.redis.support.collections.DefaultRedisSet
-
- diff(RedisSet<?>) - Method in interface org.springframework.data.redis.support.collections.RedisSet
-
- diff(Collection<? extends RedisSet<?>>) - Method in interface org.springframework.data.redis.support.collections.RedisSet
-
- diffAndStore(K, K) - Method in interface org.springframework.data.redis.core.BoundSetOperations
-
Diff all sets for given the bound key and keys
and store result in destKey
.
- diffAndStore(Collection<K>, K) - Method in interface org.springframework.data.redis.core.BoundSetOperations
-
Diff all sets for given the bound key and keys
and store result in destKey
.
- diffAndStore(RedisSet<?>, String) - Method in class org.springframework.data.redis.support.collections.DefaultRedisSet
-
- diffAndStore(Collection<? extends RedisSet<?>>, String) - Method in class org.springframework.data.redis.support.collections.DefaultRedisSet
-
- diffAndStore(RedisSet<?>, String) - Method in interface org.springframework.data.redis.support.collections.RedisSet
-
- diffAndStore(Collection<? extends RedisSet<?>>, String) - Method in interface org.springframework.data.redis.support.collections.RedisSet
-
- difference(K, K) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
-
Diff all sets for given key
and otherKey
.
- difference(K, Collection<K>) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
-
Diff all sets for given key
and otherKeys
.
- difference(Collection<K>) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
-
Diff all sets for given keys
.
- difference(K, K) - Method in interface org.springframework.data.redis.core.SetOperations
-
Diff all sets for given key
and otherKey
.
- difference(K, Collection<K>) - Method in interface org.springframework.data.redis.core.SetOperations
-
Diff all sets for given key
and otherKeys
.
- difference(Collection<K>) - Method in interface org.springframework.data.redis.core.SetOperations
-
Diff all sets for given keys
.
- differenceAndStore(K, K, K) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
-
Diff all sets for given key
and otherKey
and store result in destKey
.
- differenceAndStore(K, Collection<K>, K) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
-
Diff all sets for given key
and otherKeys
and store result in destKey
.
- differenceAndStore(Collection<K>, K) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
-
Diff all sets for given keys
and store result in destKey
.
- differenceAndStore(K, K, K) - Method in interface org.springframework.data.redis.core.SetOperations
-
Diff all sets for given key
and otherKey
and store result in destKey
.
- differenceAndStore(K, Collection<K>, K) - Method in interface org.springframework.data.redis.core.SetOperations
-
Diff all sets for given key
and otherKeys
and store result in destKey
.
- differenceAndStore(Collection<K>, K) - Method in interface org.springframework.data.redis.core.SetOperations
-
Diff all sets for given keys
and store result in destKey
.
- DigestUtils - Class in org.springframework.data.redis.core.script
-
- DigestUtils() - Constructor for class org.springframework.data.redis.core.script.DigestUtils
-
- disableCachingNullValues() - Method in class org.springframework.data.redis.cache.RedisCacheConfiguration
-
Disable caching null values.
- disableCreateOnMissingCache() - Method in class org.springframework.data.redis.cache.RedisCacheManager.RedisCacheManagerBuilder
-
Disable in-flight
Cache
creation for unconfigured caches.
- disableKeyPrefix() - Method in class org.springframework.data.redis.cache.RedisCacheConfiguration
-
Disable using cache key prefixes.
- disablePeerVerification() - Method in class org.springframework.data.redis.connection.lettuce.LettuceClientConfiguration.LettuceSslClientConfigurationBuilder
-
Disable peer verification.
- disablePeerVerification() - Method in class org.springframework.data.redis.connection.lettuce.LettucePoolingClientConfiguration.LettucePoolingSslClientConfigurationBuilder
-
- discard() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- discard() - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
-
- discard() - Method in class org.springframework.data.redis.connection.jedis.JedisConnection
-
- discard() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
-
- discard() - Method in interface org.springframework.data.redis.connection.RedisTxCommands
-
- discard() - Method in interface org.springframework.data.redis.core.RedisOperations
-
- discard() - Method in class org.springframework.data.redis.core.RedisTemplate
-
- distance(M, M) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
-
Get the
Distance
between member1 and member2.
- distance(M, M, Metric) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
-
- distance(K, M, M) - Method in interface org.springframework.data.redis.core.GeoOperations
-
Get the
Distance
between member1 and member2.
- distance(K, M, M, Metric) - Method in interface org.springframework.data.redis.core.GeoOperations
-
- distance(K, M, M) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
-
Get the
Distance
between member1 and member2.
- distance(K, M, M, Metric) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
-
- distanceConverterForMetric(Metric) - Static method in class org.springframework.data.redis.connection.convert.Converters
-
- distinctRandomMembers(long) - Method in interface org.springframework.data.redis.core.BoundSetOperations
-
Get count
distinct random elements from set at the bound key.
- distinctRandomMembers(K, long) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
-
Get count
distinct random elements from set at key
.
- distinctRandomMembers(K, long) - Method in interface org.springframework.data.redis.core.SetOperations
-
Get count
distinct random elements from set at key
.
- doClose() - Method in class org.springframework.data.redis.connection.lettuce.LettuceSubscription
-
- doClose() - Method in class org.springframework.data.redis.connection.util.AbstractSubscription
-
Shutdown the subscription and free any resources held.
- doClose() - Method in class org.springframework.data.redis.core.ScanCursor
-
- doCreateConnectionProvider(AbstractRedisClient, RedisCodec<?, ?>) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
- doCreateLettuceClusterConnection(StatefulRedisClusterConnection<byte[], byte[]>, LettuceConnectionProvider, ClusterTopologyProvider, ClusterCommandExecutor, Duration) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
- doCreateLettuceConnection(StatefulRedisConnection<byte[], byte[]>, LettuceConnectionProvider, long, int) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
- doCreateSubscription(MessageListener, StatefulRedisPubSubConnection<byte[], byte[]>, LettuceConnectionProvider) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
-
- doGetAsyncDedicatedConnection() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
-
- doGetConnection(RedisConnectionFactory, boolean, boolean, boolean) - Static method in class org.springframework.data.redis.core.RedisConnectionUtils
-
- doHandleMessage(Message) - Method in class org.springframework.data.redis.listener.KeyExpirationEventMessageListener
-
- doHandleMessage(Message) - Method in class org.springframework.data.redis.listener.KeyspaceEventMessageListener
-
Handle the actual message
- doInCluster(T) - Method in interface org.springframework.data.redis.connection.ClusterCommandExecutor.ClusterCommandCallback
-
- doInCluster(T, byte[]) - Method in interface org.springframework.data.redis.connection.ClusterCommandExecutor.MultiKeyClusterCommandCallback
-
- doInit(Jedis) - Method in class org.springframework.data.redis.connection.jedis.JedisSentinelConnection
-
Do what ever is required to establish the connection to redis.
- doInKeyValue(KeyValueAdapter) - Method in class org.springframework.data.redis.core.RedisKeyValueTemplate.RedisKeyValueCallback
-
- doInRedis(ReactiveRedisConnection) - Method in interface org.springframework.data.redis.core.ReactiveRedisCallback
-
- doInRedis(RedisConnection) - Method in interface org.springframework.data.redis.core.RedisCallback
-
- doInRedis(RedisClusterConnection) - Method in interface org.springframework.data.redis.core.RedisClusterCallback
-
Gets called by RedisClusterTemplate
with an active Redis connection.
- doInRedis(RedisKeyValueAdapter) - Method in class org.springframework.data.redis.core.RedisKeyValueTemplate.RedisKeyValueCallback
-
- doOpen(long) - Method in class org.springframework.data.redis.core.ScanCursor
-
- doPartialUpdate(PartialUpdate<?>) - Method in class org.springframework.data.redis.core.RedisKeyValueTemplate
-
- doPsubscribe(byte[]...) - Method in class org.springframework.data.redis.connection.lettuce.LettuceSubscription
-
- doPsubscribe(byte[]...) - Method in class org.springframework.data.redis.connection.util.AbstractSubscription
-
Subscribe to the given patterns
- doPUnsubscribe(boolean, byte[]...) - Method in class org.springframework.data.redis.connection.lettuce.LettuceSubscription
-
- doPUnsubscribe(boolean, byte[]...) - Method in class org.springframework.data.redis.connection.util.AbstractSubscription
-
Pattern unsubscribe.
- doRegister(RedisMessageListenerContainer) - Method in class org.springframework.data.redis.listener.KeyExpirationEventMessageListener
-
- doRegister(RedisMessageListenerContainer) - Method in class org.springframework.data.redis.listener.KeyspaceEventMessageListener
-
Register instance within the container.
- doScan(long, ScanOptions) - Method in class org.springframework.data.redis.core.KeyBoundCursor
-
- doScan(byte[], long, ScanOptions) - Method in class org.springframework.data.redis.core.KeyBoundCursor
-
- doScan(long, ScanOptions) - Method in class org.springframework.data.redis.core.ScanCursor
-
Performs the actual scan command using the native client implementation.
- doSubscribe(byte[]...) - Method in class org.springframework.data.redis.connection.lettuce.LettuceSubscription
-
- doSubscribe(byte[]...) - Method in class org.springframework.data.redis.connection.util.AbstractSubscription
-
Subscribe to the given channels.
- doubleValue() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicDouble
-
- doubleValue() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicInteger
-
- doubleValue() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicLong
-
- doUnsubscribe(boolean, byte[]...) - Method in class org.springframework.data.redis.connection.lettuce.LettuceSubscription
-
- doUnsubscribe(boolean, byte[]...) - Method in class org.springframework.data.redis.connection.util.AbstractSubscription
-
Channel unsubscribe.
- drainTo(Collection<? super E>, int) - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
-
- drainTo(Collection<? super E>) - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
-
- dump(byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
- dump(byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- dump(byte[]) - Method in interface org.springframework.data.redis.connection.RedisKeyCommands
-
Retrieve serialized version of the value stored at key
.
- dump(K) - Method in interface org.springframework.data.redis.core.RedisOperations
-
Retrieve serialized version of the value stored at key
.
- dump(K) - Method in class org.springframework.data.redis.core.RedisTemplate
-
Executes the Redis dump command and returns the results.
- echo(byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- echo(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- echo(byte[]) - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
-
- echo(byte[]) - Method in class org.springframework.data.redis.connection.jedis.JedisConnection
-
- echo(byte[]) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
-
- echo(byte[]) - Method in interface org.springframework.data.redis.connection.RedisConnectionCommands
-
Returns message
via server roundtrip.
- echo(String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Returns message
via server roundtrip.
- element() - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
-
- elementAt(long) - Static method in class org.springframework.data.redis.connection.ReactiveListCommands.LIndexCommand
-
- elementAt(long) - Static method in class org.springframework.data.redis.connection.ReactiveListCommands.LSetCommand
-
- elements() - Method in class org.springframework.data.redis.support.collections.RedisProperties
-
- empty() - Static method in class org.springframework.data.redis.connection.RedisClusterNode.SlotRange
-
- empty() - Static method in class org.springframework.data.redis.connection.RedisZSetCommands.ZAddArgs
-
- empty() - Static method in class org.springframework.data.redis.connection.stream.StreamReadOptions
-
- EnableRedisRepositories - Annotation Type in org.springframework.data.redis.repository.configuration
-
Annotation to activate Redis repositories.
- enableStatistics() - Method in class org.springframework.data.redis.cache.RedisCacheManager.RedisCacheManagerBuilder
-
- encode(String) - Static method in class org.springframework.data.redis.connection.util.DecodeUtils
-
- encodeMap(Map<String, byte[]>) - Static method in class org.springframework.data.redis.connection.util.DecodeUtils
-
- ENCODING - Static variable in class org.springframework.data.redis.support.collections.AbstractRedisCollection
-
- encodingOf(byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
- encodingOf(byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- encodingOf(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- encodingOf(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
-
Get the type of internal representation used for storing the value at the given key
.
- encodingOf(byte[]) - Method in interface org.springframework.data.redis.connection.RedisKeyCommands
-
Get the type of internal representation used for storing the value at the given key
.
- encodingOf(String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get the type of internal representation used for storing the value at the given key
.
- entries() - Method in interface org.springframework.data.redis.core.BoundHashOperations
-
Get entire hash at the bound key.
- entries(H) - Method in interface org.springframework.data.redis.core.HashOperations
-
Get entire hash stored at key
.
- entries(H) - Method in interface org.springframework.data.redis.core.ReactiveHashOperations
-
Get entire hash stored at key
.
- entries(String) - Method in class org.springframework.data.redis.core.RedisKeyValueAdapter
-
- entryIds(String...) - Static method in interface org.springframework.data.redis.connection.StringRedisConnection
-
- entrySet() - Method in class org.springframework.data.redis.core.convert.Bucket
-
A set view of the mappings contained in this bucket.
- entrySet() - Method in class org.springframework.data.redis.support.collections.DefaultRedisMap
-
- entrySet() - Method in class org.springframework.data.redis.support.collections.RedisProperties
-
- entryTtl(Duration) - Method in class org.springframework.data.redis.cache.RedisCacheConfiguration
-
Set the ttl to apply for cache entries.
- equals(Object) - Method in class org.springframework.data.redis.connection.DefaultStringTuple
-
- equals(Object) - Method in class org.springframework.data.redis.connection.DefaultTuple
-
- equals(Object) - Method in class org.springframework.data.redis.connection.ReactiveRedisConnection.CommandResponse
-
- equals(Object) - Method in class org.springframework.data.redis.connection.ReactiveSubscription.ChannelMessage
-
- equals(Object) - Method in class org.springframework.data.redis.connection.ReactiveSubscription.PatternMessage
-
- equals(Object) - Method in class org.springframework.data.redis.connection.RedisGeoCommands.GeoLocation
-
- equals(Object) - Method in class org.springframework.data.redis.connection.RedisNode
-
- equals(Object) - Method in class org.springframework.data.redis.connection.RedisPassword
-
- equals(Object) - Method in class org.springframework.data.redis.connection.RedisStreamCommands.XAddOptions
-
- equals(Object) - Method in class org.springframework.data.redis.connection.RedisZSetCommands.Weights
-
- equals(Object) - Method in class org.springframework.data.redis.connection.RedisZSetCommands.ZAddArgs
-
- equals(Object) - Method in class org.springframework.data.redis.connection.stream.Consumer
-
- equals(Object) - Method in class org.springframework.data.redis.connection.stream.ReadOffset
-
- equals(Object) - Method in class org.springframework.data.redis.connection.stream.RecordId
-
- equals(Object) - Method in class org.springframework.data.redis.connection.stream.StreamOffset
-
- equals(Object) - Method in class org.springframework.data.redis.connection.stream.StreamReadOptions
-
- equals(Object) - Method in class org.springframework.data.redis.connection.util.ByteArrayWrapper
-
- equals(Object) - Method in class org.springframework.data.redis.core.convert.GeoIndexedPropertyValue
-
- equals(Object) - Method in class org.springframework.data.redis.core.convert.SimpleIndexedPropertyValue
-
- equals(Object) - Method in class org.springframework.data.redis.core.DefaultTypedTuple
-
- equals(Object) - Method in class org.springframework.data.redis.core.index.IndexDefinition.IndexingContext
-
- equals(Object) - Method in class org.springframework.data.redis.core.index.RedisIndexDefinition
-
- equals(Object) - Method in class org.springframework.data.redis.core.index.SpelIndexDefinition
-
- equals(Object) - Method in class org.springframework.data.redis.core.types.RedisClientInfo
-
- equals(Object) - Method in class org.springframework.data.redis.listener.ChannelTopic
-
- equals(Object) - Method in class org.springframework.data.redis.listener.PatternTopic
-
- equals(Object) - Method in class org.springframework.data.redis.repository.query.RedisOperationChain.PathAndValue
-
- equals(Object) - Method in class org.springframework.data.redis.support.collections.AbstractRedisCollection
-
- equals(Object) - Method in class org.springframework.data.redis.support.collections.DefaultRedisMap
-
- equals(Object) - Method in class org.springframework.data.redis.support.collections.RedisProperties
-
- equals(Object) - Method in class org.springframework.data.redis.Version
-
Deprecated.
- errorHandler(ErrorHandler) - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.ConsumerStreamReadRequestBuilder
-
- errorHandler(ErrorHandler) - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamMessageListenerContainerOptionsBuilder
-
- errorHandler(ErrorHandler) - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamReadRequestBuilder
-
- eval(byte[], ReturnType, int, byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
- eval(byte[], ReturnType, int, byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- eval(String, ReturnType, int, String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
NOTE: This method will not deserialize Strings returned by Lua scripts, as they may not be encoded with the same
serializer used here.
- eval(ByteBuffer, ReturnType, int, ByteBuffer...) - Method in interface org.springframework.data.redis.connection.ReactiveScriptingCommands
-
Evaluate given script
.
- eval(byte[], ReturnType, int, byte[]...) - Method in interface org.springframework.data.redis.connection.RedisScriptingCommands
-
Evaluate given script
.
- eval(String, ReturnType, int, String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Evaluate given script
.
- eval(ReactiveRedisConnection, RedisScript<T>, ReturnType, int, ByteBuffer[], RedisElementReader<T>) - Method in class org.springframework.data.redis.core.script.DefaultReactiveScriptExecutor
-
- eval(RedisConnection, RedisScript<T>, ReturnType, int, byte[][], RedisSerializer<T>) - Method in class org.springframework.data.redis.core.script.DefaultScriptExecutor
-
- evalSha(String, ReturnType, int, byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
- evalSha(byte[], ReturnType, int, byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
- evalSha(String, ReturnType, int, byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- evalSha(byte[], ReturnType, int, byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- evalSha(String, ReturnType, int, String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
NOTE: This method will not deserialize Strings returned by Lua scripts, as they may not be encoded with the same
serializer used here.
- evalSha(String, ReturnType, int, ByteBuffer...) - Method in interface org.springframework.data.redis.connection.ReactiveScriptingCommands
-
Evaluate given scriptSha
.
- evalSha(String, ReturnType, int, byte[]...) - Method in interface org.springframework.data.redis.connection.RedisScriptingCommands
-
Evaluate given scriptSha
.
- evalSha(byte[], ReturnType, int, byte[]...) - Method in interface org.springframework.data.redis.connection.RedisScriptingCommands
-
Evaluate given scriptSha
.
- evalSha(String, ReturnType, int, String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Evaluate given scriptSha
.
- evict(Object) - Method in class org.springframework.data.redis.cache.RedisCache
-
- ExampleQueryMapper - Class in org.springframework.data.redis.repository.query
-
Mapper for Query-by-Example examples to an actual query.
- ExampleQueryMapper(MappingContext<RedisPersistentEntity<?>, RedisPersistentProperty>, IndexResolver) - Constructor for class org.springframework.data.redis.repository.query.ExampleQueryMapper
-
- exceptionConverter() - Static method in class org.springframework.data.redis.connection.jedis.JedisConverters
-
- exceptionConverter() - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
-
Deprecated.
- ExceptionTranslationStrategy - Interface in org.springframework.data.redis
-
- exec() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- exec() - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
-
- exec() - Method in class org.springframework.data.redis.connection.jedis.JedisConnection
-
- exec() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
-
- exec() - Method in interface org.springframework.data.redis.connection.RedisTxCommands
-
- exec() - Method in interface org.springframework.data.redis.core.RedisOperations
-
- exec(RedisSerializer<?>) - Method in interface org.springframework.data.redis.core.RedisOperations
-
Execute a transaction, using the provided
RedisSerializer
to deserialize any results that are byte[]s or
Collections of byte[]s.
- exec() - Method in class org.springframework.data.redis.core.RedisTemplate
-
Execute a transaction, using the default
RedisSerializer
s to deserialize any results that are byte[]s or
Collections or Maps of byte[]s or Tuples.
- exec(RedisSerializer<?>) - Method in class org.springframework.data.redis.core.RedisTemplate
-
- execRaw() - Method in class org.springframework.data.redis.core.RedisTemplate
-
- execute(String, byte[], Collection<byte[]>) - Method in interface org.springframework.data.redis.connection.DefaultedRedisClusterConnection
-
- execute(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- execute(String, byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- execute(String, String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- execute(String, byte[]...) - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
-
- execute(String, byte[], Collection<byte[]>) - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
-
- execute(String, Collection<byte[]>, Collection<byte[]>) - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
-
Execute the given command for each key in keys
provided appending all args
on each invocation.
- execute(String, byte[]...) - Method in class org.springframework.data.redis.connection.jedis.JedisConnection
-
- execute(String, byte[]...) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
-
- execute(String, CommandOutput, byte[]...) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
-
'Native' or 'raw' execution of the given command along-side the given arguments.
- execute(String, byte[], Collection<byte[]>) - Method in interface org.springframework.data.redis.connection.RedisClusterConnection
-
Execute the given command for the key
provided potentially appending args.
- execute(String, byte[]...) - Method in interface org.springframework.data.redis.connection.RedisCommands
-
'Native' or 'raw' execution of the given command along-side the given arguments.
- execute(String, String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
'Native' or 'raw' execution of the given command along-side the given arguments.
- execute(String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
'Native' or 'raw' execution of the given command along-side the given arguments.
- execute(ReactiveRedisCallback<T>) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
-
Executes the given action within a Redis connection.
- execute(RedisScript<T>) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
-
- execute(RedisScript<T>, List<K>) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
-
- execute(RedisScript<T>, List<K>, List<?>) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
-
- execute(RedisScript<T>, List<K>, List<?>, RedisElementWriter<?>, RedisElementReader<T>) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
-
- execute(ReactiveRedisCallback<T>) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
-
- execute(ReactiveRedisCallback<T>, boolean) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
-
Executes the given action object within a connection that can be exposed or not.
- execute(RedisScript<T>, List<K>, List<?>) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
-
- execute(RedisScript<T>, List<K>, List<?>, RedisElementWriter<?>, RedisElementReader<T>) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
-
- execute(RedisCallback<T>) - Method in class org.springframework.data.redis.core.RedisKeyValueAdapter
-
- execute(RedisCallback<T>) - Method in interface org.springframework.data.redis.core.RedisOperations
-
Executes the given action within a Redis connection.
- execute(SessionCallback<T>) - Method in interface org.springframework.data.redis.core.RedisOperations
-
Executes a Redis session.
- execute(RedisScript<T>, List<K>, Object...) - Method in interface org.springframework.data.redis.core.RedisOperations
-
- execute(RedisScript<T>, RedisSerializer<?>, RedisSerializer<T>, List<K>, Object...) - Method in interface org.springframework.data.redis.core.RedisOperations
-
- execute(RedisCallback<T>) - Method in class org.springframework.data.redis.core.RedisTemplate
-
- execute(RedisCallback<T>, boolean) - Method in class org.springframework.data.redis.core.RedisTemplate
-
Executes the given action object within a connection, which can be exposed or not.
- execute(RedisCallback<T>, boolean, boolean) - Method in class org.springframework.data.redis.core.RedisTemplate
-
Executes the given action object within a connection that can be exposed or not.
- execute(SessionCallback<T>) - Method in class org.springframework.data.redis.core.RedisTemplate
-
- execute(RedisScript<T>, List<K>, Object...) - Method in class org.springframework.data.redis.core.RedisTemplate
-
- execute(RedisScript<T>, RedisSerializer<?>, RedisSerializer<T>, List<K>, Object...) - Method in class org.springframework.data.redis.core.RedisTemplate
-
- execute(RedisScript<T>, List<K>, List<?>) - Method in class org.springframework.data.redis.core.script.DefaultReactiveScriptExecutor
-
- execute(RedisScript<T>, List<K>, List<?>, RedisElementWriter<?>, RedisElementReader<T>) - Method in class org.springframework.data.redis.core.script.DefaultReactiveScriptExecutor
-
- execute(RedisScript<T>, List<K>, Object...) - Method in class org.springframework.data.redis.core.script.DefaultScriptExecutor
-
- execute(RedisScript<T>, RedisSerializer<?>, RedisSerializer<T>, List<K>, Object...) - Method in class org.springframework.data.redis.core.script.DefaultScriptExecutor
-
- execute(RedisScript<T>) - Method in interface org.springframework.data.redis.core.script.ReactiveScriptExecutor
-
- execute(RedisScript<T>, List<K>) - Method in interface org.springframework.data.redis.core.script.ReactiveScriptExecutor
-
- execute(RedisScript<T>, List<K>, List<?>) - Method in interface org.springframework.data.redis.core.script.ReactiveScriptExecutor
-
- execute(RedisScript<T>, List<K>, List<?>, RedisElementWriter<?>, RedisElementReader<T>) - Method in interface org.springframework.data.redis.core.script.ReactiveScriptExecutor
-
- execute(RedisScript<T>, List<K>, Object...) - Method in interface org.springframework.data.redis.core.script.ScriptExecutor
-
- execute(RedisScript<T>, RedisSerializer<?>, RedisSerializer<T>, List<K>, Object...) - Method in interface org.springframework.data.redis.core.script.ScriptExecutor
-
- execute(RedisOperations<K, V>) - Method in interface org.springframework.data.redis.core.SessionCallback
-
Executes all the given operations inside the same session.
- executeCommandAsyncOnNodes(ClusterCommandExecutor.ClusterCommandCallback<S, T>, Iterable<RedisClusterNode>) - Method in class org.springframework.data.redis.connection.ClusterCommandExecutor
-
- executeCommandOnAllNodes(ClusterCommandExecutor.ClusterCommandCallback<S, T>) - Method in class org.springframework.data.redis.connection.ClusterCommandExecutor
-
- executeCommandOnArbitraryNode(ClusterCommandExecutor.ClusterCommandCallback<?, T>) - Method in class org.springframework.data.redis.connection.ClusterCommandExecutor
-
- executeCommandOnSingleNode(ClusterCommandExecutor.ClusterCommandCallback<S, T>, RedisClusterNode) - Method in class org.springframework.data.redis.connection.ClusterCommandExecutor
-
- executeListener(MessageListener, Message, byte[]) - Method in class org.springframework.data.redis.listener.RedisMessageListenerContainer
-
Execute the specified listener.
- executeMultiKeyCommand(ClusterCommandExecutor.MultiKeyClusterCommandCallback<S, T>, Iterable<byte[]>) - Method in class org.springframework.data.redis.connection.ClusterCommandExecutor
-
- executePipelined(RedisCallback<?>) - Method in interface org.springframework.data.redis.core.RedisOperations
-
Executes the given action object on a pipelined connection, returning the results.
- executePipelined(RedisCallback<?>, RedisSerializer<?>) - Method in interface org.springframework.data.redis.core.RedisOperations
-
Executes the given action object on a pipelined connection, returning the results using a dedicated serializer.
- executePipelined(SessionCallback<?>) - Method in interface org.springframework.data.redis.core.RedisOperations
-
Executes the given Redis session on a pipelined connection.
- executePipelined(SessionCallback<?>, RedisSerializer<?>) - Method in interface org.springframework.data.redis.core.RedisOperations
-
Executes the given Redis session on a pipelined connection, returning the results using a dedicated serializer.
- executePipelined(SessionCallback<?>) - Method in class org.springframework.data.redis.core.RedisTemplate
-
- executePipelined(SessionCallback<?>, RedisSerializer<?>) - Method in class org.springframework.data.redis.core.RedisTemplate
-
- executePipelined(RedisCallback<?>) - Method in class org.springframework.data.redis.core.RedisTemplate
-
- executePipelined(RedisCallback<?>, RedisSerializer<?>) - Method in class org.springframework.data.redis.core.RedisTemplate
-
- executeWithStickyConnection(RedisCallback<T>) - Method in interface org.springframework.data.redis.core.RedisOperations
-
Allocates and binds a new
RedisConnection
to the actual return type of the method.
- executeWithStickyConnection(RedisCallback<T>) - Method in class org.springframework.data.redis.core.RedisTemplate
-
- executor(Executor) - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamMessageListenerContainerOptionsBuilder
-
- exists(byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
- exists(byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
- exists(byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- exists(String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- exists(byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- exists(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- exists(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
-
Determine if given key exists.
- exists(Publisher<ReactiveRedisConnection.KeyCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
-
Determine if given key exists.
- exists(byte[]) - Method in interface org.springframework.data.redis.connection.RedisKeyCommands
-
Determine if given key
exists.
- exists(byte[]...) - Method in interface org.springframework.data.redis.connection.RedisKeyCommands
-
Count how many of the given keys
exist.
- exists(String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Determine if given key
exists.
- exists(String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Count how many of the given keys
exist.
- exists(Example<S>) - Method in class org.springframework.data.redis.repository.support.QueryByExampleRedisExecutor
-
- Expiration - Class in org.springframework.data.redis.core.types
-
Expiration holds a value with its associated
TimeUnit
.
- Expiration(long, TimeUnit) - Constructor for class org.springframework.data.redis.core.types.Expiration
-
- expire(byte[], long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
- expire(byte[], long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- expire(String, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- expire(ByteBuffer, Duration) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
-
Set time to live for given key
in seconds.
- expire(Publisher<ReactiveKeyCommands.ExpireCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
-
Expire keys one by one.
- expire(byte[], long) - Method in interface org.springframework.data.redis.connection.RedisKeyCommands
-
Set time to live for given key
in seconds.
- expire(String, long) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Set time to live for given key
in seconds.
- expire(Duration) - Method in interface org.springframework.data.redis.core.BoundKeyOperations
-
Sets the key time-to-live/expiration.
- expire(long, TimeUnit) - Method in interface org.springframework.data.redis.core.BoundKeyOperations
-
Sets the key time-to-live/expiration.
- expire(K, Duration) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
-
Set time to live for given key
.
- expire(K, Duration) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
-
- expire(K, long, TimeUnit) - Method in interface org.springframework.data.redis.core.RedisOperations
-
Set time to live for given key
.
- expire(K, Duration) - Method in interface org.springframework.data.redis.core.RedisOperations
-
Set time to live for given key
.
- expire(K, long, TimeUnit) - Method in class org.springframework.data.redis.core.RedisTemplate
-
- expire(long, TimeUnit) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicDouble
-
- expire(long, TimeUnit) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicInteger
-
- expire(long, TimeUnit) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicLong
-
- expire(long, TimeUnit) - Method in class org.springframework.data.redis.support.collections.AbstractRedisCollection
-
- expire(long, TimeUnit) - Method in class org.springframework.data.redis.support.collections.DefaultRedisMap
-
- expire(long, TimeUnit) - Method in class org.springframework.data.redis.support.collections.RedisProperties
-
- expireAt(byte[], long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
- expireAt(byte[], long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- expireAt(String, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- expireAt(ByteBuffer, Instant) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
-
Set the expiration for given key
as a UNIX timestamp.
- expireAt(Publisher<ReactiveKeyCommands.ExpireAtCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
-
Set one-by-one the expiration for given key
as a UNIX timestamp.
- expireAt(byte[], long) - Method in interface org.springframework.data.redis.connection.RedisKeyCommands
-
Set the expiration for given key
as a UNIX timestamp.
- expireAt(String, long) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Set the expiration for given key
as a UNIX timestamp.
- expireAt(Date) - Method in interface org.springframework.data.redis.core.BoundKeyOperations
-
Sets the key time-to-live/expiration.
- expireAt(Instant) - Method in interface org.springframework.data.redis.core.BoundKeyOperations
-
Sets the key time-to-live/expiration.
- expireAt(K, Instant) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
-
Set the expiration for given key
as a expireAt timestamp.
- expireAt(K, Instant) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
-
- expireAt(K, Date) - Method in interface org.springframework.data.redis.core.RedisOperations
-
Set the expiration for given key
as a date timestamp.
- expireAt(K, Instant) - Method in interface org.springframework.data.redis.core.RedisOperations
-
Set the expiration for given key
as a date timestamp.
- expireAt(K, Date) - Method in class org.springframework.data.redis.core.RedisTemplate
-
- expireAt(Date) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicDouble
-
- expireAt(Date) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicInteger
-
- expireAt(Date) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicLong
-
- expireAt(Date) - Method in class org.springframework.data.redis.support.collections.AbstractRedisCollection
-
- expireAt(Date) - Method in class org.springframework.data.redis.support.collections.DefaultRedisMap
-
- expireAt(Date) - Method in class org.springframework.data.redis.support.collections.RedisProperties
-
- expiring(Expiration) - Method in class org.springframework.data.redis.connection.ReactiveStringCommands.SetCommand
-
- extract(String) - Method in class org.springframework.data.redis.core.convert.Bucket
-
Extracts a bucket containing key/value pairs with the prefix
.
- extractAllKeysFor(String) - Method in class org.springframework.data.redis.core.convert.Bucket
-
Get all the keys matching a given path.
- extractBytes(ByteBuffer) - Static method in class org.springframework.data.redis.util.ByteUtils
-
Extract/Transfer bytes from the given
ByteBuffer
into an array by duplicating the buffer and fetching its
content.
- extractMessage(Message) - Method in class org.springframework.data.redis.listener.adapter.MessageListenerAdapter
-
Extract the message body from the given Redis message.
- GenericJackson2JsonRedisSerializer - Class in org.springframework.data.redis.serializer
-
- GenericJackson2JsonRedisSerializer() - Constructor for class org.springframework.data.redis.serializer.GenericJackson2JsonRedisSerializer
-
- GenericJackson2JsonRedisSerializer(String) - Constructor for class org.springframework.data.redis.serializer.GenericJackson2JsonRedisSerializer
-
- GenericJackson2JsonRedisSerializer(ObjectMapper) - Constructor for class org.springframework.data.redis.serializer.GenericJackson2JsonRedisSerializer
-
Setting a custom-configured ObjectMapper
is one way to take further control of the JSON serialization
process.
- GenericToStringSerializer<T> - Class in org.springframework.data.redis.serializer
-
Generic String to byte[] (and back) serializer.
- GenericToStringSerializer(Class<T>) - Constructor for class org.springframework.data.redis.serializer.GenericToStringSerializer
-
- GenericToStringSerializer(Class<T>, Charset) - Constructor for class org.springframework.data.redis.serializer.GenericToStringSerializer
-
- geoAdd(byte[], Point, byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
- geoAdd(byte[], Map<byte[], Point>) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
- geoAdd(byte[], Iterable<RedisGeoCommands.GeoLocation<byte[]>>) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
- geoAdd(byte[], Point, byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- geoAdd(byte[], RedisGeoCommands.GeoLocation<byte[]>) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- geoAdd(String, Point, String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- geoAdd(String, RedisGeoCommands.GeoLocation<String>) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- geoAdd(byte[], Map<byte[], Point>) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- geoAdd(byte[], Iterable<RedisGeoCommands.GeoLocation<byte[]>>) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- geoAdd(String, Map<String, Point>) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- geoAdd(String, Iterable<RedisGeoCommands.GeoLocation<String>>) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- geoAdd(ByteBuffer, Point, ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
-
Add
Point
with given member to key.
- geoAdd(ByteBuffer, RedisGeoCommands.GeoLocation<ByteBuffer>) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
-
- geoAdd(ByteBuffer, Collection<RedisGeoCommands.GeoLocation<ByteBuffer>>) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
-
- geoAdd(Publisher<ReactiveGeoCommands.GeoAddCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
-
- geoAdd(byte[], Point, byte[]) - Method in interface org.springframework.data.redis.connection.RedisGeoCommands
-
Add
Point
with given member name to key.
- geoAdd(byte[], RedisGeoCommands.GeoLocation<byte[]>) - Method in interface org.springframework.data.redis.connection.RedisGeoCommands
-
- geoAdd(byte[], Map<byte[], Point>) - Method in interface org.springframework.data.redis.connection.RedisGeoCommands
-
- geoAdd(byte[], Iterable<RedisGeoCommands.GeoLocation<byte[]>>) - Method in interface org.springframework.data.redis.connection.RedisGeoCommands
-
- geoAdd(String, Point, String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Add
Point
with given member name to key.
- geoAdd(String, RedisGeoCommands.GeoLocation<String>) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Add GeoLocation
to key.
- geoAdd(String, Map<String, Point>) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
- geoAdd(String, Iterable<RedisGeoCommands.GeoLocation<String>>) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Add GeoLocation
s to key
- geoAdd(Point, M) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
-
- geoAdd(RedisGeoCommands.GeoLocation<M>) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
-
- geoAdd(Map<M, Point>) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
-
- geoAdd(Iterable<RedisGeoCommands.GeoLocation<M>>) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
-
- geoAdd(K, Point, M) - Method in interface org.springframework.data.redis.core.GeoOperations
-
- geoAdd(K, RedisGeoCommands.GeoLocation<M>) - Method in interface org.springframework.data.redis.core.GeoOperations
-
- geoAdd(K, Map<M, Point>) - Method in interface org.springframework.data.redis.core.GeoOperations
-
- geoAdd(K, Iterable<RedisGeoCommands.GeoLocation<M>>) - Method in interface org.springframework.data.redis.core.GeoOperations
-
- geoCommands() - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
-
- geoCommands() - Method in class org.springframework.data.redis.connection.jedis.JedisConnection
-
- geoCommands() - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
-
- geoCommands() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
-
- geoCommands() - Method in interface org.springframework.data.redis.connection.ReactiveRedisClusterConnection
-
- geoCommands() - Method in interface org.springframework.data.redis.connection.ReactiveRedisConnection
-
- geoCommands() - Method in interface org.springframework.data.redis.connection.RedisConnection
-
- geoCoordinatesToPoint(GeoCoordinates) - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
-
- geoCoordinatesToPointConverter() - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
-
Deprecated.
- geoCoordinateToPointConverter() - Static method in class org.springframework.data.redis.connection.jedis.JedisConverters
-
- geoDist(byte[], byte[], byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
- geoDist(byte[], byte[], byte[], Metric) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
- geoDist(byte[], byte[], byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- geoDist(String, String, String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- geoDist(byte[], byte[], byte[], Metric) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- geoDist(String, String, String, Metric) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- geoDist(ByteBuffer, ByteBuffer, ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
-
- geoDist(ByteBuffer, ByteBuffer, ByteBuffer, Metric) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
-
- geoDist(Publisher<ReactiveGeoCommands.GeoDistCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
-
- geoDist(byte[], byte[], byte[]) - Method in interface org.springframework.data.redis.connection.RedisGeoCommands
-
Get the
Distance
between member1 and member2.
- geoDist(byte[], byte[], byte[], Metric) - Method in interface org.springframework.data.redis.connection.RedisGeoCommands
-
- geoDist(String, String, String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get the
Distance
between member1 and member2.
- geoDist(String, String, String, Metric) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
- geoDist(M, M) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
-
- geoDist(M, M, Metric) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
-
- geoDist(K, M, M) - Method in interface org.springframework.data.redis.core.GeoOperations
-
- geoDist(K, M, M, Metric) - Method in interface org.springframework.data.redis.core.GeoOperations
-
- geoHash(byte[], byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
- geoHash(byte[], byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- geoHash(String, String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- geoHash(ByteBuffer, ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
-
Get geohash representation of the position for the one member.
- geoHash(ByteBuffer, Collection<ByteBuffer>) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
-
Get geohash representation of the position for one or more members.
- geoHash(Publisher<ReactiveGeoCommands.GeoHashCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
-
Get geohash representation of the position for one or more members.
- geoHash(byte[], byte[]...) - Method in interface org.springframework.data.redis.connection.RedisGeoCommands
-
Get Geohash representation of the position for one or more members.
- geoHash(String, String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get geohash representation of the position for one or more members.
- geoHash(M...) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
-
- geoHash(K, M...) - Method in interface org.springframework.data.redis.core.GeoOperations
-
- GeoIndexDefinition - Class in org.springframework.data.redis.core.index
-
- GeoIndexDefinition(String, String) - Constructor for class org.springframework.data.redis.core.index.GeoIndexDefinition
-
- GeoIndexDefinition(String, String, String) - Constructor for class org.springframework.data.redis.core.index.GeoIndexDefinition
-
- GeoIndexed - Annotation Type in org.springframework.data.redis.core.index
-
Mark properties value to be included in a secondary index.
- GeoIndexedPropertyValue - Class in org.springframework.data.redis.core.convert
-
IndexedData
implementation indicating storage of data within a Redis GEO structure.
- GeoIndexedPropertyValue(String, String, Point) - Constructor for class org.springframework.data.redis.core.convert.GeoIndexedPropertyValue
-
- geoIndexName(String) - Static method in class org.springframework.data.redis.core.convert.GeoIndexedPropertyValue
-
- GeoLocation(T, Point) - Constructor for class org.springframework.data.redis.connection.RedisGeoCommands.GeoLocation
-
- GeoOperations<K,M> - Interface in org.springframework.data.redis.core
-
Redis operations for geo commands.
- geoPos(byte[], byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
- geoPos(byte[], byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- geoPos(String, String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- geoPos(ByteBuffer, ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
-
Get the
Point
representation of positions for the members.
- geoPos(ByteBuffer, Collection<ByteBuffer>) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
-
Get the
Point
representation of positions for one or more members.
- geoPos(Publisher<ReactiveGeoCommands.GeoPosCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
-
Get the
Point
representation of positions for one or more members.
- geoPos(byte[], byte[]...) - Method in interface org.springframework.data.redis.connection.RedisGeoCommands
-
Get the
Point
representation of positions for one or more members.
- geoPos(String, String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get the
Point
representation of positions for one or more members.
- geoPos(M...) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
-
- geoPos(K, M...) - Method in interface org.springframework.data.redis.core.GeoOperations
-
- geoRadius(byte[], Circle) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
- geoRadius(byte[], Circle, RedisGeoCommands.GeoRadiusCommandArgs) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
- geoRadius(String, Circle) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- geoRadius(String, Circle, RedisGeoCommands.GeoRadiusCommandArgs) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- geoRadius(byte[], Circle) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- geoRadius(byte[], Circle, RedisGeoCommands.GeoRadiusCommandArgs) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- geoRadius(ByteBuffer, Circle) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
-
Get the members within the boundaries of a given
Circle
.
- geoRadius(ByteBuffer, Circle, RedisGeoCommands.GeoRadiusCommandArgs) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
-
Get the members within the boundaries of a given
Circle
applying given parameters.
- geoRadius(Publisher<ReactiveGeoCommands.GeoRadiusCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
-
Get the members within the boundaries of a given
Circle
applying given parameters.
- geoRadius(byte[], Circle) - Method in interface org.springframework.data.redis.connection.RedisGeoCommands
-
Get the members within the boundaries of a given
Circle
.
- geoRadius(byte[], Circle, RedisGeoCommands.GeoRadiusCommandArgs) - Method in interface org.springframework.data.redis.connection.RedisGeoCommands
-
- geoRadius(String, Circle) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get the members within the boundaries of a given
Circle
.
- geoRadius(String, Circle, RedisGeoCommands.GeoRadiusCommandArgs) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get the members within the boundaries of a given
Circle
applying
GeoRadiusCommandArgs
.
- geoRadius(Circle) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
-
- geoRadius(Circle, RedisGeoCommands.GeoRadiusCommandArgs) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
-
- geoRadius(K, Circle) - Method in interface org.springframework.data.redis.core.GeoOperations
-
- geoRadius(K, Circle, RedisGeoCommands.GeoRadiusCommandArgs) - Method in interface org.springframework.data.redis.core.GeoOperations
-
- geoRadiusByMember(byte[], byte[], Distance) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
- geoRadiusByMember(byte[], byte[], Distance, RedisGeoCommands.GeoRadiusCommandArgs) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
- geoRadiusByMember(String, String, double) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- geoRadiusByMember(String, String, Distance) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- geoRadiusByMember(String, String, Distance, RedisGeoCommands.GeoRadiusCommandArgs) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- geoRadiusByMember(byte[], byte[], double) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- geoRadiusByMember(byte[], byte[], Distance) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- geoRadiusByMember(byte[], byte[], Distance, RedisGeoCommands.GeoRadiusCommandArgs) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- geoRadiusByMember(ByteBuffer, ByteBuffer, Distance) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
-
Get the members within given
Distance
from member applying given parameters.
- geoRadiusByMember(ByteBuffer, ByteBuffer, Distance, RedisGeoCommands.GeoRadiusCommandArgs) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
-
Get the members within given
Distance
from member applying given parameters.
- geoRadiusByMember(Publisher<ReactiveGeoCommands.GeoRadiusByMemberCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
-
Get the members within given
Distance
from member applying given parameters.
- geoRadiusByMember(byte[], byte[], double) - Method in interface org.springframework.data.redis.connection.RedisGeoCommands
-
Get the members within the circle defined by the members coordinates and given
radius.
- geoRadiusByMember(byte[], byte[], Distance) - Method in interface org.springframework.data.redis.connection.RedisGeoCommands
-
Get the members within the circle defined by the members coordinates and given
Distance
.
- geoRadiusByMember(byte[], byte[], Distance, RedisGeoCommands.GeoRadiusCommandArgs) - Method in interface org.springframework.data.redis.connection.RedisGeoCommands
-
- geoRadiusByMember(String, String, double) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get the members within the circle defined by the members coordinates and given
radius.
- geoRadiusByMember(String, String, Distance) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get the members within the circle defined by the members coordinates and given
Distance
.
- geoRadiusByMember(String, String, Distance, RedisGeoCommands.GeoRadiusCommandArgs) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get the members within the circle defined by the members coordinates and given
Distance
and
GeoRadiusCommandArgs
.
- geoRadiusByMember(K, M, double) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
-
- geoRadiusByMember(M, Distance) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
-
- geoRadiusByMember(M, Distance, RedisGeoCommands.GeoRadiusCommandArgs) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
-
- geoRadiusByMember(K, M, double) - Method in interface org.springframework.data.redis.core.GeoOperations
-
- geoRadiusByMember(K, M, Distance) - Method in interface org.springframework.data.redis.core.GeoOperations
-
- geoRadiusByMember(K, M, Distance, RedisGeoCommands.GeoRadiusCommandArgs) - Method in interface org.springframework.data.redis.core.GeoOperations
-
- geoRadiusResponseToGeoResultsConverter(Metric) - Static method in class org.springframework.data.redis.connection.jedis.JedisConverters
-
- geoRadiusResponseToGeoResultsConverter(Metric) - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
-
- geoRemove(byte[], byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
- geoRemove(byte[], byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- geoRemove(String, String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- geoRemove(byte[], byte[]...) - Method in interface org.springframework.data.redis.connection.RedisGeoCommands
-
Remove the members.
- geoRemove(String, String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Remove the members.
- geoRemove(M...) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
-
- geoRemove(K, M...) - Method in interface org.springframework.data.redis.core.GeoOperations
-
- get(Object, Callable<T>) - Method in class org.springframework.data.redis.cache.RedisCache
-
- get(String, byte[]) - Method in interface org.springframework.data.redis.cache.RedisCacheWriter
-
Get the binary value representation from Redis stored for the given key.
- get(BitFieldSubCommands.BitFieldType) - Method in class org.springframework.data.redis.connection.BitFieldSubCommands
-
- get(BitFieldSubCommands.BitFieldGet) - Method in class org.springframework.data.redis.connection.BitFieldSubCommands
-
- get(ClusterInfo.Info) - Method in class org.springframework.data.redis.connection.ClusterInfo
-
- get(String) - Method in class org.springframework.data.redis.connection.ClusterInfo
-
- get(byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
- get(byte[]) - Method in class org.springframework.data.redis.connection.DefaultSortParameters
-
- get(byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- get(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- get() - Method in class org.springframework.data.redis.connection.FutureResult
-
- get(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
-
Get single element stored at key.
- get(Publisher<ReactiveRedisConnection.KeyCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
-
Get elements one by one.
- get() - Method in class org.springframework.data.redis.connection.RedisPassword
-
Return the password value if present.
- get(RedisServer.INFO) - Method in class org.springframework.data.redis.connection.RedisServer
-
- get(String) - Method in class org.springframework.data.redis.connection.RedisServer
-
- get(byte[]) - Method in interface org.springframework.data.redis.connection.RedisStringCommands
-
Get the value of key
.
- get(int) - Method in class org.springframework.data.redis.connection.stream.PendingMessages
-
- get(int) - Method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoConsumers
-
- get(int) - Method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoGroups
-
- get(String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get the value of key
.
- get(Object) - Method in interface org.springframework.data.redis.core.BoundHashOperations
-
Get value for given key
from the hash at the bound key.
- get() - Method in interface org.springframework.data.redis.core.BoundValueOperations
-
Get the value of the bound key.
- get(long, long) - Method in interface org.springframework.data.redis.core.BoundValueOperations
-
Get a substring of value of the bound key between begin
and end
.
- get(String) - Method in class org.springframework.data.redis.core.convert.Bucket.BucketPropertyPath
-
Retrieve a value at key
considering top-level/nesting.
- get(String) - Method in class org.springframework.data.redis.core.convert.Bucket
-
Get value assigned with path.
- get(H, Object) - Method in interface org.springframework.data.redis.core.HashOperations
-
Get value for given hashKey
from hash at key
.
- get(String) - Method in interface org.springframework.data.redis.core.query.SortCriterion
-
- get(H, Object) - Method in interface org.springframework.data.redis.core.ReactiveHashOperations
-
Get value for given hashKey
from hash at key
.
- get(Object) - Method in interface org.springframework.data.redis.core.ReactiveValueOperations
-
Get the value of key
.
- get(K, long, long) - Method in interface org.springframework.data.redis.core.ReactiveValueOperations
-
Get a substring of value of key
between begin
and end
.
- get(Object, String) - Method in class org.springframework.data.redis.core.RedisKeyValueAdapter
-
- get(Object, String, Class<T>) - Method in class org.springframework.data.redis.core.RedisKeyValueAdapter
-
- get(RedisClientInfo.INFO) - Method in class org.springframework.data.redis.core.types.RedisClientInfo
-
- get(String) - Method in class org.springframework.data.redis.core.types.RedisClientInfo
-
- get(Object) - Method in interface org.springframework.data.redis.core.ValueOperations
-
Get the value of key
.
- get(K, long, long) - Method in interface org.springframework.data.redis.core.ValueOperations
-
Get a substring of value of key
between begin
and end
.
- get() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicDouble
-
Get the current value.
- get() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicInteger
-
Get the current value.
- get() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicLong
-
Get the current value.
- get(int) - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
-
- get(Object) - Method in class org.springframework.data.redis.support.collections.DefaultRedisMap
-
- get(Object) - Method in class org.springframework.data.redis.support.collections.RedisProperties
-
- getAbbreviation() - Method in enum org.springframework.data.redis.connection.RedisGeoCommands.DistanceUnit
-
- getAction() - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.GroupCommand
-
- getActiveMasterNodes() - Method in class org.springframework.data.redis.connection.ClusterTopology
-
Get all master nodes in cluster where link-state
is connected and flags
does not contain
fail or fail?.
- getActiveNodes() - Method in class org.springframework.data.redis.connection.ClusterTopology
-
Get all nodes (master and slave) in cluster where link-state
is connected and flags
does
not contain fail or fail?.
- getActiveSubscriptions() - Method in class org.springframework.data.redis.listener.ReactiveRedisMessageListenerContainer
-
- getAddressPort() - Method in class org.springframework.data.redis.core.types.RedisClientInfo
-
Get address/port of the client.
- getAge() - Method in class org.springframework.data.redis.core.types.RedisClientInfo
-
Get total duration of the connection in seconds.
- getAggregateFunction() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZInterStoreCommand
-
- getAggregateFunction() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZUnionStoreCommand
-
- getAllOf(String) - Method in class org.springframework.data.redis.core.RedisKeyValueAdapter
-
- getAllOf(String, Class<T>) - Method in class org.springframework.data.redis.core.RedisKeyValueAdapter
-
- getAllOf(String, Class<T>, long, int) - Method in class org.springframework.data.redis.core.RedisKeyValueAdapter
-
Get all elements for given keyspace.
- getAllowCacheNullValues() - Method in class org.springframework.data.redis.cache.RedisCacheConfiguration
-
- getAndAccumulate(double, DoubleBinaryOperator) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicDouble
-
- getAndAccumulate(int, IntBinaryOperator) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicInteger
-
- getAndAccumulate(long, LongBinaryOperator) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicLong
-
- getAndAdd(double) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicDouble
-
Atomically add the given value to current value.
- getAndAdd(int) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicInteger
-
Atomically add the given value to current value.
- getAndAdd(long) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicLong
-
Atomically add the given value to current value.
- getAndDecrement() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicDouble
-
Atomically decrement by one the current value.
- getAndDecrement() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicInteger
-
Atomically decrement by one the current value.
- getAndDecrement() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicLong
-
Atomically decrement by one the current value.
- getAndIncrement() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicDouble
-
Atomically increment by one the current value.
- getAndIncrement() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicInteger
-
Atomically increment by one the current value.
- getAndIncrement() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicLong
-
Atomically increment by one the current value.
- getAndSet(V) - Method in interface org.springframework.data.redis.core.BoundValueOperations
-
Set value
of the bound key and return its old value.
- getAndSet(K, V) - Method in interface org.springframework.data.redis.core.ReactiveValueOperations
-
Set value
of key
and return its old value.
- getAndSet(K, V) - Method in interface org.springframework.data.redis.core.ValueOperations
-
Set value
of key
and return its old value.
- getAndSet(double) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicDouble
-
Set to the given value and return the old value.
- getAndSet(int) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicInteger
-
Set to the given value and return the old value.
- getAndSet(long) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicLong
-
Set to the given value and return the old value.
- getAndUpdate(DoubleUnaryOperator) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicDouble
-
- getAndUpdate(IntUnaryOperator) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicInteger
-
- getAndUpdate(LongUnaryOperator) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicLong
-
- getAnnotation() - Method in class org.springframework.data.redis.repository.configuration.RedisRepositoriesRegistrar
-
- getArgs() - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusByMemberCommand
-
- getArgs() - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusCommand
-
- getArray() - Method in class org.springframework.data.redis.connection.util.ByteArrayWrapper
-
Returns the array.
- getAsyncDedicatedConnection() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
-
- getBatchSize() - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamMessageListenerContainerOptions
-
Batch size polling using the COUNT
option during reads.
- getBatchSize() - Method in class org.springframework.data.redis.stream.StreamReceiver.StreamReceiverOptions
-
Batch size polling using the COUNT
option during reads.
- getBeanClass() - Method in class org.springframework.data.redis.repository.cdi.CdiBean
-
- getBit(byte[], long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
- getBit(byte[], long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- getBit(String, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- getBit() - Method in class org.springframework.data.redis.connection.ReactiveStringCommands.BitPosCommand
-
- getBit(ByteBuffer, long) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
-
Get the bit value at offset of value at key.
- getBit(Publisher<ReactiveStringCommands.GetBitCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
-
Get the bit value at offset of value at key.
- getBit(byte[], long) - Method in interface org.springframework.data.redis.connection.RedisStringCommands
-
Get the bit value at offset
of value at key
.
- getBit(String, long) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get the bit value at offset
of value at key
.
- getBit(K, long) - Method in interface org.springframework.data.redis.core.ReactiveValueOperations
-
« Get the bit value at offset
of value at key
.
- getBit(K, long) - Method in interface org.springframework.data.redis.core.ValueOperations
-
Get the bit value at offset
of value at key
.
- getBitOp() - Method in class org.springframework.data.redis.connection.ReactiveStringCommands.BitOpCommand
-
- getBits() - Method in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldType
-
Get the actual bits of the type.
- getBlock() - Method in class org.springframework.data.redis.connection.stream.StreamReadOptions
-
- getBody() - Method in class org.springframework.data.redis.connection.DefaultMessage
-
- getBody() - Method in interface org.springframework.data.redis.connection.Message
-
Returns the body (or the payload) of the message.
- getBody() - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.AddStreamRecord
-
- getBucket() - Method in class org.springframework.data.redis.core.convert.Bucket.BucketPropertyPath
-
- getBucket() - Method in class org.springframework.data.redis.core.convert.RedisData
-
- getBufferFreeSpace() - Method in class org.springframework.data.redis.core.types.RedisClientInfo
-
Get the free space of the query buffer.
- getBufferLength() - Method in class org.springframework.data.redis.core.types.RedisClientInfo
-
Get the query buffer length.
- getBy() - Method in interface org.springframework.data.redis.core.query.SortQuery
-
Returns the pattern of the external key used for sorting.
- getByPattern() - Method in class org.springframework.data.redis.connection.DefaultSortParameters
-
- getByPattern() - Method in interface org.springframework.data.redis.connection.SortParameters
-
Returns the pattern (if set) for sorting by external keys (BY).
- getByteBuffer(String) - Static method in class org.springframework.data.redis.util.ByteUtils
-
- getByteBuffer(String, Charset) - Static method in class org.springframework.data.redis.util.ByteUtils
-
- getBytes(ByteBuffer) - Static method in class org.springframework.data.redis.util.ByteUtils
-
Extract a byte array from
ByteBuffer
without consuming it.
- getBytesListToLongListConverter() - Static method in class org.springframework.data.redis.connection.jedis.JedisConverters
-
- getCacheConfiguration() - Method in class org.springframework.data.redis.cache.RedisCache
-
- getCacheConfigurationFor(String) - Method in class org.springframework.data.redis.cache.RedisCacheManager.RedisCacheManagerBuilder
-
- getCacheConfigurations() - Method in class org.springframework.data.redis.cache.RedisCacheManager
-
- getCacheName() - Method in interface org.springframework.data.redis.cache.CacheStatistics
-
- getCacheStatistics(String) - Method in interface org.springframework.data.redis.cache.CacheStatisticsProvider
-
Obtain snapshot of the captured statistics.
- getCancelSubscriptionOnError() - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamReadRequest
-
- getCauses() - Method in exception org.springframework.data.redis.connection.ClusterCommandExecutionFailureException
-
- getChannel() - Method in class org.springframework.data.redis.connection.DefaultMessage
-
- getChannel() - Method in interface org.springframework.data.redis.connection.Message
-
Returns the channel associated with the message.
- getChannel() - Method in class org.springframework.data.redis.connection.ReactiveSubscription.ChannelMessage
-
- getChannel() - Method in interface org.springframework.data.redis.connection.ReactiveSubscription.Message
-
Get the channel the message published to.
- getChannel() - Method in class org.springframework.data.redis.core.RedisKeyspaceEvent
-
- getChannels() - Method in interface org.springframework.data.redis.connection.ReactiveSubscription
-
Returns the (named) channels for this subscription.
- getChannels() - Method in interface org.springframework.data.redis.connection.Subscription
-
Returns the (named) channels for this subscription.
- getChannels() - Method in class org.springframework.data.redis.connection.util.AbstractSubscription
-
- getChannelSubscribtions() - Method in class org.springframework.data.redis.core.types.RedisClientInfo
-
Get number of channel subscriptions.
- getClient() - Method in class org.springframework.data.redis.connection.lettuce.DefaultLettucePool
-
Deprecated.
- getClient() - Method in interface org.springframework.data.redis.connection.lettuce.LettucePool
-
Deprecated.
- getClientConfiguration() - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
-
- getClientConfiguration() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
- getClientList(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.DefaultedRedisClusterConnection
-
- getClientList() - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
- getClientList() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- getClientList(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.ReactiveClusterServerCommands
-
Request information and statistics about connected clients.
- getClientList() - Method in interface org.springframework.data.redis.connection.ReactiveServerCommands
-
Request information and statistics about connected clients.
- getClientList(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.RedisClusterServerCommands
-
- getClientList() - Method in interface org.springframework.data.redis.connection.RedisServerCommands
-
Request information and statistics about connected clients.
- getClientList() - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Request information and statistics about connected clients.
- getClientList() - Method in interface org.springframework.data.redis.core.RedisOperations
-
Request information and statistics about connected clients.
- getClientList() - Method in class org.springframework.data.redis.core.RedisTemplate
-
- getClientName() - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
- getClientName() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- getClientName() - Method in interface org.springframework.data.redis.connection.jedis.JedisClientConfiguration
-
- getClientName() - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
-
Returns the client name.
- getClientName() - Method in interface org.springframework.data.redis.connection.lettuce.LettuceClientConfiguration
-
- getClientName() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
Returns the client name.
- getClientName() - Method in interface org.springframework.data.redis.connection.ReactiveServerCommands
-
Returns the name of the current connection.
- getClientName() - Method in interface org.springframework.data.redis.connection.RedisServerCommands
-
Returns the name of the current connection.
- getClientOptions() - Method in interface org.springframework.data.redis.connection.lettuce.LettuceClientConfiguration
-
- getClientResources() - Method in class org.springframework.data.redis.connection.lettuce.DefaultLettucePool
-
Deprecated.
Get the ClientResources
to reuse infrastructure.
- getClientResources() - Method in interface org.springframework.data.redis.connection.lettuce.LettuceClientConfiguration
-
- getClientResources() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
Get the ClientResources
to reuse infrastructure.
- getCluster() - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
-
- getClusterCommandExecutor() - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
-
- getClusterCommandExecutor() - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
-
- getClusterConfiguration() - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
-
- getClusterConfiguration() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
- getClusterConnection() - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
-
- getClusterConnection() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
- getClusterConnection() - Method in interface org.springframework.data.redis.connection.RedisConnectionFactory
-
Provides a suitable connection for interacting with Redis Cluster.
- getClusterNodes() - Method in class org.springframework.data.redis.connection.RedisClusterConfiguration
-
- getClusterNodes() - Method in interface org.springframework.data.redis.connection.RedisConfiguration.ClusterConfiguration
-
- getClusterSize() - Method in class org.springframework.data.redis.connection.ClusterInfo
-
- getCmd() - Method in class org.springframework.data.redis.core.PartialUpdate.PropertyUpdate
-
- getCommand() - Method in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldGet
-
- getCommand() - Method in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldIncrBy
-
- getCommand() - Method in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldSet
-
- getCommand() - Method in interface org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldSubCommand
-
The actual sub command
- getCommandTimeout() - Method in interface org.springframework.data.redis.connection.lettuce.LettuceClientConfiguration
-
- getConditions() - Method in interface org.springframework.data.redis.core.index.IndexDefinition
-
- getConditions() - Method in class org.springframework.data.redis.core.index.RedisIndexDefinition
-
- getConfig(RedisClusterNode, String) - Method in interface org.springframework.data.redis.connection.DefaultedRedisClusterConnection
-
- getConfig(String) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
- getConfig(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- getConfig(RedisClusterNode, String) - Method in interface org.springframework.data.redis.connection.ReactiveClusterServerCommands
-
Load configuration parameters for given pattern
from server.
- getConfig(String) - Method in interface org.springframework.data.redis.connection.ReactiveServerCommands
-
Load configuration parameters for given pattern
from server.
- getConfig(RedisClusterNode, String) - Method in interface org.springframework.data.redis.connection.RedisClusterServerCommands
-
- getConfig(String) - Method in interface org.springframework.data.redis.connection.RedisServerCommands
-
Load configuration parameters for given pattern
from server.
- getConfigEpoch() - Method in class org.springframework.data.redis.connection.RedisServer
-
- getConfiguredCaches() - Method in class org.springframework.data.redis.cache.RedisCacheManager.RedisCacheManagerBuilder
-
- getConnection() - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
-
- getConnection() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
-
- getConnection() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
- getConnection(Class<T>) - Method in interface org.springframework.data.redis.connection.lettuce.LettuceConnectionProvider
-
Request a connection given connectionType
.
- getConnection(Class<T>, RedisURI) - Method in interface org.springframework.data.redis.connection.lettuce.LettuceConnectionProvider.TargetAware
-
Request a connection given connectionType
for a specific RedisURI
.
- getConnection() - Method in interface org.springframework.data.redis.connection.RedisConnectionFactory
-
Provides a suitable connection for interacting with Redis.
- getConnection(RedisConnectionFactory) - Static method in class org.springframework.data.redis.core.RedisConnectionUtils
-
- getConnection(RedisConnectionFactory, boolean) - Static method in class org.springframework.data.redis.core.RedisConnectionUtils
-
- getConnectionAsync(Class<T>) - Method in interface org.springframework.data.redis.connection.lettuce.LettuceConnectionProvider
-
Request asynchronously a connection given connectionType
.
- getConnectionAsync(Class<T>, RedisURI) - Method in interface org.springframework.data.redis.connection.lettuce.LettuceConnectionProvider.TargetAware
-
Request asynchronously a connection given connectionType
for a specific RedisURI
.
- getConnectionFactory() - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
-
Returns the connectionFactory.
- getConnectionFactory() - Method in class org.springframework.data.redis.core.RedisAccessor
-
Returns the connectionFactory.
- getConnectionFactory() - Method in class org.springframework.data.redis.core.script.DefaultReactiveScriptExecutor
-
- getConnectionFactory() - Method in class org.springframework.data.redis.listener.RedisMessageListenerContainer
-
Returns the connectionFactory.
- getConnectTimeout() - Method in interface org.springframework.data.redis.connection.jedis.JedisClientConfiguration
-
- getConsumer() - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.ReadCommand
-
- getConsumer() - Method in class org.springframework.data.redis.connection.stream.PendingMessage
-
The
Consumer
to acknowledge the message.
- getConsumer() - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.ConsumerStreamReadRequest
-
- getConsumerCount() - Method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoConsumers
-
Total number of consumers in the consumer group.
- getConsumerName() - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.GroupCommand
-
- getConsumerName() - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.PendingRecordsCommand
-
- getConsumerName() - Method in class org.springframework.data.redis.connection.RedisStreamCommands.XPendingOptions
-
- getConsumerName() - Method in class org.springframework.data.redis.connection.stream.PendingMessage
-
The consumer name to acknowledge the message.
- getConversionService() - Method in class org.springframework.data.redis.cache.RedisCacheConfiguration
-
- getConversionService() - Method in class org.springframework.data.redis.core.convert.MappingRedisConverter
-
- getConverted(TimeUnit) - Method in class org.springframework.data.redis.core.types.Expiration
-
Get the expiration time converted into the desired targetTimeUnit
.
- getConverter() - Method in class org.springframework.data.redis.connection.FutureResult
-
- getConverter() - Method in class org.springframework.data.redis.core.RedisKeyValueAdapter
-
- getConverter() - Method in class org.springframework.data.redis.core.RedisKeyValueTemplate
-
- getConvertersToRegister() - Static method in class org.springframework.data.redis.core.convert.Jsr310Converters
-
Returns the converters to be registered.
- getConvertPipelineAndTxResults() - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
-
Specifies if pipelined results should be converted to the expected data type.
- getConvertPipelineAndTxResults() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
Specifies if pipelined results should be converted to the expected data type.
- getConvertPipelineAndTxResults() - Method in interface org.springframework.data.redis.connection.RedisConnectionFactory
-
Specifies if pipelined results should be converted to the expected data type.
- getCount() - Method in class org.springframework.data.redis.connection.ReactiveListCommands.LPosCommand
-
- getCount() - Method in class org.springframework.data.redis.connection.ReactiveListCommands.LRemCommand
-
- getCount() - Method in class org.springframework.data.redis.connection.ReactiveSetCommands.SPopCommand
-
- getCount() - Method in class org.springframework.data.redis.connection.ReactiveSetCommands.SRandMembersCommand
-
- getCount() - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.PendingRecordsCommand
-
- getCount() - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.TrimCommand
-
- getCount() - Method in class org.springframework.data.redis.connection.RedisStreamCommands.XPendingOptions
-
- getCount() - Method in class org.springframework.data.redis.connection.RedisZSetCommands.Limit
-
- getCount() - Method in class org.springframework.data.redis.connection.SortParameters.Range
-
- getCount() - Method in class org.springframework.data.redis.connection.stream.StreamReadOptions
-
- getCount() - Method in class org.springframework.data.redis.core.ScanOptions
-
- getCurrentEpoch() - Method in class org.springframework.data.redis.connection.ClusterInfo
-
- getCursorId() - Method in class org.springframework.data.redis.core.ConvertingCursor
-
- getCursorId() - Method in interface org.springframework.data.redis.core.Cursor
-
Get the reference cursor.
- getCursorId() - Method in class org.springframework.data.redis.core.ScanCursor
-
- getCursorId() - Method in class org.springframework.data.redis.core.ScanIteration
-
The cursor id to be used for subsequent requests.
- getDatabase() - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
-
Returns the index of the database.
- getDatabase() - Method in class org.springframework.data.redis.connection.lettuce.DefaultLettucePool
-
Deprecated.
Returns the index of the database.
- getDatabase() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
Returns the index of the database.
- getDatabase() - Method in class org.springframework.data.redis.connection.ReactiveKeyCommands.MoveCommand
-
- getDatabase() - Method in interface org.springframework.data.redis.connection.RedisConfiguration.WithDatabaseIndex
-
Get the database index to use.
- getDatabase() - Method in class org.springframework.data.redis.connection.RedisSentinelConfiguration
-
- getDatabase() - Method in class org.springframework.data.redis.connection.RedisSocketConfiguration
-
- getDatabase() - Method in class org.springframework.data.redis.connection.RedisStandaloneConfiguration
-
- getDatabase() - Method in class org.springframework.data.redis.connection.RedisStaticMasterReplicaConfiguration
-
- getDatabaseId() - Method in class org.springframework.data.redis.core.types.RedisClientInfo
-
Get current database index.
- getDatabaseOrElse(Supplier<Integer>) - Method in interface org.springframework.data.redis.connection.RedisConfiguration
-
- getDatabaseOrElse(RedisConfiguration, Supplier<Integer>) - Static method in interface org.springframework.data.redis.connection.RedisConfiguration
-
- getDataNodePassword() - Method in interface org.springframework.data.redis.connection.RedisConfiguration.SentinelConfiguration
-
Get the
RedisPassword
used when authenticating with a Redis Server.
- getDataNodeUsername() - Method in interface org.springframework.data.redis.connection.RedisConfiguration.SentinelConfiguration
-
Get the username used when authenticating with a Redis Server.
- getDefaultKeyValueTemplateBeanDefinition(RepositoryConfigurationSource) - Method in class org.springframework.data.redis.repository.configuration.RedisRepositoryConfigurationExtension
-
- getDefaultKeyValueTemplateRef() - Method in class org.springframework.data.redis.repository.configuration.RedisRepositoryConfigurationExtension
-
- getDefaultListenerMethod() - Method in class org.springframework.data.redis.listener.adapter.MessageListenerAdapter
-
Return the name of the default listener method to delegate to.
- getDefaultScore() - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
-
- getDefaultScore() - Method in interface org.springframework.data.redis.support.collections.RedisZSet
-
Returns the default score used by this set.
- getDefaultSerializer() - Method in class org.springframework.data.redis.core.RedisTemplate
-
Returns the default serializer used by this template.
- getDelegate() - Method in interface org.springframework.data.redis.connection.DecoratedRedisConnection
-
- getDelegate() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
- getDelegate() - Method in class org.springframework.data.redis.listener.adapter.MessageListenerAdapter
-
Returns the target object to delegate message listening to.
- getDeletes() - Method in interface org.springframework.data.redis.cache.CacheStatistics
-
- getDependencyInstance(Bean<S>, Type) - Method in class org.springframework.data.redis.repository.cdi.CdiBean
-
Returns an instance of the given Bean
from the container.
- getDestination() - Method in class org.springframework.data.redis.connection.ReactiveListCommands.BRPopLPushCommand
-
- getDestination() - Method in class org.springframework.data.redis.connection.ReactiveListCommands.RPopLPushCommand
-
- getDestination() - Method in class org.springframework.data.redis.connection.ReactiveSetCommands.SMoveCommand
-
- getDestinationKey() - Method in class org.springframework.data.redis.connection.ReactiveStringCommands.BitOpCommand
-
- getDirection() - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusByMemberCommand
-
- getDirection() - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusCommand
-
- getDirection() - Method in class org.springframework.data.redis.connection.ReactiveListCommands.BPopCommand
-
- getDirection() - Method in class org.springframework.data.redis.connection.ReactiveListCommands.PopCommand
-
- getDirection() - Method in class org.springframework.data.redis.connection.ReactiveListCommands.PushCommand
-
- getDirection() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRangeByLexCommand
-
- getDirection() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRangeByScoreCommand
-
- getDirection() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRangeCommand
-
- getDirection() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRankCommand
-
- getDistance() - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusByMemberCommand
-
- getDistance() - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusCommand
-
- getDistance() - Method in class org.springframework.data.redis.repository.query.RedisOperationChain.NearPath
-
- getDownAfterMilliseconds() - Method in class org.springframework.data.redis.connection.RedisServer
-
- getEagerInitialization() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
- getElapsedTimeSinceLastDelivery() - Method in class org.springframework.data.redis.connection.stream.PendingMessage
-
Get the elapsed time (with milliseconds precision) since the messages last delivery to the
consumer
.
- getElement() - Method in class org.springframework.data.redis.connection.ReactiveListCommands.LPosCommand
-
- getEntityInformation(Class<T>) - Method in class org.springframework.data.redis.repository.support.RedisRepositoryFactory
-
- getErrorHandler() - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamMessageListenerContainerOptions
-
- getErrorHandler() - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamReadRequest
-
- getEvents() - Method in class org.springframework.data.redis.core.types.RedisClientInfo
-
Get file descriptor events.
- getExecutor() - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamMessageListenerContainerOptions
-
- getExpiration() - Method in class org.springframework.data.redis.connection.ReactiveStringCommands.SetCommand
-
- getExpirationTime() - Method in class org.springframework.data.redis.core.types.Expiration
-
Get the expiration time.
- getExpirationTimeInMilliseconds() - Method in class org.springframework.data.redis.core.types.Expiration
-
- getExpirationTimeInSeconds() - Method in class org.springframework.data.redis.core.types.Expiration
-
- getExpire() - Method in interface org.springframework.data.redis.core.BoundKeyOperations
-
Returns the expiration of this key.
- getExpire(K) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
-
Get the time to live for key
.
- getExpire(K) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
-
- getExpire(K) - Method in interface org.springframework.data.redis.core.RedisOperations
-
Get the time to live for key
in seconds.
- getExpire(K, TimeUnit) - Method in interface org.springframework.data.redis.core.RedisOperations
-
Get the time to live for
key
in and convert it to the given
TimeUnit
.
- getExpire(K) - Method in class org.springframework.data.redis.core.RedisTemplate
-
- getExpire(K, TimeUnit) - Method in class org.springframework.data.redis.core.RedisTemplate
-
- getExpire() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicDouble
-
- getExpire() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicInteger
-
- getExpire() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicLong
-
- getExpire() - Method in class org.springframework.data.redis.support.collections.AbstractRedisCollection
-
- getExpire() - Method in class org.springframework.data.redis.support.collections.DefaultRedisMap
-
- getExpire() - Method in class org.springframework.data.redis.support.collections.RedisProperties
-
- getExpireAt() - Method in class org.springframework.data.redis.connection.ReactiveKeyCommands.ExpireAtCommand
-
- getExplicitTimeToLiveProperty() - Method in class org.springframework.data.redis.core.mapping.BasicRedisPersistentEntity
-
- getExplicitTimeToLiveProperty() - Method in interface org.springframework.data.redis.core.mapping.RedisPersistentEntity
-
- getExpression() - Method in class org.springframework.data.redis.core.index.SpelIndexDefinition
-
Get the raw expression.
- getExtension() - Method in class org.springframework.data.redis.repository.configuration.RedisRepositoriesRegistrar
-
- getFailoverTimeout() - Method in class org.springframework.data.redis.connection.RedisServer
-
- getFallback(Exception) - Method in class org.springframework.data.redis.FallbackExceptionTranslationStrategy
-
- getField() - Method in class org.springframework.data.redis.connection.ReactiveHashCommands.HExistsCommand
-
- getField() - Method in class org.springframework.data.redis.connection.ReactiveHashCommands.HStrLenCommand
-
- getField() - Method in class org.springframework.data.redis.connection.ReactiveNumberCommands.HIncrByCommand
-
- getFields() - Method in class org.springframework.data.redis.connection.ReactiveHashCommands.HDelCommand
-
- getFields() - Method in class org.springframework.data.redis.connection.ReactiveHashCommands.HGetCommand
-
- getFieldValueMap() - Method in class org.springframework.data.redis.connection.ReactiveHashCommands.HSetCommand
-
- getFileDescriptor() - Method in class org.springframework.data.redis.core.types.RedisClientInfo
-
Get file descriptor corresponding to the socket
- getFirst() - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
-
- getFirstEntry() - Method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoStream
-
The streams first entry.
- getFirstNonNullNotEmptyOrDefault(T) - Method in class org.springframework.data.redis.connection.ClusterCommandExecutor.MultiNodeResult
-
- getFirstValue() - Method in class org.springframework.data.redis.repository.query.RedisOperationChain.PathAndValue
-
- getFlags() - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusByMemberCommand
-
- getFlags() - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusCommand
-
- getFlags() - Method in class org.springframework.data.redis.connection.RedisClusterNode
-
- getFlags() - Method in class org.springframework.data.redis.connection.RedisGeoCommands.GeoRadiusCommandArgs
-
- getFlags() - Method in class org.springframework.data.redis.connection.RedisServer
-
- getFlags() - Method in class org.springframework.data.redis.core.types.RedisClientInfo
-
Get client flags.
- getFrom() - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoDistCommand
-
- getGeoLocations() - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoAddCommand
-
- getGetPattern() - Method in class org.springframework.data.redis.connection.DefaultSortParameters
-
- getGetPattern() - Method in interface org.springframework.data.redis.connection.SortParameters
-
Returns the pattern (if set) for retrieving external keys (GET).
- getGetPattern() - Method in interface org.springframework.data.redis.core.query.SortQuery
-
Returns the external key(s) whose values are returned by the sort.
- getGets() - Method in interface org.springframework.data.redis.cache.CacheStatistics
-
- getGroup() - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.AcknowledgeCommand
-
- getGroup() - Method in class org.springframework.data.redis.connection.stream.Consumer
-
- getGroupName() - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.GroupCommand
-
- getGroupName() - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.PendingRecordsCommand
-
- getGroupName() - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.XClaimCommand
-
- getGroupName() - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.XInfoCommand
-
- getGroupName() - Method in class org.springframework.data.redis.connection.stream.PendingMessage
-
Get the consumer group.
- getGroupName() - Method in class org.springframework.data.redis.connection.stream.PendingMessages
-
The consumer group name.
- getGroupName() - Method in class org.springframework.data.redis.connection.stream.PendingMessagesSummary
-
- getHashKeySerializationPair() - Method in interface org.springframework.data.redis.serializer.RedisSerializationContext
-
- getHashKeySerializer() - Method in interface org.springframework.data.redis.core.RedisOperations
-
- getHashKeySerializer() - Method in class org.springframework.data.redis.core.RedisTemplate
-
Returns the hashKeySerializer.
- getHashKeySerializer() - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamMessageListenerContainerOptions
-
- getHashKeySerializer() - Method in class org.springframework.data.redis.stream.StreamReceiver.StreamReceiverOptions
-
- getHashMapper(Class<V>) - Method in interface org.springframework.data.redis.core.HashMapperProvider
-
- getHashMapper(Class<V>) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
-
- getHashMapper(Class<V>) - Method in interface org.springframework.data.redis.core.StreamOperations
-
- getHashMapper() - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamMessageListenerContainerOptions
-
- getHashMapper() - Method in class org.springframework.data.redis.stream.StreamReceiver.StreamReceiverOptions
-
- getHashValueSerializationPair() - Method in interface org.springframework.data.redis.serializer.RedisSerializationContext
-
- getHashValueSerializer() - Method in interface org.springframework.data.redis.core.RedisOperations
-
- getHashValueSerializer() - Method in class org.springframework.data.redis.core.RedisTemplate
-
Returns the hashValueSerializer.
- getHashValueSerializer() - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamMessageListenerContainerOptions
-
- getHashValueSerializer() - Method in class org.springframework.data.redis.stream.StreamReceiver.StreamReceiverOptions
-
- getHits() - Method in interface org.springframework.data.redis.cache.CacheStatistics
-
- getHost() - Method in class org.springframework.data.redis.connection.RedisNode
-
- getHostName() - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
-
Returns the Redis hostname.
- getHostName() - Method in class org.springframework.data.redis.connection.lettuce.DefaultLettucePool
-
Deprecated.
Returns the current host.
- getHostName() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
Returns the current host.
- getHostName() - Method in interface org.springframework.data.redis.connection.RedisConfiguration.WithHostAndPort
-
- getHostName() - Method in class org.springframework.data.redis.connection.RedisStandaloneConfiguration
-
- getHostnameVerifier() - Method in interface org.springframework.data.redis.connection.jedis.JedisClientConfiguration
-
- getHostOrElse(RedisConfiguration, Supplier<String>) - Static method in interface org.springframework.data.redis.connection.RedisConfiguration
-
- getId() - Method in class org.springframework.data.redis.connection.RedisNode
-
- getId() - Method in class org.springframework.data.redis.connection.stream.PendingMessage
-
- getId() - Method in interface org.springframework.data.redis.connection.stream.Record
-
The id of the entry inside the stream.
- getId() - Method in class org.springframework.data.redis.core.convert.MappingRedisConverter.BinaryKeyspaceIdentifier
-
- getId() - Method in class org.springframework.data.redis.core.convert.MappingRedisConverter.KeyspaceIdentifier
-
- getId() - Method in class org.springframework.data.redis.core.convert.RedisData
-
- getId() - Method in class org.springframework.data.redis.core.PartialUpdate
-
Get the id of the element to update.
- getId() - Method in class org.springframework.data.redis.core.RedisKeyExpiredEvent
-
Get the expired objects id.
- getId() - Method in class org.springframework.data.redis.repository.cdi.CdiBean
-
- getIdAsString() - Method in class org.springframework.data.redis.connection.stream.PendingMessage
-
- getIdentifyingAnnotations() - Method in class org.springframework.data.redis.repository.configuration.RedisRepositoryConfigurationExtension
-
- getIdle() - Method in class org.springframework.data.redis.core.types.RedisClientInfo
-
Get idle time of the connection in seconds.
- getIdleTime() - Method in class org.springframework.data.redis.connection.RedisStreamCommands.XClaimOptions
-
Get the IDLE ms time.
- getIdRange() - Method in class org.springframework.data.redis.connection.stream.PendingMessagesSummary
-
Get the range between the smallest and greatest ID among the pending messages.
- getIds() - Method in class org.springframework.data.redis.connection.RedisStreamCommands.XClaimOptions
-
- getIdsAsStringArray() - Method in class org.springframework.data.redis.connection.RedisStreamCommands.XClaimOptions
-
- getIncrement() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZIncrByCommand
-
- getIndex() - Method in class org.springframework.data.redis.connection.ReactiveListCommands.LIndexCommand
-
- getIndex() - Method in class org.springframework.data.redis.connection.ReactiveListCommands.LSetCommand
-
- getIndexConfiguration() - Method in class org.springframework.data.redis.core.convert.MappingConfiguration
-
- getIndexDefinitionsFor(Serializable, String) - Method in class org.springframework.data.redis.core.index.IndexConfiguration
-
- getIndexDefinitionsFor(Serializable) - Method in class org.springframework.data.redis.core.index.IndexConfiguration
-
- getIndexDefinitionsFor(Serializable) - Method in interface org.springframework.data.redis.core.index.IndexDefinitionProvider
-
- getIndexDefinitionsFor(Serializable, String) - Method in interface org.springframework.data.redis.core.index.IndexDefinitionProvider
-
- getIndexedData() - Method in class org.springframework.data.redis.core.convert.RedisData
-
- getIndexName() - Method in class org.springframework.data.redis.core.convert.GeoIndexedPropertyValue
-
- getIndexName() - Method in interface org.springframework.data.redis.core.convert.IndexedData
-
Get the
String
representation of the index name.
- getIndexName() - Method in class org.springframework.data.redis.core.convert.RemoveIndexedData
-
- getIndexName() - Method in class org.springframework.data.redis.core.convert.SimpleIndexedPropertyValue
-
- getIndexName() - Method in interface org.springframework.data.redis.core.index.IndexDefinition
-
- getIndexName() - Method in class org.springframework.data.redis.core.index.RedisIndexDefinition
-
- getIndexResolver() - Method in class org.springframework.data.redis.core.convert.MappingRedisConverter
-
- getIndexResolver() - Method in interface org.springframework.data.redis.core.convert.RedisConverter
-
- getInfoRefresh() - Method in class org.springframework.data.redis.connection.RedisServer
-
- getInjectionPoints() - Method in class org.springframework.data.redis.repository.cdi.CdiBean
-
- getInput() - Method in class org.springframework.data.redis.connection.ReactiveRedisConnection.CommandResponse
-
- getItems() - Method in class org.springframework.data.redis.core.ScanIteration
-
Get the items returned.
- getJavaType(Class<?>) - Method in class org.springframework.data.redis.serializer.Jackson2JsonRedisSerializer
-
Returns the Jackson JavaType
for the specific class.
- getJedis() - Method in class org.springframework.data.redis.connection.jedis.JedisConnection
-
- getJedis(RedisNode) - Method in class org.springframework.data.redis.connection.jedis.JedisConnection
-
- getKey() - Method in class org.springframework.data.redis.connection.ClusterCommandExecutor.NodeResult
-
- getKey() - Method in class org.springframework.data.redis.connection.ReactiveHyperLogLogCommands.PfCountCommand
-
- getKey() - Method in class org.springframework.data.redis.connection.ReactiveListCommands.BPopCommand
-
- getKey() - Method in class org.springframework.data.redis.connection.ReactiveListCommands.PopResult
-
- getKey() - Method in interface org.springframework.data.redis.connection.ReactiveRedisConnection.Command
-
- getKey() - Method in class org.springframework.data.redis.connection.ReactiveRedisConnection.KeyCommand
-
- getKey() - Method in class org.springframework.data.redis.connection.ReactiveSetCommands.SDiffCommand
-
- getKey() - Method in class org.springframework.data.redis.connection.ReactiveSetCommands.SInterCommand
-
- getKey() - Method in class org.springframework.data.redis.connection.ReactiveSetCommands.SUnionCommand
-
- getKey() - Method in class org.springframework.data.redis.connection.ReactiveStringCommands.MSetCommand
-
- getKey() - Method in class org.springframework.data.redis.connection.stream.StreamOffset
-
- getKey() - Method in interface org.springframework.data.redis.core.BoundKeyOperations
-
Returns the key associated with this entity.
- getKey() - Method in class org.springframework.data.redis.core.KeyBoundCursor
-
- getKey() - Method in interface org.springframework.data.redis.core.query.SortQuery
-
Return the target key for sorting.
- getKey() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicDouble
-
- getKey() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicInteger
-
- getKey() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicLong
-
- getKey() - Method in class org.springframework.data.redis.support.collections.AbstractRedisCollection
-
- getKey() - Method in class org.springframework.data.redis.support.collections.DefaultRedisMap
-
- getKey() - Method in class org.springframework.data.redis.support.collections.RedisProperties
-
- getKeyPrefix() - Method in class org.springframework.data.redis.cache.RedisCacheConfiguration
-
- getKeyPrefixFor(String) - Method in class org.springframework.data.redis.cache.RedisCacheConfiguration
-
Get the computed key prefix for a given cacheName.
- getKeys() - Method in class org.springframework.data.redis.connection.ReactiveHyperLogLogCommands.PfCountCommand
-
- getKeys() - Method in class org.springframework.data.redis.connection.ReactiveListCommands.BPopCommand
-
- getKeys() - Method in class org.springframework.data.redis.connection.ReactiveSetCommands.SDiffCommand
-
- getKeys() - Method in class org.springframework.data.redis.connection.ReactiveSetCommands.SDiffStoreCommand
-
- getKeys() - Method in class org.springframework.data.redis.connection.ReactiveSetCommands.SInterCommand
-
- getKeys() - Method in class org.springframework.data.redis.connection.ReactiveSetCommands.SInterStoreCommand
-
- getKeys() - Method in class org.springframework.data.redis.connection.ReactiveSetCommands.SUnionCommand
-
- getKeys() - Method in class org.springframework.data.redis.connection.ReactiveSetCommands.SUnionStoreCommand
-
- getKeys() - Method in class org.springframework.data.redis.connection.ReactiveStringCommands.BitOpCommand
-
- getKeySerializationPair() - Method in class org.springframework.data.redis.cache.RedisCacheConfiguration
-
- getKeySerializationPair() - Method in interface org.springframework.data.redis.serializer.RedisSerializationContext
-
- getKeySerializer() - Method in interface org.springframework.data.redis.core.RedisOperations
-
- getKeySerializer() - Method in class org.springframework.data.redis.core.RedisTemplate
-
Returns the key serializer used by this template.
- getKeySerializer() - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamMessageListenerContainerOptions
-
- getKeySerializer() - Method in class org.springframework.data.redis.stream.StreamReceiver.StreamReceiverOptions
-
- getKeyServingMasterNode(byte[]) - Method in class org.springframework.data.redis.connection.ClusterTopology
-
- getKeyServingNodes(byte[]) - Method in class org.springframework.data.redis.connection.ClusterTopology
-
- getKeyspace() - Method in class org.springframework.data.redis.core.convert.GeoIndexedPropertyValue
-
- getKeyspace() - Method in interface org.springframework.data.redis.core.convert.IndexedData
-
Get the associated keyspace the index resides in.
- getKeyspace() - Method in class org.springframework.data.redis.core.convert.KeyspaceConfiguration.KeyspaceSettings
-
- getKeyspace() - Method in class org.springframework.data.redis.core.convert.MappingRedisConverter.BinaryKeyspaceIdentifier
-
- getKeyspace() - Method in class org.springframework.data.redis.core.convert.MappingRedisConverter.KeyspaceIdentifier
-
- getKeyspace() - Method in class org.springframework.data.redis.core.convert.RedisData
-
- getKeyspace() - Method in class org.springframework.data.redis.core.convert.RemoveIndexedData
-
- getKeyspace() - Method in class org.springframework.data.redis.core.convert.SimpleIndexedPropertyValue
-
- getKeyspace() - Method in interface org.springframework.data.redis.core.index.IndexDefinition
-
- getKeyspace() - Method in class org.springframework.data.redis.core.index.IndexDefinition.IndexingContext
-
- getKeyspace() - Method in class org.springframework.data.redis.core.index.RedisIndexDefinition
-
- getKeyspace() - Method in class org.springframework.data.redis.core.RedisKeyExpiredEvent
-
Gets the keyspace in which the expiration occured.
- getKeyspaceConfiguration() - Method in class org.springframework.data.redis.core.convert.MappingConfiguration
-
- getKeyspaceSettings(Class<?>) - Method in class org.springframework.data.redis.core.convert.KeyspaceConfiguration
-
- getKeyValuePairs() - Method in class org.springframework.data.redis.connection.ReactiveStringCommands.MSetCommand
-
- getKnownNodes() - Method in class org.springframework.data.redis.connection.ClusterInfo
-
- getLast() - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
-
- getLastCommand() - Method in class org.springframework.data.redis.core.types.RedisClientInfo
-
Get last command played.
- getLastEntry() - Method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoStream
-
The streams first entry.
- getLastOkPingReply() - Method in class org.springframework.data.redis.connection.RedisServer
-
- getLastPingSent() - Method in class org.springframework.data.redis.connection.RedisServer
-
- getLastReset() - Method in interface org.springframework.data.redis.cache.CacheStatistics
-
- getLimit() - Method in class org.springframework.data.redis.connection.DefaultSortParameters
-
- getLimit() - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusByMemberCommand
-
- getLimit() - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusCommand
-
- getLimit() - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.RangeCommand
-
- getLimit() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRangeByLexCommand
-
- getLimit() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRangeByScoreCommand
-
- getLimit() - Method in class org.springframework.data.redis.connection.RedisGeoCommands.GeoRadiusCommandArgs
-