Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
A
- 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
-
Base implementation for
RedisCollection
. - AbstractRedisCollection(String, RedisOperations<String, E>) - Constructor for class org.springframework.data.redis.support.collections.AbstractRedisCollection
-
Constructs a new
AbstractRedisCollection
instance. - 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
-
Atomically update the current value using the given
accumulator function
. - accumulateAndGet(int, IntBinaryOperator) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicInteger
-
Atomically update the current value using the given
accumulator function
. - accumulateAndGet(long, LongBinaryOperator) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicLong
-
Atomically update the current value using the given
accumulator function
. - acknowledge(String, String...) - Method in interface org.springframework.data.redis.core.BoundStreamOperations
-
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(String, Record<K, ?>) - Method in interface org.springframework.data.redis.core.StreamOperations
-
Acknowledge the given record 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, 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.ReactiveStreamOperations
-
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.
- add(byte[]) - Method in class org.springframework.data.redis.connection.util.ByteArraySet
- add(int, E) - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- add(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) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
-
Adds an element to the set with a default score.
- 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(Iterable<RedisGeoCommands.GeoLocation<M>>) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
-
Add
RedisGeoCommands.GeoLocation
s to key - add(Map<HK, HV>) - Method in interface org.springframework.data.redis.core.BoundStreamOperations
-
Append a record to the stream
key
. - add(Map<HK, HV>, RedisStreamCommands.XAddOptions) - Method in interface org.springframework.data.redis.core.BoundStreamOperations
-
Append a record to the stream
key
with the specified options. - add(Map<M, Point>) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
- 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 itsscore
if it already exists. - add(K, Iterable<RedisGeoCommands.GeoLocation<M>>) - Method in interface org.springframework.data.redis.core.GeoOperations
-
Add
RedisGeoCommands.GeoLocation
s to key - add(K, Iterable<RedisGeoCommands.GeoLocation<M>>) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
-
Add
RedisGeoCommands.GeoLocation
s to 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(K, Map<? extends HK, ? extends HV>) - Method in interface org.springframework.data.redis.core.StreamOperations
-
Append a record to the stream
key
. - add(K, Map<? extends HK, ? extends HV>, RedisStreamCommands.XAddOptions) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
-
Append a record to the stream
key
with the specified options. - add(K, Map<? extends HK, ? extends HV>, RedisStreamCommands.XAddOptions) - Method in interface org.springframework.data.redis.core.StreamOperations
-
Append a record to the stream
key
with the specified options. - add(K, Map<M, Point>) - Method in interface org.springframework.data.redis.core.GeoOperations
- add(K, Map<M, Point>) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
- add(K, Set<ZSetOperations.TypedTuple<V>>) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Add
tuples
to a sorted set atkey
, or update itsscore
if it already exists. - add(K, Publisher<? extends Collection<RedisGeoCommands.GeoLocation<M>>>) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
-
Add
RedisGeoCommands.GeoLocation
s to 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, Point, M) - Method in interface org.springframework.data.redis.core.GeoOperations
-
Add
Point
with given member name to 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.GeoOperations
-
Add
RedisGeoCommands.GeoLocation
to key. - add(K, RedisGeoCommands.GeoLocation<M>) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
-
Add
RedisGeoCommands.GeoLocation
to key. - add(K, V...) - Method in interface org.springframework.data.redis.core.HyperLogLogOperations
-
Adds the given values to the key.
- 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 atkey
. - add(K, V...) - Method in interface org.springframework.data.redis.core.SetOperations
-
Add given
values
to set atkey
. - add(K, V, double) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Add
value
to a sorted set atkey
, or update itsscore
if it already exists. - add(K, V, double) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Add
value
to a sorted set atkey
, or update itsscore
if it already exists. - 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
RedisGeoCommands.GeoLocation
to 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(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(MapRecord<K, ? extends HK, ? extends HV>, RedisStreamCommands.XAddOptions) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
-
Append a record, backed by a
Map
holding the field/value pairs, to the stream with the specified options. - add(MapRecord<K, ? extends HK, ? extends HV>, RedisStreamCommands.XAddOptions) - Method in interface org.springframework.data.redis.core.StreamOperations
-
Append a record, backed by a
Map
holding the field/value pairs, to the stream with the specified options. - add(Record<K, ?>) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
-
Append the record, backed by the given value, 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(Record<K, ?>, RedisStreamCommands.XAddOptions) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
-
Append the record, backed by the given value, to the stream with the specified options.
- add(Record<K, ?>, RedisStreamCommands.XAddOptions) - Method in interface org.springframework.data.redis.core.StreamOperations
-
Append the record, backed by the given value, to the stream with the specified options.
- add(ByteArrayWrapper) - Method in class org.springframework.data.redis.connection.util.ByteArraySet
- add(V...) - Method in interface org.springframework.data.redis.core.BoundSetOperations
-
Add given
values
to set at the bound 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 itsscore
if it already exists. - addAll(int, Collection<? extends E>) - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- addAll(Iterable<byte[]>) - Method in class org.springframework.data.redis.connection.util.ByteArraySet
- addAll(Collection<? extends E>) - Method in class org.springframework.data.redis.support.collections.AbstractRedisCollection
- addAll(Collection<? extends ByteArrayWrapper>) - 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 atkey
, or update their score if it already exists. - 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
-
Adds a
Converter
to extract theString
representation of a cache key if no suitableObject.toString()
method is present. - 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
- addFirst(E) - Method in interface org.springframework.data.redis.support.collections.RedisList
- addGetPattern(byte[]) - Method in class org.springframework.data.redis.connection.DefaultSortParameters
- 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 class org.springframework.data.redis.support.collections.DefaultRedisZSet
- 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.
- addIfAbsent(Set<ZSetOperations.TypedTuple<V>>) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Add
tuples
to a sorted set at the bound 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 atkey
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 atkey
if it does not already exists. - addIfAbsent(V, double) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Add
value
to a sorted set at the bound key if it 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
IndexDefinition
. - addIndexedData(Collection<IndexedData>) - Method in class org.springframework.data.redis.core.convert.RedisData
- addIndexedData(IndexedData) - Method in class org.springframework.data.redis.core.convert.RedisData
- addKeyspaceSettings(KeyspaceConfiguration.KeyspaceSettings) - Method in class org.springframework.data.redis.core.convert.KeyspaceConfiguration
-
Add
KeyspaceConfiguration.KeyspaceSettings
for type. - addLast(E) - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- addLast(E) - Method in interface org.springframework.data.redis.support.collections.RedisList
- 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 givenhostName
. - ADDRESS_PORT - Enum constant in enum class org.springframework.data.redis.core.types.RedisClientInfo.INFO
- 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
-
Add slots in
RedisClusterNode.SlotRange
to given node. - after(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveListCommands.LInsertCommand
-
Applies the after pivot.
- AFTER - Enum constant in enum class org.springframework.data.redis.connection.RedisListCommands.Position
- afterPropertiesSet() - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
- 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
- Aggregate - Enum Class in org.springframework.data.redis.connection.zset
-
Sort aggregation operations.
- aggregateUsing(Aggregate) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZAggregateCommand
-
Applies a specific
Aggregate
function. - aggregateUsing(Aggregate) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZAggregateStoreCommand
-
Applies a specific
Aggregate
function. - aggregateUsing(Aggregate) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZInterStoreCommand
-
Applies a specific
Aggregate
function. - aggregateUsing(Aggregate) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZUnionStoreCommand
-
Applies a specific
Aggregate
function. - all() - Static method in class org.springframework.data.redis.connection.ReactiveListCommands.LRemCommand
-
Creates a new
ReactiveListCommands.LRemCommand
to delete all values. - allowCreateOnMissingCache(boolean) - Method in class org.springframework.data.redis.cache.RedisCacheManager.RedisCacheManagerBuilder
-
Configure whether to allow cache creation at runtime.
- alpha() - Method in class org.springframework.data.redis.connection.DefaultSortParameters
- alphabetical(boolean) - Method in class org.springframework.data.redis.core.query.SortQueryBuilder
- 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
- AND - Enum constant in enum class org.springframework.data.redis.connection.RedisStringCommands.BitOperation
- andSaveAs(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveStringCommands.BitOpCommand
-
Applies the key to store the result at.
- ANONYMOUS - Enum constant in enum class org.springframework.data.redis.connection.lettuce.RedisCredentialsProviderFactory.AbsentRedisCredentials
- any() - Static method in interface org.springframework.data.redis.connection.RedisGeoCommands.GeoCommandArgs.GeoCommandFlag
- ANY - Enum constant in enum class org.springframework.data.redis.connection.RedisGeoCommands.GeoRadiusCommandArgs.Flag
- append(byte[], byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.
- append(byte[], byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- append(byte[], byte[]) - Method in interface org.springframework.data.redis.connection.RedisStringCommands
-
Append a
value
tokey
. - append(String) - Method in interface org.springframework.data.redis.core.BoundValueOperations
-
Append a
value
to the bound key. - append(String, String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- append(String, String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Append a
value
tokey
. - append(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveStringCommands.AppendCommand
-
Applies the value to append.
- append(ByteBuffer, ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
-
Append a value to key.
- append(K, String) - Method in interface org.springframework.data.redis.core.ReactiveValueOperations
-
Append a
value
tokey
. - append(K, String) - Method in interface org.springframework.data.redis.core.ValueOperations
-
Append a
value
tokey
. - append(Publisher<ReactiveStringCommands.AppendCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
- APPEND - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- apply(RedisURI) - Method in class org.springframework.data.redis.connection.lettuce.LettuceClientConfiguration.LettuceClientConfigurationBuilder
-
Apply SSL settings, command timeout, and client name from a
RedisURI
. - apply(Function<Double, Double>) - Method in class org.springframework.data.redis.connection.zset.Weights
- applyWeights(List<Double>) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZAggregateCommand
-
Applies the
List
of weights. - applyWeights(List<Double>) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZAggregateStoreCommand
-
Applies the
List
of weights. - applyWeights(List<Double>) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZInterStoreCommand
-
Applies the
Collection
of weights. - applyWeights(List<Double>) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZUnionStoreCommand
-
Applies the
List
of weights. - applyWeights(Weights) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZAggregateCommand
-
Applies the
Weights
. - applyWeights(Weights) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZAggregateStoreCommand
-
Applies the
Weights
. - applyWeights(Weights) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZInterStoreCommand
-
Applies the
Weights
. - applyWeights(Weights) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZUnionStoreCommand
-
Applies the
Weights
. - 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
. - approximateTrimming(boolean) - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.AddStreamRecord
-
Apply efficient trimming for capped streams using the
~
flag. - approximateTrimming(boolean) - Method in class org.springframework.data.redis.connection.RedisStreamCommands.XAddOptions
-
Apply efficient trimming for capped streams using the
~
flag. - as(Consumer) - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.ReadCommand
-
Applies a
Consumer
. - asc() - Method in class org.springframework.data.redis.connection.DefaultSortParameters
- ASC - Enum constant in enum class org.springframework.data.redis.connection.SortParameters.Order
- 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
- ASYNC - Enum constant in enum class org.springframework.data.redis.connection.RedisServerCommands.FlushOption
- at(ReadOffset) - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.GroupCommand
- at(GeoReference<ByteBuffer>) - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoSearchCommand
-
Sets the geoset key.
- at(GeoReference<ByteBuffer>) - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoSearchStoreCommand
-
Sets the geoset key.
- 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.
- AUTH - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- 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.
B
- basePackageClasses() - Element in annotation interface org.springframework.data.redis.repository.configuration.EnableRedisRepositories
-
Type-safe alternative to
EnableRedisRepositories.basePackages()
for specifying the packages to scan for annotated components. - basePackages() - Element in annotation interface org.springframework.data.redis.repository.configuration.EnableRedisRepositories
-
Base packages to scan for annotated components.
- BasicRedisPersistentEntity<T> - Class in org.springframework.data.redis.core.mapping
-
RedisPersistentEntity
implementation. - BasicRedisPersistentEntity(TypeInformation<T>, KeySpaceResolver, TimeToLiveAccessor) - Constructor for class org.springframework.data.redis.core.mapping.BasicRedisPersistentEntity
-
Creates new
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. - BatchStrategies - Class in org.springframework.data.redis.cache
- BatchStrategy - Interface in org.springframework.data.redis.cache
-
A
BatchStrategy
to be used withRedisCacheWriter
. - 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
-
Create a new
BeanUtilsHashMapper
for the giventype
. - before(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveListCommands.LInsertCommand
-
Applies the before pivot.
- BEFORE - Enum constant in enum class org.springframework.data.redis.connection.RedisListCommands.Position
- between(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoDistCommand
-
Applies the from member.
- bgReWriteAof() - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.serverCommands()
. - bgReWriteAof() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- bgReWriteAof() - Method in interface org.springframework.data.redis.connection.ReactiveServerCommands
-
Start an Append Only File rewrite process on server.
- 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.connection.DefaultedRedisClusterConnection
-
Deprecated.in favor of
RedisCommandsProvider.serverCommands()
. - bgReWriteAof(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.ReactiveClusterServerCommands
-
Start an Append Only File rewrite process on the specific server.
- bgReWriteAof(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.RedisClusterServerCommands
- bgReWriteAof(RedisClusterNode) - Method in interface org.springframework.data.redis.core.ClusterOperations
-
Start an Append Only File rewrite process on given node.
- BGREWRITEAOF - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- bgSave() - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.serverCommands()
. - bgSave() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- bgSave() - Method in interface org.springframework.data.redis.connection.ReactiveServerCommands
-
Start background saving of db on server.
- 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.connection.DefaultedRedisClusterConnection
-
Deprecated.in favor of
RedisCommandsProvider.serverCommands()
. - bgSave(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.ReactiveClusterServerCommands
-
Start background saving of db on server.
- bgSave(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.RedisClusterServerCommands
- bgSave(RedisClusterNode) - Method in interface org.springframework.data.redis.core.ClusterOperations
-
Start background saving of db on given node.
- BGSAVE - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- bindConnection(RedisConnectionFactory) - Static method in class org.springframework.data.redis.core.RedisConnectionUtils
-
Obtain a
RedisConnection
from the givenRedisConnectionFactory
and binds the connection to the current thread to be used in closure-scope, if none is already bound. - bindConnection(RedisConnectionFactory, boolean) - Static method in class org.springframework.data.redis.core.RedisConnectionUtils
-
Obtain a
RedisConnection
from the givenRedisConnectionFactory
and binds the connection to the current thread to be used in closure-scope, if none is already bound. - bit(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveStringCommands.GetBitCommand
-
Creates a new
ReactiveStringCommands.GetBitCommand
given a key. - bit(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveStringCommands.SetBitCommand
-
Creates a new
ReactiveStringCommands.SetBitCommand
given a key. - bitCount(byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.stringCommands()
}. - bitCount(byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- 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.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.stringCommands()
}. - bitCount(byte[], long, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- 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
betweenstart
andend
. - bitCount(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- 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 class org.springframework.data.redis.connection.DefaultStringRedisConnection
- 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
betweenstart
andend
. - 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) - Static method in class org.springframework.data.redis.connection.ReactiveStringCommands.BitCountCommand
-
Creates a new
ReactiveStringCommands.BitCountCommand
given a 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 - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- bitfield(String, BitFieldSubCommands) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- 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(byte[], BitFieldSubCommands) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.stringCommands()
}. - bitField(byte[], BitFieldSubCommands) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- 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(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveStringCommands.BitFieldCommand
-
Creates a new
ReactiveStringCommands.BitFieldCommand
given a key. - 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(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
. - 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
. - 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
-
The actual
BITFIELD
command representation holding severalBitFieldSubCommands.BitFieldSubCommand
s to execute. - BitFieldSubCommands.AbstractBitFieldSubCommand - Class in org.springframework.data.redis.connection
- BitFieldSubCommands.BitFieldGet - Class in org.springframework.data.redis.connection
-
The
GET
sub command used withBitFieldSubCommands
. - BitFieldSubCommands.BitFieldGetBuilder - Class in org.springframework.data.redis.connection
- BitFieldSubCommands.BitFieldIncrBy - Class in org.springframework.data.redis.connection
-
The
INCRBY
sub command used withBitFieldSubCommands
. - BitFieldSubCommands.BitFieldIncrBy.Overflow - Enum Class in org.springframework.data.redis.connection
- BitFieldSubCommands.BitFieldIncrByBuilder - Class in org.springframework.data.redis.connection
- BitFieldSubCommands.BitFieldSet - Class in org.springframework.data.redis.connection
-
The
SET
sub command used withBitFieldSubCommands
. - BitFieldSubCommands.BitFieldSetBuilder - Class in org.springframework.data.redis.connection
- BitFieldSubCommands.BitFieldSubCommand - Interface in org.springframework.data.redis.connection
-
Sub command to be used as part of
BitFieldSubCommands
. - BitFieldSubCommands.BitFieldType - Class in org.springframework.data.redis.connection
-
The actual Redis bitfield type representation for signed and unsigned integers used with
BitFieldSubCommands.BitFieldSubCommand
. - BitFieldSubCommands.Offset - Class in org.springframework.data.redis.connection
-
Offset used inside a
BitFieldSubCommands.BitFieldSubCommand
. - 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.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.stringCommands()
}. - bitOp(RedisStringCommands.BitOperation, byte[], byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- 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 class org.springframework.data.redis.connection.DefaultStringRedisConnection
- bitOp(RedisStringCommands.BitOperation, String, String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Perform bitwise operations between strings.
- BITOP - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- 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.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.stringCommands()
}. - bitPos(byte[], boolean, Range<Long>) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- 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 class org.springframework.data.redis.connection.DefaultStringRedisConnection
- 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. - 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 - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- bLMove(byte[], byte[], RedisListCommands.Direction, RedisListCommands.Direction, double) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.listCommands()
}. - bLMove(byte[], byte[], RedisListCommands.Direction, RedisListCommands.Direction, double) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- bLMove(byte[], byte[], RedisListCommands.Direction, RedisListCommands.Direction, double) - Method in interface org.springframework.data.redis.connection.RedisListCommands
-
Atomically returns and removes the first/last element (head/tail depending on the
from
argument) of the list stored atsourceKey
, and pushes the element at the first/last element (head/tail depending on theto
argument) of the list stored atdestinationKey
. - bLMove(String, String, RedisListCommands.Direction, RedisListCommands.Direction, double) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- bLMove(String, String, RedisListCommands.Direction, RedisListCommands.Direction, double) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Atomically returns and removes the first/last element (head/tail depending on the
from
argument) of the list stored atsourceKey
, and pushes the element at the first/last element (head/tail depending on theto
argument) of the list stored atdestinationKey
. - bLMove(ByteBuffer, ByteBuffer, ReactiveListCommands.Direction, ReactiveListCommands.Direction, Duration) - Method in interface org.springframework.data.redis.connection.ReactiveListCommands
-
Atomically returns and removes the first/last element (head/tail depending on the
from
argument) of the list stored atsourceKey
, and pushes the element at the first/last element (head/tail depending on theto
argument) of the list stored atdestinationKey
. - bLMove(Publisher<ReactiveListCommands.BLMoveCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveListCommands
-
Atomically returns and removes the first/last element (head/tail depending on the
from
argument) of the list stored atsourceKey
, and pushes the element at the first/last element (head/tail depending on theto
argument) of the list stored atdestinationKey
. - 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(long, TimeUnit) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.BZPopCommand
-
Applies a
timeout
. - blockingFor(Duration) - Method in class org.springframework.data.redis.connection.ReactiveListCommands.BPopCommand
-
Applies a
timeout
. - blockingFor(Duration) - Method in class org.springframework.data.redis.connection.ReactiveListCommands.BRPopLPushCommand
-
Applies a
timeout
. - blockingFor(Duration) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.BZPopCommand
-
Applies a
timeout
. - 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.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.listCommands()
}. - bLPop(int, byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- 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 class org.springframework.data.redis.connection.DefaultStringRedisConnection
- bLPop(int, String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Removes and returns first element from lists stored at
keys
(see:DefaultedRedisConnection.lPop(byte[])
). - BLPOP - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- body(Map<ByteBuffer, ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveStreamCommands.AddStreamRecord
-
Creates a new
ReactiveStreamCommands.AddStreamRecord
givenbody
. - BOOLEAN - Enum constant in enum class org.springframework.data.redis.connection.ReturnType
-
Returned as Boolean
- BooleanResponse(I, Boolean) - Constructor for class org.springframework.data.redis.connection.ReactiveRedisConnection.BooleanResponse
- BoundGeoOperations<K,
M> - Interface in org.springframework.data.redis.core -
GeoOperations
bound to a certain key. - 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.
- boundHashOps(K) - Method in class org.springframework.data.redis.core.RedisTemplate
- BoundingBox - Class in org.springframework.data.redis.domain.geo
-
Represents a geospatial bounding box defined by width and height.
- BoundingBox(double, double, Metric) - Constructor for class org.springframework.data.redis.domain.geo.BoundingBox
-
Creates a new
BoundingBox
from the given width, height andMetric
. - BoundingBox(Distance, Distance) - Constructor for class org.springframework.data.redis.domain.geo.BoundingBox
-
Creates a new
BoundingBox
from the given width and height. - 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
- BoxShape - Class in org.springframework.data.redis.domain.geo
-
Bounding box defined by width and height.
- BoxShape(BoundingBox) - Constructor for class org.springframework.data.redis.domain.geo.BoxShape
- bPop(Publisher<ReactiveListCommands.BPopCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveListCommands
-
Removes and returns the top
ReactiveListCommands.BPopCommand.getDirection()
element from lists stored atReactiveListCommands.BPopCommand.getKeys()
.
Blocks connection until element available orReactiveListCommands.BPopCommand.getTimeout()
reached. - 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.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.listCommands()
}. - bRPop(int, byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- 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 class org.springframework.data.redis.connection.DefaultStringRedisConnection
- bRPop(int, String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Removes and returns last element from lists stored at
keys
(see:DefaultedRedisConnection.rPop(byte[])
). - BRPOP - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- bRPopLPush(int, byte[], byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.listCommands()
}. - bRPopLPush(int, byte[], byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- bRPopLPush(int, byte[], byte[]) - Method in interface org.springframework.data.redis.connection.RedisListCommands
-
Remove the last element from list at
srcKey
, append it todstKey
and return its value. - bRPopLPush(int, String, String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- bRPopLPush(int, String, String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Remove the last element from list at
srcKey
, append it todstKey
and return its value (seeDefaultedRedisConnection.rPopLPush(byte[], byte[])
). - 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
-
Remove the last element from list at
ReactiveRedisConnection.KeyCommand.getKey()
, append it toReactiveListCommands.BRPopLPushCommand.getDestination()
and return its value. - BRPOPLPUSH - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- 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
. - BUFFER_FREE_SPACE - Enum constant in enum class org.springframework.data.redis.connection.RedisServer.INFO
- BUFFER_FREE_SPACE - Enum constant in enum class org.springframework.data.redis.core.types.RedisClientInfo.INFO
- BUFFER_LENGTH - Enum constant in enum class org.springframework.data.redis.connection.RedisServer.INFO
- BUFFER_LENGTH - Enum constant in enum class org.springframework.data.redis.core.types.RedisClientInfo.INFO
- 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
-
Create new instance of
RedisCacheManager
with configuration options applied. - 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 the
JedisClientConfiguration
with the configuration applied from this builder. - build() - Method in interface org.springframework.data.redis.connection.jedis.JedisClientConfiguration.JedisPoolingClientConfigurationBuilder
-
Build the
JedisClientConfiguration
with the configuration applied from this builder. - build() - Method in interface org.springframework.data.redis.connection.jedis.JedisClientConfiguration.JedisSslClientConfigurationBuilder
-
Build the
JedisClientConfiguration
with the configuration applied from this builder. - build() - Method in class org.springframework.data.redis.connection.lettuce.LettuceClientConfiguration.LettuceClientConfigurationBuilder
-
Build the
LettuceClientConfiguration
with the configuration applied from this builder. - build() - Method in class org.springframework.data.redis.connection.lettuce.LettuceClientConfiguration.LettuceSslClientConfigurationBuilder
-
Build the
LettuceClientConfiguration
with the configuration applied from this builder. - 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
-
Get the
RedisNode
. - build() - Method in class org.springframework.data.redis.core.query.SortQueryBuilder
- build() - Method in interface org.springframework.data.redis.core.query.SortCriterion
- build() - Method in class org.springframework.data.redis.core.ScanOptions.ScanOptionsBuilder
-
Builds a new
ScanOptions
objects. - build() - Method in class org.springframework.data.redis.serializer.GenericJackson2JsonRedisSerializer.GenericJackson2JsonRedisSerializerBuilder
-
Creates a new instance of
GenericJackson2JsonRedisSerializer
with configuration options applied. - build() - Method in interface org.springframework.data.redis.serializer.RedisSerializationContext.RedisSerializationContextBuilder
-
Builds a
RedisSerializationContext
. - build() - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.ConsumerStreamReadRequestBuilder
-
Build a new instance of
StreamMessageListenerContainer.ConsumerStreamReadRequest
. - build() - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamMessageListenerContainerOptionsBuilder
- build() - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamReadRequestBuilder
-
Build a new instance of
StreamMessageListenerContainer.StreamReadRequest
. - build() - Method in class org.springframework.data.redis.stream.StreamReceiver.StreamReceiverOptionsBuilder
-
Build new
StreamReceiver.StreamReceiverOptions
. - builder() - Static method in class org.springframework.data.redis.cache.RedisCacheManager
-
Factory method returning a Builder used to construct and configure a
RedisCacheManager
. - builder() - Static method in interface org.springframework.data.redis.connection.jedis.JedisClientConfiguration
-
Creates a new
JedisClientConfiguration.JedisClientConfigurationBuilder
to buildJedisClientConfiguration
to be used with the jedis client. - builder() - Static method in interface org.springframework.data.redis.connection.lettuce.LettuceClientConfiguration
-
Creates a new
LettuceClientConfiguration.LettuceClientConfigurationBuilder
to buildLettuceClientConfiguration
to be used with the Lettuce client. - builder() - Static method in interface org.springframework.data.redis.connection.lettuce.LettucePoolingClientConfiguration
-
Creates a new
LettucePoolingClientConfiguration.LettucePoolingClientConfigurationBuilder
to buildLettucePoolingClientConfiguration
to be used with the Lettuce client. - builder() - Static method in class org.springframework.data.redis.serializer.GenericJackson2JsonRedisSerializer
-
Factory method returning a Builder used to construct and configure a
GenericJackson2JsonRedisSerializer
. - builder() - Static method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamMessageListenerContainerOptions
- builder() - Static method in class org.springframework.data.redis.stream.StreamReceiver.StreamReceiverOptions
- builder(RedisCacheWriter) - Static method in class org.springframework.data.redis.cache.RedisCacheManager
-
Factory method returning a Builder used to construct and configure a
RedisCacheManager
initialized with the givenRedisCacheWriter
. - builder(RedisConnectionFactory) - Static method in class org.springframework.data.redis.cache.RedisCacheManager
-
Factory method returning a Builder used to construct and configure a
RedisCacheManager
initialized with the givenRedisConnectionFactory
. - builder(StreamOffset<K>) - Static method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamReadRequest
- 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(byte[]) - Method in class org.springframework.data.redis.connection.DefaultSortParameters
- by(long) - Method in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldIncrByBuilder
-
Set the value used for increasing.
- 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
- 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.
- byBox(double, double, RedisGeoCommands.DistanceUnit) - Static method in interface org.springframework.data.redis.domain.geo.GeoShape
-
Create a shape used as predicate for geo queries from a bounding box with specified by
width
andheight
. - byBox(BoundingBox) - Static method in interface org.springframework.data.redis.domain.geo.GeoShape
-
Create a shape used as predicate for geo queries from a
BoundingBox
. - ByLex - Enum constant in enum class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRangeStoreCommand.RangeMode
- byRadius(Distance) - Static method in interface org.springframework.data.redis.domain.geo.GeoShape
-
Create a shape used as predicate for geo queries from a
radius
around the query center point. - ByScore - Enum constant in enum class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRangeStoreCommand.RangeMode
- byteArray() - Static method in interface org.springframework.data.redis.serializer.RedisSerializationContext
-
Creates a new
RedisSerializationContext
using abyte[]
serialization. - byteArray() - Static method in interface org.springframework.data.redis.serializer.RedisSerializationContext.SerializationPair
-
Creates a pass through
RedisSerializationContext.SerializationPair
to pass-thrubyte
objects. - byteArray() - Static method in interface org.springframework.data.redis.serializer.RedisSerializer
-
Obtain a
RedisSerializer
that passes thrubyte[]
. - 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
- ByteArrayWrapper(ByteBuffer) - Constructor for class org.springframework.data.redis.connection.util.ByteArrayWrapper
- byteBuffer() - Static method in interface org.springframework.data.redis.serializer.RedisSerializationContext
-
Creates a new
RedisSerializationContext
using aByteBuffer
serialization. - byteBuffer() - Static method in interface org.springframework.data.redis.serializer.RedisSerializationContext.SerializationPair
-
Creates a pass through
RedisSerializationContext.SerializationPair
to pass-thruByteBuffer
objects. - ByteBufferRecord - Interface in org.springframework.data.redis.connection.stream
-
A
Record
within the stream backed by a collection of binary field/value pairs. - 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 pairs. - bytesSetToGeoResultsConverter() - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
- ByteUtils - Class in org.springframework.data.redis.util
-
Some handy methods for dealing with
byte
arrays. - bZPop(Publisher<ReactiveZSetCommands.BZPopCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Remove and return elements from sorted set at
keyCommand#getKey()
. - bZPopMax(byte[], long, TimeUnit) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - bZPopMax(byte[], long, TimeUnit) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- bZPopMax(byte[], long, TimeUnit) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Remove and return the value with its score having the highest score from sorted set at
key
. - bZPopMax(String, long, TimeUnit) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- bZPopMax(String, long, TimeUnit) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Remove and return the value with its score having the highest score from sorted set at
key
. - bZPopMax(ByteBuffer, Duration) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Remove and return the value with its score having the highest score from sorted set at
key
. - bZPopMin(byte[], long, TimeUnit) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - bZPopMin(byte[], long, TimeUnit) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- bZPopMin(byte[], long, TimeUnit) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Remove and return the value with its score having the lowest score from sorted set at
key
. - bZPopMin(String, long, TimeUnit) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- bZPopMin(String, long, TimeUnit) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Remove and return the value with its score having the lowest score from sorted set at
key
. - bZPopMin(ByteBuffer, Duration) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Remove and return the value with its score having the lowest score from sorted set at
key
.
C
- cacheDefaults() - Method in class org.springframework.data.redis.cache.RedisCacheManager.RedisCacheManagerBuilder
-
Returns the default
RedisCacheConfiguration
. - cacheDefaults(RedisCacheConfiguration) - Method in class org.springframework.data.redis.cache.RedisCacheManager.RedisCacheManagerBuilder
-
Define a default
RedisCacheConfiguration
applied to dynamically createdRedisCache
s. - CacheKeyPrefix - Interface in org.springframework.data.redis.cache
-
CacheKeyPrefix
is a callback hook for creating custom prefixes prepended to the actual key stored in Redis. - CacheStatistics - Interface in org.springframework.data.redis.cache
-
Cache statistics for a
RedisCache
. - 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 bycacheName
. - cacheWriter(RedisCacheWriter) - Method in class org.springframework.data.redis.cache.RedisCacheManager.RedisCacheManagerBuilder
-
Configure a
RedisCacheWriter
. - calculateSlot(byte[]) - Static method in class org.springframework.data.redis.connection.ClusterSlotHashUtil
-
Calculate the slot from the given key.
- calculateSlot(String) - 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.
- CANCELLED - Enum constant in enum class org.springframework.data.redis.stream.Task.State
- cancelOnError(Predicate<Throwable>) - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.ConsumerStreamReadRequestBuilder
-
Configure a cancellation
Predicate
to be notified onread, deserialization, and listener errors
. - cancelOnError(Predicate<Throwable>) - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamReadRequestBuilder
- canEqual(Object) - Method in class org.springframework.data.redis.core.convert.GeoIndexedPropertyValue
- canSerialize(Class<?>) - Method in interface org.springframework.data.redis.serializer.RedisSerializer
-
Check whether the given value
type
can be serialized by this serializer. - 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
-
Creates a new
CdiBean
. - CdiBean(Set<Annotation>, Set<Type>, Class<T>, BeanManager) - Constructor for class org.springframework.data.redis.repository.cdi.CdiBean
-
Creates a new
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.
- CH - Enum constant in enum class org.springframework.data.redis.connection.RedisZSetCommands.ZAddArgs.Flag
-
Modify the return value from the number of new elements added, to the total number of elements changed.
- CHANNEL_SUBSCRIBTIONS - Enum constant in enum class org.springframework.data.redis.core.types.RedisClientInfo.INFO
- ChannelMessage(C, M) - Constructor for class org.springframework.data.redis.connection.ReactiveSubscription.ChannelMessage
-
Create a new
ReactiveSubscription.ChannelMessage
. - ChannelTopic - Class in org.springframework.data.redis.listener
-
Channel Topic
implementation mapping to a Redis channel. - ChannelTopic(String) - Constructor for class org.springframework.data.redis.listener.ChannelTopic
-
Constructs a new
ChannelTopic
instance. - CHARSET - Static variable in class org.springframework.data.redis.core.convert.Bucket
- checkResult(Object) - Method in class org.springframework.data.redis.support.collections.AbstractRedisCollection
- claim(K, String, String, Duration, RecordId...) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
-
Changes the ownership of a pending message so that the new owner is the consumer specified as the command argument.
- claim(K, String, String, Duration, RecordId...) - Method in interface org.springframework.data.redis.core.StreamOperations
-
Changes the ownership of a pending message so that the new owner is the consumer specified as the command argument.
- claim(K, String, String, RedisStreamCommands.XClaimOptions) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
-
Changes the ownership of a pending message so that the new owner is the consumer specified as the command argument.
- claim(K, String, String, RedisStreamCommands.XClaimOptions) - Method in interface org.springframework.data.redis.core.StreamOperations
-
Changes the ownership of a pending message so that the new owner is the consumer specified as the command argument.
- clean(String, byte[]) - Method in interface org.springframework.data.redis.cache.RedisCacheWriter
-
Remove all keys following the given pattern.
- cleanCache(RedisConnection, String, byte[]) - Method in interface org.springframework.data.redis.cache.BatchStrategy
-
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
- clear(String) - Method in class org.springframework.data.redis.cache.RedisCache
-
Clear keys that match the given
keyPattern
. - 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.
- CLIENT_GETNAME - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- CLIENT_KILL - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- CLIENT_LIST - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- CLIENT_PAUSE - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- CLIENT_SETNAME - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- 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 withCLIENT SETNAME
. - clientName(String) - Method in class org.springframework.data.redis.connection.lettuce.LettuceClientConfiguration.LettuceClientConfigurationBuilder
-
Configure a
clientName
to be set withCLIENT 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.connection.RedisGeoCommands.GeoSearchCommandArgs
- clone() - Method in class org.springframework.data.redis.connection.RedisGeoCommands.GeoSearchStoreCommandArgs
- 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, int...) - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
- clusterAddSlots(RedisClusterNode, int...) - Method in interface org.springframework.data.redis.connection.ReactiveClusterCommands
-
Assign slots to given
RedisClusterNode
. - clusterAddSlots(RedisClusterNode, int...) - Method in interface org.springframework.data.redis.connection.RedisClusterCommands
-
Assign slots to given
RedisClusterNode
. - clusterAddSlots(RedisClusterNode, RedisClusterNode.SlotRange) - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
- clusterAddSlots(RedisClusterNode, RedisClusterNode.SlotRange) - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
- clusterAddSlots(RedisClusterNode, RedisClusterNode.SlotRange) - Method in interface org.springframework.data.redis.connection.ReactiveClusterCommands
-
Assign
RedisClusterNode.SlotRange.getSlotsArray()
to givenRedisClusterNode
. - clusterAddSlots(RedisClusterNode, RedisClusterNode.SlotRange) - Method in interface org.springframework.data.redis.connection.RedisClusterCommands
-
Assign
RedisClusterNode.SlotRange.getSlotsArray()
to givenRedisClusterNode
. - 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
-
Creates new
ClusterCommandExecutionFailureException
. - ClusterCommandExecutionFailureException(List<? extends Throwable>) - Constructor for exception org.springframework.data.redis.connection.ClusterCommandExecutionFailureException
-
Creates new
ClusterCommandExecutionFailureException
. - ClusterCommandExecutor - Class in org.springframework.data.redis.connection
-
ClusterCommandExecutor
takes care of running commands across the known cluster nodes. - ClusterCommandExecutor(ClusterTopologyProvider, ClusterNodeResourceProvider, ExceptionTranslationStrategy) - Constructor for class org.springframework.data.redis.connection.ClusterCommandExecutor
-
Create a new
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.MultiNodeResult
holds allClusterCommandExecutor.NodeResult
of a command executed on multipleRedisClusterNode
. - ClusterCommandExecutor.NodeResult<T> - Class in org.springframework.data.redis.connection
-
ClusterCommandExecutor.NodeResult
encapsulates the actualvalue
returned by aClusterCommandExecutor.ClusterCommandCallback
on a givenRedisClusterNode
. - clusterCommands() - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
- clusterCommands() - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
- clusterCommands() - Method in interface org.springframework.data.redis.connection.RedisClusterCommandsProvider
-
Get
RedisGeoCommands
. - 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
-
Remove slots from
RedisClusterNode
. - clusterDeleteSlots(RedisClusterNode, int...) - Method in interface org.springframework.data.redis.connection.RedisClusterCommands
-
Remove slots from
RedisClusterNode
. - 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
-
Removes
RedisClusterNode.SlotRange.getSlotsArray()
from givenRedisClusterNode
. - clusterDeleteSlotsInRange(RedisClusterNode, RedisClusterNode.SlotRange) - Method in interface org.springframework.data.redis.connection.RedisClusterCommands
-
Removes
RedisClusterNode.SlotRange.getSlotsArray()
from givenRedisClusterNode
. - 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, int) - Method in interface org.springframework.data.redis.connection.ReactiveClusterCommands
-
Get keys served by slot.
- 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, Integer) - Method in interface org.springframework.data.redis.connection.RedisClusterCommands
-
Get keys served by slot.
- clusterGetMasterReplicaMap() - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
- clusterGetMasterReplicaMap() - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
- clusterGetMasterReplicaMap() - Method in interface org.springframework.data.redis.connection.ReactiveClusterCommands
-
Retrieve information about masters and their connected replicas.
- clusterGetMasterReplicaMap() - Method in interface org.springframework.data.redis.connection.RedisClusterCommands
-
Retrieve information about masters and their connected replicas.
- 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(byte[]) - Method in interface org.springframework.data.redis.connection.RedisClusterCommands
-
Find the
RedisClusterNode
serving given key. - clusterGetNodeForKey(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveClusterCommands
-
Find the
RedisClusterNode
serving given key. - 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
-
Find the
RedisClusterNode
serving given slot. - clusterGetNodeForSlot(int) - Method in interface org.springframework.data.redis.connection.RedisClusterCommands
-
Find the
RedisClusterNode
serving given slot. - 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.
- clusterGetReplicas(RedisClusterNode) - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
- clusterGetReplicas(RedisClusterNode) - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
- clusterGetReplicas(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.ReactiveClusterCommands
-
Retrieve information about connected replicas for given master node.
- clusterGetReplicas(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.RedisClusterCommands
-
Retrieve information about connected replicas 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(byte[]) - Method in interface org.springframework.data.redis.connection.RedisClusterCommands
-
Find the slot for a given
key
. - clusterGetSlotForKey(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveClusterCommands
-
Find the slot for a given
key
. - ClusterInfo - Class in org.springframework.data.redis.connection
-
ClusterInfo
gives access to cluster information such ascluster_state
andcluster_slots_assigned
provided by theCLUSTER INFO
command. - ClusterInfo(Properties) - Constructor for class org.springframework.data.redis.connection.ClusterInfo
-
Creates new
ClusterInfo
for givenProperties
. - ClusterInfo.Info - Enum Class 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(String, Integer) - Method in class org.springframework.data.redis.connection.RedisClusterConfiguration
- clusterNode(RedisNode) - Method in class org.springframework.data.redis.connection.RedisClusterConfiguration
- ClusterNodeResourceProvider - Interface in org.springframework.data.redis.connection
-
ClusterNodeResourceProvider
provides access to low level client api to directly execute operations against a Redis instance. - 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
-
Creates new
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 replica to given master.
- clusterReplicate(RedisClusterNode, RedisClusterNode) - Method in interface org.springframework.data.redis.connection.RedisClusterCommands
-
Assign a replica to given master.
- clusterSetSlot(RedisClusterNode, int, ReactiveClusterCommands.AddSlots) - Method in interface org.springframework.data.redis.connection.ReactiveClusterCommands
- 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, RedisClusterCommands.AddSlots) - Method in interface org.springframework.data.redis.connection.RedisClusterCommands
- ClusterSlotHashUtil - Class in org.springframework.data.redis.connection
-
Utility class encapsulating functionality commonly used for cluster slot hashing.
- ClusterSlotHashUtil() - Constructor for class org.springframework.data.redis.connection.ClusterSlotHashUtil
- ClusterStateFailureException - Exception in org.springframework.data.redis
-
DataAccessResourceFailureException
indicating the current local snapshot of cluster state does no longer represent the actual remote state. - ClusterStateFailureException(String) - Constructor for exception org.springframework.data.redis.ClusterStateFailureException
-
Creates new
ClusterStateFailureException
. - ClusterStateFailureException(String, Throwable) - Constructor for exception org.springframework.data.redis.ClusterStateFailureException
-
Creates new
ClusterStateFailureException
. - ClusterTopology - Class in org.springframework.data.redis.connection
-
ClusterTopology
holds snapshot like information aboutRedisClusterNode
s. - ClusterTopology(Set<RedisClusterNode>) - Constructor for class org.springframework.data.redis.connection.ClusterTopology
-
Creates new instance of
ClusterTopology
. - ClusterTopologyProvider - Interface in org.springframework.data.redis.connection
-
ClusterTopologyProvider
manages the current cluster topology and makes sure to refresh cluster information. - code() - Method in enum class org.springframework.data.redis.connection.DataType
-
Returns the code associated with the current enum.
- CollectionUtils - Class in org.springframework.data.redis.support.collections
-
Utility class used mainly for type conversion by the default collection implementations.
- CollectionUtils() - Constructor for class org.springframework.data.redis.support.collections.CollectionUtils
- CommandResponse(I, O) - Constructor for class org.springframework.data.redis.connection.ReactiveRedisConnection.CommandResponse
- commands() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- commands() - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
- commands() - Method in class org.springframework.data.redis.connection.jedis.JedisConnection
- commands() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
- commands() - Method in interface org.springframework.data.redis.connection.RedisCommandsProvider
-
Get
RedisCommands
. - commands(BitFieldSubCommands) - Method in class org.springframework.data.redis.connection.ReactiveStringCommands.BitFieldCommand
-
Applies the
BitFieldSubCommands
. - 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.zset.DefaultTuple
- compareTo(Double) - Method in class org.springframework.data.redis.core.DefaultTypedTuple
- compareTo(ByteArrayWrapper) - Method in class org.springframework.data.redis.connection.util.ByteArrayWrapper
- compareTo(ZSetOperations.TypedTuple<V>) - Method in class org.springframework.data.redis.core.DefaultTypedTuple
- complete(RedisOperationChain, Sort) - Method in class org.springframework.data.redis.repository.query.RedisQueryCreator
- CompositeIndexResolver - Class in org.springframework.data.redis.core.convert
-
Composite
IndexResolver
implementation that iterates over a given collection of delegateIndexResolver
instances. - CompositeIndexResolver(Collection<IndexResolver>) - Constructor for class org.springframework.data.redis.core.convert.CompositeIndexResolver
-
Create new
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 cache 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. - concatAll(byte[]...) - Static method in class org.springframework.data.redis.util.ByteUtils
-
Concatenate the given
byte
arrays into one. - CONFIG_EPOCH - Enum constant in enum class org.springframework.data.redis.connection.RedisServer.INFO
- CONFIG_GET - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- CONFIG_RESETSTAT - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- CONFIG_REWRITE - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- CONFIG_SET - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- ConfigurableIndexDefinitionProvider - Interface in org.springframework.data.redis.core.index
- configure(Consumer<ObjectMapper>) - Method in class org.springframework.data.redis.serializer.GenericJackson2JsonRedisSerializer
-
Builder method used to configure and customize the internal Jackson
ObjectMapper
created by thisGenericJackson2JsonRedisSerializer
and used to de/serializeobjects
as JSON. - configureKeyConverters(Consumer<ConverterRegistry>) - Method in class org.springframework.data.redis.cache.RedisCacheConfiguration
-
Configure the underlying
ConversionService
used to extract the cache key. - CONNECTED - Enum constant in enum class org.springframework.data.redis.connection.RedisClusterNode.LinkState
- CONNECTION_AGE - Enum constant in enum class org.springframework.data.redis.core.types.RedisClientInfo.INFO
- CONNECTION_IDLE - Enum constant in enum class org.springframework.data.redis.core.types.RedisClientInfo.INFO
- CONNECTION_NAME - Enum constant in enum class org.springframework.data.redis.core.types.RedisClientInfo.INFO
- ConnectionUtils - Class in org.springframework.data.redis.connection
-
Utilities for examining a
RedisConnection
- ConnectionUtils() - Constructor for class org.springframework.data.redis.connection.ConnectionUtils
- 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.
- considerNestedRepositories() - Element in annotation interface org.springframework.data.redis.repository.configuration.EnableRedisRepositories
-
Configures whether nested repository-interfaces (e.g. defined as inner classes) should be discovered by the repositories infrastructure.
- 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(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. - Consumer - Class in org.springframework.data.redis.connection.stream
-
Value object representing a Stream consumer 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
-
Determines whether this
RedisClusterNode.SlotRange
contains the givenslot
, which implies this cluster nodes manages the slot holding data stored in Redis. - contains(Object) - Method in class org.springframework.data.redis.connection.util.ByteArraySet
- 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
- contains(Object, String) - Method in class org.springframework.data.redis.core.RedisKeyValueAdapter
- contains(RedisZSetCommands.ZAddArgs.Flag) - Method in class org.springframework.data.redis.connection.RedisZSetCommands.ZAddArgs
-
Only update elements that already exist.
- containsAll(Collection<?>) - Method in class org.springframework.data.redis.connection.util.ByteArraySet
- containsAll(Collection<?>) - Method in class org.springframework.data.redis.support.collections.AbstractRedisCollection
- containsAll(Collection<?>) - Method in class org.springframework.data.redis.support.collections.DefaultRedisSet
- 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(Exception) - Method in class org.springframework.data.redis.connection.jedis.JedisExceptionConverter
- convert(Exception) - Method in class org.springframework.data.redis.connection.lettuce.LettuceExceptionConverter
- convert(Long) - Method in class org.springframework.data.redis.connection.convert.LongToBooleanConverter
- 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(Object) - Method in class org.springframework.data.redis.connection.jedis.JedisScriptReturnConverter
- convert(Object) - Method in class org.springframework.data.redis.core.index.RedisIndexDefinition.CompositeValueTransformer
- convert(Object) - Method in enum class org.springframework.data.redis.core.index.RedisIndexDefinition.LowercaseIndexValueTransformer
- convert(Object) - Method in enum class org.springframework.data.redis.core.index.RedisIndexDefinition.NoOpValueTransformer
- 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(Collection<S>) - Method in class org.springframework.data.redis.connection.convert.SetConverter
- convert(List<Object>) - Method in class org.springframework.data.redis.connection.convert.TransactionResultConverter
- convert(List<S>) - Method in class org.springframework.data.redis.connection.convert.ListConverter
- convert(Map<?, ?>) - Method in enum class org.springframework.data.redis.connection.convert.MapToPropertiesConverter
- convert(Map<S, S>) - Method in class org.springframework.data.redis.connection.convert.MapConverter
- convert(Set<S>) - Method in class org.springframework.data.redis.connection.convert.SetConverter
- 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
- 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
- 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
wraps a given cursor and applies givenConverter
to items prior to returning them. - 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
- convertKey(Object) - Method in class org.springframework.data.redis.cache.RedisCache
-
Convert
key
to aString
used in 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
- copy(byte[], byte[], boolean) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.keyCommands()
. - copy(byte[], byte[], boolean) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- copy(byte[], byte[], boolean) - Method in interface org.springframework.data.redis.connection.RedisKeyCommands
-
Copy given
sourceKey
totargetKey
. - copy(String, String, boolean) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- copy(String, String, boolean) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Copy given
sourceKey
totargetKey
. - copy(ByteBuffer, ByteBuffer, boolean) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
-
Copy given
key
to a targetkey
. - copy(K, K, boolean) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
-
Copy given
sourceKey
totargetKey
. - copy(K, K, boolean) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
- copy(K, K, boolean) - Method in interface org.springframework.data.redis.core.RedisOperations
-
Copy given
sourceKey
totargetKey
. - copy(K, K, boolean) - Method in class org.springframework.data.redis.core.RedisTemplate
- copy(Publisher<ReactiveKeyCommands.CopyCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
-
Copy keys one-by-one.
- COPY - Enum constant in enum class org.springframework.data.redis.connection.RedisServerCommands.MigrateOption
- CopyCommand(ByteBuffer, ByteBuffer, boolean, Integer) - Constructor for class org.springframework.data.redis.connection.ReactiveKeyCommands.CopyCommand
- count(double, double) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Count number of elements within sorted set with scores between
min
andmax
. - count(int) - Method in class org.springframework.data.redis.connection.Limit
- count(long) - Method in class org.springframework.data.redis.connection.ReactiveHashCommands.HRandFieldCommand
-
Applies the count.
- count(long) - Method in class org.springframework.data.redis.connection.ReactiveListCommands.PopCommand
-
Applies the key.
- count(long) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.BZPopCommand
-
Applies the key.
- count(long) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZPopCommand
-
Applies the key.
- count(long) - Method in class org.springframework.data.redis.connection.stream.StreamReadOptions
-
Limit the number of messages returned per stream.
- count(long) - Method in class org.springframework.data.redis.core.ScanOptions.ScanOptionsBuilder
-
Returns the current
ScanOptions.ScanOptionsBuilder
configured with the givencount
. - count(Integer) - Method in class org.springframework.data.redis.connection.ReactiveListCommands.LPosCommand
-
Applies the count parameter specifying the number of matches to return.
- count(String) - Method in class org.springframework.data.redis.core.RedisKeyValueAdapter
- count(K, double, double) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Count number of elements within sorted set with scores between
min
andmax
. - count(K, Range<Double>) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Count number of elements within sorted set with scores between
min
andmax
. - 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() - Static method in class org.springframework.data.redis.connection.BitFieldSubCommands
-
Creates a new
BitFieldSubCommands
. - create() - Static method in interface org.springframework.data.redis.serializer.JacksonObjectReader
-
Create a default
JacksonObjectReader
delegating toObjectMapper.readValue(InputStream, JavaType)
. - create() - Static method in interface org.springframework.data.redis.serializer.JacksonObjectWriter
-
Create a default
JacksonObjectWriter
delegating toObjectMapper.writeValueAsBytes(Object)
. - create(CreationalContext<KeyValueOperations>) - Method in class org.springframework.data.redis.repository.cdi.RedisKeyValueTemplateBean
- create(CreationalContext<RedisKeyValueAdapter>) - Method in class org.springframework.data.redis.repository.cdi.RedisKeyValueAdapterBean
- create(CreationalContext<T>, Class<T>) - Method in class org.springframework.data.redis.repository.cdi.RedisRepositoryBean
- create(String, RedisOperations<String, E>) - Static method in interface org.springframework.data.redis.support.collections.RedisList
-
Constructs a new, uncapped
RedisList
instance. - create(String, RedisOperations<String, E>) - Static method in interface org.springframework.data.redis.support.collections.RedisSet
-
Constructs a new
RedisSet
instance. - create(String, RedisOperations<String, E>) - Static method in interface org.springframework.data.redis.support.collections.RedisZSet
-
Constructs a new
RedisZSet
instance with a default score of 1. - create(String, RedisOperations<String, E>, double) - Static method in interface org.springframework.data.redis.support.collections.RedisZSet
-
Constructs a new
RedisZSet
instance. - create(String, RedisOperations<String, E>, int) - Static method in interface org.springframework.data.redis.support.collections.RedisList
- create(K, ReadOffset) - Static method in class org.springframework.data.redis.connection.stream.StreamOffset
- create(BitFieldSubCommands.BitFieldSubCommand...) - Static method in class org.springframework.data.redis.connection.BitFieldSubCommands
-
Creates a new
BitFieldSubCommands
with Multiple BitFieldSubCommand. - create(BitFieldSubCommands.BitFieldType, BitFieldSubCommands.Offset) - Static method in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldGet
-
Creates a new
BitFieldSubCommands.BitFieldGet
. - create(BitFieldSubCommands.BitFieldType, BitFieldSubCommands.Offset, long) - Static method in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldIncrBy
-
Creates a new
BitFieldSubCommands.BitFieldIncrBy
. - create(BitFieldSubCommands.BitFieldType, BitFieldSubCommands.Offset, long) - Static method in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldSet
-
Creates a new
BitFieldSubCommands.BitFieldSet
. - create(BitFieldSubCommands.BitFieldType, BitFieldSubCommands.Offset, long, BitFieldSubCommands.BitFieldIncrBy.Overflow) - Static method in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldIncrBy
-
Creates a new
BitFieldSubCommands.BitFieldIncrBy
. - 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
-
Create a new
StreamReceiver
givenReactiveRedisConnectionFactory
andStreamReceiver.StreamReceiverOptions
. - create(RedisConnectionFactory) - Static method in class org.springframework.data.redis.cache.RedisCacheManager
-
Factory method used to construct a new
RedisCacheManager
initialized with the givenRedisConnectionFactory
and usingdefaults
for caching. - 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(BoundListOperations<String, E>) - Static method in interface org.springframework.data.redis.support.collections.RedisList
-
Constructs a new, uncapped
DefaultRedisList
instance. - create(BoundListOperations<String, E>, int) - Static method in interface org.springframework.data.redis.support.collections.RedisList
-
Constructs a new
DefaultRedisList
. - create(Part, Iterator<Object>) - Method in class org.springframework.data.redis.repository.query.RedisQueryCreator
- 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
- CREATE - Enum constant in enum class org.springframework.data.redis.connection.ReactiveStreamCommands.GroupCommand.GroupCommandAction
- 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<Connection>) - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
- createCredentialsProvider(RedisConfiguration) - Method in interface org.springframework.data.redis.connection.lettuce.RedisCredentialsProviderFactory
-
Create a
RedisCredentialsProvider
for data node authentication givenRedisConfiguration
. - CREATED - Enum constant in enum class org.springframework.data.redis.stream.Task.State
- createDefaultTaskExecutor() - Method in class org.springframework.data.redis.listener.RedisMessageListenerContainer
-
Creates a default TaskExecutor.
- createEndpoint(SocketAddress) - Method in class org.springframework.data.redis.connection.lettuce.observability.MicrometerTracingAdapter
-
Deprecated.
- createFlux(ReactiveRedisCallback<T>) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
-
Create a reusable Flux for a
ReactiveRedisCallback
. - createGroup(String) - Static method in class org.springframework.data.redis.connection.ReactiveStreamCommands.GroupCommand
- createGroup(K, String) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
-
Create a consumer group at the
latest offset
. - createGroup(K, String) - Method in interface org.springframework.data.redis.core.StreamOperations
-
Create a consumer group at the
latest offset
. - createGroup(K, ReadOffset, String) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
-
Create a consumer group.
- createGroup(K, ReadOffset, String) - Method in interface org.springframework.data.redis.core.StreamOperations
-
Create a consumer group.
- createGroup(ReadOffset, String) - Method in interface org.springframework.data.redis.core.BoundStreamOperations
-
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
-
Create a reusable Mono for a
ReactiveRedisCallback
. - 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
- createRedisConfiguration(RedisURI) - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
Creates a
RedisConfiguration
based on aRedisURI
according to the following: IfRedisURI
contains sentinels, aRedisSentinelConfiguration
is returned IfRedisURI
has a configured socket aRedisSocketConfiguration
is returned Otherwise aRedisStandaloneConfiguration
is returned - createRedisConfiguration(String) - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
Creates a
RedisConfiguration
based on aURI
according to the following: IfredisUri
contains sentinels, aRedisSentinelConfiguration
is returned IfredisUri
has a configured socket aRedisSocketConfiguration
is returned Otherwise aRedisStandaloneConfiguration
is returned - 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
- createSentinelCredentialsProvider(RedisSentinelConfiguration) - Method in interface org.springframework.data.redis.connection.lettuce.RedisCredentialsProviderFactory
-
Create a
RedisCredentialsProvider
for Sentinel node authentication givenRedisSentinelConfiguration
. - createSubscription() - Method in interface org.springframework.data.redis.connection.ReactivePubSubCommands
-
Creates a subscription for this connection.
- createSubscription(SubscriptionListener) - 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
-
Template method to create a
ClusterTopologyProvider
givenJedisCluster
. - CURRENT_EPOCH - Enum constant in enum class org.springframework.data.redis.connection.ClusterInfo.Info
- 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. - Cursor.CursorId - Class in org.springframework.data.redis.core
-
Value class representing a cursor identifier.
- CursorId() - Constructor for class org.springframework.data.redis.core.Cursor.CursorId
- customize(JedisClientConfigBuilderCustomizer) - Method in class org.springframework.data.redis.connection.jedis.JedisClientConfiguration.DefaultJedisClientConfigurationBuilder
- customize(JedisClientConfigBuilderCustomizer) - Method in interface org.springframework.data.redis.connection.jedis.JedisClientConfiguration.JedisClientConfigurationBuilder
-
Configure a
JedisClientConfigBuilderCustomizer
to configureJedisClientConfig
. - customize(DefaultJedisClientConfig.Builder) - Method in interface org.springframework.data.redis.connection.jedis.JedisClientConfigBuilderCustomizer
-
Customize the
DefaultJedisClientConfig.Builder
.
D
- database(int) - Method in class org.springframework.data.redis.connection.ReactiveKeyCommands.CopyCommand
-
Applies the database index.
- DATABSE_ID - Enum constant in enum class org.springframework.data.redis.core.types.RedisClientInfo.INFO
- DataType - Enum Class in org.springframework.data.redis.connection
-
Enumeration of the Redis data types.
- dbSize() - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.serverCommands()
. - dbSize() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- dbSize() - Method in interface org.springframework.data.redis.connection.ReactiveServerCommands
-
Get the total number of available keys in currently selected database.
- dbSize() - Method in interface org.springframework.data.redis.connection.RedisServerCommands
-
Get the total number of available keys in currently selected database.
- dbSize(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.DefaultedRedisClusterConnection
-
Deprecated.in favor of
RedisCommandsProvider.serverCommands()
. - dbSize(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.ReactiveClusterServerCommands
-
Get the total number of available keys in currently selected database.
- dbSize(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.RedisClusterServerCommands
- DBSIZE - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- 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
-
Specifies that the connection decorates another
RedisConnection
. - 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
-
Deprecated.in favor of
RedisCommandsProvider.stringCommands()
}. - decr(byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- 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 class org.springframework.data.redis.connection.DefaultStringRedisConnection
- decr(String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Decrement an integer value stored as string value of
key
by 1. - decr(ByteBuffer) - 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
-
Creates a new
ReactiveNumberCommands.DecrByCommand
given akey
. - decr(Publisher<ReactiveRedisConnection.KeyCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveNumberCommands
-
Decrement value of key by 1.
- DECR - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- decrBy(byte[], long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.stringCommands()
}. - decrBy(byte[], long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- decrBy(byte[], long) - Method in interface org.springframework.data.redis.connection.RedisStringCommands
-
Decrement an integer value stored as string value of
key
byvalue
. - decrBy(String, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- decrBy(String, long) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Decrement an integer value stored as string value of
key
byvalue
. - 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 - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- 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) - 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.ReactiveValueOperations
-
Decrements the number stored at
key
bydelta
. - decrement(K, long) - Method in interface org.springframework.data.redis.core.ValueOperations
-
Decrement an integer value stored as string value under
key
bydelta
. - 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 - Enum constant in enum class org.springframework.data.redis.core.RedisKeyValueAdapter.ShadowCopy
-
Store shadow copies of expiring entities depending on the
RedisKeyValueAdapter.EnableKeyspaceEvents
. - DEFAULT_ALLOW_RUNTIME_CACHE_CREATION - Static variable in class org.springframework.data.redis.cache.RedisCacheManager
- DEFAULT_CACHE_NULL_VALUES - Static variable in class org.springframework.data.redis.cache.RedisCacheConfiguration
- DEFAULT_CHARSET - Static variable in class org.springframework.data.redis.serializer.Jackson2JsonRedisSerializer
-
Deprecated, for removal: This API element is subject to removal in a future version.since 3.0 for removal.
- DEFAULT_ENABLE_TIME_TO_IDLE_EXPIRATION - Static variable in class org.springframework.data.redis.cache.RedisCacheConfiguration
- DEFAULT_PORT - Static variable in class org.springframework.data.redis.connection.RedisNode
- DEFAULT_RECOVERY_INTERVAL - Static variable in class org.springframework.data.redis.listener.RedisMessageListenerContainer
-
The default recovery interval: 5000 ms = 5 seconds.
- DEFAULT_SENTINEL_PORT - Static variable in class org.springframework.data.redis.connection.RedisNode
- 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: "RedisMessageListenerContainer-".
- 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
- DEFAULT_USE_PREFIX - Static variable in class org.springframework.data.redis.cache.RedisCacheConfiguration
- defaultCacheConfig() - Static method in class org.springframework.data.redis.cache.RedisCacheConfiguration
-
Default
RedisCacheConfiguration
using the following: key expiration eternal cache null values yes prefix cache keys yes default prefix [the actual cache name] key serializerStringRedisSerializer
value serializerJdkSerializationRedisSerializer
conversion serviceDefaultFormattingConversionService
withdefault
cache key converters - defaultCacheConfig(ClassLoader) - Static method in class org.springframework.data.redis.cache.RedisCacheConfiguration
-
Create default
RedisCacheConfiguration
givenClassLoader
using the following: key expiration eternal cache null values yes prefix cache keys yes default prefix [the actual cache name] key serializerStringRedisSerializer
value serializerJdkSerializationRedisSerializer
conversion serviceDefaultFormattingConversionService
withdefault
cache key converters - defaultConfiguration() - Static method in interface org.springframework.data.redis.connection.jedis.JedisClientConfiguration
-
Creates a default
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 OptionsClientOptions
with enabledTimeoutOptions
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 OptionsClientOptions
with enabledTimeoutOptions
Client Resources none Client name none Read From none Connect Timeout 60 Seconds Shutdown Timeout 100 Milliseconds Shutdown Quiet Period 100 Milliseconds pool config defaultGenericObjectPoolConfig
- DefaultedRedisClusterConnection - Interface in org.springframework.data.redis.connection
-
Deprecated.
- DefaultedRedisConnection - Interface in org.springframework.data.redis.connection
-
Deprecated.
- 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
-
Default implementation of
ReactiveScriptExecutor
. - DefaultReactiveScriptExecutor(ReactiveRedisConnectionFactory, RedisSerializationContext<K, ?>) - Constructor for class org.springframework.data.redis.core.script.DefaultReactiveScriptExecutor
-
Creates a new
DefaultReactiveScriptExecutor
givenReactiveRedisConnectionFactory
andRedisSerializationContext
. - DefaultRedisList<E> - Class in org.springframework.data.redis.support.collections
-
Default implementation for
RedisList
. - DefaultRedisList(String, RedisOperations<String, E>) - Constructor for class org.springframework.data.redis.support.collections.DefaultRedisList
-
Constructs a new, uncapped
DefaultRedisList
instance. - DefaultRedisList(String, RedisOperations<String, E>, int) - Constructor for class org.springframework.data.redis.support.collections.DefaultRedisList
-
Constructs a new
DefaultRedisList
instance constrained to the givenmax size
. - DefaultRedisList(BoundListOperations<String, E>) - Constructor for class org.springframework.data.redis.support.collections.DefaultRedisList
-
Constructs a new, uncapped
DefaultRedisList
instance. - DefaultRedisList(BoundListOperations<String, E>, int) - Constructor for class org.springframework.data.redis.support.collections.DefaultRedisList
-
Constructs a new
DefaultRedisList
instance constrained to the givenmax size
. - DefaultRedisMap<K,
V> - Class in org.springframework.data.redis.support.collections -
Default implementation for
RedisMap
. - DefaultRedisMap(String, RedisOperations<String, ?>) - Constructor for class org.springframework.data.redis.support.collections.DefaultRedisMap
-
Constructs a new
DefaultRedisMap
instance. - DefaultRedisMap(BoundHashOperations<String, K, V>) - Constructor for class org.springframework.data.redis.support.collections.DefaultRedisMap
-
Constructs a new
DefaultRedisMap
instance. - DefaultRedisScript<T> - Class in org.springframework.data.redis.core.script
-
Default implementation of
RedisScript
. - DefaultRedisScript() - Constructor for class org.springframework.data.redis.core.script.DefaultRedisScript
-
Creates a new
DefaultRedisScript
- DefaultRedisScript(String) - Constructor for class org.springframework.data.redis.core.script.DefaultRedisScript
-
Creates a new
DefaultRedisScript
- DefaultRedisScript(String, Class<T>) - Constructor for class org.springframework.data.redis.core.script.DefaultRedisScript
-
Creates a new
DefaultRedisScript
- DefaultRedisSet<E> - Class in org.springframework.data.redis.support.collections
-
Default implementation for
RedisSet
. - DefaultRedisSet(String, RedisOperations<String, E>) - Constructor for class org.springframework.data.redis.support.collections.DefaultRedisSet
-
Constructs a new
DefaultRedisSet
instance. - DefaultRedisSet(BoundSetOperations<String, E>) - Constructor for class org.springframework.data.redis.support.collections.DefaultRedisSet
-
Constructs a new
DefaultRedisSet
instance. - DefaultRedisTypeMapper - Class in org.springframework.data.redis.core.convert
-
Default implementation of
RedisTypeMapper
allowing configuration of the key to lookup and store type information viaBucket.BucketPropertyPath
in buckets. - DefaultRedisTypeMapper() - Constructor for class org.springframework.data.redis.core.convert.DefaultRedisTypeMapper
-
Create a new
DefaultRedisTypeMapper
usingDefaultRedisTypeMapper.DEFAULT_TYPE_KEY
to exchange type hints. - DefaultRedisTypeMapper(String) - Constructor for class org.springframework.data.redis.core.convert.DefaultRedisTypeMapper
-
Create a new
DefaultRedisTypeMapper
giventypeKey
to exchange type hints. - DefaultRedisTypeMapper(String, List<? extends TypeInformationMapper>) - Constructor for class org.springframework.data.redis.core.convert.DefaultRedisTypeMapper
-
Create a new
DefaultRedisTypeMapper
giventypeKey
to exchange type hints andList
ofTypeInformationMapper
. - DefaultRedisTypeMapper(String, MappingContext<? extends PersistentEntity<?, ?>, ?>) - Constructor for class org.springframework.data.redis.core.convert.DefaultRedisTypeMapper
- DefaultRedisZSet<E> - Class in org.springframework.data.redis.support.collections
-
Default implementation for
RedisZSet
. - DefaultRedisZSet(String, RedisOperations<String, E>) - Constructor for class org.springframework.data.redis.support.collections.DefaultRedisZSet
-
Constructs a new
DefaultRedisZSet
instance with a default score of 1. - DefaultRedisZSet(String, RedisOperations<String, E>, double) - Constructor for class org.springframework.data.redis.support.collections.DefaultRedisZSet
-
Constructs a new
DefaultRedisZSet
instance. - DefaultRedisZSet(BoundZSetOperations<String, E>) - Constructor for class org.springframework.data.redis.support.collections.DefaultRedisZSet
-
Constructs a new
DefaultRedisZSet
instance with a default score of '1'. - DefaultRedisZSet(BoundZSetOperations<String, E>, double) - Constructor for class org.springframework.data.redis.support.collections.DefaultRedisZSet
-
Constructs a new
DefaultRedisZSet
instance. - DefaultScriptExecutor<K> - Class in org.springframework.data.redis.core.script
-
Default implementation of
ScriptExecutor
. - DefaultScriptExecutor(RedisTemplate<K, ?>) - Constructor for class org.springframework.data.redis.core.script.DefaultScriptExecutor
- DefaultSortParameters - Class in org.springframework.data.redis.connection
-
Default implementation for
SortParameters
. - DefaultSortParameters() - 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. - DefaultSortParameters(SortParameters.Range, 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
-
Default implementation of
StringRedisConnection
. - 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
-
Default implementation for
StringRedisConnection.StringTuple
interface. - DefaultStringTuple(byte[], String, Double) - Constructor for class org.springframework.data.redis.connection.DefaultStringTuple
-
Constructs a new
DefaultStringTuple
instance. - DefaultStringTuple(String, double) - Constructor for class org.springframework.data.redis.connection.DefaultStringTuple
-
Constructs a new
DefaultStringTuple
instance. - DefaultStringTuple(Tuple, String) - Constructor for class org.springframework.data.redis.connection.DefaultStringTuple
-
Constructs a new
DefaultStringTuple
instance. - DefaultTuple - Class in org.springframework.data.redis.connection.zset
-
Default implementation for
Tuple
interface. - DefaultTuple(byte[], Double) - Constructor for class org.springframework.data.redis.connection.zset.DefaultTuple
-
Constructs a new
DefaultTuple
. - 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. - defaultTyping(boolean) - Method in class org.springframework.data.redis.serializer.GenericJackson2JsonRedisSerializer.GenericJackson2JsonRedisSerializerBuilder
-
Enable or disable default typing.
- del(byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.keyCommands()
. - del(byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- del(byte[]...) - Method in interface org.springframework.data.redis.connection.RedisKeyCommands
-
Delete given
keys
. - del(String) - Method in class org.springframework.data.redis.core.PartialUpdate
-
Remove the value reachable via given path.
- del(String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- del(String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Delete given
keys
. - 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 - Enum constant in enum class org.springframework.data.redis.core.PartialUpdate.UpdateCommand
- DEL - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- delete(H) - Method in interface org.springframework.data.redis.core.ReactiveHashOperations
-
Removes the given key.
- delete(H, Object...) - Method in interface org.springframework.data.redis.core.HashOperations
-
Delete given hash
hashKeys
. - delete(Object...) - Method in interface org.springframework.data.redis.core.BoundHashOperations
-
Delete given hash
keys
at the bound 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(String...) - Method in interface org.springframework.data.redis.core.BoundStreamOperations
-
Removes the specified entries from the stream.
- delete(Collection<K>) - Method in interface org.springframework.data.redis.core.RedisOperations
-
Delete given
keys
. - delete(Collection<K>) - Method in class org.springframework.data.redis.core.RedisTemplate
- 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(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.ReactiveSetOperations
-
Removes the given key.
- 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(K) - Method in interface org.springframework.data.redis.core.RedisOperations
-
Delete given
key
. - delete(K) - Method in class org.springframework.data.redis.core.RedisTemplate
- delete(K...) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
-
Delete given
key
. - delete(K...) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
- delete(K, String...) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
-
Removes the specified records from the stream.
- delete(K, String...) - Method in interface org.springframework.data.redis.core.StreamOperations
-
Removes the specified records from the stream.
- delete(K, RecordId...) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
-
Removes the specified records from the stream.
- delete(K, RecordId...) - Method in interface org.springframework.data.redis.core.StreamOperations
-
Removes the specified records from the stream.
- delete(Publisher<K>) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
-
Delete given
keys
. - delete(Publisher<K>) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
- delete(Record<K, ?>) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
-
Removes a given
Record
from the stream. - delete(Record<K, ?>) - Method in interface org.springframework.data.redis.core.StreamOperations
-
Removes a given
Record
from the stream. - DELETE_CONSUMER - Enum constant in enum class org.springframework.data.redis.connection.ReactiveStreamCommands.GroupCommand.GroupCommandAction
- 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(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.
- 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.
- DELIMITER - Static variable in class org.springframework.data.redis.core.convert.MappingRedisConverter.BinaryKeyspaceIdentifier
- DELIMITER - Static variable in class org.springframework.data.redis.core.convert.MappingRedisConverter.KeyspaceIdentifier
- desc() - Method in class org.springframework.data.redis.connection.DefaultSortParameters
- DESC - Enum constant in enum class org.springframework.data.redis.connection.SortParameters.Order
- descendingIterator() - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- deserialize(byte[]) - 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(byte[]) - Method in class org.springframework.data.redis.serializer.StringRedisSerializer
- deserialize(byte[], Class<T>) - Method in class org.springframework.data.redis.serializer.GenericJackson2JsonRedisSerializer
- deserialize(Collection<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(Map<byte[], byte[]>, RedisSerializer<HK>, RedisSerializer<HV>) - 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(Set<byte[]>, RedisSerializer<T>) - Static method in class org.springframework.data.redis.serializer.SerializationUtils
- 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<? 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(RedisSerializer<T>) - Method in interface org.springframework.data.redis.connection.stream.ByteBufferRecord
- deserialize(RedisSerializer<T>) - Method in interface org.springframework.data.redis.connection.stream.ByteRecord
- deserializeCacheValue(byte[]) - Method in class org.springframework.data.redis.cache.RedisCache
-
Deserialize the given the array of bytes to the actual
cache value
. - deserializeRecord(ByteBufferRecord) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
-
Deserialize a
ByteBufferRecord
using the configured serialization context into aMapRecord
. - deserializeRecord(ByteRecord) - Method in interface org.springframework.data.redis.core.StreamOperations
-
Deserialize a
ByteRecord
using the configured serializers into aMapRecord
. - 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
-
Converter
capable of deserializingGeoResults
. - 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.LettuceConnectionFactory
- 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 the container and stop it.
- destroy(KeyValueOperations, CreationalContext<KeyValueOperations>) - Method in class org.springframework.data.redis.repository.cdi.RedisKeyValueTemplateBean
- destroy(RedisKeyValueAdapter, CreationalContext<RedisKeyValueAdapter>) - Method in class org.springframework.data.redis.repository.cdi.RedisKeyValueAdapterBean
- destroy(T, CreationalContext<T>) - Method in class org.springframework.data.redis.repository.cdi.CdiBean
- DESTROY - Enum constant in enum class org.springframework.data.redis.connection.ReactiveStreamCommands.GroupCommand.GroupCommandAction
- 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(Collection<? extends RedisSet<?>>) - Method in class org.springframework.data.redis.support.collections.DefaultRedisSet
- diff(Collection<? extends RedisSet<?>>) - Method in interface org.springframework.data.redis.support.collections.RedisSet
-
Diff this set and other
RedisSet
s. - diff(Collection<? extends RedisZSet<?>>) - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
- diff(Collection<? extends RedisZSet<?>>) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
-
Diff this set and other
RedisZSet
s. - diff(Collection<K>) - Method in interface org.springframework.data.redis.core.BoundSetOperations
-
Deprecated.since 3.0, use
BoundSetOperations.difference(Collection)
instead to follow a consistent method naming scheme. - diff(K) - Method in interface org.springframework.data.redis.core.BoundSetOperations
-
Deprecated.since 3.0, use
BoundSetOperations.difference(Object)
instead to follow a consistent method naming scheme. - diff(RedisSet<?>) - Method in class org.springframework.data.redis.support.collections.DefaultRedisSet
- diff(RedisSet<?>) - Method in interface org.springframework.data.redis.support.collections.RedisSet
-
Diff this set and another
RedisSet
. - diff(RedisZSet<?>) - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
- diff(RedisZSet<?>) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
-
Diff this set and another
RedisZSet
. - diffAndStore(Collection<? extends RedisSet<?>>, String) - Method in class org.springframework.data.redis.support.collections.DefaultRedisSet
- diffAndStore(Collection<? extends RedisSet<?>>, String) - Method in interface org.springframework.data.redis.support.collections.RedisSet
- diffAndStore(Collection<? extends RedisZSet<?>>, String) - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
- diffAndStore(Collection<? extends RedisZSet<?>>, String) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
- diffAndStore(Collection<K>, K) - Method in interface org.springframework.data.redis.core.BoundSetOperations
-
Deprecated.since 3.0, use
BoundSetOperations.differenceAndStore(Collection, Object)
instead to follow a consistent method naming scheme. - diffAndStore(K, K) - Method in interface org.springframework.data.redis.core.BoundSetOperations
-
Deprecated.since 3.0, use
BoundSetOperations.differenceAndStore(Object, Object)
instead to follow a consistent method naming scheme.. - diffAndStore(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(RedisZSet<?>, String) - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
- diffAndStore(RedisZSet<?>, String) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
- difference(Collection<K>) - Method in interface org.springframework.data.redis.core.BoundSetOperations
-
Diff all sets for given the bound key and
keys
. - difference(Collection<K>) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Diff sorted
sets
. - difference(Collection<K>) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
-
Diff all sets for given
keys
. - difference(Collection<K>) - Method in interface org.springframework.data.redis.core.SetOperations
-
Diff all sets for given
keys
. - difference(K) - Method in interface org.springframework.data.redis.core.BoundSetOperations
-
Diff all sets for given the bound key and
key
. - difference(K) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Diff sorted
sets
. - difference(K, Collection<K>) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
-
Diff all sets for given
key
andotherKeys
. - difference(K, Collection<K>) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Diff sorted
sets
. - difference(K, Collection<K>) - Method in interface org.springframework.data.redis.core.SetOperations
-
Diff all sets for given
key
andotherKeys
. - difference(K, Collection<K>) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Diff sorted
sets
. - difference(K, K) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
-
Diff all sets for given
key
andotherKey
. - difference(K, K) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Diff sorted
sets
. - difference(K, K) - Method in interface org.springframework.data.redis.core.SetOperations
-
Diff all sets for given
key
andotherKey
. - difference(K, K) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Diff sorted
sets
. - differenceAndStore(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 indestKey
. - differenceAndStore(Collection<K>, K) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Diff sorted
sets
and store result in destinationdestKey
. - differenceAndStore(Collection<K>, K) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
-
Diff all sets for given
keys
and store result indestKey
. - differenceAndStore(Collection<K>, K) - Method in interface org.springframework.data.redis.core.SetOperations
-
Diff all sets for given
keys
and store result indestKey
. - differenceAndStore(K, Collection<K>, K) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
-
Diff all sets for given
key
andotherKeys
and store result indestKey
. - differenceAndStore(K, Collection<K>, K) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Diff sorted
sets
and store result in destinationdestKey
. - differenceAndStore(K, Collection<K>, K) - Method in interface org.springframework.data.redis.core.SetOperations
-
Diff all sets for given
key
andotherKeys
and store result indestKey
. - differenceAndStore(K, Collection<K>, K) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Diff sorted
sets
and store result in destinationdestKey
. - differenceAndStore(K, K) - Method in interface org.springframework.data.redis.core.BoundSetOperations
-
Diff all sets for given the bound key and
keys
and store result indestKey
. - differenceAndStore(K, K) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Diff sorted
sets
and store result in destinationdestKey
. - differenceAndStore(K, K, K) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
-
Diff all sets for given
key
andotherKey
and store result indestKey
. - differenceAndStore(K, K, K) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Diff sorted
sets
and store result in destinationdestKey
. - differenceAndStore(K, K, K) - Method in interface org.springframework.data.redis.core.SetOperations
-
Diff all sets for given
key
andotherKey
and store result indestKey
. - differenceWithScores(Collection<K>) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Diff sorted
sets
. - differenceWithScores(K) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Diff sorted
sets
. - differenceWithScores(K, Collection<K>) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Diff sorted
sets
. - differenceWithScores(K, Collection<K>) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Diff sorted
sets
. - differenceWithScores(K, K) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Diff sorted
sets
. - differenceWithScores(K, K) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Diff sorted
sets
. - diffWithScores(Collection<? extends RedisZSet<?>>) - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
- diffWithScores(Collection<? extends RedisZSet<?>>) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
-
Diff this set and other
RedisZSet
s. - diffWithScores(RedisZSet<?>) - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
- diffWithScores(RedisZSet<?>) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
-
Diff this set and another
RedisZSet
. - DigestUtils - Class in org.springframework.data.redis.core.script
-
Utilties for working with
MessageDigest
- 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
RedisCache
creation at runtime for non-configured, undeclared 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 all commands issued after
RedisTxCommands.multi()
. - discard() - Method in interface org.springframework.data.redis.core.RedisOperations
-
Discard all commands issued after
RedisOperations.multi()
. - discard() - Method in class org.springframework.data.redis.core.RedisTemplate
- DISCARD - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- DISCONNECTED - Enum constant in enum class org.springframework.data.redis.connection.RedisClusterNode.LinkState
- distance(K, M, M) - Method in interface org.springframework.data.redis.core.GeoOperations
-
Get the
Distance
between member1 and member2. - 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.GeoOperations
- distance(K, M, M, Metric) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
- 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
- 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(long) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
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 atkey
. - distinctRandomMembers(K, long) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Get
count
distinct random elements from set atkey
. - distinctRandomMembers(K, long) - Method in interface org.springframework.data.redis.core.SetOperations
-
Get
count
distinct random elements from set atkey
. - distinctRandomMembers(K, long) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Get
count
distinct random elements from set atkey
. - distinctRandomMembersWithScore(long) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Get
count
distinct random elements with their score from set at the bound key. - distinctRandomMembersWithScore(K, long) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Get
count
distinct random elements with their score from set atkey
. - distinctRandomMembersWithScore(K, long) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Get
count
distinct random elements with their score from set atkey
. - DO_NOT_CACHE_NULL_VALUES - Static variable in class org.springframework.data.redis.cache.RedisCacheConfiguration
- DO_NOT_USE_PREFIX - Static variable in class org.springframework.data.redis.cache.RedisCacheConfiguration
- 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
-
Customization hook for cleaning up resources on when calling
ScanCursor.close()
. - 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
-
Customization hook for
LettuceClusterConnection
creation. - doCreateLettuceConnection(StatefulRedisConnection<byte[], byte[]>, LettuceConnectionProvider, long, int) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
Customization hook for
LettuceConnection
creation. - doCreateSubscription(MessageListener, StatefulRedisPubSubConnection<byte[], byte[]>, LettuceConnectionProvider) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
-
Customization hook to create a
LettuceSubscription
. - 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
-
Actually obtain a
RedisConnection
from the givenRedisConnectionFactory
. - 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
-
Gets called by
ReactiveRedisTemplate.execute(ReactiveRedisCallback)
with an active Redis connection. - doInRedis(RedisClusterConnection) - Method in interface org.springframework.data.redis.core.RedisClusterCallback
-
Gets called by
ClusterOperations
with an active Redis connection. - doInRedis(RedisConnection) - Method in interface org.springframework.data.redis.core.RedisCallback
-
Method called by
RedisTemplate
with an activeRedisConnection
. - doInRedis(RedisKeyValueAdapter) - Method in class org.springframework.data.redis.core.RedisKeyValueTemplate.RedisKeyValueCallback
- doOpen(long) - Method in class org.springframework.data.redis.core.ScanCursor
-
Deprecated, for removal: This API element is subject to removal in a future version.since 3.3.0, use
ScanCursor.doOpen(CursorId)
instead. - doOpen(Cursor.CursorId) - Method in class org.springframework.data.redis.core.ScanCursor
-
Customization hook when calling
ScanCursor.open()
. - 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(byte[], Cursor.CursorId, ScanOptions) - Method in class org.springframework.data.redis.core.KeyBoundCursor
- doScan(long, ScanOptions) - Method in class org.springframework.data.redis.core.KeyBoundCursor
- doScan(long, ScanOptions) - Method in class org.springframework.data.redis.core.ScanCursor
-
Deprecated.since 3.3.0, cursorId, can exceed
Long.MAX_VALUE
. - doScan(Cursor.CursorId, ScanOptions) - Method in class org.springframework.data.redis.core.KeyBoundCursor
- doScan(Cursor.CursorId, 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.
- doWithOperations(ReactiveRedisOperations<K, V>) - Method in interface org.springframework.data.redis.core.ReactiveRedisSessionCallback
-
Gets called by
ReactiveRedisOperations.executeInSession(ReactiveRedisSessionCallback)
with an active Redis connection. - DOWN_AFTER_MILLISECONDS - Enum constant in enum class org.springframework.data.redis.connection.RedisServer.INFO
- drainTo(Collection<? super E>) - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- drainTo(Collection<? super E>, int) - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- dump(byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.keyCommands()
. - 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.
- DUMP - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- duration() - Method in record class org.springframework.data.redis.cache.FixedDurationTtlFunction
-
Returns the value of the
duration
record component.
E
- echo(byte[]) - 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 class org.springframework.data.redis.connection.DefaultStringRedisConnection
- echo(String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Returns
message
via server roundtrip. - ECHO - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- element() - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- elementAt(long) - Static method in class org.springframework.data.redis.connection.ReactiveListCommands.LIndexCommand
-
Creates a new
ReactiveListCommands.LIndexCommand
given an index. - elementAt(long) - Static method in class org.springframework.data.redis.connection.ReactiveListCommands.LSetCommand
-
Creates a new
ReactiveListCommands.LSetCommand
given an index. - elements() - Method in class org.springframework.data.redis.support.collections.RedisProperties
- empty() - Static method in class org.springframework.data.redis.connection.RedisClusterNode.SlotRange
-
Factory method used to construct a new, empty
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
-
Creates an empty
StreamReadOptions
instance. - enableCreateOnMissingCache() - Method in class org.springframework.data.redis.cache.RedisCacheManager.RedisCacheManagerBuilder
-
Enables
RedisCache
creation at runtime for unconfigured, undeclared caches. - enableKeyspaceEvents() - Element in annotation interface org.springframework.data.redis.repository.configuration.EnableRedisRepositories
-
Configure usage of
KeyExpirationEventMessageListener
. - EnableRedisRepositories - Annotation Interface in org.springframework.data.redis.repository.configuration
-
Annotation to activate Redis repositories.
- enableStatistics() - Method in class org.springframework.data.redis.cache.RedisCacheManager.RedisCacheManagerBuilder
-
Enables cache statistics.
- enableTimeToIdle() - Method in class org.springframework.data.redis.cache.RedisCacheConfiguration
-
Enables time-to-idle (TTI) expiration on
Cache
read operations, such asCache.get(Object)
. - 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
-
Deprecated.in favor of
RedisCommandsProvider.keyCommands()
. - encodingOf(byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- 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 class org.springframework.data.redis.connection.DefaultStringRedisConnection
- 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
. - 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
. - 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
- entryOf(K, V) - Static method in class org.springframework.data.redis.connection.convert.Converters
- 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.
- entryTtl(RedisCacheWriter.TtlFunction) - Method in class org.springframework.data.redis.cache.RedisCacheConfiguration
-
Set the
TTL function
to compute the time to live for cache entries. - equals(Object) - Method in record class org.springframework.data.redis.cache.FixedDurationTtlFunction
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in class org.springframework.data.redis.connection.BitFieldSubCommands.AbstractBitFieldSubCommand
- equals(Object) - Method in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldIncrBy
- equals(Object) - Method in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldSet
- equals(Object) - Method in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldType
- equals(Object) - Method in class org.springframework.data.redis.connection.BitFieldSubCommands
- equals(Object) - Method in class org.springframework.data.redis.connection.BitFieldSubCommands.Offset
- equals(Object) - Method in class org.springframework.data.redis.connection.ClusterCommandExecutor.NodeResult
- equals(Object) - Method in class org.springframework.data.redis.connection.DefaultStringTuple
- 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.RedisClusterConfiguration
- 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.RedisSentinelConfiguration
- equals(Object) - Method in class org.springframework.data.redis.connection.RedisSocketConfiguration
- equals(Object) - Method in class org.springframework.data.redis.connection.RedisStandaloneConfiguration
- equals(Object) - Method in class org.springframework.data.redis.connection.RedisStaticMasterReplicaConfiguration
- equals(Object) - Method in class org.springframework.data.redis.connection.RedisStreamCommands.XAddOptions
- 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.connection.zset.DefaultTuple
- equals(Object) - Method in class org.springframework.data.redis.connection.zset.Weights
- 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.Cursor.CursorId
- 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.Expiration
- equals(Object) - Method in class org.springframework.data.redis.core.types.RedisClientInfo
- equals(Object) - Method in class org.springframework.data.redis.domain.geo.BoundingBox
- equals(Object) - Method in class org.springframework.data.redis.domain.geo.GeoLocation
- equals(Object) - Method in class org.springframework.data.redis.domain.geo.GeoReference.GeoCoordinateReference
- equals(Object) - Method in class org.springframework.data.redis.domain.geo.GeoReference.GeoMemberReference
- equals(Object) - Method in class org.springframework.data.redis.listener.ChannelTopic
- 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
- errorHandler(ErrorHandler) - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.ConsumerStreamReadRequestBuilder
-
Configure a
ErrorHandler
to be notified onread, deserialization, and listener errors
. - errorHandler(ErrorHandler) - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamMessageListenerContainerOptionsBuilder
-
Configure a
ErrorHandler
to be notified onerrors
. - errorHandler(ErrorHandler) - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamReadRequestBuilder
-
Configure a
ErrorHandler
to be notified onerrors
. - eval(byte[], ReturnType, int, byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.scriptingCommands()
. - eval(byte[], ReturnType, int, byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- eval(byte[], ReturnType, int, byte[]...) - Method in interface org.springframework.data.redis.connection.RedisScriptingCommands
-
Evaluate given
script
. - 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(String, ReturnType, int, String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Evaluate given
script
. - eval(ByteBuffer, ReturnType, int, ByteBuffer...) - Method in interface org.springframework.data.redis.connection.ReactiveScriptingCommands
-
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
- EVAL - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- evalSha(byte[], ReturnType, int, byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.scriptingCommands()
. - evalSha(byte[], ReturnType, int, byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- evalSha(byte[], ReturnType, int, byte[]...) - Method in interface org.springframework.data.redis.connection.RedisScriptingCommands
-
Evaluate given
scriptSha
. - evalSha(String, ReturnType, int, byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.scriptingCommands()
. - evalSha(String, ReturnType, int, byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- evalSha(String, ReturnType, int, byte[]...) - Method in interface org.springframework.data.redis.connection.RedisScriptingCommands
-
Evaluate given
scriptSha
. - 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, String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Evaluate given
scriptSha
. - evalSha(String, ReturnType, int, ByteBuffer...) - Method in interface org.springframework.data.redis.connection.ReactiveScriptingCommands
-
Evaluate given
scriptSha
. - EVALSHA - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- EVENTS - Enum constant in enum class org.springframework.data.redis.core.types.RedisClientInfo.INFO
- 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
- ExceptionTranslationStrategy - Interface in org.springframework.data.redis
-
Potentially translates an
Exception
into appropriateDataAccessException
. - excludeFilters() - Element in annotation interface org.springframework.data.redis.repository.configuration.EnableRedisRepositories
-
Specifies which types are not eligible for component scanning.
- 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
-
Executes all queued commands in a transaction started with
RedisTxCommands.multi()
. - exec() - Method in interface org.springframework.data.redis.core.RedisOperations
-
Executes all queued commands in a transaction started with
RedisOperations.multi()
. - 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 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(RedisSerializer<?>) - Method in class org.springframework.data.redis.core.RedisTemplate
- EXEC - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- execRaw() - Method in class org.springframework.data.redis.core.RedisTemplate
- execute(Object[]) - Method in class org.springframework.data.redis.repository.query.RedisPartTreeQuery
- execute(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- 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(String, byte[]...) - 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[]...) - 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, byte[]...) - Method in interface org.springframework.data.redis.connection.RedisCommands
-
Native or raw execution of the given Redis command along with the given arguments.
- execute(String, byte[], Collection<byte[]>) - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
- 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, 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, String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- 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, 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 allargs
on each invocation. - execute(ReactiveRedisCallback<T>) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
-
Executes the given action within a Redis connection.
- 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(RedisCallback<T>) - Method in class org.springframework.data.redis.core.RedisKeyValueAdapter
-
Execute
RedisCallback
via underlyingRedisOperations
. - execute(RedisCallback<T>) - Method in interface org.springframework.data.redis.core.RedisOperations
-
Executes the given action within a Redis connection.
- 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(RedisOperations<K, V>) - Method in interface org.springframework.data.redis.core.SessionCallback
-
Executes all the given operations inside the same session.
- execute(RedisScript<T>) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
-
Executes the given
RedisScript
. - execute(RedisScript<T>) - Method in interface org.springframework.data.redis.core.script.ReactiveScriptExecutor
-
Execute the given
RedisScript
- execute(RedisScript<T>, List<K>) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
-
Executes the given
RedisScript
. - execute(RedisScript<T>, List<K>) - Method in interface org.springframework.data.redis.core.script.ReactiveScriptExecutor
-
Execute the given
RedisScript
- execute(RedisScript<T>, List<K>, Object...) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
-
Executes the given
RedisScript
- execute(RedisScript<T>, List<K>, Object...) - Method in interface org.springframework.data.redis.core.RedisOperations
-
Executes the given
RedisScript
- execute(RedisScript<T>, List<K>, Object...) - Method in class org.springframework.data.redis.core.RedisTemplate
- execute(RedisScript<T>, List<K>, Object...) - Method in class org.springframework.data.redis.core.script.DefaultScriptExecutor
- execute(RedisScript<T>, List<K>, Object...) - Method in interface org.springframework.data.redis.core.script.ReactiveScriptExecutor
-
Executes the given
RedisScript
- execute(RedisScript<T>, List<K>, Object...) - Method in interface org.springframework.data.redis.core.script.ScriptExecutor
-
Executes the given
RedisScript
- execute(RedisScript<T>, List<K>, List<?>) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
-
Executes the given
RedisScript
- execute(RedisScript<T>, List<K>, List<?>) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
- execute(RedisScript<T>, List<K>, List<?>) - Method in class org.springframework.data.redis.core.script.DefaultReactiveScriptExecutor
- execute(RedisScript<T>, List<K>, List<?>) - Method in interface org.springframework.data.redis.core.script.ReactiveScriptExecutor
-
Executes the given
RedisScript
- execute(RedisScript<T>, List<K>, List<?>, RedisElementWriter<?>, RedisElementReader<T>) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
-
Executes the given
RedisScript
, using the providedRedisSerializer
s to serialize the script arguments and result. - execute(RedisScript<T>, List<K>, List<?>, RedisElementWriter<?>, RedisElementReader<T>) - 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.script.DefaultReactiveScriptExecutor
- execute(RedisScript<T>, List<K>, List<?>, RedisElementWriter<?>, RedisElementReader<T>) - Method in interface org.springframework.data.redis.core.script.ReactiveScriptExecutor
-
Executes the given
RedisScript
, using the providedRedisSerializer
s to serialize the script arguments and result. - execute(RedisScript<T>, RedisSerializer<?>, RedisSerializer<T>, List<K>, Object...) - Method in interface org.springframework.data.redis.core.RedisOperations
-
Executes the given
RedisScript
, using the providedRedisSerializer
s to serialize the script arguments and result. - execute(RedisScript<T>, RedisSerializer<?>, RedisSerializer<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.script.DefaultScriptExecutor
- execute(RedisScript<T>, RedisSerializer<?>, RedisSerializer<T>, List<K>, Object...) - Method in interface org.springframework.data.redis.core.script.ScriptExecutor
-
Executes the given
RedisScript
, using the providedRedisSerializer
s to serialize the script arguments and result. - execute(SessionCallback<T>) - Method in interface org.springframework.data.redis.core.RedisOperations
-
Executes a Redis session.
- execute(SessionCallback<T>) - Method in class org.springframework.data.redis.core.RedisTemplate
- 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
-
Run
ClusterCommandExecutor.ClusterCommandCallback
on all reachable master nodes. - executeCommandOnArbitraryNode(ClusterCommandExecutor.ClusterCommandCallback<?, T>) - Method in class org.springframework.data.redis.connection.ClusterCommandExecutor
-
Run
ClusterCommandExecutor.ClusterCommandCallback
on a random node. - executeCommandOnSingleNode(ClusterCommandExecutor.ClusterCommandCallback<S, T>, RedisClusterNode) - Method in class org.springframework.data.redis.connection.ClusterCommandExecutor
- executeInSession(ReactiveRedisSessionCallback<K, V, T>) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
-
Executes the given action within a Redis session using the same
ReactiveRedisConnection
. - executeInSession(ReactiveRedisSessionCallback<K, V, T>) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
- executeMultiKeyCommand(ClusterCommandExecutor.MultiKeyClusterCommandCallback<S, T>, Iterable<byte[]>) - Method in class org.springframework.data.redis.connection.ClusterCommandExecutor
-
Run
ClusterCommandExecutor.MultiKeyClusterCommandCallback
with on a curated set of nodes serving one or more keys. - 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<?>) - Method in class org.springframework.data.redis.core.RedisTemplate
- 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(RedisCallback<?>, RedisSerializer<?>) - Method in class org.springframework.data.redis.core.RedisTemplate
- executePipelined(SessionCallback<?>) - Method in interface org.springframework.data.redis.core.RedisOperations
-
Executes the given Redis session on a pipelined connection.
- executePipelined(SessionCallback<?>) - Method in class org.springframework.data.redis.core.RedisTemplate
- 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<?>, 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
-
Deprecated.in favor of
RedisCommandsProvider.keyCommands()
. - exists(byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- 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.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.keyCommands()
. - exists(byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- exists(byte[]...) - Method in interface org.springframework.data.redis.connection.RedisKeyCommands
-
Count how many of the given
keys
exist. - exists(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- exists(String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Determine if given
key
exists. - exists(String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- exists(String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Count how many of the given
keys
exist. - 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(Example<S>) - Method in class org.springframework.data.redis.repository.support.QueryByExampleRedisExecutor
- EXISTS - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- Expiration - Class in org.springframework.data.redis.core.types
- Expiration(long, TimeUnit) - Constructor for class org.springframework.data.redis.core.types.Expiration
-
Creates new
Expiration
. - expire(byte[], long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.keyCommands()
. - expire(byte[], long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- expire(byte[], long) - Method in interface org.springframework.data.redis.connection.RedisKeyCommands
-
Set time to live for given
key
in seconds. - expire(long, TimeUnit) - Method in interface org.springframework.data.redis.core.BoundKeyOperations
-
Sets the key time-to-live/expiration.
- 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
- expire(String, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- expire(String, long) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Set time to live for given
key
in seconds. - expire(ByteBuffer, Duration) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
-
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(K, long, TimeUnit) - 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(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, Duration) - Method in interface org.springframework.data.redis.core.RedisOperations
-
Set time to live for given
key
. - expire(Publisher<ReactiveKeyCommands.ExpireCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
-
Expire keys one by one.
- EXPIRE - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- expireAt(byte[], long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.keyCommands()
. - expireAt(byte[], long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- 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 class org.springframework.data.redis.connection.DefaultStringRedisConnection
- expireAt(String, long) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Set the expiration for given
key
as a UNIX timestamp. - expireAt(ByteBuffer, Instant) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
-
Set the expiration for given
key
as a UNIX timestamp. - expireAt(Instant) - Method in interface org.springframework.data.redis.core.BoundKeyOperations
-
Sets the key time-to-live/expiration.
- expireAt(Date) - Method in interface org.springframework.data.redis.core.BoundKeyOperations
-
Sets the key time-to-live/expiration.
- 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
- 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, 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 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(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 - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- expiring(Expiration) - Method in class org.springframework.data.redis.connection.ReactiveStringCommands.SetCommand
-
Applies
Expiration
. - 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
-
Deprecated.Since 3.2. Use
ByteUtils.getBytes(ByteBuffer)
instead. - extractMessage(Message) - Method in class org.springframework.data.redis.listener.adapter.MessageListenerAdapter
-
Extract the message body from the given Redis message.
F
- FAIL - Enum constant in enum class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldIncrBy.Overflow
- FAIL - Enum constant in enum class org.springframework.data.redis.connection.RedisClusterNode.Flag
- failover(NamedNode) - Method in class org.springframework.data.redis.connection.jedis.JedisSentinelConnection
- failover(NamedNode) - Method in class org.springframework.data.redis.connection.lettuce.LettuceSentinelConnection
- failover(NamedNode) - Method in interface org.springframework.data.redis.connection.RedisSentinelCommands
-
Force a failover as if the master was not reachable.
- FAILOVER_TIMEOUT - Enum constant in enum class org.springframework.data.redis.connection.RedisServer.INFO
- failsafeCommandLookup(String) - Static method in enum class org.springframework.data.redis.core.RedisCommand
-
Returns the command represented by the given
key
, otherwise returnsRedisCommand.UNKNOWN
if no matching command could be found. - FallbackExceptionTranslationStrategy - Class in org.springframework.data.redis
- FallbackExceptionTranslationStrategy(Converter<Exception, DataAccessException>) - Constructor for class org.springframework.data.redis.FallbackExceptionTranslationStrategy
- feet() - Static method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoDistCommand
-
Creates a new
ReactiveGeoCommands.GeoDistCommand
forRedisGeoCommands.DistanceUnit.FEET
. - FEET - Enum constant in enum class org.springframework.data.redis.connection.RedisGeoCommands.DistanceUnit
- FEET - Enum constant in enum class org.springframework.data.redis.domain.geo.Metrics
- fetchJedisConnector() - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
-
Returns a Jedis instance to be used as a Redis connection.
- field(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveHashCommands.HDelCommand
-
Creates a new
ReactiveHashCommands.HDelCommand
given afield name
. - field(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveHashCommands.HExistsCommand
-
Creates a new
ReactiveHashCommands.HExistsCommand
given afield name
. - field(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveHashCommands.HGetCommand
-
Creates a new
ReactiveHashCommands.HGetCommand
given afield name
. - fields(Collection<ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveHashCommands.HDelCommand
-
Creates a new
ReactiveHashCommands.HDelCommand
given aCollection
of field names. - fields(Collection<ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveHashCommands.HGetCommand
-
Creates a new
ReactiveHashCommands.HGetCommand
given aCollection
of field names. - fieldValues(Map<ByteBuffer, ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveHashCommands.HSetCommand
-
Creates a new
ReactiveHashCommands.HSetCommand
given aMap
of field values. - FILE_DESCRIPTOR - Enum constant in enum class org.springframework.data.redis.core.types.RedisClientInfo.INFO
- find(RedisCallback<?>, Class<T>) - Method in class org.springframework.data.redis.core.RedisKeyValueTemplate
-
Retrieve entities by resolving their ids and converting them into required type.
- findAll(Example<S>) - Method in class org.springframework.data.redis.repository.support.QueryByExampleRedisExecutor
- findAll(Example<S>, Pageable) - Method in class org.springframework.data.redis.repository.support.QueryByExampleRedisExecutor
- findAll(Example<S>, Sort) - Method in class org.springframework.data.redis.repository.support.QueryByExampleRedisExecutor
- findBy(Example<S>, Function<FluentQuery.FetchableFluentQuery<S>, R>) - Method in class org.springframework.data.redis.repository.support.QueryByExampleRedisExecutor
- findOne(Example<S>) - Method in class org.springframework.data.redis.repository.support.QueryByExampleRedisExecutor
- first() - Static method in enum class org.springframework.data.redis.connection.ReactiveListCommands.Direction
-
Alias for
ReactiveListCommands.Direction.LEFT
. - first() - Static method in enum class org.springframework.data.redis.connection.RedisListCommands.Direction
-
Alias for
RedisListCommands.Direction.LEFT
. - first() - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
- first() - Method in interface org.springframework.data.redis.support.collections.RedisZSet
-
Returns the first (lowest) element currently in this sorted set.
- first(long) - Static method in class org.springframework.data.redis.connection.ReactiveListCommands.LRemCommand
-
Creates a new
ReactiveListCommands.LRemCommand
to first count values. - firstEntryId() - Method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoStream
-
The id of the streams first entry.
- FixedDurationTtlFunction - Record Class in org.springframework.data.redis.cache
-
RedisCacheWriter.TtlFunction
implementation returning the given, predeterminedDuration
used for per cache entry time-to-live (TTL) expiration. - FixedDurationTtlFunction(Duration) - Constructor for record class org.springframework.data.redis.cache.FixedDurationTtlFunction
-
Creates an instance of a
FixedDurationTtlFunction
record class. - flags - Variable in class org.springframework.data.redis.connection.RedisGeoCommands.GeoSearchCommandArgs
- FLAGS - Enum constant in enum class org.springframework.data.redis.connection.RedisServer.INFO
- FLAGS - Enum constant in enum class org.springframework.data.redis.core.types.RedisClientInfo.INFO
- floatValue() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicDouble
- floatValue() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicInteger
- floatValue() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicLong
- flushAll() - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.serverCommands()
. - flushAll() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- flushAll() - Method in interface org.springframework.data.redis.connection.ReactiveServerCommands
-
Delete all all keys from all databases.
- flushAll() - Method in interface org.springframework.data.redis.connection.RedisServerCommands
-
Delete all all keys from all databases.
- flushAll(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.DefaultedRedisClusterConnection
-
Deprecated.in favor of
RedisCommandsProvider.serverCommands()
. - flushAll(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.ReactiveClusterServerCommands
-
Delete all all keys from all databases.
- flushAll(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.RedisClusterServerCommands
- flushAll(RedisClusterNode, RedisServerCommands.FlushOption) - Method in interface org.springframework.data.redis.connection.DefaultedRedisClusterConnection
-
Deprecated.in favor of
RedisCommandsProvider.serverCommands()
. - flushAll(RedisClusterNode, RedisServerCommands.FlushOption) - Method in interface org.springframework.data.redis.connection.ReactiveClusterServerCommands
-
Delete all all keys from all databases using the specified
RedisServerCommands.FlushOption
. - flushAll(RedisClusterNode, RedisServerCommands.FlushOption) - Method in interface org.springframework.data.redis.connection.RedisClusterServerCommands
- flushAll(RedisServerCommands.FlushOption) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.serverCommands()
. - flushAll(RedisServerCommands.FlushOption) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- flushAll(RedisServerCommands.FlushOption) - Method in interface org.springframework.data.redis.connection.ReactiveServerCommands
-
Delete all all keys from all databases using the specified
RedisServerCommands.FlushOption
. - flushAll(RedisServerCommands.FlushOption) - Method in interface org.springframework.data.redis.connection.RedisServerCommands
-
Delete all all keys from all databases using the specified
RedisServerCommands.FlushOption
. - FLUSHALL - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- flushDb() - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.serverCommands()
. - flushDb() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- flushDb() - Method in interface org.springframework.data.redis.connection.ReactiveServerCommands
-
Delete all keys of the currently selected database.
- flushDb() - Method in interface org.springframework.data.redis.connection.RedisServerCommands
-
Delete all keys of the currently selected database.
- flushDb(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.DefaultedRedisClusterConnection
-
Deprecated.in favor of
RedisCommandsProvider.serverCommands()
. - flushDb(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.ReactiveClusterServerCommands
-
Delete all keys of the currently selected database.
- flushDb(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.RedisClusterServerCommands
- flushDb(RedisClusterNode) - Method in interface org.springframework.data.redis.core.ClusterOperations
-
Flush db on node.
- flushDb(RedisClusterNode, RedisServerCommands.FlushOption) - Method in interface org.springframework.data.redis.connection.DefaultedRedisClusterConnection
-
Deprecated.in favor of
RedisCommandsProvider.serverCommands()
. - flushDb(RedisClusterNode, RedisServerCommands.FlushOption) - Method in interface org.springframework.data.redis.connection.ReactiveClusterServerCommands
-
Delete all keys of the currently selected database using the specified
RedisServerCommands.FlushOption
. - flushDb(RedisClusterNode, RedisServerCommands.FlushOption) - Method in interface org.springframework.data.redis.connection.RedisClusterServerCommands
- flushDb(RedisClusterNode, RedisServerCommands.FlushOption) - Method in interface org.springframework.data.redis.core.ClusterOperations
-
Flush db on node using the specified
RedisServerCommands.FlushOption
. - flushDb(RedisServerCommands.FlushOption) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.serverCommands()
. - flushDb(RedisServerCommands.FlushOption) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- flushDb(RedisServerCommands.FlushOption) - Method in interface org.springframework.data.redis.connection.ReactiveServerCommands
-
Delete all keys of the currently selected database using the specified
RedisServerCommands.FlushOption
. - flushDb(RedisServerCommands.FlushOption) - Method in interface org.springframework.data.redis.connection.RedisServerCommands
-
Delete all keys of the currently selected database using the specified
RedisServerCommands.FlushOption
. - FLUSHDB - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- flushEachCommand() - Static method in interface org.springframework.data.redis.connection.lettuce.LettuceConnection.PipeliningFlushPolicy
-
Return a policy to flush after each command (default behavior).
- flushOnClose() - Static method in interface org.springframework.data.redis.connection.lettuce.LettuceConnection.PipeliningFlushPolicy
-
Return a policy to flush only if
LettuceConnection.closePipeline()
is called. - force() - Method in class org.springframework.data.redis.connection.RedisStreamCommands.XClaimOptions
-
Forces creation of a pending message entry in the PEL even if it does not already exist as long a the given stream record id is valid.
- forEach(Consumer<? super StreamInfo.XInfoConsumer>) - Method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoConsumers
-
Performs the given action on every available
StreamInfo.XInfoConsumer
of thisStreamInfo.XInfoConsumers
. - forEach(Consumer<? super StreamInfo.XInfoGroup>) - Method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoGroups
-
Performs the given action on every available
StreamInfo.XInfoGroup
of thisStreamInfo.XInfoGroups
. - forget(RedisClusterNode) - Method in interface org.springframework.data.redis.core.ClusterOperations
-
Remove the node from the cluster.
- forKey(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoDistCommand
-
Applies the Geo set key member.
- forKey(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusByMemberCommand
-
Applies the Geo set key.
- forKey(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusCommand
-
Applies the Geo set key.
- forKey(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveHashCommands.HSetCommand
-
Applies the key.
- forKey(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveListCommands.LInsertCommand
-
Applies the key.
- forKey(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveListCommands.LSetCommand
-
Applies the key.
- forKey(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveNumberCommands.HIncrByCommand
-
Applies the key.
- forKey(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZCountCommand
-
Applies the key.
- forKey(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZLexCountCommand
-
Applies the key.
- forKey(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZMScoreCommand
-
Applies the key.
- forKey(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZScoreCommand
-
Applies the key.
- forRecords(String...) - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.AcknowledgeCommand
-
Applies the recordIds.
- forRecords(RecordId...) - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.AcknowledgeCommand
-
Applies the recordIds.
- forStream(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.GroupCommand
- forType(BitFieldSubCommands.BitFieldType) - Method in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldGetBuilder
- forType(BitFieldSubCommands.BitFieldType) - Method in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldIncrByBuilder
- forType(BitFieldSubCommands.BitFieldType) - Method in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldSetBuilder
- from(long, TimeUnit) - Static method in class org.springframework.data.redis.core.types.Expiration
-
Creates new
Expiration
with the providedTimeUnit
. - from(String) - Static method in class org.springframework.data.redis.connection.stream.ReadOffset
-
Read all arriving elements from the stream starting at
offset
. - from(String, String) - Static method in class org.springframework.data.redis.connection.stream.Consumer
-
Create a new consumer.
- from(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusByMemberCommand
-
Sets the member.
- from(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveHashCommands.HDelCommand
-
Applies the hash key.
- from(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveHashCommands.HGetCommand
-
Applies the hash key.
- from(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveHashCommands.HStrLenCommand
-
Define the
key
the hash is stored at. - from(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveListCommands.BRPopLPushCommand
-
Creates a new
ReactiveListCommands.BRPopLPushCommand
given a sourceKey. - from(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveListCommands.LIndexCommand
-
Applies the key.
- from(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveListCommands.LPosCommand
-
Applies the key.
- from(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveListCommands.LRemCommand
-
Applies the key.
- from(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveListCommands.PopCommand
-
Applies the key.
- from(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveListCommands.RPopLPushCommand
-
Creates a new
ReactiveListCommands.RPopLPushCommand
given a sourceKey. - from(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveSetCommands.SMoveCommand
-
Applies the source key.
- from(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveSetCommands.SPopCommand
-
Applies the key.
- from(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveSetCommands.SRandMembersCommand
-
Applies the key.
- from(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveSetCommands.SRemCommand
-
Applies the key.
- from(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.BZPopCommand
-
Applies the key.
- from(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZPopCommand
-
Applies the key.
- from(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRandMemberCommand
-
Applies the key.
- from(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRangeByLexCommand
-
Applies the key.
- from(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRangeByScoreCommand
-
Applies the key.
- from(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRangeCommand
-
Applies the key.
- from(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRangeStoreCommand
-
Applies the key.
- from(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRemCommand
-
Applies the key.
- from(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRemRangeByLexCommand
-
Applies the key.
- from(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRemRangeByRankCommand
-
Applies the key.
- from(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRemRangeByScoreCommand
-
Applies the key.
- from(ByteBuffer, ReactiveListCommands.Direction) - Static method in class org.springframework.data.redis.connection.ReactiveListCommands.LMoveCommand
-
Creates a new
ReactiveListCommands.LMoveCommand
given asourceKey
. - from(Duration) - Static method in class org.springframework.data.redis.core.types.Expiration
-
Creates a new
Expiration
with the given, requiredDuration
. - from(List<ByteBuffer>) - Method in class org.springframework.data.redis.connection.ReactiveListCommands.BPopCommand
-
Applies the value.
- from(Point) - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusCommand
-
Sets the center
Point
. - from(Record<K, ?>) - Static method in class org.springframework.data.redis.connection.stream.StreamOffset
- from(RecordId) - Static method in class org.springframework.data.redis.connection.stream.ReadOffset
-
Read all arriving elements from the stream starting at
RecordId
. - from(StreamOffset<ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveStreamCommands.ReadCommand
-
Creates a new
ReactiveStreamCommands.ReadCommand
given aStreamOffset
. - from(StreamOffset<ByteBuffer>...) - Static method in class org.springframework.data.redis.connection.ReactiveStreamCommands.ReadCommand
-
Creates a new
ReactiveStreamCommands.ReadCommand
given aStreamOffset
s. - from(Bucket) - Static method in class org.springframework.data.redis.core.convert.Bucket.BucketPropertyPath
-
Creates a top-level
Bucket.BucketPropertyPath
givenBucket
. - from(Bucket, String) - Static method in class org.springframework.data.redis.core.convert.Bucket.BucketPropertyPath
- from(RedisSerializer<T>) - Static method in interface org.springframework.data.redis.serializer.RedisElementReader
-
Create new
RedisElementReader
using givenRedisSerializer
. - from(RedisSerializer<T>) - Static method in interface org.springframework.data.redis.serializer.RedisElementWriter
-
Create new
RedisElementWriter
using givenRedisSerializer
. - fromBytes(byte[], Class<T>) - Method in class org.springframework.data.redis.core.convert.MappingRedisConverter
-
Convert given binary representation to desired target type using the underlying
ConversionService
. - fromCacheWriter(RedisCacheWriter) - Static method in class org.springframework.data.redis.cache.RedisCacheManager.RedisCacheManagerBuilder
-
Factory method returning a new Builder used to create and configure a
RedisCacheManager
using the givenRedisCacheWriter
. - fromCircle(Circle) - Static method in interface org.springframework.data.redis.domain.geo.GeoReference
-
Creates a
GeoReference
from acircle center point
. - fromCode(String) - Static method in enum class org.springframework.data.redis.connection.DataType
-
Utility method for converting an enum code to an actual enum.
- fromConnectionFactory(RedisConnectionFactory) - Static method in class org.springframework.data.redis.cache.RedisCacheManager.RedisCacheManagerBuilder
-
Factory method returning a new Builder used to create and configure a
RedisCacheManager
using the givenRedisConnectionFactory
. - fromCoordinate(double, double) - Static method in interface org.springframework.data.redis.domain.geo.GeoReference
-
Creates a
GeoReference
from a WGS84 longitude/latitude coordinate. - fromCoordinate(Point) - Static method in interface org.springframework.data.redis.domain.geo.GeoReference
-
Creates a
GeoReference
from a WGS84 longitude/latitude coordinate. - fromCoordinate(RedisGeoCommands.GeoLocation<?>) - Static method in interface org.springframework.data.redis.domain.geo.GeoReference
-
Creates a
GeoReference
from a WGS84 longitude/latitude coordinate. - fromGroup(String) - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.GroupCommand
- fromHash(Map) - Method in class org.springframework.data.redis.hash.DecoratingStringHashMapper
- fromHash(Map<byte[], byte[]>) - Method in class org.springframework.data.redis.hash.ObjectHashMapper
- fromHash(Map<byte[], byte[]>, Class<T>) - Method in class org.springframework.data.redis.hash.ObjectHashMapper
-
Convert a
hash
(map) to an object and return the casted result. - fromHash(Map<String, Object>) - Method in class org.springframework.data.redis.hash.Jackson2HashMapper
- fromHash(Map<String, String>) - Method in class org.springframework.data.redis.hash.BeanUtilsHashMapper
- fromHash(Map<K, V>) - Method in interface org.springframework.data.redis.hash.HashMapper
-
Convert a
hash
(map) to an object. - fromHead(K) - Static method in class org.springframework.data.redis.core.ListOperations.MoveFrom
- fromIndex(long) - Method in class org.springframework.data.redis.connection.ReactiveRedisConnection.RangeCommand
-
Applies a lower bound to the
Range
. - fromJavaType(Class<?>) - Static method in enum class org.springframework.data.redis.connection.ReturnType
- fromList(String, List<Object>) - Static method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoConsumers
- fromList(List<Object>) - Static method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoGroup
- fromList(List<Object>) - Static method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoGroups
-
Factory method to create a new instance of
StreamInfo.XInfoGroups
. - fromList(List<Object>) - Static method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoStream
-
Factory method to create a new instance of
StreamInfo.XInfoStream
. - fromMember(RedisGeoCommands.GeoLocation<T>) - Static method in interface org.springframework.data.redis.domain.geo.GeoReference
-
Creates a
GeoReference
from ageoset member
. - fromMember(T) - Static method in interface org.springframework.data.redis.domain.geo.GeoReference
-
Creates a
GeoReference
from a geoset member. - fromSerializer(RedisSerializer<T>) - Static method in interface org.springframework.data.redis.serializer.RedisSerializationContext
-
Creates a new
RedisSerializationContext
using the givenRedisSerializer
. - fromSerializer(RedisSerializer<T>) - Static method in interface org.springframework.data.redis.serializer.RedisSerializationContext.SerializationPair
-
Creates a
RedisSerializationContext.SerializationPair
adapter givenRedisSerializer
. - fromSetCount(int) - Static method in class org.springframework.data.redis.connection.zset.Weights
-
Creates equal
Weights
for a number of input setscount
with a weight of one. - fromStart(K) - Static method in class org.springframework.data.redis.connection.stream.StreamOffset
- fromString(String) - Static method in class org.springframework.data.redis.connection.RedisNode
-
Parse a
hostAndPort
string intoRedisNode
. - fromString(String) - Static method in class org.springframework.data.redis.core.types.RedisClientInfo.RedisClientInfoBuilder
- fromString(String, int) - Static method in class org.springframework.data.redis.connection.RedisNode
-
Parse a
hostAndPort
string intoRedisNode
. - fromTail(K) - Static method in class org.springframework.data.redis.core.ListOperations.MoveFrom
- FutureResult<T> - Class in org.springframework.data.redis.connection
-
The result of an asynchronous operation
- FutureResult(T) - Constructor for class org.springframework.data.redis.connection.FutureResult
-
Create new
FutureResult
for given object actually holding the result itself. - FutureResult(T, Converter) - Constructor for class org.springframework.data.redis.connection.FutureResult
-
Create new
FutureResult
for given object actually holding the result itself and a converter capable of transforming the result viaFutureResult.convert(Object)
. - FutureResult(T, Converter, Supplier<?>) - Constructor for class org.springframework.data.redis.connection.FutureResult
-
Create new
FutureResult
for given object actually holding the result itself and a converter capable of transforming the result viaFutureResult.convert(Object)
.
G
- GenericJackson2JsonRedisSerializer - Class in org.springframework.data.redis.serializer
-
Generic Jackson 2-based
RedisSerializer
that mapsobjects
to and from JSON using dynamic typing. - GenericJackson2JsonRedisSerializer() - Constructor for class org.springframework.data.redis.serializer.GenericJackson2JsonRedisSerializer
-
Creates
GenericJackson2JsonRedisSerializer
initialized with anObjectMapper
configured for default typing. - 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. - GenericJackson2JsonRedisSerializer(ObjectMapper, JacksonObjectReader, JacksonObjectWriter) - 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. - GenericJackson2JsonRedisSerializer(String) - Constructor for class org.springframework.data.redis.serializer.GenericJackson2JsonRedisSerializer
-
Creates
GenericJackson2JsonRedisSerializer
initialized with anObjectMapper
configured for default typing using the givenname
. - GenericJackson2JsonRedisSerializer(String, JacksonObjectReader, JacksonObjectWriter) - Constructor for class org.springframework.data.redis.serializer.GenericJackson2JsonRedisSerializer
-
Creates
GenericJackson2JsonRedisSerializer
initialized with anObjectMapper
configured for default typing using the givenname
along with the given, requiredJacksonObjectReader
andJacksonObjectWriter
used to read/writeObjects
de/serialized as JSON. - GenericJackson2JsonRedisSerializer.GenericJackson2JsonRedisSerializerBuilder - Class in org.springframework.data.redis.serializer
-
Builder for configuring and creating a
GenericJackson2JsonRedisSerializer
. - 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[], Iterable<RedisGeoCommands.GeoLocation<byte[]>>) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.geoCommands()
}. - geoAdd(byte[], Iterable<RedisGeoCommands.GeoLocation<byte[]>>) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- geoAdd(byte[], Iterable<RedisGeoCommands.GeoLocation<byte[]>>) - Method in interface org.springframework.data.redis.connection.RedisGeoCommands
-
Add
RedisGeoCommands.GeoLocation
s to key - geoAdd(byte[], Map<byte[], Point>) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.geoCommands()
}. - geoAdd(byte[], Map<byte[], Point>) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- geoAdd(byte[], Map<byte[], Point>) - Method in interface org.springframework.data.redis.connection.RedisGeoCommands
- geoAdd(byte[], Point, byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.geoCommands()
}. - geoAdd(byte[], Point, byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- 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 class org.springframework.data.redis.connection.DefaultStringRedisConnection
- geoAdd(byte[], RedisGeoCommands.GeoLocation<byte[]>) - Method in interface org.springframework.data.redis.connection.RedisGeoCommands
-
Add
RedisGeoCommands.GeoLocation
to key. - geoAdd(String, Iterable<RedisGeoCommands.GeoLocation<String>>) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- geoAdd(String, Iterable<RedisGeoCommands.GeoLocation<String>>) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Add
RedisGeoCommands.GeoLocation
s to key - geoAdd(String, Map<String, Point>) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- geoAdd(String, Map<String, Point>) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
- geoAdd(String, Point, String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- 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 class org.springframework.data.redis.connection.DefaultStringRedisConnection
- geoAdd(String, RedisGeoCommands.GeoLocation<String>) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Add
RedisGeoCommands.GeoLocation
to key. - geoAdd(ByteBuffer, Collection<RedisGeoCommands.GeoLocation<ByteBuffer>>) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
-
Add
RedisGeoCommands.GeoLocation
to key. - 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
-
Add
RedisGeoCommands.GeoLocation
to key. - geoAdd(Publisher<ReactiveGeoCommands.GeoAddCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
-
Add
RedisGeoCommands.GeoLocation
s to key. - GEOADD - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- geoCommands() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- 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.RedisCommandsProvider
-
Get
RedisGeoCommands
. - GeoCoordinateReference(double, double) - Constructor for class org.springframework.data.redis.domain.geo.GeoReference.GeoCoordinateReference
- geoCoordinatesToPoint(GeoCoordinates) - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
- geoDist(byte[], byte[], byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.geoCommands()
}. - geoDist(byte[], byte[], byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- 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.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.geoCommands()
}. - geoDist(byte[], byte[], byte[], Metric) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- geoDist(byte[], byte[], byte[], Metric) - Method in interface org.springframework.data.redis.connection.RedisGeoCommands
- geoDist(String, String, String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- 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 class org.springframework.data.redis.connection.DefaultStringRedisConnection
- geoDist(String, String, String, Metric) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
- geoDist(ByteBuffer, ByteBuffer, ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
-
Get the
Distance
between from and to. - geoDist(ByteBuffer, ByteBuffer, ByteBuffer, Metric) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
-
Get the
Distance
between from and to. - geoDist(Publisher<ReactiveGeoCommands.GeoDistCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
-
Get the
Distance
between from and to. - GEODIST - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- geoHash(byte[], byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.geoCommands()
}. - geoHash(byte[], byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- 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 class org.springframework.data.redis.connection.DefaultStringRedisConnection
- geoHash(String, String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get geohash representation of the position for one or more members.
- 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 - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- GeoIndexDefinition - Class in org.springframework.data.redis.core.index
- GeoIndexDefinition(String, String) - Constructor for class org.springframework.data.redis.core.index.GeoIndexDefinition
-
Creates new
GeoIndexDefinition
. - GeoIndexDefinition(String, String, String) - Constructor for class org.springframework.data.redis.core.index.GeoIndexDefinition
-
Creates new
GeoIndexDefinition
. - GeoIndexed - Annotation Interface 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> - Class in org.springframework.data.redis.domain.geo
- GeoLocation(T, Point) - Constructor for class org.springframework.data.redis.connection.RedisGeoCommands.GeoLocation
- GeoLocation(T, Point) - Constructor for class org.springframework.data.redis.domain.geo.GeoLocation
- GeoMemberReference(T) - Constructor for class org.springframework.data.redis.domain.geo.GeoReference.GeoMemberReference
- 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
-
Deprecated.in favor of
RedisCommandsProvider.geoCommands()
}. - geoPos(byte[], byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- 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 class org.springframework.data.redis.connection.DefaultStringRedisConnection
- geoPos(String, String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get the
Point
representation of positions for one or more members. - 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 - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- geoRadius(byte[], Circle) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.geoCommands()
}. - geoRadius(byte[], Circle) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- 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.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.geoCommands()
}. - geoRadius(byte[], Circle, RedisGeoCommands.GeoRadiusCommandArgs) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- geoRadius(byte[], Circle, RedisGeoCommands.GeoRadiusCommandArgs) - Method in interface org.springframework.data.redis.connection.RedisGeoCommands
-
Get the members within the boundaries of a given
Circle
applyingRedisGeoCommands.GeoRadiusCommandArgs
. - geoRadius(String, Circle) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- 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 class org.springframework.data.redis.connection.DefaultStringRedisConnection
- geoRadius(String, Circle, RedisGeoCommands.GeoRadiusCommandArgs) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get the members within the boundaries of a given
Circle
applyingRedisGeoCommands.GeoRadiusCommandArgs
. - 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 - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- geoRadiusByMember(byte[], byte[], double) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- 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.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.geoCommands()
}. - geoRadiusByMember(byte[], byte[], Distance) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- 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.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.geoCommands()
}. - geoRadiusByMember(byte[], byte[], Distance, RedisGeoCommands.GeoRadiusCommandArgs) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- geoRadiusByMember(byte[], byte[], Distance, RedisGeoCommands.GeoRadiusCommandArgs) - Method in interface org.springframework.data.redis.connection.RedisGeoCommands
-
Get the members within the circle defined by the members coordinates, given
Distance
andRedisGeoCommands.GeoRadiusCommandArgs
. - geoRadiusByMember(String, String, double) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- 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 class org.springframework.data.redis.connection.DefaultStringRedisConnection
- 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 class org.springframework.data.redis.connection.DefaultStringRedisConnection
- 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
andRedisGeoCommands.GeoRadiusCommandArgs
. - 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 - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- geoRadiusResponseToGeoResultsConverter(Metric) - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
- GeoReference<T> - Interface in org.springframework.data.redis.domain.geo
-
Reference point for
GEOSEARCH
andGEOSEARCHSTORE
commands. - GeoReference.GeoCoordinateReference<T> - Class in org.springframework.data.redis.domain.geo
- GeoReference.GeoMemberReference<T> - Class in org.springframework.data.redis.domain.geo
- geoRemove(byte[], byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.geoCommands()
}. - geoRemove(byte[], byte[]...) - 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 class org.springframework.data.redis.connection.DefaultStringRedisConnection
- geoRemove(String, String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Remove the members.
- geoSearch(byte[], GeoReference<byte[]>, GeoShape, RedisGeoCommands.GeoSearchCommandArgs) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.geoCommands()
}. - geoSearch(byte[], GeoReference<byte[]>, GeoShape, RedisGeoCommands.GeoSearchCommandArgs) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- geoSearch(byte[], GeoReference<byte[]>, GeoShape, RedisGeoCommands.GeoSearchCommandArgs) - Method in interface org.springframework.data.redis.connection.RedisGeoCommands
-
Return the members of a geo set which are within the borders of the area specified by a given
shape
. - geoSearch(String, GeoReference<String>, GeoShape, RedisGeoCommands.GeoSearchCommandArgs) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- geoSearch(String, GeoReference<String>, GeoShape, RedisGeoCommands.GeoSearchCommandArgs) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Return the members of a geo set which are within the borders of the area specified by a given
shape
. - geoSearch(ByteBuffer, GeoReference<ByteBuffer>, GeoShape, RedisGeoCommands.GeoSearchCommandArgs) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
-
Return the members of a geo set which are within the borders of the area specified by a given
shape
. - geoSearch(Publisher<ReactiveGeoCommands.GeoSearchCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
-
Get the members within given
GeoShape
fromGeoReference
applying given parameters. - geoSearchStore(byte[], byte[], GeoReference<byte[]>, GeoShape, RedisGeoCommands.GeoSearchStoreCommandArgs) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.geoCommands()
}. - geoSearchStore(byte[], byte[], GeoReference<byte[]>, GeoShape, RedisGeoCommands.GeoSearchStoreCommandArgs) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- geoSearchStore(byte[], byte[], GeoReference<byte[]>, GeoShape, RedisGeoCommands.GeoSearchStoreCommandArgs) - Method in interface org.springframework.data.redis.connection.RedisGeoCommands
-
Query the members of a geo set which are within the borders of the area specified by a given
shape
and store the result atdestKey
. - geoSearchStore(String, String, GeoReference<String>, GeoShape, RedisGeoCommands.GeoSearchStoreCommandArgs) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- geoSearchStore(String, String, GeoReference<String>, GeoShape, RedisGeoCommands.GeoSearchStoreCommandArgs) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Query the members of a geo set which are within the borders of the area specified by a given
shape
and store the result atdestKey
. - geoSearchStore(ByteBuffer, ByteBuffer, GeoReference<ByteBuffer>, GeoShape, RedisGeoCommands.GeoSearchStoreCommandArgs) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
-
Query the members of a geo set which are within the borders of the area specified by a given
shape
and store the result atdestKey
. - geoSearchStore(Publisher<ReactiveGeoCommands.GeoSearchStoreCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
-
Store the members within given
GeoShape
fromGeoReference
applying given parameters in a new geo set. - GeoShape - Interface in org.springframework.data.redis.domain.geo
-
Search predicate for
GEOSEARCH
andGEOSEARCHSTORE
commands. - get() - Method in class org.springframework.data.redis.connection.FutureResult
- get() - Method in class org.springframework.data.redis.connection.RedisPassword
-
Return the password value if present.
- get() - Method in interface org.springframework.data.redis.core.BoundValueOperations
-
Get the value of the bound key.
- 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(byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.stringCommands()
}. - get(byte[]) - Method in class org.springframework.data.redis.connection.DefaultSortParameters
- get(byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- 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 the
PendingMessage
at the given position. - get(int) - Method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoConsumers
-
Returns the
StreamInfo.XInfoConsumer
element at the given index. - get(int) - Method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoGroups
-
Returns the
StreamInfo.XInfoGroup
element at the given index. - get(int) - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- get(long, long) - Method in interface org.springframework.data.redis.core.BoundValueOperations
-
Get a substring of value of the bound key between
begin
andend
. - get(H, Object) - Method in interface org.springframework.data.redis.core.HashOperations
-
Get value for given
hashKey
from hash atkey
. - get(H, Object) - Method in interface org.springframework.data.redis.core.ReactiveHashOperations
-
Get value for given
hashKey
from hash atkey
. - get(Object) - Method in interface org.springframework.data.redis.core.BoundHashOperations
-
Get value for given
key
from the hash at the bound key. - get(Object) - Method in interface org.springframework.data.redis.core.ReactiveValueOperations
-
Get the value of
key
. - get(Object) - Method in interface org.springframework.data.redis.core.ValueOperations
-
Get the value of
key
. - get(Object) - Method in class org.springframework.data.redis.support.collections.DefaultRedisMap
- get(Object) - Method in class org.springframework.data.redis.support.collections.RedisProperties
- 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(Object, Callable<T>) - Method in class org.springframework.data.redis.cache.RedisCache
- get(String) - Method in class org.springframework.data.redis.connection.ClusterInfo
- get(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- get(String) - Method in class org.springframework.data.redis.connection.RedisServer
- get(String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get the value of
key
. - 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(String) - Method in class org.springframework.data.redis.core.query.SortQueryBuilder
- get(String) - Method in interface org.springframework.data.redis.core.query.SortCriterion
- get(String) - Method in class org.springframework.data.redis.core.types.RedisClientInfo
- 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(String, byte[], Duration) - Method in interface org.springframework.data.redis.cache.RedisCacheWriter
-
Get the binary value representation from Redis stored for the given key and set the given
TTL expiration
for the cache entry. - get(String, byte[], Supplier<byte[]>, Duration, boolean) - Method in interface org.springframework.data.redis.cache.RedisCacheWriter
-
Get the binary value representation from Redis stored for the given key and set the given
TTL expiration
for the cache entry, obtaining the value fromvalueLoader
if necessary. - get(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
-
Get single element stored at key.
- get(K, long, long) - Method in interface org.springframework.data.redis.core.ReactiveValueOperations
-
Get a substring of value of
key
betweenbegin
andend
. - get(K, long, long) - Method in interface org.springframework.data.redis.core.ValueOperations
-
Get a substring of value of
key
betweenbegin
andend
. - get(Publisher<ReactiveRedisConnection.KeyCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
-
Get elements one by one.
- get(BitFieldSubCommands.BitFieldGet) - Method in class org.springframework.data.redis.connection.BitFieldSubCommands
-
Create new
BitFieldSubCommands
adding givenBitFieldSubCommands.BitFieldGet
to the sub commands. - get(BitFieldSubCommands.BitFieldType) - Method in class org.springframework.data.redis.connection.BitFieldSubCommands
-
Obtain a new
BitFieldSubCommands.BitFieldGetBuilder
for creating and adding aBitFieldSubCommands.BitFieldGet
sub command. - get(ClusterInfo.Info) - Method in class org.springframework.data.redis.connection.ClusterInfo
- get(RedisServer.INFO) - Method in class org.springframework.data.redis.connection.RedisServer
- get(RedisClientInfo.INFO) - Method in class org.springframework.data.redis.core.types.RedisClientInfo
- GET - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- getAbbreviation() - Method in enum class org.springframework.data.redis.connection.RedisGeoCommands.DistanceUnit
- getAbbreviation() - Method in enum class org.springframework.data.redis.domain.geo.Metrics
- 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 andflags
does not contain fail or fail?. - getActiveNodes() - Method in class org.springframework.data.redis.connection.ClusterTopology
-
Get all nodes (master and replica) in cluster where
link-state
is connected andflags
does not contain fail or fail?. - getActiveSubscriptions() - Method in class org.springframework.data.redis.listener.ReactiveRedisMessageListenerContainer
-
Return the currently active
subscriptions
. - 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.ZAggregateCommand
- getAggregateFunction() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZAggregateStoreCommand
- 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
-
Atomically update the current value using the given
accumulator function
. - getAndAccumulate(int, IntBinaryOperator) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicInteger
-
Atomically update the current value using the given
accumulator function
. - getAndAccumulate(long, LongBinaryOperator) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicLong
-
Atomically update the current value using the given
accumulator function
. - 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.
- getAndDelete() - Method in interface org.springframework.data.redis.core.BoundValueOperations
-
Return the value at the bound key and delete the key.
- getAndDelete(K) - Method in interface org.springframework.data.redis.core.ReactiveValueOperations
-
Return the value at
key
and delete the key. - getAndDelete(K) - Method in interface org.springframework.data.redis.core.ValueOperations
-
Return the value at
key
and delete the key. - getAndExpire(long, TimeUnit) - Method in interface org.springframework.data.redis.core.BoundValueOperations
-
Return the value at the bound key and expire the key by applying
timeout
. - getAndExpire(Duration) - Method in interface org.springframework.data.redis.core.BoundValueOperations
-
Return the value at the bound key and expire the key by applying
timeout
. - getAndExpire(K, long, TimeUnit) - Method in interface org.springframework.data.redis.core.ValueOperations
-
Return the value at
key
and expire the key by applyingtimeout
. - getAndExpire(K, Duration) - Method in interface org.springframework.data.redis.core.ReactiveValueOperations
-
Return the value at
key
and expire the key by applyingtimeout
. - getAndExpire(K, Duration) - Method in interface org.springframework.data.redis.core.ValueOperations
-
Return the value at
key
and expire the key by applyingtimeout
. - 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.
- getAndPersist() - Method in interface org.springframework.data.redis.core.BoundValueOperations
-
Return the value at the bound key and persist the key.
- getAndPersist(K) - Method in interface org.springframework.data.redis.core.ReactiveValueOperations
-
Return the value at
key
and persist the key. - getAndPersist(K) - Method in interface org.springframework.data.redis.core.ValueOperations
-
Return the value at
key
and persist the key. - 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.
- getAndSet(K, V) - Method in interface org.springframework.data.redis.core.ReactiveValueOperations
-
Set
value
ofkey
and return its old value. - getAndSet(K, V) - Method in interface org.springframework.data.redis.core.ValueOperations
-
Set
value
ofkey
and return its old value. - getAndSet(V) - Method in interface org.springframework.data.redis.core.BoundValueOperations
-
Set
value
of the bound key and return its old value. - getAndUpdate(DoubleUnaryOperator) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicDouble
-
Atomically update the current value using the given
update function
. - getAndUpdate(IntUnaryOperator) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicInteger
-
Atomically update the current value using the given
update function
. - getAndUpdate(LongUnaryOperator) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicLong
-
Atomically update the current value using the given
update function
. - 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
- getArgs() - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoSearchCommand
- getArgs() - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoSearchStoreCommand
- 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() - Method in class org.springframework.data.redis.connection.ReactiveStringCommands.BitPosCommand
- getBit(byte[], long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.stringCommands()
}. - getBit(byte[], long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- getBit(byte[], long) - Method in interface org.springframework.data.redis.connection.RedisStringCommands
-
Get the bit value at
offset
of value atkey
. - getBit(String, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- getBit(String, long) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get the bit value at
offset
of value atkey
. - getBit(ByteBuffer, long) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
-
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 atkey
. - getBit(K, long) - Method in interface org.springframework.data.redis.core.ValueOperations
-
Get the bit value at
offset
of value atkey
. - getBit(Publisher<ReactiveStringCommands.GetBitCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
-
Get the bit value at offset of value at key.
- GETBIT - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- 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
- getBoundingBox() - Method in class org.springframework.data.redis.domain.geo.BoxShape
- 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
- getBytePattern() - Method in class org.springframework.data.redis.core.ScanOptions
- getBytes(ByteBuffer) - Static method in class org.springframework.data.redis.util.ByteUtils
-
Extract a byte array from
ByteBuffer
without consuming it. - getCacheConfiguration() - Method in class org.springframework.data.redis.cache.RedisCache
-
Get the
RedisCacheConfiguration
used to configure thisRedisCache
on initialization. - getCacheConfigurationFor(String) - Method in class org.springframework.data.redis.cache.RedisCacheManager.RedisCacheManagerBuilder
-
Get the
RedisCacheConfiguration
for a given cache by its name. - 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.
- getCacheWriter() - Method in class org.springframework.data.redis.cache.RedisCache
-
Gets the configured
RedisCacheWriter
used to adapt Redis for cache operations. - getCacheWriter() - Method in class org.springframework.data.redis.cache.RedisCacheManager
-
Returns a reference to the configured
RedisCacheWriter
used to performRedisCache
operations, such as reading from and writing to the cache. - getCancelSubscriptionOnError() - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamReadRequest
- 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.
- getClientConfiguration() - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
- getClientConfiguration() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
- getClientList() - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.serverCommands()
. - getClientList() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- getClientList() - Method in interface org.springframework.data.redis.connection.ReactiveServerCommands
-
Request information and statistics about connected clients.
- 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
- getClientList(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.DefaultedRedisClusterConnection
-
Deprecated.in favor of
RedisCommandsProvider.serverCommands()
. - getClientList(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.ReactiveClusterServerCommands
-
Request information and statistics about connected clients.
- getClientList(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.RedisClusterServerCommands
- getClientName() - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.serverCommands()
. - 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 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
-
Returns 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
-
Returns an
Set
ofcluster nodes
. - getClusterSize() - Method in class org.springframework.data.redis.connection.ClusterInfo
- getCmd() - Method in class org.springframework.data.redis.core.PartialUpdate.PropertyUpdate
-
Get the associated
PartialUpdate.UpdateCommand
. - 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(String) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.serverCommands()
. - getConfig(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- getConfig(String) - Method in interface org.springframework.data.redis.connection.ReactiveServerCommands
-
Load configuration parameters for given
pattern
from server. - getConfig(String) - Method in interface org.springframework.data.redis.connection.RedisServerCommands
-
Load configuration parameters for given
pattern
from server. - getConfig(RedisClusterNode, String) - Method in interface org.springframework.data.redis.connection.DefaultedRedisClusterConnection
-
Deprecated.in favor of
RedisCommandsProvider.serverCommands()
. - getConfig(RedisClusterNode, String) - Method in interface org.springframework.data.redis.connection.ReactiveClusterServerCommands
-
Load configuration parameters for given
pattern
from server. - getConfig(RedisClusterNode, String) - Method in interface org.springframework.data.redis.connection.RedisClusterServerCommands
- getConfigEpoch() - Method in class org.springframework.data.redis.connection.RedisServer
- getConfiguredCaches() - Method in class org.springframework.data.redis.cache.RedisCacheManager.RedisCacheManagerBuilder
-
Get the
Set
of cache names for which the builder holdsconfiguration
. - 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() - Method in interface org.springframework.data.redis.connection.RedisConnectionFactory
-
Returns a suitable
connection
for interacting with Redis. - getConnection() - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
-
Creates a
Mono
which emits a newReactiveRedisConnection
. - 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 specificRedisURI
. - getConnection(RedisConnectionFactory) - Static method in class org.springframework.data.redis.core.RedisConnectionUtils
-
Obtain a
RedisConnection
from the givenRedisConnectionFactory
. - getConnection(RedisConnectionFactory, boolean) - Static method in class org.springframework.data.redis.core.RedisConnectionUtils
-
Obtain a
RedisConnection
from the givenRedisConnectionFactory
. - 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 specificRedisURI
. - 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 factory configured to acquire connections and perform operations on the connected Redis instance.
- 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.RedisCache
-
Gets the configured
ConversionService
used to convertcache keys
to aString
when accessing entries in the cache. - 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
-
Converts
expiration time
into the given, desiredTimeUnit
. - getConverter() - Method in class org.springframework.data.redis.connection.FutureResult
- getConverter() - Method in class org.springframework.data.redis.core.RedisKeyValueAdapter
-
Get the
RedisConverter
in use. - getConverter() - Method in class org.springframework.data.redis.core.RedisKeyValueTemplate
-
Obtain the underlying redis specific
EntityConverter
. - 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.Limit
- getCount() - Method in class org.springframework.data.redis.connection.ReactiveHashCommands.HRandFieldCommand
- 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.ReactiveListCommands.PopCommand
- 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.ReactiveZSetCommands.BZPopCommand
- getCount() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZPopCommand
- getCount() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRandMemberCommand
- getCount() - Method in class org.springframework.data.redis.connection.RedisStreamCommands.XPendingOptions
- 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
-
Deprecated.
- getCursorId() - Method in class org.springframework.data.redis.core.Cursor.CursorId
- getCursorId() - Method in interface org.springframework.data.redis.core.Cursor
-
Deprecated.since 3.3.0, use
Cursor.getId()
instead as the cursorId can exceedLong.MAX_VALUE
. - getCursorId() - Method in class org.springframework.data.redis.core.ScanCursor
- getCursorId() - Method in class org.springframework.data.redis.core.ScanIteration
-
Deprecated.since 3.3.0, use
ScanIteration.getId()
instead as the cursorId can exceedLong.MAX_VALUE
. - getCustomizer() - Method in interface org.springframework.data.redis.connection.jedis.JedisClientConfiguration
- 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.LettuceConnectionFactory
-
Returns the index of the database.
- getDatabase() - Method in class org.springframework.data.redis.connection.ReactiveKeyCommands.CopyCommand
- 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
-
Get the configured database index if the current
RedisConfiguration
isdatabase aware
or evaluate and return the value of the givenSupplier
. - 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.
- getDefaultCacheConfiguration() - Method in class org.springframework.data.redis.cache.RedisCacheManager
-
Gets the default
RedisCacheConfiguration
applied to newRedisCache
instances on creation when custom, non-specificRedisCacheConfiguration
was not provided. - 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.
- getDel(byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.stringCommands()
}. - getDel(byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- getDel(byte[]) - Method in interface org.springframework.data.redis.connection.RedisStringCommands
-
Return the value at
key
and delete the key. - getDel(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- getDel(String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Return the value at
key
and delete the key. - getDel(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
-
Return the value at
key
and delete the key. - getDel(Publisher<ReactiveRedisConnection.KeyCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
-
Return the value at
key
and delete the key. - getDelegate() - Method in interface org.springframework.data.redis.connection.DecoratedRedisConnection
-
Gets the underlying
RedisConnection
. - 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.ReactiveListCommands.LMoveCommand
- getDestinationKey() - Method in class org.springframework.data.redis.connection.ReactiveStringCommands.BitOpCommand
- getDestKey() - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoSearchStoreCommand
- getDestKey() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRangeStoreCommand
- 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.BZPopCommand
- getDirection() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZPopCommand
- 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.ZRangeStoreCommand
- 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
-
Indicates
shared connections
should be eagerly initialized. - 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
- getEntityInstantiators() - Method in class org.springframework.data.redis.core.convert.MappingRedisConverter
- getEntityInstantiators() - Method in interface org.springframework.data.redis.core.convert.RedisConverter
- 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.
- getEx(byte[], Expiration) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.stringCommands()
}. - getEx(byte[], Expiration) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- getEx(byte[], Expiration) - Method in interface org.springframework.data.redis.connection.RedisStringCommands
-
Return the value at
key
and expire the key by applyingExpiration
. - getEx(String, Expiration) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- getEx(String, Expiration) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Return the value at
key
and expire the key by applyingExpiration
. - getEx(ByteBuffer, Expiration) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
-
Return the value at
key
and expire the key by applyingExpiration
. - getEx(Publisher<ReactiveStringCommands.GetExCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
-
Return the value at
key
and expire the key by applyingExpiration
. - getExecutor() - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamMessageListenerContainerOptions
- getExpiration() - Method in class org.springframework.data.redis.connection.ReactiveStringCommands.GetExCommand
-
Get the
Expiration
to apply. - getExpiration() - Method in class org.springframework.data.redis.connection.ReactiveStringCommands.SetCommand
- getExpirationTime() - Method in class org.springframework.data.redis.core.types.Expiration
-
Get the
length of time
for thisExpiration
. - getExpirationTimeInMilliseconds() - Method in class org.springframework.data.redis.core.types.Expiration
-
Get the
expiration time
converted intoTimeUnit.MILLISECONDS
. - getExpirationTimeInSeconds() - Method in class org.springframework.data.redis.core.types.Expiration
-
Get the
expiration time
converted intoTimeUnit.SECONDS
. - getExpire() - Method in interface org.springframework.data.redis.core.BoundKeyOperations
-
Returns the expiration of this key.
- 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
- 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) - Method in class org.springframework.data.redis.core.RedisTemplate
- 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 givenTimeUnit
. - getExpire(K, TimeUnit) - Method in class org.springframework.data.redis.core.RedisTemplate
- 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
-
Get the
PersistentProperty
that is annotated withTimeToLive
. - 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
-
Returns a new
RedisSystemException
wrapping the givenException
. - 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 interface org.springframework.data.redis.core.BoundListOperations
-
Returns the first element from the list at the bound
key
. - getFirst() - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- getFirst() - Method in interface org.springframework.data.redis.support.collections.RedisList
- getFirst(K) - Method in interface org.springframework.data.redis.core.ListOperations
-
Returns the first element from the list at
key
. - getFirst(K) - Method in interface org.springframework.data.redis.core.ReactiveListOperations
-
Returns the first element from the list at
key
. - 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 interface org.springframework.data.redis.connection.RedisGeoCommands.GeoCommandArgs
- getFlags() - Method in class org.springframework.data.redis.connection.RedisGeoCommands.GeoRadiusCommandArgs
- getFlags() - Method in class org.springframework.data.redis.connection.RedisGeoCommands.GeoSearchCommandArgs
- getFlags() - Method in class org.springframework.data.redis.connection.RedisGeoCommands.GeoSearchStoreCommandArgs
- 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
- getFrom() - Method in class org.springframework.data.redis.connection.ReactiveListCommands.LMoveCommand
- 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() - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamMessageListenerContainerOptions
- getHashMapper() - Method in class org.springframework.data.redis.stream.StreamReceiver.StreamReceiverOptions
- getHashMapper(Class<V>) - Method in interface org.springframework.data.redis.core.HashMapperProvider
-
Get the
HashMapper
for a specific type. - getHashMapper(Class<V>) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
-
Get the
HashMapper
for a specific type. - getHashMapper(Class<V>) - Method in interface org.springframework.data.redis.core.StreamOperations
-
Get the
HashMapper
for a specific type. - 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
- getHeight() - Method in class org.springframework.data.redis.domain.geo.BoundingBox
-
Returns the height of this bounding box.
- 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.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.ConvertingCursor
- getId() - Method in interface org.springframework.data.redis.core.Cursor
-
Returns the reference cursor.
- 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.core.ScanCursor
- getId() - Method in class org.springframework.data.redis.core.ScanIteration
-
The cursor id to be used for subsequent requests.
- 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
-
Get the
List
of ID. - getIdsAsStringArray() - Method in class org.springframework.data.redis.connection.RedisStreamCommands.XClaimOptions
-
Get the ID array as
strings
. - 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) - Method in class org.springframework.data.redis.core.index.IndexConfiguration
- getIndexDefinitionsFor(Serializable) - Method in interface org.springframework.data.redis.core.index.IndexDefinitionProvider
-
Get the list of
IndexDefinition
for a givenkeyspace
. - getIndexDefinitionsFor(Serializable, String) - Method in class org.springframework.data.redis.core.index.IndexConfiguration
- 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
- getInitialCacheConfiguration() - Method in class org.springframework.data.redis.cache.RedisCacheManager
-
Gets a
Map
ofcache names
toRedisCacheConfiguration
objects as the initial set ofRedis caches
to create on startup. - 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
-
Return the
key
mapped to the value stored in Redis. - 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.ReactiveZSetCommands.ZAggregateCommand
- getKey() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZDiffCommand
- 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
-
Gets the configured
CacheKeyPrefix
. - getKeyPrefix() - Method in interface org.springframework.data.redis.core.convert.IndexedData
-
Return the key prefix for usage in Redis.
- 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
- getKeys() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZDiffCommand
- 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
-
Get the
RedisClusterNode
that is the current master serving the given key. - 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
-
Get the
KeyspaceConfiguration.KeyspaceSettings
for given type. - getKeyValuePairs() - Method in class org.springframework.data.redis.connection.ReactiveStringCommands.MSetCommand
- getKnownNodes() - Method in class org.springframework.data.redis.connection.ClusterInfo
- getLast() - Method in interface org.springframework.data.redis.core.BoundListOperations
-
Returns the last element from the list at the bound
key
. - getLast() - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- getLast() - Method in interface org.springframework.data.redis.support.collections.RedisList
- getLast(K) - Method in interface org.springframework.data.redis.core.ListOperations
-
Returns the last element from the list at
key
. - getLast(K) - Method in interface org.springframework.data.redis.core.ReactiveListOperations
-
Returns the last element from the list at
key
. - 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
- getLatitude() - Method in class org.springframework.data.redis.domain.geo.GeoReference.GeoCoordinateReference
- 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.ReactiveZSetCommands.ZRangeStoreCommand
- getLimit() - Method in interface org.springframework.data.redis.connection.RedisGeoCommands.GeoCommandArgs
- getLimit() - Method in class org.springframework.data.redis.connection.RedisGeoCommands.GeoSearchCommandArgs
- getLimit() - Method in class org.springframework.data.redis.connection.RedisGeoCommands.GeoSearchStoreCommandArgs
- getLimit() - Method in interface org.springframework.data.redis.connection.SortParameters
-
Returns the sorting limit (range or pagination).
- getLimit() - Method in interface org.springframework.data.redis.core.query.SortQuery
-
Returns the sorting limit (range or pagination).
- getLinkState() - Method in class org.springframework.data.redis.connection.RedisClusterNode
- getListener() - Method in interface org.springframework.data.redis.connection.Subscription
-
Returns the listener used for this subscription.
- getListener() - Method in class org.springframework.data.redis.connection.util.AbstractSubscription
- getListenerMethodName(Message, Object) - Method in class org.springframework.data.redis.listener.adapter.MessageListenerAdapter
-
Determine the name of the listener method that is supposed to handle the given message.
- getLockWaitDuration(TimeUnit) - Method in interface org.springframework.data.redis.cache.CacheStatistics
- getLongitude() - Method in class org.springframework.data.redis.domain.geo.GeoReference.GeoCoordinateReference
- getMappedExample(Example<?>) - Method in class org.springframework.data.redis.repository.query.ExampleQueryMapper
-
Retrieve a mapped
RedisOperationChain
to query secondary indexes givenExample
. - getMappingConfiguration() - Method in class org.springframework.data.redis.core.mapping.RedisMappingContext
-
Get the
MappingConfiguration
used. - getMappingContext() - Method in class org.springframework.data.redis.core.convert.MappingRedisConverter
- getMappingContext() - Method in interface org.springframework.data.redis.core.convert.RedisConverter
- getMappingContext() - Method in class org.springframework.data.redis.core.RedisKeyValueTemplate
- getMaster() - Method in interface org.springframework.data.redis.connection.RedisConfiguration.SentinelConfiguration
-
Get the Sentinel master node.
- getMaster() - Method in class org.springframework.data.redis.connection.RedisSentinelConfiguration
- getMasterId() - Method in class org.springframework.data.redis.connection.RedisNode
- getMasterNodes() - Method in class org.springframework.data.redis.connection.ClusterTopology
-
Get all master nodes in cluster.
- getMax() - Method in class org.springframework.data.redis.connection.RedisZSetCommands.Range
-
Deprecated.
- getMaxlen() - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.AddStreamRecord
-
Limit the size of the stream to the given maximum number of elements.
- getMaxlen() - Method in class org.springframework.data.redis.connection.RedisStreamCommands.XAddOptions
-
Limit the size of the stream to the given maximum number of elements.
- getMaxRedirects() - Method in class org.springframework.data.redis.connection.RedisClusterConfiguration
- getMaxRedirects() - Method in interface org.springframework.data.redis.connection.RedisConfiguration.ClusterConfiguration
- getMaxSubscriptionRegistrationWaitingTime() - Method in class org.springframework.data.redis.listener.RedisMessageListenerContainer
- getMember() - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusByMemberCommand
- getMember() - Method in class org.springframework.data.redis.domain.geo.GeoReference.GeoMemberReference
- getMembers() - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoHashCommand
- getMembers() - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoPosCommand
- getMessage() - Method in class org.springframework.data.redis.connection.ReactiveSubscription.ChannelMessage
- getMessage() - Method in interface org.springframework.data.redis.connection.ReactiveSubscription.Message
-
Get the actual message body.
- getMessagesReceived() - Method in class org.springframework.data.redis.connection.ClusterInfo
- getMessagesSent() - Method in class org.springframework.data.redis.connection.ClusterInfo
- getMetric() - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoDistCommand
- getMetric() - Method in class org.springframework.data.redis.domain.geo.BoxShape
- getMetric() - Method in interface org.springframework.data.redis.domain.geo.GeoShape
-
The metric used for this geo predicate.
- getMetric() - Method in class org.springframework.data.redis.domain.geo.RadiusShape
- getMin() - Method in class org.springframework.data.redis.connection.RedisZSetCommands.Range
-
Deprecated.
- getMinId() - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.AddStreamRecord
- getMinId() - Method in class org.springframework.data.redis.connection.RedisStreamCommands.XAddOptions
- getMinIdleTime() - Method in class org.springframework.data.redis.connection.RedisStreamCommands.XClaimOptions
-
Get the min-idle-time.
- getMisses() - Method in interface org.springframework.data.redis.cache.CacheStatistics
- getMissingCache(String) - Method in class org.springframework.data.redis.cache.RedisCacheManager
- getModuleName() - Method in class org.springframework.data.redis.repository.configuration.RedisRepositoryConfigurationExtension
- getModulePrefix() - Method in class org.springframework.data.redis.repository.configuration.RedisRepositoryConfigurationExtension
- getMultiCommandContext() - Method in class org.springframework.data.redis.core.types.RedisClientInfo
-
Get the number of commands in a MULTI/EXEC context.
- getMultiplier() - Method in enum class org.springframework.data.redis.connection.RedisGeoCommands.DistanceUnit
- getMultiplier() - Method in enum class org.springframework.data.redis.domain.geo.Metrics
- getName() - Method in class org.springframework.data.redis.cache.RedisCache
- getName() - Method in interface org.springframework.data.redis.connection.NamedNode
- getName() - Method in interface org.springframework.data.redis.connection.ReactiveRedisConnection.Command
- getName() - Method in class org.springframework.data.redis.connection.RedisNode
- getName() - Method in class org.springframework.data.redis.connection.stream.Consumer
- getName() - Method in class org.springframework.data.redis.core.types.RedisClientInfo
-
Get the clients name.
- getName() - Method in class org.springframework.data.redis.domain.geo.GeoLocation
- getName() - Method in class org.springframework.data.redis.repository.cdi.CdiBean
- getNativeCache() - Method in class org.springframework.data.redis.cache.RedisCache
- getNativeClient() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
Returns the native
AbstractRedisClient
used by this instance. - getNativeConnection() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- getNativeConnection() - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
- getNativeConnection() - Method in class org.springframework.data.redis.connection.jedis.JedisConnection
- getNativeConnection() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
- getNativeConnection() - Method in class org.springframework.data.redis.connection.lettuce.LettuceSubscription
- getNativeConnection() - Method in interface org.springframework.data.redis.connection.RedisConnection
-
Returns the native connection (the underlying library/driver object).
- getNear() - Method in class org.springframework.data.redis.repository.query.RedisOperationChain
- getNewKey() - Method in class org.springframework.data.redis.connection.ReactiveKeyCommands.RenameCommand
- getNewOwner() - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.XClaimCommand
- getNode() - Method in class org.springframework.data.redis.connection.ClusterCommandExecutor.NodeResult
-
Get the
RedisClusterNode
the command was executed on. - getNodes() - Method in class org.springframework.data.redis.connection.ClusterTopology
-
Get all
RedisClusterNode
s. - getNodes() - Method in interface org.springframework.data.redis.connection.RedisConfiguration.StaticMasterReplicaConfiguration
- getNodes() - Method in class org.springframework.data.redis.connection.RedisStaticMasterReplicaConfiguration
- getNumberOtherSentinels() - Method in class org.springframework.data.redis.connection.RedisServer
- getNumberReplicas() - Method in class org.springframework.data.redis.connection.RedisServer
-
Get the number of connected replicas.
- getObject() - Method in class org.springframework.data.redis.support.collections.RedisCollectionFactoryBean
- getObjectMapper() - Method in class org.springframework.data.redis.serializer.GenericJackson2JsonRedisSerializer
-
Gets the configured
ObjectMapper
used internally by thisGenericJackson2JsonRedisSerializer
to de/serializeobjects
as JSON. - getObjectType() - Method in class org.springframework.data.redis.support.collections.RedisCollectionFactoryBean
- getOffset() - Method in class org.springframework.data.redis.connection.BitFieldSubCommands.AbstractBitFieldSubCommand
- getOffset() - Method in interface org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldSubCommand
-
The bit offset to apply for the command.
- getOffset() - Method in class org.springframework.data.redis.connection.Limit
- getOffset() - Method in class org.springframework.data.redis.connection.ReactiveStringCommands.GetBitCommand
- getOffset() - Method in class org.springframework.data.redis.connection.ReactiveStringCommands.SetBitCommand
- getOffset() - Method in class org.springframework.data.redis.connection.ReactiveStringCommands.SetRangeCommand
- getOffset() - Method in class org.springframework.data.redis.connection.stream.ReadOffset
- getOffset() - Method in class org.springframework.data.redis.connection.stream.StreamOffset
- getOperations() - Method in interface org.springframework.data.redis.core.BoundHashOperations
- getOperations() - Method in interface org.springframework.data.redis.core.BoundListOperations
- getOperations() - Method in interface org.springframework.data.redis.core.BoundSetOperations
- getOperations() - Method in interface org.springframework.data.redis.core.BoundValueOperations
- getOperations() - Method in interface org.springframework.data.redis.core.BoundZSetOperations
- getOperations() - Method in interface org.springframework.data.redis.core.HashOperations
- getOperations() - Method in interface org.springframework.data.redis.core.ListOperations
- getOperations() - Method in interface org.springframework.data.redis.core.SetOperations
- getOperations() - Method in interface org.springframework.data.redis.core.ValueOperations
- getOperations() - Method in interface org.springframework.data.redis.core.ZSetOperations
- getOperations() - Method in class org.springframework.data.redis.support.collections.AbstractRedisCollection
- getOperations() - Method in class org.springframework.data.redis.support.collections.DefaultRedisMap
- getOperations() - Method in class org.springframework.data.redis.support.collections.RedisProperties
- getOperations() - Method in interface org.springframework.data.redis.support.collections.RedisStore
-
Returns the underlying Redis operations used by the backing implementation.
- getOption() - Method in class org.springframework.data.redis.connection.ReactiveStringCommands.SetCommand
- getOptions() - Method in class org.springframework.data.redis.connection.ReactiveRedisConnection.KeyScanCommand
-
Get the
ScanOptions
to apply. - getOptions() - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.XClaimCommand
- getOrder() - Method in class org.springframework.data.redis.connection.DefaultSortParameters
- getOrder() - Method in interface org.springframework.data.redis.connection.SortParameters
-
Returns the sorting order.
- getOrder() - Method in interface org.springframework.data.redis.core.query.SortQuery
-
Returns the sorting order.
- getOrSismember() - Method in class org.springframework.data.redis.repository.query.RedisOperationChain
- getOutput() - Method in class org.springframework.data.redis.connection.ReactiveRedisConnection.CommandResponse
- getOutputBufferLength() - Method in class org.springframework.data.redis.core.types.RedisClientInfo
-
Get the output buffer length.
- getOutputBufferMemoryUsage() - Method in class org.springframework.data.redis.core.types.RedisClientInfo
-
Get output buffer memory usage.
- getOutputListLength() - Method in class org.springframework.data.redis.core.types.RedisClientInfo
-
Get number queued replies in output buffer.
- getOverflow() - Method in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldIncrBy
-
Get the overflow to apply.
- getParallelSyncs() - Method in class org.springframework.data.redis.connection.RedisServer
- getPassword() - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
-
Returns the password used for authenticating with the Redis server.
- getPassword() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
Returns the password used for authenticating with the Redis server.
- getPassword() - Method in enum class org.springframework.data.redis.connection.lettuce.RedisCredentialsProviderFactory.AbsentRedisCredentials
- getPassword() - Method in class org.springframework.data.redis.connection.RedisClusterConfiguration
- getPassword() - Method in interface org.springframework.data.redis.connection.RedisConfiguration.WithAuthentication
-
Get the RedisPassword to use when connecting.
- getPassword() - Method in class org.springframework.data.redis.connection.RedisSentinelConfiguration
- getPassword() - Method in class org.springframework.data.redis.connection.RedisSocketConfiguration
- getPassword() - Method in class org.springframework.data.redis.connection.RedisStandaloneConfiguration
- getPassword() - Method in class org.springframework.data.redis.connection.RedisStaticMasterReplicaConfiguration
- getPasswordOrElse(Supplier<RedisPassword>) - Method in interface org.springframework.data.redis.connection.RedisConfiguration
-
Get the configured
RedisPassword
if the currentRedisConfiguration
ispassword aware
or evaluate and return the value of the givenSupplier
. - getPasswordOrElse(RedisConfiguration, Supplier<RedisPassword>) - Static method in interface org.springframework.data.redis.connection.RedisConfiguration
- getPath() - Method in class org.springframework.data.redis.core.convert.Bucket
-
Get the
Bucket.BucketPropertyPath
leading to the currentBucket
. - getPath() - Method in class org.springframework.data.redis.core.index.IndexDefinition.IndexingContext
- getPath() - Method in interface org.springframework.data.redis.core.index.PathBasedRedisIndexDefinition
- getPath() - Method in class org.springframework.data.redis.core.index.RedisIndexDefinition
- getPath() - Method in class org.springframework.data.redis.repository.query.RedisOperationChain.PathAndValue
- getPattern() - Method in class org.springframework.data.redis.connection.ReactiveSubscription.PatternMessage
-
Get the pattern that matched the channel.
- getPattern() - Method in class org.springframework.data.redis.core.ScanOptions
- getPatterns() - Method in interface org.springframework.data.redis.connection.ReactiveSubscription
-
Returns the channel patters for this subscription.
- getPatterns() - Method in interface org.springframework.data.redis.connection.Subscription
-
Returns the channel patters for this subscription.
- getPatterns() - Method in class org.springframework.data.redis.connection.util.AbstractSubscription
- getPatternSubscrbtions() - Method in class org.springframework.data.redis.core.types.RedisClientInfo
-
Get number of pattern subscriptions.
- getPending() - Method in interface org.springframework.data.redis.cache.CacheStatistics
- getPendingCommands() - Method in class org.springframework.data.redis.connection.RedisServer
- getPendingMessagesPerConsumer() - Method in class org.springframework.data.redis.connection.stream.PendingMessagesSummary
-
Obtain a map of every consumer in the consumer group with at least one pending message, and the number of pending messages.
- getPhase() - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
- getPhase() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
- getPipeline() - Method in class org.springframework.data.redis.connection.jedis.JedisConnection
- getPipelineResult() - Method in exception org.springframework.data.redis.connection.RedisPipelineException
-
Optionally returns the result of the pipeline that caused the exception.
- getPivot() - Method in class org.springframework.data.redis.connection.ReactiveListCommands.LInsertCommand
- getPoint() - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusCommand
- getPoint() - Method in class org.springframework.data.redis.core.convert.GeoIndexedPropertyValue
- getPoint() - Method in class org.springframework.data.redis.domain.geo.GeoLocation
- getPoint() - Method in class org.springframework.data.redis.repository.query.RedisOperationChain.NearPath
- getPollTimeout() - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamMessageListenerContainerOptions
-
Timeout for blocking polling using the
BLOCK
option during reads. - getPollTimeout() - Method in class org.springframework.data.redis.stream.StreamReceiver.StreamReceiverOptions
-
Timeout for blocking polling using the
BLOCK
option during reads. - getPoolConfig() - Method in interface org.springframework.data.redis.connection.jedis.JedisClientConfiguration
- getPoolConfig() - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
-
Returns the poolConfig.
- getPoolConfig() - Method in interface org.springframework.data.redis.connection.lettuce.LettucePoolingClientConfiguration
- getPort() - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
-
Returns the port used to connect to the Redis instance.
- getPort() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
Returns the current port.
- getPort() - Method in interface org.springframework.data.redis.connection.RedisConfiguration.WithHostAndPort
-
Get the Redis server port.
- getPort() - Method in class org.springframework.data.redis.connection.RedisNode
- getPort() - Method in class org.springframework.data.redis.connection.RedisStandaloneConfiguration
- getPortOrElse(RedisConfiguration, IntSupplier) - Static method in interface org.springframework.data.redis.connection.RedisConfiguration
- getPosition() - Method in class org.springframework.data.redis.connection.ReactiveListCommands.LInsertCommand
- getPosition() - Method in class org.springframework.data.redis.core.ConvertingCursor
- getPosition() - Method in interface org.springframework.data.redis.core.Cursor
- getPosition() - Method in class org.springframework.data.redis.core.ScanCursor
- getPrefix() - Method in class org.springframework.data.redis.core.convert.Bucket.BucketPropertyPath
- getPropertyPath() - Method in class org.springframework.data.redis.core.PartialUpdate.PropertyUpdate
-
Get the target path.
- getPropertyPath(String) - Method in class org.springframework.data.redis.core.convert.Bucket
-
Get the
Bucket.BucketPropertyPath
for a given property within the currentBucket
. - getPropertyUpdates() - Method in class org.springframework.data.redis.core.PartialUpdate
-
Get the list of individual property updates.
- getPuts() - Method in interface org.springframework.data.redis.cache.CacheStatistics
- getQualifiers() - Method in class org.springframework.data.redis.repository.cdi.CdiBean
- getQuorum() - Method in class org.springframework.data.redis.connection.RedisServer
- getRadius() - Method in class org.springframework.data.redis.domain.geo.RadiusShape
- getRange() - Method in class org.springframework.data.redis.connection.ReactiveRedisConnection.RangeCommand
- getRange() - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.PendingRecordsCommand
- getRange() - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.RangeCommand
- getRange() - Method in class org.springframework.data.redis.connection.ReactiveStringCommands.BitCountCommand
- getRange() - Method in class org.springframework.data.redis.connection.ReactiveStringCommands.BitPosCommand
- getRange() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZCountCommand
- getRange() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZLexCountCommand
- getRange() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRangeByLexCommand
- getRange() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRangeByScoreCommand
- getRange() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRangeCommand
- getRange() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRangeStoreCommand
- getRange() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRemRangeByLexCommand
- getRange() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRemRangeByRankCommand
- getRange() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRemRangeByScoreCommand
- getRange() - Method in class org.springframework.data.redis.connection.RedisStreamCommands.XPendingOptions
- getRange() - Method in class org.springframework.data.redis.connection.stream.PendingMessages
-
The
Range
pending messages have been loaded. - getRange(byte[], long, long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.stringCommands()
}. - getRange(byte[], long, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- getRange(byte[], long, long) - Method in interface org.springframework.data.redis.connection.RedisStringCommands
-
Get a substring of value of
key
betweenstart
andend
. - getRange(String, long, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- getRange(String, long, long) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get a substring of value of
key
betweenstart
andend
. - getRange(ByteBuffer, long, long) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
-
Get a substring of value of key between start and end.
- getRange(Publisher<ReactiveRedisConnection.RangeCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
-
Get a substring of value of key between start and end.
- GETRANGE - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- getRangeMode() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRangeStoreCommand
- getRank() - Method in class org.springframework.data.redis.connection.ReactiveListCommands.LPosCommand
- getRaw() - Method in class org.springframework.data.redis.connection.ReactiveListCommands.PopResult
- getRaw() - Method in enum class org.springframework.data.redis.connection.RedisClusterNode.Flag
- getRaw() - Method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoObject
- getReactiveClusterConnection() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
- getReactiveClusterConnection() - Method in interface org.springframework.data.redis.connection.ReactiveRedisConnectionFactory
- getReactiveConnection() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
- getReactiveConnection() - Method in interface org.springframework.data.redis.connection.ReactiveRedisConnectionFactory
- getReader() - Method in interface org.springframework.data.redis.serializer.RedisSerializationContext.SerializationPair
- getReadFrom() - Method in interface org.springframework.data.redis.connection.lettuce.LettuceClientConfiguration
- getReadOffset() - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.GroupCommand
- getReadOptions() - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.ReadCommand
- getReadTimeout() - Method in interface org.springframework.data.redis.connection.jedis.JedisClientConfiguration
- getRecord() - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.AddStreamRecord
- getRecordIds() - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.AcknowledgeCommand
- getRecordIds() - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.DeleteCommand
- getRedisCredentialsProviderFactory() - Method in interface org.springframework.data.redis.connection.lettuce.LettuceClientConfiguration
- getReference() - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoSearchCommand
- getReference() - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoSearchStoreCommand
- getReplicas(RedisClusterNode) - Method in interface org.springframework.data.redis.core.ClusterOperations
- getRepositoryFragments(RepositoryMetadata) - Method in class org.springframework.data.redis.repository.support.RedisRepositoryFactory
- getRequiredCommand() - Method in class org.springframework.data.redis.connection.lettuce.observability.LettuceObservationContext
-
Deprecated.
- getRequiredConnectionFactory() - Method in class org.springframework.data.redis.core.RedisAccessor
-
Returns the required
RedisConnectionFactory
, throwing anIllegalStateException
if theRedisConnectionFactory
is not set. - getRequiredEndpoint() - Method in class org.springframework.data.redis.connection.lettuce.observability.LettuceObservationContext
-
Deprecated.
- getRequiredHashMapper() - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamMessageListenerContainerOptions
- getRequiredHashMapper() - Method in class org.springframework.data.redis.stream.StreamReceiver.StreamReceiverOptions
- getRequiredNativeClient() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
Returns the native
AbstractRedisClient
used by this instance. - getRequiredPipeline() - Method in class org.springframework.data.redis.connection.jedis.JedisConnection
- getRequiredStream() - Method in interface org.springframework.data.redis.connection.stream.Record
-
The id of the stream (aka the key in Redis).
- getRequiredTransaction() - Method in class org.springframework.data.redis.connection.jedis.JedisConnection
- getResourceForSpecificNode(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.ClusterNodeResourceProvider
-
Get the client resource for the given node.
- getResultHolder() - Method in class org.springframework.data.redis.connection.FutureResult
-
Get the object holding the actual result.
- getResults() - Method in class org.springframework.data.redis.connection.ClusterCommandExecutor.MultiNodeResult
- getResultType() - Method in class org.springframework.data.redis.core.script.DefaultRedisScript
- getResultType() - Method in interface org.springframework.data.redis.core.script.RedisScript
- getResumeFunction() - Method in class org.springframework.data.redis.stream.StreamReceiver.StreamReceiverOptions
- getRetryCount() - Method in class org.springframework.data.redis.connection.RedisStreamCommands.XClaimOptions
-
Get the RETRYCOUNT count.
- getRoleReported() - Method in class org.springframework.data.redis.connection.RedisServer
- getRunId() - Method in class org.springframework.data.redis.connection.RedisServer
- getScope() - Method in class org.springframework.data.redis.repository.cdi.CdiBean
- getScore() - Method in class org.springframework.data.redis.connection.zset.DefaultTuple
- getScore() - Method in interface org.springframework.data.redis.connection.zset.Tuple
- getScore() - Method in class org.springframework.data.redis.core.DefaultTypedTuple
- getScore() - Method in interface org.springframework.data.redis.core.ZSetOperations.TypedTuple
- getScriptAsString() - Method in class org.springframework.data.redis.core.script.DefaultRedisScript
- getScriptAsString() - Method in interface org.springframework.data.redis.core.script.RedisScript
- getSentinelConfiguration() - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
- getSentinelConfiguration() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
- getSentinelConnection() - Method in class org.springframework.data.redis.connection.AbstractRedisConnection
- getSentinelConnection() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- getSentinelConnection() - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
- getSentinelConnection() - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
- getSentinelConnection() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
- getSentinelConnection() - Method in interface org.springframework.data.redis.connection.RedisConnection
- getSentinelConnection() - Method in interface org.springframework.data.redis.connection.RedisConnectionFactory
-
Returns a suitable
connection
for interacting with Redis Sentinel. - getSentinelConnection(RedisNode) - Method in class org.springframework.data.redis.connection.AbstractRedisConnection
-
Get
RedisSentinelCommands
connected to given node. - getSentinelConnection(RedisNode) - Method in class org.springframework.data.redis.connection.jedis.JedisConnection
- getSentinelConnection(RedisNode) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
- getSentinelPassword() - Method in interface org.springframework.data.redis.connection.RedisConfiguration.SentinelConfiguration
-
Returns the
RedisPassword
to use when connecting to a Redis Sentinel. - getSentinelPassword() - Method in class org.springframework.data.redis.connection.RedisSentinelConfiguration
- getSentinels() - Method in interface org.springframework.data.redis.connection.RedisConfiguration.SentinelConfiguration
-
Returns an
Collections.unmodifiableSet(Set)
of Sentinels. - getSentinels() - Method in class org.springframework.data.redis.connection.RedisSentinelConfiguration
- getSentinelUsername() - Method in interface org.springframework.data.redis.connection.RedisConfiguration.SentinelConfiguration
-
Get the username to use when connecting.
- getSentinelUsername() - Method in class org.springframework.data.redis.connection.RedisSentinelConfiguration
- getSequence() - Method in class org.springframework.data.redis.connection.stream.RecordId
-
Get the entry-id sequenceNumber part or null if it
RecordId.shouldBeAutoGenerated()
. - getSerializationContext() - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
- getSerializationContext() - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
- getSet(byte[], byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.stringCommands()
}. - getSet(byte[], byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- getSet(byte[], byte[]) - Method in interface org.springframework.data.redis.connection.RedisStringCommands
-
Set
value
ofkey
and return its old value. - getSet(String, String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- getSet(String, String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Set
value
ofkey
and return its old value. - getSet(ByteBuffer, ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
-
Set value for key and return the existing value.
- getSet(Publisher<ReactiveStringCommands.SetCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
-
Set value for key and return the existing value one by one.
- GETSET - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- getSha1() - Method in class org.springframework.data.redis.core.script.DefaultRedisScript
- getSha1() - Method in interface org.springframework.data.redis.core.script.RedisScript
- getShape() - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoSearchCommand
- getShape() - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoSearchStoreCommand
- getSharedClusterConnection() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
- getSharedConnection() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
- getSharedInstance() - Static method in class org.springframework.data.redis.hash.ObjectHashMapper
-
Return a shared default
ObjectHashMapper
instance, lazily building it once needed. - getSharedReactiveConnection() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
- getShareNativeConnection() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
Indicates if multiple
LettuceConnection
s should share a single native connection. - getShutdownQuietPeriod() - Method in interface org.springframework.data.redis.connection.lettuce.LettuceClientConfiguration
- getShutdownTimeout() - Method in interface org.springframework.data.redis.connection.lettuce.LettuceClientConfiguration
- getShutdownTimeout() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
Returns the shutdown timeout for shutting down the RedisClient (in milliseconds).
- getSince() - Method in interface org.springframework.data.redis.cache.CacheStatistics
- getSismember() - Method in class org.springframework.data.redis.repository.query.RedisOperationChain
- getSlot() - Method in exception org.springframework.data.redis.ClusterRedirectException
- getSlotRange() - Method in class org.springframework.data.redis.connection.RedisClusterNode
-
Get the served
RedisClusterNode.SlotRange
. - getSlots() - Method in class org.springframework.data.redis.connection.RedisClusterNode.SlotRange
-
Gets all slots in this
RedisClusterNode.SlotRange
managed by this cluster node. - getSlotsArray() - Method in class org.springframework.data.redis.connection.RedisClusterNode.SlotRange
- getSlotsAssigned() - Method in class org.springframework.data.redis.connection.ClusterInfo
- getSlotServingNodes(int) - Method in class org.springframework.data.redis.connection.ClusterTopology
-
Get the
RedisClusterNode
s (master and replica) serving s specific slot. - getSlotsFail() - Method in class org.springframework.data.redis.connection.ClusterInfo
- getSlotsOk() - Method in class org.springframework.data.redis.connection.ClusterInfo
- getSlotsPfail() - Method in class org.springframework.data.redis.connection.ClusterInfo
- getSocket() - Method in interface org.springframework.data.redis.connection.RedisConfiguration.WithDomainSocket
-
Get the domain socket.
- getSocket() - Method in class org.springframework.data.redis.connection.RedisSocketConfiguration
- getSocketConfiguration() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
- getSortDirection() - Method in interface org.springframework.data.redis.connection.RedisGeoCommands.GeoCommandArgs
- getSortDirection() - Method in class org.springframework.data.redis.connection.RedisGeoCommands.GeoSearchCommandArgs
- getSortDirection() - Method in class org.springframework.data.redis.connection.RedisGeoCommands.GeoSearchStoreCommandArgs
- getSource() - Method in class org.springframework.data.redis.core.RedisKeyspaceEvent
- getSourceKeys() - Method in class org.springframework.data.redis.connection.ReactiveHyperLogLogCommands.PfMergeCommand
- getSourceKeys() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZAggregateCommand
- getSourceKeys() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZAggregateStoreCommand
- getSourceKeys() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZDiffStoreCommand
- getSslParameters() - Method in interface org.springframework.data.redis.connection.jedis.JedisClientConfiguration
- getSslSocketFactory() - Method in interface org.springframework.data.redis.connection.jedis.JedisClientConfiguration
- getStandaloneConfiguration() - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
- getStandaloneConfiguration() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
- getStart() - Method in class org.springframework.data.redis.connection.SortParameters.Range
- getState() - Method in class org.springframework.data.redis.connection.ClusterInfo
- getState() - Method in interface org.springframework.data.redis.stream.Task
-
Get the current lifecycle phase.
- getStatistics() - Method in class org.springframework.data.redis.cache.RedisCache
-
Return the
CacheStatistics
snapshot for this cache instance. - getStereotypes() - Method in class org.springframework.data.redis.repository.cdi.CdiBean
- getStore() - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusByMemberCommand
- getStore() - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusCommand
- getStoreDist() - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusByMemberCommand
- getStoreDist() - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusCommand
- getStream() - Method in interface org.springframework.data.redis.connection.stream.Record
-
The id of the stream (aka the key in Redis).
- getStreamOffset() - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamReadRequest
- getStreamOffsets() - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.ReadCommand
- getStringSerializationPair() - Method in interface org.springframework.data.redis.serializer.RedisSerializationContext
- getStringSerializer() - Method in class org.springframework.data.redis.core.RedisTemplate
-
Returns the stringSerializer.
- getSubCommands() - Method in class org.springframework.data.redis.connection.BitFieldSubCommands
-
Get the
List
of sub commands. - getSubCommands() - Method in class org.springframework.data.redis.connection.ReactiveStringCommands.BitFieldCommand
- getSubscription() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- getSubscription() - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
- getSubscription() - Method in class org.springframework.data.redis.connection.jedis.JedisConnection
- getSubscription() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
- getSubscription() - Method in interface org.springframework.data.redis.connection.RedisPubSubCommands
-
Returns the current subscription for this connection or null if the connection is not subscribed.
- getTarget() - Method in class org.springframework.data.redis.connection.ReactiveKeyCommands.CopyCommand
- getTarget() - Method in class org.springframework.data.redis.core.PartialUpdate
-
Get the target type.
- getTargetConnection() - Method in interface org.springframework.data.redis.core.RedisConnectionUtils.RedisConnectionProxy
-
Return the target
RedisConnection
of this proxy. - getTargetHost() - Method in exception org.springframework.data.redis.ClusterRedirectException
- getTargetPort() - Method in exception org.springframework.data.redis.ClusterRedirectException
- getTargetType() - Method in interface org.springframework.data.redis.serializer.RedisSerializer
-
Return the serializer target type.
- getTargetType() - Method in class org.springframework.data.redis.serializer.StringRedisSerializer
- getTargetType() - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamMessageListenerContainerOptions
- getTargetType() - Method in class org.springframework.data.redis.stream.StreamReceiver.StreamReceiverOptions
- getTime() - Method in interface org.springframework.data.redis.cache.CacheStatistics
- getTime() - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection.JedisClusterTopology
-
Get the time in ms when the
ClusterTopology
was captured. - getTimeout() - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
-
Returns the timeout.
- getTimeout() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
Returns the connection timeout (in milliseconds).
- getTimeout() - Method in class org.springframework.data.redis.connection.ReactiveKeyCommands.ExpireCommand
- getTimeout() - Method in class org.springframework.data.redis.connection.ReactiveListCommands.BLMoveCommand
- getTimeout() - Method in class org.springframework.data.redis.connection.ReactiveListCommands.BPopCommand
- getTimeout() - Method in class org.springframework.data.redis.connection.ReactiveListCommands.BRPopLPushCommand
- getTimeout() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.BZPopCommand
- getTimestamp() - Method in class org.springframework.data.redis.connection.stream.RecordId
-
Get the entry-id millisecondsTime part or null if it
RecordId.shouldBeAutoGenerated()
. - getTimeToLive() - Method in class org.springframework.data.redis.core.convert.KeyspaceConfiguration.KeyspaceSettings
- getTimeToLive() - Method in class org.springframework.data.redis.core.convert.RedisData
-
Get the time before expiration in seconds.
- getTimeToLive(Object) - Method in interface org.springframework.data.redis.core.TimeToLiveAccessor
- getTimeToLive(Object, Object) - Method in record class org.springframework.data.redis.cache.FixedDurationTtlFunction
- getTimeToLive(Object, Object) - Method in interface org.springframework.data.redis.cache.RedisCacheWriter.TtlFunction
- getTimeToLiveAccessor() - Method in class org.springframework.data.redis.core.mapping.BasicRedisPersistentEntity
- getTimeToLiveAccessor() - Method in interface org.springframework.data.redis.core.mapping.RedisPersistentEntity
-
Get the
TimeToLiveAccessor
associated with the entity. - getTimeToLivePropertyName() - Method in class org.springframework.data.redis.core.convert.KeyspaceConfiguration.KeyspaceSettings
- getTimeUnit() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.BZPopCommand
- getTimeUnit() - Method in class org.springframework.data.redis.core.types.Expiration
-
Get the configured
TimeUnit
for theexpiration time
. - getTo() - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoDistCommand
- getTo() - Method in class org.springframework.data.redis.connection.ReactiveListCommands.LMoveCommand
- getTopic() - Method in class org.springframework.data.redis.listener.ChannelTopic
- getTopic() - Method in interface org.springframework.data.redis.listener.Topic
-
Returns the topic (as a String).
- getTopology() - Method in interface org.springframework.data.redis.connection.ClusterTopologyProvider
-
Get the current known
ClusterTopology
. - getTopology() - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection.JedisClusterTopologyProvider
- getTopologyProvider() - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
- getTotalDeliveryCount() - Method in class org.springframework.data.redis.connection.stream.PendingMessage
-
Get the total number of times the messages has been delivered to the
consumer
. - getTotalPendingMessages() - Method in class org.springframework.data.redis.connection.stream.PendingMessagesSummary
-
Get the number of total pending messages within the consumer group.
- getTracerProvider() - Method in class org.springframework.data.redis.connection.lettuce.observability.MicrometerTracingAdapter
-
Deprecated.
- getTransaction() - Method in class org.springframework.data.redis.connection.jedis.JedisConnection
- getTtl() - Method in class org.springframework.data.redis.cache.RedisCacheConfiguration
-
Deprecated.since 3.2. Use
RedisCacheConfiguration.getTtlFunction()
instead. - getTtlFunction() - Method in class org.springframework.data.redis.cache.RedisCacheConfiguration
-
Gets the
RedisCacheWriter.TtlFunction
used to compute a cache key time-to-live (TTL) expiration. - getTuples() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZAddCommand
- getType() - Method in class org.springframework.data.redis.connection.BitFieldSubCommands.AbstractBitFieldSubCommand
- getType() - Method in interface org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldSubCommand
-
The
BitFieldSubCommands.BitFieldType
to apply for the command. - getType() - Method in class org.springframework.data.redis.connection.RedisNode
- getType() - Method in interface org.springframework.data.redis.core.BoundKeyOperations
-
Returns the associated Redis type.
- getType() - Method in class org.springframework.data.redis.core.convert.KeyspaceConfiguration.KeyspaceSettings
- getType() - Method in class org.springframework.data.redis.core.KeyScanOptions
- getType() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicDouble
- getType() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicInteger
- getType() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicLong
- getType() - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- getType() - Method in class org.springframework.data.redis.support.collections.DefaultRedisMap
- getType() - Method in class org.springframework.data.redis.support.collections.DefaultRedisSet
- getType() - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
- getType() - Method in class org.springframework.data.redis.support.collections.RedisProperties
- getTypeInformation() - Method in class org.springframework.data.redis.core.index.IndexDefinition.IndexingContext
- getTypes() - Method in class org.springframework.data.redis.repository.cdi.CdiBean
- getUnixTime() - Method in class org.springframework.data.redis.connection.RedisStreamCommands.XClaimOptions
-
Get the TIME ms-unix-time
- getUpsert() - Method in class org.springframework.data.redis.connection.ReactiveListCommands.PushCommand
- getUsePool() - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
-
Indicates the use of a connection pool.
- getUsername() - Method in enum class org.springframework.data.redis.connection.lettuce.RedisCredentialsProviderFactory.AbsentRedisCredentials
- getUsername() - Method in class org.springframework.data.redis.connection.RedisClusterConfiguration
- getUsername() - Method in interface org.springframework.data.redis.connection.RedisConfiguration.WithAuthentication
-
Get the username to use when connecting.
- getUsername() - Method in class org.springframework.data.redis.connection.RedisSentinelConfiguration
- getUsername() - Method in class org.springframework.data.redis.connection.RedisSocketConfiguration
- getUsername() - Method in class org.springframework.data.redis.connection.RedisStandaloneConfiguration
- getUsername() - Method in class org.springframework.data.redis.connection.RedisStaticMasterReplicaConfiguration
- getUsernameOrElse(RedisConfiguration, Supplier<String>) - Static method in interface org.springframework.data.redis.connection.RedisConfiguration
- getValidateConnection() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
Indicates if validation of the native Lettuce connection is enabled.
- getValue() - Method in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldIncrBy
-
Get the increment value.
- getValue() - Method in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldSet
-
Get the value to set.
- getValue() - Method in class org.springframework.data.redis.connection.BitFieldSubCommands.Offset
- getValue() - Method in class org.springframework.data.redis.connection.ClusterCommandExecutor.NodeResult
-
Get the actual value of the command execution.
- getValue() - Method in class org.springframework.data.redis.connection.ReactiveListCommands.LInsertCommand
- getValue() - Method in class org.springframework.data.redis.connection.ReactiveListCommands.LRemCommand
- getValue() - Method in class org.springframework.data.redis.connection.ReactiveListCommands.LSetCommand
- getValue() - Method in class org.springframework.data.redis.connection.ReactiveListCommands.PopResult
- getValue() - Method in class org.springframework.data.redis.connection.ReactiveNumberCommands.DecrByCommand
- getValue() - Method in class org.springframework.data.redis.connection.ReactiveNumberCommands.HIncrByCommand
- getValue() - Method in class org.springframework.data.redis.connection.ReactiveNumberCommands.IncrByCommand
- getValue() - Method in class org.springframework.data.redis.connection.ReactiveSetCommands.SIsMemberCommand
- getValue() - Method in class org.springframework.data.redis.connection.ReactiveSetCommands.SMoveCommand
- getValue() - Method in class org.springframework.data.redis.connection.ReactiveStringCommands.AppendCommand
- getValue() - Method in class org.springframework.data.redis.connection.ReactiveStringCommands.SetBitCommand
- getValue() - Method in class org.springframework.data.redis.connection.ReactiveStringCommands.SetCommand
- getValue() - Method in class org.springframework.data.redis.connection.ReactiveStringCommands.SetRangeCommand
- getValue() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZIncrByCommand
- getValue() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRankCommand
- getValue() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZScoreCommand
- getValue() - Method in class org.springframework.data.redis.connection.RedisZSetCommands.Range.Boundary
-
Deprecated.
- getValue() - Method in interface org.springframework.data.redis.connection.stream.Record
- getValue() - Method in class org.springframework.data.redis.connection.stream.RecordId
- getValue() - Method in class org.springframework.data.redis.connection.zset.DefaultTuple
- getValue() - Method in interface org.springframework.data.redis.connection.zset.Tuple
- getValue() - Method in class org.springframework.data.redis.core.convert.GeoIndexedPropertyValue
- getValue() - Method in class org.springframework.data.redis.core.convert.SimpleIndexedPropertyValue
-
Get the value to index.
- getValue() - Method in class org.springframework.data.redis.core.DefaultTypedTuple
- getValue() - Method in class org.springframework.data.redis.core.PartialUpdate
- getValue() - Method in class org.springframework.data.redis.core.PartialUpdate.PropertyUpdate
-
Get the value to set.
- getValue() - Method in class org.springframework.data.redis.core.RedisKeyExpiredEvent
-
Get the expired Object
- getValue() - Method in interface org.springframework.data.redis.core.ZSetOperations.TypedTuple
- getValueAsString() - Method in class org.springframework.data.redis.connection.DefaultStringTuple
- getValueAsString() - Method in interface org.springframework.data.redis.connection.StringRedisConnection.StringTuple
- getValues() - Method in class org.springframework.data.redis.connection.ReactiveHyperLogLogCommands.PfAddCommand
- getValues() - Method in class org.springframework.data.redis.connection.ReactiveListCommands.PushCommand
- getValues() - Method in class org.springframework.data.redis.connection.ReactiveSetCommands.SAddCommand
- getValues() - Method in class org.springframework.data.redis.connection.ReactiveSetCommands.SMIsMemberCommand
- getValues() - Method in class org.springframework.data.redis.connection.ReactiveSetCommands.SRemCommand
- getValues() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZMScoreCommand
- getValues() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRemCommand
- getValueSerializationPair() - Method in class org.springframework.data.redis.cache.RedisCacheConfiguration
- getValueSerializationPair() - Method in interface org.springframework.data.redis.serializer.RedisSerializationContext
- getValueSerializer() - Method in interface org.springframework.data.redis.core.RedisOperations
- getValueSerializer() - Method in class org.springframework.data.redis.core.RedisTemplate
-
Returns the value serializer used by this template.
- getVerifyMode() - Method in interface org.springframework.data.redis.connection.lettuce.LettuceClientConfiguration
- getWeight(int) - Method in class org.springframework.data.redis.connection.zset.Weights
-
Retrieve the weight at
index
. - getWeights() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZAggregateCommand
- getWeights() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZAggregateStoreCommand
- getWidth() - Method in class org.springframework.data.redis.domain.geo.BoundingBox
-
Returns the width of this bounding box.
- getWriter() - Method in interface org.springframework.data.redis.serializer.RedisSerializationContext.SerializationPair
- GroupCommand(ByteBuffer, ReactiveStreamCommands.GroupCommand.GroupCommandAction, String, String, ReadOffset) - Constructor for class org.springframework.data.redis.connection.ReactiveStreamCommands.GroupCommand
- GroupCommand(ByteBuffer, ReactiveStreamCommands.GroupCommand.GroupCommandAction, String, String, ReadOffset, boolean) - Constructor for class org.springframework.data.redis.connection.ReactiveStreamCommands.GroupCommand
- groupCount() - Method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoGroups
-
Total number of associated consumer groups.
- groupCount() - Method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoStream
-
The number of associated consumer groups.
- groupName() - Method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoConsumer
-
The consumer group name.
- groupName() - Method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoGroup
-
The consumer group name.
- groups(K) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
-
Obtain information about consumer groups associated with the stream stored at the specified key.
- groups(K) - Method in interface org.springframework.data.redis.core.StreamOperations
-
Obtain information about consumer groups associated with the stream stored at the specified key.
- gt() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZAddCommand
-
Applies GT mode.
- gt() - Method in class org.springframework.data.redis.connection.RedisZSetCommands.ZAddArgs
-
Only update existing elements if the new score is greater than the current score.
- gt(Object) - Method in class org.springframework.data.redis.connection.RedisZSetCommands.Range
-
Deprecated.Greater Than
- GT - Enum constant in enum class org.springframework.data.redis.connection.RedisZSetCommands.ZAddArgs.Flag
-
Only update existing elements if the new score is greater than the current score.
- gte(Object) - Method in class org.springframework.data.redis.connection.RedisZSetCommands.Range
-
Deprecated.Greater Than Equals
H
- handleListenerException(Throwable) - Method in class org.springframework.data.redis.listener.adapter.MessageListenerAdapter
-
Handle the given exception that arose during listener execution.
- handleListenerException(Throwable) - Method in class org.springframework.data.redis.listener.RedisMessageListenerContainer
-
Handle the given exception that arose during listener execution.
- handleSubscriptionException(CompletableFuture<Void>, BackOffExecution, Throwable) - Method in class org.springframework.data.redis.listener.RedisMessageListenerContainer
-
Handle subscription task exception.
- HANDSHAKE - Enum constant in enum class org.springframework.data.redis.connection.RedisClusterNode.Flag
- hasAnyLimit() - Method in class org.springframework.data.redis.connection.RedisGeoCommands.GeoSearchCommandArgs
- hasAnyLimit() - Method in class org.springframework.data.redis.connection.RedisGeoCommands.GeoSearchStoreCommandArgs
- hasConsumer() - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.PendingRecordsCommand
- hasConsumer() - Method in class org.springframework.data.redis.connection.RedisStreamCommands.XPendingOptions
- hasExplicitTimeToLiveProperty() - Method in interface org.springframework.data.redis.core.mapping.RedisPersistentEntity
- hasExplictTimeToLiveProperty() - Method in interface org.springframework.data.redis.core.mapping.RedisPersistentEntity
-
Deprecated, for removal: This API element is subject to removal in a future version.
- hasFlags() - Method in interface org.springframework.data.redis.connection.RedisGeoCommands.GeoCommandArgs
- hash(K, M) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
-
Get Geohash representation of the position for one or more members.
- hash(K, M...) - Method in interface org.springframework.data.redis.core.GeoOperations
-
Get Geohash representation of the position for one or more members.
- hash(K, M...) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
-
Get Geohash representation of the position for one or more members.
- hash(M...) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
-
Get Geohash representation of the position for one or more members.
- HASH - Enum constant in enum class org.springframework.data.redis.connection.DataType
- hasHashMapper() - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamMessageListenerContainerOptions
- hasHashMapper() - Method in class org.springframework.data.redis.stream.StreamReceiver.StreamReceiverOptions
- hashCode() - Method in record class org.springframework.data.redis.cache.FixedDurationTtlFunction
-
Returns a hash code value for this object.
- hashCode() - Method in class org.springframework.data.redis.connection.BitFieldSubCommands.AbstractBitFieldSubCommand
- hashCode() - Method in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldIncrBy
- hashCode() - Method in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldSet
- hashCode() - Method in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldType
- hashCode() - Method in class org.springframework.data.redis.connection.BitFieldSubCommands
- hashCode() - Method in class org.springframework.data.redis.connection.BitFieldSubCommands.Offset
- hashCode() - Method in class org.springframework.data.redis.connection.ClusterCommandExecutor.NodeResult
- hashCode() - Method in class org.springframework.data.redis.connection.DefaultStringTuple
- hashCode() - Method in class org.springframework.data.redis.connection.ReactiveRedisConnection.CommandResponse
- hashCode() - Method in class org.springframework.data.redis.connection.ReactiveSubscription.ChannelMessage
- hashCode() - Method in class org.springframework.data.redis.connection.ReactiveSubscription.PatternMessage
- hashCode() - Method in class org.springframework.data.redis.connection.RedisClusterConfiguration
- hashCode() - Method in class org.springframework.data.redis.connection.RedisNode
- hashCode() - Method in class org.springframework.data.redis.connection.RedisPassword
- hashCode() - Method in class org.springframework.data.redis.connection.RedisSentinelConfiguration
- hashCode() - Method in class org.springframework.data.redis.connection.RedisSocketConfiguration
- hashCode() - Method in class org.springframework.data.redis.connection.RedisStandaloneConfiguration
- hashCode() - Method in class org.springframework.data.redis.connection.RedisStaticMasterReplicaConfiguration
- hashCode() - Method in class org.springframework.data.redis.connection.RedisStreamCommands.XAddOptions
- hashCode() - Method in class org.springframework.data.redis.connection.RedisZSetCommands.ZAddArgs
- hashCode() - Method in class org.springframework.data.redis.connection.stream.Consumer
- hashCode() - Method in class org.springframework.data.redis.connection.stream.ReadOffset
- hashCode() - Method in class org.springframework.data.redis.connection.stream.RecordId
- hashCode() - Method in class org.springframework.data.redis.connection.stream.StreamOffset
- hashCode() - Method in class org.springframework.data.redis.connection.stream.StreamReadOptions
- hashCode() - Method in class org.springframework.data.redis.connection.util.ByteArrayWrapper
- hashCode() - Method in class org.springframework.data.redis.connection.zset.DefaultTuple
- hashCode() - Method in class org.springframework.data.redis.connection.zset.Weights
- hashCode() - Method in class org.springframework.data.redis.core.convert.GeoIndexedPropertyValue
- hashCode() - Method in class org.springframework.data.redis.core.convert.SimpleIndexedPropertyValue
- hashCode() - Method in class org.springframework.data.redis.core.Cursor.CursorId
- hashCode() - Method in class org.springframework.data.redis.core.DefaultTypedTuple
- hashCode() - Method in class org.springframework.data.redis.core.index.IndexDefinition.IndexingContext
- hashCode() - Method in class org.springframework.data.redis.core.index.RedisIndexDefinition
- hashCode() - Method in class org.springframework.data.redis.core.index.SpelIndexDefinition
- hashCode() - Method in class org.springframework.data.redis.core.types.Expiration
- hashCode() - Method in class org.springframework.data.redis.core.types.RedisClientInfo
- hashCode() - Method in class org.springframework.data.redis.domain.geo.BoundingBox
- hashCode() - Method in class org.springframework.data.redis.domain.geo.GeoLocation
- hashCode() - Method in class org.springframework.data.redis.domain.geo.GeoReference.GeoCoordinateReference
- hashCode() - Method in class org.springframework.data.redis.domain.geo.GeoReference.GeoMemberReference
- hashCode() - Method in class org.springframework.data.redis.listener.ChannelTopic
- hashCode() - Method in class org.springframework.data.redis.repository.query.RedisOperationChain.PathAndValue
- hashCode() - Method in class org.springframework.data.redis.support.collections.AbstractRedisCollection
- hashCode() - Method in class org.springframework.data.redis.support.collections.DefaultRedisMap
- hashCode() - Method in class org.springframework.data.redis.support.collections.RedisProperties
- hashCommands() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- hashCommands() - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
- hashCommands() - Method in class org.springframework.data.redis.connection.jedis.JedisConnection
- hashCommands() - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
- hashCommands() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
- hashCommands() - Method in interface org.springframework.data.redis.connection.ReactiveRedisClusterConnection
- hashCommands() - Method in interface org.springframework.data.redis.connection.ReactiveRedisConnection
-
Get
ReactiveHashCommands
. - hashCommands() - Method in interface org.springframework.data.redis.connection.RedisCommandsProvider
-
Get
RedisHashCommands
. - hashKey(RedisElementReader<?>, RedisElementWriter<?>) - Method in interface org.springframework.data.redis.serializer.RedisSerializationContext.RedisSerializationContextBuilder
-
Set the hash key
RedisElementReader
andRedisElementWriter
. - hashKey(RedisSerializationContext.SerializationPair<?>) - Method in interface org.springframework.data.redis.serializer.RedisSerializationContext.RedisSerializationContextBuilder
-
Set the hash key
RedisSerializationContext.SerializationPair
. - hashKey(RedisSerializer<?>) - Method in interface org.springframework.data.redis.serializer.RedisSerializationContext.RedisSerializationContextBuilder
-
Set the hash key
RedisSerializationContext.SerializationPair
given aRedisSerializer
. - hashKeySerializer(RedisSerializationContext.SerializationPair<HK>) - Method in class org.springframework.data.redis.stream.StreamReceiver.StreamReceiverOptionsBuilder
-
Configure a hash key serializer.
- hashKeySerializer(RedisSerializer<HK>) - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamMessageListenerContainerOptionsBuilder
-
Configure a hash key serializer.
- HashMapper<T,
K, V> - Interface in org.springframework.data.redis.hash -
Core mapping contract between Java types and Redis hashes/maps.
- HashMapperProvider<HK,
HV> - Interface in org.springframework.data.redis.core -
Function that returns a
HashMapper
for a giventype
. - HashOperations<H,
HK, HV> - Interface in org.springframework.data.redis.core -
Redis map specific operations working on a hash.
- HASHTABLE - Enum constant in enum class org.springframework.data.redis.connection.ValueEncoding.RedisValueEncoding
-
Encoding for large hashes.
- hashValue(RedisElementReader<?>, RedisElementWriter<?>) - Method in interface org.springframework.data.redis.serializer.RedisSerializationContext.RedisSerializationContextBuilder
-
Set the hash value
RedisElementReader
andRedisElementWriter
. - hashValue(RedisSerializationContext.SerializationPair<?>) - Method in interface org.springframework.data.redis.serializer.RedisSerializationContext.RedisSerializationContextBuilder
-
Set the hash value
RedisSerializationContext.SerializationPair
. - hashValue(RedisSerializer<?>) - Method in interface org.springframework.data.redis.serializer.RedisSerializationContext.RedisSerializationContextBuilder
-
Set the hash value
RedisSerializationContext.SerializationPair
given aRedisSerializer
. - hashValueSerializer(RedisSerializationContext.SerializationPair<HV>) - Method in class org.springframework.data.redis.stream.StreamReceiver.StreamReceiverOptionsBuilder
-
Configure a hash value serializer.
- hashValueSerializer(RedisSerializer<HV>) - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamMessageListenerContainerOptionsBuilder
-
Configure a hash value serializer.
- hasIndexFor(Serializable) - Method in class org.springframework.data.redis.core.index.IndexConfiguration
- hasIndexFor(Serializable) - Method in interface org.springframework.data.redis.core.index.IndexDefinitionProvider
-
Checks if an index is defined for a given
keyspace
. - hasIndexFor(Serializable, String) - Method in class org.springframework.data.redis.core.index.IndexConfiguration
- hasIndexFor(Serializable, String) - Method in interface org.springframework.data.redis.core.index.IndexDefinitionProvider
-
Checks if an index is defined for a given
keyspace
and propertypath
. - hasKey(H, Object) - Method in interface org.springframework.data.redis.core.HashOperations
-
Determine if given hash
hashKey
exists. - hasKey(H, Object) - Method in interface org.springframework.data.redis.core.ReactiveHashOperations
-
Determine if given hash
hashKey
exists. - hasKey(Object) - Method in interface org.springframework.data.redis.core.BoundHashOperations
-
Determine if given hash
key
exists at the bound key. - hasKey(K) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
-
Determine if given
key
exists. - hasKey(K) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
- hasKey(K) - Method in interface org.springframework.data.redis.core.RedisOperations
-
Determine if given
key
exists. - hasKey(K) - Method in class org.springframework.data.redis.core.RedisTemplate
- hasLimit() - Method in interface org.springframework.data.redis.connection.RedisGeoCommands.GeoCommandArgs
- hasMaxlen() - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.AddStreamRecord
- hasMaxlen() - Method in class org.springframework.data.redis.connection.RedisStreamCommands.XAddOptions
- hasMillis(Duration) - Static method in class org.springframework.data.redis.core.TimeoutUtils
-
Check if a given Duration can be represented in
sec
or requiresmsec
representation. - hasMinId() - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.AddStreamRecord
- hasMinId() - Method in class org.springframework.data.redis.connection.RedisStreamCommands.XAddOptions
- hasNext() - Method in class org.springframework.data.redis.core.ConvertingCursor
- hasNext() - Method in class org.springframework.data.redis.core.ScanCursor
- hasPassword() - Method in enum class org.springframework.data.redis.connection.lettuce.RedisCredentialsProviderFactory.AbsentRedisCredentials
- hasRedisSentinelConfigured() - Method in class org.springframework.data.redis.connection.AbstractRedisConnection
- hasSettingsFor(Class<?>) - Method in class org.springframework.data.redis.core.convert.KeyspaceConfiguration
-
Check if specific
KeyspaceConfiguration.KeyspaceSettings
are available for given type. - hasSortDirection() - Method in interface org.springframework.data.redis.connection.RedisGeoCommands.GeoCommandArgs
- hasUsername() - Method in enum class org.springframework.data.redis.connection.lettuce.RedisCredentialsProviderFactory.AbsentRedisCredentials
- hasValidHost() - Method in class org.springframework.data.redis.connection.RedisNode
- hasValue(String) - Method in class org.springframework.data.redis.core.convert.Bucket
-
Return whether
path
is associated with a non-null value. - hDel(byte[], byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.hashCommands()
}. - hDel(byte[], byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- hDel(byte[], byte[]...) - Method in interface org.springframework.data.redis.connection.RedisHashCommands
-
Delete given hash
fields
. - hDel(String, String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- hDel(String, String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Delete given hash
fields
. - hDel(ByteBuffer, ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveHashCommands
-
Delete given hash field.
- hDel(ByteBuffer, Collection<ByteBuffer>) - Method in interface org.springframework.data.redis.connection.ReactiveHashCommands
-
Delete given hash fields.
- hDel(Publisher<ReactiveHashCommands.HDelCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveHashCommands
-
Delete given hash fields.
- HDEL - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- hExists(byte[], byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.hashCommands()
}. - hExists(byte[], byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- hExists(byte[], byte[]) - Method in interface org.springframework.data.redis.connection.RedisHashCommands
-
Determine if given hash
field
exists. - hExists(String, String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- hExists(String, String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Determine if given hash
field
exists. - hExists(ByteBuffer, ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveHashCommands
-
Determine if given hash field exists.
- hExists(Publisher<ReactiveHashCommands.HExistsCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveHashCommands
-
Determine if given hash field exists.
- HEXISTS - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- hGet(byte[], byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.hashCommands()
}. - hGet(byte[], byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- hGet(byte[], byte[]) - Method in interface org.springframework.data.redis.connection.RedisHashCommands
-
Get value for given
field
from hash atkey
. - hGet(String, String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- hGet(String, String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get value for given
field
from hash atkey
. - hGet(ByteBuffer, ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveHashCommands
-
Get value for given field from hash at key.
- HGET - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- hGetAll(byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.hashCommands()
}. - hGetAll(byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- hGetAll(byte[]) - Method in interface org.springframework.data.redis.connection.RedisHashCommands
-
Get entire hash stored at
key
. - hGetAll(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- hGetAll(String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get entire hash stored at
key
. - hGetAll(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveHashCommands
-
Get entire hash stored at key.
- hGetAll(Publisher<ReactiveRedisConnection.KeyCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveHashCommands
-
Get entire hash stored at key.
- HGETALL - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- HINCBYFLOAT - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- hIncrBy(byte[], byte[], double) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.hashCommands()
}. - hIncrBy(byte[], byte[], double) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- hIncrBy(byte[], byte[], double) - Method in interface org.springframework.data.redis.connection.RedisHashCommands
-
Increment
value
of a hashfield
by the givendelta
. - hIncrBy(byte[], byte[], long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.hashCommands()
}. - hIncrBy(byte[], byte[], long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- hIncrBy(byte[], byte[], long) - Method in interface org.springframework.data.redis.connection.RedisHashCommands
-
Increment
value
of a hashfield
by the givendelta
. - hIncrBy(String, String, double) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- hIncrBy(String, String, double) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Increment
value
of a hashfield
by the givendelta
. - hIncrBy(String, String, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- hIncrBy(String, String, long) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Increment
value
of a hashfield
by the givendelta
. - hIncrBy(ByteBuffer, ByteBuffer, T) - Method in interface org.springframework.data.redis.connection.ReactiveNumberCommands
-
Increment value of a hash field by the given value.
- hIncrBy(Publisher<ReactiveNumberCommands.HIncrByCommand<T>>) - Method in interface org.springframework.data.redis.connection.ReactiveNumberCommands
-
Increment value of a hash field by the given value.
- HINCRBY - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- hKeys(byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.hashCommands()
}. - hKeys(byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- hKeys(byte[]) - Method in interface org.springframework.data.redis.connection.RedisHashCommands
-
Get key set (fields) of hash at
key
. - hKeys(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- hKeys(String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get key set (fields) of hash at
key
. - hKeys(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveHashCommands
-
Get key set (fields) of hash at key.
- hKeys(Publisher<ReactiveRedisConnection.KeyCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveHashCommands
-
Get key set (fields) of hash at key.
- HKEYS - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- hLen(byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.
- hLen(byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- hLen(byte[]) - Method in interface org.springframework.data.redis.connection.RedisHashCommands
-
Get size of hash at
key
. - hLen(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- hLen(String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get size of hash at
key
. - hLen(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveHashCommands
-
Get size of hash at key.
- hLen(Publisher<ReactiveRedisConnection.KeyCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveHashCommands
-
Get size of hash at key.
- HLEN - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- hMGet(byte[], byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.hashCommands()
}. - hMGet(byte[], byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- hMGet(byte[], byte[]...) - Method in interface org.springframework.data.redis.connection.RedisHashCommands
-
Get values for given
fields
from hash atkey
. - hMGet(String, String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- hMGet(String, String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get values for given
fields
from hash atkey
. - hMGet(ByteBuffer, Collection<ByteBuffer>) - Method in interface org.springframework.data.redis.connection.ReactiveHashCommands
-
Get values for given fields from hash at key.
- hMGet(Publisher<ReactiveHashCommands.HGetCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveHashCommands
-
Get values for given fields from hash at key.
- HMGET - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- hMSet(byte[], Map<byte[], byte[]>) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.hashCommands()
}. - hMSet(byte[], Map<byte[], byte[]>) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- hMSet(byte[], Map<byte[], byte[]>) - Method in interface org.springframework.data.redis.connection.RedisHashCommands
-
Set multiple hash fields to multiple values using data provided in
hashes
- hMSet(String, Map<String, String>) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- hMSet(String, Map<String, String>) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Set multiple hash fields to multiple values using data provided in
hashes
- hMSet(ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in interface org.springframework.data.redis.connection.ReactiveHashCommands
-
Set multiple hash fields to multiple values using data provided in fieldValueMap.
- HMSET - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- HOST - Enum constant in enum class org.springframework.data.redis.connection.RedisServer.INFO
- hostnameVerifier(HostnameVerifier) - Method in class org.springframework.data.redis.connection.jedis.JedisClientConfiguration.DefaultJedisClientConfigurationBuilder
- hostnameVerifier(HostnameVerifier) - Method in interface org.springframework.data.redis.connection.jedis.JedisClientConfiguration.JedisSslClientConfigurationBuilder
- hRandField(byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.hashCommands()
}. - hRandField(byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- hRandField(byte[]) - Method in interface org.springframework.data.redis.connection.RedisHashCommands
-
Return a random field from the hash stored at
key
. - hRandField(byte[], long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.hashCommands()
}. - hRandField(byte[], long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- hRandField(byte[], long) - Method in interface org.springframework.data.redis.connection.RedisHashCommands
-
Return a random field from the hash stored at
key
. - hRandField(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- hRandField(String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Return a random field from the hash stored at
key
. - hRandField(String, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- hRandField(String, long) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Return a random field from the hash stored at
key
. - hRandField(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveHashCommands
-
Return a random field from the hash stored at
key
. - hRandField(ByteBuffer, long) - Method in interface org.springframework.data.redis.connection.ReactiveHashCommands
-
Return a random field from the hash stored at
key
. - hRandField(Publisher<ReactiveHashCommands.HRandFieldCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveHashCommands
-
Get random fields of hash at key.
- hRandFieldWithValues(byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.hashCommands()
}. - hRandFieldWithValues(byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- hRandFieldWithValues(byte[]) - Method in interface org.springframework.data.redis.connection.RedisHashCommands
-
Return a random field from the hash along with its value stored at
key
. - hRandFieldWithValues(byte[], long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.hashCommands()
}. - hRandFieldWithValues(byte[], long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- hRandFieldWithValues(byte[], long) - Method in interface org.springframework.data.redis.connection.RedisHashCommands
-
Return a random field from the hash along with its value stored at
key
. - hRandFieldWithValues(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- hRandFieldWithValues(String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Return a random field from the hash along with its value stored at
key
. - hRandFieldWithValues(String, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- hRandFieldWithValues(String, long) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Return a random field from the hash along with its value stored at
key
. - hRandFieldWithValues(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveHashCommands
-
Return a random field from the hash along with its value stored at
key
. - hRandFieldWithValues(ByteBuffer, long) - Method in interface org.springframework.data.redis.connection.ReactiveHashCommands
-
Return a random field from the hash along with its value stored at
key
. - hRandFieldWithValues(Publisher<ReactiveHashCommands.HRandFieldCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveHashCommands
-
Get random fields along their values of hash at key.
- hScan(byte[], ScanOptions) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.hashCommands()
}. - hScan(byte[], ScanOptions) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- hScan(byte[], ScanOptions) - Method in interface org.springframework.data.redis.connection.RedisHashCommands
-
Use a
Cursor
to iterate over entries in hash atkey
. - hScan(String, ScanOptions) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- hScan(String, ScanOptions) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Use a
Cursor
to iterate over entries in hash atkey
. - hScan(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveHashCommands
-
Use a
Flux
to iterate over entries in the hash atkey
. - hScan(ByteBuffer, ScanOptions) - Method in interface org.springframework.data.redis.connection.ReactiveHashCommands
- hScan(Publisher<ReactiveRedisConnection.KeyScanCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveHashCommands
-
Use a
Flux
to iterate over entries in the hash atkey
. - HSCAN - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- hSet(byte[], byte[], byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.hashCommands()
}. - hSet(byte[], byte[], byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- hSet(byte[], byte[], byte[]) - Method in interface org.springframework.data.redis.connection.RedisHashCommands
-
Set the
value
of a hashfield
. - hSet(String, String, String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- hSet(String, String, String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Set the
value
of a hashfield
. - hSet(ByteBuffer, ByteBuffer, ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveHashCommands
-
Set the value of a hash field.
- hSet(Publisher<ReactiveHashCommands.HSetCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveHashCommands
-
Set the value of a hash field.
- HSET - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- hSetNX(byte[], byte[], byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.hashCommands()
}. - hSetNX(byte[], byte[], byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- hSetNX(byte[], byte[], byte[]) - Method in interface org.springframework.data.redis.connection.RedisHashCommands
-
Set the
value
of a hashfield
only iffield
does not exist. - hSetNX(String, String, String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- hSetNX(String, String, String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Set the
value
of a hashfield
only iffield
does not exist. - hSetNX(ByteBuffer, ByteBuffer, ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveHashCommands
-
Set the value of a hash field.
- HSETNX - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- hStrLen(byte[], byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.hashCommands()
. - hStrLen(byte[], byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- hStrLen(byte[], byte[]) - Method in interface org.springframework.data.redis.connection.RedisHashCommands
-
Returns the length of the value associated with
field
in the hash stored atkey
. - hStrLen(String, String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- hStrLen(String, String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Returns the length of the value associated with
field
in the hash stored atkey
. - hStrLen(ByteBuffer, ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveHashCommands
-
Get the length of the value associated with
field
. - hStrLen(Publisher<ReactiveHashCommands.HStrLenCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveHashCommands
-
Get the length of the value associated with
field
. - hVals(byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.hashCommands()
}. - hVals(byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- hVals(byte[]) - Method in interface org.springframework.data.redis.connection.RedisHashCommands
-
Get entry set (values) of hash at
field
. - hVals(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- hVals(String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get entry set (values) of hash at
field
. - hVals(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveHashCommands
-
Get entry set (values) of hash at key.
- hVals(Publisher<ReactiveRedisConnection.KeyCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveHashCommands
-
Get entry set (values) of hash at key.
- HVALS - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- hyperLogLogCommands() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- hyperLogLogCommands() - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
- hyperLogLogCommands() - Method in class org.springframework.data.redis.connection.jedis.JedisConnection
- hyperLogLogCommands() - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
- hyperLogLogCommands() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
- hyperLogLogCommands() - Method in interface org.springframework.data.redis.connection.ReactiveRedisClusterConnection
- hyperLogLogCommands() - Method in interface org.springframework.data.redis.connection.ReactiveRedisConnection
- hyperLogLogCommands() - Method in interface org.springframework.data.redis.connection.RedisCommandsProvider
- HyperLogLogOperations<K,
V> - Interface in org.springframework.data.redis.core
I
- identityConverter() - Static method in class org.springframework.data.redis.connection.convert.Converters
-
Returns a
Converter
that always returns its input argument. - idle(Duration) - Method in class org.springframework.data.redis.connection.RedisStreamCommands.XClaimOptions
-
Set the idle time since last delivery of a message.
- idletime(byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.keyCommands()
. - idletime(byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- idletime(byte[]) - Method in interface org.springframework.data.redis.connection.RedisKeyCommands
-
Get the
Duration
since the object stored at the givenkey
is idle. - idletime(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- idletime(String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get the
Duration
since the object stored at the givenkey
is idle. - idletime(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
-
Get the
Duration
since the object stored at the givenkey
is idle. - idleTime() - Method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoConsumer
-
The idle time.
- idleTimeMs() - Method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoConsumer
-
The idle time (in millis).
- ids(String...) - Method in class org.springframework.data.redis.connection.RedisStreamCommands.XClaimOptions.XClaimOptionsBuilder
-
Set the IDs to claim.
- ids(List<?>) - Method in class org.springframework.data.redis.connection.RedisStreamCommands.XClaimOptions.XClaimOptionsBuilder
-
Set the IDs to claim.
- ids(RecordId...) - Method in class org.springframework.data.redis.connection.RedisStreamCommands.XClaimOptions.XClaimOptionsBuilder
-
Set the IDs to claim.
- ifAbsent() - Static method in enum class org.springframework.data.redis.connection.RedisStringCommands.SetOption
-
NX
- ifExists() - Method in class org.springframework.data.redis.connection.ReactiveListCommands.PushCommand
-
Disable upsert.
- ifExists() - Static method in class org.springframework.data.redis.connection.RedisZSetCommands.ZAddArgs
- ifNotExists() - Static method in class org.springframework.data.redis.connection.RedisZSetCommands.ZAddArgs
- ifPresent() - Static method in enum class org.springframework.data.redis.connection.RedisStringCommands.SetOption
-
XX
- ifValueNotExists() - Method in class org.springframework.data.redis.connection.ReactiveHashCommands.HSetCommand
-
Disable upsert.
- IMPORTING - Enum constant in enum class org.springframework.data.redis.connection.ReactiveClusterCommands.AddSlots
- IMPORTING - Enum constant in enum class org.springframework.data.redis.connection.RedisClusterCommands.AddSlots
- in(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoSearchCommand
-
Sets the geoset key.
- in(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoSearchStoreCommand
-
Sets the geoset key.
- in(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveHashCommands.HExistsCommand
-
Applies the hash key.
- in(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveStringCommands.BitPosCommand
- in(STREAM_KEY) - Method in class org.springframework.data.redis.connection.stream.StreamRecords.RecordBuilder
-
Configure a stream key.
- incDeletes(String) - Method in interface org.springframework.data.redis.cache.CacheStatisticsCollector
-
Increase the counter for delete operations of the given cache.
- incDeletesBy(String, int) - Method in interface org.springframework.data.redis.cache.CacheStatisticsCollector
-
Increase the counter for delete operations of the given cache by the given value.
- incGets(String) - Method in interface org.springframework.data.redis.cache.CacheStatisticsCollector
-
Increase the counter for get operations of the given cache.
- incHits(String) - Method in interface org.springframework.data.redis.cache.CacheStatisticsCollector
-
Increase the counter for get operations with result of the given cache.
- incLockTime(String, long) - Method in interface org.springframework.data.redis.cache.CacheStatisticsCollector
-
Increase the gauge for sync lock duration of the cache by the given nanoseconds.
- includeCommandArgsInSpanTags() - Method in class org.springframework.data.redis.connection.lettuce.observability.MicrometerTracingAdapter
-
Deprecated.
- includeCoordinates() - Method in class org.springframework.data.redis.connection.RedisGeoCommands.GeoRadiusCommandArgs
-
Sets the
RedisGeoCommands.GeoRadiusCommandArgs.Flag.WITHCOORD
flag to also return the longitude, latitude coordinates of the matching items. - includeCoordinates() - Method in class org.springframework.data.redis.connection.RedisGeoCommands.GeoSearchCommandArgs
-
Sets the
RedisGeoCommands.GeoRadiusCommandArgs.Flag.WITHCOORD
flag to also return the longitude, latitude coordinates of the matching items. - includeDistance() - Method in class org.springframework.data.redis.connection.RedisGeoCommands.GeoRadiusCommandArgs
-
Sets the
RedisGeoCommands.GeoRadiusCommandArgs.Flag.WITHDIST
flag to also return the distance of the returned items from the specified center. - includeDistance() - Method in class org.springframework.data.redis.connection.RedisGeoCommands.GeoSearchCommandArgs
-
Sets the
RedisGeoCommands.GeoRadiusCommandArgs.Flag.WITHDIST
flag to also return the distance of the returned items from the specified center. - includeFilters() - Element in annotation interface org.springframework.data.redis.repository.configuration.EnableRedisRepositories
-
Specifies which types are eligible for component scanning.
- incMisses(String) - Method in interface org.springframework.data.redis.cache.CacheStatisticsCollector
-
Increase the counter for get operations without result of the given cache.
- incPuts(String) - Method in interface org.springframework.data.redis.cache.CacheStatisticsCollector
-
Increase the counter for put operations of the given cache.
- incr() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZAddCommand
-
Applies incr mode (When this option is specified ZADD acts like ZINCRBY).
- incr(byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.stringCommands()
}. - incr(byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- incr(byte[]) - Method in interface org.springframework.data.redis.connection.RedisStringCommands
-
Increment an integer value stored as string value of
key
by 1. - incr(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- incr(String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Increment an integer value stored as string value of
key
by 1. - incr(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveNumberCommands.HIncrByCommand
-
Creates a new
ReactiveNumberCommands.HIncrByCommand
given akey
. - incr(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveNumberCommands
-
Increment value of key by 1.
- incr(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveNumberCommands.IncrByCommand
-
Creates a new
ReactiveNumberCommands.IncrByCommand
given akey
. - incr(Publisher<ReactiveRedisConnection.KeyCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveNumberCommands
-
Increment value of key by 1.
- incr(BitFieldSubCommands.BitFieldIncrBy) - Method in class org.springframework.data.redis.connection.BitFieldSubCommands
-
Create new
BitFieldSubCommands
adding givenBitFieldSubCommands.BitFieldIncrBy
to the sub commands. - incr(BitFieldSubCommands.BitFieldType) - Method in class org.springframework.data.redis.connection.BitFieldSubCommands
-
Obtain a new
BitFieldSubCommands.BitFieldIncrByBuilder
for creating and adding aBitFieldSubCommands.BitFieldIncrBy
sub command. - INCR - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- incrBy(byte[], double) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.stringCommands()
}. - incrBy(byte[], double) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- incrBy(byte[], double) - Method in interface org.springframework.data.redis.connection.RedisStringCommands
-
Increment a floating point number value of
key
bydelta
. - incrBy(byte[], long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.stringCommands()
}. - incrBy(byte[], long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- incrBy(byte[], long) - Method in interface org.springframework.data.redis.connection.RedisStringCommands
-
Increment an integer value stored of
key
bydelta
. - incrBy(String, double) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- incrBy(String, double) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Increment a floating point number value of
key
bydelta
. - incrBy(String, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- incrBy(String, long) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Increment an integer value stored of
key
bydelta
. - incrBy(ByteBuffer, T) - Method in interface org.springframework.data.redis.connection.ReactiveNumberCommands
-
Increment value of key by value.
- incrBy(Publisher<ReactiveNumberCommands.IncrByCommand<T>>) - Method in interface org.springframework.data.redis.connection.ReactiveNumberCommands
-
Increment value of key by value.
- INCRBYFLOAT - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- increment() - Method in interface org.springframework.data.redis.core.BoundValueOperations
-
Increment an integer value stored as string value under the bound key by one.
- increment(double) - Method in interface org.springframework.data.redis.core.BoundValueOperations
-
Increment a floating point number value stored as string value under the bound key by
delta
. - increment(long) - Method in interface org.springframework.data.redis.core.BoundValueOperations
-
Increment an integer value stored as string value under the bound key by
delta
. - increment(HK, double) - Method in interface org.springframework.data.redis.core.BoundHashOperations
-
Increment
value
of a hashkey
by the givendelta
at the bound key. - increment(HK, long) - Method in interface org.springframework.data.redis.core.BoundHashOperations
-
Increment
value
of a hashkey
by the givendelta
at the bound key. - increment(H, HK, double) - Method in interface org.springframework.data.redis.core.HashOperations
-
Increment
value
of a hashhashKey
by the givendelta
. - increment(H, HK, double) - Method in interface org.springframework.data.redis.core.ReactiveHashOperations
-
Increment
value
of a hashhashKey
by the givendelta
. - increment(H, HK, long) - Method in interface org.springframework.data.redis.core.HashOperations
-
Increment
value
of a hashhashKey
by the givendelta
. - increment(H, HK, long) - Method in interface org.springframework.data.redis.core.ReactiveHashOperations
-
Increment
value
of a hashhashKey
by the givendelta
. - increment(Object, double) - Method in class org.springframework.data.redis.support.collections.RedisProperties
- increment(Object, long) - Method in class org.springframework.data.redis.support.collections.RedisProperties
- increment(K) - Method in interface org.springframework.data.redis.core.ReactiveValueOperations
-
Increments the number stored at
key
by one. - increment(K) - Method in interface org.springframework.data.redis.core.ValueOperations
-
Increment an integer value stored as string value under
key
by one. - increment(K, double) - Method in interface org.springframework.data.redis.core.ReactiveValueOperations
-
Increment the string representing a floating point number stored at
key
bydelta
. - increment(K, double) - Method in interface org.springframework.data.redis.core.ValueOperations
-
Increment a floating point number value stored as string value under
key
bydelta
. - increment(K, double) - Method in class org.springframework.data.redis.support.collections.DefaultRedisMap
- increment(K, double) - Method in interface org.springframework.data.redis.support.collections.RedisMap
-
Increment
value
of the hashkey
by the givendelta
. - increment(K, long) - Method in interface org.springframework.data.redis.core.ReactiveValueOperations
-
Increments the number stored at
key
bydelta
. - increment(K, long) - Method in interface org.springframework.data.redis.core.ValueOperations
-
Increment an integer value stored as string value under
key
bydelta
. - increment(K, long) - Method in class org.springframework.data.redis.support.collections.DefaultRedisMap
- increment(K, long) - Method in interface org.springframework.data.redis.support.collections.RedisMap
-
Increment
value
of the hashkey
by the givendelta
. - incrementAndGet() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicDouble
-
Atomically increment by one the current value.
- incrementAndGet() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicInteger
-
Atomically increment by one the current value.
- incrementAndGet() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicLong
-
Atomically increment by one the current value.
- incrementScore(K, V, double) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Increment the score of element with
value
in sorted set byincrement
. - incrementScore(K, V, double) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Increment the score of element with
value
in sorted set byincrement
. - incrementScore(V, double) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Increment the score of element with
value
in sorted set byincrement
. - index(long) - Method in interface org.springframework.data.redis.core.BoundListOperations
-
Get element at
index
from list at the bound key. - index(K, long) - Method in interface org.springframework.data.redis.core.ListOperations
-
Get element at
index
from list atkey
. - index(K, long) - Method in interface org.springframework.data.redis.core.ReactiveListOperations
-
Get element at
index
from list atkey
. - indexConfiguration() - Element in annotation interface org.springframework.data.redis.repository.configuration.EnableRedisRepositories
-
Set up index patterns using simple configuration class.
- IndexConfiguration - Class in org.springframework.data.redis.core.index
-
IndexConfiguration
allows programmatic setup of indexes. - IndexConfiguration() - Constructor for class org.springframework.data.redis.core.index.IndexConfiguration
-
Creates new empty
IndexConfiguration
. - IndexDefinition - Interface in org.springframework.data.redis.core.index
-
IndexDefinition
allow to set up a blueprint for creating secondary index structures in Redis. - IndexDefinition.Condition<T> - Interface in org.springframework.data.redis.core.index
- IndexDefinition.IndexingContext - Class in org.springframework.data.redis.core.index
-
Context in which a particular value is about to get indexed.
- IndexDefinitionProvider - Interface in org.springframework.data.redis.core.index
-
IndexDefinitionProvider
give access toIndexDefinition
s for creating secondary index structures. - IndexDefinitionRegistry - Interface in org.springframework.data.redis.core.index
-
Registry that allows adding
IndexDefinition
. - Indexed - Annotation Interface in org.springframework.data.redis.core.index
-
Mark properties value to be included in a secondary index.
- IndexedData - Interface in org.springframework.data.redis.core.convert
-
IndexedData
represents a secondary index for a property path in a given keyspace. - IndexingContext(String, String, TypeInformation<?>) - Constructor for class org.springframework.data.redis.core.index.IndexDefinition.IndexingContext
- indexOf(byte[], byte) - Static method in class org.springframework.data.redis.util.ByteUtils
-
Searches the specified array of bytes for the specified value.
- indexOf(Object) - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- indexOf(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRankCommand
-
Creates a new
ReactiveZSetCommands.ZRankCommand
given amember
to obtain its rank (ordering low to high). - indexOf(K, V) - Method in interface org.springframework.data.redis.core.ListOperations
-
Returns the index of the first occurrence of the specified value in the list at at
key
. - indexOf(K, V) - Method in interface org.springframework.data.redis.core.ReactiveListOperations
-
Returns the index of the first occurrence of the specified value in the list at at
key
. - indexOf(V) - Method in interface org.springframework.data.redis.core.BoundListOperations
-
Returns the index of the first occurrence of the specified value in the list at at
key
. - IndexResolver - Interface in org.springframework.data.redis.core.convert
-
IndexResolver
extracts secondary index structures to be applied on a given path,PersistentProperty
and value. - IndexValueTransformer - Interface in org.springframework.data.redis.core.index
-
Converter
implementation that is used to transform values for usage in a particular secondary index. - info() - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.serverCommands()
. - info() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- info() - Method in interface org.springframework.data.redis.connection.ReactiveServerCommands
-
Load default server information like memory cpu utilization replication
- info() - Method in interface org.springframework.data.redis.connection.RedisServerCommands
-
Load default server information like memory cpu utilization replication
- info(String) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.serverCommands()
. - info(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- info(String) - Method in interface org.springframework.data.redis.connection.ReactiveServerCommands
-
Load server information for given
selection
. - info(String) - Method in interface org.springframework.data.redis.connection.RedisServerCommands
-
Load server information for given
selection
. - info(K) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
-
Obtain general information about the stream stored at the specified key.
- info(K) - Method in interface org.springframework.data.redis.core.StreamOperations
-
Obtain general information about the stream stored at the specified key.
- info(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.DefaultedRedisClusterConnection
-
Deprecated.in favor of
RedisCommandsProvider.serverCommands()
. - info(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.ReactiveClusterServerCommands
-
Load default server information like memory cpu utilization replication
- info(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.RedisClusterServerCommands
- info(RedisClusterNode, String) - Method in interface org.springframework.data.redis.connection.DefaultedRedisClusterConnection
-
Deprecated.in favor of
RedisCommandsProvider.serverCommands()
. - info(RedisClusterNode, String) - Method in interface org.springframework.data.redis.connection.ReactiveClusterServerCommands
-
Load server information for given
selection
. - info(RedisClusterNode, String) - Method in interface org.springframework.data.redis.connection.RedisClusterServerCommands
- INFO - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- INFO_REFRESH - Enum constant in enum class org.springframework.data.redis.connection.RedisServer.INFO
- inGroup(String) - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.AcknowledgeCommand
-
Applies the group.
- init() - Method in class org.springframework.data.redis.listener.KeyspaceEventMessageListener
-
Initialize the message listener by writing requried redis config for notify-keyspace-events and registering the listener within the container.
- initConnection() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
Initialize the shared connection if
native connection sharing
is enabled and reset any previously existing connection. - initDefaultStrategies() - Method in class org.springframework.data.redis.listener.adapter.MessageListenerAdapter
-
Initialize the default implementations for the adapter's strategies.
- initial() - Static method in class org.springframework.data.redis.core.Cursor.CursorId
-
Creates a new initial
Cursor.CursorId
. - initialCacheNames(Set<String>) - Method in class org.springframework.data.redis.cache.RedisCacheManager.RedisCacheManagerBuilder
-
Append a
Set
of cache names to be pre initialized with currentRedisCacheConfiguration
. - initialConfiguration() - Method in class org.springframework.data.redis.core.convert.KeyspaceConfiguration
-
Customization hook.
- initialConfiguration() - Method in class org.springframework.data.redis.core.index.IndexConfiguration
-
Customization hook.
- initialize() - Method in class org.springframework.data.redis.repository.cdi.CdiBean
-
Forces the initialization of bean target.
- initializeList(List<T>, int) - Static method in class org.springframework.data.redis.support.collections.CollectionUtils
- initialTraceContextProvider() - Method in class org.springframework.data.redis.connection.lettuce.observability.MicrometerTracingAdapter
-
Deprecated.
- insert(Object, T) - Method in class org.springframework.data.redis.core.RedisKeyValueTemplate
- INSTANCE - Enum constant in enum class org.springframework.data.redis.connection.convert.MapToPropertiesConverter
- INSTANCE - Enum constant in enum class org.springframework.data.redis.core.index.RedisIndexDefinition.LowercaseIndexValueTransformer
- INSTANCE - Enum constant in enum class org.springframework.data.redis.core.index.RedisIndexDefinition.NoOpValueTransformer
- INSTANCE - Static variable in class org.springframework.data.redis.connection.convert.LongToBooleanConverter
- INSTANCE - Static variable in class org.springframework.data.redis.connection.convert.StringToRedisClientInfoConverter
- INT - Enum constant in enum class org.springframework.data.redis.connection.ValueEncoding.RedisValueEncoding
-
64 bit signed interval String representing an integer.
- INT_16 - Static variable in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldType
-
16 bit signed Integer
- INT_32 - Static variable in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldType
-
32 bit signed Integer
- INT_64 - Static variable in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldType
-
64 bit signed Integer
- INT_8 - Static variable in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldType
-
8 bit signed Integer
- INTEGER - Enum constant in enum class org.springframework.data.redis.connection.ReturnType
-
Returned as
Long
- intersect(Collection<? extends RedisSet<?>>) - Method in class org.springframework.data.redis.support.collections.DefaultRedisSet
- intersect(Collection<? extends RedisSet<?>>) - Method in interface org.springframework.data.redis.support.collections.RedisSet
-
Intersect this set and other
RedisSet
s. - intersect(Collection<? extends RedisZSet<?>>) - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
- intersect(Collection<? extends RedisZSet<?>>) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
-
Intersect this set and other
RedisZSet
s. - intersect(Collection<K>) - Method in interface org.springframework.data.redis.core.BoundSetOperations
-
Returns the members intersecting all given sets at the bound key and
keys
. - intersect(Collection<K>) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Intersect sorted
sets
. - intersect(Collection<K>) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
-
Returns the members intersecting all given sets at
keys
. - intersect(Collection<K>) - Method in interface org.springframework.data.redis.core.SetOperations
-
Returns the members intersecting all given sets at
keys
. - intersect(K) - Method in interface org.springframework.data.redis.core.BoundSetOperations
-
Returns the members intersecting all given sets at the bound key and
key
. - intersect(K) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Intersect sorted
sets
. - intersect(K, Collection<K>) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
-
Returns the members intersecting all given sets at
key
andotherKeys
. - intersect(K, Collection<K>) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Intersect sorted
sets
. - intersect(K, Collection<K>) - Method in interface org.springframework.data.redis.core.SetOperations
-
Returns the members intersecting all given sets at
key
andotherKeys
. - intersect(K, Collection<K>) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Intersect sorted
sets
. - intersect(K, K) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
-
Returns the members intersecting all given sets at
key
andotherKey
. - intersect(K, K) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Intersect sorted
sets
. - intersect(K, K) - Method in interface org.springframework.data.redis.core.SetOperations
-
Returns the members intersecting all given sets at
key
andotherKey
. - intersect(K, K) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Intersect sorted
sets
. - intersect(RedisSet<?>) - Method in class org.springframework.data.redis.support.collections.DefaultRedisSet
- intersect(RedisSet<?>) - Method in interface org.springframework.data.redis.support.collections.RedisSet
-
Intersect this set and another
RedisSet
. - intersect(RedisZSet<?>) - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
- intersect(RedisZSet<?>) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
-
Intersect this set and another
RedisZSet
. - intersectAndStore(Collection<? extends RedisSet<?>>, String) - Method in class org.springframework.data.redis.support.collections.DefaultRedisSet
- intersectAndStore(Collection<? extends RedisSet<?>>, String) - Method in interface org.springframework.data.redis.support.collections.RedisSet
- intersectAndStore(Collection<? extends RedisZSet<?>>, String) - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
- intersectAndStore(Collection<? extends RedisZSet<?>>, String) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
- intersectAndStore(Collection<K>, K) - Method in interface org.springframework.data.redis.core.BoundSetOperations
-
Intersect all given sets at the bound key and
keys
and store result indestKey
. - intersectAndStore(Collection<K>, K) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Intersect sorted sets at the bound key and
otherKeys
and store result in destinationdestKey
. - intersectAndStore(Collection<K>, K) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
-
Intersect all given sets at
keys
and store result indestKey
. - intersectAndStore(Collection<K>, K) - Method in interface org.springframework.data.redis.core.SetOperations
-
Intersect all given sets at
keys
and store result indestKey
. - intersectAndStore(Collection<K>, K, Aggregate) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Intersect sorted sets at the bound key and
otherKeys
and store result in destinationdestKey
. - intersectAndStore(Collection<K>, K, Aggregate, Weights) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Intersect sorted sets at the bound key and
otherKeys
and store result in destinationdestKey
. - intersectAndStore(K, Collection<K>, K) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
-
Intersect all given sets at
key
andotherKeys
and store result indestKey
. - intersectAndStore(K, Collection<K>, K) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Intersect sorted sets at
key
andotherKeys
and store result in destinationdestKey
. - intersectAndStore(K, Collection<K>, K) - Method in interface org.springframework.data.redis.core.SetOperations
-
Intersect all given sets at
key
andotherKeys
and store result indestKey
. - intersectAndStore(K, Collection<K>, K) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Intersect sorted sets at
key
andotherKeys
and store result in destinationdestKey
. - intersectAndStore(K, Collection<K>, K, Aggregate) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Intersect sorted sets at
key
andotherKeys
and store result in destinationdestKey
. - intersectAndStore(K, Collection<K>, K, Aggregate) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Intersect sorted sets at
key
andotherKeys
and store result in destinationdestKey
. - intersectAndStore(K, Collection<K>, K, Aggregate, Weights) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Intersect sorted sets at
key
andotherKeys
and store result in destinationdestKey
. - intersectAndStore(K, Collection<K>, K, Aggregate, Weights) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Intersect sorted sets at
key
andotherKeys
and store result in destinationdestKey
. - intersectAndStore(K, K) - Method in interface org.springframework.data.redis.core.BoundSetOperations
-
Intersect all given sets at the bound key and
key
and store result indestKey
. - intersectAndStore(K, K) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Intersect sorted sets at the bound key and
otherKey
and store result in destinationdestKey
. - intersectAndStore(K, K, K) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
-
Intersect all given sets at
key
andotherKey
and store result indestKey
. - intersectAndStore(K, K, K) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Intersect sorted sets at
key
andotherKey
and store result in destinationdestKey
. - intersectAndStore(K, K, K) - Method in interface org.springframework.data.redis.core.SetOperations
-
Intersect all given sets at
key
andotherKey
and store result indestKey
. - intersectAndStore(K, K, K) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Intersect sorted sets at
key
andotherKey
and store result in destinationdestKey
. - intersectAndStore(RedisSet<?>, String) - Method in class org.springframework.data.redis.support.collections.DefaultRedisSet
- intersectAndStore(RedisSet<?>, String) - Method in interface org.springframework.data.redis.support.collections.RedisSet
- intersectAndStore(RedisZSet<?>, String) - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
- intersectAndStore(RedisZSet<?>, String) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
- intersectWithScores(Collection<? extends RedisZSet<?>>) - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
- intersectWithScores(Collection<? extends RedisZSet<?>>) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
-
Intersect this set and other
RedisZSet
s. - intersectWithScores(Collection<K>) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Intersect sorted
sets
. - intersectWithScores(Collection<K>, Aggregate, Weights) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Intersect sorted
sets
. - intersectWithScores(K) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Intersect sorted
sets
. - intersectWithScores(K, Collection<K>) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Intersect sorted
sets
. - intersectWithScores(K, Collection<K>) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Intersect sorted
sets
. - intersectWithScores(K, Collection<K>, Aggregate) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Intersect sorted sets at
key
andotherKeys
. - intersectWithScores(K, Collection<K>, Aggregate) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Intersect sorted sets at
key
andotherKeys
. - intersectWithScores(K, Collection<K>, Aggregate, Weights) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Intersect sorted
sets
. - intersectWithScores(K, Collection<K>, Aggregate, Weights) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Intersect sorted
sets
. - intersectWithScores(K, K) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Intersect sorted
sets
. - intersectWithScores(K, K) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Intersect sorted
sets
. - intersectWithScores(RedisZSet<?>) - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
- intersectWithScores(RedisZSet<?>) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
-
Intersect this set and another
RedisZSet
. - into(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveHyperLogLogCommands.PfMergeCommand
-
Applies the destinationKey.
- INTSET - Enum constant in enum class org.springframework.data.redis.connection.ValueEncoding.RedisValueEncoding
-
Space saving representation for small sets that contain only integers.ø
- intValue() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicDouble
- intValue() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicInteger
- intValue() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicLong
- invokeErrorHandler(Throwable) - Method in class org.springframework.data.redis.listener.RedisMessageListenerContainer
-
Invoke the registered ErrorHandler, if any.
- invokeListenerMethod(String, Object[]) - Method in class org.springframework.data.redis.listener.adapter.MessageListenerAdapter
-
Invoke the specified listener method.
- isActive() - Method in class org.springframework.data.redis.listener.RedisMessageListenerContainer
-
Return whether this container is currently active, that is, whether it has been set up but not shut down yet.
- isActive() - Method in interface org.springframework.data.redis.stream.Subscription
- isActive() - Method in interface org.springframework.data.redis.stream.Task
- isActive(RedisNode) - Method in class org.springframework.data.redis.connection.AbstractRedisConnection
-
Check if node is active by sending ping.
- isActive(RedisNode) - Method in class org.springframework.data.redis.connection.jedis.JedisConnection
- isActive(RedisNode) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
- isAlive() - Method in interface org.springframework.data.redis.connection.Subscription
-
Indicates whether this subscription is still 'alive' or not.
- isAlive() - Method in class org.springframework.data.redis.connection.util.AbstractSubscription
- isAllowRuntimeCacheCreation() - Method in class org.springframework.data.redis.cache.RedisCacheManager
-
Determines whether
Redis caches
are allowed to be created at runtime. - isAlphabetic() - Method in class org.springframework.data.redis.connection.DefaultSortParameters
- isAlphabetic() - Method in interface org.springframework.data.redis.connection.SortParameters
-
Indicates if the sorting is numeric (default) or alphabetical (lexicographical).
- isAlphabetic() - Method in interface org.springframework.data.redis.core.query.SortQuery
-
Indicates if the sorting is numeric (default) or alphabetical (lexicographical).
- isAlternative() - Method in class org.springframework.data.redis.repository.cdi.CdiBean
- isApproximateTrimming() - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.AddStreamRecord
- isApproximateTrimming() - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.TrimCommand
- isApproximateTrimming() - Method in class org.springframework.data.redis.connection.RedisStreamCommands.XAddOptions
- isAsync(RedisConnectionFactory) - Static method in class org.springframework.data.redis.connection.ConnectionUtils
- isAuthenticationAware(RedisConfiguration) - Static method in interface org.springframework.data.redis.connection.RedisConfiguration
- isAutoAcknowledge() - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.ConsumerStreamReadRequest
- isAutoStartup() - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
- isAutoStartup() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
- isBlocking() - Method in class org.springframework.data.redis.connection.stream.StreamReadOptions
- isClosed() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- isClosed() - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
- isClosed() - Method in class org.springframework.data.redis.connection.jedis.JedisConnection
- isClosed() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
- isClosed() - Method in interface org.springframework.data.redis.connection.RedisConnection
-
Indicates whether the underlying connection is closed or not.
- isClosed() - Method in class org.springframework.data.redis.core.ConvertingCursor
- isClosed() - Method in interface org.springframework.data.redis.core.Cursor
- isClosed() - Method in class org.springframework.data.redis.core.ScanCursor
- isClusterAware() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
- isClusterConfiguration(RedisConfiguration) - Static method in interface org.springframework.data.redis.connection.RedisConfiguration
- isConnected() - Method in class org.springframework.data.redis.connection.RedisClusterNode
- isConnectionTransactional(RedisConnection, RedisConnectionFactory) - Static method in class org.springframework.data.redis.core.RedisConnectionUtils
-
Return whether the given Redis connection is transactional, that is, bound to the current thread by Spring's transaction facilities.
- isDatabaseIndexAware(RedisConfiguration) - Static method in interface org.springframework.data.redis.connection.RedisConfiguration
- isDomainSocketConfiguration(RedisConfiguration) - Static method in interface org.springframework.data.redis.connection.RedisConfiguration
- isEarlyStartup() - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
- isEarlyStartup() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
- isEmpty() - Method in class org.springframework.data.redis.connection.RedisZSetCommands.ZAddArgs
- isEmpty() - Method in class org.springframework.data.redis.connection.stream.PendingMessages
- isEmpty() - Method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoConsumers
- isEmpty() - Method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoGroups
- isEmpty() - Method in class org.springframework.data.redis.connection.util.ByteArraySet
- isEmpty() - Method in class org.springframework.data.redis.core.convert.Bucket
- isEmpty() - Method in class org.springframework.data.redis.repository.query.RedisOperationChain
- isEmpty() - Method in class org.springframework.data.redis.support.collections.DefaultRedisMap
- isEmpty() - Method in class org.springframework.data.redis.support.collections.RedisProperties
- isEnabled() - Method in class org.springframework.data.redis.connection.lettuce.observability.MicrometerTracingAdapter
-
Deprecated.
- isEnableDefaultSerializer() - Method in class org.springframework.data.redis.core.RedisTemplate
-
Returns whether the default serializer should be used or not.
- isExpiring() - Method in interface org.springframework.data.redis.core.mapping.RedisPersistentEntity
- isExpiringEntity(Class<?>) - Method in interface org.springframework.data.redis.core.TimeToLiveAccessor
- isExposeConnection() - Method in class org.springframework.data.redis.core.RedisTemplate
-
Returns whether the underlying RedisConnection should be directly exposed to the RedisCallback code, or rather a connection proxy (default behavior).
- isFinished(long) - Method in class org.springframework.data.redis.core.ScanCursor
-
Deprecated, for removal: This API element is subject to removal in a future version.
- isFinished(Cursor.CursorId) - Method in class org.springframework.data.redis.core.ScanCursor
-
Check whether
cursorId
is finished. - isForce() - Method in class org.springframework.data.redis.connection.RedisStreamCommands.XClaimOptions
-
Get the FORCE flag.
- isGt() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZAddCommand
- isHostAndPortAware(RedisConfiguration) - Static method in interface org.springframework.data.redis.connection.RedisConfiguration
- isIdProperty() - Method in class org.springframework.data.redis.core.mapping.RedisPersistentProperty
- isIfExists() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZAddCommand
- isIfNotExists() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZAddCommand
- isIncluding() - Method in class org.springframework.data.redis.connection.RedisZSetCommands.Range.Boundary
-
Deprecated.
- isIncr() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZAddCommand
- isInitial() - Method in class org.springframework.data.redis.core.Cursor.CursorId
-
Returns whether the current cursor identifier represent an initial cursor identifier to indicate an initial/finished cursor state.
- isInitial(String) - Static method in class org.springframework.data.redis.core.Cursor.CursorId
-
Returns whether the given
cursorId
represent an initial cursor identifier to indicate an initial/finished cursor state. - isJedis(RedisConnectionFactory) - Static method in class org.springframework.data.redis.connection.ConnectionUtils
- isKeepTtl() - Method in class org.springframework.data.redis.core.types.Expiration
- isLettuce(RedisConnectionFactory) - Static method in class org.springframework.data.redis.connection.ConnectionUtils
- isLimited() - Method in class org.springframework.data.redis.connection.Limit
- isLimited() - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.PendingRecordsCommand
- isLimited() - Method in class org.springframework.data.redis.connection.RedisStreamCommands.XPendingOptions
- isListening() - Method in class org.springframework.data.redis.listener.RedisMessageListenerContainer
- isLt() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZAddCommand
- isMarkedAsFail() - Method in class org.springframework.data.redis.connection.RedisClusterNode
- isMaster() - Method in class org.springframework.data.redis.connection.RedisNode
- isMaster() - Method in class org.springframework.data.redis.connection.RedisServer
- isMember(Object) - Method in interface org.springframework.data.redis.core.BoundSetOperations
-
Check if set at the bound key contains
value
. - isMember(Object...) - Method in interface org.springframework.data.redis.core.BoundSetOperations
-
Check if set at at the bound key contains one or more
values
. - isMember(K, Object) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
-
Check if set at
key
containsvalue
. - isMember(K, Object) - Method in interface org.springframework.data.redis.core.SetOperations
-
Check if set at
key
containsvalue
. - isMember(K, Object...) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
-
Check if set at
key
contains one or morevalues
. - isMember(K, Object...) - Method in interface org.springframework.data.redis.core.SetOperations
-
Check if set at
key
contains one or morevalues
. - isMkStream() - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.GroupCommand
- isNoack() - Method in class org.springframework.data.redis.connection.stream.StreamReadOptions
- isNoMkStream() - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.AddStreamRecord
- isNoMkStream() - Method in class org.springframework.data.redis.connection.RedisStreamCommands.XAddOptions
- isNullable() - Method in class org.springframework.data.redis.repository.cdi.CdiBean
- ISO_8859_1 - Static variable in class org.springframework.data.redis.serializer.StringRedisSerializer
-
StringRedisSerializer
to use ISO Latin Alphabet No. 1, a.k.a. - isOpen() - Method in class org.springframework.data.redis.connection.jedis.JedisSentinelConnection
- isOpen() - Method in class org.springframework.data.redis.connection.lettuce.LettuceSentinelConnection
- isOpen() - Method in interface org.springframework.data.redis.connection.RedisSentinelConnection
- isOpen() - Method in class org.springframework.data.redis.core.ScanCursor
- isPersistent() - Method in class org.springframework.data.redis.core.types.Expiration
- isPhantomKey() - Method in class org.springframework.data.redis.core.convert.MappingRedisConverter.BinaryKeyspaceIdentifier
- isPhantomKey() - Method in class org.springframework.data.redis.core.convert.MappingRedisConverter.KeyspaceIdentifier
- isPipelined() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- isPipelined() - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
- isPipelined() - Method in class org.springframework.data.redis.connection.jedis.JedisConnection
- isPipelined() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
- isPipelined() - Method in interface org.springframework.data.redis.connection.RedisConnection
-
Indicates whether the connection is currently pipelined or not.
- isPresent() - Method in class org.springframework.data.redis.connection.ReactiveRedisConnection.AbsentByteBufferResponse
- isPresent() - Method in class org.springframework.data.redis.connection.ReactiveRedisConnection.CommandResponse
- isPresent() - Method in class org.springframework.data.redis.connection.RedisPassword
-
Return
true
if there is a password present, otherwisefalse
. - isQueueing() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- isQueueing() - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
- isQueueing() - Method in class org.springframework.data.redis.connection.jedis.JedisConnection
- isQueueing() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
- isQueueing() - Method in interface org.springframework.data.redis.connection.RedisConnection
-
Indicates whether the connection is in "queue"(or "MULTI") mode or not.
- isRead() - Method in enum class org.springframework.data.redis.core.RedisCommand
- isReadonly() - Method in enum class org.springframework.data.redis.core.RedisCommand
- isReady() - Method in class org.springframework.data.redis.core.ScanCursor
- isRedisClusterAware() - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
- isRedisSentinelAware() - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
- isRedisSentinelAware() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
- isRefreshTtl() - Method in class org.springframework.data.redis.core.PartialUpdate
- isReplace() - Method in class org.springframework.data.redis.connection.ReactiveKeyCommands.CopyCommand
- isReplica() - Method in class org.springframework.data.redis.connection.RedisNode
- isRepresentedBy(String) - Method in enum class org.springframework.data.redis.core.RedisCommand
-
Compares
the givenString
representing the Redis command to theEnum.toString()
representation ofRedisCommand
as well as anyRedisCommand.alias
. - isReturnTotalChanged() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZAddCommand
- isRunning() - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
- isRunning() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
- isRunning() - Method in class org.springframework.data.redis.core.RedisKeyValueAdapter
- isRunning() - Method in class org.springframework.data.redis.listener.RedisMessageListenerContainer
- isSameSlotForAllKeys(byte[]...) - Static method in class org.springframework.data.redis.connection.ClusterSlotHashUtil
-
Determines whether all keys will hash to the same slot.
- isSameSlotForAllKeys(ByteBuffer...) - Static method in class org.springframework.data.redis.connection.ClusterSlotHashUtil
-
Determines whether all keys will hash to the same slot.
- isSameSlotForAllKeys(Collection<ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ClusterSlotHashUtil
-
Determines whether all keys will hash to the same slot.
- isSentinelConfiguration(RedisConfiguration) - Static method in interface org.springframework.data.redis.connection.RedisConfiguration
- isSigned() - Method in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldType
- isSingleValue() - Method in class org.springframework.data.redis.repository.query.RedisOperationChain.PathAndValue
- isStartTls() - Method in interface org.springframework.data.redis.connection.lettuce.LettuceClientConfiguration
- isStartTls() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
Returns whether to issue a StartTLS.
- isStaticMasterReplicaConfiguration(RedisConfiguration) - Static method in interface org.springframework.data.redis.connection.RedisConfiguration
- isStatus() - Method in class org.springframework.data.redis.connection.FutureResult
-
Indicates if this result is the status of an operation.
- isStoreDistance() - Method in class org.springframework.data.redis.connection.RedisGeoCommands.GeoSearchStoreCommandArgs
- isSubscribed() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- isSubscribed() - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
- isSubscribed() - Method in class org.springframework.data.redis.connection.jedis.JedisConnection
- isSubscribed() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
- isSubscribed() - Method in interface org.springframework.data.redis.connection.RedisPubSubCommands
-
Indicates whether the current connection is subscribed (to at least one channel) or not.
- isTimeToIdleEnabled() - Method in class org.springframework.data.redis.cache.RedisCacheConfiguration
-
Determines whether time-to-idle (TTI) expiration has been enabled for caching.
- isTypeKey(String) - Method in class org.springframework.data.redis.core.convert.DefaultRedisTypeMapper
- isTypeKey(String) - Method in interface org.springframework.data.redis.core.convert.RedisTypeMapper
-
Returns whether the given
key
is the type key. - isUnixTimestamp() - Method in class org.springframework.data.redis.core.types.Expiration
- isUnlimited() - Method in class org.springframework.data.redis.connection.Limit
- isUpsert() - Method in class org.springframework.data.redis.connection.ReactiveHashCommands.HSetCommand
- isUpsert() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZAddCommand
- isUsePooling() - Method in interface org.springframework.data.redis.connection.jedis.JedisClientConfiguration
- isUseSsl() - Method in interface org.springframework.data.redis.connection.jedis.JedisClientConfiguration
- isUseSsl() - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
-
Returns whether to use SSL.
- isUseSsl() - Method in interface org.springframework.data.redis.connection.lettuce.LettuceClientConfiguration
- isUseSsl() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
Returns whether to use SSL.
- isValid(byte[]) - Static method in class org.springframework.data.redis.core.convert.MappingRedisConverter.BinaryKeyspaceIdentifier
-
Check whether the
key
is valid, in particular whether the key contains a keyspace and an id part in the form of keyspace:id. - isValid(String) - Static method in class org.springframework.data.redis.core.convert.MappingRedisConverter.KeyspaceIdentifier
-
Check whether the
key
is valid, in particular whether the key contains a keyspace and an id part in the form of keyspace:id. - isVerifyPeer() - Method in interface org.springframework.data.redis.connection.lettuce.LettuceClientConfiguration
-
Deprecated.since 3.4, use
LettuceClientConfiguration.getVerifyMode()
for how peer verification is configured. - isVerifyPeer() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
Deprecated.since 3.4, use
LettuceClientConfiguration.getVerifyMode()
instead. - isWithScores() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRangeByScoreCommand
- isWithScores() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRangeCommand
- isWrite() - Method in enum class org.springframework.data.redis.core.RedisCommand
- isZeroBased() - Method in class org.springframework.data.redis.connection.BitFieldSubCommands.Offset
- iterator() - Method in class org.springframework.data.redis.connection.BitFieldSubCommands
- iterator() - Method in class org.springframework.data.redis.connection.stream.PendingMessages
- iterator() - Method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoConsumers
-
Returns an iterator over the
StreamInfo.XInfoConsumer
elements. - iterator() - Method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoGroups
-
Returns an iterator over the
StreamInfo.XInfoGroup
elements. - iterator() - Method in class org.springframework.data.redis.connection.util.ByteArraySet
- iterator() - Method in class org.springframework.data.redis.core.ScanIteration
- iterator() - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- iterator() - Method in class org.springframework.data.redis.support.collections.DefaultRedisSet
- iterator() - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
J
- Jackson2HashMapper - Class in org.springframework.data.redis.hash
-
ObjectMapper
basedHashMapper
implementation that allows flattening. - Jackson2HashMapper(boolean) - Constructor for class org.springframework.data.redis.hash.Jackson2HashMapper
-
Creates new
Jackson2HashMapper
with a defaultObjectMapper
. - Jackson2HashMapper(ObjectMapper, boolean) - Constructor for class org.springframework.data.redis.hash.Jackson2HashMapper
-
Creates new
Jackson2HashMapper
initialized with a custom JacksonObjectMapper
. - Jackson2JsonRedisSerializer<T> - Class in org.springframework.data.redis.serializer
- Jackson2JsonRedisSerializer(JavaType) - Constructor for class org.springframework.data.redis.serializer.Jackson2JsonRedisSerializer
-
Creates a new
Jackson2JsonRedisSerializer
for the given targetJavaType
. - Jackson2JsonRedisSerializer(ObjectMapper, JavaType) - Constructor for class org.springframework.data.redis.serializer.Jackson2JsonRedisSerializer
-
Creates a new
Jackson2JsonRedisSerializer
for the given targetJavaType
. - Jackson2JsonRedisSerializer(ObjectMapper, JavaType, JacksonObjectReader, JacksonObjectWriter) - Constructor for class org.springframework.data.redis.serializer.Jackson2JsonRedisSerializer
-
Creates a new
Jackson2JsonRedisSerializer
for the given targetJavaType
. - Jackson2JsonRedisSerializer(ObjectMapper, Class<T>) - Constructor for class org.springframework.data.redis.serializer.Jackson2JsonRedisSerializer
-
Creates a new
Jackson2JsonRedisSerializer
for the given targetClass
. - Jackson2JsonRedisSerializer(Class<T>) - Constructor for class org.springframework.data.redis.serializer.Jackson2JsonRedisSerializer
-
Creates a new
Jackson2JsonRedisSerializer
for the given targetClass
. - JacksonObjectReader - Interface in org.springframework.data.redis.serializer
-
Defines the contract for Object Mapping readers.
- JacksonObjectWriter - Interface in org.springframework.data.redis.serializer
-
Defines the contract for Object Mapping writers.
- java() - Static method in interface org.springframework.data.redis.serializer.RedisSerializationContext
-
Creates a new
RedisSerializationContext
using aJdkSerializationRedisSerializer
. - java() - Static method in interface org.springframework.data.redis.serializer.RedisSerializer
-
Obtain a
RedisSerializer
using java serialization. - java(ClassLoader) - Static method in interface org.springframework.data.redis.serializer.RedisSerializationContext
-
Creates a new
RedisSerializationContext
using aJdkSerializationRedisSerializer
with givenClassLoader
to resolvestype
of the keys and values stored in Redis. - java(ClassLoader) - Static method in interface org.springframework.data.redis.serializer.RedisSerializer
-
Obtain a
RedisSerializer
using java serialization with the givenClassLoader
. - JdkSerializationRedisSerializer - Class in org.springframework.data.redis.serializer
-
Java Serialization
RedisSerializer
. - JdkSerializationRedisSerializer() - Constructor for class org.springframework.data.redis.serializer.JdkSerializationRedisSerializer
-
Creates a new
JdkSerializationRedisSerializer
using the defaultClassLoader
. - JdkSerializationRedisSerializer(ClassLoader) - Constructor for class org.springframework.data.redis.serializer.JdkSerializationRedisSerializer
-
Creates a new
JdkSerializationRedisSerializer
with the givenClassLoader
used to resolvetypes
during deserialization. - JdkSerializationRedisSerializer(Converter<Object, byte[]>, Converter<byte[], Object>) - Constructor for class org.springframework.data.redis.serializer.JdkSerializationRedisSerializer
-
Creates a new
JdkSerializationRedisSerializer
usingconverters
to serialize and deserializeobjects
. - JedisClientConfigBuilderCustomizer - Interface in org.springframework.data.redis.connection.jedis
-
Strategy interface for customizing
JedisClientConfig
. - JedisClientConfiguration - Interface in org.springframework.data.redis.connection.jedis
-
Redis client configuration for jedis.
- JedisClientConfiguration.DefaultJedisClientConfigurationBuilder - Class in org.springframework.data.redis.connection.jedis
-
Default
JedisClientConfiguration.JedisClientConfigurationBuilder
implementation to build an immutableJedisClientConfiguration
. - JedisClientConfiguration.JedisClientConfigurationBuilder - Interface in org.springframework.data.redis.connection.jedis
-
Builder for
JedisClientConfiguration
. - JedisClientConfiguration.JedisPoolingClientConfigurationBuilder - Interface in org.springframework.data.redis.connection.jedis
-
Builder for Pooling-related
JedisClientConfiguration
. - JedisClientConfiguration.JedisSslClientConfigurationBuilder - Interface in org.springframework.data.redis.connection.jedis
-
Builder for SSL-related
JedisClientConfiguration
. - JedisClusterConnection - Class in org.springframework.data.redis.connection.jedis
-
RedisClusterConnection
implementation on top ofJedisCluster
.
Uses the nativeJedisCluster
api where possible and falls back to direct node communication usingJedis
where needed. - JedisClusterConnection(JedisCluster) - Constructor for class org.springframework.data.redis.connection.jedis.JedisClusterConnection
-
Create new
JedisClusterConnection
utilizing native connections viaJedisCluster
. - JedisClusterConnection(JedisCluster, ClusterCommandExecutor) - Constructor for class org.springframework.data.redis.connection.jedis.JedisClusterConnection
-
Create new
JedisClusterConnection
utilizing native connections viaJedisCluster
running commands across the cluster via givenClusterCommandExecutor
. - JedisClusterConnection(JedisCluster, ClusterCommandExecutor, ClusterTopologyProvider) - Constructor for class org.springframework.data.redis.connection.jedis.JedisClusterConnection
-
Create new
JedisClusterConnection
utilizing native connections viaJedisCluster
running commands across the cluster via givenClusterCommandExecutor
and using the givenClusterTopologyProvider
. - JedisClusterConnection.JedisClusterCommandCallback<T> - Interface in org.springframework.data.redis.connection.jedis
-
Jedis
specificClusterCommandExecutor.ClusterCommandCallback
. - JedisClusterConnection.JedisClusterTopology - Class in org.springframework.data.redis.connection.jedis
- JedisClusterConnection.JedisClusterTopologyProvider - Class in org.springframework.data.redis.connection.jedis
-
Jedis specific implementation of
ClusterTopologyProvider
. - JedisClusterConnection.JedisMultiKeyClusterCommandCallback<T> - Interface in org.springframework.data.redis.connection.jedis
-
Jedis
specificClusterCommandExecutor.MultiKeyClusterCommandCallback
. - JedisClusterTopologyProvider(JedisCluster) - Constructor for class org.springframework.data.redis.connection.jedis.JedisClusterConnection.JedisClusterTopologyProvider
- JedisClusterTopologyProvider(JedisCluster, Duration) - Constructor for class org.springframework.data.redis.connection.jedis.JedisClusterConnection.JedisClusterTopologyProvider
- JedisConnection - Class in org.springframework.data.redis.connection.jedis
-
RedisConnection
implementation on top of Jedis library. - JedisConnection(Jedis) - Constructor for class org.springframework.data.redis.connection.jedis.JedisConnection
-
Constructs a new
JedisConnection
. - JedisConnection(Jedis, Pool<Jedis>, int) - Constructor for class org.springframework.data.redis.connection.jedis.JedisConnection
-
Constructs a new <
JedisConnection
backed by a JedisPool
. - JedisConnection(Jedis, Pool<Jedis>, int, String) - Constructor for class org.springframework.data.redis.connection.jedis.JedisConnection
-
Constructs a new <
JedisConnection
backed by a JedisPool
. - JedisConnection(Jedis, Pool<Jedis>, JedisClientConfig, JedisClientConfig) - Constructor for class org.springframework.data.redis.connection.jedis.JedisConnection
-
Constructs a new <
JedisConnection
backed by a JedisPool
. - JedisConnectionFactory - Class in org.springframework.data.redis.connection.jedis
-
Connection factory creating Jedis based connections.
- JedisConnectionFactory() - Constructor for class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
-
Constructs a new
JedisConnectionFactory
instance with default settings (default connection pooling). - JedisConnectionFactory(RedisClusterConfiguration) - Constructor for class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
-
Constructs a new
JedisConnectionFactory
instance using the givenRedisClusterConfiguration
applied to create aJedisCluster
. - JedisConnectionFactory(RedisClusterConfiguration, JedisClientConfiguration) - Constructor for class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
-
Constructs a new
JedisConnectionFactory
instance using the givenRedisClusterConfiguration
andJedisClientConfiguration
. - JedisConnectionFactory(RedisClusterConfiguration, JedisPoolConfig) - Constructor for class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
-
Constructs a new
JedisConnectionFactory
instance using the givenRedisClusterConfiguration
applied to create aJedisCluster
. - JedisConnectionFactory(RedisSentinelConfiguration) - Constructor for class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
-
Constructs a new
JedisConnectionFactory
instance using the givenJedisPoolConfig
applied toJedisSentinelPool
. - JedisConnectionFactory(RedisSentinelConfiguration, JedisClientConfiguration) - Constructor for class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
-
Constructs a new
JedisConnectionFactory
instance using the givenRedisSentinelConfiguration
andJedisClientConfiguration
. - JedisConnectionFactory(RedisSentinelConfiguration, JedisPoolConfig) - Constructor for class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
-
Constructs a new
JedisConnectionFactory
instance using the givenJedisPoolConfig
applied toJedisSentinelPool
. - JedisConnectionFactory(RedisStandaloneConfiguration) - Constructor for class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
-
Constructs a new
JedisConnectionFactory
instance using the givenRedisStandaloneConfiguration
. - JedisConnectionFactory(RedisStandaloneConfiguration, JedisClientConfiguration) - Constructor for class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
-
Constructs a new
JedisConnectionFactory
instance using the givenRedisStandaloneConfiguration
andJedisClientConfiguration
. - JedisConnectionFactory(JedisPoolConfig) - Constructor for class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
-
Constructs a new
JedisConnectionFactory
instance using the given pool configuration. - JedisExceptionConverter - Class in org.springframework.data.redis.connection.jedis
-
Converts Exceptions thrown from Jedis to
DataAccessException
s - JedisExceptionConverter() - Constructor for class org.springframework.data.redis.connection.jedis.JedisExceptionConverter
- JedisScriptReturnConverter - Class in org.springframework.data.redis.connection.jedis
-
Converts the value returned by Jedis script eval to the expected
ReturnType
- JedisScriptReturnConverter(ReturnType) - Constructor for class org.springframework.data.redis.connection.jedis.JedisScriptReturnConverter
- JedisSentinelConnection - Class in org.springframework.data.redis.connection.jedis
- JedisSentinelConnection(String, int) - Constructor for class org.springframework.data.redis.connection.jedis.JedisSentinelConnection
- JedisSentinelConnection(RedisNode) - Constructor for class org.springframework.data.redis.connection.jedis.JedisSentinelConnection
- JedisSentinelConnection(Jedis) - Constructor for class org.springframework.data.redis.connection.jedis.JedisSentinelConnection
- json() - Static method in interface org.springframework.data.redis.serializer.RedisSerializer
-
Obtain a
RedisSerializer
that can read and write JSON using Jackson. - Jsr310Converters - Class in org.springframework.data.redis.core.convert
-
Helper class to register JSR-310 specific
Converter
implementations. - Jsr310Converters() - Constructor for class org.springframework.data.redis.core.convert.Jsr310Converters
- just(Duration) - Static method in interface org.springframework.data.redis.cache.RedisCacheWriter.TtlFunction
-
Creates a Singleton
RedisCacheWriter.TtlFunction
using the givenDuration
. - just(RedisElementReader<? extends T>, RedisElementWriter<? extends T>) - Static method in interface org.springframework.data.redis.serializer.RedisSerializationContext.SerializationPair
-
Creates a
RedisSerializationContext.SerializationPair
adapter givenRedisElementReader
andRedisElementWriter
. - just(RedisSerializationContext.SerializationPair<T>) - Static method in interface org.springframework.data.redis.serializer.RedisSerializationContext
-
Creates a new
RedisSerializationContext
using the givenRedisSerializationContext.SerializationPair
.
K
- keepTtl() - Static method in class org.springframework.data.redis.core.types.Expiration
-
Obtain an
Expiration
that indicates to keep the existing one, e.g. when sending aSET
command. - key(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveHashCommands.HRandFieldCommand
-
Applies the hash key.
- key(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveKeyCommands.CopyCommand
-
Creates a new
ReactiveKeyCommands.CopyCommand
given akey
. - key(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveKeyCommands.ExpireAtCommand
-
Creates a new
ReactiveKeyCommands.ExpireAtCommand
given akey
. - key(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveKeyCommands.ExpireCommand
-
Creates a new
ReactiveKeyCommands.ExpireCommand
given akey
. - key(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveKeyCommands.MoveCommand
-
Creates a new
ReactiveKeyCommands.MoveCommand
given akey
. - key(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveKeyCommands.RenameCommand
-
Creates a new
ReactiveKeyCommands.RenameCommand
given akey
. - key(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveRedisConnection.KeyScanCommand
-
Creates a new
ReactiveRedisConnection.KeyScanCommand
given akey
. - key(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveRedisConnection.RangeCommand
-
Creates a new
ReactiveRedisConnection.RangeCommand
given akey
. - key(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveStringCommands.AppendCommand
-
Creates a new
ReactiveStringCommands.AppendCommand
given a key. - key(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveStringCommands.GetExCommand
-
Creates a new
ReactiveStringCommands.GetExCommand
given akey
. - key(RedisElementReader<K>, RedisElementWriter<K>) - Method in interface org.springframework.data.redis.serializer.RedisSerializationContext.RedisSerializationContextBuilder
-
Set the key
RedisElementReader
andRedisElementWriter
. - key(RedisSerializationContext.SerializationPair<K>) - Method in interface org.springframework.data.redis.serializer.RedisSerializationContext.RedisSerializationContextBuilder
-
Set the key
RedisSerializationContext.SerializationPair
. - key(RedisSerializer<K>) - Method in interface org.springframework.data.redis.serializer.RedisSerializationContext.RedisSerializationContextBuilder
-
Set the key
RedisSerializationContext.SerializationPair
given aRedisSerializer
. - KeyBoundCursor<T> - Class in org.springframework.data.redis.core
- KeyBoundCursor(byte[], long, ScanOptions) - Constructor for class org.springframework.data.redis.core.KeyBoundCursor
-
Deprecated.since 3.3.0 - Use
KeyBoundCursor(byte[], CursorId, ScanOptions)
instead. - KeyBoundCursor(byte[], Cursor.CursorId, ScanOptions) - Constructor for class org.springframework.data.redis.core.KeyBoundCursor
-
Crates new
ScanCursor
- KeyCommand(ByteBuffer) - Constructor for class org.springframework.data.redis.connection.ReactiveRedisConnection.KeyCommand
-
Creates a new
ReactiveRedisConnection.KeyCommand
given akey
. - keyCommands() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- keyCommands() - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
- keyCommands() - Method in class org.springframework.data.redis.connection.jedis.JedisConnection
- keyCommands() - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
- keyCommands() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
- keyCommands() - Method in interface org.springframework.data.redis.connection.ReactiveRedisClusterConnection
- keyCommands() - Method in interface org.springframework.data.redis.connection.ReactiveRedisConnection
-
Get
ReactiveKeyCommands
. - keyCommands() - Method in interface org.springframework.data.redis.connection.RedisCommandsProvider
-
Get
RedisKeyCommands
. - KeyExpirationEventMessageListener - Class in org.springframework.data.redis.listener
-
MessageListener
publishingRedisKeyExpiredEvent
s viaApplicationEventPublisher
by listening to Redis keyspace notifications for key expirations. - KeyExpirationEventMessageListener(RedisMessageListenerContainer) - Constructor for class org.springframework.data.redis.listener.KeyExpirationEventMessageListener
-
Creates new
MessageListener
for__keyevent@*__:expired
messages. - keys() - Static method in class org.springframework.data.redis.cache.BatchStrategies
- keys() - Method in interface org.springframework.data.redis.core.BoundHashOperations
-
Get key set (fields) of hash at the bound key.
- keys() - Method in class org.springframework.data.redis.support.collections.RedisProperties
- keys(byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.keyCommands()
. - keys(byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- keys(byte[]) - Method in interface org.springframework.data.redis.connection.RedisKeyCommands
-
Find all keys matching the given
pattern
. - keys(H) - Method in interface org.springframework.data.redis.core.HashOperations
-
Get key set (fields) of hash at
key
. - keys(H) - Method in interface org.springframework.data.redis.core.ReactiveHashOperations
-
Get key set (fields) of hash at
key
. - keys(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- keys(String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Find all keys matching the given
pattern
. - keys(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
-
Find all keys matching the given pattern.
It is recommended to useReactiveKeyCommands.scan(ScanOptions)
to iterate over the keyspace asReactiveKeyCommands.keys(ByteBuffer)
is a non-interruptible and expensive Redis operation. - keys(Collection<ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveSetCommands.SDiffCommand
-
Creates a new
ReactiveSetCommands.SDiffCommand
given aCollection
of keys. - keys(Collection<ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveSetCommands.SDiffStoreCommand
-
Creates a new
ReactiveSetCommands.SDiffStoreCommand
given aCollection
of keys. - keys(Collection<ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveSetCommands.SInterCommand
-
Creates a new
ReactiveSetCommands.SInterCommand
given aCollection
of keys. - keys(Collection<ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveSetCommands.SInterStoreCommand
-
Creates a new
ReactiveSetCommands.SInterStoreCommand
given aCollection
of keys. - keys(Collection<ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveSetCommands.SUnionCommand
-
Creates a new
ReactiveSetCommands.SUnionCommand
given aCollection
of keys. - keys(Collection<ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveSetCommands.SUnionStoreCommand
-
Creates a new
ReactiveSetCommands.SUnionStoreCommand
given aCollection
of keys. - keys(K) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
-
Find all keys matching the given
pattern
. - keys(K) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
- keys(K) - Method in interface org.springframework.data.redis.core.RedisOperations
-
Find all keys matching the given
pattern
. - keys(K) - Method in class org.springframework.data.redis.core.RedisTemplate
- keys(Publisher<ByteBuffer>) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
-
Find all keys matching the given pattern.
It is recommended to useReactiveKeyCommands.scan(ScanOptions)
to iterate over the keyspace asReactiveKeyCommands.keys(Publisher)
is a non-interruptible and expensive Redis operation. - keys(RedisClusterNode, byte[]) - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
- keys(RedisClusterNode, byte[]) - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
- keys(RedisClusterNode, byte[]) - Method in interface org.springframework.data.redis.connection.RedisClusterConnection
- keys(RedisClusterNode, ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveClusterKeyCommands
-
Retrieve all keys for a given pattern from
RedisNode
. - keys(RedisClusterNode, K) - Method in interface org.springframework.data.redis.core.ClusterOperations
-
Get all keys located at given node.
- KEYS - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- keysAndArgs(RedisElementWriter, List<K>, List<?>) - Method in class org.springframework.data.redis.core.script.DefaultReactiveScriptExecutor
- keysAndArgs(RedisSerializer, List<K>, Object[]) - Method in class org.springframework.data.redis.core.script.DefaultScriptExecutor
- KeyScanOptions - Class in org.springframework.data.redis.core
-
Options to be used for with SCAN commands.
- keySerializer() - Method in class org.springframework.data.redis.core.script.DefaultReactiveScriptExecutor
- keySerializer() - Method in class org.springframework.data.redis.core.script.DefaultScriptExecutor
- keySerializer(RedisSerializationContext.SerializationPair<NK>) - Method in class org.springframework.data.redis.stream.StreamReceiver.StreamReceiverOptionsBuilder
-
Configure a key serializer.
- keySerializer(RedisSerializer<NK>) - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamMessageListenerContainerOptionsBuilder
-
Configure a key serializer.
- keySet() - Method in class org.springframework.data.redis.core.convert.Bucket
- keySet() - Method in class org.springframework.data.redis.support.collections.DefaultRedisMap
- keySet() - Method in class org.springframework.data.redis.support.collections.RedisProperties
- keyspaceConfiguration() - Element in annotation interface org.springframework.data.redis.repository.configuration.EnableRedisRepositories
-
Set up keyspaces for specific types.
- KeyspaceConfiguration - Class in org.springframework.data.redis.core.convert
-
KeyspaceConfiguration
allows programmatic setup of keyspaces and time to live options for certain types. - KeyspaceConfiguration() - Constructor for class org.springframework.data.redis.core.convert.KeyspaceConfiguration
- KeyspaceConfiguration.KeyspaceSettings - Class in org.springframework.data.redis.core.convert
- KeyspaceEventMessageListener - Class in org.springframework.data.redis.listener
-
Base
MessageListener
implementation for listening to Redis keyspace notifications. - KeyspaceEventMessageListener(RedisMessageListenerContainer) - Constructor for class org.springframework.data.redis.listener.KeyspaceEventMessageListener
-
Creates new
KeyspaceEventMessageListener
. - keyspaceNotificationsConfigParameter() - Element in annotation interface org.springframework.data.redis.repository.configuration.EnableRedisRepositories
-
Configure the notify-keyspace-events property if not already set.
- KeyspaceSettings(Class<?>, String) - Constructor for class org.springframework.data.redis.core.convert.KeyspaceConfiguration.KeyspaceSettings
- KeyspaceSettings(Class<?>, String, boolean) - Constructor for class org.springframework.data.redis.core.convert.KeyspaceConfiguration.KeyspaceSettings
- keyValueTemplateRef() - Element in annotation interface org.springframework.data.redis.repository.configuration.EnableRedisRepositories
-
Configures the name of the
KeyValueOperations
bean to be used with the repositories detected. - killClient(String, int) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.serverCommands()
. - killClient(String, int) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- killClient(String, int) - Method in interface org.springframework.data.redis.connection.ReactiveServerCommands
-
Closes a given client connection identified by host:port.
- killClient(String, int) - Method in interface org.springframework.data.redis.connection.RedisServerCommands
-
Closes a given client connection identified by host:port.
- killClient(String, int) - Method in interface org.springframework.data.redis.core.RedisOperations
-
Closes a given client connection identified by ip:port given in
client
. - killClient(String, int) - Method in class org.springframework.data.redis.core.RedisTemplate
- kilometers() - Static method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoDistCommand
-
Creates a new
ReactiveGeoCommands.GeoDistCommand
forRedisGeoCommands.DistanceUnit.KILOMETERS
. - KILOMETERS - Enum constant in enum class org.springframework.data.redis.connection.RedisGeoCommands.DistanceUnit
- KILOMETERS - Enum constant in enum class org.springframework.data.redis.domain.geo.Metrics
- KNOWN_NODES - Enum constant in enum class org.springframework.data.redis.connection.ClusterInfo.Info
L
- last() - Static method in enum class org.springframework.data.redis.connection.ReactiveListCommands.Direction
-
Alias for
ReactiveListCommands.Direction.RIGHT
. - last() - Static method in enum class org.springframework.data.redis.connection.RedisListCommands.Direction
-
Alias for
RedisListCommands.Direction.RIGHT
. - last() - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
- last() - Method in interface org.springframework.data.redis.support.collections.RedisZSet
-
Returns the last (highest) element currently in this sorted set.
- last(long) - Static method in class org.springframework.data.redis.connection.ReactiveListCommands.LRemCommand
-
Creates a new
ReactiveListCommands.LRemCommand
to last count values. - LAST_COMMAND - Enum constant in enum class org.springframework.data.redis.core.types.RedisClientInfo.INFO
- LAST_OK_PING_REPLY - Enum constant in enum class org.springframework.data.redis.connection.RedisServer.INFO
- LAST_PING_SENT - Enum constant in enum class org.springframework.data.redis.connection.RedisServer.INFO
- lastConsumed() - Static method in class org.springframework.data.redis.connection.stream.ReadOffset
-
Read all new arriving elements with ids greater than the last one consumed by the consumer group.
- lastDeliveredId() - Method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoGroup
-
The id of the last delivered message.
- lastEntryId() - Method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoStream
-
The id of the streams last entry.
- lastGeneratedId() - Method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoStream
-
The last generated id.
- lastIndexOf(Object) - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- lastIndexOf(K, V) - Method in interface org.springframework.data.redis.core.ListOperations
-
Returns the index of the last occurrence of the specified value in the list at at
key
. - lastIndexOf(K, V) - Method in interface org.springframework.data.redis.core.ReactiveListOperations
-
Returns the index of the last occurrence of the specified value in the list at at
key
. - lastIndexOf(V) - Method in interface org.springframework.data.redis.core.BoundListOperations
-
Returns the index of the last occurrence of the specified value in the list at at
key
. - lastSave() - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.serverCommands()
. - lastSave() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- lastSave() - Method in interface org.springframework.data.redis.connection.ReactiveServerCommands
-
Get time unix timestamp of last successful
ReactiveServerCommands.bgSave()
operation in seconds. - lastSave() - Method in interface org.springframework.data.redis.connection.RedisServerCommands
-
Get time of last
RedisServerCommands.bgSave()
operation in seconds. - lastSave(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.DefaultedRedisClusterConnection
-
Deprecated.in favor of
RedisCommandsProvider.serverCommands()
. - lastSave(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.ReactiveClusterServerCommands
-
Get time unix timestamp of last successful
ReactiveServerCommands.bgSave()
operation in seconds. - lastSave(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.RedisClusterServerCommands
- LASTSAVE - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- latest() - Static method in class org.springframework.data.redis.connection.stream.ReadOffset
-
Read from the latest offset.
- latest(K) - Static method in class org.springframework.data.redis.connection.stream.StreamOffset
- left() - Static method in class org.springframework.data.redis.connection.ReactiveListCommands.BPopCommand
-
Creates a new
ReactiveListCommands.BPopCommand
for right push (BLPOP). - left() - Static method in class org.springframework.data.redis.connection.ReactiveListCommands.PopCommand
-
Creates a new
ReactiveListCommands.PopCommand
for right push (LPOP). - left() - Static method in class org.springframework.data.redis.connection.ReactiveListCommands.PushCommand
-
Creates a new
ReactiveListCommands.PushCommand
for left push (LPUSH). - LEFT - Enum constant in enum class org.springframework.data.redis.connection.ReactiveListCommands.Direction
- LEFT - Enum constant in enum class org.springframework.data.redis.connection.RedisListCommands.Direction
- leftPop() - Method in interface org.springframework.data.redis.core.BoundListOperations
-
Removes and returns first element in list stored at the bound key.
- leftPop(long) - Method in interface org.springframework.data.redis.core.BoundListOperations
-
Removes and returns first elements in list stored at
key
. - leftPop(long, TimeUnit) - Method in interface org.springframework.data.redis.core.BoundListOperations
-
Removes and returns first element from lists stored at the bound key .
- leftPop(Duration) - Method in interface org.springframework.data.redis.core.BoundListOperations
-
Removes and returns first element from lists stored at the bound key .
- leftPop(K) - Method in interface org.springframework.data.redis.core.ListOperations
-
Removes and returns first element in list stored at
key
. - leftPop(K) - Method in interface org.springframework.data.redis.core.ReactiveListOperations
-
Removes and returns first element in list stored at
key
. - leftPop(K, long) - Method in interface org.springframework.data.redis.core.ListOperations
-
Removes and returns first elements in list stored at
key
. - leftPop(K, long) - Method in interface org.springframework.data.redis.core.ReactiveListOperations
-
Removes
count
elements from the left-side of the Redis list stored at key. - leftPop(K, long, TimeUnit) - Method in interface org.springframework.data.redis.core.ListOperations
-
Removes and returns first element from lists stored at
key
. - leftPop(K, Duration) - Method in interface org.springframework.data.redis.core.ListOperations
-
Removes and returns first element from lists stored at
key
. - leftPop(K, Duration) - Method in interface org.springframework.data.redis.core.ReactiveListOperations
-
Removes and returns first element from lists stored at
key
. - leftPush(K, V) - Method in interface org.springframework.data.redis.core.ListOperations
-
Prepend
value
tokey
. - leftPush(K, V) - Method in interface org.springframework.data.redis.core.ReactiveListOperations
-
Prepend
value
tokey
. - leftPush(K, V, V) - Method in interface org.springframework.data.redis.core.ListOperations
-
Insert
value
tokey
beforepivot
. - leftPush(K, V, V) - Method in interface org.springframework.data.redis.core.ReactiveListOperations
-
Insert
value
tokey
beforepivot
. - leftPush(V) - Method in interface org.springframework.data.redis.core.BoundListOperations
-
Prepend
value
to the bound key. - leftPush(V, V) - Method in interface org.springframework.data.redis.core.BoundListOperations
-
Prepend
values
to the bound key beforevalue
. - leftPushAll(K, Collection<V>) - Method in interface org.springframework.data.redis.core.ListOperations
-
Prepend
values
tokey
. - leftPushAll(K, Collection<V>) - Method in interface org.springframework.data.redis.core.ReactiveListOperations
-
Prepend
values
tokey
. - leftPushAll(K, V...) - Method in interface org.springframework.data.redis.core.ListOperations
-
Prepend
values
tokey
. - leftPushAll(K, V...) - Method in interface org.springframework.data.redis.core.ReactiveListOperations
-
Prepend
values
tokey
. - leftPushAll(V...) - Method in interface org.springframework.data.redis.core.BoundListOperations
-
Prepend
values
to the bound key. - leftPushIfPresent(K, V) - Method in interface org.springframework.data.redis.core.ListOperations
-
Prepend
values
tokey
only if the list exists. - leftPushIfPresent(K, V) - Method in interface org.springframework.data.redis.core.ReactiveListOperations
-
Prepend
values
tokey
only if the list exists. - leftPushIfPresent(V) - Method in interface org.springframework.data.redis.core.BoundListOperations
-
Prepend
values
to the bound key only if the list exists. - lengthOf(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveHashCommands.HStrLenCommand
-
Specify the
field
within the hash to get the length of thevalue
of.ø - lengthOfValue(HK) - Method in interface org.springframework.data.redis.core.BoundHashOperations
-
Returns the length of the value associated with
hashKey
. - lengthOfValue(H, HK) - Method in interface org.springframework.data.redis.core.HashOperations
-
Returns the length of the value associated with
hashKey
. - LettuceClientConfiguration - Interface in org.springframework.data.redis.connection.lettuce
-
Redis client configuration for lettuce.
- LettuceClientConfiguration.LettuceClientConfigurationBuilder - Class in org.springframework.data.redis.connection.lettuce
- LettuceClientConfiguration.LettuceSslClientConfigurationBuilder - Class in org.springframework.data.redis.connection.lettuce
-
Builder for SSL-related
LettuceClientConfiguration
. - LettuceClusterConnection - Class in org.springframework.data.redis.connection.lettuce
-
RedisClusterConnection
implementation on top of Lettuce Redis client. - LettuceClusterConnection(StatefulRedisClusterConnection<byte[], byte[]>, LettuceConnectionProvider, ClusterTopologyProvider, ClusterCommandExecutor, Duration) - Constructor for class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
-
Creates new
LettuceClusterConnection
given a sharedStatefulRedisClusterConnection
andLettuceConnectionProvider
running commands across the cluster via givenClusterCommandExecutor
. - LettuceClusterConnection(RedisClusterClient) - Constructor for class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
-
Creates new
LettuceClusterConnection
usingRedisClusterClient
with defaulttimeout
and a freshClusterCommandExecutor
that gets destroyed on close. - LettuceClusterConnection(RedisClusterClient, ClusterCommandExecutor) - Constructor for class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
-
Creates new
LettuceClusterConnection
with defaulttimeout
usingRedisClusterClient
running commands across the cluster via givenClusterCommandExecutor
. - LettuceClusterConnection(RedisClusterClient, ClusterCommandExecutor, Duration) - Constructor for class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
-
Creates new
LettuceClusterConnection
with given commandtimeout
usingRedisClusterClient
running commands across the cluster via givenClusterCommandExecutor
. - LettuceClusterConnection(LettuceConnectionProvider) - Constructor for class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
-
Creates new
LettuceClusterConnection
usingLettuceConnectionProvider
running commands across the cluster via givenClusterCommandExecutor
. - LettuceClusterConnection(LettuceConnectionProvider, ClusterCommandExecutor) - Constructor for class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
-
Creates new
LettuceClusterConnection
usingLettuceConnectionProvider
running commands across the cluster via givenClusterCommandExecutor
. - LettuceClusterConnection(LettuceConnectionProvider, ClusterCommandExecutor, Duration) - Constructor for class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
-
Creates new
LettuceClusterConnection
usingLettuceConnectionProvider
running commands across the cluster via givenClusterCommandExecutor
. - LettuceClusterConnection.LettuceClusterCommandCallback<T> - Interface in org.springframework.data.redis.connection.lettuce
-
Lettuce specific implementation of
ClusterCommandExecutor.ClusterCommandCallback
. - LettuceClusterConnection.LettuceMultiKeyClusterCommandCallback<T> - Interface in org.springframework.data.redis.connection.lettuce
-
Lettuce specific implementation of
ClusterCommandExecutor.MultiKeyClusterCommandCallback
. - LettuceConnection - Class in org.springframework.data.redis.connection.lettuce
-
RedisConnection
implementation on top of Lettuce Redis client. - LettuceConnection(long, RedisClient) - Constructor for class org.springframework.data.redis.connection.lettuce.LettuceConnection
-
Creates a new
LettuceConnection
. - LettuceConnection(StatefulRedisConnection<byte[], byte[]>, long, AbstractRedisClient, int) - Constructor for class org.springframework.data.redis.connection.lettuce.LettuceConnection
-
Creates a new
LettuceConnection
. - LettuceConnection(StatefulRedisConnection<byte[], byte[]>, long, RedisClient) - Constructor for class org.springframework.data.redis.connection.lettuce.LettuceConnection
-
Creates a new
LettuceConnection
. - LettuceConnection(StatefulRedisConnection<byte[], byte[]>, LettuceConnectionProvider, long, int) - Constructor for class org.springframework.data.redis.connection.lettuce.LettuceConnection
-
Creates a new
LettuceConnection
. - LettuceConnection.PipeliningFlushPolicy - Interface in org.springframework.data.redis.connection.lettuce
-
Strategy interface to control pipelining flush behavior.
- LettuceConnection.PipeliningFlushState - Interface in org.springframework.data.redis.connection.lettuce
-
State object associated with flushing of the currently ongoing pipeline.
- LettuceConnectionFactory - Class in org.springframework.data.redis.connection.lettuce
-
Connection factory
creating Lettuce-based connections. - LettuceConnectionFactory() - Constructor for class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
Constructs a new
LettuceConnectionFactory
instance with default settings. - LettuceConnectionFactory(String, int) - Constructor for class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
Constructs a new
LettuceConnectionFactory
instance with default settings. - LettuceConnectionFactory(RedisClusterConfiguration) - Constructor for class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
Constructs a new
LettuceConnectionFactory
instance using the givenRedisClusterConfiguration
applied to create aRedisClusterClient
. - LettuceConnectionFactory(RedisClusterConfiguration, LettuceClientConfiguration) - Constructor for class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
Constructs a new
LettuceConnectionFactory
instance using the givenRedisClusterConfiguration
andLettuceClientConfiguration
. - LettuceConnectionFactory(RedisConfiguration) - Constructor for class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
Constructs a new
LettuceConnectionFactory
instance using the givenRedisSocketConfiguration
. - LettuceConnectionFactory(RedisConfiguration, LettuceClientConfiguration) - Constructor for class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
Constructs a new
LettuceConnectionFactory
instance using the givenRedisStaticMasterReplicaConfiguration
andLettuceClientConfiguration
. - LettuceConnectionFactory(RedisSentinelConfiguration) - Constructor for class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
Constructs a new
LettuceConnectionFactory
instance using the givenRedisSentinelConfiguration
. - LettuceConnectionFactory(RedisSentinelConfiguration, LettuceClientConfiguration) - Constructor for class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
Constructs a new
LettuceConnectionFactory
instance using the givenRedisSentinelConfiguration
andLettuceClientConfiguration
. - LettuceConnectionFactory(RedisStandaloneConfiguration) - Constructor for class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
Constructs a new
LettuceConnectionFactory
instance with default settings. - LettuceConnectionFactory(RedisStandaloneConfiguration, LettuceClientConfiguration) - Constructor for class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
Constructs a new
LettuceConnectionFactory
instance using the givenRedisStandaloneConfiguration
andLettuceClientConfiguration
. - LettuceConnectionProvider - Interface in org.springframework.data.redis.connection.lettuce
-
Defines a provider for Lettuce connections.
- LettuceConnectionProvider.TargetAware - Interface in org.springframework.data.redis.connection.lettuce
-
Extension to
LettuceConnectionProvider
for providers that allow connection creation to specific nodes. - LettuceConverters - Class in org.springframework.data.redis.connection.lettuce
-
Lettuce type converters
- LettuceConverters() - Constructor for class org.springframework.data.redis.connection.lettuce.LettuceConverters
- LettuceExceptionConverter - Class in org.springframework.data.redis.connection.lettuce
-
Converts Lettuce Exceptions to
DataAccessException
s - LettuceExceptionConverter() - Constructor for class org.springframework.data.redis.connection.lettuce.LettuceExceptionConverter
- LettuceObservationContext - Class in org.springframework.data.redis.connection.lettuce.observability
-
Deprecated, for removal: This API element is subject to removal in a future version.since 3.4 for removal with the next major revision. Use Lettuce's Micrometer integration through
MicrometerTracing
. - LettuceObservationContext(String) - Constructor for class org.springframework.data.redis.connection.lettuce.observability.LettuceObservationContext
-
Deprecated.
- LettucePoolingClientConfiguration - Interface in org.springframework.data.redis.connection.lettuce
-
Redis client configuration for lettuce using a driver level pooled connection by adding pooling specific configuration to
LettuceClientConfiguration
. - LettucePoolingClientConfiguration.LettucePoolingClientConfigurationBuilder - Class in org.springframework.data.redis.connection.lettuce
- LettucePoolingClientConfiguration.LettucePoolingSslClientConfigurationBuilder - Class in org.springframework.data.redis.connection.lettuce
- LettuceSentinelConnection - Class in org.springframework.data.redis.connection.lettuce
- LettuceSentinelConnection(RedisClient) - Constructor for class org.springframework.data.redis.connection.lettuce.LettuceSentinelConnection
-
Creates a
LettuceSentinelConnection
using a suppliedRedisClient
. - LettuceSentinelConnection(StatefulRedisSentinelConnection<String, String>) - Constructor for class org.springframework.data.redis.connection.lettuce.LettuceSentinelConnection
-
Creates a
LettuceSentinelConnection
using a supplied redis connection. - LettuceSentinelConnection(String, int) - Constructor for class org.springframework.data.redis.connection.lettuce.LettuceSentinelConnection
- LettuceSentinelConnection(String, int, ClientResources) - Constructor for class org.springframework.data.redis.connection.lettuce.LettuceSentinelConnection
-
Creates a
LettuceSentinelConnection
with a client for the suppliedhost
andport
and reuse existingClientResources
. - LettuceSentinelConnection(LettuceConnectionProvider) - Constructor for class org.springframework.data.redis.connection.lettuce.LettuceSentinelConnection
-
Creates a
LettuceSentinelConnection
using aLettuceConnectionProvider
. - LettuceSentinelConnection(RedisNode) - Constructor for class org.springframework.data.redis.connection.lettuce.LettuceSentinelConnection
-
Creates a
LettuceSentinelConnection
with a dedicated client for a suppliedRedisNode
. - LettuceSubscription - Class in org.springframework.data.redis.connection.lettuce
-
Message subscription on top of Lettuce.
- LettuceSubscription(MessageListener, StatefulRedisPubSubConnection<byte[], byte[]>, LettuceConnectionProvider) - Constructor for class org.springframework.data.redis.connection.lettuce.LettuceSubscription
-
Creates a new
LettuceSubscription
givenMessageListener
,StatefulRedisPubSubConnection
, andLettuceConnectionProvider
. - lexCount(K, Range<String>) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Count number of elements within sorted set with a value between
Range.getLowerBound()
andRange.getUpperBound()
applying lexicographical ordering. - lexCount(K, Range<String>) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Count number of elements within sorted set with value between
Range.getLowerBound()
andRange.getUpperBound()
applying lexicographical ordering. - lexCount(K, RedisZSetCommands.Range) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Deprecated, for removal: This API element is subject to removal in a future version.since 3.0. Please use #lexCount(Range) instead.
- lexCount(Range<String>) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Count number of elements within sorted set with value between
Range.getLowerBound()
andRange.getUpperBound()
applying lexicographical ordering. - lexCount(Range<String>) - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
- lexCount(Range<String>) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
-
Count number of elements within sorted set with value between
Range#min
andRange#max
applying lexicographical ordering. - lexCount(RedisZSetCommands.Range) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Deprecated, for removal: This API element is subject to removal in a future version.since 3.0. Please use
BoundZSetOperations.lexCount(Range)
instead. - lexWithin(Range<String>) - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRemRangeByLexCommand
-
Creates a new
ReactiveZSetCommands.ZRemRangeByLexCommand
given aRange
. - limit - Variable in class org.springframework.data.redis.connection.RedisGeoCommands.GeoSearchCommandArgs
- limit() - Static method in class org.springframework.data.redis.connection.Limit
- limit(int) - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.RangeCommand
-
Applies a
Limit
. - limit(long) - Method in class org.springframework.data.redis.connection.RedisGeoCommands.GeoRadiusCommandArgs
-
Limit the results to the first N matching items.
- limit(long) - Method in class org.springframework.data.redis.connection.RedisGeoCommands.GeoSearchCommandArgs
-
Limit the results to the first N matching items.
- limit(long) - Method in class org.springframework.data.redis.connection.RedisGeoCommands.GeoSearchStoreCommandArgs
-
Limit the results to the first N matching items.
- limit(long, boolean) - Method in class org.springframework.data.redis.connection.RedisGeoCommands.GeoSearchCommandArgs
-
Limit the results to the first N matching items.
- limit(long, boolean) - Method in class org.springframework.data.redis.connection.RedisGeoCommands.GeoSearchStoreCommandArgs
-
Limit the results to the first N matching items.
- limit(long, long) - Method in class org.springframework.data.redis.connection.DefaultSortParameters
- limit(long, long) - Method in class org.springframework.data.redis.core.query.SortQueryBuilder
- limit(long, long) - Method in interface org.springframework.data.redis.core.query.SortCriterion
- limit(Limit) - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.RangeCommand
-
Applies a
Limit
. - limit(Limit) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRangeStoreCommand
-
Applies the limit.
- limit(SortParameters.Range) - Method in class org.springframework.data.redis.core.query.SortQueryBuilder
- limit(SortParameters.Range) - Method in interface org.springframework.data.redis.core.query.SortCriterion
- Limit - Class in org.springframework.data.redis.connection
- Limit() - Constructor for class org.springframework.data.redis.connection.Limit
- Limit() - Constructor for class org.springframework.data.redis.connection.RedisZSetCommands.Limit
-
Deprecated.
- limitTo(long) - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusByMemberCommand
-
Applies the limit.
- limitTo(long) - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusCommand
-
Applies the limit.
- limitTo(Limit) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRangeByLexCommand
-
Applies the
Limit
. - limitTo(Limit) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRangeByScoreCommand
-
Applies the
Limit
. - lIndex(byte[], long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.listCommands()
}. - lIndex(byte[], long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- lIndex(byte[], long) - Method in interface org.springframework.data.redis.connection.RedisListCommands
-
Get element at
index
form list atkey
. - lIndex(String, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- lIndex(String, long) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get element at
index
form list atkey
. - lIndex(ByteBuffer, long) - Method in interface org.springframework.data.redis.connection.ReactiveListCommands
-
Get element at index form list at key.
- lIndex(Publisher<ReactiveListCommands.LIndexCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveListCommands
-
Get element at
ReactiveListCommands.LIndexCommand.getIndex()
form list atReactiveRedisConnection.KeyCommand.getKey()
. - LINDEX - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- LINKEDLIST - Enum constant in enum class org.springframework.data.redis.connection.ValueEncoding.RedisValueEncoding
-
Encoding for large lists.
- linkState(RedisClusterNode.LinkState) - Method in class org.springframework.data.redis.connection.RedisClusterNode.RedisClusterNodeBuilder
- lInsert(byte[], RedisListCommands.Position, byte[], byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.listCommands()
}. - lInsert(byte[], RedisListCommands.Position, byte[], byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- lInsert(byte[], RedisListCommands.Position, byte[], byte[]) - Method in interface org.springframework.data.redis.connection.RedisListCommands
-
Insert
value
RedisListCommands.Position.BEFORE
orRedisListCommands.Position.AFTER
existingpivot
forkey
. - lInsert(String, RedisListCommands.Position, String, String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- lInsert(String, RedisListCommands.Position, String, String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Insert
value
RedisListCommands.Position.BEFORE
orRedisListCommands.Position.AFTER
existingpivot
forkey
. - lInsert(ByteBuffer, RedisListCommands.Position, ByteBuffer, ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveListCommands
-
Insert value
RedisListCommands.Position.BEFORE
orRedisListCommands.Position.AFTER
existing pivot for key. - lInsert(Publisher<ReactiveListCommands.LInsertCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveListCommands
- LINSERT - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- LIST - Enum constant in enum class org.springframework.data.redis.connection.DataType
- LIST - Enum constant in enum class org.springframework.data.redis.support.collections.RedisCollectionFactoryBean.CollectionType
- listCommands() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- listCommands() - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
- listCommands() - Method in class org.springframework.data.redis.connection.jedis.JedisConnection
- listCommands() - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
- listCommands() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
- listCommands() - Method in interface org.springframework.data.redis.connection.ReactiveRedisClusterConnection
- listCommands() - Method in interface org.springframework.data.redis.connection.ReactiveRedisConnection
-
Get
ReactiveListCommands
. - listCommands() - Method in interface org.springframework.data.redis.connection.RedisCommandsProvider
-
Get
RedisListCommands
. - ListConverter<S,
T> - Class in org.springframework.data.redis.connection.convert -
Converts a List of values of one type to a List of values of another type
- ListConverter(Converter<S, T>) - Constructor for class org.springframework.data.redis.connection.convert.ListConverter
- listeningAt(String, int) - Method in class org.springframework.data.redis.connection.RedisClusterNode.RedisClusterNodeBuilder
- listeningAt(String, int) - Method in class org.springframework.data.redis.connection.RedisNode.RedisNodeBuilder
-
Set host and port of server.
- listenTo(Topic...) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
- listenTo(Topic...) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
- listenToChannel(String...) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
-
Subscribe to the given Redis
channels
and emitmessages
received for those. - listenToChannelLater(String...) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
-
Subscribe to the given Redis
channels
and emitmessages
received for those. - listenToLater(Topic...) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
- listenToLater(Topic...) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
- listenToPattern(String...) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
-
Subscribe to the Redis channels matching the given
pattern
and emitmessages
received for those. - listenToPatternLater(String...) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
-
Subscribe to the Redis channels matching the given
pattern
and emitmessages
received for those. - listIterator() - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- listIterator(int) - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- ListOperations<K,
V> - Interface in org.springframework.data.redis.core -
Redis list specific operations.
- ListOperations.MoveFrom<K> - Class in org.springframework.data.redis.core
-
Value object representing the
where from
part for theLMOVE
command. - ListOperations.MoveTo<K> - Class in org.springframework.data.redis.core
-
Value object representing the
where to
from part for theLMOVE
command. - listToPropertiesConverter() - Static method in class org.springframework.data.redis.connection.convert.Converters
-
Returns a converter to convert array outputs with key-value sequences (such as produced by
CONFIG GET
) from aList
toProperties
. - lLen(byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.listCommands()
}. - lLen(byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- lLen(byte[]) - Method in interface org.springframework.data.redis.connection.RedisListCommands
-
Get the size of list stored at
key
. - lLen(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- lLen(String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get the size of list stored at
key
. - lLen(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveListCommands
-
Get the size of list stored at key.
- lLen(Publisher<ReactiveRedisConnection.KeyCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveListCommands
-
Get the size of list stored at
ReactiveRedisConnection.KeyCommand.getKey()
- LLEN - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- lMove(byte[], byte[], RedisListCommands.Direction, RedisListCommands.Direction) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.listCommands()
}. - lMove(byte[], byte[], RedisListCommands.Direction, RedisListCommands.Direction) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- lMove(byte[], byte[], RedisListCommands.Direction, RedisListCommands.Direction) - Method in interface org.springframework.data.redis.connection.RedisListCommands
-
Atomically returns and removes the first/last element (head/tail depending on the
from
argument) of the list stored atsourceKey
, and pushes the element at the first/last element (head/tail depending on theto
argument) of the list stored atdestinationKey
. - lMove(String, String, RedisListCommands.Direction, RedisListCommands.Direction) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- lMove(String, String, RedisListCommands.Direction, RedisListCommands.Direction) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Atomically returns and removes the first/last element (head/tail depending on the
from
argument) of the list stored atsourceKey
, and pushes the element at the first/last element (head/tail depending on theto
argument) of the list stored atdestinationKey
. - lMove(ByteBuffer, ByteBuffer, ReactiveListCommands.Direction, ReactiveListCommands.Direction) - Method in interface org.springframework.data.redis.connection.ReactiveListCommands
-
Atomically returns and removes the first/last element (head/tail depending on the
from
argument) of the list stored atsourceKey
, and pushes the element at the first/last element (head/tail depending on theto
argument) of the list stored atdestinationKey
. - lMove(Publisher<? extends ReactiveListCommands.LMoveCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveListCommands
-
Atomically returns and removes the first/last element (head/tail depending on the
from
argument) of the list stored atsourceKey
, and pushes the element at the first/last element (head/tail depending on theto
argument) of the list stored atdestinationKey
. - LMoveCommand(ByteBuffer, ByteBuffer, ReactiveListCommands.Direction, ReactiveListCommands.Direction) - Constructor for class org.springframework.data.redis.connection.ReactiveListCommands.LMoveCommand
- loadCaches() - Method in class org.springframework.data.redis.cache.RedisCacheManager
- loadCacheValue(Object, Callable<T>) - Method in class org.springframework.data.redis.cache.RedisCache
-
Loads the
Object
using the givenvalueLoader
. - location(RedisGeoCommands.GeoLocation<ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoAddCommand
-
Creates a new
ReactiveGeoCommands.GeoAddCommand
givenRedisGeoCommands.GeoLocation
. - locations(Collection<RedisGeoCommands.GeoLocation<ByteBuffer>>) - Static method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoAddCommand
-
Creates a new
ReactiveGeoCommands.GeoAddCommand
given an index. - lockingRedisCacheWriter(RedisConnectionFactory) - Static method in interface org.springframework.data.redis.cache.RedisCacheWriter
-
Create new
RedisCacheWriter
with locking behavior. - lockingRedisCacheWriter(RedisConnectionFactory, Duration, RedisCacheWriter.TtlFunction, BatchStrategy) - Static method in interface org.springframework.data.redis.cache.RedisCacheWriter
-
Create new
RedisCacheWriter
with locking behavior. - lockingRedisCacheWriter(RedisConnectionFactory, BatchStrategy) - Static method in interface org.springframework.data.redis.cache.RedisCacheWriter
-
Create new
RedisCacheWriter
with locking behavior. - logger - Variable in class org.springframework.data.redis.core.RedisAccessor
-
Logger available to subclasses
- logger - Variable in class org.springframework.data.redis.listener.adapter.MessageListenerAdapter
-
Logger available to subclasses
- logger - Variable in class org.springframework.data.redis.listener.RedisMessageListenerContainer
-
Logger available to subclasses
- longToBoolean() - Static method in class org.springframework.data.redis.connection.convert.Converters
- longToBooleanConverter() - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
- LongToBooleanConverter - Class in org.springframework.data.redis.connection.convert
-
Converts Longs to Booleans
- LongToBooleanConverter() - Constructor for class org.springframework.data.redis.connection.convert.LongToBooleanConverter
- longValue() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicDouble
- longValue() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicInteger
- longValue() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicLong
- lookup(Object) - Method in class org.springframework.data.redis.cache.RedisCache
- lookup(String) - Method in class org.springframework.data.redis.connection.ClusterTopology
-
Get the
RedisClusterNode
matching given nodeId. - lookup(String, int) - Method in class org.springframework.data.redis.connection.ClusterTopology
-
Get the
RedisClusterNode
matching given host and port. - lookup(RedisClusterNode) - Method in class org.springframework.data.redis.connection.ClusterTopology
- lPop(byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.listCommands()
}. - lPop(byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- lPop(byte[]) - Method in interface org.springframework.data.redis.connection.RedisListCommands
-
Removes and returns first element in list stored at
key
. - lPop(byte[], long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.listCommands()
}. - lPop(byte[], long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- lPop(byte[], long) - Method in interface org.springframework.data.redis.connection.RedisListCommands
-
Removes and returns first elements in list stored at
key
. - lPop(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- lPop(String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Removes and returns first element in list stored at
key
. - lPop(String, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- lPop(String, long) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Removes and returns first elements in list stored at
key
. - lPop(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveListCommands
-
Removes and returns first element in list stored at key.
- lPop(ByteBuffer, long) - Method in interface org.springframework.data.redis.connection.ReactiveListCommands
-
Removes and returns first
count
elements in list stored at key. - LPOP - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- lPos(byte[], byte[]) - Method in interface org.springframework.data.redis.connection.RedisListCommands
-
Returns the index of matching elements inside the list stored at given key.
- lPos(byte[], byte[], Integer, Integer) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.listCommands()
}. - lPos(byte[], byte[], Integer, Integer) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- lPos(byte[], byte[], Integer, Integer) - Method in interface org.springframework.data.redis.connection.RedisListCommands
-
Returns the index of matching elements inside the list stored at given key.
- lPos(String, String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Returns the index of matching elements inside the list stored at given key.
- lPos(String, String, Integer, Integer) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- lPos(String, String, Integer, Integer) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Returns the index of matching elements inside the list stored at given key.
- lPos(ByteBuffer, ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveListCommands
-
Get first index of the element from list at key.
- lPos(Publisher<ReactiveListCommands.LPosCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveListCommands
-
Get indices of the element from list at
ReactiveRedisConnection.KeyCommand.getKey()
. - lPos(ReactiveListCommands.LPosCommand) - Method in interface org.springframework.data.redis.connection.ReactiveListCommands
-
Get indices of the element from list at
ReactiveRedisConnection.KeyCommand.getKey()
. - lPosOf(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveListCommands.LPosCommand
-
Creates a new
ReactiveListCommands.LPosCommand
for given element. - lPush(byte[], byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.listCommands()
}. - lPush(byte[], byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- lPush(byte[], byte[]...) - Method in interface org.springframework.data.redis.connection.RedisListCommands
-
Prepend
values
tokey
. - lPush(String, String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- lPush(String, String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Prepend
values
tokey
. - lPush(ByteBuffer, List<ByteBuffer>) - Method in interface org.springframework.data.redis.connection.ReactiveListCommands
-
Prepend values to key.
- LPUSH - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- lPushX(byte[], byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.listCommands()
}. - lPushX(byte[], byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- lPushX(byte[], byte[]) - Method in interface org.springframework.data.redis.connection.RedisListCommands
-
Prepend
values
tokey
only if the list exists. - lPushX(String, String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- lPushX(String, String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Prepend
values
tokey
only if the list exists. - lPushX(ByteBuffer, ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveListCommands
-
Prepend value to key if key already exists.
- LPUSHX - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- lRange(byte[], long, long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.listCommands()
}. - lRange(byte[], long, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- lRange(byte[], long, long) - Method in interface org.springframework.data.redis.connection.RedisListCommands
-
Get elements between
start
andend
from list atkey
. - lRange(String, long, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- lRange(String, long, long) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get elements between
start
andend
from list atkey
. - lRange(ByteBuffer, long, long) - Method in interface org.springframework.data.redis.connection.ReactiveListCommands
-
Get elements between start and end from list at key.
- lRange(Publisher<ReactiveRedisConnection.RangeCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveListCommands
-
Get elements in
ReactiveRedisConnection.RangeCommand.getRange()
from list atReactiveRedisConnection.KeyCommand.getKey()
- LRANGE - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- lRem(byte[], long, byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.listCommands()
}. - lRem(byte[], long, byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- lRem(byte[], long, byte[]) - Method in interface org.springframework.data.redis.connection.RedisListCommands
-
Removes the first
count
occurrences ofvalue
from the list stored atkey
. - lRem(String, long, String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- lRem(String, long, String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Removes the first
count
occurrences ofvalue
from the list stored atkey
. - lRem(ByteBuffer, Long, ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveListCommands
-
Removes the first count occurrences of value from the list stored at key.
- lRem(ByteBuffer, ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveListCommands
-
Removes all occurrences of value from the list stored at key.
- lRem(Publisher<ReactiveListCommands.LRemCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveListCommands
-
Removes the
ReactiveListCommands.LRemCommand.getCount()
occurrences ofReactiveListCommands.LRemCommand.getValue()
from the list stored atReactiveRedisConnection.KeyCommand.getKey()
. - LREM - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- lSet(byte[], long, byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.listCommands()
}. - lSet(byte[], long, byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- lSet(byte[], long, byte[]) - Method in interface org.springframework.data.redis.connection.RedisListCommands
-
Set the
value
list element atindex
. - lSet(String, long, String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- lSet(String, long, String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Set the
value
list element atindex
. - lSet(ByteBuffer, long, ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveListCommands
-
Set the value list element at index.
- lSet(Publisher<ReactiveListCommands.LSetCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveListCommands
-
Set the
ReactiveListCommands.LSetCommand.getValue()
list element atReactiveRedisConnection.KeyCommand.getKey()
. - LSET - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- lt() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZAddCommand
-
Applies LT mode.
- lt() - Method in class org.springframework.data.redis.connection.RedisZSetCommands.ZAddArgs
-
Only update existing elements if the new score is less than the current score.
- lt(Object) - Method in class org.springframework.data.redis.connection.RedisZSetCommands.Range
-
Deprecated.Less Than
- LT - Enum constant in enum class org.springframework.data.redis.connection.RedisZSetCommands.ZAddArgs.Flag
-
Only update existing elements if the new score is less than the current score.
- lte(Object) - Method in class org.springframework.data.redis.connection.RedisZSetCommands.Range
-
Deprecated.Less Then Equals
- lTrim(byte[], long, long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.listCommands()
}. - lTrim(byte[], long, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- lTrim(byte[], long, long) - Method in interface org.springframework.data.redis.connection.RedisListCommands
-
Trim list at
key
to elements betweenstart
andend
. - lTrim(String, long, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- lTrim(String, long, long) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Trim list at
key
to elements betweenstart
andend
. - lTrim(ByteBuffer, long, long) - Method in interface org.springframework.data.redis.connection.ReactiveListCommands
-
Trim list at key to elements between start and end.
- lTrim(Publisher<ReactiveRedisConnection.RangeCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveListCommands
-
Trim list at
ReactiveRedisConnection.KeyCommand.getKey()
to elements withinReactiveRedisConnection.RangeCommand.getRange()
. - LTRIM - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
M
- makeNoStream() - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.AddStreamRecord
-
Disable creation of stream if it does not already exist.
- makeNoStream() - Static method in class org.springframework.data.redis.connection.RedisStreamCommands.XAddOptions
-
Disable creation of stream if it does not already exist.
- makeNoStream(boolean) - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.AddStreamRecord
-
Disable creation of stream if it does not already exist.
- makeNoStream(boolean) - Static method in class org.springframework.data.redis.connection.RedisStreamCommands.XAddOptions
-
Disable creation of stream if it does not already exist.
- makeStream(boolean) - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.GroupCommand
- map(Function<char[], R>) - Method in class org.springframework.data.redis.connection.RedisPassword
- map(Function<MapRecord<S, K, V>, MapRecord<SK, HK, HV>>) - Method in interface org.springframework.data.redis.connection.stream.MapRecord
- map(List<MapRecord<K, HK, HV>>, Class<V>) - Method in interface org.springframework.data.redis.core.StreamOperations
-
Map records from
MapRecord
toObjectRecord
s. - map(MapRecord<K, HK, HV>, Class<V>) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
-
Map records from
MapRecord
toObjectRecord
. - map(MapRecord<K, HK, HV>, Class<V>) - Method in interface org.springframework.data.redis.core.StreamOperations
-
Map record from
MapRecord
toObjectRecord
. - MAP - Enum constant in enum class org.springframework.data.redis.support.collections.RedisCollectionFactoryBean.CollectionType
- mapBacked(Map<K, V>) - Static method in class org.springframework.data.redis.connection.stream.StreamRecords
- mapBulk(List<V>) - Method in interface org.springframework.data.redis.core.BulkMapper
- MapConverter<S,
T> - Class in org.springframework.data.redis.connection.convert -
Converts a Map of values of one key/value type to a Map of values of another type
- MapConverter(Converter<S, T>) - Constructor for class org.springframework.data.redis.connection.convert.MapConverter
- mapEntries(Function<Map.Entry<K, V>, Map.Entry<HK, HV>>) - Method in interface org.springframework.data.redis.connection.stream.MapRecord
-
Apply the given
mapFunction
to each and every entry in the backing collection to create a newMapRecord
. - MappingConfiguration - Class in org.springframework.data.redis.core.convert
-
MappingConfiguration
is used for programmatic configuration of secondary indexes, key prefixes, expirations and the such. - MappingConfiguration(ConfigurableIndexDefinitionProvider, KeyspaceConfiguration) - Constructor for class org.springframework.data.redis.core.convert.MappingConfiguration
-
Creates new
MappingConfiguration
. - MappingRedisConverter - Class in org.springframework.data.redis.core.convert
-
RedisConverter
implementation creating flat binary map structure out of a given domain type. - MappingRedisConverter(RedisMappingContext) - Constructor for class org.springframework.data.redis.core.convert.MappingRedisConverter
-
Creates new
MappingRedisConverter
. - MappingRedisConverter(RedisMappingContext, IndexResolver, ReferenceResolver) - Constructor for class org.springframework.data.redis.core.convert.MappingRedisConverter
-
Creates new
MappingRedisConverter
and defaultsRedisMappingContext
when null. - MappingRedisConverter(RedisMappingContext, IndexResolver, ReferenceResolver, RedisTypeMapper) - Constructor for class org.springframework.data.redis.core.convert.MappingRedisConverter
-
Creates new
MappingRedisConverter
and defaultsRedisMappingContext
when null. - MappingRedisConverter.BinaryKeyspaceIdentifier - Class in org.springframework.data.redis.core.convert
-
Value object representing a binary Redis Hash/Object identifier composed from keyspace and object id in the form of keyspace:id.
- MappingRedisConverter.KeyspaceIdentifier - Class in org.springframework.data.redis.core.convert
-
Value object representing a Redis Hash/Object identifier composed from keyspace and object id in the form of keyspace:id.
- MappingRedisEntityInformation<T,
ID> - Class in org.springframework.data.redis.repository.core -
RedisEntityInformation
implementation using aRedisPersistentEntity
instance to lookup the necessary information. - MappingRedisEntityInformation(RedisPersistentEntity<T>) - Constructor for class org.springframework.data.redis.repository.core.MappingRedisEntityInformation
- MapRecord<S,
K, V> - Interface in org.springframework.data.redis.connection.stream -
A
Record
within the stream backed by a collection of field/value pairs. - mapToPropertiesConverter() - Static method in class org.springframework.data.redis.connection.convert.Converters
-
Returns a converter to convert from
Map
toProperties
. - MapToPropertiesConverter - Enum Class in org.springframework.data.redis.connection.convert
- mapValue(Function<? super T, ? extends U>) - Method in class org.springframework.data.redis.connection.ClusterCommandExecutor.NodeResult
-
Apply the
mapper function
to the value and return the mapped value. - master(String) - Method in class org.springframework.data.redis.connection.RedisSentinelConfiguration
- master(NamedNode) - Method in class org.springframework.data.redis.connection.RedisSentinelConfiguration
- MASTER - Enum constant in enum class org.springframework.data.redis.connection.RedisClusterNode.Flag
- MASTER - Enum constant in enum class org.springframework.data.redis.connection.RedisNode.NodeType
- masters() - Method in class org.springframework.data.redis.connection.jedis.JedisSentinelConnection
- masters() - Method in class org.springframework.data.redis.connection.lettuce.LettuceSentinelConnection
- masters() - Method in interface org.springframework.data.redis.connection.RedisSentinelCommands
-
Get a
Collection
of monitored masters and their state. - match(byte[]) - Method in class org.springframework.data.redis.core.ScanOptions.ScanOptionsBuilder
-
Returns the current
ScanOptions.ScanOptionsBuilder
configured with the givenpattern
. - match(String) - Method in class org.springframework.data.redis.core.ScanOptions.ScanOptionsBuilder
-
Returns the current
ScanOptions.ScanOptionsBuilder
configured with the givenpattern
. - matches(Object, IndexDefinition.IndexingContext) - Method in class org.springframework.data.redis.core.index.RedisIndexDefinition.PathCondition
- matches(T, IndexDefinition.IndexingContext) - Method in interface org.springframework.data.redis.core.index.IndexDefinition.Condition
- matches(T, IndexDefinition.IndexingContext) - Method in class org.springframework.data.redis.core.index.RedisIndexDefinition.OrCondition
- max() - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.BZPopCommand
-
Creates a new
ReactiveZSetCommands.BZPopCommand
for max pop (ZPOPMAX). - max() - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZPopCommand
-
Creates a new
ReactiveZSetCommands.ZPopCommand
for max pop (ZPOPMAX). - MAX - Enum constant in enum class org.springframework.data.redis.connection.ReactiveZSetCommands.PopDirection
- MAX - Enum constant in enum class org.springframework.data.redis.connection.zset.Aggregate
- maxlen(long) - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.AddStreamRecord
-
Limit the size of the stream to the given maximum number of elements.
- maxlen(long) - Static method in class org.springframework.data.redis.connection.RedisStreamCommands.XAddOptions
-
Limit the size of the stream to the given maximum number of elements.
- maxMessageId() - Method in class org.springframework.data.redis.connection.stream.PendingMessagesSummary
-
Get the greatest ID as
String
among the pending messages. - maxRecordId() - Method in class org.springframework.data.redis.connection.stream.PendingMessagesSummary
-
Get the greatest ID among the pending messages.
- mDel(List<ByteBuffer>) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
-
Delete multiple keys one in one batch.
- mDel(Publisher<List<ByteBuffer>>) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
-
Delete multiple keys in batches.
- meet(RedisClusterNode) - Method in interface org.springframework.data.redis.core.ClusterOperations
-
Add the node to cluster.
- member(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoHashCommand
-
Creates a new
ReactiveGeoCommands.GeoHashCommand
given a member. - member(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoPosCommand
-
Creates a new
ReactiveGeoCommands.GeoPosCommand
given a member. - members() - Method in interface org.springframework.data.redis.core.BoundSetOperations
-
Get all elements of set at the bound key.
- members(long) - Static method in class org.springframework.data.redis.connection.ReactiveSetCommands.SPopCommand
-
Creates a new
ReactiveSetCommands.SPopCommand
forcount
members. - members(Collection<ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoHashCommand
-
Creates a new
ReactiveGeoCommands.GeoHashCommand
given aCollection
of values. - members(Collection<ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoPosCommand
-
Creates a new
ReactiveGeoCommands.GeoPosCommand
given aCollection
of values. - members(K) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
-
Get all elements of set at
key
. - members(K) - Method in interface org.springframework.data.redis.core.SetOperations
-
Get all elements of set at
key
. - mergeArrays(byte[], byte[]...) - Static method in class org.springframework.data.redis.util.ByteUtils
-
Merge multiple
byte
arrays into one array - Message - Interface in org.springframework.data.redis.connection
-
Class encapsulating a Redis message body and its properties.
- MessageListener - Interface in org.springframework.data.redis.connection
-
Listener of messages published in Redis.
- MessageListenerAdapter - Class in org.springframework.data.redis.listener.adapter
-
Message listener adapter that delegates the handling of messages to target listener methods via reflection, with flexible message type conversion.
- MessageListenerAdapter() - Constructor for class org.springframework.data.redis.listener.adapter.MessageListenerAdapter
-
Create a new
MessageListenerAdapter
with default settings. - MessageListenerAdapter(Object) - Constructor for class org.springframework.data.redis.listener.adapter.MessageListenerAdapter
-
Create a new
MessageListenerAdapter
for the given delegate. - MessageListenerAdapter(Object, String) - Constructor for class org.springframework.data.redis.listener.adapter.MessageListenerAdapter
-
Create a new
MessageListenerAdapter
for the given delegate. - messageListenerContainerRef() - Element in annotation interface org.springframework.data.redis.repository.configuration.EnableRedisRepositories
-
Configure the name of the
RedisMessageListenerContainer
bean to be used for keyspace event subscriptions. - MESSAGES_RECEIVED - Enum constant in enum class org.springframework.data.redis.connection.ClusterInfo.Info
- MESSAGES_SENT - Enum constant in enum class org.springframework.data.redis.connection.ClusterInfo.Info
- meters() - Static method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoDistCommand
-
Creates a new
ReactiveGeoCommands.GeoDistCommand
forRedisGeoCommands.DistanceUnit.METERS
. - METERS - Enum constant in enum class org.springframework.data.redis.connection.RedisGeoCommands.DistanceUnit
- METERS - Enum constant in enum class org.springframework.data.redis.domain.geo.Metrics
- Metrics - Enum Class in org.springframework.data.redis.domain.geo
-
Metric
s supported by Redis. - mGet(byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.stringCommands()
}. - mGet(byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- mGet(byte[]...) - Method in interface org.springframework.data.redis.connection.RedisStringCommands
-
Get multiple
keys
. - mGet(String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- mGet(String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get multiple
keys
. - mGet(List<ByteBuffer>) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
-
Get multiple values in one batch.
- mGet(Publisher<List<ByteBuffer>>) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
-
Get multiple values at for keysets in batches.
- MGET - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- MicrometerTracer(ObservationRegistry) - Constructor for class org.springframework.data.redis.connection.lettuce.observability.MicrometerTracingAdapter.MicrometerTracer
-
Deprecated.
- MicrometerTracingAdapter - Class in org.springframework.data.redis.connection.lettuce.observability
-
Deprecated, for removal: This API element is subject to removal in a future version.since 3.4 for removal with the next major revision. Use Lettuce's Micrometer integration through
MicrometerTracing
. - MicrometerTracingAdapter(ObservationRegistry, String) - Constructor for class org.springframework.data.redis.connection.lettuce.observability.MicrometerTracingAdapter
-
Deprecated.Create a new
MicrometerTracingAdapter
instance. - MicrometerTracingAdapter(ObservationRegistry, String, boolean) - Constructor for class org.springframework.data.redis.connection.lettuce.observability.MicrometerTracingAdapter
-
Deprecated.Create a new
MicrometerTracingAdapter
instance. - MicrometerTracingAdapter.MicrometerTracer - Class in org.springframework.data.redis.connection.lettuce.observability
-
Deprecated.
Tracer
implementation based on Micrometer'sObservationRegistry
. - migrate(byte[], RedisNode, int, RedisServerCommands.MigrateOption) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.serverCommands()
. - migrate(byte[], RedisNode, int, RedisServerCommands.MigrateOption) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- migrate(byte[], RedisNode, int, RedisServerCommands.MigrateOption) - Method in interface org.springframework.data.redis.connection.RedisServerCommands
-
Atomically transfer a key from a source Redis instance to a destination Redis instance.
- migrate(byte[], RedisNode, int, RedisServerCommands.MigrateOption, long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.serverCommands()
. - migrate(byte[], RedisNode, int, RedisServerCommands.MigrateOption, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- migrate(byte[], RedisNode, int, RedisServerCommands.MigrateOption, long) - Method in interface org.springframework.data.redis.connection.RedisServerCommands
-
Atomically transfer a key from a source Redis instance to a destination Redis instance.
- MIGRATE - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- MIGRATING - Enum constant in enum class org.springframework.data.redis.connection.ReactiveClusterCommands.AddSlots
- MIGRATING - Enum constant in enum class org.springframework.data.redis.connection.RedisClusterCommands.AddSlots
- miles() - Static method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoDistCommand
-
Creates a new
ReactiveGeoCommands.GeoDistCommand
forRedisGeoCommands.DistanceUnit.MILES
. - MILES - Enum constant in enum class org.springframework.data.redis.connection.RedisGeoCommands.DistanceUnit
- MILES - Enum constant in enum class org.springframework.data.redis.domain.geo.Metrics
- milliseconds(long) - Static method in class org.springframework.data.redis.core.types.Expiration
-
Creates a new
Expiration
inTimeUnit.MILLISECONDS
. - millisecondsToTimeUnit(long, TimeUnit) - Static method in class org.springframework.data.redis.connection.convert.Converters
-
Converts
milliseconds
to the givenTimeUnit
. - millisecondsToTimeUnit(TimeUnit) - Static method in class org.springframework.data.redis.connection.convert.Converters
- min() - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.BZPopCommand
-
Creates a new
ReactiveZSetCommands.BZPopCommand
for min pop (ZPOPMIN). - min() - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZPopCommand
-
Creates a new
ReactiveZSetCommands.ZPopCommand
for min pop (ZPOPMIN). - MIN - Enum constant in enum class org.springframework.data.redis.connection.ReactiveZSetCommands.PopDirection
- MIN - Enum constant in enum class org.springframework.data.redis.connection.zset.Aggregate
- minId(RecordId) - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.AddStreamRecord
-
Apply
MINID
trimming strategy, that evicts entries with IDs lower than the one specified. - minId(RecordId) - Method in class org.springframework.data.redis.connection.RedisStreamCommands.XAddOptions
-
Apply
MINID
trimming strategy, that evicts entries with IDs lower than the one specified. - minIdle(Duration) - Static method in class org.springframework.data.redis.connection.RedisStreamCommands.XClaimOptions
-
Set the min-idle-time to limit the command to messages that have been idle for at at least the given
Duration
. - minIdleMs(long) - Static method in class org.springframework.data.redis.connection.RedisStreamCommands.XClaimOptions
-
Set the min-idle-time to limit the command to messages that have been idle for at at least the given milliseconds.
- minMessageId() - Method in class org.springframework.data.redis.connection.stream.PendingMessagesSummary
-
Get the smallest ID as
String
among the pending messages. - minRecordId() - Method in class org.springframework.data.redis.connection.stream.PendingMessagesSummary
-
Get the smallest ID among the pending messages.
- MINUS_BYTES - Static variable in class org.springframework.data.redis.connection.lettuce.LettuceConverters
- monitor(RedisServer) - Method in class org.springframework.data.redis.connection.jedis.JedisSentinelConnection
- monitor(RedisServer) - Method in class org.springframework.data.redis.connection.lettuce.LettuceSentinelConnection
- monitor(RedisServer) - Method in interface org.springframework.data.redis.connection.RedisSentinelCommands
-
Tell sentinel to start monitoring a new master with the specified
RedisNode.getName()
,RedisNode.getHost()
,RedisNode.getPort()
, andRedisServer.getQuorum()
. - MONITOR - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- move(byte[], int) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.keyCommands()
. - move(byte[], int) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- move(byte[], int) - Method in interface org.springframework.data.redis.connection.RedisKeyCommands
-
Move given
key
to database withindex
. - move(String, int) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- move(String, int) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Move given
key
to database withindex
. - move(ByteBuffer, int) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
-
Move given
key
to database withindex
. - move(K, int) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
-
Move given
key
to database withindex
. - move(K, int) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
- move(K, int) - Method in interface org.springframework.data.redis.core.RedisOperations
-
Move given
key
to database withindex
. - move(K, int) - Method in class org.springframework.data.redis.core.RedisTemplate
- move(K, ReactiveListCommands.Direction, K, ReactiveListCommands.Direction) - Method in interface org.springframework.data.redis.core.ReactiveListOperations
-
Atomically returns and removes the first/last element (head/tail depending on the
from
argument) of the list stored atsourceKey
, and pushes the element at the first/last element (head/tail depending on theto
argument) of the list stored atdestinationKey
. - move(K, ReactiveListCommands.Direction, K, ReactiveListCommands.Direction, Duration) - Method in interface org.springframework.data.redis.core.ReactiveListOperations
-
Atomically returns and removes the first/last element (head/tail depending on the
from
argument) of the list stored atsourceKey
, and pushes the element at the first/last element (head/tail depending on theto
argument) of the list stored atdestinationKey
. - move(K, RedisListCommands.Direction, K, RedisListCommands.Direction) - Method in interface org.springframework.data.redis.core.ListOperations
-
Atomically returns and removes the first/last element (head/tail depending on the
from
argument) of the list stored atsourceKey
, and pushes the element at the first/last element (head/tail depending on theto
argument) of the list stored atdestinationKey
. - move(K, RedisListCommands.Direction, K, RedisListCommands.Direction, long, TimeUnit) - Method in interface org.springframework.data.redis.core.ListOperations
-
Atomically returns and removes the first/last element (head/tail depending on the
from
argument) of the list stored atsourceKey
, and pushes the element at the first/last element (head/tail depending on theto
argument) of the list stored atdestinationKey
. - move(K, RedisListCommands.Direction, K, RedisListCommands.Direction, Duration) - Method in interface org.springframework.data.redis.core.ListOperations
-
Atomically returns and removes the first/last element (head/tail depending on the
from
argument) of the list stored atsourceKey
, and pushes the element at the first/last element (head/tail depending on theto
argument) of the list stored atdestinationKey
. - move(K, V) - Method in interface org.springframework.data.redis.core.BoundSetOperations
-
Move
value
from the bound key todestKey
- move(K, V, K) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
-
Move
value
fromkey
todestKey
- move(K, V, K) - Method in interface org.springframework.data.redis.core.SetOperations
-
Move
value
fromkey
todestKey
- move(Publisher<ReactiveKeyCommands.MoveCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
-
Move keys one-by-one between databases.
- move(RedisListCommands.Direction, K, RedisListCommands.Direction) - Method in interface org.springframework.data.redis.core.BoundListOperations
-
Atomically returns and removes the first/last element (head/tail depending on the
from
argument) of the list stored at the bound key, and pushes the element at the first/last element (head/tail depending on theto
argument) of the list stored atdestinationKey
. - move(RedisListCommands.Direction, K, RedisListCommands.Direction, long, TimeUnit) - Method in interface org.springframework.data.redis.core.BoundListOperations
-
Atomically returns and removes the first/last element (head/tail depending on the
from
argument) of the list stored at the bound key, and pushes the element at the first/last element (head/tail depending on theto
argument) of the list stored atdestinationKey
. - move(RedisListCommands.Direction, K, RedisListCommands.Direction, Duration) - Method in interface org.springframework.data.redis.core.BoundListOperations
-
Atomically returns and removes the first/last element (head/tail depending on the
from
argument) of the list stored at the bound key, and pushes the element at the first/last element (head/tail depending on theto
argument) of the list stored atdestinationKey
. - move(ListOperations.MoveFrom<K>, ListOperations.MoveTo<K>) - Method in interface org.springframework.data.redis.core.ListOperations
-
Atomically returns and removes the first/last element (head/tail depending on the
from
argument) of the list stored atsourceKey
, and pushes the element at the first/last element (head/tail depending on theto
argument) of the list stored atdestinationKey
. - move(ListOperations.MoveFrom<K>, ListOperations.MoveTo<K>) - Method in interface org.springframework.data.redis.core.ReactiveListOperations
-
Atomically returns and removes the first/last element (head/tail depending on the
from
argument) of the list stored atsourceKey
, and pushes the element at the first/last element (head/tail depending on theto
argument) of the list stored atdestinationKey
. - move(ListOperations.MoveFrom<K>, ListOperations.MoveTo<K>, Duration) - Method in interface org.springframework.data.redis.core.ListOperations
-
Atomically returns and removes the first/last element (head/tail depending on the
from
argument) of the list stored atsourceKey
, and pushes the element at the first/last element (head/tail depending on theto
argument) of the list stored atdestinationKey
. - move(ListOperations.MoveFrom<K>, ListOperations.MoveTo<K>, Duration) - Method in interface org.springframework.data.redis.core.ReactiveListOperations
-
Atomically returns and removes the first/last element (head/tail depending on the
from
argument) of the list stored atsourceKey
, and pushes the element at the first/last element (head/tail depending on theto
argument) of the list stored atdestinationKey
. - MOVE - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- moveFirstTo(RedisList<E>, RedisListCommands.Direction) - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- moveFirstTo(RedisList<E>, RedisListCommands.Direction) - Method in interface org.springframework.data.redis.support.collections.RedisList
-
Atomically returns and removes the first element of the list stored at the bound key, and pushes the element at the first/last element (head/tail depending on the
destinationPosition
argument) of the list stored atdestination
. - moveFirstTo(RedisList<E>, RedisListCommands.Direction, long, TimeUnit) - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- moveFirstTo(RedisList<E>, RedisListCommands.Direction, long, TimeUnit) - Method in interface org.springframework.data.redis.support.collections.RedisList
-
Atomically returns and removes the first element of the list stored at the bound key, and pushes the element at the first/last element (head/tail depending on the
destinationPosition
argument) of the list stored atdestination
. - moveFirstTo(RedisList<E>, RedisListCommands.Direction, Duration) - Method in interface org.springframework.data.redis.support.collections.RedisList
-
Atomically returns and removes the first element of the list stored at the bound key, and pushes the element at the first/last element (head/tail depending on the
destinationPosition
argument) of the list stored atdestination
. - moveLastTo(RedisList<E>, RedisListCommands.Direction) - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- moveLastTo(RedisList<E>, RedisListCommands.Direction) - Method in interface org.springframework.data.redis.support.collections.RedisList
-
Atomically returns and removes the last element of the list stored at the bound key, and pushes the element at the first/last element (head/tail depending on the
destinationPosition
argument) of the list stored atdestination
. - moveLastTo(RedisList<E>, RedisListCommands.Direction, long, TimeUnit) - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- moveLastTo(RedisList<E>, RedisListCommands.Direction, long, TimeUnit) - Method in interface org.springframework.data.redis.support.collections.RedisList
-
Atomically returns and removes the last element of the list stored at the bound key, and pushes the element at the first/last element (head/tail depending on the
destinationPosition
argument) of the list stored atdestination
. - moveLastTo(RedisList<E>, RedisListCommands.Direction, Duration) - Method in interface org.springframework.data.redis.support.collections.RedisList
-
Atomically returns and removes the last element of the list stored at the bound key, and pushes the element at the first/last element (head/tail depending on the
destinationPosition
argument) of the list stored atdestination
. - moveNext(Iterator<T>) - Method in class org.springframework.data.redis.core.ScanCursor
-
Fetch the next item from the underlying
Iterable
. - mset(Map<ByteBuffer, ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveStringCommands.MSetCommand
-
Creates a new
ReactiveStringCommands.MSetCommand
given aMap
of key-value tuples. - mSet(Map<byte[], byte[]>) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.stringCommands()
}. - mSet(Map<byte[], byte[]>) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- mSet(Map<byte[], byte[]>) - Method in interface org.springframework.data.redis.connection.RedisStringCommands
-
Set multiple keys to multiple values using key-value pairs provided in
tuple
. - mSet(Map<ByteBuffer, ByteBuffer>) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
-
Set multiple keys to multiple values using key-value pairs provided in tuple.
- mSet(Publisher<ReactiveStringCommands.MSetCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
-
Set multiple keys to multiple values using key-value pairs provided in commands.
- MSET - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- mSetNX(Map<byte[], byte[]>) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.stringCommands()
}. - mSetNX(Map<byte[], byte[]>) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- mSetNX(Map<byte[], byte[]>) - Method in interface org.springframework.data.redis.connection.RedisStringCommands
-
Set multiple keys to multiple values using key-value pairs provided in
tuple
only if the provided key does not exist. - mSetNX(Map<ByteBuffer, ByteBuffer>) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
-
Set multiple keys to multiple values using key-value pairs provided in keyValuePairs only if the provided key does not exist.
- mSetNX(Publisher<ReactiveStringCommands.MSetCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
-
Set multiple keys to multiple values using key-value pairs provided in tuples only if the provided key does not exist.
- MSETNX - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- mSetNXString(Map<String, String>) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- mSetNXString(Map<String, String>) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Set multiple keys to multiple values using key-value pairs provided in
tuple
only if the provided key does not exist. - mSetString(Map<String, String>) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- mSetString(Map<String, String>) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Set multiple keys to multiple values using key-value pairs provided in
tuple
. - MULIT_COMMAND_CONTEXT - Enum constant in enum class org.springframework.data.redis.core.types.RedisClientInfo.INFO
- multi() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- multi() - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
- multi() - Method in class org.springframework.data.redis.connection.jedis.JedisConnection
- multi() - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
- multi() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
- multi() - Method in interface org.springframework.data.redis.connection.RedisTxCommands
-
Mark the start of a transaction block.
- multi() - Method in interface org.springframework.data.redis.core.RedisOperations
-
Mark the start of a transaction block.
- multi() - Method in class org.springframework.data.redis.core.RedisTemplate
- MULTI - Enum constant in enum class org.springframework.data.redis.connection.ReturnType
- MULTI - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- multiGet(H, Collection<HK>) - Method in interface org.springframework.data.redis.core.HashOperations
-
Get values for given
hashKeys
from hash atkey
. - multiGet(H, Collection<HK>) - Method in interface org.springframework.data.redis.core.ReactiveHashOperations
-
Get values for given
hashKeys
from hash atkey
. - multiGet(Collection<HK>) - Method in interface org.springframework.data.redis.core.BoundHashOperations
-
Get values for given
keys
from the hash at the bound key. - multiGet(Collection<K>) - Method in interface org.springframework.data.redis.core.ReactiveValueOperations
-
Get multiple
keys
. - multiGet(Collection<K>) - Method in interface org.springframework.data.redis.core.ValueOperations
-
Get multiple
keys
. - MultiNodeResult() - Constructor for class org.springframework.data.redis.connection.ClusterCommandExecutor.MultiNodeResult
- multipliedByTypeLength() - Method in class org.springframework.data.redis.connection.BitFieldSubCommands.Offset
-
Creates new type based offset.
- multiply(double) - Method in class org.springframework.data.redis.connection.zset.Weights
-
Creates a new
Weights
object that contains all weights multiplied bymultiplier
- multiply(int) - Method in class org.springframework.data.redis.connection.zset.Weights
-
Creates a new
Weights
object that contains all weights multiplied bymultiplier
- multiSet(Map<? extends K, ? extends V>) - Method in interface org.springframework.data.redis.core.ReactiveValueOperations
-
Set multiple keys to multiple values using key-value pairs provided in
tuple
. - multiSet(Map<? extends K, ? extends V>) - Method in interface org.springframework.data.redis.core.ValueOperations
-
Set multiple keys to multiple values using key-value pairs provided in
tuple
. - multiSetIfAbsent(Map<? extends K, ? extends V>) - Method in interface org.springframework.data.redis.core.ReactiveValueOperations
-
Set multiple keys to multiple values using key-value pairs provided in
tuple
only if the provided key does not exist. - multiSetIfAbsent(Map<? extends K, ? extends V>) - Method in interface org.springframework.data.redis.core.ValueOperations
-
Set multiple keys to multiple values using key-value pairs provided in
tuple
only if the provided key does not exist. - MultiValueResponse(I, List<O>) - Constructor for class org.springframework.data.redis.connection.ReactiveRedisConnection.MultiValueResponse
- mUnlink(List<ByteBuffer>) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
-
Unlink the
keys
from the keyspace. - mUnlink(Publisher<List<ByteBuffer>>) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
-
Unlink the
keys
from the keyspace. - MY_EPOCH - Enum constant in enum class org.springframework.data.redis.connection.ClusterInfo.Info
- MYSELF - Enum constant in enum class org.springframework.data.redis.connection.RedisClusterNode.Flag
N
- NAME - Enum constant in enum class org.springframework.data.redis.connection.RedisServer.INFO
- NamedNode - Interface in org.springframework.data.redis.connection
- namedQueriesLocation() - Element in annotation interface org.springframework.data.redis.repository.configuration.EnableRedisRepositories
-
Configures the location of where to find the Spring Data named queries properties file.
- nameGenerator() - Element in annotation interface org.springframework.data.redis.repository.configuration.EnableRedisRepositories
-
Configure a specific
BeanNameGenerator
to be used when creating the repositoy beans. - near(RedisOperationChain.NearPath) - Method in class org.springframework.data.redis.repository.query.RedisOperationChain
- NearPath(String, Point, Distance) - Constructor for class org.springframework.data.redis.repository.query.RedisOperationChain.NearPath
- NEGATIVE_INFINITY_BYTES - Static variable in class org.springframework.data.redis.connection.lettuce.LettuceConverters
- newBucketFromRawMap(Map<byte[], byte[]>) - Static method in class org.springframework.data.redis.core.convert.Bucket
-
Creates a new Bucket from a given raw map.
- newBucketFromStringMap(Map<String, String>) - Static method in class org.springframework.data.redis.core.convert.Bucket
-
Creates a new Bucket from a given
String
map. - newGeoRadiusArgs() - Static method in class org.springframework.data.redis.connection.RedisGeoCommands.GeoRadiusCommandArgs
-
Create new
RedisGeoCommands.GeoRadiusCommandArgs
. - newGeoSearchArgs() - Static method in class org.springframework.data.redis.connection.RedisGeoCommands.GeoSearchCommandArgs
-
Create new
RedisGeoCommands.GeoSearchCommandArgs
. - newGeoSearchStoreArgs() - Static method in class org.springframework.data.redis.connection.RedisGeoCommands.GeoSearchStoreCommandArgs
-
Create new
RedisGeoCommands.GeoSearchStoreCommandArgs
. - newPartialUpdate(Object, Class<S>) - Static method in class org.springframework.data.redis.core.PartialUpdate
-
Create new
PartialUpdate
for given id and type. - newPipeline() - Method in interface org.springframework.data.redis.connection.lettuce.LettuceConnection.PipeliningFlushPolicy
- newRecord() - Static method in class org.springframework.data.redis.connection.stream.StreamRecords
-
Obtain new instance of
StreamRecords.RecordBuilder
to fluently createrecords
. - newRedisClusterNode() - Static method in class org.springframework.data.redis.connection.RedisClusterNode
-
Get
RedisClusterNode.RedisClusterNodeBuilder
for creating newRedisClusterNode
. - newRedisNode() - Static method in class org.springframework.data.redis.connection.RedisNode
-
Get
RedisNode.RedisNodeBuilder
for creating newRedisNode
. - newSerializationContext() - Static method in interface org.springframework.data.redis.serializer.RedisSerializationContext
-
Creates a new
RedisSerializationContext.RedisSerializationContextBuilder
. - newSerializationContext(RedisSerializationContext.SerializationPair<?>) - Static method in interface org.springframework.data.redis.serializer.RedisSerializationContext
-
Creates a new
RedisSerializationContext.RedisSerializationContextBuilder
using a given defaultRedisSerializationContext.SerializationPair
. - newSerializationContext(RedisSerializer<?>) - Static method in interface org.springframework.data.redis.serializer.RedisSerializationContext
-
Creates a new
RedisSerializationContext.RedisSerializationContextBuilder
using a given defaultRedisSerializer
. - newServerFrom(Properties) - Static method in class org.springframework.data.redis.connection.RedisServer
-
Creates a new
RedisServer
from the given properties. - next() - Method in class org.springframework.data.redis.core.ConvertingCursor
- next() - Method in class org.springframework.data.redis.core.ScanCursor
- nextSpan() - Method in class org.springframework.data.redis.connection.lettuce.observability.MicrometerTracingAdapter.MicrometerTracer
-
Deprecated.
- nextSpan(TraceContext) - Method in class org.springframework.data.redis.connection.lettuce.observability.MicrometerTracingAdapter.MicrometerTracer
-
Deprecated.
- NO_EXPIRATION - Static variable in interface org.springframework.data.redis.cache.RedisCacheWriter.TtlFunction
- NO_OP_SUBSCRIPTION_LISTENER - Static variable in interface org.springframework.data.redis.connection.SubscriptionListener
-
Empty
SubscriptionListener
. - noack() - 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. - NOADDR - Enum constant in enum class org.springframework.data.redis.connection.RedisClusterNode.Flag
- node(String) - Method in class org.springframework.data.redis.connection.RedisStaticMasterReplicaConfiguration
-
Add a
node
to the list of nodes givenhostName
. - node(String, int) - Method in class org.springframework.data.redis.connection.RedisStaticMasterReplicaConfiguration
- NODE - Enum constant in enum class org.springframework.data.redis.connection.ReactiveClusterCommands.AddSlots
- NODE - Enum constant in enum class org.springframework.data.redis.connection.RedisClusterCommands.AddSlots
- NodeResult(RedisClusterNode, T) - Constructor for class org.springframework.data.redis.connection.ClusterCommandExecutor.NodeResult
-
Create a new
ClusterCommandExecutor.NodeResult
. - NodeResult(RedisClusterNode, T, byte[]) - Constructor for class org.springframework.data.redis.connection.ClusterCommandExecutor.NodeResult
-
Create a new
ClusterCommandExecutor.NodeResult
. - NOFLAGS - Enum constant in enum class org.springframework.data.redis.connection.RedisClusterNode.Flag
- none() - Static method in interface org.springframework.data.redis.cache.CacheStatisticsCollector
- none() - Static method in class org.springframework.data.redis.connection.RedisPassword
-
Create an absent
RedisPassword
. - none() - Static method in class org.springframework.data.redis.connection.RedisStreamCommands.XAddOptions
- NONE - Enum constant in enum class org.springframework.data.redis.connection.DataType
- NONE - Static variable in class org.springframework.data.redis.core.KeyScanOptions
-
Constant to apply default
KeyScanOptions
without setting a limit or matching a pattern. - NONE - Static variable in class org.springframework.data.redis.core.ScanOptions
-
Constant to apply default
ScanOptions
without setting a limit or matching a pattern. - nonLockingRedisCacheWriter(RedisConnectionFactory) - Static method in interface org.springframework.data.redis.cache.RedisCacheWriter
-
Create new
RedisCacheWriter
without locking behavior. - nonLockingRedisCacheWriter(RedisConnectionFactory, BatchStrategy) - Static method in interface org.springframework.data.redis.cache.RedisCacheWriter
-
Create new
RedisCacheWriter
without locking behavior. - NOSAVE - Enum constant in enum class org.springframework.data.redis.connection.RedisServerCommands.ShutdownOption
- noSort() - Method in class org.springframework.data.redis.core.query.SortQueryBuilder
- NOT - Enum constant in enum class org.springframework.data.redis.connection.RedisStringCommands.BitOperation
- nullSafeList(List<T>) - Static method in class org.springframework.data.redis.support.collections.CollectionUtils
- nullValueSerializer(StdSerializer<NullValue>) - Method in class org.springframework.data.redis.serializer.GenericJackson2JsonRedisSerializer.GenericJackson2JsonRedisSerializerBuilder
-
Register a
serializer
forNullValue
. - NUMBER_OTHER_SENTINELS - Enum constant in enum class org.springframework.data.redis.connection.RedisServer.INFO
- NUMBER_SLAVES - Enum constant in enum class org.springframework.data.redis.connection.RedisServer.INFO
- numberCommands() - Method in interface org.springframework.data.redis.connection.ReactiveRedisClusterConnection
- numberCommands() - Method in interface org.springframework.data.redis.connection.ReactiveRedisConnection
- numeric() - Method in class org.springframework.data.redis.connection.DefaultSortParameters
- NumericResponse(I, O) - Constructor for class org.springframework.data.redis.connection.ReactiveRedisConnection.NumericResponse
- nx() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZAddCommand
-
Applies nx mode (Don't update already existing elements.
- nx() - Method in class org.springframework.data.redis.connection.RedisZSetCommands.ZAddArgs
-
Only update elements that already exist.
- NX - Enum constant in enum class org.springframework.data.redis.connection.RedisZSetCommands.ZAddArgs.Flag
-
Don't update already existing elements.
O
- objectBacked(V) - Static method in class org.springframework.data.redis.connection.stream.StreamRecords
-
Create new
ObjectRecord
backed by the given value. - ObjectHashMapper - Class in org.springframework.data.redis.hash
-
HashMapper
based onMappingRedisConverter
. - ObjectHashMapper() - Constructor for class org.springframework.data.redis.hash.ObjectHashMapper
-
Creates new
ObjectHashMapper
. - ObjectHashMapper(CustomConversions) - Constructor for class org.springframework.data.redis.hash.ObjectHashMapper
-
Creates new
ObjectHashMapper
. - ObjectHashMapper(RedisConverter) - Constructor for class org.springframework.data.redis.hash.ObjectHashMapper
-
Creates a new
ObjectHashMapper
using the givenRedisConverter
for conversion. - objectMapper(ObjectMapper) - Method in class org.springframework.data.redis.serializer.GenericJackson2JsonRedisSerializer.GenericJackson2JsonRedisSerializerBuilder
-
Configure a provided
ObjectMapper
. - objectMapper(HashMapper<NV, ?, ?>) - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamMessageListenerContainerOptionsBuilder
-
Configure a hash mapper.
- objectMapper(HashMapper<NV, ?, ?>) - Method in class org.springframework.data.redis.stream.StreamReceiver.StreamReceiverOptionsBuilder
-
Configure a hash mapper.
- ObjectRecord<S,
V> - Interface in org.springframework.data.redis.connection.stream -
A
Record
within the stream mapped to a single object. - occurrencesOf(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveListCommands.LRemCommand
-
Applies the value.
- of(byte[]) - Static method in class org.springframework.data.redis.core.convert.MappingRedisConverter.BinaryKeyspaceIdentifier
-
Parse a binary
key
intoMappingRedisConverter.BinaryKeyspaceIdentifier
. - of(byte[], Double) - Static method in interface org.springframework.data.redis.connection.zset.Tuple
-
Create a new
Tuple
. - of(char[]) - Static method in class org.springframework.data.redis.connection.RedisPassword
-
Create a
RedisPassword
from achar
array. - of(double...) - Static method in class org.springframework.data.redis.connection.zset.Weights
- of(int...) - Static method in class org.springframework.data.redis.connection.zset.Weights
- of(long) - Static method in class org.springframework.data.redis.core.Cursor.CursorId
-
Creates a
Cursor.CursorId
from the givencursorId
. - of(long, long) - Static method in class org.springframework.data.redis.connection.stream.RecordId
-
Create a new instance of
RecordId
using the provided String formatted as <millisecondsTime>-<sequenceNumber>. - of(String) - Static method in class org.springframework.data.redis.connection.RedisPassword
-
Create a
RedisPassword
from aString
. - of(String) - Static method in class org.springframework.data.redis.connection.stream.RecordId
-
Obtain an instance of
RecordId
using the provided String formatted as <millisecondsTime>-<sequenceNumber>. - of(String) - Static method in interface org.springframework.data.redis.connection.ValueEncoding
-
Get the
ValueEncoding
for givenencoding
. - of(String) - Static method in class org.springframework.data.redis.core.convert.MappingRedisConverter.KeyspaceIdentifier
-
Parse a
key
intoMappingRedisConverter.KeyspaceIdentifier
. - of(String) - Static method in class org.springframework.data.redis.core.Cursor.CursorId
-
Creates a
Cursor.CursorId
from the givencursorId
. - of(String) - Static method in interface org.springframework.data.redis.core.script.RedisScript
- of(String) - Static method in class org.springframework.data.redis.listener.ChannelTopic
-
Create a new
ChannelTopic
for channel subscriptions. - of(String) - Static method in class org.springframework.data.redis.listener.PatternTopic
-
Create a new
PatternTopic
for channel subscriptions based on apattern
. - of(String, Class<T>) - Static method in interface org.springframework.data.redis.core.script.RedisScript
- of(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoHashCommand
-
Applies the Geo set key.
- of(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoPosCommand
-
Applies the Geo set key.
- of(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveSetCommands.SIsMemberCommand
-
Applies the set key.
- of(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveSetCommands.SMIsMemberCommand
-
Applies the set key.
- of(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveStreamCommands.XInfoCommand
- of(Map<String, String>) - Static method in interface org.springframework.data.redis.connection.stream.StringRecord
- of(Map<K, V>) - Static method in interface org.springframework.data.redis.connection.stream.Record
- of(PropertySource<?>) - Static method in class org.springframework.data.redis.connection.RedisClusterConfiguration
-
Creates a new
RedisClusterConfiguration
looking up configuration values from the givenPropertySource
. - of(PropertySource<?>) - Static method in class org.springframework.data.redis.connection.RedisSentinelConfiguration
-
Construct a new
RedisSentinelConfiguration
from the givenPropertySource
. - of(Resource) - Static method in interface org.springframework.data.redis.core.script.RedisScript
-
Creates new
RedisScript
(with throw away result) from the givenResource
. - of(Resource, Class<T>) - Static method in interface org.springframework.data.redis.core.script.RedisScript
-
Creates new
RedisScript
fromResource
. - of(ByteBufferRecord) - Static method in class org.springframework.data.redis.connection.ReactiveStreamCommands.AddStreamRecord
-
Creates a new
ReactiveStreamCommands.AddStreamRecord
givenbody
. - of(MapRecord<byte[], byte[], byte[]>) - Static method in interface org.springframework.data.redis.connection.stream.ByteRecord
-
Convert a binary
MapRecord
into aByteRecord
. - of(MapRecord<String, String, String>) - Static method in interface org.springframework.data.redis.connection.stream.StringRecord
- of(MapRecord<ByteBuffer, ByteBuffer, ByteBuffer>) - Static method in interface org.springframework.data.redis.connection.stream.ByteBufferRecord
-
Convert a binary
MapRecord
into aByteRecord
. - of(V) - Static method in interface org.springframework.data.redis.connection.stream.Record
-
Create a new
ObjectRecord
instance backed by the given value. - of(V, Double) - Static method in interface org.springframework.data.redis.core.ZSetOperations.TypedTuple
-
Create a new
ZSetOperations.TypedTuple
. - ofBuffer(Map<ByteBuffer, ByteBuffer>) - Method in class org.springframework.data.redis.connection.stream.StreamRecords.RecordBuilder
- ofBytes(Map<byte[], byte[]>) - Method in class org.springframework.data.redis.connection.stream.StreamRecords.RecordBuilder
- OFF - Enum constant in enum class org.springframework.data.redis.core.RedisKeyValueAdapter.EnableKeyspaceEvents
-
Turn
KeyExpirationEventMessageListener
usage off. - OFF - Enum constant in enum class org.springframework.data.redis.core.RedisKeyValueAdapter.ShadowCopy
-
Do not store shadow copies.
- offer(E) - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- offer(E, long, TimeUnit) - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- offerFirst(E) - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- offerFirst(E, long, TimeUnit) - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- offerLast(E) - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- offerLast(E, long, TimeUnit) - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- ofField(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveHashCommands.HSetCommand
-
Applies a field.
- offset(int) - Method in class org.springframework.data.redis.connection.Limit
- offset(long) - Static method in class org.springframework.data.redis.connection.BitFieldSubCommands.Offset
-
Creates new zero based offset.
- ofMap(Map<K, V>) - Method in class org.springframework.data.redis.connection.stream.StreamRecords.RecordBuilder
-
Create a
MapRecord
. - ofObject(V) - Method in class org.springframework.data.redis.connection.stream.StreamRecords.RecordBuilder
-
Create an
ObjectRecord
. - ofStrings(Map<String, String>) - Method in class org.springframework.data.redis.connection.stream.StreamRecords.RecordBuilder
-
Create a
StringRecord
. - ON - Enum constant in enum class org.springframework.data.redis.core.RedisKeyValueAdapter.ShadowCopy
-
Store shadow copies of expiring entities.
- ON_DEMAND - Enum constant in enum class org.springframework.data.redis.core.RedisKeyValueAdapter.EnableKeyspaceEvents
-
Initializes the
KeyExpirationEventMessageListener
on first insert having expiration time set. - ON_STARTUP - Enum constant in enum class org.springframework.data.redis.core.RedisKeyValueAdapter.EnableKeyspaceEvents
-
Initializes the
KeyExpirationEventMessageListener
on startup. - onApplicationEvent(RedisKeyspaceEvent) - Method in class org.springframework.data.redis.core.RedisKeyValueAdapter
- onChannelSubscribed(byte[], long) - Method in interface org.springframework.data.redis.connection.SubscriptionListener
-
Notification when Redis has confirmed a channel subscription.
- onChannelUnsubscribed(byte[], long) - Method in interface org.springframework.data.redis.connection.SubscriptionListener
-
Notification when Redis has confirmed a channel un-subscription.
- onClose(StatefulConnection<?, ?>) - Method in interface org.springframework.data.redis.connection.lettuce.LettuceConnection.PipeliningFlushState
-
Callback if the pipeline gets closed.
- onCommand(StatefulConnection<?, ?>) - Method in interface org.springframework.data.redis.connection.lettuce.LettuceConnection.PipeliningFlushState
-
Callback for each issued Redis command.
- one() - Static method in class org.springframework.data.redis.connection.ReactiveSetCommands.SPopCommand
-
Creates a new
ReactiveSetCommands.SPopCommand
for a single member. - onErrorResume(Function<? super Throwable, ? extends Publisher<Void>>) - Method in class org.springframework.data.redis.stream.StreamReceiver.StreamReceiverOptionsBuilder
-
Configure a resume
Function
to resume the main sequence when polling the stream fails. - onKeys(Collection<ByteBuffer>) - Method in class org.springframework.data.redis.connection.ReactiveStringCommands.BitOpCommand
-
Applies the operation to keys.
- onMessage(Message, byte[]) - Method in interface org.springframework.data.redis.connection.MessageListener
-
Callback for processing received objects through Redis.
- onMessage(Message, byte[]) - Method in class org.springframework.data.redis.listener.adapter.MessageListenerAdapter
-
Standard Redis
MessageListener
entry point. - onMessage(Message, byte[]) - Method in class org.springframework.data.redis.listener.KeyspaceEventMessageListener
- onMessage(V) - Method in interface org.springframework.data.redis.stream.StreamListener
-
Callback invoked on receiving a
Record
. - onOpen(StatefulConnection<?, ?>) - Method in interface org.springframework.data.redis.connection.lettuce.LettuceConnection.PipeliningFlushState
-
Callback if the pipeline gets opened.
- onPatternSubscribed(byte[], long) - Method in interface org.springframework.data.redis.connection.SubscriptionListener
-
Notification when Redis has confirmed a pattern subscription.
- onPatternUnsubscribed(byte[], long) - Method in interface org.springframework.data.redis.connection.SubscriptionListener
-
Notification when Redis has confirmed a pattern un-subscription.
- open() - Method in class org.springframework.data.redis.core.ScanCursor
-
Initialize the
Cursor
prior to usage. - openPipeline() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- openPipeline() - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
- openPipeline() - Method in class org.springframework.data.redis.connection.jedis.JedisConnection
- openPipeline() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
- openPipeline() - Method in interface org.springframework.data.redis.connection.RedisConnection
-
Activates the pipeline mode for this connection.
- opsForCluster() - Method in interface org.springframework.data.redis.core.RedisOperations
-
Returns the cluster specific operations interface.
- opsForCluster() - Method in class org.springframework.data.redis.core.RedisTemplate
- opsForGeo() - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
-
Returns geospatial specific operations interface.
- opsForGeo() - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
- opsForGeo() - Method in interface org.springframework.data.redis.core.RedisOperations
-
Returns geospatial specific operations interface.
- opsForGeo() - Method in class org.springframework.data.redis.core.RedisTemplate
- opsForGeo(RedisSerializationContext<K, V>) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
-
Returns geospatial specific operations interface.
- opsForGeo(RedisSerializationContext<K1, V1>) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
- opsForHash() - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
-
Returns the operations performed on hash values.
- opsForHash() - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
- opsForHash() - Method in interface org.springframework.data.redis.core.RedisOperations
-
Returns the operations performed on hash values.
- opsForHash() - Method in class org.springframework.data.redis.core.RedisTemplate
- opsForHash(RedisSerializationContext<K, ?>) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
-
Returns the operations performed on hash values given a
RedisSerializationContext
. - opsForHash(RedisSerializationContext<K1, ?>) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
- opsForHyperLogLog() - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
-
Returns the operations performed on multisets using HyperLogLog.
- opsForHyperLogLog() - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
- opsForHyperLogLog() - Method in interface org.springframework.data.redis.core.RedisOperations
- opsForHyperLogLog() - Method in class org.springframework.data.redis.core.RedisTemplate
- opsForHyperLogLog(RedisSerializationContext<K, V>) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
-
Returns the operations performed on multisets using HyperLogLog given a
RedisSerializationContext
. - opsForHyperLogLog(RedisSerializationContext<K1, V1>) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
- opsForList() - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
-
Returns the operations performed on list values.
- opsForList() - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
- opsForList() - Method in interface org.springframework.data.redis.core.RedisOperations
-
Returns the operations performed on list values.
- opsForList() - Method in class org.springframework.data.redis.core.RedisTemplate
- opsForList(RedisSerializationContext<K, V>) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
-
Returns the operations performed on list values given a
RedisSerializationContext
. - opsForList(RedisSerializationContext<K1, V1>) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
- opsForSet() - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
-
Returns the operations performed on set values.
- opsForSet() - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
- opsForSet() - Method in interface org.springframework.data.redis.core.RedisOperations
-
Returns the operations performed on set values.
- opsForSet() - Method in class org.springframework.data.redis.core.RedisTemplate
- opsForSet(RedisSerializationContext<K, V>) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
-
Returns the operations performed on set values given a
RedisSerializationContext
. - opsForSet(RedisSerializationContext<K1, V1>) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
- opsForStream() - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
-
Returns the operations performed on streams.
- opsForStream() - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
- opsForStream() - Method in interface org.springframework.data.redis.core.RedisOperations
-
Returns the operations performed on Streams.
- opsForStream() - Method in class org.springframework.data.redis.core.RedisTemplate
- opsForStream(HashMapper<? super K, ? super HK, ? super HV>) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
-
Returns the operations performed on streams.
- opsForStream(HashMapper<? super K, ? super HK, ? super HV>) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
- opsForStream(HashMapper<? super K, ? super HK, ? super HV>) - Method in interface org.springframework.data.redis.core.RedisOperations
-
Returns the operations performed on Streams.
- opsForStream(HashMapper<? super K, ? super HK, ? super HV>) - Method in class org.springframework.data.redis.core.RedisTemplate
- opsForStream(RedisSerializationContext<K, ?>) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
-
Returns the operations performed on streams given a
RedisSerializationContext
. - opsForStream(RedisSerializationContext<K, ?>) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
- opsForStream(RedisSerializationContext<K, ?>, HashMapper<? super K, ? super HK, ? super HV>) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
- opsForValue() - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
-
Returns the operations performed on simple values (or Strings in Redis terminology).
- opsForValue() - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
- opsForValue() - Method in interface org.springframework.data.redis.core.RedisOperations
-
Returns the operations performed on simple values (or Strings in Redis terminology).
- opsForValue() - Method in class org.springframework.data.redis.core.RedisTemplate
- opsForValue(RedisSerializationContext<K, V>) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
-
Returns the operations performed on simple values (or Strings in Redis terminology) given a
RedisSerializationContext
. - opsForValue(RedisSerializationContext<K1, V1>) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
- opsForZSet() - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
-
Returns the operations performed on zset values (also known as sorted sets).
- opsForZSet() - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
- opsForZSet() - Method in interface org.springframework.data.redis.core.RedisOperations
-
Returns the operations performed on zset values (also known as sorted sets).
- opsForZSet() - Method in class org.springframework.data.redis.core.RedisTemplate
- opsForZSet(RedisSerializationContext<K, V>) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
-
Returns the operations performed on zset values (also known as sorted sets) given a
RedisSerializationContext
. - opsForZSet(RedisSerializationContext<K1, V1>) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
- or(RedisOperationChain, RedisOperationChain) - Method in class org.springframework.data.redis.repository.query.RedisQueryCreator
- OR - Enum constant in enum class org.springframework.data.redis.connection.RedisStringCommands.BitOperation
- OrCondition(Collection<IndexDefinition.Condition<T>>) - Constructor for class org.springframework.data.redis.core.index.RedisIndexDefinition.OrCondition
- order(SortParameters.Order) - Method in class org.springframework.data.redis.connection.DefaultSortParameters
- order(SortParameters.Order) - Method in class org.springframework.data.redis.core.query.SortQueryBuilder
- order(SortParameters.Order) - Method in interface org.springframework.data.redis.core.query.SortCriterion
- orderByDistanceAsc() - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusByMemberCommand
-
Applies ascending sort by distance.
- orderByDistanceAsc() - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusCommand
-
Applies ascending sort by distance.
- orderByDistanceDesc() - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusByMemberCommand
-
Applies descending sort by distance.
- orderByDistanceDesc() - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusCommand
-
Applies descending sort by distance.
- org.springframework.data.redis - package org.springframework.data.redis
-
Root package for integrating Redis with Spring concepts.
- org.springframework.data.redis.aot - package org.springframework.data.redis.aot
- org.springframework.data.redis.cache - package org.springframework.data.redis.cache
-
Package providing a Redis implementation for Spring cache abstraction.
- org.springframework.data.redis.config - package org.springframework.data.redis.config
-
Namespace and configuration.
- org.springframework.data.redis.connection - package org.springframework.data.redis.connection
-
Connection package providing low-level abstractions for interacting with the various Redis 'drivers'/libraries.
- org.springframework.data.redis.connection.convert - package org.springframework.data.redis.connection.convert
-
Redis specific converters used for sending data and parsing responses.
- org.springframework.data.redis.connection.jedis - package org.springframework.data.redis.connection.jedis
-
Connection package for Jedis library.
- org.springframework.data.redis.connection.lettuce - package org.springframework.data.redis.connection.lettuce
-
Connection package for Lettuce Redis client.
- org.springframework.data.redis.connection.lettuce.aot - package org.springframework.data.redis.connection.lettuce.aot
- org.springframework.data.redis.connection.lettuce.observability - package org.springframework.data.redis.connection.lettuce.observability
-
Integration of Micrometer Tracing for Lettuce Observability.
- org.springframework.data.redis.connection.stream - package org.springframework.data.redis.connection.stream
-
Data structures and interfaces to interact with Redis Streams.
- org.springframework.data.redis.connection.util - package org.springframework.data.redis.connection.util
-
Internal utility package for encoding/decoding Strings to byte[] (using Base64) library.
- org.springframework.data.redis.connection.zset - package org.springframework.data.redis.connection.zset
- org.springframework.data.redis.core - package org.springframework.data.redis.core
-
Core package for integrating Redis with Spring concepts.
- org.springframework.data.redis.core.convert - package org.springframework.data.redis.core.convert
-
Converters for Redis repository support utilizing mapping metadata.
- org.springframework.data.redis.core.index - package org.springframework.data.redis.core.index
-
Abstractions for Redis secondary indexes.
- org.springframework.data.redis.core.mapping - package org.springframework.data.redis.core.mapping
-
Redis specific repository support mapping meta information.
- org.springframework.data.redis.core.query - package org.springframework.data.redis.core.query
-
Query package for Redis template.
- org.springframework.data.redis.core.script - package org.springframework.data.redis.core.script
-
Lua script execution abstraction.
- org.springframework.data.redis.core.types - package org.springframework.data.redis.core.types
-
Redis domain specific types.
- org.springframework.data.redis.domain.geo - package org.springframework.data.redis.domain.geo
- org.springframework.data.redis.hash - package org.springframework.data.redis.hash
-
Dedicated support package for Redis hashes.
- org.springframework.data.redis.listener - package org.springframework.data.redis.listener
-
Base package for Redis message listener / pubsub container facility
- org.springframework.data.redis.listener.adapter - package org.springframework.data.redis.listener.adapter
-
Message listener adapter package.
- org.springframework.data.redis.repository.cdi - package org.springframework.data.redis.repository.cdi
-
CDI support for Redis specific repository implementation.
- org.springframework.data.redis.repository.configuration - package org.springframework.data.redis.repository.configuration
-
Redis repository specific configuration and bean registration.
- org.springframework.data.redis.repository.core - package org.springframework.data.redis.repository.core
-
Core domain entities for repository support.
- org.springframework.data.redis.repository.query - package org.springframework.data.redis.repository.query
-
Redis specific query execution engine.
- org.springframework.data.redis.repository.support - package org.springframework.data.redis.repository.support
-
Spring context specific factory support.
- org.springframework.data.redis.serializer - package org.springframework.data.redis.serializer
-
Serialization/Deserialization package for converting Object to (and from) binary data.
- org.springframework.data.redis.stream - package org.springframework.data.redis.stream
- org.springframework.data.redis.support.atomic - package org.springframework.data.redis.support.atomic
-
Small toolkit mirroring the
java.util.atomic
package in Redis. - org.springframework.data.redis.support.collections - package org.springframework.data.redis.support.collections
-
Package providing implementations for most of the
java.util
collections on top of Redis. - org.springframework.data.redis.util - package org.springframework.data.redis.util
-
Commonly used stuff for data manipulation throughout different driver specific implementations.
- ORIGINAL_DEFAULT_LISTENER_METHOD - Static variable in class org.springframework.data.redis.listener.adapter.MessageListenerAdapter
-
Out-of-the-box value for the default listener method: "handleMessage".
- orSismember(String, Object) - Method in class org.springframework.data.redis.repository.query.RedisOperationChain
- orSismember(Collection<RedisOperationChain.PathAndValue>) - Method in class org.springframework.data.redis.repository.query.RedisOperationChain
- orSismember(RedisOperationChain.PathAndValue) - Method in class org.springframework.data.redis.repository.query.RedisOperationChain
- OUTPUT_BUFFER_LENGTH - Enum constant in enum class org.springframework.data.redis.connection.RedisServer.INFO
- OUTPUT_BUFFER_LENGTH - Enum constant in enum class org.springframework.data.redis.core.types.RedisClientInfo.INFO
- OUTPUT_BUFFER_MEMORY_USAGE - Enum constant in enum class org.springframework.data.redis.core.types.RedisClientInfo.INFO
- OUTPUT_LIST_LENGTH - Enum constant in enum class org.springframework.data.redis.connection.RedisServer.INFO
- OUTPUT_LIST_LENGTH - Enum constant in enum class org.springframework.data.redis.core.types.RedisClientInfo.INFO
- overflow(BitFieldSubCommands.BitFieldIncrBy.Overflow) - Method in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldIncrByBuilder
-
Set the
BitFieldSubCommands.BitFieldIncrBy.Overflow
to be used for this and any subsequentBitFieldSubCommands.BitFieldIncrBy
commands. - overwrite(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveStringCommands.SetRangeCommand
-
Creates a new
ReactiveStringCommands.SetRangeCommand
given a key. - OxmSerializer - Class in org.springframework.data.redis.serializer
-
Serializer adapter on top of Spring's O/X Mapping.
- OxmSerializer() - Constructor for class org.springframework.data.redis.serializer.OxmSerializer
-
Creates a new, uninitialized
OxmSerializer
. - OxmSerializer(Marshaller, Unmarshaller) - Constructor for class org.springframework.data.redis.serializer.OxmSerializer
P
- PARALLEL_SYNCS - Enum constant in enum class org.springframework.data.redis.connection.RedisServer.INFO
- parse(Object, Class<T>) - Static method in class org.springframework.data.redis.connection.convert.Converters
-
Parse a rather generic Redis response, such as a list of something into a meaningful structure applying best effort conversion of
byte[]
andByteBuffer
. - parse(Object, String, Map<String, Class<?>>) - Static method in class org.springframework.data.redis.connection.convert.Converters
-
Parse a rather generic Redis response, such as a list of something into a meaningful structure applying best effort conversion of
byte[]
andByteBuffer
based on the sourcePath and a typeHintMap - PartialUpdate<T> - Class in org.springframework.data.redis.core
-
PartialUpdate
allows to issue individual property updates without the need of rewriting the whole entity. - PartialUpdate(Object, Class<T>) - Constructor for class org.springframework.data.redis.core.PartialUpdate
-
Create new
PartialUpdate
for given id and type. - PartialUpdate(Object, T) - Constructor for class org.springframework.data.redis.core.PartialUpdate
-
Create new
PartialUpdate
for given id and object. - PartialUpdate.PropertyUpdate - Class in org.springframework.data.redis.core
- PartialUpdate.UpdateCommand - Enum Class in org.springframework.data.redis.core
- partitionsToClusterNodes(Partitions) - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
- PassThroughExceptionTranslationStrategy - Class in org.springframework.data.redis
-
PassThroughExceptionTranslationStrategy
returns null for unknownException
s. - PassThroughExceptionTranslationStrategy(Converter<Exception, DataAccessException>) - Constructor for class org.springframework.data.redis.PassThroughExceptionTranslationStrategy
- PathAndValue(String, Object) - Constructor for class org.springframework.data.redis.repository.query.RedisOperationChain.PathAndValue
- PathAndValue(String, Collection<Object>) - Constructor for class org.springframework.data.redis.repository.query.RedisOperationChain.PathAndValue
- PathBasedRedisIndexDefinition - Interface in org.springframework.data.redis.core.index
-
IndexDefinition
that is based on a property paths. - PathCondition(String) - Constructor for class org.springframework.data.redis.core.index.RedisIndexDefinition.PathCondition
- PathIndexResolver - Class in org.springframework.data.redis.core.convert
-
IndexResolver
implementation considering properties annotated withIndexed
or paths set up inIndexConfiguration
. - PathIndexResolver() - Constructor for class org.springframework.data.redis.core.convert.PathIndexResolver
-
Creates new
PathIndexResolver
with emptyIndexConfiguration
. - PathIndexResolver(RedisMappingContext) - Constructor for class org.springframework.data.redis.core.convert.PathIndexResolver
-
Creates new
PathIndexResolver
with givenIndexConfiguration
. - PATTERN_SUBSCRIBTIONS - Enum constant in enum class org.springframework.data.redis.core.types.RedisClientInfo.INFO
- PatternMessage(P, C, M) - Constructor for class org.springframework.data.redis.connection.ReactiveSubscription.PatternMessage
-
Create a new
ReactiveSubscription.PatternMessage
. - PatternTopic - Class in org.springframework.data.redis.listener
- PatternTopic(String) - Constructor for class org.springframework.data.redis.listener.PatternTopic
-
Constructs a new
PatternTopic
instance. - peek() - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- peekFirst() - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- peekLast() - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- pending(K, String) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
-
Obtain the
PendingMessagesSummary
for a given consumer group. - pending(K, String) - Method in interface org.springframework.data.redis.core.StreamOperations
-
Obtain the
PendingMessagesSummary
for a given consumer group. - pending(K, String, Range<?>, long) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
- pending(K, String, Range<?>, long) - Method in interface org.springframework.data.redis.core.StreamOperations
- pending(K, Consumer) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
-
Obtained detailed information about all pending messages for a given
Consumer
. - pending(K, Consumer) - Method in interface org.springframework.data.redis.core.StreamOperations
-
Obtained detailed information about all pending messages for a given
Consumer
. - pending(K, Consumer, Range<?>, long) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
- pending(K, Consumer, Range<?>, long) - Method in interface org.springframework.data.redis.core.StreamOperations
- PENDING_COMMANDS - Enum constant in enum class org.springframework.data.redis.connection.RedisServer.INFO
- pendingCount() - Method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoConsumer
-
The number of pending messages.
- pendingCount() - Method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoGroup
-
The total number of pending messages in the consumer group.
- PendingMessage - Class in org.springframework.data.redis.connection.stream
-
Value object representing a single pending message containing its ID, the consumer that fetched the message and has still to acknowledge it, the time elapsed since the messages last delivery and the the total number of times delivered.
- PendingMessage(RecordId, Consumer, Duration, long) - Constructor for class org.springframework.data.redis.connection.stream.PendingMessage
- PendingMessages - Class in org.springframework.data.redis.connection.stream
-
Value object holding detailed information about pending messages in consumer group for a given
Range
and offset. - PendingMessages(String, List<PendingMessage>) - Constructor for class org.springframework.data.redis.connection.stream.PendingMessages
- PendingMessages(String, Range<?>, List<PendingMessage>) - Constructor for class org.springframework.data.redis.connection.stream.PendingMessages
- PendingMessagesSummary - Class in org.springframework.data.redis.connection.stream
-
Value Object summarizing pending messages in a consumer group.
- PendingMessagesSummary(String, long, Range<String>, Map<String, Long>) - Constructor for class org.springframework.data.redis.connection.stream.PendingMessagesSummary
- perform(RedisStringCommands.BitOperation) - Static method in class org.springframework.data.redis.connection.ReactiveStringCommands.BitOpCommand
-
Creates a new
ReactiveStringCommands.BitOpCommand
given aRedisStringCommands.BitOperation
. - persist() - Method in interface org.springframework.data.redis.core.BoundKeyOperations
-
Removes the expiration (if any) of the key.
- persist() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicDouble
- persist() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicInteger
- persist() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicLong
- persist() - Method in class org.springframework.data.redis.support.collections.AbstractRedisCollection
- persist() - Method in class org.springframework.data.redis.support.collections.DefaultRedisMap
- persist() - Method in class org.springframework.data.redis.support.collections.RedisProperties
- persist(byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.keyCommands()
. - persist(byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- persist(byte[]) - Method in interface org.springframework.data.redis.connection.RedisKeyCommands
-
Remove the expiration from given
key
. - persist(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- persist(String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Remove the expiration from given
key
. - persist(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
-
Remove the expiration from given
key
. - persist(K) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
-
Remove the expiration from given
key
. - persist(K) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
- persist(K) - Method in interface org.springframework.data.redis.core.RedisOperations
-
Remove the expiration from given
key
. - persist(K) - Method in class org.springframework.data.redis.core.RedisTemplate
- persist(Publisher<ReactiveRedisConnection.KeyCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
-
Remove one-by-one the expiration from given
key
. - PERSIST - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- persistent() - Static method in interface org.springframework.data.redis.cache.RedisCacheWriter.TtlFunction
-
Returns a
RedisCacheWriter.TtlFunction
to create persistent entires that do not expire. - persistent() - Static method in class org.springframework.data.redis.core.types.Expiration
-
Creates a new persistent, non-expiring
Expiration
. - pExpire(byte[], long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.keyCommands()
. - pExpire(byte[], long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- pExpire(byte[], long) - Method in interface org.springframework.data.redis.connection.RedisKeyCommands
-
Set time to live for given
key
in milliseconds. - pExpire(String, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- pExpire(String, long) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Set time to live for given
key
in milliseconds. - pExpire(ByteBuffer, Duration) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
-
Set time to live for given
key
in milliseconds. - pExpire(Publisher<ReactiveKeyCommands.ExpireCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
-
Expire keys one by one.
- PEXPIRE - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- pExpireAt(byte[], long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.keyCommands()
. - pExpireAt(byte[], long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- pExpireAt(byte[], long) - Method in interface org.springframework.data.redis.connection.RedisKeyCommands
-
Set the expiration for given
key
as a UNIX timestamp in milliseconds. - pExpireAt(String, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- pExpireAt(String, long) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Set the expiration for given
key
as a UNIX timestamp in milliseconds. - pExpireAt(ByteBuffer, Instant) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
-
Set the expiration for given
key
as a UNIX timestamp. - pExpireAt(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 in milliseconds. - PEXPIREAT - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- pfAdd(byte[], byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.hyperLogLogCommands()
. - pfAdd(byte[], byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- pfAdd(byte[], byte[]...) - Method in interface org.springframework.data.redis.connection.RedisHyperLogLogCommands
-
Adds given values to the HyperLogLog stored at given key.
- pfAdd(String, String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- pfAdd(String, String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Adds given values to the HyperLogLog stored at given key.
- pfAdd(ByteBuffer, ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveHyperLogLogCommands
-
Adds given value to the HyperLogLog stored at given key.
- pfAdd(ByteBuffer, Collection<ByteBuffer>) - Method in interface org.springframework.data.redis.connection.ReactiveHyperLogLogCommands
-
Adds given values to the HyperLogLog stored at given key.
- pfAdd(Publisher<ReactiveHyperLogLogCommands.PfAddCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveHyperLogLogCommands
-
Adds given values to the HyperLogLog stored at given key.
- PFAIL - Enum constant in enum class org.springframework.data.redis.connection.RedisClusterNode.Flag
- pfCount(byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.hyperLogLogCommands()
. - pfCount(byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- pfCount(byte[]...) - Method in interface org.springframework.data.redis.connection.RedisHyperLogLogCommands
-
Return the approximated cardinality of the structures observed by the HyperLogLog at key(s).
- pfCount(String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- pfCount(String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Return the approximated cardinality of the structures observed by the HyperLogLog at key(s).
- pfCount(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveHyperLogLogCommands
-
Return the approximated cardinality of the structures observed by the HyperLogLog at key.
- pfCount(Collection<ByteBuffer>) - Method in interface org.springframework.data.redis.connection.ReactiveHyperLogLogCommands
-
Return the approximated cardinality of the structures observed by the HyperLogLog at key(s).
- pfCount(Publisher<ReactiveHyperLogLogCommands.PfCountCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveHyperLogLogCommands
-
Return the approximated cardinality of the structures observed by the HyperLogLog at key(s).
- pfMerge(byte[], byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.hyperLogLogCommands()
. - pfMerge(byte[], byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- pfMerge(byte[], byte[]...) - Method in interface org.springframework.data.redis.connection.RedisHyperLogLogCommands
-
Merge N different HyperLogLogs at sourceKeys into a single destinationKey.
- pfMerge(String, String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- pfMerge(String, String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Merge N different HyperLogLogs at sourceKeys into a single destinationKey.
- pfMerge(ByteBuffer, Collection<ByteBuffer>) - Method in interface org.springframework.data.redis.connection.ReactiveHyperLogLogCommands
-
Merge N different HyperLogLogs at sourceKeys into a single destinationKey.
- pfMerge(Publisher<ReactiveHyperLogLogCommands.PfMergeCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveHyperLogLogCommands
-
Merge N different HyperLogLogs at sourceKeys into a single destinationKey.
- PHANTOM - Static variable in class org.springframework.data.redis.core.convert.MappingRedisConverter.BinaryKeyspaceIdentifier
- PHANTOM - Static variable in class org.springframework.data.redis.core.convert.MappingRedisConverter.KeyspaceIdentifier
- PHANTOM_SUFFIX - Static variable in class org.springframework.data.redis.core.convert.MappingRedisConverter.BinaryKeyspaceIdentifier
- PHANTOM_SUFFIX - Static variable in class org.springframework.data.redis.core.convert.MappingRedisConverter.KeyspaceIdentifier
- ping() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- ping() - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
- ping() - Method in class org.springframework.data.redis.connection.jedis.JedisConnection
- ping() - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
- ping() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
- ping() - Method in interface org.springframework.data.redis.connection.ReactiveRedisConnection
-
Test connection.
- ping() - Method in interface org.springframework.data.redis.connection.RedisConnectionCommands
-
Test connection.
- ping(RedisClusterNode) - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
- ping(RedisClusterNode) - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
- ping(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.ReactiveRedisClusterConnection
-
Test the connection to a specific Redis cluster node.
- ping(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.RedisClusterConnection
- ping(RedisClusterNode) - Method in interface org.springframework.data.redis.core.ClusterOperations
-
Ping the given node;
- PING - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- PLUS_BYTES - Static variable in class org.springframework.data.redis.connection.lettuce.LettuceConverters
- poll() - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- poll(long, TimeUnit) - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- pollFirst() - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- pollFirst(long, TimeUnit) - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- pollLast() - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- pollLast(long, TimeUnit) - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- pollTimeout(Duration) - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamMessageListenerContainerOptionsBuilder
-
Configure a poll timeout for the
BLOCK
option during reading. - pollTimeout(Duration) - Method in class org.springframework.data.redis.stream.StreamReceiver.StreamReceiverOptionsBuilder
-
Configure a poll timeout for the
BLOCK
option during reading. - poolConfig(GenericObjectPoolConfig) - Method in class org.springframework.data.redis.connection.jedis.JedisClientConfiguration.DefaultJedisClientConfigurationBuilder
- poolConfig(GenericObjectPoolConfig) - Method in interface org.springframework.data.redis.connection.jedis.JedisClientConfiguration.JedisPoolingClientConfigurationBuilder
- poolConfig(GenericObjectPoolConfig) - Method in class org.springframework.data.redis.connection.lettuce.LettucePoolingClientConfiguration.LettucePoolingClientConfigurationBuilder
-
Set the
GenericObjectPoolConfig
used by the driver. - PoolException - Exception in org.springframework.data.redis.connection
-
Exception thrown when there are issues with a resource pool
- PoolException(String) - Constructor for exception org.springframework.data.redis.connection.PoolException
-
Constructs a new
PoolException
instance. - PoolException(String, Throwable) - Constructor for exception org.springframework.data.redis.connection.PoolException
-
Constructs a new
PoolException
instance. - pop() - Method in interface org.springframework.data.redis.core.BoundSetOperations
-
Remove and return a random member from set at the bound key.
- pop() - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- pop(K) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
-
Remove and return a random member from set at
key
. - pop(K) - Method in interface org.springframework.data.redis.core.SetOperations
-
Remove and return a random member from set at
key
. - pop(K, long) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
-
Remove and return
count
random members from set atkey
. - pop(K, long) - Method in interface org.springframework.data.redis.core.SetOperations
-
Remove and return
count
random members from set atkey
. - pop(Publisher<ReactiveListCommands.PopCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveListCommands
-
Removes and returns last element in list stored at
ReactiveRedisConnection.KeyCommand.getKey()
- popFirst() - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
- popFirst() - Method in interface org.springframework.data.redis.support.collections.RedisZSet
-
Removes the first (lowest) object at the top of this sorted set and returns that object as the value of this function.
- popFirst(long, TimeUnit) - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
- popFirst(long, TimeUnit) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
-
Removes the first (lowest) object at the top of this sorted set and returns that object as the value of this function.
- popLast() - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
- popLast() - Method in interface org.springframework.data.redis.support.collections.RedisZSet
-
Removes the last (highest) object at the top of this sorted set and returns that object as the value of this function.
- popLast(long, TimeUnit) - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
- popLast(long, TimeUnit) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
-
Removes the last (highest) object at the top of this sorted set and returns that object as the value of this function.
- popList(Publisher<ReactiveListCommands.PopCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveListCommands
-
Removes and returns last element in list stored at
ReactiveRedisConnection.KeyCommand.getKey()
- popMax() - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Remove and return the value with its score having the highest score from sorted set at the bound key.
- popMax(long) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Remove and return
count
values with their score having the highest score from sorted set at the bound key. - popMax(long, TimeUnit) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Remove and return the value with its score having the highest score from sorted set at the bound key.
- popMax(Duration) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Remove and return the value with its score having the highest score from sorted set at the bound key.
- popMax(K) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Remove and return the value with its score having the highest score from sorted set at
key
. - popMax(K) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Remove and return the value with its score having the highest score from sorted set at
key
. - popMax(K, long) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Remove and return
count
values with their score having the highest score from sorted set atkey
. - popMax(K, long) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Remove and return
count
values with their score having the highest score from sorted set atkey
. - popMax(K, long, TimeUnit) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Remove and return the value with its score having the highest score from sorted set at
key
. - popMax(K, Duration) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Remove and return the value with its score having the highest score from sorted set at
key
. - popMax(K, Duration) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Remove and return the value with its score having the highest score from sorted set at
key
. - popMin() - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Remove and return the value with its score having the lowest score from sorted set at the bound key.
- popMin(long) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Remove and return
count
values with their score having the lowest score from sorted set at the bound key. - popMin(long, TimeUnit) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Remove and return the value with its score having the lowest score from sorted set at the bound key.
- popMin(Duration) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Remove and return the value with its score having the lowest score from sorted set at the bound key.
- popMin(K) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Remove and return the value with its score having the lowest score from sorted set at
key
. - popMin(K) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Remove and return the value with its score having the lowest score from sorted set at
key
. - popMin(K, long) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Remove and return
count
values with their score having the lowest score from sorted set atkey
. - popMin(K, long) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Remove and return
count
values with their score having the lowest score from sorted set atkey
. - popMin(K, long, TimeUnit) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Remove and return the value with its score having the lowest score from sorted set at
key
. - popMin(K, Duration) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Remove and return the value with its score having the lowest score from sorted set at
key
. - popMin(K, Duration) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Remove and return the value with its score having the lowest score from sorted set at
key
. - PopResponse(ReactiveListCommands.BPopCommand, ReactiveListCommands.PopResult) - Constructor for class org.springframework.data.redis.connection.ReactiveListCommands.PopResponse
- PopResult(List<ByteBuffer>) - Constructor for class org.springframework.data.redis.connection.ReactiveListCommands.PopResult
- PORT - Enum constant in enum class org.springframework.data.redis.connection.RedisServer.INFO
- position(K, M) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
-
Get the
Point
representation of positions for one or more members. - position(K, M...) - Method in interface org.springframework.data.redis.core.GeoOperations
-
Get the
Point
representation of positions for one or more members. - position(K, M...) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
-
Get the
Point
representation of positions for one or more members. - position(M...) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
-
Get the
Point
representation of positions for one or more members. - POSITIVE_INFINITY_BYTES - Static variable in class org.springframework.data.redis.connection.lettuce.LettuceConverters
- postProcessConnection(JedisClusterConnection) - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
-
Post process a newly retrieved connection.
- postProcessConnection(JedisConnection) - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
-
Post process a newly retrieved connection.
- postProcessResult(Publisher<T>, ReactiveRedisConnection, boolean) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
-
Processes the result before returning the
Publisher
. - postProcessResult(T, RedisConnection, boolean) - Method in class org.springframework.data.redis.core.RedisTemplate
- prefixCacheNameWith(String) - Method in class org.springframework.data.redis.cache.RedisCacheConfiguration
-
Prefix the
cache name
with the given value. - prefixed(String) - Static method in interface org.springframework.data.redis.cache.CacheKeyPrefix
-
Creates a
CacheKeyPrefix
scheme that prefixes cache keys with the givenprefix
. - preProcessCacheValue(Object) - Method in class org.springframework.data.redis.cache.RedisCache
-
Customization hook called before passing object to
RedisSerializer
. - preProcessConnection(ReactiveRedisConnection, boolean) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
-
Processes the connection (before any settings are executed on it).
- preProcessConnection(RedisConnection, boolean) - Method in class org.springframework.data.redis.core.RedisTemplate
-
Processes the connection (before any settings are executed on it).
- preProcessConnection(RedisConnection, boolean) - Method in class org.springframework.data.redis.core.StringRedisTemplate
- processMessage(MessageListener, Message, byte[]) - Method in class org.springframework.data.redis.listener.RedisMessageListenerContainer
-
Process a message received from the provider.
- promotedAs(RedisNode.NodeType) - Method in class org.springframework.data.redis.connection.RedisClusterNode.RedisClusterNodeBuilder
- promotedAs(RedisNode.NodeType) - Method in class org.springframework.data.redis.connection.RedisNode.RedisNodeBuilder
-
Set server role.
- PROPERTIES - Enum constant in enum class org.springframework.data.redis.support.collections.RedisCollectionFactoryBean.CollectionType
- propertyNames() - Method in class org.springframework.data.redis.support.collections.RedisProperties
- pSetEx(byte[], long, byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.stringCommands()
}. - pSetEx(byte[], long, byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- pSetEx(byte[], long, byte[]) - Method in interface org.springframework.data.redis.connection.RedisStringCommands
-
Set the
value
and expiration inmilliseconds
forkey
. - pSetEx(String, long, String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- pSetEx(String, long, String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Set the
value
and expiration inmilliseconds
forkey
. - pSetEX(ByteBuffer, ByteBuffer, Expiration) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
-
Set key value pair and
Expiration
. - pSetEX(Publisher<ReactiveStringCommands.SetCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
-
Set key value pairs and
Expiration
. - PSETEX - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- pSubscribe(byte[]...) - Method in interface org.springframework.data.redis.connection.Subscription
-
Adds the given channel patterns to the current subscription.
- pSubscribe(byte[]...) - Method in class org.springframework.data.redis.connection.util.AbstractSubscription
- pSubscribe(ByteBuffer...) - Method in interface org.springframework.data.redis.connection.ReactivePubSubCommands
-
Subscribes the connection to all channels matching the given
patterns
. - pSubscribe(ByteBuffer...) - Method in interface org.springframework.data.redis.connection.ReactiveSubscription
-
Subscribes to the channel
patterns
and adds these to the current subscription. - pSubscribe(MessageListener, byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- pSubscribe(MessageListener, byte[]...) - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
- pSubscribe(MessageListener, byte[]...) - Method in class org.springframework.data.redis.connection.jedis.JedisConnection
- pSubscribe(MessageListener, byte[]...) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
- pSubscribe(MessageListener, byte[]...) - Method in interface org.springframework.data.redis.connection.RedisPubSubCommands
-
Subscribes the connection to all channels matching the given patterns.
- pSubscribe(MessageListener, String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- pSubscribe(MessageListener, String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Subscribes the connection to all channels matching the given patterns.
- PSUBSCRIBE - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- pTtl(byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.keyCommands()
. - pTtl(byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- pTtl(byte[]) - Method in interface org.springframework.data.redis.connection.RedisKeyCommands
-
Get the precise time to live for
key
in milliseconds. - pTtl(byte[], TimeUnit) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.keyCommands()
. - pTtl(byte[], TimeUnit) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- pTtl(byte[], TimeUnit) - Method in interface org.springframework.data.redis.connection.RedisKeyCommands
-
Get the precise time to live for
key
in and convert it to the givenTimeUnit
. - pTtl(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- pTtl(String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get the precise time to live for
key
in milliseconds. - pTtl(String, TimeUnit) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- pTtl(String, TimeUnit) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get the precise time to live for
key
in and convert it to the givenTimeUnit
. - pTtl(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
-
Get the time to live for
key
in milliseconds. - pTtl(Publisher<ReactiveRedisConnection.KeyCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
-
Get one-by-one the time to live for keys.
- PTTL - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- publish(byte[], byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- publish(byte[], byte[]) - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
- publish(byte[], byte[]) - Method in class org.springframework.data.redis.connection.jedis.JedisConnection
- publish(byte[], byte[]) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
- publish(byte[], byte[]) - Method in interface org.springframework.data.redis.connection.RedisPubSubCommands
-
Publishes the given message to the given channel.
- publish(String, String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- publish(String, String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Publishes the given message to the given channel.
- publish(ByteBuffer, ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactivePubSubCommands
-
Publishes the given
message
to the givenchannel
. - publish(Publisher<ReactiveSubscription.ChannelMessage<ByteBuffer, ByteBuffer>>) - Method in interface org.springframework.data.redis.connection.ReactivePubSubCommands
-
Publishes the given messages to the
appropriate channels
. - publishEvent(RedisKeyExpiredEvent) - Method in class org.springframework.data.redis.listener.KeyExpirationEventMessageListener
-
Publish the event in case an
ApplicationEventPublisher
is set. - pubSubCommands() - Method in interface org.springframework.data.redis.connection.ReactiveRedisConnection
- pUnsubscribe() - Method in interface org.springframework.data.redis.connection.ReactiveSubscription
-
Cancels the subscription for all channels matched by
ReactiveSubscription.getPatterns()
patterns}. - pUnsubscribe() - Method in interface org.springframework.data.redis.connection.Subscription
-
Cancels the subscription for all channels matched by patterns.
- pUnsubscribe() - Method in class org.springframework.data.redis.connection.util.AbstractSubscription
- pUnsubscribe(byte[]...) - Method in interface org.springframework.data.redis.connection.Subscription
-
Cancels the subscription for all channels matching the given patterns.
- pUnsubscribe(byte[]...) - Method in class org.springframework.data.redis.connection.util.AbstractSubscription
- pUnsubscribe(ByteBuffer...) - Method in interface org.springframework.data.redis.connection.ReactiveSubscription
-
Cancels the subscription for all channels matching the given patterns.
- push(E) - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- push(Publisher<ReactiveListCommands.PushCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveListCommands
- put(E) - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- put(HK, HV) - Method in interface org.springframework.data.redis.core.BoundHashOperations
-
Set the
value
of a hashkey
at the bound key. - put(H, HK, HV) - Method in interface org.springframework.data.redis.core.HashOperations
-
Set the
value
of a hashhashKey
. - put(H, HK, HV) - Method in interface org.springframework.data.redis.core.ReactiveHashOperations
-
Set the
value
of a hashhashKey
. - put(Object, Object) - Method in class org.springframework.data.redis.cache.RedisCache
- put(Object, Object) - Method in class org.springframework.data.redis.support.collections.RedisProperties
- put(Object, Object, String) - Method in class org.springframework.data.redis.core.RedisKeyValueAdapter
- put(String, byte[]) - Method in class org.springframework.data.redis.core.convert.Bucket.BucketPropertyPath
-
Write a
value
atkey
considering top-level/nesting. - put(String, byte[]) - Method in class org.springframework.data.redis.core.convert.Bucket
-
Add
String
representation of property dot path with given value. - put(String, byte[], byte[], Duration) - Method in interface org.springframework.data.redis.cache.RedisCacheWriter
-
Write the given key/value pair to Redis and set the expiration time if defined.
- put(K, V) - Method in class org.springframework.data.redis.support.collections.DefaultRedisMap
- putAll(H, Map<? extends HK, ? extends HV>) - Method in interface org.springframework.data.redis.core.HashOperations
-
Set multiple hash fields to multiple values using data provided in
m
. - putAll(H, Map<? extends HK, ? extends HV>) - Method in interface org.springframework.data.redis.core.ReactiveHashOperations
-
Set multiple hash fields to multiple values using data provided in
m
. - putAll(Map<? extends HK, ? extends HV>) - Method in interface org.springframework.data.redis.core.BoundHashOperations
-
Set multiple hash fields to multiple values using data provided in
m
at the bound key. - putAll(Map<? extends Object, ? extends Object>) - Method in class org.springframework.data.redis.support.collections.RedisProperties
- putAll(Map<? extends K, ? extends V>) - Method in class org.springframework.data.redis.support.collections.DefaultRedisMap
- putFirst(E) - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- putIfAbsent(HK, HV) - Method in interface org.springframework.data.redis.core.BoundHashOperations
-
Set the
value
of a hashkey
only ifkey
does not exist. - putIfAbsent(H, HK, HV) - Method in interface org.springframework.data.redis.core.HashOperations
-
Set the
value
of a hashhashKey
only ifhashKey
does not exist. - putIfAbsent(H, HK, HV) - Method in interface org.springframework.data.redis.core.ReactiveHashOperations
-
Set the
value
of a hashhashKey
only ifhashKey
does not exist. - putIfAbsent(Object, Object) - Method in class org.springframework.data.redis.cache.RedisCache
- putIfAbsent(Object, Object) - Method in class org.springframework.data.redis.support.collections.RedisProperties
- putIfAbsent(String, byte[], byte[], Duration) - Method in interface org.springframework.data.redis.cache.RedisCacheWriter
-
Write the given value to Redis if the key does not already exist.
- putIfAbsent(K, V) - Method in class org.springframework.data.redis.support.collections.DefaultRedisMap
- putLast(E) - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
Q
- QueryByExampleRedisExecutor<T> - Class in org.springframework.data.redis.repository.support
-
Repository fragment implementing Redis
Query-by-Example
operations. - QueryByExampleRedisExecutor(EntityInformation<T, ?>, RedisKeyValueTemplate) - Constructor for class org.springframework.data.redis.repository.support.QueryByExampleRedisExecutor
- QueryByExampleRedisExecutor(EntityInformation<T, ?>, RedisKeyValueTemplate, IndexResolver) - Constructor for class org.springframework.data.redis.repository.support.QueryByExampleRedisExecutor
- queryLookupStrategy() - Element in annotation interface org.springframework.data.redis.repository.configuration.EnableRedisRepositories
-
Returns the key of the
QueryLookupStrategy
to be used for lookup queries for query methods. - QueryUtils - Class in org.springframework.data.redis.core.query
-
Utilities for
SortQuery
implementations. - QueryUtils() - Constructor for class org.springframework.data.redis.core.query.QueryUtils
- QUIT - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- QUORUM - Enum constant in enum class org.springframework.data.redis.connection.RedisServer.INFO
R
- radius(K, M, double) - Method in interface org.springframework.data.redis.core.GeoOperations
-
Get the members within the circle defined by the members coordinates and given radius.
- radius(K, M, double) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
-
Get the members within the circle defined by the members coordinates and given radius.
- radius(K, M, Distance) - Method in interface org.springframework.data.redis.core.GeoOperations
-
Get the members within the circle defined by the members coordinates and given radius applying
Metric
. - radius(K, M, Distance) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
-
Get the members within the circle defined by the members coordinates and given radius applying
Metric
. - radius(K, M, Distance, RedisGeoCommands.GeoRadiusCommandArgs) - Method in interface org.springframework.data.redis.core.GeoOperations
-
Get the members within the circle defined by the members coordinates and given radius applying
Metric
andRedisGeoCommands.GeoRadiusCommandArgs
. - radius(K, M, Distance, RedisGeoCommands.GeoRadiusCommandArgs) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
-
Get the members within the circle defined by the members coordinates and given radius applying
Metric
andRedisGeoCommands.GeoRadiusCommandArgs
. - radius(K, Circle) - Method in interface org.springframework.data.redis.core.GeoOperations
-
Get the members within the boundaries of a given
Circle
. - radius(K, Circle) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
-
Get the members within the boundaries of a given
Circle
. - radius(K, Circle, RedisGeoCommands.GeoRadiusCommandArgs) - Method in interface org.springframework.data.redis.core.GeoOperations
-
Get the members within the boundaries of a given
Circle
applyingRedisGeoCommands.GeoRadiusCommandArgs
. - radius(K, Circle, RedisGeoCommands.GeoRadiusCommandArgs) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
-
Get the members within the boundaries of a given
Circle
applyingRedisGeoCommands.GeoRadiusCommandArgs
. - radius(M, double) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
-
Get the members within the circle defined by the members coordinates and given radius.
- radius(M, Distance) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
-
Get the members within the circle defined by the members coordinates and given radius applying
Metric
. - radius(M, Distance, RedisGeoCommands.GeoRadiusCommandArgs) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
-
Get the members within the circle defined by the members coordinates and given radius applying
Metric
andRedisGeoCommands.GeoRadiusCommandArgs
. - radius(Circle) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
-
Get the members within the boundaries of a given
Circle
. - radius(Circle, RedisGeoCommands.GeoRadiusCommandArgs) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
-
Get the members within the boundaries of a given
Circle
applyingRedisGeoCommands.GeoRadiusCommandArgs
. - RadiusShape - Class in org.springframework.data.redis.domain.geo
-
Radius defined by
Distance
. - RadiusShape(Distance) - Constructor for class org.springframework.data.redis.domain.geo.RadiusShape
- radixTreeKeySize() - Method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoStream
-
The streams radix tree key size.
- radixTreeNodesSize() - Method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoStream
-
Total number of element radix tree nodes.
- randomEntries(long) - Method in interface org.springframework.data.redis.core.BoundHashOperations
-
Return a random entry from the hash stored at the bound key.
- randomEntries(H, long) - Method in interface org.springframework.data.redis.core.HashOperations
-
Return a random entries from the hash stored at
key
. - randomEntries(H, long) - Method in interface org.springframework.data.redis.core.ReactiveHashOperations
-
Return random entries from the hash stored at
key
. - randomEntry() - Method in interface org.springframework.data.redis.core.BoundHashOperations
-
Return a random entry from the hash stored at the bound key.
- randomEntry() - Method in class org.springframework.data.redis.support.collections.DefaultRedisMap
- randomEntry() - Method in interface org.springframework.data.redis.support.collections.RedisMap
-
Get a random entry from the hash.
- randomEntry() - Method in class org.springframework.data.redis.support.collections.RedisProperties
- randomEntry(H) - Method in interface org.springframework.data.redis.core.HashOperations
-
Return a random entry from the hash stored at
key
. - randomEntry(H) - Method in interface org.springframework.data.redis.core.ReactiveHashOperations
-
Return a random entry from the hash stored at
key
. - randomKey() - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.keyCommands()
. - randomKey() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- randomKey() - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
-
Return a random key from the keyspace.
- randomKey() - Method in interface org.springframework.data.redis.connection.RedisKeyCommands
-
Return a random key from the keyspace.
- randomKey() - Method in interface org.springframework.data.redis.core.BoundHashOperations
-
Return a random key (aka field) from the hash stored at the bound key.
- randomKey() - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
-
Return a random key from the keyspace.
- randomKey() - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
- randomKey() - Method in interface org.springframework.data.redis.core.RedisOperations
-
Return a random key from the keyspace.
- randomKey() - Method in class org.springframework.data.redis.core.RedisTemplate
- randomKey() - Method in class org.springframework.data.redis.support.collections.DefaultRedisMap
- randomKey() - Method in interface org.springframework.data.redis.support.collections.RedisMap
-
Get a random key from the hash.
- randomKey() - Method in class org.springframework.data.redis.support.collections.RedisProperties
- randomKey(H) - Method in interface org.springframework.data.redis.core.HashOperations
-
Return a random hash key (aka field) from the hash stored at
key
. - randomKey(H) - Method in interface org.springframework.data.redis.core.ReactiveHashOperations
-
Return a random hash key (aka field) from the hash stored at
key
. - randomKey(RedisClusterNode) - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
- randomKey(RedisClusterNode) - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
- randomKey(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.ReactiveClusterKeyCommands
-
Retrieve a random key from
RedisNode
. - randomKey(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.RedisClusterConnection
- randomKey(RedisClusterNode) - Method in interface org.springframework.data.redis.core.ClusterOperations
-
Get a random key from the range served by the given node.
- RANDOMKEY - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- randomKeys(long) - Method in interface org.springframework.data.redis.core.BoundHashOperations
-
Return a random keys (aka fields) from the hash stored at the bound key.
- randomKeys(H, long) - Method in interface org.springframework.data.redis.core.HashOperations
-
Return random hash keys (aka fields) from the hash stored at
key
. - randomKeys(H, long) - Method in interface org.springframework.data.redis.core.ReactiveHashOperations
-
Return random hash keys (aka fields) from the hash stored at
key
. - randomMember() - Method in interface org.springframework.data.redis.core.BoundSetOperations
-
Get random element from set at the bound key.
- randomMember() - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Get random element from set at the bound key.
- randomMember(K) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
-
Get random element from set at
key
. - randomMember(K) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Get random element from set at
key
. - randomMember(K) - Method in interface org.springframework.data.redis.core.SetOperations
-
Get random element from set at
key
. - randomMember(K) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Get random element from set at
key
. - randomMembers(long) - Method in interface org.springframework.data.redis.core.BoundSetOperations
-
Get
count
random elements from set at the bound key. - randomMembers(long) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Get
count
random elements from set at the bound key. - randomMembers(K, long) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
-
Get
count
random elements from set atkey
. - randomMembers(K, long) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Get
count
random elements from set atkey
. - randomMembers(K, long) - Method in interface org.springframework.data.redis.core.SetOperations
-
Get
count
random elements from set atkey
. - randomMembers(K, long) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Get
count
random elements from set atkey
. - randomMembersWithScore(long) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Get
count
random elements with their score from set at the bound key. - randomMembersWithScore(K, long) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Get
count
random elements with their score from set atkey
. - randomMembersWithScore(K, long) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Get
count
random elements with their score from set atkey
. - randomMemberWithScore() - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Get random element with its score from set at the bound key.
- randomMemberWithScore(K) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Get random element with its score from set at
key
. - randomMemberWithScore(K) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Get random element with its score from set at
key
. - randomValue() - Method in class org.springframework.data.redis.support.collections.DefaultRedisSet
- randomValue() - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
- randomValue() - Method in interface org.springframework.data.redis.support.collections.RedisSet
-
Get random element from the set.
- randomValue() - Method in interface org.springframework.data.redis.support.collections.RedisZSet
-
Get random element from the set.
- range() - Static method in class org.springframework.data.redis.connection.RedisZSetCommands.Range
-
Deprecated.
- range(long, long) - Method in interface org.springframework.data.redis.core.BoundListOperations
-
Get elements between
begin
andend
from list at the bound key. - range(long, long) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Get elements between
start
andend
from sorted set. - range(long, long) - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- range(long, long) - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
- range(long, long) - Method in interface org.springframework.data.redis.support.collections.RedisList
-
Get elements between
start
andend
from list at the bound key. - range(long, long) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
-
Get elements between
start
andend
from sorted set. - range(Class<V>, K, Range<String>) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
-
Read all records from a stream within a specific
Range
. - range(Class<V>, K, Range<String>) - Method in interface org.springframework.data.redis.core.StreamOperations
-
Read all records from a stream within a specific
Range
asObjectRecord
. - range(Class<V>, K, Range<String>, Limit) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
- range(Class<V>, K, Range<String>, Limit) - Method in interface org.springframework.data.redis.core.StreamOperations
- range(K, long, long) - Method in interface org.springframework.data.redis.core.ListOperations
-
Get elements between
begin
andend
from list atkey
. - range(K, long, long) - Method in interface org.springframework.data.redis.core.ReactiveListOperations
-
Get elements between
begin
andend
from list atkey
. - range(K, long, long) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Get elements between
start
andend
from sorted set. - range(K, Range<Long>) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Get elements between
start
andend
from sorted set. - range(K, Range<String>) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
-
Read records from a stream within a specific
Range
. - range(K, Range<String>) - Method in interface org.springframework.data.redis.core.StreamOperations
-
Read records from a stream within a specific
Range
. - range(K, Range<String>, Limit) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
- range(K, Range<String>, Limit) - Method in interface org.springframework.data.redis.core.StreamOperations
- range(Range<?>, Long) - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.PendingRecordsCommand
-
Create new
ReactiveStreamCommands.PendingRecordsCommand
with givenRange
and limit. - range(Range<?>, Long) - Static method in class org.springframework.data.redis.connection.RedisStreamCommands.XPendingOptions
-
Create new
RedisStreamCommands.XPendingOptions
with givenRange
and limit. - range(Range<String>) - Method in interface org.springframework.data.redis.core.BoundStreamOperations
-
Read records from a stream within a specific
Range
. - range(Range<String>, Limit) - Method in interface org.springframework.data.redis.core.BoundStreamOperations
- Range() - Constructor for class org.springframework.data.redis.connection.RedisZSetCommands.Range
-
Deprecated.
- Range(long, long) - Constructor for class org.springframework.data.redis.connection.SortParameters.Range
- rangeAndStoreByLex(String, Range<String>) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
-
Store all elements at
dstKey
with lexicographical ordering from ZSET at the bound key with a value betweenRange.getLowerBound()
andRange.getUpperBound()
. - rangeAndStoreByLex(String, Range<String>, Limit) - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
- rangeAndStoreByLex(String, Range<String>, Limit) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
-
Store n elements at
dstKey
, where n =Limit.getCount()
, starting atLimit.getOffset()
with lexicographical ordering from ZSET at the bound key with a value betweenRange.getLowerBound()
andRange.getUpperBound()
. - rangeAndStoreByLex(K, K, Range<String>) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Store all elements at
dstKey
with lexicographical ordering from ZSET atsrcKey
with a value betweenRange.getLowerBound()
andRange.getUpperBound()
. - rangeAndStoreByLex(K, K, Range<String>) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Store all elements at
dstKey
with lexicographical ordering from ZSET atsrcKey
with a value betweenRange.getLowerBound()
andRange.getUpperBound()
. - rangeAndStoreByLex(K, K, Range<String>, Limit) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Store n elements at
dstKey
, where n =Limit.getCount()
, starting atLimit.getOffset()
with lexicographical ordering from ZSET atsrcKey
with a value betweenRange.getLowerBound()
andRange.getUpperBound()
. - rangeAndStoreByLex(K, K, Range<String>, Limit) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Store n elements at
dstKey
, where n =Limit.getCount()
, starting atLimit.getOffset()
with lexicographical ordering from ZSET atsrcKey
with a value betweenRange.getLowerBound()
andRange.getUpperBound()
. - rangeAndStoreByLex(K, Range<String>) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Store all elements at
dstKey
with lexicographical ordering from ZSET at the bound key with a value betweenRange.getLowerBound()
andRange.getUpperBound()
. - rangeAndStoreByLex(K, Range<String>, Limit) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Store n elements at
dstKey
, where n =Limit.getCount()
, starting atLimit.getOffset()
with lexicographical ordering from ZSET at the bound key with a value betweenRange.getLowerBound()
andRange.getUpperBound()
. - rangeAndStoreByScore(String, Range<? extends Number>) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
-
Store all elements at
dstKey
with ordering by score from ZSET at the bound key with a score betweenRange.getLowerBound()
andRange.getUpperBound()
. - rangeAndStoreByScore(String, Range<? extends Number>, Limit) - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
- rangeAndStoreByScore(String, Range<? extends Number>, Limit) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
-
Store n elements at
dstKey
, where n =Limit.getCount()
, starting atLimit.getOffset()
with ordering by score from ZSET at the bound key with a score betweenRange.getLowerBound()
andRange.getUpperBound()
. - rangeAndStoreByScore(K, K, Range<? extends Number>) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Store all elements at
dstKey
with ordering by score from ZSET atsrcKey
with a score betweenRange.getLowerBound()
andRange.getUpperBound()
. - rangeAndStoreByScore(K, K, Range<? extends Number>, Limit) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Store n elements at
dstKey
, where n =Limit.getCount()
, starting atLimit.getOffset()
with ordering by score from ZSET atsrcKey
with a score betweenRange.getLowerBound()
andRange.getUpperBound()
. - rangeAndStoreByScore(K, K, Range<Double>) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Store all elements at
dstKey
with ordering by score from ZSET atsrcKey
with a score betweenRange.getLowerBound()
andRange.getUpperBound()
. - rangeAndStoreByScore(K, K, Range<Double>, Limit) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Store n elements at
dstKey
, where n =Limit.getCount()
, starting atLimit.getOffset()
with ordering by score from ZSET atsrcKey
with a score betweenRange.getLowerBound()
andRange.getUpperBound()
. - rangeAndStoreByScore(K, Range<? extends Number>) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Store all elements at
dstKey
with ordering by score from ZSET at the bound key with a score betweenRange.getLowerBound()
andRange.getUpperBound()
. - rangeAndStoreByScore(K, Range<? extends Number>, Limit) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Store n elements at
dstKey
, where n =Limit.getCount()
, starting atLimit.getOffset()
with ordering by score from ZSET at the bound key with a score betweenRange.getLowerBound()
andRange.getUpperBound()
. - rangeByLex(K, Range<String>) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Get all elements with lexicographical ordering from ZSET at
key
with a value betweenRange.getLowerBound()
andRange.getUpperBound()
. - rangeByLex(K, Range<String>) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Get all elements with lexicographical ordering from ZSET at
key
with a value betweenRange.getLowerBound()
andRange.getUpperBound()
. - rangeByLex(K, Range<String>, Limit) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Get all elements n elements, where n =
Limit.getCount()
, starting atLimit.getOffset()
with lexicographical ordering from ZSET atkey
with a value betweenRange.getLowerBound()
andRange.getUpperBound()
. - rangeByLex(K, Range<String>, Limit) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Get all elements n elements, where n =
Limit.getCount()
, starting atLimit.getOffset()
with lexicographical ordering from ZSET atkey
with a value betweenRange.getLowerBound()
andRange.getUpperBound()
. - rangeByLex(K, RedisZSetCommands.Range) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Deprecated, for removal: This API element is subject to removal in a future version.since 3.0. Please use
ZSetOperations.rangeByLex(Object, Range)
instead. - rangeByLex(K, RedisZSetCommands.Range, Limit) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Deprecated, for removal: This API element is subject to removal in a future version.since 3.0. Please use
ZSetOperations.rangeByLex(Object, Range, Limit)
instead. - rangeByLex(Range<String>) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Get all elements with lexicographical ordering with a value between
Range.getLowerBound()
andRange.getUpperBound()
. - rangeByLex(Range<String>) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
-
Get all elements with lexicographical ordering with a value between
Range.getLowerBound()
andRange.getUpperBound()
. - rangeByLex(Range<String>, Limit) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Get all elements n elements, where n =
Limit.getCount()
, starting atLimit.getOffset()
with lexicographical ordering having a value betweenRange.getLowerBound()
andRange.getUpperBound()
. - rangeByLex(Range<String>, Limit) - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
- rangeByLex(Range<String>, Limit) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
-
Get all elements n elements, where n =
Limit.getCount()
, starting atLimit.getOffset()
with lexicographical ordering having a value betweenRange.getLowerBound()
andRange.getUpperBound()
. - rangeByLex(RedisZSetCommands.Range) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Deprecated, for removal: This API element is subject to removal in a future version.since 3.0. Please use
BoundZSetOperations.rangeByLex(Range)
instead. - rangeByLex(RedisZSetCommands.Range) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
-
Deprecated, for removal: This API element is subject to removal in a future version.since 3.0. Please use
RedisZSet.rangeByLex(Range)
instead. - rangeByLex(RedisZSetCommands.Range, Limit) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Deprecated, for removal: This API element is subject to removal in a future version.since 3.0. Please use
BoundZSetOperations.rangeByLex(Range, Limit)
instead. - rangeByLex(RedisZSetCommands.Range, Limit) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
-
Deprecated, for removal: This API element is subject to removal in a future version.since 3.0. Please use
RedisZSet.rangeByLex(Range, Limit)
instead. - rangeByScore(double, double) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Get elements where score is between
min
andmax
from sorted set. - rangeByScore(double, double) - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
- rangeByScore(double, double) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
-
Get elements where score is between
min
andmax
from sorted set. - rangeByScore(K, double, double) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Get elements where score is between
min
andmax
from sorted set. - rangeByScore(K, double, double, long, long) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Get elements in range from
start
toend
where score is betweenmin
andmax
from sorted set. - rangeByScore(K, Range<Double>) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Get elements where score is between
min
andmax
from sorted set. - rangeByScore(K, Range<Double>, Limit) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Get elements in range from
start
toend
where score is betweenmin
andmax
from sorted set. - rangeByScoreWithScores(double, double) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
- rangeByScoreWithScores(double, double) - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
- rangeByScoreWithScores(double, double) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
- rangeByScoreWithScores(K, double, double) - Method in interface org.springframework.data.redis.core.ZSetOperations
- rangeByScoreWithScores(K, double, double, long, long) - Method in interface org.springframework.data.redis.core.ZSetOperations
- rangeByScoreWithScores(K, Range<Double>) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- rangeByScoreWithScores(K, Range<Double>, Limit) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- rangeWithScores(long, long) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
- rangeWithScores(long, long) - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
- rangeWithScores(long, long) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
- rangeWithScores(K, long, long) - Method in interface org.springframework.data.redis.core.ZSetOperations
- rangeWithScores(K, Range<Long>) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- rank(Integer) - Method in class org.springframework.data.redis.connection.ReactiveListCommands.LPosCommand
-
Applies the rank parameter specifying the "rank" of the first element to return.
- rank(Object) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Determine the index of element with
value
in a sorted set. - rank(Object) - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
- rank(Object) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
-
Returns the rank (position) of the given element in the set, in ascending order.
- rank(K, Object) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Determine the index of element with
value
in a sorted set. - rank(K, Object) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Determine the index of element with
value
in a sorted set. - raw() - Method in interface org.springframework.data.redis.connection.ValueEncoding
- raw() - Method in enum class org.springframework.data.redis.connection.ValueEncoding.RedisValueEncoding
- raw() - Static method in interface org.springframework.data.redis.serializer.RedisSerializationContext
-
Deprecated.since 2.2. Please use
RedisSerializationContext.byteArray()
instead. - raw() - Static method in interface org.springframework.data.redis.serializer.RedisSerializationContext.SerializationPair
-
Deprecated.since 2.2. Please use either
RedisSerializationContext.SerializationPair.byteArray()
orRedisSerializationContext.SerializationPair.byteBuffer()
. - RAW - Enum constant in enum class org.springframework.data.redis.connection.ValueEncoding.RedisValueEncoding
-
Normal string encoding.
- rawBuffer(Map<ByteBuffer, ByteBuffer>) - Static method in class org.springframework.data.redis.connection.stream.StreamRecords
-
Create a new
ByteBufferRecord
for the given raw field/value pairs. - rawBytes(Map<byte[], byte[]>) - Static method in class org.springframework.data.redis.connection.stream.StreamRecords
-
Create a new
ByteRecord
for the given raw field/value pairs. - rawMap() - Method in class org.springframework.data.redis.core.convert.Bucket
-
Get keys and values in binary format.
- ReactiveClusterCommands - Interface in org.springframework.data.redis.connection
-
Interface for the cluster commands supported by Redis executed using reactive infrastructure.
- ReactiveClusterCommands.AddSlots - Enum Class in org.springframework.data.redis.connection
- ReactiveClusterGeoCommands - Interface in org.springframework.data.redis.connection
- ReactiveClusterHashCommands - Interface in org.springframework.data.redis.connection
- ReactiveClusterHyperLogLogCommands - Interface in org.springframework.data.redis.connection
- ReactiveClusterKeyCommands - Interface in org.springframework.data.redis.connection
- ReactiveClusterListCommands - Interface in org.springframework.data.redis.connection
- ReactiveClusterNumberCommands - Interface in org.springframework.data.redis.connection
- ReactiveClusterScriptingCommands - Interface in org.springframework.data.redis.connection
- ReactiveClusterServerCommands - Interface in org.springframework.data.redis.connection
-
Redis Server commands executed in cluster environment using reactive infrastructure.
- ReactiveClusterSetCommands - Interface in org.springframework.data.redis.connection
- ReactiveClusterStreamCommands - Interface in org.springframework.data.redis.connection
- ReactiveClusterStringCommands - Interface in org.springframework.data.redis.connection
- ReactiveClusterZSetCommands - Interface in org.springframework.data.redis.connection
- ReactiveGeoCommands - Interface in org.springframework.data.redis.connection
-
Redis Geo commands executed using reactive infrastructure.
- ReactiveGeoCommands.GeoAddCommand - Class in org.springframework.data.redis.connection
-
GEOADD
command parameters. - ReactiveGeoCommands.GeoDistCommand - Class in org.springframework.data.redis.connection
-
GEODIST
command parameters. - ReactiveGeoCommands.GeoHashCommand - Class in org.springframework.data.redis.connection
-
GEOHASH
command parameters. - ReactiveGeoCommands.GeoPosCommand - Class in org.springframework.data.redis.connection
-
GEOPOS
command parameters. - ReactiveGeoCommands.GeoRadiusByMemberCommand - Class in org.springframework.data.redis.connection
-
GEORADIUSBYMEMBER
command parameters. - ReactiveGeoCommands.GeoRadiusCommand - Class in org.springframework.data.redis.connection
-
GEORADIUS
command parameters. - ReactiveGeoCommands.GeoSearchCommand - Class in org.springframework.data.redis.connection
-
GEOSEARCH
command parameters. - ReactiveGeoCommands.GeoSearchStoreCommand - Class in org.springframework.data.redis.connection
-
GEOSEARCHSTORE
command parameters. - ReactiveGeoOperations<K,
M> - Interface in org.springframework.data.redis.core -
Reactive Redis operations for Geo Commands.
- ReactiveHashCommands - Interface in org.springframework.data.redis.connection
-
Redis Hash commands executed using reactive infrastructure.
- ReactiveHashCommands.HDelCommand - Class in org.springframework.data.redis.connection
- ReactiveHashCommands.HExistsCommand - Class in org.springframework.data.redis.connection
-
HEXISTS
ReactiveRedisConnection.Command
. - ReactiveHashCommands.HGetCommand - Class in org.springframework.data.redis.connection
- ReactiveHashCommands.HRandFieldCommand - Class in org.springframework.data.redis.connection
-
HRANDFIELD
ReactiveRedisConnection.Command
. - ReactiveHashCommands.HSetCommand - Class in org.springframework.data.redis.connection
- ReactiveHashCommands.HStrLenCommand - Class in org.springframework.data.redis.connection
- ReactiveHashOperations<H,
HK, HV> - Interface in org.springframework.data.redis.core -
Reactive Redis operations for Hash Commands.
- ReactiveHyperLogLogCommands - Interface in org.springframework.data.redis.connection
-
Redis HyperLogLog commands executed using reactive infrastructure.
- ReactiveHyperLogLogCommands.PfAddCommand - Class in org.springframework.data.redis.connection
-
PFADD
command parameters. - ReactiveHyperLogLogCommands.PfCountCommand - Class in org.springframework.data.redis.connection
-
PFCOUNT
command parameters. - ReactiveHyperLogLogCommands.PfMergeCommand - Class in org.springframework.data.redis.connection
-
PFMERGE
command parameters. - ReactiveHyperLogLogOperations<K,
V> - Interface in org.springframework.data.redis.core -
Reactive Redis operations for working on a HyperLogLog multiset.
- ReactiveKeyCommands - Interface in org.springframework.data.redis.connection
-
Redis Key commands executed using reactive infrastructure.
- ReactiveKeyCommands.CopyCommand - Class in org.springframework.data.redis.connection
-
MOVE
command parameters. - ReactiveKeyCommands.ExpireAtCommand - Class in org.springframework.data.redis.connection
-
EXPIREAT
/PEXPIREAT
command parameters. - ReactiveKeyCommands.ExpireCommand - Class in org.springframework.data.redis.connection
-
EXPIRE
/PEXPIRE
command parameters. - ReactiveKeyCommands.MoveCommand - Class in org.springframework.data.redis.connection
-
MOVE
command parameters. - ReactiveKeyCommands.RenameCommand - Class in org.springframework.data.redis.connection
-
RENAME
command parameters. - ReactiveListCommands - Interface in org.springframework.data.redis.connection
-
Redis List commands executed using reactive infrastructure.
- ReactiveListCommands.BLMoveCommand - Class in org.springframework.data.redis.connection
-
BLMOVE
command parameters. - ReactiveListCommands.BPopCommand - Class in org.springframework.data.redis.connection
- ReactiveListCommands.BRPopLPushCommand - Class in org.springframework.data.redis.connection
-
BRPOPLPUSH
command parameters. - ReactiveListCommands.Direction - Enum Class in org.springframework.data.redis.connection
- ReactiveListCommands.LIndexCommand - Class in org.springframework.data.redis.connection
-
LINDEX
command parameters. - ReactiveListCommands.LInsertCommand - Class in org.springframework.data.redis.connection
-
LINSERT
command parameters. - ReactiveListCommands.LMoveCommand - Class in org.springframework.data.redis.connection
-
LMOVE
command parameters. - ReactiveListCommands.LPosCommand - Class in org.springframework.data.redis.connection
-
LPOS
command parameters. - ReactiveListCommands.LRemCommand - Class in org.springframework.data.redis.connection
-
LREM
command parameters. - ReactiveListCommands.LSetCommand - Class in org.springframework.data.redis.connection
-
LSET
command parameters. - ReactiveListCommands.PopCommand - Class in org.springframework.data.redis.connection
-
LPOP
/RPOP command parameters. - ReactiveListCommands.PopResponse - Class in org.springframework.data.redis.connection
- ReactiveListCommands.PopResult - Class in org.springframework.data.redis.connection
- ReactiveListCommands.PushCommand - Class in org.springframework.data.redis.connection
-
LPUSH
/RPUSH command parameters. - ReactiveListCommands.RPopLPushCommand - Class in org.springframework.data.redis.connection
-
RPOPLPUSH
command parameters. - ReactiveListOperations<K,
V> - Interface in org.springframework.data.redis.core -
Reactive Redis operations for List Commands.
- ReactiveNumberCommands - Interface in org.springframework.data.redis.connection
-
Redis numeric commands executed using reactive infrastructure.
- ReactiveNumberCommands.DecrByCommand<T extends Number> - Class in org.springframework.data.redis.connection
-
DECRBY
command parameters. - ReactiveNumberCommands.HIncrByCommand<T extends Number> - Class in org.springframework.data.redis.connection
-
HINCRBY
command parameters. - ReactiveNumberCommands.IncrByCommand<T extends Number> - Class in org.springframework.data.redis.connection
-
INCRBY
command parameters. - ReactivePubSubCommands - Interface in org.springframework.data.redis.connection
-
Redis Pub/Sub commands executed using reactive infrastructure.
- ReactiveRedisCallback<T> - Interface in org.springframework.data.redis.core
-
Generic callback interface for code that operates on a low-level
ReactiveRedisConnection
. - ReactiveRedisClusterConnection - Interface in org.springframework.data.redis.connection
- ReactiveRedisConnection - Interface in org.springframework.data.redis.connection
-
Redis connection using reactive infrastructure declaring entry points for reactive command execution.
- ReactiveRedisConnection.AbsentByteBufferResponse<I> - Class in org.springframework.data.redis.connection
-
ReactiveRedisConnection.CommandResponse
implementation forByteBuffer
responses for absent keys. - ReactiveRedisConnection.BooleanResponse<I> - Class in org.springframework.data.redis.connection
-
ReactiveRedisConnection.CommandResponse
implementation forBoolean
responses. - ReactiveRedisConnection.ByteBufferResponse<I> - Class in org.springframework.data.redis.connection
-
ReactiveRedisConnection.CommandResponse
implementation forByteBuffer
responses. - ReactiveRedisConnection.Command - Interface in org.springframework.data.redis.connection
-
Base interface for Redis commands executed with a reactive infrastructure.
- ReactiveRedisConnection.CommandResponse<I,
O> - Class in org.springframework.data.redis.connection -
Base class for command responses.
- ReactiveRedisConnection.KeyCommand - Class in org.springframework.data.redis.connection
-
ReactiveRedisConnection.Command
for key-bound operations. - ReactiveRedisConnection.KeyScanCommand - Class in org.springframework.data.redis.connection
- ReactiveRedisConnection.MultiValueResponse<I,
O> - Class in org.springframework.data.redis.connection -
ReactiveRedisConnection.CommandResponse
implementation forList
responses. - ReactiveRedisConnection.NumericResponse<I,
O extends Number> - Class in org.springframework.data.redis.connection -
ReactiveRedisConnection.CommandResponse
implementation fornumeric
responses. - ReactiveRedisConnection.RangeCommand - Class in org.springframework.data.redis.connection
- ReactiveRedisConnectionFactory - Interface in org.springframework.data.redis.connection
-
Thread-safe factory of reactive Redis connections.
- ReactiveRedisMessageListenerContainer - Class in org.springframework.data.redis.listener
-
Container providing a stream of
ReactiveSubscription.ChannelMessage
for messages received via Redis Pub/Sub listeners. - ReactiveRedisMessageListenerContainer(ReactiveRedisConnectionFactory) - Constructor for class org.springframework.data.redis.listener.ReactiveRedisMessageListenerContainer
-
Create a new
ReactiveRedisMessageListenerContainer
givenReactiveRedisConnectionFactory
. - ReactiveRedisOperations<K,
V> - Interface in org.springframework.data.redis.core -
Interface that specified a basic set of Redis operations, implemented by
ReactiveRedisTemplate
. - ReactiveRedisSessionCallback<K,
V, T> - Interface in org.springframework.data.redis.core -
Generic callback interface for code that wants to use the same
ReactiveRedisConnection
avoiding connection allocation overhead upon each Template API method call. - ReactiveRedisTemplate<K,
V> - Class in org.springframework.data.redis.core -
Central abstraction for reactive Redis data access implementing
ReactiveRedisOperations
. - ReactiveRedisTemplate(ReactiveRedisConnectionFactory, RedisSerializationContext<K, V>) - Constructor for class org.springframework.data.redis.core.ReactiveRedisTemplate
-
Creates new
ReactiveRedisTemplate
using givenReactiveRedisConnectionFactory
andRedisSerializationContext
. - ReactiveRedisTemplate(ReactiveRedisConnectionFactory, RedisSerializationContext<K, V>, boolean) - Constructor for class org.springframework.data.redis.core.ReactiveRedisTemplate
-
Creates new
ReactiveRedisTemplate
using givenReactiveRedisConnectionFactory
andRedisSerializationContext
. - ReactiveScriptExecutor<K> - Interface in org.springframework.data.redis.core.script
-
Executes
RedisScript
s using reactive infrastructure. - ReactiveScriptingCommands - Interface in org.springframework.data.redis.connection
-
Redis Scripting commands executed using reactive infrastructure.
- ReactiveServerCommands - Interface in org.springframework.data.redis.connection
-
Redis Server commands executed using reactive infrastructure.
- ReactiveSetCommands - Interface in org.springframework.data.redis.connection
-
Redis Set commands executed using reactive infrastructure.
- ReactiveSetCommands.SAddCommand - Class in org.springframework.data.redis.connection
-
SADD
command parameters. - ReactiveSetCommands.SDiffCommand - Class in org.springframework.data.redis.connection
-
SDIFF
command parameters. - ReactiveSetCommands.SDiffStoreCommand - Class in org.springframework.data.redis.connection
-
SDIFFSTORE
command parameters. - ReactiveSetCommands.SInterCommand - Class in org.springframework.data.redis.connection
-
SINTER
command parameters. - ReactiveSetCommands.SInterStoreCommand - Class in org.springframework.data.redis.connection
-
SINTERSTORE
command parameters. - ReactiveSetCommands.SIsMemberCommand - Class in org.springframework.data.redis.connection
-
SISMEMBER
command parameters. - ReactiveSetCommands.SMIsMemberCommand - Class in org.springframework.data.redis.connection
-
SMISMEMBER
command parameters. - ReactiveSetCommands.SMoveCommand - Class in org.springframework.data.redis.connection
-
SMOVE
command parameters. - ReactiveSetCommands.SPopCommand - Class in org.springframework.data.redis.connection
-
SPOP
command parameters. - ReactiveSetCommands.SRandMembersCommand - Class in org.springframework.data.redis.connection
-
SRANDMEMBER
command parameters. - ReactiveSetCommands.SRemCommand - Class in org.springframework.data.redis.connection
-
SREM
command parameters. - ReactiveSetCommands.SUnionCommand - Class in org.springframework.data.redis.connection
-
SUNION
command parameters. - ReactiveSetCommands.SUnionStoreCommand - Class in org.springframework.data.redis.connection
-
SUNIONSTORE
command parameters. - ReactiveSetOperations<K,
V> - Interface in org.springframework.data.redis.core -
Reactive Redis operations for Set Commands.
- ReactiveStreamCommands - Interface in org.springframework.data.redis.connection
-
Stream-specific Redis commands executed using reactive infrastructure.
- ReactiveStreamCommands.AcknowledgeCommand - Class in org.springframework.data.redis.connection
-
XACK
command parameters. - ReactiveStreamCommands.AddStreamRecord - Class in org.springframework.data.redis.connection
-
XADD
command parameters. - ReactiveStreamCommands.DeleteCommand - Class in org.springframework.data.redis.connection
-
XDEL
command parameters. - ReactiveStreamCommands.GroupCommand - Class in org.springframework.data.redis.connection
- ReactiveStreamCommands.GroupCommand.GroupCommandAction - Enum Class in org.springframework.data.redis.connection
- ReactiveStreamCommands.PendingRecordsCommand - Class in org.springframework.data.redis.connection
-
Value Object holding parameters for obtaining pending messages.
- ReactiveStreamCommands.RangeCommand - Class in org.springframework.data.redis.connection
-
XRANGE
/XREVRANGE
command parameters. - ReactiveStreamCommands.ReadCommand - Class in org.springframework.data.redis.connection
-
XRANGE
/XREVRANGE
command parameters. - ReactiveStreamCommands.TrimCommand - Class in org.springframework.data.redis.connection
-
XTRIM
command parameters. - ReactiveStreamCommands.XClaimCommand - Class in org.springframework.data.redis.connection
-
XCLAIM
command parameters. - ReactiveStreamCommands.XInfoCommand - Class in org.springframework.data.redis.connection
- ReactiveStreamOperations<K,
HK, HV> - Interface in org.springframework.data.redis.core -
Reactive Redis operations for Stream Commands.
- ReactiveStringCommands - Interface in org.springframework.data.redis.connection
-
Redis String commands executed using reactive infrastructure.
- ReactiveStringCommands.AppendCommand - Class in org.springframework.data.redis.connection
-
APPEND
command parameters. - ReactiveStringCommands.BitCountCommand - Class in org.springframework.data.redis.connection
-
BITCOUNT
command parameters. - ReactiveStringCommands.BitFieldCommand - Class in org.springframework.data.redis.connection
-
BITFIELD
command parameters. - ReactiveStringCommands.BitOpCommand - Class in org.springframework.data.redis.connection
-
BITOP
command parameters. - ReactiveStringCommands.BitPosCommand - Class in org.springframework.data.redis.connection
- ReactiveStringCommands.GetBitCommand - Class in org.springframework.data.redis.connection
-
GETBIT
command parameters. - ReactiveStringCommands.GetExCommand - Class in org.springframework.data.redis.connection
-
ReactiveRedisConnection.Command
forGETEX
. - ReactiveStringCommands.MSetCommand - Class in org.springframework.data.redis.connection
-
MSET
command parameters. - ReactiveStringCommands.SetBitCommand - Class in org.springframework.data.redis.connection
-
SETBIT
command parameters. - ReactiveStringCommands.SetCommand - Class in org.springframework.data.redis.connection
-
SET
command parameters. - ReactiveStringCommands.SetRangeCommand - Class in org.springframework.data.redis.connection
-
SETRANGE
command parameters. - ReactiveStringRedisTemplate - Class in org.springframework.data.redis.core
-
String-focused
extension ofReactiveRedisTemplate
. - ReactiveStringRedisTemplate(ReactiveRedisConnectionFactory) - Constructor for class org.springframework.data.redis.core.ReactiveStringRedisTemplate
-
Creates new
ReactiveRedisTemplate
using givenReactiveRedisConnectionFactory
applying defaultString
serialization. - ReactiveStringRedisTemplate(ReactiveRedisConnectionFactory, RedisSerializationContext<String, String>) - Constructor for class org.springframework.data.redis.core.ReactiveStringRedisTemplate
-
Creates new
ReactiveRedisTemplate
using givenReactiveRedisConnectionFactory
andRedisSerializationContext
. - ReactiveStringRedisTemplate(ReactiveRedisConnectionFactory, RedisSerializationContext<String, String>, boolean) - Constructor for class org.springframework.data.redis.core.ReactiveStringRedisTemplate
-
Creates new
ReactiveRedisTemplate
using givenReactiveRedisConnectionFactory
andRedisSerializationContext
. - ReactiveSubscription - Interface in org.springframework.data.redis.connection
-
Subscription for Redis channels using reactive infrastructure.
- ReactiveSubscription.ChannelMessage<C,
M> - Class in org.springframework.data.redis.connection -
Value object for a Redis channel message.
- ReactiveSubscription.Message<C,
M> - Interface in org.springframework.data.redis.connection -
ReactiveSubscription.Message
represents a Redis channel message within Redis pub/sub. - ReactiveSubscription.PatternMessage<P,
C, M> - Class in org.springframework.data.redis.connection -
Value object for a Redis channel message received from a pattern subscription.
- ReactiveValueOperations<K,
V> - Interface in org.springframework.data.redis.core -
Reactive Redis operations for simple (or in Redis terminology 'string') values.
- ReactiveZSetCommands - Interface in org.springframework.data.redis.connection
-
Redis Sorted Set commands executed using reactive infrastructure.
- ReactiveZSetCommands.BZPopCommand - Class in org.springframework.data.redis.connection
-
BZPOPMIN
/BZPOPMAX command parameters. - ReactiveZSetCommands.PopDirection - Enum Class in org.springframework.data.redis.connection
- ReactiveZSetCommands.ZAddCommand - Class in org.springframework.data.redis.connection
-
ZADD
command parameters. - ReactiveZSetCommands.ZAggregateCommand - Class in org.springframework.data.redis.connection
-
ZINTER
/ZUNION
command parameters. - ReactiveZSetCommands.ZAggregateStoreCommand - Class in org.springframework.data.redis.connection
-
ZINTERSTORE
/ZUNIONSTORE
command parameters. - ReactiveZSetCommands.ZCountCommand - Class in org.springframework.data.redis.connection
-
ZCOUNT
command parameters. - ReactiveZSetCommands.ZDiffCommand - Class in org.springframework.data.redis.connection
-
ZDIFF
command parameters. - ReactiveZSetCommands.ZDiffStoreCommand - Class in org.springframework.data.redis.connection
-
ZDIFFSTORE
command parameters. - ReactiveZSetCommands.ZIncrByCommand - Class in org.springframework.data.redis.connection
-
ZINCRBY
command parameters. - ReactiveZSetCommands.ZInterStoreCommand - Class in org.springframework.data.redis.connection
-
ZINTERSTORE
command parameters. - ReactiveZSetCommands.ZLexCountCommand - Class in org.springframework.data.redis.connection
-
ZLEXCOUNT
command parameters. - ReactiveZSetCommands.ZMScoreCommand - Class in org.springframework.data.redis.connection
-
ZMSCORE
command parameters. - ReactiveZSetCommands.ZPopCommand - Class in org.springframework.data.redis.connection
-
ZPOPMIN
/ZPOPMAX command parameters. - ReactiveZSetCommands.ZRandMemberCommand - Class in org.springframework.data.redis.connection
-
ZRANDMEMBER
command parameters. - ReactiveZSetCommands.ZRangeByLexCommand - Class in org.springframework.data.redis.connection
-
ZRANGEBYLEX
/ZREVRANGEBYLEX command parameters. - ReactiveZSetCommands.ZRangeByScoreCommand - Class in org.springframework.data.redis.connection
-
ZRANGEBYSCORE/ZREVRANGEBYSCORE.
- ReactiveZSetCommands.ZRangeCommand - Class in org.springframework.data.redis.connection
-
ZRANGE
/ZREVRANGE command parameters. - ReactiveZSetCommands.ZRangeStoreCommand - Class in org.springframework.data.redis.connection
-
ZRANGESTORE
command parameters. - ReactiveZSetCommands.ZRangeStoreCommand.RangeMode - Enum Class in org.springframework.data.redis.connection
- ReactiveZSetCommands.ZRankCommand - Class in org.springframework.data.redis.connection
-
ZRANK
/ZREVRANK command parameters. - ReactiveZSetCommands.ZRemCommand - Class in org.springframework.data.redis.connection
-
ZREM
command parameters. - ReactiveZSetCommands.ZRemRangeByLexCommand - Class in org.springframework.data.redis.connection
-
ZREMRANGEBYLEX
command parameters. - ReactiveZSetCommands.ZRemRangeByRankCommand - Class in org.springframework.data.redis.connection
-
ZREMRANGEBYRANK
command parameters. - ReactiveZSetCommands.ZRemRangeByScoreCommand - Class in org.springframework.data.redis.connection
-
ZREMRANGEBYSCORE
command parameters. - ReactiveZSetCommands.ZScoreCommand - Class in org.springframework.data.redis.connection
-
ZSCORE
command parameters. - ReactiveZSetCommands.ZUnionStoreCommand - Class in org.springframework.data.redis.connection
-
ZUNIONSTORE
command parameters. - ReactiveZSetOperations<K,
V> - Interface in org.springframework.data.redis.core -
Reactive Redis operations for Sorted (ZSet) Commands.
- read(ObjectMapper, byte[], JavaType) - Method in interface org.springframework.data.redis.serializer.JacksonObjectReader
-
Read an object graph from the given root JSON into a Java object considering the
JavaType
. - read(Class<R>, RedisData) - Method in class org.springframework.data.redis.core.convert.MappingRedisConverter
- read(Class<V>, Consumer, StreamOffset<K>...) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
-
Read records from one or more
StreamOffset
s using a consumer group asObjectRecord
. - read(Class<V>, Consumer, StreamOffset<K>...) - Method in interface org.springframework.data.redis.core.StreamOperations
-
Read records from one or more
StreamOffset
s using a consumer group asObjectRecord
. - read(Class<V>, Consumer, StreamReadOptions, StreamOffset<K>...) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
-
Read records from one or more
StreamOffset
s using a consumer group asObjectRecord
. - read(Class<V>, Consumer, StreamReadOptions, StreamOffset<K>...) - Method in interface org.springframework.data.redis.core.StreamOperations
-
Read records from one or more
StreamOffset
s using a consumer group asObjectRecord
. - read(Class<V>, StreamOffset<K>) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
-
Read records from a
StreamOffset
asObjectRecord
. - read(Class<V>, StreamOffset<K>...) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
-
Read records from one or more
StreamOffset
s asObjectRecord
. - read(Class<V>, StreamOffset<K>...) - Method in interface org.springframework.data.redis.core.StreamOperations
-
Read records from one or more
StreamOffset
s asObjectRecord
. - read(Class<V>, StreamReadOptions, StreamOffset<K>...) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
-
Read records from one or more
StreamOffset
s asObjectRecord
. - read(Class<V>, StreamReadOptions, StreamOffset<K>...) - Method in interface org.springframework.data.redis.core.StreamOperations
-
Read records from one or more
StreamOffset
s asObjectRecord
. - read(ByteBuffer) - Method in interface org.springframework.data.redis.serializer.RedisElementReader
-
Deserialize a
ByteBuffer
into the according type. - read(ByteBuffer) - Method in interface org.springframework.data.redis.serializer.RedisSerializationContext.SerializationPair
-
Deserialize a
ByteBuffer
into the according type. - read(Publisher<ReactiveStreamCommands.ReadCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
-
Read records from one or more
StreamOffset
s. - read(Consumer, ReadOffset) - Method in interface org.springframework.data.redis.core.BoundStreamOperations
-
Read records starting from
ReadOffset
. using a consumer group. - read(Consumer, StreamOffset<K>...) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
-
Read records from one or more
StreamOffset
s using a consumer group. - read(Consumer, StreamOffset<K>...) - Method in interface org.springframework.data.redis.core.StreamOperations
-
Read records from one or more
StreamOffset
s using a consumer group. - read(Consumer, StreamReadOptions, ReadOffset) - Method in interface org.springframework.data.redis.core.BoundStreamOperations
-
Read records starting from
ReadOffset
. using a consumer group. - read(Consumer, StreamReadOptions, StreamOffset<K>...) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
-
Read records from one or more
StreamOffset
s using a consumer group. - read(Consumer, StreamReadOptions, StreamOffset<K>...) - Method in interface org.springframework.data.redis.core.StreamOperations
-
Read records from one or more
StreamOffset
s using a consumer group. - read(ReadOffset) - Method in interface org.springframework.data.redis.core.BoundStreamOperations
-
Read records from
ReadOffset
. - read(StreamOffset<K>) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
-
Read records from a
StreamOffset
asObjectRecord
. - read(StreamOffset<K>...) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
-
Read records from one or more
StreamOffset
s. - read(StreamOffset<K>...) - Method in interface org.springframework.data.redis.core.StreamOperations
-
Read records from one or more
StreamOffset
s. - read(StreamReadOptions, ReadOffset) - Method in interface org.springframework.data.redis.core.BoundStreamOperations
-
Read records starting from
ReadOffset
. - read(StreamReadOptions, StreamOffset<K>...) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
-
Read records from one or more
StreamOffset
s. - read(StreamReadOptions, StreamOffset<K>...) - Method in interface org.springframework.data.redis.core.StreamOperations
-
Read records from one or more
StreamOffset
s. - ReadCommand(List<StreamOffset<ByteBuffer>>, StreamReadOptions, Consumer) - Constructor for class org.springframework.data.redis.connection.ReactiveStreamCommands.ReadCommand
- reader(JacksonObjectReader) - Method in class org.springframework.data.redis.serializer.GenericJackson2JsonRedisSerializer.GenericJackson2JsonRedisSerializerBuilder
-
Configure
JacksonObjectReader
. - readFrom(ReadFrom) - Method in class org.springframework.data.redis.connection.lettuce.LettuceClientConfiguration.LettuceClientConfigurationBuilder
-
Configure
ReadFrom
. - readFrom(ReadFrom) - Method in class org.springframework.data.redis.connection.lettuce.LettucePoolingClientConfiguration.LettucePoolingClientConfigurationBuilder
- ReadOffset - Class in org.springframework.data.redis.connection.stream
-
Value object representing read offset for a Stream.
- readProperty(String, RedisData, RedisPersistentProperty) - Method in class org.springframework.data.redis.core.convert.MappingRedisConverter
- readTimeout(Duration) - Method in class org.springframework.data.redis.connection.jedis.JedisClientConfiguration.DefaultJedisClientConfigurationBuilder
- readTimeout(Duration) - Method in interface org.springframework.data.redis.connection.jedis.JedisClientConfiguration.JedisClientConfigurationBuilder
-
Configure a read timeout.
- receive() - Method in interface org.springframework.data.redis.connection.ReactiveSubscription
-
Retrieve the message stream emitting
messages
. - receive(Iterable<? extends Topic>, SubscriptionListener) - Method in class org.springframework.data.redis.listener.ReactiveRedisMessageListenerContainer
-
Subscribe to one or more
Topic
s and receive a stream ofReactiveSubscription.ChannelMessage
. - receive(Iterable<? extends Topic>, RedisSerializationContext.SerializationPair<C>, RedisSerializationContext.SerializationPair<B>) - Method in class org.springframework.data.redis.listener.ReactiveRedisMessageListenerContainer
-
Subscribe to one or more
Topic
s and receive a stream ofReactiveSubscription.ChannelMessage
. - receive(Iterable<? extends Topic>, RedisSerializationContext.SerializationPair<C>, RedisSerializationContext.SerializationPair<B>, SubscriptionListener) - Method in class org.springframework.data.redis.listener.ReactiveRedisMessageListenerContainer
-
Subscribe to one or more
Topic
s and receive a stream ofReactiveSubscription.ChannelMessage
. - receive(Consumer, StreamOffset<K>) - Method in interface org.springframework.data.redis.stream.StreamReceiver
- receive(Consumer, StreamOffset<K>, StreamListener<K, V>) - Method in interface org.springframework.data.redis.stream.StreamMessageListenerContainer
-
Register a new subscription for a Redis Stream.
- receive(StreamOffset<K>) - Method in interface org.springframework.data.redis.stream.StreamReceiver
- receive(StreamOffset<K>, StreamListener<K, V>) - Method in interface org.springframework.data.redis.stream.StreamMessageListenerContainer
-
Register a new subscription for a Redis Stream.
- receive(ChannelTopic...) - Method in class org.springframework.data.redis.listener.ReactiveRedisMessageListenerContainer
-
Subscribe to one or more
ChannelTopic
s and receive a stream ofReactiveSubscription.ChannelMessage
. - receive(PatternTopic...) - Method in class org.springframework.data.redis.listener.ReactiveRedisMessageListenerContainer
-
Subscribe to one or more
PatternTopic
s and receive a stream ofReactiveSubscription.PatternMessage
. - receiveAutoAck(Consumer, StreamOffset<K>) - Method in interface org.springframework.data.redis.stream.StreamReceiver
- receiveAutoAck(Consumer, StreamOffset<K>, StreamListener<K, V>) - Method in interface org.springframework.data.redis.stream.StreamMessageListenerContainer
-
Register a new subscription for a Redis Stream.
- receiveLater(Iterable<? extends Topic>, RedisSerializationContext.SerializationPair<C>, RedisSerializationContext.SerializationPair<B>) - Method in class org.springframework.data.redis.listener.ReactiveRedisMessageListenerContainer
-
Subscribe to one or more
Topic
s and receive a stream ofReactiveSubscription.ChannelMessage
. - receiveLater(ChannelTopic...) - Method in class org.springframework.data.redis.listener.ReactiveRedisMessageListenerContainer
-
Subscribe to one or more
ChannelTopic
s and receive a stream ofReactiveSubscription.ChannelMessage
once the returnedMono
completes. - receiveLater(PatternTopic...) - Method in class org.springframework.data.redis.listener.ReactiveRedisMessageListenerContainer
-
Subscribe to one or more
PatternTopic
s and receive a stream ofReactiveSubscription.PatternMessage
once the returnedMono
completes. - Record<S,
V> - Interface in org.springframework.data.redis.connection.stream -
A single entry in the stream consisting of the
entry-id
and the actual entry-value (typically a collection offield/value pairs
). - RecordId - Class in org.springframework.data.redis.connection.stream
-
The id of a single
Record
within a stream. - records(String...) - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.DeleteCommand
-
Applies the recordIds.
- records(RecordId...) - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.DeleteCommand
-
Applies the recordIds.
- REDIS_COMMAND_OBSERVATION - Enum constant in enum class org.springframework.data.redis.connection.lettuce.observability.RedisObservation
-
Deprecated.Timer created around a Redis command execution.
- RedisAccessor - Class in org.springframework.data.redis.core
-
Base class for
RedisTemplate
implementations defining common properties. - RedisAccessor() - Constructor for class org.springframework.data.redis.core.RedisAccessor
- RedisAssertions - Class in org.springframework.data.redis.util
-
Deprecated, for removal: This API element is subject to removal in a future version.since 3.3, will be removed in a future revision in favor of Spring's
Assert
utility. - RedisAssertions() - Constructor for class org.springframework.data.redis.util.RedisAssertions
-
Deprecated.
- RedisAssertions.RuntimeExceptionSupplier - Interface in org.springframework.data.redis.util
-
Deprecated.
- RedisAtomicDouble - Class in org.springframework.data.redis.support.atomic
-
Atomic double backed by Redis.
- RedisAtomicDouble(String, RedisConnectionFactory) - Constructor for class org.springframework.data.redis.support.atomic.RedisAtomicDouble
-
Constructs a new
RedisAtomicDouble
instance. - RedisAtomicDouble(String, RedisConnectionFactory, double) - Constructor for class org.springframework.data.redis.support.atomic.RedisAtomicDouble
-
Constructs a new
RedisAtomicDouble
instance with ainitialValue
that overwrites the existing value. - RedisAtomicDouble(String, RedisOperations<String, Double>) - Constructor for class org.springframework.data.redis.support.atomic.RedisAtomicDouble
-
Constructs a new
RedisAtomicDouble
instance. - RedisAtomicDouble(String, RedisOperations<String, Double>, double) - Constructor for class org.springframework.data.redis.support.atomic.RedisAtomicDouble
-
Constructs a new
RedisAtomicDouble
instance with ainitialValue
that overwrites the existing value atredisCounter
. - RedisAtomicInteger - Class in org.springframework.data.redis.support.atomic
-
Atomic integer backed by Redis.
- RedisAtomicInteger(String, RedisConnectionFactory) - Constructor for class org.springframework.data.redis.support.atomic.RedisAtomicInteger
-
Constructs a new
RedisAtomicInteger
instance. - RedisAtomicInteger(String, RedisConnectionFactory, int) - Constructor for class org.springframework.data.redis.support.atomic.RedisAtomicInteger
-
Constructs a new
RedisAtomicInteger
instance with ainitialValue
that overwrites the existing value. - RedisAtomicInteger(String, RedisOperations<String, Integer>) - Constructor for class org.springframework.data.redis.support.atomic.RedisAtomicInteger
-
Constructs a new
RedisAtomicInteger
instance. - RedisAtomicInteger(String, RedisOperations<String, Integer>, int) - Constructor for class org.springframework.data.redis.support.atomic.RedisAtomicInteger
-
Constructs a new
RedisAtomicInteger
instance instance with ainitialValue
that overwrites the existing value. - RedisAtomicLong - Class in org.springframework.data.redis.support.atomic
-
Atomic long backed by Redis.
- RedisAtomicLong(String, RedisConnectionFactory) - Constructor for class org.springframework.data.redis.support.atomic.RedisAtomicLong
-
Constructs a new
RedisAtomicLong
instance. - RedisAtomicLong(String, RedisConnectionFactory, long) - Constructor for class org.springframework.data.redis.support.atomic.RedisAtomicLong
-
Constructs a new
RedisAtomicLong
instance with ainitialValue
that overwrites the existing value atredisCounter
. - RedisAtomicLong(String, RedisOperations<String, Long>) - Constructor for class org.springframework.data.redis.support.atomic.RedisAtomicLong
-
Constructs a new
RedisAtomicLong
instance. - RedisAtomicLong(String, RedisOperations<String, Long>, long) - Constructor for class org.springframework.data.redis.support.atomic.RedisAtomicLong
-
Constructs a new
RedisAtomicLong
instance with ainitialValue
that overwrites the existing value. - RedisCache - Class in org.springframework.data.redis.cache
-
Cache
implementation using Redis as the underlying store for cache data. - RedisCache(String, RedisCacheWriter, RedisCacheConfiguration) - Constructor for class org.springframework.data.redis.cache.RedisCache
-
Create a new
RedisCache
with the givenname
andRedisCacheConfiguration
, using theRedisCacheWriter
to execute Redis commands supporting the cache operations. - RedisCacheConfiguration - Class in org.springframework.data.redis.cache
-
Immutable
RedisCacheConfiguration
used to customizeRedisCache
behavior, such as caching null values, computing cache key prefixes and handling binary serialization. - RedisCacheManager - Class in org.springframework.data.redis.cache
-
CacheManager
implementation for Redis backed byRedisCache
. - RedisCacheManager(RedisCacheWriter, RedisCacheConfiguration) - Constructor for class org.springframework.data.redis.cache.RedisCacheManager
-
Creates a new
RedisCacheManager
initialized with the givenRedisCacheWriter
and defaultRedisCacheConfiguration
. - RedisCacheManager(RedisCacheWriter, RedisCacheConfiguration, boolean, String...) - Constructor for class org.springframework.data.redis.cache.RedisCacheManager
-
Creates a new
RedisCacheManager
initialized with the givenRedisCacheWriter
and defaultRedisCacheConfiguration
along with whether to allow cache creation at runtime. - RedisCacheManager(RedisCacheWriter, RedisCacheConfiguration, boolean, Map<String, RedisCacheConfiguration>) - Constructor for class org.springframework.data.redis.cache.RedisCacheManager
-
Creates a new
RedisCacheManager
initialized with the givenRedisCacheWriter
and a defaultRedisCacheConfiguration
, and whether to allowRedisCache
creation at runtime. - RedisCacheManager(RedisCacheWriter, RedisCacheConfiguration, String...) - Constructor for class org.springframework.data.redis.cache.RedisCacheManager
-
Creates a new
RedisCacheManager
initialized with the givenRedisCacheWriter
and a defaultRedisCacheConfiguration
along with an optional, initial set ofcache names
used to createRedis caches
on startup. - RedisCacheManager(RedisCacheWriter, RedisCacheConfiguration, Map<String, RedisCacheConfiguration>) - Constructor for class org.springframework.data.redis.cache.RedisCacheManager
- RedisCacheManager(RedisCacheWriter, RedisCacheConfiguration, Map<String, RedisCacheConfiguration>, boolean) - Constructor for class org.springframework.data.redis.cache.RedisCacheManager
-
Deprecated.since 3.2. Use
RedisCacheManager(RedisCacheWriter, RedisCacheConfiguration, boolean, Map)
instead. - RedisCacheManager.RedisCacheManagerBuilder - Class in org.springframework.data.redis.cache
-
Builder for creating a
RedisCacheManager
. - RedisCacheWriter - Interface in org.springframework.data.redis.cache
-
RedisCacheWriter
provides low-level access to Redis commands (SET, SETNX, GET, EXPIRE,...
) used for caching. - RedisCacheWriter.TtlFunction - Interface in org.springframework.data.redis.cache
-
Function to compute the time to live from the cache
key
andvalue
. - RedisCallback<T> - Interface in org.springframework.data.redis.core
-
Callback interface for Redis 'low level' code.
- RedisClientInfo - Class in org.springframework.data.redis.core.types
-
RedisClientInfo
provides general and statistical information about client connections. - RedisClientInfo(Properties) - Constructor for class org.springframework.data.redis.core.types.RedisClientInfo
-
Create
RedisClientInfo
fromProperties
. - RedisClientInfo.INFO - Enum Class in org.springframework.data.redis.core.types
- RedisClientInfo.RedisClientInfoBuilder - Class in org.springframework.data.redis.core.types
- RedisClientInfoBuilder() - Constructor for class org.springframework.data.redis.core.types.RedisClientInfo.RedisClientInfoBuilder
- RedisClusterCallback<T> - Interface in org.springframework.data.redis.core
-
Callback interface for low level operations executed against a clustered Redis environment.
- RedisClusterCommands - Interface in org.springframework.data.redis.connection
-
Interface for the cluster commands supported by Redis.
- RedisClusterCommands.AddSlots - Enum Class in org.springframework.data.redis.connection
- RedisClusterCommandsProvider - Interface in org.springframework.data.redis.connection
-
Provides access to
RedisClusterCommands
and the segregated command interfaces. - RedisClusterConfiguration - Class in org.springframework.data.redis.connection
-
Configuration class used to set up a
RedisConnection
viaRedisConnectionFactory
for connecting to Redis Cluster. - RedisClusterConfiguration() - Constructor for class org.springframework.data.redis.connection.RedisClusterConfiguration
-
Creates a new, default
RedisClusterConfiguration
. - RedisClusterConfiguration(Collection<String>) - Constructor for class org.springframework.data.redis.connection.RedisClusterConfiguration
-
Creates a new
RedisClusterConfiguration
for givenhostPort
combinations. - RedisClusterConfiguration(PropertySource<?>) - Constructor for class org.springframework.data.redis.connection.RedisClusterConfiguration
-
Deprecated.since 3.3, use
RedisSentinelConfiguration.of(PropertySource)
instead. This constructor will be made private in the next major release. - RedisClusterConnection - Interface in org.springframework.data.redis.connection
-
RedisClusterConnection
allows sending commands to dedicated nodes within the cluster. - RedisClusterNode - Class in org.springframework.data.redis.connection
-
Representation of a Redis server within the cluster.
- RedisClusterNode() - Constructor for class org.springframework.data.redis.connection.RedisClusterNode
- RedisClusterNode(String) - Constructor for class org.springframework.data.redis.connection.RedisClusterNode
-
Creates new
RedisClusterNode
with an id and emptyRedisClusterNode.SlotRange
. - RedisClusterNode(String, int) - Constructor for class org.springframework.data.redis.connection.RedisClusterNode
-
Creates new
RedisClusterNode
with emptyRedisClusterNode.SlotRange
. - RedisClusterNode(String, int, RedisClusterNode.SlotRange) - Constructor for class org.springframework.data.redis.connection.RedisClusterNode
-
Creates new
RedisClusterNode
with givenRedisClusterNode.SlotRange
. - RedisClusterNode(RedisClusterNode.SlotRange) - Constructor for class org.springframework.data.redis.connection.RedisClusterNode
-
Creates new
RedisClusterNode
with givenRedisClusterNode.SlotRange
. - RedisClusterNode.Flag - Enum Class in org.springframework.data.redis.connection
- RedisClusterNode.LinkState - Enum Class in org.springframework.data.redis.connection
- RedisClusterNode.RedisClusterNodeBuilder - Class in org.springframework.data.redis.connection
-
Builder for creating new
RedisClusterNode
. - RedisClusterNode.SlotRange - Class in org.springframework.data.redis.connection
- RedisClusterNodeBuilder() - Constructor for class org.springframework.data.redis.connection.RedisClusterNode.RedisClusterNodeBuilder
- RedisClusterServerCommands - Interface in org.springframework.data.redis.connection
- RedisCollection<E> - Interface in org.springframework.data.redis.support.collections
-
Redis extension for the
Collection
contract. - RedisCollectionFactoryBean - Class in org.springframework.data.redis.support.collections
-
Factory bean that facilitates creation of Redis-based collections.
- RedisCollectionFactoryBean() - Constructor for class org.springframework.data.redis.support.collections.RedisCollectionFactoryBean
- RedisCollectionFactoryBean.CollectionType - Enum Class in org.springframework.data.redis.support.collections
-
Collection types supported by this factory.
- RedisCommand - Enum Class in org.springframework.data.redis.core
-
Enumeration
of well-known Redis commands. - RedisCommands - Interface in org.springframework.data.redis.connection
-
Interface defining the commands supported by Redis.
- RedisCommandsProvider - Interface in org.springframework.data.redis.connection
-
Provides access to
RedisCommands
and the segregated command interfaces. - RedisConfiguration - Interface in org.springframework.data.redis.connection
-
Marker interface for configuration classes related to Redis connection setup.
- RedisConfiguration.ClusterConfiguration - Interface in org.springframework.data.redis.connection
-
Configuration interface suitable for Redis cluster environments.
- RedisConfiguration.DomainSocketConfiguration - Interface in org.springframework.data.redis.connection
-
Configuration interface suitable for single node redis connections using local unix domain socket.
- RedisConfiguration.SentinelConfiguration - Interface in org.springframework.data.redis.connection
-
Configuration interface suitable for Redis Sentinel environments.
- RedisConfiguration.StaticMasterReplicaConfiguration - Interface in org.springframework.data.redis.connection
-
Configuration interface suitable for Redis master/replica environments with fixed hosts.
- RedisConfiguration.WithAuthentication - Interface in org.springframework.data.redis.connection
-
RedisConfiguration
part suitable for configurations that may use authentication when connecting. - RedisConfiguration.WithDatabaseIndex - Interface in org.springframework.data.redis.connection
-
RedisConfiguration
part suitable for configurations that use a specific database. - RedisConfiguration.WithDomainSocket - Interface in org.springframework.data.redis.connection
-
RedisConfiguration
part suitable for configurations that use native domain sockets for connecting. - RedisConfiguration.WithHostAndPort - Interface in org.springframework.data.redis.connection
-
RedisConfiguration
part suitable for configurations that use host/port combinations for connecting. - RedisConfiguration.WithPassword - Interface in org.springframework.data.redis.connection
-
RedisConfiguration
part suitable for configurations that may use authentication when connecting. - RedisConnection - Interface in org.springframework.data.redis.connection
-
A connection to a Redis server.
- RedisConnectionCommands - Interface in org.springframework.data.redis.connection
-
Connection-specific commands supported by Redis.
- RedisConnectionFactory - Interface in org.springframework.data.redis.connection
-
Thread-safe factory of Redis connections.
- RedisConnectionFailureException - Exception in org.springframework.data.redis
-
Fatal exception thrown when the Redis connection fails completely.
- RedisConnectionFailureException(String) - Constructor for exception org.springframework.data.redis.RedisConnectionFailureException
- RedisConnectionFailureException(String, Throwable) - Constructor for exception org.springframework.data.redis.RedisConnectionFailureException
- RedisConnectionUtils - Class in org.springframework.data.redis.core
-
Helper class that provides static methods for obtaining
RedisConnection
from aRedisConnectionFactory
. - RedisConnectionUtils() - Constructor for class org.springframework.data.redis.core.RedisConnectionUtils
- RedisConnectionUtils.RedisConnectionProxy - Interface in org.springframework.data.redis.core
-
Subinterface of
RedisConnection
to be implemented byRedisConnection
proxies. - RedisConverter - Interface in org.springframework.data.redis.core.convert
-
Redis specific
EntityConverter
. - redisCredentialsProviderFactory(RedisCredentialsProviderFactory) - Method in class org.springframework.data.redis.connection.lettuce.LettuceClientConfiguration.LettuceClientConfigurationBuilder
-
Configure a
RedisCredentialsProviderFactory
to obtainRedisCredentialsProvider
instances to support credential rotation. - redisCredentialsProviderFactory(RedisCredentialsProviderFactory) - Method in class org.springframework.data.redis.connection.lettuce.LettucePoolingClientConfiguration.LettucePoolingClientConfigurationBuilder
- RedisCredentialsProviderFactory - Interface in org.springframework.data.redis.connection.lettuce
-
Factory interface to create
RedisCredentialsProvider
from aRedisConfiguration
. - RedisCredentialsProviderFactory.AbsentRedisCredentials - Enum Class in org.springframework.data.redis.connection.lettuce
-
Default anonymous
RedisCredentials
without username/password. - RedisCustomConversions - Class in org.springframework.data.redis.core.convert
-
Value object to capture custom conversion.
- RedisCustomConversions() - Constructor for class org.springframework.data.redis.core.convert.RedisCustomConversions
-
Creates an empty
RedisCustomConversions
object. - RedisCustomConversions(List<?>) - Constructor for class org.springframework.data.redis.core.convert.RedisCustomConversions
-
Creates a new
RedisCustomConversions
instance registering the given converters. - RedisData - Class in org.springframework.data.redis.core.convert
-
Data object holding
Bucket
representing the domain object to be stored in a Redis hash. - RedisData() - Constructor for class org.springframework.data.redis.core.convert.RedisData
- RedisData(Map<byte[], byte[]>) - Constructor for class org.springframework.data.redis.core.convert.RedisData
- RedisData(Bucket) - Constructor for class org.springframework.data.redis.core.convert.RedisData
- RedisElementReader<T> - Interface in org.springframework.data.redis.serializer
-
Strategy interface that specifies a deserializer that can deserialize a binary element representation stored in Redis into an object.
- RedisElementWriter<T> - Interface in org.springframework.data.redis.serializer
-
Strategy interface that specifies a serializer that can serialize an element to its binary representation to be used as Redis protocol payload.
- RedisEntityInformation<T,
ID> - Interface in org.springframework.data.redis.repository.core - RedisGeoCommands - Interface in org.springframework.data.redis.connection
-
Geo-specific Redis commands.
- RedisGeoCommands.DistanceUnit - Enum Class in org.springframework.data.redis.connection
-
Metric
s supported by Redis. - RedisGeoCommands.GeoCommandArgs - Interface in org.springframework.data.redis.connection
-
Arguments to be used with
RedisGeoCommands
. - RedisGeoCommands.GeoCommandArgs.GeoCommandFlag - Interface in org.springframework.data.redis.connection
-
A flag to be used.
- RedisGeoCommands.GeoLocation<T> - Class in org.springframework.data.redis.connection
-
RedisGeoCommands.GeoLocation
representing aPoint
associated with a name. - RedisGeoCommands.GeoRadiusCommandArgs - Class in org.springframework.data.redis.connection
-
Additional arguments (like count/sort/...) to be used with
RedisGeoCommands
. - RedisGeoCommands.GeoRadiusCommandArgs.Flag - Enum Class in org.springframework.data.redis.connection
- RedisGeoCommands.GeoSearchCommandArgs - Class in org.springframework.data.redis.connection
-
Additional arguments (like count/sort/...) to be used with
RedisGeoCommands
. - RedisGeoCommands.GeoSearchStoreCommandArgs - Class in org.springframework.data.redis.connection
-
Additional arguments (like count/sort/...) to be used with
RedisGeoCommands
. - RedisHash - Annotation Interface in org.springframework.data.redis.core
-
RedisHash
marks Objects as aggregate roots to be stored in a Redis hash. - RedisHashCommands - Interface in org.springframework.data.redis.connection
-
Hash-specific commands supported by Redis.
- redisHints(Consumer<RuntimeHints>) - Static method in class org.springframework.data.redis.aot.RedisRuntimeHints
-
Get a
RuntimeHints
instance containing the ones for Redis. - RedisHyperLogLogCommands - Interface in org.springframework.data.redis.connection
-
HyperLogLog specific commands supported by Redis.
- RedisIndexDefinition - Class in org.springframework.data.redis.core.index
-
Base
IndexDefinition
implementation. - RedisIndexDefinition(String, String, String) - Constructor for class org.springframework.data.redis.core.index.RedisIndexDefinition
-
Creates new
RedisIndexDefinition
. - RedisIndexDefinition.CompositeValueTransformer - Class in org.springframework.data.redis.core.index
- RedisIndexDefinition.LowercaseIndexValueTransformer - Enum Class in org.springframework.data.redis.core.index
- RedisIndexDefinition.NoOpValueTransformer - Enum Class in org.springframework.data.redis.core.index
- RedisIndexDefinition.OrCondition<T> - Class in org.springframework.data.redis.core.index
- RedisIndexDefinition.PathCondition - Class in org.springframework.data.redis.core.index
- RedisInvalidSubscriptionException - Exception in org.springframework.data.redis.connection
-
Exception thrown when subscribing to an expired/dead
Subscription
. - RedisInvalidSubscriptionException(String) - Constructor for exception org.springframework.data.redis.connection.RedisInvalidSubscriptionException
-
Constructs a new
RedisInvalidSubscriptionException
instance. - RedisInvalidSubscriptionException(String, Throwable) - Constructor for exception org.springframework.data.redis.connection.RedisInvalidSubscriptionException
-
Constructs a new
RedisInvalidSubscriptionException
instance. - RedisKeyCommands - Interface in org.springframework.data.redis.connection
-
Key-specific commands supported by Redis.
- RedisKeyExpiredEvent<T> - Class in org.springframework.data.redis.core
-
RedisKeyExpiredEvent
is a Redis specificApplicationEvent
published when a particular key in Redis expires. - RedisKeyExpiredEvent(byte[]) - Constructor for class org.springframework.data.redis.core.RedisKeyExpiredEvent
-
Creates new
RedisKeyExpiredEvent
. - RedisKeyExpiredEvent(byte[], Object) - Constructor for class org.springframework.data.redis.core.RedisKeyExpiredEvent
-
Creates new
RedisKeyExpiredEvent
- RedisKeyExpiredEvent(String, byte[], Object) - Constructor for class org.springframework.data.redis.core.RedisKeyExpiredEvent
-
Creates new
RedisKeyExpiredEvent
- RedisKeyspaceEvent - Class in org.springframework.data.redis.core
-
Redis specific
ApplicationEvent
published when a key expires in Redis. - RedisKeyspaceEvent(byte[]) - Constructor for class org.springframework.data.redis.core.RedisKeyspaceEvent
-
Creates new
RedisKeyspaceEvent
. - RedisKeyspaceEvent(String, byte[]) - Constructor for class org.springframework.data.redis.core.RedisKeyspaceEvent
-
Creates new
RedisKeyspaceEvent
. - RedisKeyValueAdapter - Class in org.springframework.data.redis.core
-
Redis specific
KeyValueAdapter
implementation. - RedisKeyValueAdapter() - Constructor for class org.springframework.data.redis.core.RedisKeyValueAdapter
-
Default constructor.
- RedisKeyValueAdapter(RedisOperations<?, ?>) - Constructor for class org.springframework.data.redis.core.RedisKeyValueAdapter
-
Creates new
RedisKeyValueAdapter
with defaultRedisMappingContext
and defaultRedisCustomConversions
. - RedisKeyValueAdapter(RedisOperations<?, ?>, RedisConverter) - Constructor for class org.springframework.data.redis.core.RedisKeyValueAdapter
-
Creates new
RedisKeyValueAdapter
with specificRedisConverter
. - RedisKeyValueAdapter(RedisOperations<?, ?>, RedisMappingContext) - Constructor for class org.springframework.data.redis.core.RedisKeyValueAdapter
-
Creates new
RedisKeyValueAdapter
with defaultRedisCustomConversions
. - RedisKeyValueAdapter(RedisOperations<?, ?>, RedisMappingContext, CustomConversions) - Constructor for class org.springframework.data.redis.core.RedisKeyValueAdapter
-
Creates new
RedisKeyValueAdapter
. - RedisKeyValueAdapter.EnableKeyspaceEvents - Enum Class in org.springframework.data.redis.core
- RedisKeyValueAdapter.ShadowCopy - Enum Class in org.springframework.data.redis.core
-
Configuration flag controlling storage of phantom keys (shadow copies) of expiring entities to read them later when publishing
RedisKeyspaceEvent
. - RedisKeyValueAdapterBean - Class in org.springframework.data.redis.repository.cdi
-
CdiBean
to createRedisKeyValueAdapter
instances. - RedisKeyValueAdapterBean(Bean<RedisOperations<?, ?>>, Set<Annotation>, BeanManager) - Constructor for class org.springframework.data.redis.repository.cdi.RedisKeyValueAdapterBean
-
Creates a new
RedisKeyValueAdapterBean
. - RedisKeyValueCallback() - Constructor for class org.springframework.data.redis.core.RedisKeyValueTemplate.RedisKeyValueCallback
- RedisKeyValueTemplate - Class in org.springframework.data.redis.core
-
Redis specific implementation of
KeyValueTemplate
. - RedisKeyValueTemplate(RedisKeyValueAdapter, RedisMappingContext) - Constructor for class org.springframework.data.redis.core.RedisKeyValueTemplate
-
Create new
RedisKeyValueTemplate
. - RedisKeyValueTemplate.RedisKeyValueCallback<T> - Class in org.springframework.data.redis.core
-
Redis specific
KeyValueCallback
. - RedisKeyValueTemplateBean - Class in org.springframework.data.redis.repository.cdi
-
CdiBean
to createRedisKeyValueTemplate
instances. - RedisKeyValueTemplateBean(Bean<RedisKeyValueAdapter>, Set<Annotation>, BeanManager) - Constructor for class org.springframework.data.redis.repository.cdi.RedisKeyValueTemplateBean
-
Creates a new
RedisKeyValueTemplateBean
. - RedisList<E> - Interface in org.springframework.data.redis.support.collections
-
Redis extension for the
List
contract. - RedisListCommands - Interface in org.springframework.data.redis.connection
-
List-specific commands supported by Redis.
- RedisListCommands.Direction - Enum Class in org.springframework.data.redis.connection
-
List move direction.
- RedisListCommands.Position - Enum Class in org.springframework.data.redis.connection
-
List insertion position.
- RedisListenerExecutionFailedException - Exception in org.springframework.data.redis.listener.adapter
-
Exception thrown when the execution of a listener method failed.
- RedisListenerExecutionFailedException(String) - Constructor for exception org.springframework.data.redis.listener.adapter.RedisListenerExecutionFailedException
-
Constructs a new
RedisListenerExecutionFailedException
instance. - RedisListenerExecutionFailedException(String, Throwable) - Constructor for exception org.springframework.data.redis.listener.adapter.RedisListenerExecutionFailedException
-
Constructs a new
RedisListenerExecutionFailedException
instance. - RedisMap<K,
V> - Interface in org.springframework.data.redis.support.collections -
Map view of a Redis hash.
- RedisMappingContext - Class in org.springframework.data.redis.core.mapping
-
Redis specific
MappingContext
. - RedisMappingContext() - Constructor for class org.springframework.data.redis.core.mapping.RedisMappingContext
-
Creates new
RedisMappingContext
with emptyMappingConfiguration
. - RedisMappingContext(MappingConfiguration) - Constructor for class org.springframework.data.redis.core.mapping.RedisMappingContext
-
Creates new
RedisMappingContext
. - RedisMessageListenerContainer - Class in org.springframework.data.redis.listener
-
Container providing asynchronous behaviour for Redis message listeners.
- RedisMessageListenerContainer() - Constructor for class org.springframework.data.redis.listener.RedisMessageListenerContainer
- RedisNode - Class in org.springframework.data.redis.connection
- RedisNode() - Constructor for class org.springframework.data.redis.connection.RedisNode
- RedisNode(String, int) - Constructor for class org.springframework.data.redis.connection.RedisNode
- RedisNode.NodeType - Enum Class in org.springframework.data.redis.connection
- RedisNode.RedisNodeBuilder - Class in org.springframework.data.redis.connection
-
Builder for creating new
RedisNode
. - RedisNodeBuilder() - Constructor for class org.springframework.data.redis.connection.RedisNode.RedisNodeBuilder
- RedisObservation - Enum Class in org.springframework.data.redis.connection.lettuce.observability
-
Deprecated, for removal: This API element is subject to removal in a future version.since 3.4 for removal with the next major revision. Use Lettuce's Micrometer integration through
MicrometerTracing
. - RedisOperationChain - Class in org.springframework.data.redis.repository.query
-
Simple set of operations required to run queries against Redis.
- RedisOperationChain() - Constructor for class org.springframework.data.redis.repository.query.RedisOperationChain
- RedisOperationChain.NearPath - Class in org.springframework.data.redis.repository.query
- RedisOperationChain.PathAndValue - Class in org.springframework.data.redis.repository.query
- RedisOperations<K,
V> - Interface in org.springframework.data.redis.core -
Interface that specified a basic set of Redis operations, implemented by
RedisTemplate
. - RedisPartTreeQuery - Class in org.springframework.data.redis.repository.query
-
Redis-specific implementation of
KeyValuePartTreeQuery
supporting projections. - RedisPartTreeQuery(QueryMethod, QueryMethodEvaluationContextProvider, KeyValueOperations, Class<? extends AbstractQueryCreator<?, ?>>) - Constructor for class org.springframework.data.redis.repository.query.RedisPartTreeQuery
- RedisPassword - Class in org.springframework.data.redis.connection
-
Value object which may or may not contain a Redis password.
- RedisPersistentEntity<T> - Interface in org.springframework.data.redis.core.mapping
-
Redis specific
PersistentEntity
. - RedisPersistentProperty - Class in org.springframework.data.redis.core.mapping
-
Redis specific
PersistentProperty
implementation. - RedisPersistentProperty(Property, PersistentEntity<?, RedisPersistentProperty>, SimpleTypeHolder) - Constructor for class org.springframework.data.redis.core.mapping.RedisPersistentProperty
-
Creates new
RedisPersistentProperty
. - RedisPipelineException - Exception in org.springframework.data.redis.connection
-
Exception thrown when executing/closing a pipeline that contains one or multiple invalid/incorrect statements.
- RedisPipelineException(Exception) - Constructor for exception org.springframework.data.redis.connection.RedisPipelineException
-
Constructs a new
RedisPipelineException
instance using a default message and an empty pipeline result list. - RedisPipelineException(Exception, List<Object>) - Constructor for exception org.springframework.data.redis.connection.RedisPipelineException
-
Constructs a new
RedisPipelineException
instance using a default message. - RedisPipelineException(String, Throwable, List<Object>) - Constructor for exception org.springframework.data.redis.connection.RedisPipelineException
-
Constructs a new
RedisPipelineException
instance. - RedisPipelineException(String, List<Object>) - Constructor for exception org.springframework.data.redis.connection.RedisPipelineException
-
Constructs a new
RedisPipelineException
instance. - RedisProperties - Class in org.springframework.data.redis.support.collections
-
Properties
extension for a Redis back-store. - RedisProperties(String, RedisOperations<String, ?>) - Constructor for class org.springframework.data.redis.support.collections.RedisProperties
-
Constructs a new
RedisProperties
instance. - RedisProperties(Properties, String, RedisOperations<String, ?>) - Constructor for class org.springframework.data.redis.support.collections.RedisProperties
-
Constructs a new
RedisProperties
instance. - RedisProperties(Properties, BoundHashOperations<String, String, String>) - Constructor for class org.springframework.data.redis.support.collections.RedisProperties
-
Constructs a new
RedisProperties
instance. - RedisProperties(BoundHashOperations<String, String, String>) - Constructor for class org.springframework.data.redis.support.collections.RedisProperties
-
Constructs a new
RedisProperties
instance. - RedisPubSubCommands - Interface in org.springframework.data.redis.connection
-
PubSub-specific Redis commands.
- RedisQueryCreator - Class in org.springframework.data.redis.repository.query
-
AbstractQueryCreator
implementation for Redis. - RedisQueryCreator(PartTree, ParameterAccessor) - Constructor for class org.springframework.data.redis.repository.query.RedisQueryCreator
- RedisRepositoriesRegistrar - Class in org.springframework.data.redis.repository.configuration
-
Redis specific
ImportBeanDefinitionRegistrar
. - RedisRepositoriesRegistrar() - Constructor for class org.springframework.data.redis.repository.configuration.RedisRepositoriesRegistrar
- RedisRepositoryBean<T> - Class in org.springframework.data.redis.repository.cdi
-
CdiRepositoryBean
to create Redis repository instances. - RedisRepositoryBean(Bean<KeyValueOperations>, Set<Annotation>, Class<T>, BeanManager, CustomRepositoryImplementationDetector) - Constructor for class org.springframework.data.redis.repository.cdi.RedisRepositoryBean
-
Creates a new
CdiRepositoryBean
. - RedisRepositoryConfigurationExtension - Class in org.springframework.data.redis.repository.configuration
-
RepositoryConfigurationExtension
for Redis. - RedisRepositoryConfigurationExtension() - Constructor for class org.springframework.data.redis.repository.configuration.RedisRepositoryConfigurationExtension
- RedisRepositoryExtension - Class in org.springframework.data.redis.repository.cdi
-
CDI extension to export Redis repositories.
- RedisRepositoryExtension() - Constructor for class org.springframework.data.redis.repository.cdi.RedisRepositoryExtension
- RedisRepositoryFactory - Class in org.springframework.data.redis.repository.support
-
RepositoryFactorySupport
specific of handing RedisKeyValueRepository
. - RedisRepositoryFactory(KeyValueOperations) - Constructor for class org.springframework.data.redis.repository.support.RedisRepositoryFactory
- RedisRepositoryFactory(KeyValueOperations, Class<? extends AbstractQueryCreator<?, ?>>) - Constructor for class org.springframework.data.redis.repository.support.RedisRepositoryFactory
- RedisRepositoryFactory(KeyValueOperations, Class<? extends AbstractQueryCreator<?, ?>>, Class<? extends RepositoryQuery>) - Constructor for class org.springframework.data.redis.repository.support.RedisRepositoryFactory
- RedisRepositoryFactoryBean<T extends Repository<S,
ID>, S, ID> - Class in org.springframework.data.redis.repository.support -
Adapter for Springs
FactoryBean
interface to allow easy setup ofRedisRepositoryFactory
via Spring configuration. - RedisRepositoryFactoryBean(Class<? extends T>) - Constructor for class org.springframework.data.redis.repository.support.RedisRepositoryFactoryBean
-
Creates a new
RedisRepositoryFactoryBean
for the given repository interface. - RedisRuntimeHints - Class in org.springframework.data.redis.aot
-
RuntimeHintsRegistrar
for Redis operations and repository support. - RedisRuntimeHints() - Constructor for class org.springframework.data.redis.aot.RedisRuntimeHints
- RedisScript<T> - Interface in org.springframework.data.redis.core.script
-
A script to be executed using the Redis scripting support available as of version 2.6
- RedisScriptingCommands - Interface in org.springframework.data.redis.connection
-
Scripting commands.
- RedisSentinelCommands - Interface in org.springframework.data.redis.connection
-
Redis Sentinel-specific commands.
- RedisSentinelConfiguration - Class in org.springframework.data.redis.connection
-
Configuration
class used to set up aRedisConnection
withRedisConnectionFactory
for connecting to Redis Sentinel(s). - RedisSentinelConfiguration() - Constructor for class org.springframework.data.redis.connection.RedisSentinelConfiguration
-
Creates a new, default
RedisSentinelConfiguration
. - RedisSentinelConfiguration(String, Set<String>) - Constructor for class org.springframework.data.redis.connection.RedisSentinelConfiguration
-
Creates a new
RedisSentinelConfiguration
for givenhostPort
combinations. - RedisSentinelConfiguration(PropertySource<?>) - Constructor for class org.springframework.data.redis.connection.RedisSentinelConfiguration
-
Deprecated.since 3.3, use
RedisSentinelConfiguration.of(PropertySource)
instead. This constructor will be made private in the next major release. - RedisSentinelConnection - Interface in org.springframework.data.redis.connection
- RedisSerializationContext<K,
V> - Interface in org.springframework.data.redis.serializer -
Serialization context for reactive use.
- RedisSerializationContext.RedisSerializationContextBuilder<K,
V> - Interface in org.springframework.data.redis.serializer -
Builder for
RedisSerializationContext
. - RedisSerializationContext.SerializationPair<T> - Interface in org.springframework.data.redis.serializer
-
Typed serialization tuple.
- RedisSerializer<T> - Interface in org.springframework.data.redis.serializer
-
Basic interface serialization and deserialization of Objects to byte arrays (binary data).
- RedisServer - Class in org.springframework.data.redis.connection
- RedisServer(String, int) - Constructor for class org.springframework.data.redis.connection.RedisServer
- RedisServer(String, int, Properties) - Constructor for class org.springframework.data.redis.connection.RedisServer
- RedisServer.INFO - Enum Class in org.springframework.data.redis.connection
- RedisServerCommands - Interface in org.springframework.data.redis.connection
-
Server-specific commands supported by Redis.
- RedisServerCommands.FlushOption - Enum Class in org.springframework.data.redis.connection
- RedisServerCommands.MigrateOption - Enum Class in org.springframework.data.redis.connection
- RedisServerCommands.ShutdownOption - Enum Class in org.springframework.data.redis.connection
- RedisSet<E> - Interface in org.springframework.data.redis.support.collections
-
Redis extension for the
Set
contract. - RedisSetCommands - Interface in org.springframework.data.redis.connection
-
Set-specific commands supported by Redis.
- RedisSocketConfiguration - Class in org.springframework.data.redis.connection
-
Configuration class used for setting up
RedisConnection
viaRedisConnectionFactory
connecting to single Redis using a local unix domain socket. - RedisSocketConfiguration() - Constructor for class org.springframework.data.redis.connection.RedisSocketConfiguration
-
Create a new default
RedisSocketConfiguration
. - RedisSocketConfiguration(String) - Constructor for class org.springframework.data.redis.connection.RedisSocketConfiguration
-
Create a new
RedisSocketConfiguration
givensocket
. - RedisStandaloneConfiguration - Class in org.springframework.data.redis.connection
-
Configuration class used to set up a
RedisConnection
withRedisConnectionFactory
for connecting to a single node Redis instance. - RedisStandaloneConfiguration() - Constructor for class org.springframework.data.redis.connection.RedisStandaloneConfiguration
-
Create a new default
RedisStandaloneConfiguration
. - RedisStandaloneConfiguration(String) - Constructor for class org.springframework.data.redis.connection.RedisStandaloneConfiguration
-
Create a new
RedisStandaloneConfiguration
givenhostName
. - RedisStandaloneConfiguration(String, int) - Constructor for class org.springframework.data.redis.connection.RedisStandaloneConfiguration
- RedisStaticMasterReplicaConfiguration - Class in org.springframework.data.redis.connection
-
Configuration class used for setting up
RedisConnection
viaRedisConnectionFactory
using the provided Master / Replica configuration to nodes know to not change address. - RedisStaticMasterReplicaConfiguration(String) - Constructor for class org.springframework.data.redis.connection.RedisStaticMasterReplicaConfiguration
-
Create a new
RedisConfiguration.StaticMasterReplicaConfiguration
givenhostName
. - RedisStaticMasterReplicaConfiguration(String, int) - Constructor for class org.springframework.data.redis.connection.RedisStaticMasterReplicaConfiguration
- RedisStore - Interface in org.springframework.data.redis.support.collections
-
Basic interface for Redis-based collections.
- RedisStreamCommands - Interface in org.springframework.data.redis.connection
-
Stream-specific Redis commands.
- RedisStreamCommands.XAddOptions - Class in org.springframework.data.redis.connection
-
Additional options applicable for XADD command.
- RedisStreamCommands.XClaimOptions - Class in org.springframework.data.redis.connection
- RedisStreamCommands.XClaimOptions.XClaimOptionsBuilder - Class in org.springframework.data.redis.connection
- RedisStreamCommands.XPendingOptions - Class in org.springframework.data.redis.connection
-
Value Object holding parameters for obtaining pending messages.
- RedisStringCommands - Interface in org.springframework.data.redis.connection
-
String/Value-specific commands supported by Redis.
- RedisStringCommands.BitOperation - Enum Class in org.springframework.data.redis.connection
- RedisStringCommands.SetOption - Enum Class in org.springframework.data.redis.connection
-
SET
command arguments forNX
,XX
. - RedisSubscribedConnectionException - Exception in org.springframework.data.redis.connection
-
Exception thrown when issuing commands on a connection that is subscribed and waiting for events.
- RedisSubscribedConnectionException(String) - Constructor for exception org.springframework.data.redis.connection.RedisSubscribedConnectionException
-
Constructs a new
RedisSubscribedConnectionException
instance. - RedisSubscribedConnectionException(String, Throwable) - Constructor for exception org.springframework.data.redis.connection.RedisSubscribedConnectionException
-
Constructs a new
RedisSubscribedConnectionException
instance. - RedisSystemException - Exception in org.springframework.data.redis
-
Exception thrown when we can't classify a Redis exception into one of Spring generic data access exceptions.
- RedisSystemException(String, Throwable) - Constructor for exception org.springframework.data.redis.RedisSystemException
- RedisTemplate<K,
V> - Class in org.springframework.data.redis.core -
Helper class that simplifies Redis data access code.
- RedisTemplate() - Constructor for class org.springframework.data.redis.core.RedisTemplate
-
Constructs a new
RedisTemplate
instance. - redisTemplateRef() - Element in annotation interface org.springframework.data.redis.repository.configuration.EnableRedisRepositories
-
Configures the bean name of the
RedisOperations
to be used. - RedisTxCommands - Interface in org.springframework.data.redis.connection
-
Transaction/Batch specific commands supported by Redis.
- RedisTypeMapper - Interface in org.springframework.data.redis.core.convert
-
Redis-specific
TypeMapper
exposing thatBucket.BucketPropertyPath
s might contain a type key. - RedisZSet<E> - Interface in org.springframework.data.redis.support.collections
-
Redis ZSet (or sorted set (by weight)).
- RedisZSetCommands - Interface in org.springframework.data.redis.connection
-
ZSet(SortedSet)-specific commands supported by Redis.
- RedisZSetCommands.Limit - Class in org.springframework.data.redis.connection
-
Deprecated.since 3.0, use
Limit
instead. - RedisZSetCommands.Range - Class in org.springframework.data.redis.connection
-
Deprecated.since 3.0, use
Range
orRedisZSetCommands.Range.toRange()
instead. - RedisZSetCommands.Range.Boundary - Class in org.springframework.data.redis.connection
-
Deprecated.
- RedisZSetCommands.ZAddArgs - Class in org.springframework.data.redis.connection
-
ZADD
specific arguments. - RedisZSetCommands.ZAddArgs.Flag - Enum Class in org.springframework.data.redis.connection
- refcount(byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.keyCommands()
. - refcount(byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- refcount(byte[]) - Method in interface org.springframework.data.redis.connection.RedisKeyCommands
-
Get the number of references of the value associated with the specified
key
. - refcount(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- refcount(String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get the number of references of the value associated with the specified
key
. - refcount(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
-
Get the number of references of the value associated with the specified
key
. - ReferenceResolver - Interface in org.springframework.data.redis.core.convert
-
ReferenceResolver
retrieves Objects marked withReference
from Redis. - ReferenceResolverImpl - Class in org.springframework.data.redis.core.convert
-
ReferenceResolver
usingRedisKeyValueAdapter
to read raw data. - ReferenceResolverImpl(RedisOperations<?, ?>) - Constructor for class org.springframework.data.redis.core.convert.ReferenceResolverImpl
- refreshTtl(boolean) - Method in class org.springframework.data.redis.core.PartialUpdate
-
Set indicator for updating expiration time of target.
- register(StreamMessageListenerContainer.StreamReadRequest<K>, StreamListener<K, V>) - Method in interface org.springframework.data.redis.stream.StreamMessageListenerContainer
-
Register a new subscription for a Redis Stream.
- registerBeansForRoot(BeanDefinitionRegistry, RepositoryConfigurationSource) - Method in class org.springframework.data.redis.repository.configuration.RedisRepositoryConfigurationExtension
- registerDefaultConverters(ConverterRegistry) - Static method in class org.springframework.data.redis.cache.RedisCacheConfiguration
-
Registers default cache
key converters
. - registerHints(RuntimeHints, ClassLoader) - Method in class org.springframework.data.redis.aot.RedisRuntimeHints
- registerNullValueSerializer(boolean) - Method in class org.springframework.data.redis.serializer.GenericJackson2JsonRedisSerializer.GenericJackson2JsonRedisSerializerBuilder
-
Configure whether to register a
serializer
forNullValue
serialization. - registerNullValueSerializer(ObjectMapper, String) - Static method in class org.springframework.data.redis.serializer.GenericJackson2JsonRedisSerializer
-
Register
GenericJackson2JsonRedisSerializer.NullValueSerializer
in the givenObjectMapper
with an optionaltypeHintPropertyName
. - release(StatefulConnection<?, ?>) - Method in interface org.springframework.data.redis.connection.lettuce.LettuceConnectionProvider
-
Release the
connection
. - releaseAsync(StatefulConnection<?, ?>) - Method in interface org.springframework.data.redis.connection.lettuce.LettuceConnectionProvider
-
Release asynchronously the
connection
. - releaseConnection(RedisConnection, RedisConnectionFactory) - Static method in class org.springframework.data.redis.core.RedisConnectionUtils
-
Closes the given
RedisConnection
, created via the given factory if not managed externally (i.e. not bound to the transaction). - remainingCapacity() - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- remove() - Method in class org.springframework.data.redis.core.ConvertingCursor
- remove() - Method in class org.springframework.data.redis.core.ScanCursor
- remove() - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- remove(int) - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- remove(long, long) - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
- remove(long, long) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
-
Remove elements in range between
start
andend
from sorted set. - remove(long, Object) - Method in interface org.springframework.data.redis.core.BoundListOperations
-
Removes the first
count
occurrences ofvalue
from the list stored at the bound key. - remove(H, Object...) - Method in interface org.springframework.data.redis.core.ReactiveHashOperations
-
Delete given hash
hashKeys
from the hash at key. - remove(Object) - Method in class org.springframework.data.redis.connection.util.ByteArraySet
- remove(Object) - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- remove(Object) - Method in class org.springframework.data.redis.support.collections.DefaultRedisMap
- remove(Object) - Method in class org.springframework.data.redis.support.collections.DefaultRedisSet
- remove(Object) - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
- remove(Object) - Method in class org.springframework.data.redis.support.collections.RedisProperties
- remove(Object...) - Method in interface org.springframework.data.redis.core.BoundSetOperations
-
Remove given
values
from set at the bound key and return the number of removed elements. - remove(Object...) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Remove
values
from sorted set. - remove(Object, Object) - Method in class org.springframework.data.redis.support.collections.DefaultRedisMap
- remove(Object, Object) - Method in class org.springframework.data.redis.support.collections.RedisProperties
- remove(String) - Method in class org.springframework.data.redis.connection.jedis.JedisSentinelConnection
- remove(String) - Method in class org.springframework.data.redis.connection.lettuce.LettuceSentinelConnection
- remove(String) - Method in class org.springframework.data.redis.core.convert.Bucket
-
Remove the property at property dot
path
. - remove(String, byte[]) - Method in interface org.springframework.data.redis.cache.RedisCacheWriter
-
Remove the given key from Redis.
- remove(K, long, Object) - Method in interface org.springframework.data.redis.core.ListOperations
-
Removes the first
count
occurrences ofvalue
from the list stored atkey
. - remove(K, long, Object) - Method in interface org.springframework.data.redis.core.ReactiveListOperations
-
Removes the first
count
occurrences ofvalue
from the list stored atkey
. - remove(K, Object...) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
-
Remove given
values
from set atkey
and return the number of removed elements. - remove(K, Object...) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Remove
values
from sorted set. - remove(K, Object...) - Method in interface org.springframework.data.redis.core.SetOperations
-
Remove given
values
from set atkey
and return the number of removed elements. - remove(K, Object...) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Remove
values
from sorted set. - remove(K, M...) - Method in interface org.springframework.data.redis.core.GeoOperations
-
Remove the members.
- remove(K, M...) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
-
Remove the members.
- remove(M...) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
-
Remove the members.
- remove(NamedNode) - Method in class org.springframework.data.redis.connection.jedis.JedisSentinelConnection
- remove(NamedNode) - Method in class org.springframework.data.redis.connection.lettuce.LettuceSentinelConnection
- remove(NamedNode) - Method in interface org.springframework.data.redis.connection.RedisSentinelCommands
-
Removes given master.
- remove(Subscription) - Method in interface org.springframework.data.redis.stream.StreamMessageListenerContainer
-
Unregister a given
Subscription
from the container. - removeAll(Collection<?>) - Method in class org.springframework.data.redis.connection.util.ByteArraySet
- removeAll(Collection<?>) - Method in class org.springframework.data.redis.support.collections.AbstractRedisCollection
- removeByLex(Range<String>) - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
- removeByLex(Range<String>) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
-
Remove all elements in range.
- removeByScore(double, double) - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
- removeByScore(double, double) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
-
Remove elements with scores between
min
andmax
from sorted set with the bound key. - removeFirst() - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- removeFirst() - Method in interface org.springframework.data.redis.support.collections.RedisList
- removeFirstOccurrence(Object) - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- RemoveIndexedData - Class in org.springframework.data.redis.core.convert
-
RemoveIndexedData
represents a removed index entry from a secondary index for a property path in a given keyspace. - removeLast() - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- removeLast() - Method in interface org.springframework.data.redis.support.collections.RedisList
- removeLastOccurrence(Object) - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- removeMessageListener(MessageListener) - Method in class org.springframework.data.redis.listener.RedisMessageListenerContainer
-
Removes the given message listener completely (from all topics).
- removeMessageListener(MessageListener, Collection<? extends Topic>) - Method in class org.springframework.data.redis.listener.RedisMessageListenerContainer
-
Removes a message listener from the given topics.
- removeMessageListener(MessageListener, Topic) - Method in class org.springframework.data.redis.listener.RedisMessageListenerContainer
-
Removes a message listener from the given topic.
- removeRange(long, long) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Remove elements in range between
start
andend
from sorted set with the bound key. - removeRange(K, long, long) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Remove elements in range between
start
andend
from sorted set withkey
. - removeRange(K, Range<Long>) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Remove elements in range between
start
andend
from sorted set withkey
. - removeRangeByLex(K, Range<String>) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Remove elements in range from sorted set with
key
. - removeRangeByLex(K, Range<String>) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Remove elements in
Range
from sorted set with key. - removeRangeByLex(K, RedisZSetCommands.Range) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Deprecated, for removal: This API element is subject to removal in a future version.since 3.0. Please use
ZSetOperations.removeRangeByLex(Object, Range)
instead; - removeRangeByLex(Range<String>) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Remove elements in
Range
from sorted set with the bound key. - removeRangeByLex(RedisZSetCommands.Range) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Deprecated, for removal: This API element is subject to removal in a future version.since 3.0. Please use
BoundZSetOperations.removeRangeByLex(Range)
. - removeRangeByScore(double, double) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Remove elements with scores between
min
andmax
from sorted set with the bound key. - removeRangeByScore(K, double, double) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Remove elements with scores between
min
andmax
from sorted set withkey
. - removeRangeByScore(K, Range<Double>) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Remove elements with scores between
min
andmax
from sorted set withkey
. - rename(byte[], byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.keyCommands()
. - rename(byte[], byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- rename(byte[], byte[]) - Method in interface org.springframework.data.redis.connection.RedisKeyCommands
-
Rename key
oldKey
tonewKey
. - rename(String) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicDouble
- rename(String) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicInteger
- rename(String) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicLong
- rename(String) - Method in class org.springframework.data.redis.support.collections.AbstractRedisCollection
- rename(String) - Method in class org.springframework.data.redis.support.collections.DefaultRedisMap
- rename(String) - Method in class org.springframework.data.redis.support.collections.RedisProperties
- rename(String, String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- rename(String, String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Rename key
oldKey
tonewKey
. - rename(ByteBuffer, ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
-
Rename key oldKey to newKey.
- rename(K) - Method in interface org.springframework.data.redis.core.BoundKeyOperations
-
Renames the key.
- rename(K, K) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
-
Rename key
oldKey
tonewKey
. - rename(K, K) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
- rename(K, K) - Method in interface org.springframework.data.redis.core.RedisOperations
-
Rename key
oldKey
tonewKey
. - rename(K, K) - Method in class org.springframework.data.redis.core.RedisTemplate
- rename(Publisher<ReactiveKeyCommands.RenameCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
-
Rename key oldKey to newKey.
- RENAME - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- renameIfAbsent(K, K) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
-
Rename key
oldKey
tonewKey
only ifnewKey
does not exist. - renameIfAbsent(K, K) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
- renameIfAbsent(K, K) - Method in interface org.springframework.data.redis.core.RedisOperations
-
Rename key
oldKey
tonewKey
only ifnewKey
does not exist. - renameIfAbsent(K, K) - Method in class org.springframework.data.redis.core.RedisTemplate
- renameNX(byte[], byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.keyCommands()
. - renameNX(byte[], byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- renameNX(byte[], byte[]) - Method in interface org.springframework.data.redis.connection.RedisKeyCommands
-
Rename key
oldKey
tonewKey
only ifnewKey
does not exist. - renameNX(String, String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- renameNX(String, String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Rename key
oldKey
tonewKey
only ifnewKey
does not exist. - renameNX(ByteBuffer, ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
-
Rename key oldKey to newKey only if newKey does not exist.
- renameNX(Publisher<ReactiveKeyCommands.RenameCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
-
Rename key oldKey to newKey only if newKey does not exist.
- RENAMENX - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- replace(boolean) - Method in class org.springframework.data.redis.connection.ReactiveKeyCommands.CopyCommand
-
Applies
replace
. - replace(Object, Object) - Method in class org.springframework.data.redis.support.collections.RedisProperties
- replace(Object, Object, Object) - Method in class org.springframework.data.redis.support.collections.RedisProperties
- replace(K, V) - Method in class org.springframework.data.redis.support.collections.DefaultRedisMap
- replace(K, V, V) - Method in class org.springframework.data.redis.support.collections.DefaultRedisMap
- REPLACE - Enum constant in enum class org.springframework.data.redis.connection.RedisServerCommands.MigrateOption
- REPLICA - Enum constant in enum class org.springframework.data.redis.connection.RedisClusterNode.Flag
- REPLICA - Enum constant in enum class org.springframework.data.redis.connection.RedisNode.NodeType
- replicaOf(String) - Method in class org.springframework.data.redis.connection.RedisClusterNode.RedisClusterNodeBuilder
- replicaOf(String) - Method in class org.springframework.data.redis.connection.RedisNode.RedisNodeBuilder
-
Set the id of the master node.
- replicaOf(String, int) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.serverCommands()
. - replicaOf(String, int) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- replicaOf(String, int) - Method in interface org.springframework.data.redis.connection.RedisServerCommands
-
Change redis replication setting to new master.
- replicaOf(String, int) - Method in interface org.springframework.data.redis.core.RedisOperations
-
Change redis replication setting to new master.
- replicaOf(String, int) - Method in class org.springframework.data.redis.core.RedisTemplate
- REPLICAOF - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- replicaOfNoOne() - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.serverCommands()
. - replicaOfNoOne() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- replicaOfNoOne() - Method in interface org.springframework.data.redis.connection.RedisServerCommands
-
Change server into master.
- replicaOfNoOne() - Method in interface org.springframework.data.redis.core.RedisOperations
-
Change server into master.
- replicaOfNoOne() - Method in class org.springframework.data.redis.core.RedisTemplate
- replicas(String) - Method in class org.springframework.data.redis.connection.jedis.JedisSentinelConnection
- replicas(NamedNode) - Method in class org.springframework.data.redis.connection.jedis.JedisSentinelConnection
- replicas(NamedNode) - Method in class org.springframework.data.redis.connection.lettuce.LettuceSentinelConnection
- replicas(NamedNode) - Method in interface org.springframework.data.redis.connection.RedisSentinelCommands
-
Show list of replicas for given master.
- repositoryBaseClass() - Element in annotation interface org.springframework.data.redis.repository.configuration.EnableRedisRepositories
-
Configure the repository base class to be used to create repository proxies for this particular configuration.
- repositoryFactoryBeanClass() - Element in annotation interface org.springframework.data.redis.repository.configuration.EnableRedisRepositories
-
Returns the
FactoryBean
class to be used for each repository instance. - repositoryImplementationPostfix() - Element in annotation interface org.springframework.data.redis.repository.configuration.EnableRedisRepositories
-
Returns the postfix to be used when looking up custom repository implementations.
- requireNonNull(T, String, Object...) - Static method in class org.springframework.data.redis.util.RedisAssertions
-
Deprecated.Asserts the given
Object
is not null. - requireNonNull(T, Supplier<String>) - Static method in class org.springframework.data.redis.util.RedisAssertions
-
Deprecated.Asserts the given
Object
is not null. - requireNonNull(T, RedisAssertions.RuntimeExceptionSupplier) - Static method in class org.springframework.data.redis.util.RedisAssertions
-
Deprecated.
- requiresArguments() - Method in enum class org.springframework.data.redis.core.RedisCommand
- requiresExactNumberOfArguments() - Method in enum class org.springframework.data.redis.core.RedisCommand
- requireState(T, String, Object...) - Static method in class org.springframework.data.redis.util.RedisAssertions
-
Deprecated.Asserts the given
Object
is not null. - requireState(T, Supplier<String>) - Static method in class org.springframework.data.redis.util.RedisAssertions
-
Deprecated.Asserts the given
Object
is not null. - reset(String) - Method in interface org.springframework.data.redis.cache.CacheStatisticsCollector
-
Reset the all counters and gauges of for the given cache.
- resetConfigStats() - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.serverCommands()
. - resetConfigStats() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- resetConfigStats() - Method in interface org.springframework.data.redis.connection.ReactiveServerCommands
-
Reset statistic counters on server.
- resetConfigStats() - Method in interface org.springframework.data.redis.connection.RedisServerCommands
-
Reset statistic counters on server.
- resetConfigStats(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.DefaultedRedisClusterConnection
-
Deprecated.in favor of
RedisCommandsProvider.serverCommands()
. - resetConfigStats(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.ReactiveClusterServerCommands
-
Reset statistic counters on server.
- resetConfigStats(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.RedisClusterServerCommands
- resetConnection() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
Reset the underlying shared Connection, to be reinitialized on next access.
- reshard(RedisClusterNode, int, RedisClusterNode) - Method in interface org.springframework.data.redis.core.ClusterOperations
-
Move slot assignment from one source to target node and copy keys associated with the slot.
- resolveIndex(String, String, PersistentProperty<?>, Object) - Method in class org.springframework.data.redis.core.convert.PathIndexResolver
- resolveIndexesFor(String, String, TypeInformation<?>, Object) - Method in class org.springframework.data.redis.core.convert.CompositeIndexResolver
- resolveIndexesFor(String, String, TypeInformation<?>, Object) - Method in interface org.springframework.data.redis.core.convert.IndexResolver
-
Resolves all indexes for given type information / value combination.
- resolveIndexesFor(String, String, TypeInformation<?>, Object) - Method in class org.springframework.data.redis.core.convert.PathIndexResolver
- resolveIndexesFor(String, String, TypeInformation<?>, Object) - Method in class org.springframework.data.redis.core.convert.SpelIndexResolver
- resolveIndexesFor(TypeInformation<?>, Object) - Method in class org.springframework.data.redis.core.convert.CompositeIndexResolver
- resolveIndexesFor(TypeInformation<?>, Object) - Method in interface org.springframework.data.redis.core.convert.IndexResolver
-
Resolves all indexes for given type information / value combination.
- resolveIndexesFor(TypeInformation<?>, Object) - Method in class org.springframework.data.redis.core.convert.PathIndexResolver
- resolveIndexesFor(TypeInformation<?>, Object) - Method in class org.springframework.data.redis.core.convert.SpelIndexResolver
- resolveReference(Object, String) - Method in interface org.springframework.data.redis.core.convert.ReferenceResolver
- resolveReference(Object, String) - Method in class org.springframework.data.redis.core.convert.ReferenceResolverImpl
- resolveType(byte[], Class<?>) - Method in class org.springframework.data.redis.serializer.GenericJackson2JsonRedisSerializer
- restore(byte[], long, byte[]) - Method in interface org.springframework.data.redis.connection.RedisKeyCommands
- restore(byte[], long, byte[], boolean) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.keyCommands()
. - restore(byte[], long, byte[], boolean) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- restore(byte[], long, byte[], boolean) - Method in interface org.springframework.data.redis.connection.RedisKeyCommands
- restore(K, byte[], long, TimeUnit) - Method in interface org.springframework.data.redis.core.RedisOperations
- restore(K, byte[], long, TimeUnit, boolean) - Method in interface org.springframework.data.redis.core.RedisOperations
- restore(K, byte[], long, TimeUnit, boolean) - Method in class org.springframework.data.redis.core.RedisTemplate
-
Executes the Redis restore command.
- RESTORE - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- resultsAsList() - Method in class org.springframework.data.redis.connection.ClusterCommandExecutor.MultiNodeResult
-
Get
List
of all individualClusterCommandExecutor.NodeResult.value
. - resultsAsListSortBy(byte[]...) - Method in class org.springframework.data.redis.connection.ClusterCommandExecutor.MultiNodeResult
-
Get
List
of all individualClusterCommandExecutor.NodeResult.value
. - retainAll(Collection<?>) - Method in class org.springframework.data.redis.connection.util.ByteArraySet
- retrieve(Object) - Method in class org.springframework.data.redis.cache.RedisCache
- retrieve(Object, Supplier<CompletableFuture<T>>) - Method in class org.springframework.data.redis.cache.RedisCache
- retrieve(String, byte[]) - Method in interface org.springframework.data.redis.cache.RedisCacheWriter
- retrieve(String, byte[], Duration) - Method in interface org.springframework.data.redis.cache.RedisCacheWriter
-
Asynchronously retrieves the
value
to which theRedisCache
maps the givenkey
setting theTTL expiration
for the cache entry. - retryCount(long) - Method in class org.springframework.data.redis.connection.RedisStreamCommands.XClaimOptions
-
Set the retry counter to the specified value.
- returnPropertyIfBetterIdPropertyCandidateOrNull(RedisPersistentProperty) - Method in class org.springframework.data.redis.core.mapping.BasicRedisPersistentEntity
- returnResourceForSpecificNode(RedisClusterNode, Object) - Method in interface org.springframework.data.redis.connection.ClusterNodeResourceProvider
-
Return the resource object for the given node.
- returnsRawValue() - Method in interface org.springframework.data.redis.core.script.RedisScript
- ReturnType - Enum Class in org.springframework.data.redis.connection
-
Represents a data type returned from Redis, currently used to denote the expected return type of Redis scripting commands
- reversed() - Method in interface org.springframework.data.redis.support.collections.RedisList
-
Returns a reverse-ordered view of this collection.
- reverseIndexOf(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRankCommand
-
Creates a new
ReactiveZSetCommands.ZIncrByCommand
given amember
to obtain its reversed rank (ordering high to low). - reverseRange(long, long) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Get elements in range from
start
toend
from sorted set ordered from high to low. - reverseRange(long, long) - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
- reverseRange(long, long) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
-
Get elements in range from
start
toend
from sorted set ordered from high to low. - reverseRange(Class<V>, K, Range<String>) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
-
Read records from a stream within a specific
Range
in reverse order asObjectRecord
. - reverseRange(Class<V>, K, Range<String>) - Method in interface org.springframework.data.redis.core.StreamOperations
-
Read records from a stream within a specific
Range
in reverse order asObjectRecord
. - reverseRange(Class<V>, K, Range<String>, Limit) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
-
Read records from a stream within a specific
Range
applying aLimit
in reverse order asObjectRecord
. - reverseRange(Class<V>, K, Range<String>, Limit) - Method in interface org.springframework.data.redis.core.StreamOperations
-
Read records from a stream within a specific
Range
applying aLimit
in reverse order asObjectRecord
. - reverseRange(K, long, long) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Get elements in range from
start
toend
from sorted set ordered from high to low. - reverseRange(K, Range<Long>) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Get elements in range from
start
toend
from sorted set ordered from high to low. - reverseRange(K, Range<String>) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
-
Read records from a stream within a specific
Range
in reverse order. - reverseRange(K, Range<String>) - Method in interface org.springframework.data.redis.core.StreamOperations
-
Read records from a stream within a specific
Range
in reverse order. - reverseRange(K, Range<String>, Limit) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
- reverseRange(K, Range<String>, Limit) - Method in interface org.springframework.data.redis.core.StreamOperations
- reverseRange(Range<String>) - Method in interface org.springframework.data.redis.core.BoundStreamOperations
-
Read records from a stream within a specific
Range
in reverse order. - reverseRange(Range<String>, Limit) - Method in interface org.springframework.data.redis.core.BoundStreamOperations
- reverseRangeAndStoreByLex(String, Range<String>) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
-
Store all elements at
dstKey
with reverse lexicographical ordering from ZSET at the bound key with a value betweenRange.getLowerBound()
andRange.getUpperBound()
. - reverseRangeAndStoreByLex(String, Range<String>, Limit) - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
- reverseRangeAndStoreByLex(String, Range<String>, Limit) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
-
Store n elements at
dstKey
, where n =Limit.getCount()
, starting atLimit.getOffset()
with reverse lexicographical ordering from ZSET at the bound key with a value betweenRange.getLowerBound()
andRange.getUpperBound()
. - reverseRangeAndStoreByLex(K, K, Range<String>) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Store all elements at
dstKey
with reverse lexicographical ordering from ZSET atsrcKey
with a value betweenRange.getLowerBound()
andRange.getUpperBound()
. - reverseRangeAndStoreByLex(K, K, Range<String>) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Store all elements at
dstKey
with reverse lexicographical ordering from ZSET atsrcKey
with a value betweenRange.getLowerBound()
andRange.getUpperBound()
. - reverseRangeAndStoreByLex(K, K, Range<String>, Limit) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Store n elements at
dstKey
, where n =Limit.getCount()
, starting atLimit.getOffset()
with reverse lexicographical ordering from ZSET atsrcKey
with a value betweenRange.getLowerBound()
andRange.getUpperBound()
. - reverseRangeAndStoreByLex(K, K, Range<String>, Limit) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Store n elements at
dstKey
, where n =Limit.getCount()
, starting atLimit.getOffset()
with reverse lexicographical ordering from ZSET atsrcKey
with a value betweenRange.getLowerBound()
andRange.getUpperBound()
. - reverseRangeAndStoreByLex(K, Range<String>) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Store all elements at
dstKey
with reverse lexicographical ordering from ZSET at the bound key with a value betweenRange.getLowerBound()
andRange.getUpperBound()
. - reverseRangeAndStoreByLex(K, Range<String>, Limit) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Store n elements at
dstKey
, where n =Limit.getCount()
, starting atLimit.getOffset()
with reverse lexicographical ordering from ZSET at the bound key with a value betweenRange.getLowerBound()
andRange.getUpperBound()
. - reverseRangeAndStoreByScore(String, Range<? extends Number>) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
-
Store all elements at
dstKey
with reverse ordering by score from ZSET at the bound key with a score betweenRange.getLowerBound()
andRange.getUpperBound()
. - reverseRangeAndStoreByScore(String, Range<? extends Number>, Limit) - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
- reverseRangeAndStoreByScore(String, Range<? extends Number>, Limit) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
-
Store n elements at
dstKey
, where n =Limit.getCount()
, starting atLimit.getOffset()
with reverse ordering by score from ZSET at the bound key with a score betweenRange.getLowerBound()
andRange.getUpperBound()
. - reverseRangeAndStoreByScore(K, K, Range<? extends Number>) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Store all elements at
dstKey
with reverse ordering by score from ZSET atsrcKey
with a score betweenRange.getLowerBound()
andRange.getUpperBound()
. - reverseRangeAndStoreByScore(K, K, Range<? extends Number>, Limit) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Store n elements at
dstKey
, where n =Limit.getCount()
, starting atLimit.getOffset()
with reverse ordering by score from ZSET atsrcKey
with a score betweenRange.getLowerBound()
andRange.getUpperBound()
. - reverseRangeAndStoreByScore(K, K, Range<Double>) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Store all elements at
dstKey
with reverse ordering by score from ZSET atsrcKey
with a score betweenRange.getLowerBound()
andRange.getUpperBound()
. - reverseRangeAndStoreByScore(K, K, Range<Double>, Limit) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Store n elements at
dstKey
, where n =Limit.getCount()
, starting atLimit.getOffset()
with reverse ordering by score from ZSET atsrcKey
with a score betweenRange.getLowerBound()
andRange.getUpperBound()
. - reverseRangeAndStoreByScore(K, Range<? extends Number>) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Store all elements at
dstKey
with reverse ordering by score from ZSET at the bound key with a score betweenRange.getLowerBound()
andRange.getUpperBound()
. - reverseRangeAndStoreByScore(K, Range<? extends Number>, Limit) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Store n elements at
dstKey
, where n =Limit.getCount()
, starting atLimit.getOffset()
with reverse ordering by score from ZSET at the bound key with a score betweenRange.getLowerBound()
andRange.getUpperBound()
. - reverseRangeByLex(K, Range<String>) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Get all elements with reverse lexicographical ordering from ZSET at
key
with a value betweenRange.getLowerBound()
andRange.getUpperBound()
. - reverseRangeByLex(K, Range<String>) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Get all elements with reverse lexicographical ordering from ZSET at
key
with a value betweenRange.getLowerBound()
andRange.getUpperBound()
. - reverseRangeByLex(K, Range<String>, Limit) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Get all elements n elements, where n =
Limit.getCount()
, starting atLimit.getOffset()
with reverse lexicographical ordering from ZSET atkey
with a value betweenRange.getLowerBound()
andRange.getUpperBound()
. - reverseRangeByLex(K, Range<String>, Limit) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Get all elements n elements, where n =
Limit.getCount()
, starting atLimit.getOffset()
with reverse lexicographical ordering from ZSET atkey
with a value betweenRange.getLowerBound()
andRange.getUpperBound()
. - reverseRangeByLex(K, RedisZSetCommands.Range) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Deprecated, for removal: This API element is subject to removal in a future version.since 3.0. Please use
ZSetOperations.reverseRangeByLex(Object, Range)
- reverseRangeByLex(K, RedisZSetCommands.Range, Limit) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Deprecated, for removal: This API element is subject to removal in a future version.since 3.0. Please use
ZSetOperations.reverseRangeByLex(Object, Range, Limit)
instead. - reverseRangeByLex(Range<String>) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Get all elements with reverse lexicographical ordering with a value between
Range.getLowerBound()
andRange.getUpperBound()
. - reverseRangeByLex(Range<String>) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
-
Get all elements with reverse lexicographical ordering with a value between
Range.getLowerBound()
andRange.getUpperBound()
. - reverseRangeByLex(Range<String>, Limit) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Get all elements n elements, where n =
Limit.getCount()
, starting atLimit.getOffset()
with reverse lexicographical ordering having a value betweenRange.getLowerBound()
andRange.getUpperBound()
. - reverseRangeByLex(Range<String>, Limit) - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
- reverseRangeByLex(Range<String>, Limit) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
-
Get all elements n elements, where n =
Limit.getCount()
, starting atLimit.getOffset()
with reverse lexicographical ordering having a value betweenRange.getLowerBound()
andRange.getUpperBound()
. - reverseRangeByLex(RedisZSetCommands.Range) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Deprecated, for removal: This API element is subject to removal in a future version.since 3.0. Please use
BoundZSetOperations.reverseRangeByLex(Range)
instead. - reverseRangeByLex(RedisZSetCommands.Range) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
-
Deprecated, for removal: This API element is subject to removal in a future version.since 3.0. Please use
RedisZSet.reverseRangeByLex(Range, Limit)
instead. - reverseRangeByLex(RedisZSetCommands.Range, Limit) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Deprecated, for removal: This API element is subject to removal in a future version.since 3.0. Please use
BoundZSetOperations.reverseRangeByLex(Range, Limit)
instead. - reverseRangeByLex(RedisZSetCommands.Range, Limit) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
-
Deprecated, for removal: This API element is subject to removal in a future version.since 3.0. Please use
RedisZSet.reverseRangeByLex(Range, Limit)
instead. - reverseRangeByScore(double, double) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Get elements where score is between
min
andmax
from sorted set ordered from high to low. - reverseRangeByScore(double, double) - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
- reverseRangeByScore(double, double) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
-
Get elements where score is between
min
andmax
from sorted set ordered from high to low. - reverseRangeByScore(K, double, double) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Get elements where score is between
min
andmax
from sorted set ordered from high to low. - reverseRangeByScore(K, double, double, long, long) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Get elements in range from
start
toend
where score is betweenmin
andmax
from sorted set ordered high -> low. - reverseRangeByScore(K, Range<Double>) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Get elements where score is between
min
andmax
from sorted set ordered from high to low. - reverseRangeByScore(K, Range<Double>, Limit) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Get elements in range from
start
toend
where score is betweenmin
andmax
from sorted set ordered high -> low. - reverseRangeByScoreWithScores(double, double) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
- reverseRangeByScoreWithScores(double, double) - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
- reverseRangeByScoreWithScores(double, double) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
- reverseRangeByScoreWithScores(K, double, double) - Method in interface org.springframework.data.redis.core.ZSetOperations
- reverseRangeByScoreWithScores(K, double, double, long, long) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Get set of
Tuple
in range fromstart
toend
where score is betweenmin
andmax
from sorted set ordered high -> low. - reverseRangeByScoreWithScores(K, Range<Double>) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- reverseRangeByScoreWithScores(K, Range<Double>, Limit) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Get set of
Tuple
in range fromstart
toend
where score is betweenmin
andmax
from sorted set ordered high -> low. - reverseRangeWithScores(long, long) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
- reverseRangeWithScores(long, long) - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
- reverseRangeWithScores(long, long) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
- reverseRangeWithScores(K, long, long) - Method in interface org.springframework.data.redis.core.ZSetOperations
- reverseRangeWithScores(K, Range<Long>) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- reverseRank(Object) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Determine the index of element with
value
in a sorted set when scored high to low. - reverseRank(Object) - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
- reverseRank(Object) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
-
Returns the rank (position) of the given element in the set, in descending order.
- reverseRank(K, Object) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Determine the index of element with
value
in a sorted set when scored high to low. - reverseRank(K, Object) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Determine the index of element with
value
in a sorted set when scored high to low. - reverseScoresWithin(Range<Double>) - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRangeByScoreCommand
-
Creates a new
ReactiveZSetCommands.ZRangeByScoreCommand
given aRange
to obtain elements ordered from the highest to the lowest score. - reverseScoreWithin(Range<Double>) - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRangeStoreCommand
-
Creates a new
ReactiveZSetCommands.ZRangeStoreCommand
given aRange
to obtain elements ordered from the highest to the lowest score. - reverseStringsWithin(Range<String>) - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRangeByLexCommand
-
Creates a new
ReactiveZSetCommands.ZRangeByLexCommand
given aRange
ofString
to obtain elements in reverse lexicographical ordering. - reverseValuesWithin(Range<Long>) - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRangeCommand
-
Creates a new
ReactiveZSetCommands.ZRangeCommand
given aRange
to obtain elements ordered from the highest to the lowest score. - reverseValueWithin(Range<String>) - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRangeStoreCommand
-
Creates a new
ReactiveZSetCommands.ZRangeStoreCommand
given aRange
to obtain elements ordered from the highest to the lowest lexicographical value. - rewriteConfig() - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.serverCommands()
. - rewriteConfig() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- rewriteConfig() - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
- rewriteConfig() - Method in interface org.springframework.data.redis.connection.RedisServerCommands
-
Rewrites the
redis.conf
file. - rewriteConfig(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.DefaultedRedisClusterConnection
-
Deprecated.in favor of
RedisCommandsProvider.serverCommands()
. - rewriteConfig(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.RedisClusterServerCommands
- right() - Static method in class org.springframework.data.redis.connection.ReactiveListCommands.BPopCommand
-
Creates a new
ReactiveListCommands.BPopCommand
for right push (BRPOP). - right() - Static method in class org.springframework.data.redis.connection.ReactiveListCommands.PopCommand
-
Creates a new
ReactiveListCommands.PopCommand
for right push (RPOP). - right() - Static method in class org.springframework.data.redis.connection.ReactiveListCommands.PushCommand
-
Creates a new
ReactiveListCommands.PushCommand
for right push (RPUSH). - RIGHT - Enum constant in enum class org.springframework.data.redis.connection.ReactiveListCommands.Direction
- RIGHT - Enum constant in enum class org.springframework.data.redis.connection.RedisListCommands.Direction
- rightPop() - Method in interface org.springframework.data.redis.core.BoundListOperations
-
Removes and returns last element in list stored at the bound key.
- rightPop(long) - Method in interface org.springframework.data.redis.core.BoundListOperations
-
Removes and returns last elements in list stored at
key
. - rightPop(long, TimeUnit) - Method in interface org.springframework.data.redis.core.BoundListOperations
-
Removes and returns last element from lists stored at the bound key.
- rightPop(Duration) - Method in interface org.springframework.data.redis.core.BoundListOperations
-
Removes and returns last element from lists stored at the bound key.
- rightPop(K) - Method in interface org.springframework.data.redis.core.ListOperations
-
Removes and returns last element in list stored at
key
. - rightPop(K) - Method in interface org.springframework.data.redis.core.ReactiveListOperations
-
Removes and returns last element in list stored at
key
. - rightPop(K, long) - Method in interface org.springframework.data.redis.core.ListOperations
-
Removes and returns last elements in list stored at
key
. - rightPop(K, long) - Method in interface org.springframework.data.redis.core.ReactiveListOperations
-
Removes
count
elements from the right-side of the Redis list stored at key. - rightPop(K, long, TimeUnit) - Method in interface org.springframework.data.redis.core.ListOperations
-
Removes and returns last element from lists stored at
key
. - rightPop(K, Duration) - Method in interface org.springframework.data.redis.core.ListOperations
-
Removes and returns last element from lists stored at
key
. - rightPop(K, Duration) - Method in interface org.springframework.data.redis.core.ReactiveListOperations
-
Removes and returns last element from lists stored at
key
. - rightPopAndLeftPush(K, K) - Method in interface org.springframework.data.redis.core.ListOperations
-
Remove the last element from list at
sourceKey
, append it todestinationKey
and return its value. - rightPopAndLeftPush(K, K) - Method in interface org.springframework.data.redis.core.ReactiveListOperations
-
Remove the last element from list at
sourceKey
, append it todestinationKey
and return its value. - rightPopAndLeftPush(K, K, long, TimeUnit) - Method in interface org.springframework.data.redis.core.ListOperations
-
Remove the last element from list at
sourceKey
, append it todestinationKey
and return its value.
Blocks connection until element available ortimeout
reached. - rightPopAndLeftPush(K, K, Duration) - Method in interface org.springframework.data.redis.core.ListOperations
-
Remove the last element from list at
sourceKey
, append it todestinationKey
and return its value.
Blocks connection until element available ortimeout
reached. - rightPopAndLeftPush(K, K, Duration) - Method in interface org.springframework.data.redis.core.ReactiveListOperations
-
Remove the last element from list at
srcKey
, append it todstKey
and return its value.
Results return once an element available ortimeout
reached. - rightPush(K, V) - Method in interface org.springframework.data.redis.core.ListOperations
-
Append
value
tokey
. - rightPush(K, V) - Method in interface org.springframework.data.redis.core.ReactiveListOperations
-
Append
value
tokey
. - rightPush(K, V, V) - Method in interface org.springframework.data.redis.core.ListOperations
-
Insert
value
tokey
afterpivot
. - rightPush(K, V, V) - Method in interface org.springframework.data.redis.core.ReactiveListOperations
-
Insert
value
tokey
afterpivot
. - rightPush(V) - Method in interface org.springframework.data.redis.core.BoundListOperations
-
Append
value
to the bound key. - rightPush(V, V) - Method in interface org.springframework.data.redis.core.BoundListOperations
-
Append
values
to the bound key beforevalue
. - rightPushAll(K, Collection<V>) - Method in interface org.springframework.data.redis.core.ListOperations
-
Append
values
tokey
. - rightPushAll(K, Collection<V>) - Method in interface org.springframework.data.redis.core.ReactiveListOperations
-
Append
values
tokey
. - rightPushAll(K, V...) - Method in interface org.springframework.data.redis.core.ListOperations
-
Append
values
tokey
. - rightPushAll(K, V...) - Method in interface org.springframework.data.redis.core.ReactiveListOperations
-
Append
values
tokey
. - rightPushAll(V...) - Method in interface org.springframework.data.redis.core.BoundListOperations
-
Append
values
to the bound key. - rightPushIfPresent(K, V) - Method in interface org.springframework.data.redis.core.ListOperations
-
Append
values
tokey
only if the list exists. - rightPushIfPresent(K, V) - Method in interface org.springframework.data.redis.core.ReactiveListOperations
-
Append
values
tokey
only if the list exists. - rightPushIfPresent(V) - Method in interface org.springframework.data.redis.core.BoundListOperations
-
Append
values
to the bound key only if the list exists. - ROLE_REPORTED - Enum constant in enum class org.springframework.data.redis.connection.RedisServer.INFO
- ROLE_REPORTED_TIME - Enum constant in enum class org.springframework.data.redis.connection.RedisServer.INFO
- roleReportedTime() - Method in class org.springframework.data.redis.connection.RedisServer
- rPop(byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.listCommands()
}. - rPop(byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- rPop(byte[]) - Method in interface org.springframework.data.redis.connection.RedisListCommands
-
Removes and returns last element in list stored at
key
. - rPop(byte[], long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.listCommands()
}. - rPop(byte[], long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- rPop(byte[], long) - Method in interface org.springframework.data.redis.connection.RedisListCommands
-
Removes and returns last elements in list stored at
key
. - rPop(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- rPop(String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Removes and returns last element in list stored at
key
. - rPop(String, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- rPop(String, long) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Removes and returns last elements in list stored at
key
. - rPop(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveListCommands
-
Removes and returns last element in list stored at key.
- rPop(ByteBuffer, long) - Method in interface org.springframework.data.redis.connection.ReactiveListCommands
-
Removes and returns last
count
elements in list stored at key. - RPOP - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- rPopLPush(byte[], byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.listCommands()
}. - rPopLPush(byte[], byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- rPopLPush(byte[], byte[]) - Method in interface org.springframework.data.redis.connection.RedisListCommands
-
Remove the last element from list at
srcKey
, append it todstKey
and return its value. - rPopLPush(String, String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- rPopLPush(String, String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Remove the last element from list at
srcKey
, append it todstKey
and return its value. - rPopLPush(ByteBuffer, ByteBuffer) - 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.
- rPopLPush(Publisher<ReactiveListCommands.RPopLPushCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveListCommands
-
Remove the last element from list at
ReactiveRedisConnection.KeyCommand.getKey()
, append it toReactiveListCommands.RPopLPushCommand.getDestination()
and return its value. - RPOPLPUSH - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- rPush(byte[], byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.listCommands()
}. - rPush(byte[], byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- rPush(byte[], byte[]...) - Method in interface org.springframework.data.redis.connection.RedisListCommands
-
Append
values
tokey
. - rPush(String, String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- rPush(String, String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Append
values
tokey
. - rPush(ByteBuffer, List<ByteBuffer>) - Method in interface org.springframework.data.redis.connection.ReactiveListCommands
-
Append values to key.
- RPUSH - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- rPushX(byte[], byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.listCommands()
}. - rPushX(byte[], byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- rPushX(byte[], byte[]) - Method in interface org.springframework.data.redis.connection.RedisListCommands
-
Append
values
tokey
only if the list exists. - rPushX(String, String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- rPushX(String, String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Append
values
tokey
only if the list exists. - rPushX(ByteBuffer, ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveListCommands
-
Append values to key only if key already exists.
- RPUSHX - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- RUN_ID - Enum constant in enum class org.springframework.data.redis.connection.RedisServer.INFO
- RUNNING - Enum constant in enum class org.springframework.data.redis.stream.Task.State
S
- sAdd(byte[], byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.setCommands()
}. - sAdd(byte[], byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- sAdd(byte[], byte[]...) - Method in interface org.springframework.data.redis.connection.RedisSetCommands
-
Add given
values
to set atkey
. - sAdd(String, String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- sAdd(String, String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Add given
values
to set atkey
. - sAdd(ByteBuffer, ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveSetCommands
-
Add given value to set at key.
- sAdd(ByteBuffer, Collection<ByteBuffer>) - Method in interface org.springframework.data.redis.connection.ReactiveSetCommands
-
Add given values to set at key.
- sAdd(Publisher<ReactiveSetCommands.SAddCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveSetCommands
-
Add given
ReactiveSetCommands.SAddCommand.getValues()
to set atReactiveRedisConnection.KeyCommand.getKey()
. - SADD - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- SAT - Enum constant in enum class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldIncrBy.Overflow
- save() - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.serverCommands()
. - save() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- save() - Method in interface org.springframework.data.redis.connection.ReactiveServerCommands
-
Synchronous save current db snapshot on server.
- save() - Method in interface org.springframework.data.redis.connection.RedisServerCommands
-
Synchronous save current db snapshot on server.
- save(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.DefaultedRedisClusterConnection
-
Deprecated.in favor of
RedisCommandsProvider.serverCommands()
. - save(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.ReactiveClusterServerCommands
-
Synchronous save current db snapshot on server.
- save(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.RedisClusterServerCommands
- save(RedisClusterNode) - Method in interface org.springframework.data.redis.core.ClusterOperations
-
Synchronous save current db snapshot on server.
- SAVE - Enum constant in enum class org.springframework.data.redis.connection.RedisServerCommands.ShutdownOption
- SAVE - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- scan() - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
-
Use a
Flux
to iterate over keys. - scan() - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
-
Use a
Flux
to iterate over keys. - scan() - Method in class org.springframework.data.redis.support.collections.DefaultRedisMap
- scan() - Method in class org.springframework.data.redis.support.collections.DefaultRedisSet
- scan() - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
- scan() - Method in interface org.springframework.data.redis.support.collections.RedisMap
- scan() - Method in class org.springframework.data.redis.support.collections.RedisProperties
- scan() - Method in interface org.springframework.data.redis.support.collections.RedisSet
- scan() - Method in interface org.springframework.data.redis.support.collections.RedisZSet
- scan(int) - Static method in class org.springframework.data.redis.cache.BatchStrategies
-
A
BatchStrategy
using aSCAN
cursors and potentially multipleDEL
commands to remove all matching keys. - scan(H) - Method in interface org.springframework.data.redis.core.ReactiveHashOperations
-
Use a
Flux
to iterate over entries in the hash atkey
. - scan(H, ScanOptions) - Method in interface org.springframework.data.redis.core.HashOperations
-
Use a
Cursor
to iterate over entries in hash atkey
. - scan(H, ScanOptions) - Method in interface org.springframework.data.redis.core.ReactiveHashOperations
- scan(K) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
-
Use a
Flux
to iterate over entries in the set atkey
. - scan(K) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Use a
Flux
to iterate over entries in the sorted set atkey
. - scan(K, ScanOptions) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
- scan(K, ScanOptions) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- scan(K, ScanOptions) - Method in interface org.springframework.data.redis.core.SetOperations
-
Use a
Cursor
to iterate over entries set atkey
. - scan(K, ScanOptions) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Use a
Cursor
to iterate over entries zset atkey
. - scan(RedisClusterNode, ScanOptions) - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
- scan(RedisClusterNode, ScanOptions) - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
- scan(RedisClusterNode, ScanOptions) - Method in interface org.springframework.data.redis.connection.RedisClusterConnection
-
Use a
Cursor
to iterate over keys. - scan(KeyScanOptions) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
-
Use a
Flux
to iterate over keys. - scan(KeyScanOptions) - Method in interface org.springframework.data.redis.connection.RedisKeyCommands
-
Use a
Cursor
to iterate over keys. - scan(ScanOptions) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.keyCommands()
. - scan(ScanOptions) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- scan(ScanOptions) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
-
Use a
Flux
to iterate over keys. - scan(ScanOptions) - Method in interface org.springframework.data.redis.connection.RedisKeyCommands
-
Use a
Cursor
to iterate over keys. - scan(ScanOptions) - Method in interface org.springframework.data.redis.core.BoundHashOperations
-
Use a
Cursor
to iterate over entries in hash at the bound key. - scan(ScanOptions) - Method in interface org.springframework.data.redis.core.BoundSetOperations
-
Use a
Cursor
to iterate over entries in set atkey
. - scan(ScanOptions) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Use a
Cursor
to iterate over entries in zset at the bound key. - scan(ScanOptions) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
-
Use a
Flux
to iterate over keys. - scan(ScanOptions) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
- scan(ScanOptions) - Method in interface org.springframework.data.redis.core.RedisOperations
-
Use a
Cursor
to iterate over keys. - scan(ScanOptions) - Method in class org.springframework.data.redis.core.RedisTemplate
- scan(ScanOptions) - Method in class org.springframework.data.redis.support.collections.DefaultRedisSet
- scan(ScanOptions) - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
- SCAN - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- ScanCursor<T> - Class in org.springframework.data.redis.core
-
Redis client agnostic
Cursor
implementation continuously loading additional results from Redis server until reaching its starting pointzero
. - ScanCursor() - Constructor for class org.springframework.data.redis.core.ScanCursor
-
Crates new
ScanCursor
with an initial cursor andScanOptions.NONE
- ScanCursor(long) - Constructor for class org.springframework.data.redis.core.ScanCursor
-
Deprecated.since 3.3.0 - Use
ScanCursor(CursorId)
instead. - ScanCursor(long, ScanOptions) - Constructor for class org.springframework.data.redis.core.ScanCursor
-
Deprecated.since 3.3.0 - Use
ScanCursor(CursorId, ScanOptions)
instead. - ScanCursor(Cursor.CursorId) - Constructor for class org.springframework.data.redis.core.ScanCursor
-
Crates new
ScanCursor
withScanOptions.NONE
- ScanCursor(Cursor.CursorId, ScanOptions) - Constructor for class org.springframework.data.redis.core.ScanCursor
-
Crates new
ScanCursor
- ScanCursor(ScanOptions) - Constructor for class org.springframework.data.redis.core.ScanCursor
-
Crates new
ScanCursor
with an initial cursor. - ScanIteration<T> - Class in org.springframework.data.redis.core
-
ScanIteration
holds the values contained in Redis Multibulk reply on exectuting SCAN command. - ScanIteration(long, Collection<T>) - Constructor for class org.springframework.data.redis.core.ScanIteration
-
Deprecated.
- ScanIteration(Cursor.CursorId, Collection<T>) - Constructor for class org.springframework.data.redis.core.ScanIteration
- scanOptions() - Static method in class org.springframework.data.redis.core.ScanOptions
-
Static factory method that returns a new
ScanOptions.ScanOptionsBuilder
. - scanOptions(DataType) - Static method in class org.springframework.data.redis.core.KeyScanOptions
-
Static factory method that returns a new
ScanOptions.ScanOptionsBuilder
. - ScanOptions - Class in org.springframework.data.redis.core
-
Options to be used for with SCAN commands.
- ScanOptions.ScanOptionsBuilder - Class in org.springframework.data.redis.core
- sCard(byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.setCommands()
}. - sCard(byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- sCard(byte[]) - Method in interface org.springframework.data.redis.connection.RedisSetCommands
-
Get size of set at
key
. - sCard(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- sCard(String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get size of set at
key
. - sCard(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveSetCommands
-
Get size of set at key.
- sCard(Publisher<ReactiveRedisConnection.KeyCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveSetCommands
-
Get size of set at
ReactiveRedisConnection.KeyCommand.getKey()
. - SCARD - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- score(Object) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Get the score of element with
value
from sorted set with key the bound key. - score(Object) - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
- score(Object) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
-
Returns the score of the given element.
- score(Object...) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Get the scores of elements with
values
from sorted set with key the bound key. - score(K, Object) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Get the score of element with
value
from sorted set with keykey
. - score(K, Object) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Get the score of element with
value
from sorted set with keykey
. - score(K, Object...) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Get the scores of elements with
values
from sorted set with keykey
. - score(K, Object...) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Get the scores of elements with
values
from sorted set with keykey
. - scoredValuesToTupleList() - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
- scoreOf(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZIncrByCommand
-
Creates a new
ReactiveZSetCommands.ZIncrByCommand
given amember
. - scoreOf(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZMScoreCommand
-
Creates a new
ReactiveZSetCommands.ZMScoreCommand
given amember
. - scoreOf(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZScoreCommand
-
Creates a new
ReactiveZSetCommands.ZScoreCommand
given amember
. - scoreOf(Collection<ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZMScoreCommand
-
Creates a new
ReactiveZSetCommands.ZMScoreCommand
given amembers
. - scoresWithin(Range<Double>) - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZCountCommand
-
Creates a new
ReactiveZSetCommands.ZCountCommand
given aRange
. - scoresWithin(Range<Double>) - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRangeByScoreCommand
-
Creates a new
ReactiveZSetCommands.ZRangeByScoreCommand
given aRange
to obtain elements ordered from the lowest to the highest score. - scoresWithin(Range<Double>) - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRemRangeByScoreCommand
-
Creates a new
ReactiveZSetCommands.ZRemRangeByScoreCommand
given aRange
. - scoreWithin(Range<Double>) - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRangeStoreCommand
-
Creates a new
ReactiveZSetCommands.ZRangeStoreCommand
given aRange
to obtain elements ordered from the lowest to the highest score. - SCRIPT_EXISTS - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- SCRIPT_FLUSH - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- SCRIPT_KILL - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- SCRIPT_LOAD - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- scriptBytes(RedisScript<?>) - Method in class org.springframework.data.redis.core.script.DefaultReactiveScriptExecutor
- scriptBytes(RedisScript<?>) - Method in class org.springframework.data.redis.core.script.DefaultScriptExecutor
- ScriptExecutor<K> - Interface in org.springframework.data.redis.core.script
-
Executes
RedisScript
s - scriptExists(String) - Method in interface org.springframework.data.redis.connection.ReactiveScriptingCommands
-
Check if given
scriptSha
exist in script cache. - scriptExists(String...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.scriptingCommands()
. - scriptExists(String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- scriptExists(String...) - Method in interface org.springframework.data.redis.connection.RedisScriptingCommands
-
Check if given
scriptShas
exist in script cache. - scriptExists(List<String>) - Method in interface org.springframework.data.redis.connection.ReactiveScriptingCommands
-
Check if given
scriptShas
exist in script cache. - scriptFlush() - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.scriptingCommands()
. - scriptFlush() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- scriptFlush() - Method in interface org.springframework.data.redis.connection.ReactiveScriptingCommands
-
Flush lua script cache.
- scriptFlush() - Method in interface org.springframework.data.redis.connection.RedisScriptingCommands
-
Flush lua script cache.
- scriptingCommands() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- scriptingCommands() - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
- scriptingCommands() - Method in class org.springframework.data.redis.connection.jedis.JedisConnection
- scriptingCommands() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
- scriptingCommands() - Method in interface org.springframework.data.redis.connection.ReactiveRedisConnection
- scriptingCommands() - Method in interface org.springframework.data.redis.connection.RedisCommandsProvider
- ScriptingException - Exception in org.springframework.data.redis.core.script
-
RuntimeException
thrown when issues occur withRedisScript
s - ScriptingException(String) - Constructor for exception org.springframework.data.redis.core.script.ScriptingException
-
Constructs a new
ScriptingException
instance. - ScriptingException(String, Throwable) - Constructor for exception org.springframework.data.redis.core.script.ScriptingException
-
Constructs a new
ScriptingException
instance. - scriptKill() - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.scriptingCommands()
. - scriptKill() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- scriptKill() - Method in interface org.springframework.data.redis.connection.ReactiveScriptingCommands
-
Kill current lua script execution.
- scriptKill() - Method in interface org.springframework.data.redis.connection.RedisScriptingCommands
-
Kill current lua script execution.
- scriptLoad(byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.scriptingCommands()
. - scriptLoad(byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- scriptLoad(byte[]) - Method in interface org.springframework.data.redis.connection.RedisScriptingCommands
-
Load lua script into scripts cache, without executing it.
Execute the script by callingRedisScriptingCommands.evalSha(byte[], ReturnType, int, byte[]...)
. - scriptLoad(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- scriptLoad(String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Load lua script into scripts cache, without executing it.
Execute the script by callingDefaultedRedisConnection.evalSha(byte[], ReturnType, int, byte[]...)
. - scriptLoad(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveScriptingCommands
-
Load lua script into scripts cache, without executing it.
Execute the script by callingReactiveScriptingCommands.evalSha(String, ReturnType, int, ByteBuffer...)
. - sDiff(byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.setCommands()
}. - sDiff(byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- sDiff(byte[]...) - Method in interface org.springframework.data.redis.connection.RedisSetCommands
-
Diff all sets for given
keys
. - sDiff(String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- sDiff(String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Diff all sets for given
keys
. - sDiff(Collection<ByteBuffer>) - Method in interface org.springframework.data.redis.connection.ReactiveSetCommands
-
Returns the diff of the members of all given sets at keys.
- sDiff(Publisher<ReactiveSetCommands.SDiffCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveSetCommands
-
Returns the diff of the members of all given sets at
ReactiveSetCommands.SInterCommand.getKeys()
. - SDIFF - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- sDiffStore(byte[], byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.setCommands()
}. - sDiffStore(byte[], byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- sDiffStore(byte[], byte[]...) - Method in interface org.springframework.data.redis.connection.RedisSetCommands
-
Diff all sets for given
keys
and store result indestKey
. - sDiffStore(String, String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- sDiffStore(String, String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Diff all sets for given
keys
and store result indestKey
. - sDiffStore(ByteBuffer, Collection<ByteBuffer>) - Method in interface org.springframework.data.redis.connection.ReactiveSetCommands
-
Diff all given sets at keys and store result in destinationKey.
- sDiffStore(Publisher<ReactiveSetCommands.SDiffStoreCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveSetCommands
-
Diff all given sets at keys and store result in destinationKey.
- SDIFFSTORE - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- search(K, Circle) - Method in interface org.springframework.data.redis.core.GeoOperations
-
Get the members within the boundaries of a given
Circle
. - search(K, Circle) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
-
Get the members within the boundaries of a given
Circle
. - search(K, GeoReference<M>, Distance) - Method in interface org.springframework.data.redis.core.GeoOperations
-
Get the members using
GeoReference
as center of the query within the boundaries of a givenradius
. - search(K, GeoReference<M>, Distance) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
-
Get the members using
GeoReference
as center of the query within the boundaries of a givenradius
. - search(K, GeoReference<M>, Distance, RedisGeoCommands.GeoSearchCommandArgs) - Method in interface org.springframework.data.redis.core.GeoOperations
-
Get the members using
GeoReference
as center of the query within the boundaries of a givenradius
applyingRedisGeoCommands.GeoRadiusCommandArgs
. - search(K, GeoReference<M>, Distance, RedisGeoCommands.GeoSearchCommandArgs) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
-
Get the members using
GeoReference
as center of the query within the boundaries of a givenradius
applyingRedisGeoCommands.GeoRadiusCommandArgs
. - search(K, GeoReference<M>, BoundingBox) - Method in interface org.springframework.data.redis.core.GeoOperations
-
Get the members using
GeoReference
as center of the query within the boundaries of a given bounding box. - search(K, GeoReference<M>, BoundingBox) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
-
Get the members using
GeoReference
as center of the query within the boundaries of a given bounding box. - search(K, GeoReference<M>, BoundingBox, RedisGeoCommands.GeoSearchCommandArgs) - Method in interface org.springframework.data.redis.core.GeoOperations
-
Get the members using
GeoReference
as center of the query within the boundaries of a given bounding box applyingRedisGeoCommands.GeoRadiusCommandArgs
. - search(K, GeoReference<M>, BoundingBox, RedisGeoCommands.GeoSearchCommandArgs) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
-
Get the members using
GeoReference
as center of the query within the boundaries of a given bounding box applyingRedisGeoCommands.GeoRadiusCommandArgs
. - search(K, GeoReference<M>, GeoShape, RedisGeoCommands.GeoSearchCommandArgs) - Method in interface org.springframework.data.redis.core.GeoOperations
-
Get the members using
GeoReference
as center of the query within the boundaries of a givenpredicate
applyingRedisGeoCommands.GeoRadiusCommandArgs
. - search(K, GeoReference<M>, GeoShape, RedisGeoCommands.GeoSearchCommandArgs) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
-
Get the members using
GeoReference
as center of the query within the boundaries of a givenpredicate
applyingRedisGeoCommands.GeoRadiusCommandArgs
. - search(Circle) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
-
Get the members within the boundaries of a given
Circle
. - search(GeoReference<M>, Distance) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
-
Get the members using
GeoReference
as center of the query within the boundaries of a givenradius
. - search(GeoReference<M>, Distance, RedisGeoCommands.GeoSearchCommandArgs) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
-
Get the members using
GeoReference
as center of the query within the boundaries of a givenradius
applyingRedisGeoCommands.GeoRadiusCommandArgs
. - search(GeoReference<M>, BoundingBox) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
-
Get the members using
GeoReference
as center of the query within the boundaries of a given bounding box. - search(GeoReference<M>, BoundingBox, RedisGeoCommands.GeoSearchCommandArgs) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
-
Get the members using
GeoReference
as center of the query within the boundaries of a given bounding box applyingRedisGeoCommands.GeoRadiusCommandArgs
. - search(GeoReference<M>, GeoShape, RedisGeoCommands.GeoSearchCommandArgs) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
-
Get the members using
GeoReference
as center of the query within the boundaries of a givenpredicate
applyingRedisGeoCommands.GeoRadiusCommandArgs
. - searchAndStore(K, K, Circle) - Method in interface org.springframework.data.redis.core.GeoOperations
-
Get the members within the boundaries of a given
Circle
and store results atdestKey
. - searchAndStore(K, K, Circle) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
-
Get the members within the boundaries of a given
Circle
and store results atdestKey
. - searchAndStore(K, K, GeoReference<M>, Distance) - Method in interface org.springframework.data.redis.core.GeoOperations
-
Get the members using
GeoReference
as center of the query within the boundaries of a givenradius
and store results atdestKey
. - searchAndStore(K, K, GeoReference<M>, Distance) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
-
Get the members using
GeoReference
as center of the query within the boundaries of a givenradius
and store results atdestKey
. - searchAndStore(K, K, GeoReference<M>, Distance, RedisGeoCommands.GeoSearchStoreCommandArgs) - Method in interface org.springframework.data.redis.core.GeoOperations
-
Get the members using
GeoReference
as center of the query within the boundaries of a givenradius
applyingRedisGeoCommands.GeoRadiusCommandArgs
and store results atdestKey
. - searchAndStore(K, K, GeoReference<M>, Distance, RedisGeoCommands.GeoSearchStoreCommandArgs) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
-
Get the members using
GeoReference
as center of the query within the boundaries of a givenradius
applyingRedisGeoCommands.GeoRadiusCommandArgs
and store results atdestKey
. - searchAndStore(K, K, GeoReference<M>, BoundingBox) - Method in interface org.springframework.data.redis.core.GeoOperations
-
Get the members using
GeoReference
as center of the query within the boundaries of a given bounding box and store results atdestKey
. - searchAndStore(K, K, GeoReference<M>, BoundingBox) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
-
Get the members using
GeoReference
as center of the query within the boundaries of a given bounding box and store results atdestKey
. - searchAndStore(K, K, GeoReference<M>, BoundingBox, RedisGeoCommands.GeoSearchStoreCommandArgs) - Method in interface org.springframework.data.redis.core.GeoOperations
-
Get the members using
GeoReference
as center of the query within the boundaries of a given bounding box applyingRedisGeoCommands.GeoRadiusCommandArgs
and store results atdestKey
. - searchAndStore(K, K, GeoReference<M>, BoundingBox, RedisGeoCommands.GeoSearchStoreCommandArgs) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
-
Get the members using
GeoReference
as center of the query within the boundaries of a given bounding box applyingRedisGeoCommands.GeoRadiusCommandArgs
and store results atdestKey
. - searchAndStore(K, K, GeoReference<M>, GeoShape, RedisGeoCommands.GeoSearchStoreCommandArgs) - Method in interface org.springframework.data.redis.core.GeoOperations
-
Get the members using
GeoReference
as center of the query within the boundaries of a givenpredicate
applyingRedisGeoCommands.GeoRadiusCommandArgs
and store results atdestKey
. - searchAndStore(K, K, GeoReference<M>, GeoShape, RedisGeoCommands.GeoSearchStoreCommandArgs) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
-
Get the members using
GeoReference
as center of the query within the boundaries of a givenpredicate
applyingRedisGeoCommands.GeoRadiusCommandArgs
and store results atdestKey
. - searchAndStore(K, Circle) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
-
Get the members within the boundaries of a given
Circle
and store results atdestKey
. - searchAndStore(K, GeoReference<M>, Distance) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
-
Get the members using
GeoReference
as center of the query within the boundaries of a givenradius
and store results atdestKey
. - searchAndStore(K, GeoReference<M>, Distance, RedisGeoCommands.GeoSearchStoreCommandArgs) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
-
Get the members using
GeoReference
as center of the query within the boundaries of a givenradius
applyingRedisGeoCommands.GeoRadiusCommandArgs
and store results atdestKey
. - searchAndStore(K, GeoReference<M>, BoundingBox) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
-
Get the members using
GeoReference
as center of the query within the boundaries of a given bounding box and store results atdestKey
. - searchAndStore(K, GeoReference<M>, BoundingBox, RedisGeoCommands.GeoSearchStoreCommandArgs) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
-
Get the members using
GeoReference
as center of the query within the boundaries of a given bounding box applyingRedisGeoCommands.GeoRadiusCommandArgs
and store results atdestKey
. - searchAndStore(K, GeoReference<M>, GeoShape, RedisGeoCommands.GeoSearchStoreCommandArgs) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
-
Get the members using
GeoReference
as center of the query within the boundaries of a givenpredicate
applyingRedisGeoCommands.GeoRadiusCommandArgs
and store results atdestKey
. - seconds(long) - Static method in class org.springframework.data.redis.core.types.Expiration
-
Creates a new
Expiration
inTimeUnit.SECONDS
. - secondsToDuration(Long) - Static method in class org.springframework.data.redis.connection.convert.Converters
-
Convert the given nullable seconds to a
Duration
or null. - secondsToTimeUnit(long, TimeUnit) - Static method in class org.springframework.data.redis.connection.convert.Converters
-
Converts
seconds
to the givenTimeUnit
. - secondsToTimeUnit(TimeUnit) - Static method in class org.springframework.data.redis.connection.convert.Converters
- select(int) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- select(int) - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
- select(int) - Method in class org.springframework.data.redis.connection.jedis.JedisConnection
- select(int) - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
- select(int) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
- select(int) - Method in interface org.springframework.data.redis.connection.RedisConnectionCommands
-
Select the DB with given positive
dbIndex
. - SELECT - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- sentinel(String, Integer) - Method in class org.springframework.data.redis.connection.RedisSentinelConfiguration
- sentinel(RedisNode) - Method in class org.springframework.data.redis.connection.RedisSentinelConfiguration
- sentinelConfigurationToRedisURI(RedisSentinelConfiguration) - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
- SEPARATOR - Static variable in interface org.springframework.data.redis.cache.CacheKeyPrefix
-
Default separator.
- SerializationException - Exception in org.springframework.data.redis.serializer
-
Generic exception indicating a serialization/deserialization error.
- SerializationException(String) - Constructor for exception org.springframework.data.redis.serializer.SerializationException
-
Constructs a new
SerializationException
instance. - SerializationException(String, Throwable) - Constructor for exception org.springframework.data.redis.serializer.SerializationException
-
Constructs a new
SerializationException
instance. - SerializationUtils - Class in org.springframework.data.redis.serializer
-
Utility class with various serialization-related methods.
- SerializationUtils() - Constructor for class org.springframework.data.redis.serializer.SerializationUtils
- serialize(Object) - Method in class org.springframework.data.redis.serializer.GenericJackson2JsonRedisSerializer
- serialize(Object) - Method in class org.springframework.data.redis.serializer.JdkSerializationRedisSerializer
- serialize(Object) - Method in class org.springframework.data.redis.serializer.OxmSerializer
- serialize(String) - Method in class org.springframework.data.redis.serializer.StringRedisSerializer
- serialize(RedisSerializer<?>) - Method in interface org.springframework.data.redis.connection.stream.MapRecord
- serialize(RedisSerializer<? super S>, RedisSerializer<? super K>, RedisSerializer<? super V>) - Method in interface org.springframework.data.redis.connection.stream.MapRecord
-
Serialize
key
with the streamSerializer, field names with the fieldSerializer and values with the valueSerializer. - serialize(T) - Method in class org.springframework.data.redis.serializer.GenericToStringSerializer
- serialize(T) - Method in class org.springframework.data.redis.serializer.Jackson2JsonRedisSerializer
- serialize(T) - Method in interface org.springframework.data.redis.serializer.RedisSerializer
-
Serialize the given object to binary data.
- serializeCacheKey(String) - Method in class org.springframework.data.redis.cache.RedisCache
-
Serialize the given
cache key
. - serializeCacheValue(Object) - Method in class org.springframework.data.redis.cache.RedisCache
-
Serialize the
value
to cache as an array of bytes. - serializeKeysWith(RedisSerializationContext.SerializationPair<String>) - Method in class org.springframework.data.redis.cache.RedisCacheConfiguration
-
Define the
RedisSerializationContext.SerializationPair
used for de-/serializing cache keys. - serializer(RedisSerializationContext.SerializationPair<T>) - Method in class org.springframework.data.redis.stream.StreamReceiver.StreamReceiverOptionsBuilder
-
Configure a key, hash key and hash value serializer.
- serializer(RedisSerializationContext<T, ?>) - Method in class org.springframework.data.redis.stream.StreamReceiver.StreamReceiverOptionsBuilder
-
Configure a key, hash key and hash value serializer.
- serializer(RedisSerializer<T>) - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamMessageListenerContainerOptionsBuilder
-
Configure a key, hash key and hash value serializer.
- serializeValuesWith(RedisSerializationContext.SerializationPair<?>) - Method in class org.springframework.data.redis.cache.RedisCacheConfiguration
-
Define the
RedisSerializationContext.SerializationPair
used for de-/serializing cache values. - serverCommands() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- serverCommands() - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
- serverCommands() - Method in class org.springframework.data.redis.connection.jedis.JedisConnection
- serverCommands() - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
- serverCommands() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
- serverCommands() - Method in interface org.springframework.data.redis.connection.ReactiveRedisClusterConnection
- serverCommands() - Method in interface org.springframework.data.redis.connection.ReactiveRedisConnection
- serverCommands() - Method in interface org.springframework.data.redis.connection.RedisClusterCommandsProvider
-
Get
RedisServerCommands
. - serverCommands() - Method in interface org.springframework.data.redis.connection.RedisCommandsProvider
-
Get
RedisServerCommands
. - servesSlot(int) - Method in class org.springframework.data.redis.connection.RedisClusterNode
-
Determines whether this
RedisClusterNode
manages the identifiedslot
in the cluster. - serving(RedisClusterNode.SlotRange) - Method in class org.springframework.data.redis.connection.RedisClusterNode.RedisClusterNodeBuilder
- SessionCallback<T> - Interface in org.springframework.data.redis.core
-
Callback executing all operations against a surrogate 'session' (basically against the same underlying Redis connection).
- set(byte[], byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.stringCommands()
}. - set(byte[], byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- set(byte[], byte[]) - Method in interface org.springframework.data.redis.connection.RedisStringCommands
-
Set
value
forkey
. - set(byte[], byte[], Expiration, RedisStringCommands.SetOption) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.stringCommands()
}. - set(byte[], byte[], Expiration, RedisStringCommands.SetOption) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- set(byte[], byte[], Expiration, RedisStringCommands.SetOption) - Method in interface org.springframework.data.redis.connection.RedisStringCommands
-
Set
value
forkey
applying timeouts fromexpiration
if set and inserting/updating values depending onoption
. - set(double) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicDouble
-
Set to the given value.
- set(int) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicInteger
-
Set to the given value.
- set(int, E) - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- set(long) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicLong
-
Set to the given value.
- set(long, V) - Method in interface org.springframework.data.redis.core.BoundListOperations
-
Set the
value
list element atindex
. - set(String, Object) - Method in class org.springframework.data.redis.core.PartialUpdate
-
Set the value of a simple or complex value reachable via given path.
- set(String, String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- set(String, String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Set
value
forkey
. - set(String, String, Expiration, RedisStringCommands.SetOption) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- set(String, String, Expiration, RedisStringCommands.SetOption) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Set
value
forkey
applying timeouts fromexpiration
if set and inserting/updating values depending onoption
. - set(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveStringCommands.SetCommand
-
Creates a new
ReactiveStringCommands.SetCommand
given a key. - set(ByteBuffer, ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
-
Set value for key.
- set(ByteBuffer, ByteBuffer, Expiration, RedisStringCommands.SetOption) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
-
Set value for key with expiration and options.
- set(K, long, V) - Method in interface org.springframework.data.redis.core.ListOperations
-
Set the
value
list element atindex
. - set(K, long, V) - Method in interface org.springframework.data.redis.core.ReactiveListOperations
-
Set the
value
list element atindex
. - set(K, V) - Method in interface org.springframework.data.redis.core.ReactiveValueOperations
-
Set
value
forkey
. - set(K, V) - Method in interface org.springframework.data.redis.core.ValueOperations
-
Set
value
forkey
. - set(K, V, long) - Method in interface org.springframework.data.redis.core.ReactiveValueOperations
-
Overwrite parts of
key
starting at the specifiedoffset
with givenvalue
. - set(K, V, long) - Method in interface org.springframework.data.redis.core.ValueOperations
-
Overwrite parts of
key
starting at the specifiedoffset
with givenvalue
. - set(K, V, long, TimeUnit) - Method in interface org.springframework.data.redis.core.ValueOperations
-
Set the
value
and expirationtimeout
forkey
. - set(K, V, Duration) - Method in interface org.springframework.data.redis.core.ReactiveValueOperations
-
Set the
value
and expirationtimeout
forkey
. - set(K, V, Duration) - Method in interface org.springframework.data.redis.core.ValueOperations
-
Set the
value
and expirationtimeout
forkey
. - set(Publisher<ReactiveStringCommands.SetCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
-
Set each and every item separately by invoking
ReactiveStringCommands.SetCommand
. - set(BitFieldSubCommands.BitFieldSet) - Method in class org.springframework.data.redis.connection.BitFieldSubCommands
-
Create new
BitFieldSubCommands
adding givenBitFieldSubCommands.BitFieldSet
to the sub commands. - set(BitFieldSubCommands.BitFieldType) - Method in class org.springframework.data.redis.connection.BitFieldSubCommands
-
Obtain a new
BitFieldSubCommands.BitFieldSetBuilder
for creating and adding aBitFieldSubCommands.BitFieldSet
sub command. - set(V) - Method in interface org.springframework.data.redis.core.BoundValueOperations
-
Set
value
for the bound key. - set(V, long) - Method in interface org.springframework.data.redis.core.BoundValueOperations
-
Overwrite parts of the bound key starting at the specified
offset
with givenvalue
. - set(V, long, TimeUnit) - Method in interface org.springframework.data.redis.core.BoundValueOperations
-
Set the
value
and expirationtimeout
for the bound key. - set(V, Duration) - Method in interface org.springframework.data.redis.core.BoundValueOperations
-
Set the
value
and expirationtimeout
for the bound key. - SET - Enum constant in enum class org.springframework.data.redis.connection.DataType
- SET - Enum constant in enum class org.springframework.data.redis.core.PartialUpdate.UpdateCommand
- SET - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- SET - Enum constant in enum class org.springframework.data.redis.support.collections.RedisCollectionFactoryBean.CollectionType
- SET_ID - Enum constant in enum class org.springframework.data.redis.connection.ReactiveStreamCommands.GroupCommand.GroupCommandAction
- SET_IF_ABSENT - Enum constant in enum class org.springframework.data.redis.connection.RedisStringCommands.SetOption
-
NX
- SET_IF_PRESENT - Enum constant in enum class org.springframework.data.redis.connection.RedisStringCommands.SetOption
-
XX
- setAlphabetic(Boolean) - Method in class org.springframework.data.redis.connection.DefaultSortParameters
- setApplicationContext(ApplicationContext) - Method in class org.springframework.data.redis.core.RedisKeyValueAdapter
- setApplicationEventPublisher(ApplicationEventPublisher) - Method in class org.springframework.data.redis.listener.KeyExpirationEventMessageListener
- setAutoStartup(boolean) - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
-
Configure if this Lifecycle connection factory should get started automatically by the container at the time that the containing ApplicationContext gets refreshed.
- setAutoStartup(boolean) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
Configure if this Lifecycle connection factory should get started automatically by the container at the time that the containing ApplicationContext gets refreshed.
- setBeanClassLoader(ClassLoader) - Method in class org.springframework.data.redis.core.RedisTemplate
-
Sets the
ClassLoader
to be used for the defaultJdkSerializationRedisSerializer
in case no otherRedisSerializer
is explicitly set as the default one. - setBeanClassLoader(ClassLoader) - Method in class org.springframework.data.redis.repository.support.QueryByExampleRedisExecutor
- setBeanFactory(BeanFactory) - Method in class org.springframework.data.redis.repository.support.QueryByExampleRedisExecutor
- setBeanFactory(BeanFactory) - Method in class org.springframework.data.redis.serializer.GenericToStringSerializer
- setBeanName(String) - Method in class org.springframework.data.redis.listener.RedisMessageListenerContainer
- setBeanName(String) - Method in class org.springframework.data.redis.support.collections.RedisCollectionFactoryBean
- setBeanResolver(BeanResolver) - Method in class org.springframework.data.redis.core.convert.SpelIndexResolver
-
Allows setting the BeanResolver
- setBit(byte[], long, boolean) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.stringCommands()
}. - setBit(byte[], long, boolean) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- setBit(byte[], long, boolean) - Method in interface org.springframework.data.redis.connection.RedisStringCommands
-
Sets the bit at
offset
in value stored atkey
. - setBit(String, long, boolean) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- setBit(String, long, boolean) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Sets the bit at
offset
in value stored atkey
. - setBit(ByteBuffer, long, boolean) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
-
Sets the bit at offset in value stored at key and return the original value.
- setBit(K, long, boolean) - Method in interface org.springframework.data.redis.core.ReactiveValueOperations
-
Sets the bit at
offset
in value stored atkey
. - setBit(K, long, boolean) - Method in interface org.springframework.data.redis.core.ValueOperations
-
Sets the bit at
offset
in value stored atkey
. - setBit(Publisher<ReactiveStringCommands.SetBitCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
-
Sets the bit at offset in value stored at key and return the original value.
- SETBIT - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- setByPattern(byte[]) - Method in class org.springframework.data.redis.connection.DefaultSortParameters
- setClientName(byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.serverCommands()
. - setClientName(byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- setClientName(byte[]) - Method in interface org.springframework.data.redis.connection.RedisServerCommands
-
Assign given name to current connection.
- setClientName(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- setClientName(String) - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
-
Deprecated.since 2.0, configure the client name using
JedisClientConfiguration
. - setClientName(String) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
Deprecated.configure the client name using
LettuceClientConfiguration
. - setClientName(String) - Method in interface org.springframework.data.redis.connection.ReactiveServerCommands
-
Assign given name to current connection.
- setClientName(String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Assign given name to current connection.
- setClientResources(ClientResources) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
Deprecated.since 2.0, configure
ClientResources
usingLettuceClientConfiguration
. - setClusterNodes(Iterable<RedisNode>) - Method in class org.springframework.data.redis.connection.RedisClusterConfiguration
-
Set cluster nodes to connect to.
- setCommand(RedisCommand<?, ?, ?>) - Method in class org.springframework.data.redis.connection.lettuce.observability.LettuceObservationContext
-
Deprecated.
- setCommands() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- setCommands() - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
- setCommands() - Method in class org.springframework.data.redis.connection.jedis.JedisConnection
- setCommands() - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
- setCommands() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
- setCommands() - Method in interface org.springframework.data.redis.connection.ReactiveRedisClusterConnection
- setCommands() - Method in interface org.springframework.data.redis.connection.ReactiveRedisConnection
-
Get
ReactiveSetCommands
. - setCommands() - Method in interface org.springframework.data.redis.connection.RedisCommandsProvider
-
Get
RedisSetCommands
. - setConfig(String, String) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.serverCommands()
. - setConfig(String, String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- setConfig(String, String) - Method in interface org.springframework.data.redis.connection.ReactiveServerCommands
-
Set server configuration for
param
tovalue
. - setConfig(String, String) - Method in interface org.springframework.data.redis.connection.RedisServerCommands
-
Set server configuration for
param
tovalue
. - setConfig(RedisClusterNode, String, String) - Method in interface org.springframework.data.redis.connection.DefaultedRedisClusterConnection
-
Deprecated.in favor of
RedisCommandsProvider.serverCommands()
. - setConfig(RedisClusterNode, String, String) - Method in interface org.springframework.data.redis.connection.ReactiveClusterServerCommands
-
Set server configuration for
param
tovalue
. - setConfig(RedisClusterNode, String, String) - Method in interface org.springframework.data.redis.connection.RedisClusterServerCommands
- setConnectionFactory(RedisConnectionFactory) - Method in class org.springframework.data.redis.core.RedisAccessor
-
Sets the factory used to acquire connections and perform operations on the connected Redis instance.
- setConnectionFactory(RedisConnectionFactory) - Method in class org.springframework.data.redis.listener.RedisMessageListenerContainer
- setConversionService(ConversionService) - Method in class org.springframework.data.redis.serializer.GenericToStringSerializer
-
Set the
ConversionService
to be used. - SetConverter<S,
T> - Class in org.springframework.data.redis.connection.convert -
Converts a Set of values of one type to a Set of values of another type preserving item order.
- SetConverter(Converter<S, T>) - Constructor for class org.springframework.data.redis.connection.convert.SetConverter
- setConvertPipelineAndTxResults(boolean) - Method in class org.springframework.data.redis.connection.jedis.JedisConnection
-
Specifies if pipelined results should be converted to the expected data type.
- setConvertPipelineAndTxResults(boolean) - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
-
Specifies if pipelined results should be converted to the expected data type.
- setConvertPipelineAndTxResults(boolean) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
-
Specifies if pipelined and transaction results should be converted to the expected data type.
- setConvertPipelineAndTxResults(boolean) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
Specifies if pipelined and transaction results should be converted to the expected data type.
- setCustomConversions(CustomConversions) - Method in class org.springframework.data.redis.core.convert.MappingRedisConverter
-
Set
CustomConversions
to be applied. - setDatabase(int) - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
-
Deprecated.since 2.0, configure the database index using
RedisStandaloneConfiguration
orRedisSentinelConfiguration
. - setDatabase(int) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
Deprecated.since 3.2, configure the database index using
RedisStandaloneConfiguration
,RedisSocketConfiguration
,RedisSentinelConfiguration
, orRedisStaticMasterReplicaConfiguration
. - setDatabase(int) - Method in interface org.springframework.data.redis.connection.RedisConfiguration.WithDatabaseIndex
-
Set the database index to use.
- setDatabase(int) - Method in class org.springframework.data.redis.connection.RedisSentinelConfiguration
- setDatabase(int) - Method in class org.springframework.data.redis.connection.RedisSocketConfiguration
- setDatabase(int) - Method in class org.springframework.data.redis.connection.RedisStandaloneConfiguration
- setDatabase(int) - Method in class org.springframework.data.redis.connection.RedisStaticMasterReplicaConfiguration
- setDefaultListenerMethod(String) - Method in class org.springframework.data.redis.listener.adapter.MessageListenerAdapter
-
Specify the name of the default listener method to delegate to, for the case where no specific listener method has been determined.
- setDefaultSerializer(RedisSerializer<?>) - Method in class org.springframework.data.redis.core.RedisTemplate
-
Sets the default serializer to use for this template.
- setDelegate(Object) - Method in class org.springframework.data.redis.listener.adapter.MessageListenerAdapter
-
Set a target object to delegate message listening to.
- setDeserializePipelineAndTxResults(boolean) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
-
Specifies if pipelined and tx results should be deserialized to Strings.
- setEagerInitialization(boolean) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
Enables eager initialization of
shared connections
. - setEarlyStartup(boolean) - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
-
Configure if this InitializingBean's component Lifecycle should get started early by
JedisConnectionFactory.afterPropertiesSet()
at the time that the bean is initialized. - setEarlyStartup(boolean) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
Configure if this InitializingBean's component Lifecycle should get started early by
LettuceConnectionFactory.afterPropertiesSet()
at the time that the bean is initialized. - setEnableDefaultSerializer(boolean) - Method in class org.springframework.data.redis.core.RedisTemplate
-
Configure whether the default serializer should be used or not.
- setEnableKeyspaceEvents(RedisKeyValueAdapter.EnableKeyspaceEvents) - Method in class org.springframework.data.redis.core.RedisKeyValueAdapter
-
Configure usage of
KeyExpirationEventMessageListener
. - setEnableTransactionSupport(boolean) - Method in class org.springframework.data.redis.core.RedisTemplate
-
Sets whether this template participates in ongoing transactions using MULTI...EXEC|DISCARD to keep track of operations.
- setEndpoint(Tracing.Endpoint) - Method in class org.springframework.data.redis.connection.lettuce.observability.LettuceObservationContext
-
Deprecated.
- setErrorHandler(ErrorHandler) - Method in class org.springframework.data.redis.listener.RedisMessageListenerContainer
-
Set an ErrorHandler to be invoked in case of any uncaught exceptions thrown while processing a Message.
- setEx(byte[], long, byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.stringCommands()
}. - setEx(byte[], long, byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- setEx(byte[], long, byte[]) - Method in interface org.springframework.data.redis.connection.RedisStringCommands
-
Set the
value
and expiration inseconds
forkey
. - setEx(String, long, String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- setEx(String, long, String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Set the
value
and expiration inseconds
forkey
. - setEX(ByteBuffer, ByteBuffer, Expiration) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
-
Set key value pair and
Expiration
. - setEX(Publisher<ReactiveStringCommands.SetCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
-
Set key value pairs and
Expiration
. - SETEX - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- setExecutor(AsyncTaskExecutor) - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
-
Configures the
executor
used to execute commands asynchronously across the cluster. - setExecutor(AsyncTaskExecutor) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
Configures the
executor
used to execute commands asynchronously across the cluster. - setExposeConnection(boolean) - Method in class org.springframework.data.redis.core.RedisTemplate
-
Sets whether the underlying RedisConnection should be directly exposed to the RedisCallback code.
- setGetPattern(byte[][]) - Method in class org.springframework.data.redis.connection.DefaultSortParameters
- setHashKeySerializer(RedisSerializer<?>) - Method in class org.springframework.data.redis.core.RedisTemplate
-
Sets the hash key (or field) serializer to be used by this template.
- setHashValueSerializer(RedisSerializer<?>) - Method in class org.springframework.data.redis.core.RedisTemplate
-
Sets the hash value serializer to be used by this template.
- setHostName(String) - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
-
Deprecated.since 2.0, configure the hostname using
RedisStandaloneConfiguration
. - setHostName(String) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
Deprecated.since 2.0, configure the hostname using
RedisStandaloneConfiguration
. - setHostName(String) - Method in interface org.springframework.data.redis.connection.RedisConfiguration.WithHostAndPort
-
Set the Redis server hostname
- setHostName(String) - Method in class org.springframework.data.redis.connection.RedisStandaloneConfiguration
- setId(String) - Method in class org.springframework.data.redis.connection.RedisNode
- setId(String) - Method in class org.springframework.data.redis.core.convert.RedisData
-
Set the id to be used as part of the key.
- setIfAbsent(K, V) - Method in interface org.springframework.data.redis.core.ReactiveValueOperations
-
Set
key
to hold the stringvalue
ifkey
is absent. - setIfAbsent(K, V) - Method in interface org.springframework.data.redis.core.ValueOperations
-
Set
key
to hold the stringvalue
ifkey
is absent. - setIfAbsent(K, V, long, TimeUnit) - Method in interface org.springframework.data.redis.core.ValueOperations
-
Set
key
to hold the stringvalue
and expirationtimeout
ifkey
is absent. - setIfAbsent(K, V, Duration) - Method in interface org.springframework.data.redis.core.ReactiveValueOperations
-
Set
key
to hold the stringvalue
and expirationtimeout
ifkey
is absent. - setIfAbsent(K, V, Duration) - Method in interface org.springframework.data.redis.core.ValueOperations
-
Set
key
to hold the stringvalue
and expirationtimeout
ifkey
is absent. - setIfAbsent(V) - Method in interface org.springframework.data.redis.core.BoundValueOperations
-
Set the bound key to hold the string
value
if the bound key is absent. - setIfAbsent(V, long, TimeUnit) - Method in interface org.springframework.data.redis.core.BoundValueOperations
-
Set the bound key to hold the string
value
and expirationtimeout
if the bound key is absent. - setIfAbsent(V, Duration) - Method in interface org.springframework.data.redis.core.BoundValueOperations
-
Set bound key to hold the string
value
and expirationtimeout
if the bound key is absent. - setIfPresent(K, V) - Method in interface org.springframework.data.redis.core.ReactiveValueOperations
-
Set
key
to hold the stringvalue
ifkey
is present. - setIfPresent(K, V) - Method in interface org.springframework.data.redis.core.ValueOperations
-
Set
key
to hold the stringvalue
ifkey
is present. - setIfPresent(K, V, long, TimeUnit) - Method in interface org.springframework.data.redis.core.ValueOperations
-
Set
key
to hold the stringvalue
and expirationtimeout
ifkey
is present. - setIfPresent(K, V, Duration) - Method in interface org.springframework.data.redis.core.ReactiveValueOperations
-
Set
key
to hold the stringvalue
and expirationtimeout
ifkey
is present. - setIfPresent(K, V, Duration) - Method in interface org.springframework.data.redis.core.ValueOperations
-
Set
key
to hold the stringvalue
and expirationtimeout
ifkey
is present. - setIfPresent(V) - Method in interface org.springframework.data.redis.core.BoundValueOperations
-
Set the bound key to hold the string
value
if the bound key is present. - setIfPresent(V, long, TimeUnit) - Method in interface org.springframework.data.redis.core.BoundValueOperations
-
Set the bound key to hold the string
value
and expirationtimeout
if the bound key is present. - setIfPresent(V, Duration) - Method in interface org.springframework.data.redis.core.BoundValueOperations
-
Set the bound key to hold the string
value
and expirationtimeout
if the bound key is present. - setIndexResolver(IndexResolver) - Method in class org.springframework.data.redis.core.convert.MappingRedisConverter
- setKey(String) - Method in class org.springframework.data.redis.support.collections.RedisCollectionFactoryBean
-
Sets the key of the store.
- setKeySerializer(RedisSerializer<?>) - Method in class org.springframework.data.redis.core.RedisTemplate
-
Sets the key serializer to be used by this template.
- setKeyspace(String) - Method in class org.springframework.data.redis.core.convert.RedisData
- setKeyspaceNotificationsConfigParameter(String) - Method in class org.springframework.data.redis.core.RedisKeyValueAdapter
-
Configure the notify-keyspace-events property if not already set.
- setKeyspaceNotificationsConfigParameter(String) - Method in class org.springframework.data.redis.listener.KeyspaceEventMessageListener
-
Set the configuration string to use for notify-keyspace-events.
- setLimit(SortParameters.Range) - Method in class org.springframework.data.redis.connection.DefaultSortParameters
- setLocation(Resource) - Method in class org.springframework.data.redis.core.script.DefaultRedisScript
- setMarshaller(Marshaller) - Method in class org.springframework.data.redis.serializer.OxmSerializer
- setMaster(String) - Method in interface org.springframework.data.redis.connection.RedisConfiguration.SentinelConfiguration
-
Set the name of the master node.
- setMaster(NamedNode) - Method in interface org.springframework.data.redis.connection.RedisConfiguration.SentinelConfiguration
-
Set the master node.
- setMaster(NamedNode) - Method in class org.springframework.data.redis.connection.RedisSentinelConfiguration
- setMaxRedirects(int) - Method in class org.springframework.data.redis.connection.ClusterCommandExecutor
-
Set the maximum number of redirects to follow on
MOVED
orASK
. - setMaxRedirects(int) - Method in class org.springframework.data.redis.connection.RedisClusterConfiguration
- setMaxSize(int) - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
-
Sets the maximum size of the (capped) list.
- setMaxSubscriptionRegistrationWaitingTime(long) - Method in class org.springframework.data.redis.listener.RedisMessageListenerContainer
-
Specify the max time to wait for subscription registrations, in milliseconds The default is
2000ms
, that is, 2 second. - setMessageListenerContainer(RedisMessageListenerContainer) - Method in class org.springframework.data.redis.core.RedisKeyValueAdapter
-
Configure a
RedisMessageListenerContainer
to listen for Keyspace expiry events. - setMessageListeners(Map<? extends MessageListener, Collection<? extends Topic>>) - Method in class org.springframework.data.redis.listener.RedisMessageListenerContainer
-
Attaches the given listeners (and their topics) to the container.
- setName(String) - Method in class org.springframework.data.redis.connection.RedisNode
- setNX(byte[], byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.stringCommands()
}. - setNX(byte[], byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- setNX(byte[], byte[]) - Method in interface org.springframework.data.redis.connection.RedisStringCommands
-
Set
value
forkey
, only ifkey
does not exist. - setNX(String, String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- setNX(String, String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Set
value
forkey
, only ifkey
does not exist. - setNX(ByteBuffer, ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
-
Set value for key, only if key does not exist.
- setNX(Publisher<ReactiveStringCommands.SetCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
-
Set key value pairs, only if key does not exist.
- SETNX - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- setObjectMapper(ObjectMapper) - Method in class org.springframework.data.redis.serializer.Jackson2JsonRedisSerializer
-
Deprecated, for removal: This API element is subject to removal in a future version.since 3.0, use
constructor creation
to configure the object mapper. - SetOperations<K,
V> - Interface in org.springframework.data.redis.core -
Redis set specific operations.
- setOrder(SortParameters.Order) - Method in class org.springframework.data.redis.connection.DefaultSortParameters
- setPassword(char[]) - Method in interface org.springframework.data.redis.connection.RedisConfiguration.WithAuthentication
-
Create and set a
RedisPassword
for givenString
. - setPassword(String) - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
-
Deprecated.since 2.0, configure the password using
RedisStandaloneConfiguration
,RedisSentinelConfiguration
orRedisClusterConfiguration
. - setPassword(String) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
Deprecated.since 2.0, configure the password using
RedisStandaloneConfiguration
,RedisSentinelConfiguration
orRedisClusterConfiguration
. - setPassword(String) - Method in interface org.springframework.data.redis.connection.RedisConfiguration.WithAuthentication
-
Create and set a
RedisPassword
for givenString
. - setPassword(RedisPassword) - Method in class org.springframework.data.redis.connection.RedisClusterConfiguration
- setPassword(RedisPassword) - Method in interface org.springframework.data.redis.connection.RedisConfiguration.WithAuthentication
-
Create and set a
RedisPassword
for givenString
. - setPassword(RedisPassword) - Method in class org.springframework.data.redis.connection.RedisSentinelConfiguration
- setPassword(RedisPassword) - Method in class org.springframework.data.redis.connection.RedisSocketConfiguration
- setPassword(RedisPassword) - Method in class org.springframework.data.redis.connection.RedisStandaloneConfiguration
- setPassword(RedisPassword) - Method in class org.springframework.data.redis.connection.RedisStaticMasterReplicaConfiguration
- setPhase(int) - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
-
Specify the lifecycle phase for pausing and resuming this executor.
- setPhase(int) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
Specify the lifecycle phase for pausing and resuming this executor.
- setPipeliningFlushPolicy(LettuceConnection.PipeliningFlushPolicy) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
-
Configures the flushing policy when using pipelining.
- setPipeliningFlushPolicy(LettuceConnection.PipeliningFlushPolicy) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
Configures the flushing policy when using pipelining.
- setPoolConfig(JedisPoolConfig) - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
-
Deprecated.since 2.0, configure
JedisPoolConfig
usingJedisClientConfiguration
. - setPort(int) - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
-
Deprecated.since 2.0, configure the port using
RedisStandaloneConfiguration
. - setPort(int) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
Deprecated.since 2.0, configure the port using
RedisStandaloneConfiguration
. - setPort(int) - Method in interface org.springframework.data.redis.connection.RedisConfiguration.WithHostAndPort
-
Set the Redis server port.
- setPort(int) - Method in class org.springframework.data.redis.connection.RedisStandaloneConfiguration
- setQuorum(Long) - Method in class org.springframework.data.redis.connection.RedisServer
- setRange(byte[], byte[], long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.stringCommands()
}. - setRange(byte[], byte[], long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- setRange(byte[], byte[], long) - Method in interface org.springframework.data.redis.connection.RedisStringCommands
-
Overwrite parts of
key
starting at the specifiedoffset
with givenvalue
. - setRange(String, String, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- setRange(String, String, long) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Overwrite parts of
key
starting at the specifiedoffset
with givenvalue
. - setRange(ByteBuffer, ByteBuffer, long) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
-
Overwrite parts of key starting at the specified offset with given value.
- setRange(Publisher<ReactiveStringCommands.SetRangeCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
-
Overwrite parts of
ReactiveRedisConnection.KeyCommand.key
starting at the specified offset with givenReactiveStringCommands.SetRangeCommand.value
. - SETRANGE - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- setRecoveryBackoff(BackOff) - Method in class org.springframework.data.redis.listener.RedisMessageListenerContainer
-
Specify the interval
BackOff
recovery attempts. - setRecoveryInterval(long) - Method in class org.springframework.data.redis.listener.RedisMessageListenerContainer
-
Specify the interval between recovery attempts, in milliseconds.
- setReferenceResolver(ReferenceResolver) - Method in class org.springframework.data.redis.core.convert.MappingRedisConverter
- setResultType(Class<T>) - Method in class org.springframework.data.redis.core.script.DefaultRedisScript
- sets(Collection<ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZDiffCommand
-
Creates a new
ReactiveZSetCommands.ZDiffCommand
given aCollection
of keys. - sets(List<ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZAggregateCommand
-
Creates a new
ReactiveZSetCommands.ZAggregateCommand
given aList
of keys. - sets(List<ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZAggregateStoreCommand
-
Creates a new
ReactiveZSetCommands.ZAggregateStoreCommand
given aList
of keys. - sets(List<ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZInterStoreCommand
-
Creates a new
ReactiveZSetCommands.ZInterStoreCommand
given aList
of keys. - sets(List<ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZUnionStoreCommand
-
Creates a new
ReactiveZSetCommands.ZUnionStoreCommand
given aList
of keys. - setScriptExecutor(ScriptExecutor<K>) - Method in class org.springframework.data.redis.core.RedisTemplate
- setScriptSource(ScriptSource) - Method in class org.springframework.data.redis.core.script.DefaultRedisScript
- setScriptText(String) - Method in class org.springframework.data.redis.core.script.DefaultRedisScript
- setSentinelConfiguration(RedisSentinelConfiguration) - Method in class org.springframework.data.redis.connection.AbstractRedisConnection
- setSentinelPassword(char[]) - Method in interface org.springframework.data.redis.connection.RedisConfiguration.SentinelConfiguration
-
Create and set a
RedisPassword
to be used when authenticating with Redis Sentinel from the givenCharacter
sequence. - setSentinelPassword(String) - Method in interface org.springframework.data.redis.connection.RedisConfiguration.SentinelConfiguration
-
Create and set a
RedisPassword
to be used when authenticating with Redis Sentinel from the givenString
. - setSentinelPassword(RedisPassword) - Method in interface org.springframework.data.redis.connection.RedisConfiguration.SentinelConfiguration
-
Set a
RedisPassword
to be used when authenticating with Redis Sentinel. - setSentinelPassword(RedisPassword) - Method in class org.springframework.data.redis.connection.RedisSentinelConfiguration
- setSentinels(Iterable<RedisNode>) - Method in class org.springframework.data.redis.connection.RedisSentinelConfiguration
-
Set Sentinels to connect to.
- setSentinelUsername(String) - Method in interface org.springframework.data.redis.connection.RedisConfiguration.SentinelConfiguration
-
Create and set a username with the given
String
. - setSentinelUsername(String) - Method in class org.springframework.data.redis.connection.RedisSentinelConfiguration
- setSerializer(RedisSerializer<?>) - Method in class org.springframework.data.redis.listener.adapter.MessageListenerAdapter
-
Set the serializer that will convert incoming raw Redis messages to listener method arguments.
- setShadowCopy(RedisKeyValueAdapter.ShadowCopy) - Method in class org.springframework.data.redis.core.RedisKeyValueAdapter
-
Configure storage of phantom keys (shadow copies) of expiring entities.
- setShareNativeConnection(boolean) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
Enables multiple
LettuceConnection
s to share a single native connection. - setShutdownTimeout(long) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
Deprecated.since 2.0, configure the shutdown timeout using
LettuceClientConfiguration
. - setSocket(String) - Method in interface org.springframework.data.redis.connection.RedisConfiguration.WithDomainSocket
-
Set the socket.
- setSocket(String) - Method in class org.springframework.data.redis.connection.RedisSocketConfiguration
- setStartTls(boolean) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
Deprecated.since 2.0, configure StartTLS using
LettuceClientConfiguration
. - setStatus(boolean) - Method in class org.springframework.data.redis.connection.FutureResult
-
Indicates if this result is the status of an operation.
- setStringSerializer(RedisSerializer<String>) - Method in class org.springframework.data.redis.core.RedisTemplate
-
Sets the string value serializer to be used by this template (when the arguments or return types are always strings).
- setStringSerializer(RedisSerializer<String>) - Method in class org.springframework.data.redis.listener.adapter.MessageListenerAdapter
-
Sets the serializer used for converting the channel/pattern to a String.
- setSubscriptionExecutor(Executor) - Method in class org.springframework.data.redis.listener.RedisMessageListenerContainer
-
Sets the task execution used for subscribing to Redis channels.
- setTaskExecutor(Executor) - Method in class org.springframework.data.redis.listener.RedisMessageListenerContainer
-
Sets the task executor used for running the message listeners when messages are received.
- setTemplate(RedisTemplate<String, ?>) - Method in class org.springframework.data.redis.support.collections.RedisCollectionFactoryBean
-
Sets the template used by the resulting store.
- setTimeout(int) - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
-
Deprecated.since 2.0, configure the timeout using
JedisClientConfiguration
. - setTimeout(long) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
Deprecated.since 2.0, configure the timeout using
LettuceClientConfiguration
. - setTimeToLive(Long) - Method in class org.springframework.data.redis.core.convert.KeyspaceConfiguration.KeyspaceSettings
- setTimeToLive(Long) - Method in class org.springframework.data.redis.core.convert.RedisData
-
Set the time before expiration in
TimeUnit.SECONDS
. - setTimeToLive(Long, TimeUnit) - Method in class org.springframework.data.redis.core.convert.RedisData
-
Set the time before expiration converting the given arguments to
TimeUnit.SECONDS
. - setTimeToLivePropertyName(String) - Method in class org.springframework.data.redis.core.convert.KeyspaceConfiguration.KeyspaceSettings
- setTopicSerializer(RedisSerializer<String>) - Method in class org.springframework.data.redis.listener.RedisMessageListenerContainer
-
Sets the serializer for converting the
Topic
s into low-level channels and patterns. - setType(RedisCollectionFactoryBean.CollectionType) - Method in class org.springframework.data.redis.support.collections.RedisCollectionFactoryBean
-
Sets the store type.
- setTypeConverter(TypeConverter) - Method in class org.springframework.data.redis.serializer.GenericToStringSerializer
-
Set the
TypeConverter
to be used. - setUnmarshaller(Unmarshaller) - Method in class org.springframework.data.redis.serializer.OxmSerializer
- setUsePool(boolean) - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
-
Deprecated.since 2.0, configure pooling usage with
JedisClientConfiguration
. - setUsername(String) - Method in class org.springframework.data.redis.connection.RedisClusterConfiguration
- setUsername(String) - Method in interface org.springframework.data.redis.connection.RedisConfiguration.WithAuthentication
-
Create and set a username with the given
String
. - setUsername(String) - Method in class org.springframework.data.redis.connection.RedisSentinelConfiguration
- setUsername(String) - Method in class org.springframework.data.redis.connection.RedisSocketConfiguration
- setUsername(String) - Method in class org.springframework.data.redis.connection.RedisStandaloneConfiguration
- setUsername(String) - Method in class org.springframework.data.redis.connection.RedisStaticMasterReplicaConfiguration
- setUseSsl(boolean) - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
-
Deprecated.since 2.0, configure the SSL usage with
JedisClientConfiguration
. - setUseSsl(boolean) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
Deprecated.since 2.0, configure SSL usage using
LettuceClientConfiguration
. - setValidateConnection(boolean) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
Enables validation of the shared native Lettuce connection on calls to
LettuceConnectionFactory.getConnection()
. - setValueSerializer(RedisSerializer<?>) - Method in class org.springframework.data.redis.core.RedisTemplate
-
Sets the value serializer to be used by this template.
- setValueTransformer(IndexValueTransformer) - Method in class org.springframework.data.redis.core.index.RedisIndexDefinition
- setVerifyPeer(boolean) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
Deprecated.since 2.0, configure peer verification using
LettuceClientConfiguration
. - sha1DigestAsHex(String) - Static method in class org.springframework.data.redis.core.script.DigestUtils
-
Returns the SHA1 of the provided data
- shadowCopy() - Element in annotation interface org.springframework.data.redis.repository.configuration.EnableRedisRepositories
-
Configuration flag controlling storage of phantom keys (shadow copies) of expiring entities to read them later when publishing
keyspace events
. - shouldBeAutoGenerated() - Method in class org.springframework.data.redis.connection.stream.RecordId
- shouldUseCachedValue() - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection.JedisClusterTopologyProvider
-
Deprecated, for removal: This API element is subject to removal in a future version.since 3.3.4, use
JedisClusterConnection.JedisClusterTopologyProvider.shouldUseCachedValue(JedisClusterTopology)
instead. - shouldUseCachedValue(JedisClusterConnection.JedisClusterTopology) - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection.JedisClusterTopologyProvider
-
Returns whether
JedisClusterConnection.JedisClusterTopologyProvider.getTopology()
should return the cachedJedisClusterConnection.JedisClusterTopology
. - shutdown() - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.serverCommands()
. - shutdown() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- shutdown() - Method in interface org.springframework.data.redis.connection.RedisServerCommands
-
Shutdown server.
- shutdown(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.DefaultedRedisClusterConnection
-
Deprecated.in favor of
RedisCommandsProvider.serverCommands()
. - shutdown(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.RedisClusterServerCommands
- shutdown(RedisClusterNode) - Method in interface org.springframework.data.redis.core.ClusterOperations
-
Shutdown given node.
- shutdown(RedisServerCommands.ShutdownOption) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.serverCommands()
. - shutdown(RedisServerCommands.ShutdownOption) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- shutdown(RedisServerCommands.ShutdownOption) - Method in interface org.springframework.data.redis.connection.RedisServerCommands
-
Shutdown server.
- SHUTDOWN - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- shutdownQuietPeriod(Duration) - Method in class org.springframework.data.redis.connection.lettuce.LettuceClientConfiguration.LettuceClientConfigurationBuilder
-
Configure the shutdown quiet period.
- shutdownQuietPeriod(Duration) - Method in class org.springframework.data.redis.connection.lettuce.LettucePoolingClientConfiguration.LettucePoolingClientConfigurationBuilder
- shutdownTimeout(Duration) - Method in class org.springframework.data.redis.connection.lettuce.LettuceClientConfiguration.LettuceClientConfigurationBuilder
-
Configure a shutdown timeout.
- shutdownTimeout(Duration) - Method in class org.springframework.data.redis.connection.lettuce.LettucePoolingClientConfiguration.LettucePoolingClientConfigurationBuilder
- signed(int) - Static method in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldType
-
Create new signed
BitFieldSubCommands.BitFieldType
. - simple() - Static method in interface org.springframework.data.redis.cache.CacheKeyPrefix
-
Creates a default
CacheKeyPrefix
scheme that prefixes cache keys with thename
of the cache followed by double colons. - SimpleIndexDefinition - Class in org.springframework.data.redis.core.index
-
PathBasedRedisIndexDefinition
for including property values in a secondary index. - SimpleIndexDefinition(String, String) - Constructor for class org.springframework.data.redis.core.index.SimpleIndexDefinition
-
Creates new
SimpleIndexDefinition
. - SimpleIndexDefinition(String, String, String) - Constructor for class org.springframework.data.redis.core.index.SimpleIndexDefinition
-
Creates new
SimpleIndexDefinition
. - SimpleIndexedPropertyValue - Class in org.springframework.data.redis.core.convert
-
IndexedData
implementation indicating storage of data within a Redis Set. - SimpleIndexedPropertyValue(String, String, Object) - Constructor for class org.springframework.data.redis.core.convert.SimpleIndexedPropertyValue
-
Creates new
SimpleIndexedPropertyValue
. - singleValue() - Static method in class org.springframework.data.redis.connection.ReactiveSetCommands.SRandMembersCommand
-
Creates a new
ReactiveSetCommands.SRandMembersCommand
to retrieve one random member. - singleValue() - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRandMemberCommand
-
Creates a new
ReactiveZSetCommands.ZRandMemberCommand
to retrieve one random member. - sInter(byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.setCommands()
}. - sInter(byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- sInter(byte[]...) - Method in interface org.springframework.data.redis.connection.RedisSetCommands
-
Returns the members intersecting all given sets at
keys
. - sInter(String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- sInter(String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Returns the members intersecting all given sets at
keys
. - sInter(Collection<ByteBuffer>) - Method in interface org.springframework.data.redis.connection.ReactiveSetCommands
-
Returns the members intersecting all given sets at keys.
- sInter(Publisher<ReactiveSetCommands.SInterCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveSetCommands
-
Returns the members intersecting all given sets at
ReactiveSetCommands.SInterCommand.getKeys()
. - SINTER - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- sInterStore(byte[], byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.setCommands()
}. - sInterStore(byte[], byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- sInterStore(byte[], byte[]...) - Method in interface org.springframework.data.redis.connection.RedisSetCommands
-
Intersect all given sets at
keys
and store result indestKey
. - sInterStore(String, String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- sInterStore(String, String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Intersect all given sets at
keys
and store result indestKey
. - sInterStore(ByteBuffer, Collection<ByteBuffer>) - Method in interface org.springframework.data.redis.connection.ReactiveSetCommands
-
Intersect all given sets at keys and store result in destinationKey.
- sInterStore(Publisher<ReactiveSetCommands.SInterStoreCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveSetCommands
-
Intersect all given sets at keys and store result in destinationKey.
- SINTERSTORE - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- sismember(String, Object) - Method in class org.springframework.data.redis.repository.query.RedisOperationChain
- sismember(RedisOperationChain.PathAndValue) - Method in class org.springframework.data.redis.repository.query.RedisOperationChain
- sIsMember(byte[], byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.setCommands()
}. - sIsMember(byte[], byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- sIsMember(byte[], byte[]) - Method in interface org.springframework.data.redis.connection.RedisSetCommands
-
Check if set at
key
containsvalue
. - sIsMember(String, String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- sIsMember(String, String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Check if set at
key
containsvalue
. - sIsMember(ByteBuffer, ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveSetCommands
-
Check if set at key contains value.
- sIsMember(Publisher<ReactiveSetCommands.SIsMemberCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveSetCommands
-
Check if set at
ReactiveRedisConnection.KeyCommand.getKey()
containsReactiveSetCommands.SIsMemberCommand.getValue()
. - SISMEMBER - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- size() - Method in class org.springframework.data.redis.connection.stream.PendingMessages
- size() - Method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoConsumers
-
Returns the number of
StreamInfo.XInfoConsumer
available. - size() - Method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoGroups
-
Returns the number of
StreamInfo.XInfoGroup
available. - size() - Method in class org.springframework.data.redis.connection.util.ByteArraySet
- size() - Method in class org.springframework.data.redis.connection.zset.Weights
- size() - Method in interface org.springframework.data.redis.core.BoundHashOperations
-
Get size of hash at the bound key.
- size() - Method in interface org.springframework.data.redis.core.BoundListOperations
-
Get the size of list stored at the bound key.
- size() - Method in interface org.springframework.data.redis.core.BoundSetOperations
-
Get size of set at the bound key.
- size() - Method in interface org.springframework.data.redis.core.BoundStreamOperations
-
Get the length of a stream.
- size() - Method in interface org.springframework.data.redis.core.BoundValueOperations
-
Get the length of the value stored at the bound key.
- size() - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Returns the number of elements of the sorted set stored with given the bound key.
- size() - Method in class org.springframework.data.redis.core.convert.Bucket
- size() - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- size() - Method in class org.springframework.data.redis.support.collections.DefaultRedisMap
- size() - Method in class org.springframework.data.redis.support.collections.DefaultRedisSet
- size() - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
- size() - Method in class org.springframework.data.redis.support.collections.RedisProperties
- size(H) - Method in interface org.springframework.data.redis.core.HashOperations
-
Get size of hash at
key
. - size(H) - Method in interface org.springframework.data.redis.core.ReactiveHashOperations
-
Get size of hash at
key
. - size(K) - Method in interface org.springframework.data.redis.core.ListOperations
-
Get the size of list stored at
key
. - size(K) - Method in interface org.springframework.data.redis.core.ReactiveListOperations
-
Get the size of list stored at
key
. - size(K) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
-
Get size of set at
key
. - size(K) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
-
Get the length of a stream.
- size(K) - Method in interface org.springframework.data.redis.core.ReactiveValueOperations
-
Get the length of the value stored at
key
. - size(K) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Returns the number of elements of the sorted set stored with given
key
. - size(K) - Method in interface org.springframework.data.redis.core.SetOperations
-
Get size of set at
key
. - size(K) - Method in interface org.springframework.data.redis.core.StreamOperations
-
Get the length of a stream.
- size(K) - Method in interface org.springframework.data.redis.core.ValueOperations
-
Get the length of the value stored at
key
. - size(K) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Returns the number of elements of the sorted set stored with given
key
. - size(K...) - Method in interface org.springframework.data.redis.core.HyperLogLogOperations
-
Gets the current number of elements within the key.
- size(K...) - Method in interface org.springframework.data.redis.core.ReactiveHyperLogLogOperations
-
Gets the current number of elements within the key.
- SIZE - Enum constant in enum class org.springframework.data.redis.connection.ClusterInfo.Info
- SKIPLIST - Enum constant in enum class org.springframework.data.redis.connection.ValueEncoding.RedisValueEncoding
-
Encoding for sorted sets of any size.
- SLAVEOF - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- slaves(String) - Method in class org.springframework.data.redis.connection.lettuce.LettuceSentinelConnection
- SLOT_COUNT - Static variable in class org.springframework.data.redis.connection.ClusterSlotHashUtil
- SlotRange(Integer, Integer) - Constructor for class org.springframework.data.redis.connection.RedisClusterNode.SlotRange
- SlotRange(BitSet) - Constructor for class org.springframework.data.redis.connection.RedisClusterNode.SlotRange
- SlotRange(Collection<Integer>) - Constructor for class org.springframework.data.redis.connection.RedisClusterNode.SlotRange
- SLOTS_ASSIGNED - Enum constant in enum class org.springframework.data.redis.connection.ClusterInfo.Info
- SLOTS_FAIL - Enum constant in enum class org.springframework.data.redis.connection.ClusterInfo.Info
- SLOTS_OK - Enum constant in enum class org.springframework.data.redis.connection.ClusterInfo.Info
- SLOTS_PFAIL - Enum constant in enum class org.springframework.data.redis.connection.ClusterInfo.Info
- SLOWLOG - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- sMembers(byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.setCommands()
}. - sMembers(byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- sMembers(byte[]) - Method in interface org.springframework.data.redis.connection.RedisSetCommands
-
Get all elements of set at
key
. - sMembers(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- sMembers(String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get all elements of set at
key
. - sMembers(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveSetCommands
-
Get all elements of set at key.
- sMembers(Publisher<ReactiveRedisConnection.KeyCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveSetCommands
-
Get all elements of set at
ReactiveRedisConnection.KeyCommand.getKey()
. - SMEMBERS - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- sMIsMember(byte[], byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.setCommands()
}. - sMIsMember(byte[], byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- sMIsMember(byte[], byte[]...) - Method in interface org.springframework.data.redis.connection.RedisSetCommands
-
Check if set at
key
contains one or morevalues
. - sMIsMember(String, String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- sMIsMember(String, String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Check if set at
key
contains one or morevalues
. - sMIsMember(ByteBuffer, List<ByteBuffer>) - Method in interface org.springframework.data.redis.connection.ReactiveSetCommands
-
Check if set at
key
contains one or morevalues
. - sMIsMember(Publisher<ReactiveSetCommands.SMIsMemberCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveSetCommands
-
Check if set at
ReactiveRedisConnection.KeyCommand.getKey()
containsReactiveSetCommands.SMIsMemberCommand.getValues()
. - sMove(byte[], byte[], byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.setCommands()
}. - sMove(byte[], byte[], byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- sMove(byte[], byte[], byte[]) - Method in interface org.springframework.data.redis.connection.RedisSetCommands
-
Move
value
fromsrcKey
todestKey
- sMove(String, String, String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- sMove(String, String, String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Move
value
fromsrcKey
todestKey
- sMove(ByteBuffer, ByteBuffer, ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveSetCommands
-
Move value from sourceKey to destinationKey
- sMove(Publisher<ReactiveSetCommands.SMoveCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveSetCommands
- SMOVE - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- sort(byte[], SortParameters) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.keyCommands()
. - sort(byte[], SortParameters) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- sort(byte[], SortParameters) - Method in interface org.springframework.data.redis.connection.RedisKeyCommands
-
Sort the elements for
key
. - sort(byte[], SortParameters, byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.keyCommands()
. - sort(byte[], SortParameters, byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- sort(byte[], SortParameters, byte[]) - Method in interface org.springframework.data.redis.connection.RedisKeyCommands
-
Sort the elements for
key
and store result instoreKey
. - sort(String, SortParameters) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- sort(String, SortParameters) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Sort the elements for
key
. - sort(String, SortParameters, String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- sort(String, SortParameters, String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Sort the elements for
key
and store result instoreKey
. - sort(K) - Static method in class org.springframework.data.redis.core.query.SortQueryBuilder
- sort(Sort.Direction) - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusByMemberCommand
-
Applies the distance sort
Sort.Direction
. - sort(Sort.Direction) - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusCommand
-
Applies the distance sort
Sort.Direction
. - sort(Sort.Direction) - Method in class org.springframework.data.redis.connection.RedisGeoCommands.GeoRadiusCommandArgs
-
Apply a sort direction.
- sort(Sort.Direction) - Method in class org.springframework.data.redis.connection.RedisGeoCommands.GeoSearchCommandArgs
-
Apply a sort direction.
- sort(Sort.Direction) - Method in class org.springframework.data.redis.connection.RedisGeoCommands.GeoSearchStoreCommandArgs
-
Apply a sort direction.
- sort(SortQuery<K>) - Method in interface org.springframework.data.redis.core.RedisOperations
-
Sort the elements for
query
. - sort(SortQuery<K>) - Method in class org.springframework.data.redis.core.RedisTemplate
- sort(SortQuery<K>, K) - Method in interface org.springframework.data.redis.core.RedisOperations
-
Sort the elements for
query
and store result instoreKey
. - sort(SortQuery<K>, K) - Method in class org.springframework.data.redis.core.RedisTemplate
- sort(SortQuery<K>, BulkMapper<T, S>, RedisSerializer<S>) - Method in interface org.springframework.data.redis.core.RedisOperations
- sort(SortQuery<K>, BulkMapper<T, S>, RedisSerializer<S>) - Method in class org.springframework.data.redis.core.RedisTemplate
- sort(SortQuery<K>, BulkMapper<T, V>) - Method in interface org.springframework.data.redis.core.RedisOperations
-
Sort the elements for
query
applyingBulkMapper
. - sort(SortQuery<K>, BulkMapper<T, V>) - Method in class org.springframework.data.redis.core.RedisTemplate
- sort(SortQuery<K>, RedisSerializer<T>) - Method in interface org.springframework.data.redis.core.RedisOperations
-
Sort the elements for
query
applyingRedisSerializer
. - sort(SortQuery<K>, RedisSerializer<T>) - Method in class org.springframework.data.redis.core.RedisTemplate
- SORT - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- sortAscending() - Method in class org.springframework.data.redis.connection.RedisGeoCommands.GeoRadiusCommandArgs
-
Sort returned items from the nearest to the furthest, relative to the center.
- sortAscending() - Method in class org.springframework.data.redis.connection.RedisGeoCommands.GeoSearchCommandArgs
-
Sort returned items from the nearest to the furthest, relative to the center.
- sortAscending() - Method in class org.springframework.data.redis.connection.RedisGeoCommands.GeoSearchStoreCommandArgs
-
Sort returned items from the nearest to the furthest, relative to the center.
- SortCriterion<K> - Interface in org.springframework.data.redis.core.query
-
Internal interface part of the Sort DSL.
- sortDescending() - Method in class org.springframework.data.redis.connection.RedisGeoCommands.GeoRadiusCommandArgs
-
Sort returned items from the furthest to the nearest, relative to the center.
- sortDescending() - Method in class org.springframework.data.redis.connection.RedisGeoCommands.GeoSearchCommandArgs
-
Sort returned items from the furthest to the nearest, relative to the center.
- sortDescending() - Method in class org.springframework.data.redis.connection.RedisGeoCommands.GeoSearchStoreCommandArgs
-
Sort returned items from the furthest to the nearest, relative to the center.
- sortDirection - Variable in class org.springframework.data.redis.connection.RedisGeoCommands.GeoSearchCommandArgs
- SortParameters - Interface in org.springframework.data.redis.connection
-
Entity containing the parameters for the SORT operation.
- SortParameters.Order - Enum Class in org.springframework.data.redis.connection
-
Sorting order.
- SortParameters.Range - Class in org.springframework.data.redis.connection
-
Utility class wrapping the 'LIMIT' setting.
- SortQuery<K> - Interface in org.springframework.data.redis.core.query
-
High-level abstraction over a Redis SORT (generified equivalent of
SortParameters
). - SortQueryBuilder<K> - Class in org.springframework.data.redis.core.query
-
Simple builder class for constructing
SortQuery
. - sourceKeys(Collection<ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZDiffStoreCommand
-
Creates a new
ReactiveZSetCommands.ZDiffStoreCommand
given aCollection
of keys. - SpelIndexDefinition - Class in org.springframework.data.redis.core.index
-
SpelIndexDefinition
defines index that is evaluated based on aSpelExpression
requires theSpelIndexResolver
to be evaluated. - SpelIndexDefinition(String, String, String) - Constructor for class org.springframework.data.redis.core.index.SpelIndexDefinition
-
Creates new
SpelIndexDefinition
. - SpelIndexResolver - Class in org.springframework.data.redis.core.convert
- SpelIndexResolver(RedisMappingContext) - Constructor for class org.springframework.data.redis.core.convert.SpelIndexResolver
-
Creates a new instance using a default
SpelExpressionParser
. - SpelIndexResolver(RedisMappingContext, SpelExpressionParser) - Constructor for class org.springframework.data.redis.core.convert.SpelIndexResolver
-
Creates a new instance
- split(byte[], int) - Static method in class org.springframework.data.redis.util.ByteUtils
-
Split
source
into partitioned arrays using delimiterc
. - sPop(byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.setCommands()
}. - sPop(byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- sPop(byte[]) - Method in interface org.springframework.data.redis.connection.RedisSetCommands
-
Remove and return a random member from set at
key
. - sPop(byte[], long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.setCommands()
}. - sPop(byte[], long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- sPop(byte[], long) - Method in interface org.springframework.data.redis.connection.RedisSetCommands
-
Remove and return
count
random members from set atkey
. - sPop(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- sPop(String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Remove and return a random member from set at
key
. - sPop(String, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- sPop(String, long) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Remove and return
count
random members from set atkey
. - sPop(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveSetCommands
-
Remove and return a random member from set at key.
- sPop(ByteBuffer, long) - Method in interface org.springframework.data.redis.connection.ReactiveSetCommands
-
Remove and return
count
random members from set atkey
. - sPop(Publisher<ReactiveRedisConnection.KeyCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveSetCommands
-
Remove and return a random member from set at
ReactiveRedisConnection.KeyCommand.getKey()
- sPop(ReactiveSetCommands.SPopCommand) - Method in interface org.springframework.data.redis.connection.ReactiveSetCommands
-
Remove and return a random member from set at key.
- SPOP - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- sRandMember(byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.setCommands()
}. - sRandMember(byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- sRandMember(byte[]) - Method in interface org.springframework.data.redis.connection.RedisSetCommands
-
Get random element from set at
key
. - sRandMember(byte[], long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.setCommands()
}. - sRandMember(byte[], long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- sRandMember(byte[], long) - Method in interface org.springframework.data.redis.connection.RedisSetCommands
-
Get
count
random elements from set atkey
. - sRandMember(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- sRandMember(String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get random element from set at
key
. - sRandMember(String, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- sRandMember(String, long) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get
count
random elements from set atkey
. - sRandMember(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveSetCommands
-
Get random element from set at key.
- sRandMember(ByteBuffer, Long) - Method in interface org.springframework.data.redis.connection.ReactiveSetCommands
-
Get count random elements from set at key.
- sRandMember(Publisher<ReactiveSetCommands.SRandMembersCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveSetCommands
-
Get
ReactiveSetCommands.SRandMembersCommand.getCount()
random elements from set atReactiveRedisConnection.KeyCommand.getKey()
. - SRANDMEMBER - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- sRem(byte[], byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.setCommands()
}. - sRem(byte[], byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- sRem(byte[], byte[]...) - Method in interface org.springframework.data.redis.connection.RedisSetCommands
-
Remove given
values
from set atkey
and return the number of removed elements. - sRem(String, String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- sRem(String, String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Remove given
values
from set atkey
and return the number of removed elements. - sRem(ByteBuffer, ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveSetCommands
-
Remove given value from set at key and return the number of removed elements.
- sRem(ByteBuffer, Collection<ByteBuffer>) - Method in interface org.springframework.data.redis.connection.ReactiveSetCommands
-
Remove given values from set at key and return the number of removed elements.
- sRem(Publisher<ReactiveSetCommands.SRemCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveSetCommands
-
Remove given
ReactiveSetCommands.SRemCommand.getValues()
from set atReactiveRedisConnection.KeyCommand.getKey()
. - SREM - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- sScan(byte[], ScanOptions) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.setCommands()
}. - sScan(byte[], ScanOptions) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- sScan(byte[], ScanOptions) - Method in interface org.springframework.data.redis.connection.RedisSetCommands
-
Use a
Cursor
to iterate over elements in set atkey
. - sScan(String, ScanOptions) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- sScan(String, ScanOptions) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Use a
Cursor
to iterate over elements in set atkey
. - sScan(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveSetCommands
-
Use a
Flux
to iterate over members in the set atkey
. - sScan(ByteBuffer, ScanOptions) - Method in interface org.springframework.data.redis.connection.ReactiveSetCommands
- sScan(Publisher<ReactiveRedisConnection.KeyScanCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveSetCommands
-
Use a
Flux
to iterate over members in the set atkey
. - SSCAN - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- sslParameters(SSLParameters) - Method in class org.springframework.data.redis.connection.jedis.JedisClientConfiguration.DefaultJedisClientConfigurationBuilder
- sslParameters(SSLParameters) - Method in interface org.springframework.data.redis.connection.jedis.JedisClientConfiguration.JedisSslClientConfigurationBuilder
- sslSocketFactory(SSLSocketFactory) - Method in class org.springframework.data.redis.connection.jedis.JedisClientConfiguration.DefaultJedisClientConfigurationBuilder
- sslSocketFactory(SSLSocketFactory) - Method in interface org.springframework.data.redis.connection.jedis.JedisClientConfiguration.JedisSslClientConfigurationBuilder
- STABLE - Enum constant in enum class org.springframework.data.redis.connection.ReactiveClusterCommands.AddSlots
- STABLE - Enum constant in enum class org.springframework.data.redis.connection.RedisClusterCommands.AddSlots
- start() - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
- start() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
- start() - Method in class org.springframework.data.redis.core.RedisKeyValueAdapter
- start() - Method in class org.springframework.data.redis.listener.RedisMessageListenerContainer
-
Startup the container and subscribe to topics if
listeners
were registered prior to starting the container. - STARTING - Enum constant in enum class org.springframework.data.redis.stream.Task.State
- startsWith(byte[], byte[]) - Static method in class org.springframework.data.redis.util.ByteUtils
-
Tests if the
haystack
starts with the givenprefix
. - startsWith(byte[], byte[], int) - Static method in class org.springframework.data.redis.util.ByteUtils
-
Tests if the
haystack
beginning at the specifiedoffset
starts with the givenprefix
. - startTls() - Method in class org.springframework.data.redis.connection.lettuce.LettuceClientConfiguration.LettuceSslClientConfigurationBuilder
-
Enable Start TLS to send the first bytes unencrypted.
- startTls() - Method in class org.springframework.data.redis.connection.lettuce.LettucePoolingClientConfiguration.LettucePoolingSslClientConfigurationBuilder
- STATE - Enum constant in enum class org.springframework.data.redis.connection.ClusterInfo.Info
- STATUS - Enum constant in enum class org.springframework.data.redis.connection.ReturnType
-
Returned as byte[]
- stop() - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
- stop() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
- stop() - Method in class org.springframework.data.redis.core.RedisKeyValueAdapter
- stop() - Method in class org.springframework.data.redis.listener.RedisMessageListenerContainer
-
Stop the message listener container and cancel any subscriptions if the container is
listening
. - stop(Runnable) - Method in class org.springframework.data.redis.listener.RedisMessageListenerContainer
-
Stop the message listener container and cancel any subscriptions if the container is
listening
. - store(String, byte[], byte[], Duration) - Method in interface org.springframework.data.redis.cache.RedisCacheWriter
-
Store the given key/value pair asynchronously to Redis and set the expiration time if defined.
- storeAs(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZAggregateStoreCommand
-
Applies the key at which the result is stored.
- storeAs(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZDiffStoreCommand
-
Applies the key at which the result is stored.
- storeAs(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZInterStoreCommand
-
Applies the key at which the result is stored.
- storeAs(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZUnionStoreCommand
-
Applies the key at which the result is stored.
- storeAt(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusByMemberCommand
-
NOTE: STORE option is not compatible with WITHDIST, WITHHASH and WITHCOORDS options.
- storeAt(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusCommand
-
NOTE: STORE option is not compatible with WITHDIST, WITHHASH and WITHCOORDS options.
- storeAt(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoSearchStoreCommand
-
Sets the geoset destKey.
- storeAt(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveSetCommands.SDiffStoreCommand
-
Applies the key at which the result is stored.
- storeAt(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveSetCommands.SInterStoreCommand
-
Applies the key at which the result is stored.
- storeAt(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveSetCommands.SUnionStoreCommand
-
Applies the key at which the result is stored.
- storeDist() - Static method in interface org.springframework.data.redis.connection.RedisGeoCommands.GeoCommandArgs.GeoCommandFlag
- STOREDIST - Enum constant in enum class org.springframework.data.redis.connection.RedisGeoCommands.GeoRadiusCommandArgs.Flag
- storeDistance() - Method in class org.springframework.data.redis.connection.RedisGeoCommands.GeoSearchStoreCommandArgs
-
Sets the
RedisGeoCommands.GeoRadiusCommandArgs.Flag.STOREDIST
flag to also store the distance of the returned items from the specified center. - storeDistAt(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusByMemberCommand
-
NOTE: STOREDIST option is not compatible with WITHDIST, WITHHASH and WITHCOORDS options.
- storeDistAt(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusCommand
-
NOTE: STOREDIST option is not compatible with WITHDIST, WITHHASH and WITHCOORDS options.
- storedWithin(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZIncrByCommand
-
Applies the key.
- storedWithin(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRankCommand
-
Applies the key.
- storeToXML(OutputStream, String) - Method in class org.springframework.data.redis.support.collections.RedisProperties
- storeToXML(OutputStream, String, String) - Method in class org.springframework.data.redis.support.collections.RedisProperties
- stream() - Method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoConsumers
-
Returns a sequential
Stream
ofStreamInfo.XInfoConsumer
. - stream() - Method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoGroups
-
Returns a sequential
Stream
ofStreamInfo.XInfoGroup
. - stream(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveStreamCommands.AcknowledgeCommand
-
Creates a new
ReactiveStreamCommands.AcknowledgeCommand
given akey
. - stream(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveStreamCommands.DeleteCommand
-
Creates a new
ReactiveStreamCommands.DeleteCommand
given akey
. - stream(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveStreamCommands.RangeCommand
-
Creates a new
ReactiveStreamCommands.RangeCommand
given akey
. - stream(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveStreamCommands.TrimCommand
-
Creates a new
ReactiveStreamCommands.TrimCommand
given akey
. - STREAM - Enum constant in enum class org.springframework.data.redis.connection.DataType
- streamCommands() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- streamCommands() - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
- streamCommands() - Method in class org.springframework.data.redis.connection.jedis.JedisConnection
- streamCommands() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
- streamCommands() - Method in interface org.springframework.data.redis.connection.ReactiveRedisClusterConnection
- streamCommands() - Method in interface org.springframework.data.redis.connection.ReactiveRedisConnection
- streamCommands() - Method in interface org.springframework.data.redis.connection.RedisCommandsProvider
-
Get
RedisStreamCommands
. - StreamInfo - Class in org.springframework.data.redis.connection.stream
- StreamInfo() - Constructor for class org.springframework.data.redis.connection.stream.StreamInfo
- StreamInfo.XInfoConsumer - Class in org.springframework.data.redis.connection.stream
- StreamInfo.XInfoConsumers - Class in org.springframework.data.redis.connection.stream
- StreamInfo.XInfoGroup - Class in org.springframework.data.redis.connection.stream
- StreamInfo.XInfoGroups - Class in org.springframework.data.redis.connection.stream
-
Value object holding general information about consumer groups associated with a Redis Stream.
- StreamInfo.XInfoObject - Class in org.springframework.data.redis.connection.stream
- StreamInfo.XInfoStream - Class in org.springframework.data.redis.connection.stream
-
Value object holding general information about a Redis Stream.
- streamLength() - Method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoStream
-
Total number of element in the stream.
- StreamListener<K,
V extends Record<K, ?>> - Interface in org.springframework.data.redis.stream -
Listener interface to receive delivery of
messages
. - StreamMessageListenerContainer<K,
V extends Record<K, ?>> - Interface in org.springframework.data.redis.stream -
Abstraction used by the framework representing a message listener container.
- StreamMessageListenerContainer.ConsumerStreamReadRequest<K> - Class in org.springframework.data.redis.stream
-
Request to read a Redis Stream with a
Consumer
. - StreamMessageListenerContainer.ConsumerStreamReadRequestBuilder<K> - Class in org.springframework.data.redis.stream
-
Builder to build a
StreamMessageListenerContainer.ConsumerStreamReadRequest
. - StreamMessageListenerContainer.StreamMessageListenerContainerOptions<K,
V extends Record<K, ?>> - Class in org.springframework.data.redis.stream -
Options for
StreamMessageListenerContainer
. - StreamMessageListenerContainer.StreamMessageListenerContainerOptionsBuilder<K,
V extends Record<K, ?>> - Class in org.springframework.data.redis.stream - StreamMessageListenerContainer.StreamReadRequest<K> - Class in org.springframework.data.redis.stream
-
Request to read a Redis Stream.
- StreamMessageListenerContainer.StreamReadRequestBuilder<K> - Class in org.springframework.data.redis.stream
-
Builder to build a
StreamMessageListenerContainer.StreamReadRequest
. - StreamOffset<K> - Class in org.springframework.data.redis.connection.stream
-
Value object representing a Stream Id with its offset.
- StreamOperations<K,
HK, HV> - Interface in org.springframework.data.redis.core -
Redis stream specific operations.
- StreamReadOptions - Class in org.springframework.data.redis.connection.stream
-
Options for reading messages from a Redis Stream.
- StreamReceiver<K,
V extends Record<K, ?>> - Interface in org.springframework.data.redis.stream -
A receiver to consume Redis Streams using reactive infrastructure.
- StreamReceiver.StreamReceiverOptions<K,
V extends Record<K, ?>> - Class in org.springframework.data.redis.stream -
Options for
StreamReceiver
. - StreamReceiver.StreamReceiverOptionsBuilder<K,
V extends Record<K, ?>> - Class in org.springframework.data.redis.stream -
Builder for
StreamReceiver.StreamReceiverOptions
. - StreamRecords - Class in org.springframework.data.redis.connection.stream
-
StreamRecords
provides utilities to create specificRecord
instances. - StreamRecords.RecordBuilder<S> - Class in org.springframework.data.redis.connection.stream
-
Builder for
Record
. - string() - Static method in interface org.springframework.data.redis.serializer.RedisSerializationContext
-
Creates a new
RedisSerializationContext
using aStringRedisSerializer
. - string() - Static method in interface org.springframework.data.redis.serializer.RedisSerializer
- string(Map<String, String>) - Static method in class org.springframework.data.redis.connection.stream.StreamRecords
-
Create a new
ByteBufferRecord
for the given raw field/value pairs. - string(RedisElementReader<String>, RedisElementWriter<String>) - Method in interface org.springframework.data.redis.serializer.RedisSerializationContext.RedisSerializationContextBuilder
-
Set the string
RedisElementReader
andRedisElementWriter
. - string(RedisSerializationContext.SerializationPair<String>) - Method in interface org.springframework.data.redis.serializer.RedisSerializationContext.RedisSerializationContextBuilder
-
Set the string
RedisSerializationContext.SerializationPair
. - string(RedisSerializer<String>) - Method in interface org.springframework.data.redis.serializer.RedisSerializationContext.RedisSerializationContextBuilder
-
Set the string
RedisSerializationContext.SerializationPair
given aRedisSerializer
. - STRING - Enum constant in enum class org.springframework.data.redis.connection.DataType
- stringCommands() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- stringCommands() - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
- stringCommands() - Method in class org.springframework.data.redis.connection.jedis.JedisConnection
- stringCommands() - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
- stringCommands() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
- stringCommands() - Method in interface org.springframework.data.redis.connection.ReactiveRedisClusterConnection
- stringCommands() - Method in interface org.springframework.data.redis.connection.ReactiveRedisConnection
- stringCommands() - Method in interface org.springframework.data.redis.connection.RedisCommandsProvider
-
Get
RedisStringCommands
. - StringRecord - Interface in org.springframework.data.redis.connection.stream
- StringRedisConnection - Interface in org.springframework.data.redis.connection
-
Convenience extension of
RedisConnection
that accepts and returnsString
s instead of byte arrays. - StringRedisConnection.StringTuple - Interface in org.springframework.data.redis.connection
-
String-friendly ZSet tuple.
- StringRedisSerializer - Class in org.springframework.data.redis.serializer
-
Simple
String
to byte[] (and back) serializer. - StringRedisSerializer() - Constructor for class org.springframework.data.redis.serializer.StringRedisSerializer
-
Creates a new
StringRedisSerializer
usingUTF-8
. - StringRedisSerializer(Charset) - Constructor for class org.springframework.data.redis.serializer.StringRedisSerializer
-
Creates a new
StringRedisSerializer
using the givenCharset
to encode and decode strings. - StringRedisTemplate - Class in org.springframework.data.redis.core
-
String-focused extension of RedisTemplate.
- StringRedisTemplate() - Constructor for class org.springframework.data.redis.core.StringRedisTemplate
-
Constructs a new
StringRedisTemplate
instance. - StringRedisTemplate(RedisConnectionFactory) - Constructor for class org.springframework.data.redis.core.StringRedisTemplate
-
Constructs a new
StringRedisTemplate
instance ready to be used. - stringsWithin(Range<String>) - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZLexCountCommand
-
Creates a new
ReactiveZSetCommands.ZLexCountCommand
given aRange
ofString
to retrieve elements count. - stringsWithin(Range<String>) - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRangeByLexCommand
-
Creates a new
ReactiveZSetCommands.ZRangeByLexCommand
given aRange
ofString
to retrieve elements lexicographical ordering. - stringToBoolean(String) - Static method in class org.springframework.data.redis.connection.convert.Converters
- stringToBooleanConverter() - Static method in class org.springframework.data.redis.connection.convert.Converters
- stringToDataType() - Static method in class org.springframework.data.redis.connection.convert.Converters
- StringToDataTypeConverter - Class in org.springframework.data.redis.connection.convert
-
Converts Strings to
DataType
s - StringToDataTypeConverter() - Constructor for class org.springframework.data.redis.connection.convert.StringToDataTypeConverter
- StringToPropertiesConverter - Class in org.springframework.data.redis.connection.convert
-
Converts Strings to
Properties
- StringToPropertiesConverter() - Constructor for class org.springframework.data.redis.connection.convert.StringToPropertiesConverter
- stringToProps() - Static method in class org.springframework.data.redis.connection.convert.Converters
- StringToRedisClientInfoConverter - Class in org.springframework.data.redis.connection.convert
- StringToRedisClientInfoConverter() - Constructor for class org.springframework.data.redis.connection.convert.StringToRedisClientInfoConverter
- stringToRedisClientListConverter() - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
- strLen(byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.stringCommands()
}. - strLen(byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- strLen(byte[]) - Method in interface org.springframework.data.redis.connection.RedisStringCommands
-
Get the length of the value stored at
key
. - strLen(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- strLen(String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get the length of the value stored at
key
. - strLen(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
-
Get the length of the value stored at key.
- strLen(Publisher<ReactiveRedisConnection.KeyCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
-
Get the length of the value stored at key.
- STRLEN - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- SUBKEY_END - Static variable in class org.springframework.data.redis.connection.ClusterSlotHashUtil
- SUBKEY_START - Static variable in class org.springframework.data.redis.connection.ClusterSlotHashUtil
- subList(int, int) - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- subscribe(byte[]...) - Method in interface org.springframework.data.redis.connection.Subscription
-
Adds the given channels to the current subscription.
- subscribe(byte[]...) - Method in class org.springframework.data.redis.connection.util.AbstractSubscription
- subscribe(ByteBuffer...) - Method in interface org.springframework.data.redis.connection.ReactivePubSubCommands
-
Subscribes the connection to the given
channels
. - subscribe(ByteBuffer...) - Method in interface org.springframework.data.redis.connection.ReactiveSubscription
-
Subscribes to the
channels
and adds these to the current subscription. - subscribe(MessageListener, byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- subscribe(MessageListener, byte[]...) - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
- subscribe(MessageListener, byte[]...) - Method in class org.springframework.data.redis.connection.jedis.JedisConnection
- subscribe(MessageListener, byte[]...) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
- subscribe(MessageListener, byte[]...) - Method in interface org.springframework.data.redis.connection.RedisPubSubCommands
-
Subscribes the connection to the given channels.
- subscribe(MessageListener, String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- subscribe(MessageListener, String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Subscribes the connection to the given channels.
- SUBSCRIBE - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- Subscription - Interface in org.springframework.data.redis.connection
-
Subscription for Redis channels.
- Subscription - Interface in org.springframework.data.redis.stream
-
The
Subscription
is the link to the actual runningTask
. - SubscriptionListener - Interface in org.springframework.data.redis.connection
-
Listener for subscription notifications.
- SUM - Enum constant in enum class org.springframework.data.redis.connection.zset.Aggregate
- sUnion(byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.setCommands()
}. - sUnion(byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- sUnion(byte[]...) - Method in interface org.springframework.data.redis.connection.RedisSetCommands
-
Union all sets at given
keys
. - sUnion(String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- sUnion(String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Union all sets at given
keys
. - sUnion(Collection<ByteBuffer>) - Method in interface org.springframework.data.redis.connection.ReactiveSetCommands
-
Returns the members intersecting all given sets at keys.
- sUnion(Publisher<ReactiveSetCommands.SUnionCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveSetCommands
-
Returns the members intersecting all given sets at
ReactiveSetCommands.SInterCommand.getKeys()
. - SUNION - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- sUnionStore(byte[], byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.setCommands()
}. - sUnionStore(byte[], byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- sUnionStore(byte[], byte[]...) - Method in interface org.springframework.data.redis.connection.RedisSetCommands
-
Union all sets at given
keys
and store result indestKey
. - sUnionStore(String, String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- sUnionStore(String, String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Union all sets at given
keys
and store result indestKey
. - sUnionStore(ByteBuffer, Collection<ByteBuffer>) - Method in interface org.springframework.data.redis.connection.ReactiveSetCommands
-
Union all given sets at keys and store result in destinationKey.
- sUnionStore(Publisher<ReactiveSetCommands.SUnionStoreCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveSetCommands
-
Union all given sets at keys and store result in destinationKey.
- SUNIONSTORE - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- supports(Class<?>) - Static method in class org.springframework.data.redis.core.convert.Jsr310Converters
- supportsAsyncRetrieve() - Method in interface org.springframework.data.redis.cache.RedisCacheWriter
-
Determines whether the asynchronous
RedisCacheWriter.retrieve(String, byte[])
andRedisCacheWriter.retrieve(String, byte[], Duration)
cache operations are supported by the implementation. - switchToPubSub() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
-
LettuceConnection.close()
the current connection and open a new pub/sub connection to the Redis server. - SYNC - Enum constant in enum class org.springframework.data.redis.connection.RedisServerCommands.FlushOption
- SYNC - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
T
- take() - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- takeFirst() - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- takeLast() - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- targetType(Class<NV>) - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamMessageListenerContainerOptionsBuilder
-
Configure a hash target type.
- targetType(Class<NV>) - Method in class org.springframework.data.redis.stream.StreamReceiver.StreamReceiverOptionsBuilder
-
Configure a hash target type.
- Task - Interface in org.springframework.data.redis.stream
-
The actual
Task
to run within theStreamMessageListenerContainer
. - Task.State - Enum Class in org.springframework.data.redis.stream
-
The
Task.State
defining the lifecycle phase the actualTask
. - time() - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.serverCommands()
. - time() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- time() - Method in interface org.springframework.data.redis.connection.ReactiveServerCommands
-
Request server timestamp using
TIME
command inTimeUnit.MILLISECONDS
. - time() - Method in interface org.springframework.data.redis.connection.RedisServerCommands
-
Request server timestamp using
TIME
command inTimeUnit.MILLISECONDS
. - time(Instant) - Method in class org.springframework.data.redis.connection.RedisStreamCommands.XClaimOptions
-
Sets the idle time to a specific unix time (in milliseconds).
- time(TimeUnit) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.serverCommands()
. - time(TimeUnit) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- time(TimeUnit) - Method in interface org.springframework.data.redis.connection.ReactiveServerCommands
-
Request server timestamp using
TIME
command. - time(TimeUnit) - Method in interface org.springframework.data.redis.connection.RedisServerCommands
-
Request server timestamp using
TIME
command. - time(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.DefaultedRedisClusterConnection
-
Deprecated.in favor of
RedisCommandsProvider.serverCommands()
. - time(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.ReactiveClusterServerCommands
-
Request server timestamp using
TIME
command. - time(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.RedisClusterServerCommands
- time(RedisClusterNode, TimeUnit) - Method in interface org.springframework.data.redis.connection.DefaultedRedisClusterConnection
-
Deprecated.in favor of
RedisCommandsProvider.serverCommands()
. - time(RedisClusterNode, TimeUnit) - Method in interface org.springframework.data.redis.connection.RedisClusterServerCommands
- TIME - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- timeout(int) - Method in class org.springframework.data.redis.connection.ReactiveKeyCommands.MoveCommand
-
Applies the database index.
- timeout(Duration) - Method in class org.springframework.data.redis.connection.ReactiveKeyCommands.ExpireCommand
-
Applies the timeout.
- timeout(Duration) - Method in class org.springframework.data.redis.connection.ReactiveListCommands.LMoveCommand
-
Applies the
timeout
. - timeout(Instant) - Method in class org.springframework.data.redis.connection.ReactiveKeyCommands.ExpireAtCommand
-
Applies the expireAt.
- TimeoutUtils - Class in org.springframework.data.redis.core
-
Helper class featuring methods for calculating Redis timeouts
- TimeoutUtils() - Constructor for class org.springframework.data.redis.core.TimeoutUtils
- timeToLive() - Element in annotation interface org.springframework.data.redis.core.RedisHash
-
Time before expire in seconds.
- TimeToLive - Annotation Interface in org.springframework.data.redis.core
-
TimeToLive
marks a single numeric property on aggregate root to be used for setting expirations in Redis. - TimeToLiveAccessor - Interface in org.springframework.data.redis.core
-
TimeToLiveAccessor
extracts the objects time to live used forEXPIRE
. - to(boolean) - Method in class org.springframework.data.redis.connection.ReactiveStringCommands.SetBitCommand
-
Applies the bit.
- to(long) - Method in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldSetBuilder
-
Set the value.
- to(long) - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.TrimCommand
-
Applies the numeric count.
- to(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoAddCommand
-
Applies the Geo set key.
- to(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveHyperLogLogCommands.PfAddCommand
-
Applies the key.
- to(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveKeyCommands.CopyCommand
-
Applies the
targetKey
. - to(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveKeyCommands.RenameCommand
-
Applies the newKey.
- to(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveListCommands.BRPopLPushCommand
-
Applies the destinationKey.
- to(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveListCommands.LSetCommand
-
Applies the value.
- to(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveListCommands.PushCommand
-
Applies the key.
- to(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveListCommands.RPopLPushCommand
-
Applies the destinationKey.
- to(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveSetCommands.SAddCommand
-
Applies the key.
- to(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveSetCommands.SMoveCommand
-
Applies the destination key.
- to(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.AddStreamRecord
-
Applies the Geo set key.
- to(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZAddCommand
-
Applies the key.
- to(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRangeStoreCommand
-
Applies the key.
- to(ByteBuffer, ReactiveListCommands.Direction) - Method in class org.springframework.data.redis.connection.ReactiveListCommands.LMoveCommand
-
Applies the
destinationKey
. - toArray() - Method in class org.springframework.data.redis.connection.util.ByteArraySet
- toArray() - Method in class org.springframework.data.redis.connection.zset.Weights
- toArray(T[]) - Method in class org.springframework.data.redis.connection.util.ByteArraySet
- toBit(Boolean) - Static method in class org.springframework.data.redis.connection.convert.Converters
- toBitFieldArgs(BitFieldSubCommands) - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
-
Convert
BitFieldSubCommands
intoBitFieldArgs
. - toBoolean(long) - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
- toBoolean(Long) - Static method in class org.springframework.data.redis.connection.convert.Converters
- toBoolean(RedisListCommands.Position) - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
- toBytes(Double) - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
- toBytes(Integer) - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
- toBytes(Long) - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
- toBytes(Object) - Method in class org.springframework.data.redis.core.convert.MappingRedisConverter
-
Convert given source to binary representation using the underlying
ConversionService
. - toBytes(Object) - Method in class org.springframework.data.redis.core.RedisKeyValueAdapter
-
Convert given source to binary representation using the underlying
ConversionService
. - toBytes(String) - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
- toBytesList(KeyValue<byte[], byte[]>) - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
- toBytesList(Collection<byte[]>) - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
- toBytesSet(List<byte[]>) - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
- toClusterNode(String) - Static method in class org.springframework.data.redis.connection.convert.Converters
-
Converts the result of a single line of
CLUSTER NODES
into aRedisClusterNode
. - toDataType(String) - Static method in class org.springframework.data.redis.connection.convert.Converters
- toDoubleSeconds(long, TimeUnit) - Static method in class org.springframework.data.redis.core.TimeoutUtils
-
Converts the given timeout to seconds with a fraction of seconds.
- toGeoArgs(RedisGeoCommands.GeoCommandArgs) - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
-
Convert
RedisGeoCommands.GeoCommandArgs
intoGeoArgs
. - toGeoArgs(RedisGeoCommands.GeoRadiusCommandArgs) - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
-
Convert
RedisGeoCommands.GeoRadiusCommandArgs
intoGeoArgs
. - toGeoArgsUnit(Metric) - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
-
Convert
Metric
intoGeoArgs.Unit
. - toHash(Object) - Method in class org.springframework.data.redis.hash.Jackson2HashMapper
- toHash(Object) - Method in class org.springframework.data.redis.hash.ObjectHashMapper
- toHash(T) - Method in class org.springframework.data.redis.hash.BeanUtilsHashMapper
- toHash(T) - Method in class org.springframework.data.redis.hash.DecoratingStringHashMapper
- toHash(T) - Method in interface org.springframework.data.redis.hash.HashMapper
-
Convert an
object
to a map that can be used with Redis hashes. - toHead(K) - Static method in class org.springframework.data.redis.core.ListOperations.MoveTo
- toIndex(long) - Method in class org.springframework.data.redis.connection.ReactiveRedisConnection.RangeCommand
-
Applies an upper bound to the
Range
. - toInt(boolean) - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
- toLimit(Limit) - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
-
Convert a
Limit
to a LettuceLimit
. - toList() - Method in class org.springframework.data.redis.connection.zset.Weights
- toListOfRedisClientInformation(String) - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
- toListOfRedisServer(List<Map<String, String>>) - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
- toLong(Date) - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
- toMap(List<byte[]>) - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
- toMapRecord(HashMapper<? super V, HK, HV>) - Method in interface org.springframework.data.redis.connection.stream.ObjectRecord
-
Apply the given
HashMapper
to the backing value to create a newMapRecord
. - toMillis(long, TimeUnit) - Static method in class org.springframework.data.redis.core.TimeoutUtils
-
Converts the given timeout to milliseconds.
- toObjectRecord(HashMapper<? super OV, ? super ByteBuffer, ? super ByteBuffer>) - Method in interface org.springframework.data.redis.connection.stream.ByteBufferRecord
-
Convert a binary
MapRecord
into anObjectRecord
. - toObjectRecord(HashMapper<? super OV, ? super K, ? super V>) - Method in interface org.springframework.data.redis.connection.stream.MapRecord
-
Apply the given
HashMapper
to the backing value to create a newMapRecord
. - toObjects(Set<Tuple>) - Static method in class org.springframework.data.redis.connection.convert.Converters
- TooManyClusterRedirectionsException - Exception in org.springframework.data.redis
-
DataRetrievalFailureException
thrown when following cluster redirects exceeds the max number of edges. - TooManyClusterRedirectionsException(String) - Constructor for exception org.springframework.data.redis.TooManyClusterRedirectionsException
-
Creates new
TooManyClusterRedirectionsException
. - TooManyClusterRedirectionsException(String, Throwable) - Constructor for exception org.springframework.data.redis.TooManyClusterRedirectionsException
-
Creates new
TooManyClusterRedirectionsException
. - toOptional() - Method in class org.springframework.data.redis.connection.RedisPassword
-
Adopt the password to
Optional
containing the password value. - toOptionString() - Method in class org.springframework.data.redis.core.KeyScanOptions
- toOptionString() - Method in class org.springframework.data.redis.core.ScanOptions
- Topic - Interface in org.springframework.data.redis.listener
-
Topic for a Redis message.
- toProperties(String) - Static method in class org.springframework.data.redis.connection.convert.Converters
- toProperties(List<String>) - Static method in class org.springframework.data.redis.connection.convert.Converters
-
Converts array outputs with key-value sequences (such as produced by
CONFIG GET
) from aList
toProperties
. - toProperties(Map<?, ?>) - Static method in class org.springframework.data.redis.connection.convert.Converters
- toRange() - Method in class org.springframework.data.redis.connection.RedisZSetCommands.Range
-
Deprecated.Create a
Range
object from this range. - toRange(Range<T>) - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
-
Convert a
RedisZSetCommands.Range
to a lettuceRange
. - toRange(Range<T>, boolean) - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
-
Convert a
Range
to a lettuceRange
. - toRedisClusterNode(RedisClusterNode) - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
- toRevRange(Range<T>) - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
-
Convert a
Range
to a lettuceRange
and reverse boundaries. - toScriptOutputType(ReturnType) - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
- toSeconds(long, TimeUnit) - Static method in class org.springframework.data.redis.core.TimeoutUtils
-
Converts the given timeout to seconds.
- toSeconds(Duration) - Static method in class org.springframework.data.redis.core.TimeoutUtils
-
Converts the given timeout to seconds.
- toSetArgs(Expiration, RedisStringCommands.SetOption) - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
- toSetOfRedisClusterNodes(String) - Static method in class org.springframework.data.redis.connection.convert.Converters
-
Converts the result of
CLUSTER NODES
intoRedisClusterNode
s. - toSetOfRedisClusterNodes(Collection<String>) - Static method in class org.springframework.data.redis.connection.convert.Converters
-
Converts lines from the result of
CLUSTER NODES
intoRedisClusterNode
s. - toSortArgs(SortParameters) - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
- toString() - Method in record class org.springframework.data.redis.cache.FixedDurationTtlFunction
-
Returns a string representation of this record class.
- toString() - Method in class org.springframework.data.redis.connection.BitFieldSubCommands.AbstractBitFieldSubCommand
- toString() - Method in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldIncrBy
- toString() - Method in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldSet
- toString() - Method in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldType
- toString() - Method in class org.springframework.data.redis.connection.BitFieldSubCommands.Offset
- toString() - Method in class org.springframework.data.redis.connection.BitFieldSubCommands
- toString() - Method in class org.springframework.data.redis.connection.ClusterInfo
- toString() - Method in class org.springframework.data.redis.connection.DefaultMessage
- toString() - Method in class org.springframework.data.redis.connection.DefaultStringTuple
- toString() - Method in class org.springframework.data.redis.connection.ReactiveRedisConnection.CommandResponse
- toString() - Method in class org.springframework.data.redis.connection.ReactiveSubscription.ChannelMessage
- toString() - Method in class org.springframework.data.redis.connection.ReactiveSubscription.PatternMessage
- toString() - Method in class org.springframework.data.redis.connection.RedisClusterNode.SlotRange
- toString() - Method in class org.springframework.data.redis.connection.RedisClusterNode
- toString() - Method in class org.springframework.data.redis.connection.RedisGeoCommands.GeoLocation
- toString() - Method in class org.springframework.data.redis.connection.RedisNode
- toString() - Method in class org.springframework.data.redis.connection.RedisPassword
- toString() - Method in class org.springframework.data.redis.connection.stream.Consumer
- toString() - Method in class org.springframework.data.redis.connection.stream.PendingMessage
- toString() - Method in class org.springframework.data.redis.connection.stream.PendingMessages
- toString() - Method in class org.springframework.data.redis.connection.stream.PendingMessagesSummary
- toString() - Method in class org.springframework.data.redis.connection.stream.ReadOffset
- toString() - Method in class org.springframework.data.redis.connection.stream.RecordId
- toString() - Method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoConsumers
- toString() - Method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoGroups
- toString() - Method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoObject
- toString() - Method in class org.springframework.data.redis.connection.stream.StreamOffset
- toString() - Method in class org.springframework.data.redis.connection.stream.StreamReadOptions
- toString() - Method in class org.springframework.data.redis.connection.util.ByteArrayWrapper
- toString() - Method in class org.springframework.data.redis.connection.zset.DefaultTuple
- toString() - Method in class org.springframework.data.redis.core.convert.Bucket
- toString() - Method in class org.springframework.data.redis.core.convert.GeoIndexedPropertyValue
- toString() - Method in class org.springframework.data.redis.core.convert.RedisData
- toString() - Method in class org.springframework.data.redis.core.convert.RemoveIndexedData
- toString() - Method in class org.springframework.data.redis.core.convert.SimpleIndexedPropertyValue
- toString() - Method in class org.springframework.data.redis.core.Cursor.CursorId
- toString() - Method in class org.springframework.data.redis.core.DefaultTypedTuple
- toString() - Method in class org.springframework.data.redis.core.index.IndexDefinition.IndexingContext
- toString() - Method in class org.springframework.data.redis.core.RedisKeyExpiredEvent
- toString() - Method in class org.springframework.data.redis.core.types.RedisClientInfo
- toString() - Method in class org.springframework.data.redis.domain.geo.BoundingBox
- toString() - Method in class org.springframework.data.redis.domain.geo.GeoLocation
- toString() - Method in class org.springframework.data.redis.domain.geo.GeoReference.GeoCoordinateReference
- toString() - Method in class org.springframework.data.redis.domain.geo.GeoReference.GeoMemberReference
- toString() - Method in class org.springframework.data.redis.listener.ChannelTopic
- toString() - Method in class org.springframework.data.redis.repository.cdi.CdiBean
- toString() - Method in class org.springframework.data.redis.repository.query.RedisOperationChain.PathAndValue
- toString() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicDouble
- toString() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicInteger
- toString() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicLong
- toString() - Method in class org.springframework.data.redis.support.collections.AbstractRedisCollection
- toString() - Method in class org.springframework.data.redis.support.collections.DefaultRedisMap
- toString(byte[]) - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
- toTail(K) - Static method in class org.springframework.data.redis.core.ListOperations.MoveTo
- toTimeMillis(String, String) - Static method in class org.springframework.data.redis.connection.convert.Converters
-
Returns the timestamp constructed from the given
seconds
andmicroseconds
. - toTimeMillis(String, String, TimeUnit) - Static method in class org.springframework.data.redis.connection.convert.Converters
-
Returns the timestamp constructed from the given
seconds
andmicroseconds
. - toTuple(ScoredValue<byte[]>) - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
- touch(byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.keyCommands()
. - touch(byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- touch(byte[]...) - Method in interface org.springframework.data.redis.connection.RedisKeyCommands
-
Alter the last access time of given
key(s)
. - touch(String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- touch(String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Alter the last access time of given
key(s)
. - touch(Collection<ByteBuffer>) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
-
Alter the last access time of given
key(s)
. - touch(Publisher<Collection<ByteBuffer>>) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
-
Alter the last access time of given
key(s)
. - transactionAware() - Method in class org.springframework.data.redis.cache.RedisCacheManager.RedisCacheManagerBuilder
-
Enable
RedisCache
s to synchronize cache put/evict operations with ongoing Spring-managed transactions. - TransactionResultConverter<T> - Class in org.springframework.data.redis.connection.convert
-
Converts the results of transaction exec using a supplied Queue of
FutureResult
s. - TransactionResultConverter(Queue<FutureResult<T>>, Converter<Exception, DataAccessException>) - Constructor for class org.springframework.data.redis.connection.convert.TransactionResultConverter
- transactionResultUnwrapper() - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
- translate(Exception) - Method in interface org.springframework.data.redis.ExceptionTranslationStrategy
-
Potentially translate the given
Exception
intoDataAccessException
. - translate(Exception) - Method in class org.springframework.data.redis.FallbackExceptionTranslationStrategy
- translate(Exception) - Method in class org.springframework.data.redis.PassThroughExceptionTranslationStrategy
- translateExceptionIfPossible(RuntimeException) - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
- translateExceptionIfPossible(RuntimeException) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
- trim(int, int) - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- trim(int, int) - Method in interface org.springframework.data.redis.support.collections.RedisList
-
Trim list at the bound key to elements between
start
andend
. - trim(long) - Method in interface org.springframework.data.redis.core.BoundStreamOperations
-
Trims the stream to
count
elements. - trim(long, boolean) - Method in interface org.springframework.data.redis.core.BoundStreamOperations
-
Trims the stream to
count
elements. - trim(long, long) - Method in interface org.springframework.data.redis.core.BoundListOperations
-
Trim list at the bound key to elements between
start
andend
. - trim(long, long) - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- trim(long, long) - Method in interface org.springframework.data.redis.support.collections.RedisList
-
Trim list at the bound key to elements between
start
andend
. - trim(K, long) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
-
Trims the stream to
count
elements. - trim(K, long) - Method in interface org.springframework.data.redis.core.StreamOperations
-
Trims the stream to
count
elements. - trim(K, long, boolean) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
-
Trims the stream to
count
elements. - trim(K, long, boolean) - Method in interface org.springframework.data.redis.core.StreamOperations
-
Trims the stream to
count
elements. - trim(K, long, long) - Method in interface org.springframework.data.redis.core.ListOperations
-
Trim list at
key
to elements betweenstart
andend
. - trim(K, long, long) - Method in interface org.springframework.data.redis.core.ReactiveListOperations
-
Trim list at
key
to elements betweenstart
andend
. - ttl(byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.keyCommands()
. - ttl(byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- ttl(byte[]) - Method in interface org.springframework.data.redis.connection.RedisKeyCommands
-
Get the time to live for
key
in seconds. - ttl(byte[], TimeUnit) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.keyCommands()
. - ttl(byte[], TimeUnit) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- ttl(byte[], TimeUnit) - Method in interface org.springframework.data.redis.connection.RedisKeyCommands
-
Get the time to live for
key
in and convert it to the givenTimeUnit
. - ttl(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- ttl(String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get the time to live for
key
in seconds. - ttl(String, TimeUnit) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- ttl(String, TimeUnit) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get the time to live for
key
in and convert it to the givenTimeUnit
. - ttl(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
-
Get the time to live for
key
in seconds. - ttl(Publisher<ReactiveRedisConnection.KeyCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
-
Get one-by-one the time to live for keys.
- TTL - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- tuple(Tuple) - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZAddCommand
-
Creates a new
ReactiveZSetCommands.ZAddCommand
given aTuple
. - Tuple - Interface in org.springframework.data.redis.connection.zset
-
ZSet tuple.
- tuples(Collection<? extends Tuple>) - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZAddCommand
- type(byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.keyCommands()
. - type(byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- type(byte[]) - Method in interface org.springframework.data.redis.connection.RedisKeyCommands
-
Determine the type stored at
key
. - type(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- type(String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Determine the type stored at
key
. - type(String) - Method in class org.springframework.data.redis.core.ScanOptions.ScanOptionsBuilder
-
Returns the current
ScanOptions.ScanOptionsBuilder
configured with the giventype
. - type(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
-
Determine the type stored at key.
- type(K) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
-
Determine the type stored at
key
. - type(K) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
- type(K) - Method in interface org.springframework.data.redis.core.RedisOperations
-
Determine the type stored at
key
. - type(K) - Method in class org.springframework.data.redis.core.RedisTemplate
- type(Publisher<ReactiveRedisConnection.KeyCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
-
Determine the type stored at key.
- type(DataType) - Method in class org.springframework.data.redis.core.ScanOptions.ScanOptionsBuilder
-
Returns the current
ScanOptions.ScanOptionsBuilder
configured with the giventype
. - TYPE - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- typeHintPropertyName(String) - Method in class org.springframework.data.redis.serializer.GenericJackson2JsonRedisSerializer.GenericJackson2JsonRedisSerializerBuilder
-
Configure a property name to that represents the type hint.
U
- UINT_16 - Static variable in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldType
-
16 bit unsigned Integer
- UINT_32 - Static variable in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldType
-
32 bit unsigned Integer
- UINT_64 - Static variable in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldType
-
64 bit unsigned Integer
- UINT_8 - Static variable in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldType
-
8 bit unsigned Integer
- unbindConnection(RedisConnectionFactory) - Static method in class org.springframework.data.redis.core.RedisConnectionUtils
-
Unbinds and closes the connection (if any) associated with the given factory from closure-scope.
- unbounded() - Static method in class org.springframework.data.redis.connection.RedisStreamCommands.XPendingOptions
-
Create new
RedisStreamCommands.XPendingOptions
with an unboundedRange
(- +). - unbounded() - Static method in class org.springframework.data.redis.connection.RedisZSetCommands.Range
-
Deprecated.
- unbounded(Long) - Static method in class org.springframework.data.redis.connection.RedisStreamCommands.XPendingOptions
-
Create new
RedisStreamCommands.XPendingOptions
with an unboundedRange
(- +). - union(Collection<? extends RedisSet<?>>) - Method in class org.springframework.data.redis.support.collections.DefaultRedisSet
- union(Collection<? extends RedisSet<?>>) - Method in interface org.springframework.data.redis.support.collections.RedisSet
-
Union this set and other
RedisSet
s. - union(Collection<? extends RedisZSet<?>>) - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
- union(Collection<? extends RedisZSet<?>>) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
-
Union this set and other
RedisZSet
s. - union(Collection<K>) - Method in interface org.springframework.data.redis.core.BoundSetOperations
-
Union all sets at given
keys
andkeys
. - union(Collection<K>) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Union sorted
sets
. - union(Collection<K>) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
-
Union all sets at given
keys
. - union(Collection<K>) - Method in interface org.springframework.data.redis.core.SetOperations
-
Union all sets at given
keys
. - union(K) - Method in interface org.springframework.data.redis.core.BoundSetOperations
-
Union all sets at given
key
andkey
. - union(K) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Union sorted
sets
. - union(K, Collection<K>) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
-
Union all sets at given
keys
andotherKeys
. - union(K, Collection<K>) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Union sorted
sets
. - union(K, Collection<K>) - Method in interface org.springframework.data.redis.core.SetOperations
-
Union all sets at given
keys
andotherKeys
. - union(K, Collection<K>) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Union sorted
sets
. - union(K, K) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
-
Union all sets at given
keys
andotherKey
. - union(K, K) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Union sorted
sets
. - union(K, K) - Method in interface org.springframework.data.redis.core.SetOperations
-
Union all sets at given
keys
andotherKey
. - union(K, K) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Union sorted
sets
. - union(K, K...) - Method in interface org.springframework.data.redis.core.HyperLogLogOperations
-
Merges all values of given sourceKeys into destination key.
- union(K, K...) - Method in interface org.springframework.data.redis.core.ReactiveHyperLogLogOperations
-
Merges all values of given sourceKeys into destination key.
- union(RedisSet<?>) - Method in class org.springframework.data.redis.support.collections.DefaultRedisSet
- union(RedisSet<?>) - Method in interface org.springframework.data.redis.support.collections.RedisSet
-
Union this set and another
RedisSet
. - union(RedisZSet<?>) - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
- union(RedisZSet<?>) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
-
Union this set and another
RedisZSet
. - unionAndStore(Collection<? extends RedisSet<?>>, String) - Method in class org.springframework.data.redis.support.collections.DefaultRedisSet
- unionAndStore(Collection<? extends RedisSet<?>>, String) - Method in interface org.springframework.data.redis.support.collections.RedisSet
- unionAndStore(Collection<? extends RedisZSet<?>>, String) - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
- unionAndStore(Collection<? extends RedisZSet<?>>, String) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
- unionAndStore(Collection<K>, K) - Method in interface org.springframework.data.redis.core.BoundSetOperations
-
Union all sets at given the bound key and
keys
and store result indestKey
. - unionAndStore(Collection<K>, K) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Union sorted sets at the bound key and
otherKeys
and store result in destinationdestKey
. - unionAndStore(Collection<K>, K) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
-
Union all sets at given
keys
and store result indestKey
. - unionAndStore(Collection<K>, K) - Method in interface org.springframework.data.redis.core.SetOperations
-
Union all sets at given
keys
and store result indestKey
. - unionAndStore(Collection<K>, K, Aggregate) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Union sorted sets at the bound key and
otherKeys
and store result in destinationdestKey
. - unionAndStore(Collection<K>, K, Aggregate, Weights) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Union sorted sets at the bound key and
otherKeys
and store result in destinationdestKey
. - unionAndStore(K, Collection<K>, K) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
-
Union all sets at given
key
andotherKeys
and store result indestKey
. - unionAndStore(K, Collection<K>, K) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Union sorted sets at
key
andotherKeys
and store result in destinationdestKey
. - unionAndStore(K, Collection<K>, K) - Method in interface org.springframework.data.redis.core.SetOperations
-
Union all sets at given
key
andotherKeys
and store result indestKey
. - unionAndStore(K, Collection<K>, K) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Union sorted sets at
key
andotherKeys
and store result in destinationdestKey
. - unionAndStore(K, Collection<K>, K, Aggregate) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Union sorted sets at
key
andotherKeys
and store result in destinationdestKey
. - unionAndStore(K, Collection<K>, K, Aggregate) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Union sorted sets at
key
andotherKeys
and store result in destinationdestKey
. - unionAndStore(K, Collection<K>, K, Aggregate, Weights) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Union sorted sets at
key
andotherKeys
and store result in destinationdestKey
. - unionAndStore(K, Collection<K>, K, Aggregate, Weights) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Union sorted sets at
key
andotherKeys
and store result in destinationdestKey
. - unionAndStore(K, K) - Method in interface org.springframework.data.redis.core.BoundSetOperations
-
Union all sets at given the bound key and
key
and store result indestKey
. - unionAndStore(K, K) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Union sorted sets at the bound key and
otherKeys
and store result in destinationdestKey
. - unionAndStore(K, K, K) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
-
Union all sets at given
key
andotherKey
and store result indestKey
. - unionAndStore(K, K, K) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Union sorted sets at
key
andotherKeys
and store result in destinationdestKey
. - unionAndStore(K, K, K) - Method in interface org.springframework.data.redis.core.SetOperations
-
Union all sets at given
key
andotherKey
and store result indestKey
. - unionAndStore(K, K, K) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Union sorted sets at
key
andotherKeys
and store result in destinationdestKey
. - unionAndStore(RedisSet<?>, String) - Method in class org.springframework.data.redis.support.collections.DefaultRedisSet
- unionAndStore(RedisSet<?>, String) - Method in interface org.springframework.data.redis.support.collections.RedisSet
- unionAndStore(RedisZSet<?>, String) - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
- unionAndStore(RedisZSet<?>, String) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
- unionWithScores(Collection<? extends RedisZSet<?>>) - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
- unionWithScores(Collection<? extends RedisZSet<?>>) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
-
Union this set and other
RedisZSet
s. - unionWithScores(Collection<K>) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Union sorted
sets
. - unionWithScores(Collection<K>, Aggregate) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Union sorted sets at the bound key and
otherKeys
. - unionWithScores(Collection<K>, Aggregate, Weights) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Union sorted
sets
. - unionWithScores(K) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Union sorted
sets
. - unionWithScores(K, Collection<K>) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Union sorted
sets
. - unionWithScores(K, Collection<K>) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Union sorted
sets
. - unionWithScores(K, Collection<K>, Aggregate) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Union sorted sets at
key
andotherKeys
. - unionWithScores(K, Collection<K>, Aggregate) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Union sorted sets at
key
andotherKeys
. - unionWithScores(K, Collection<K>, Aggregate, Weights) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Union sorted
sets
. - unionWithScores(K, Collection<K>, Aggregate, Weights) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Union sorted
sets
. - unionWithScores(K, K) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
-
Union sorted
sets
. - unionWithScores(K, K) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Union sorted
sets
. - unionWithScores(RedisZSet<?>) - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
- unionWithScores(RedisZSet<?>) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
-
Union this set and another
RedisZSet
. - unit() - Element in annotation interface org.springframework.data.redis.core.TimeToLive
-
TimeUnit
unit to use. - unixTimestamp(long, TimeUnit) - Static method in class org.springframework.data.redis.core.types.Expiration
-
Creates a new
Expiration
with the given unix timestamp andTimeUnit
. - UNKNOWN - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- unlimited() - Static method in class org.springframework.data.redis.connection.Limit
- unlink(byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.keyCommands()
. - unlink(byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- unlink(byte[]...) - Method in interface org.springframework.data.redis.connection.RedisKeyCommands
-
Unlink the
keys
from the keyspace. - unlink(String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- unlink(String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Unlink the
keys
from the keyspace. - unlink(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
-
Unlink the
key
from the keyspace. - unlink(Collection<K>) - Method in interface org.springframework.data.redis.core.RedisOperations
-
Unlink the
keys
from the keyspace. - unlink(Collection<K>) - Method in class org.springframework.data.redis.core.RedisTemplate
- unlink(K) - Method in interface org.springframework.data.redis.core.RedisOperations
-
Unlink the
key
from the keyspace. - unlink(K) - Method in class org.springframework.data.redis.core.RedisTemplate
- unlink(K...) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
-
Unlink the
key
from the keyspace. - unlink(K...) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
- unlink(Publisher<K>) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
-
Unlink the
keys
from the keyspace. - unlink(Publisher<K>) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
- unlink(Publisher<ReactiveRedisConnection.KeyCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
-
Unlink the
key
from the keyspace. - unsigned(int) - Static method in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldType
-
Create new unsigned
BitFieldSubCommands.BitFieldType
. - unsubscribe() - Method in interface org.springframework.data.redis.connection.ReactiveSubscription
-
Cancels the current subscription for all
channels
. - unsubscribe() - Method in interface org.springframework.data.redis.connection.Subscription
-
Cancels the current subscription for all channels given by name.
- unsubscribe() - Method in class org.springframework.data.redis.connection.util.AbstractSubscription
- unsubscribe(byte[]...) - Method in interface org.springframework.data.redis.connection.Subscription
-
Cancels the current subscription for all given channels.
- unsubscribe(byte[]...) - Method in class org.springframework.data.redis.connection.util.AbstractSubscription
- unsubscribe(ByteBuffer...) - Method in interface org.springframework.data.redis.connection.ReactiveSubscription
-
Cancels the current subscription for all given channels.
- UNSUBSCRIBE - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- unwatch() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- unwatch() - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
- unwatch() - Method in class org.springframework.data.redis.connection.jedis.JedisConnection
- unwatch() - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
- unwatch() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
- unwatch() - Method in interface org.springframework.data.redis.connection.RedisTxCommands
-
Flushes all the previously
RedisTxCommands.watch(byte[]...)
keys. - unwatch() - Method in interface org.springframework.data.redis.core.RedisOperations
-
Flushes all the previously
RedisOperations.watch(Object)
keys. - unwatch() - Method in class org.springframework.data.redis.core.RedisTemplate
- UNWATCH - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- update(Object, T) - Method in class org.springframework.data.redis.core.RedisKeyValueTemplate
- update(PartialUpdate<?>) - Method in class org.springframework.data.redis.core.RedisKeyValueAdapter
- update(T) - Method in class org.springframework.data.redis.core.RedisKeyValueTemplate
- updateAndGet(DoubleUnaryOperator) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicDouble
-
Atomically update the current value using the given
update function
. - updateAndGet(IntUnaryOperator) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicInteger
-
Atomically update the current value using the given
update function
. - updateAndGet(LongUnaryOperator) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicLong
-
Atomically update the current value using the given
update function
. - upsert() - Static method in enum class org.springframework.data.redis.connection.RedisStringCommands.SetOption
-
Do not set any additional command argument.
- UPSERT - Enum constant in enum class org.springframework.data.redis.connection.RedisStringCommands.SetOption
-
Do not set any additional command argument.
- US_ASCII - Static variable in class org.springframework.data.redis.serializer.StringRedisSerializer
-
StringRedisSerializer
to use 7 bit ASCII, a.k.a. - USE_TIME_TO_IDLE_EXPIRATION - Static variable in class org.springframework.data.redis.cache.RedisCacheConfiguration
- usePooling() - Method in class org.springframework.data.redis.connection.jedis.JedisClientConfiguration.DefaultJedisClientConfigurationBuilder
- usePooling() - Method in interface org.springframework.data.redis.connection.jedis.JedisClientConfiguration.JedisClientConfigurationBuilder
-
Enable connection-pooling.
- usePrefix() - Method in class org.springframework.data.redis.cache.RedisCacheConfiguration
- useSsl() - Method in class org.springframework.data.redis.connection.jedis.JedisClientConfiguration.DefaultJedisClientConfigurationBuilder
- useSsl() - Method in interface org.springframework.data.redis.connection.jedis.JedisClientConfiguration.JedisClientConfigurationBuilder
-
Enable SSL connections.
- useSsl() - Method in class org.springframework.data.redis.connection.lettuce.LettuceClientConfiguration.LettuceClientConfigurationBuilder
-
Enable SSL connections.
- useSsl() - Method in class org.springframework.data.redis.connection.lettuce.LettucePoolingClientConfiguration.LettucePoolingClientConfigurationBuilder
- UTF_8 - Static variable in class org.springframework.data.redis.serializer.StringRedisSerializer
-
StringRedisSerializer
to use 8 bit UCS Transformation Format.
V
- VACANT - Enum constant in enum class org.springframework.data.redis.connection.ValueEncoding.RedisValueEncoding
-
No encoding present due to non existing key.
- validateArgumentCount(int) - Method in enum class org.springframework.data.redis.core.RedisCommand
-
Validates given
argument count
against expected ones. - validateConnection() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
-
Validate the shared connections and reinitialize if invalid.
- value() - Element in annotation interface org.springframework.data.redis.core.RedisHash
-
The prefix to distinguish between domain types.
- value() - Element in annotation interface org.springframework.data.redis.repository.configuration.EnableRedisRepositories
-
Alias for the
EnableRedisRepositories.basePackages()
attribute. - value(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveHashCommands.HSetCommand
-
Creates a new
ReactiveHashCommands.HSetCommand
given akey
. - value(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveHyperLogLogCommands.PfAddCommand
-
Creates a new
ReactiveHyperLogLogCommands.PfAddCommand
given avalue
. - value(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveListCommands.LInsertCommand
-
Creates a new
ReactiveListCommands.LInsertCommand
given avalue
. - value(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveListCommands.PushCommand
-
Applies the value.
- value(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveSetCommands.SAddCommand
-
Creates a new
ReactiveSetCommands.SAddCommand
given a value. - value(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveSetCommands.SIsMemberCommand
-
Creates a new
ReactiveSetCommands.SIsMemberCommand
given a value. - value(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveSetCommands.SMoveCommand
-
Creates a new
ReactiveSetCommands.SMoveCommand
given a value. - value(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveSetCommands.SRemCommand
-
Creates a new
ReactiveSetCommands.SRemCommand
given a value. - value(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveStringCommands.SetCommand
-
Applies the value.
- value(RedisElementReader<V>, RedisElementWriter<V>) - Method in interface org.springframework.data.redis.serializer.RedisSerializationContext.RedisSerializationContextBuilder
-
Set the value
RedisElementReader
andRedisElementWriter
. - value(RedisSerializationContext.SerializationPair<V>) - Method in interface org.springframework.data.redis.serializer.RedisSerializationContext.RedisSerializationContextBuilder
-
Set the value
RedisSerializationContext.SerializationPair
. - value(RedisSerializer<V>) - Method in interface org.springframework.data.redis.serializer.RedisSerializationContext.RedisSerializationContextBuilder
-
Set the value
RedisSerializationContext.SerializationPair
given aRedisSerializer
. - VALUE - Enum constant in enum class org.springframework.data.redis.connection.ReturnType
-
Returned as byte[]
- valueAt(long) - Method in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldGetBuilder
-
Set the zero based bit offset.
- valueAt(long) - Method in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldIncrByBuilder
-
Set the zero based bit offset.
- valueAt(long) - Method in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldSetBuilder
-
Set the zero based bit offset.
- valueAt(BitFieldSubCommands.Offset) - Method in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldGetBuilder
-
Set the bit offset.
- valueAt(BitFieldSubCommands.Offset) - Method in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldIncrByBuilder
-
Set the bit offset.
- valueAt(BitFieldSubCommands.Offset) - Method in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldSetBuilder
-
Set the bit offset.
- valueCount(long) - Static method in class org.springframework.data.redis.connection.ReactiveSetCommands.SRandMembersCommand
-
Creates a new
ReactiveSetCommands.SRandMembersCommand
given the number of values to retrieve. - valueCount(long) - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRandMemberCommand
-
Creates a new
ReactiveZSetCommands.ZRandMemberCommand
given the number of values to retrieve. - ValueEncoding - Interface in org.springframework.data.redis.connection
-
ValueEncoding
is used for the Redis internal data representation used in order to store the value associated with a key. - ValueEncoding.RedisValueEncoding - Enum Class in org.springframework.data.redis.connection
-
Default
ValueEncoding
implementation of encodings used in Redis. - valueIn(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveHyperLogLogCommands.PfCountCommand
-
Creates a new
ReactiveHyperLogLogCommands.PfCountCommand
given akey
. - valueOf(String) - Static method in enum class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldIncrBy.Overflow
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.springframework.data.redis.connection.ClusterInfo.Info
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.springframework.data.redis.connection.convert.MapToPropertiesConverter
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.springframework.data.redis.connection.DataType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.springframework.data.redis.connection.lettuce.observability.RedisObservation
-
Deprecated.Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.springframework.data.redis.connection.lettuce.RedisCredentialsProviderFactory.AbsentRedisCredentials
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.springframework.data.redis.connection.ReactiveClusterCommands.AddSlots
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.springframework.data.redis.connection.ReactiveListCommands.Direction
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.springframework.data.redis.connection.ReactiveStreamCommands.GroupCommand.GroupCommandAction
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.springframework.data.redis.connection.ReactiveZSetCommands.PopDirection
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRangeStoreCommand.RangeMode
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.springframework.data.redis.connection.RedisClusterCommands.AddSlots
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.springframework.data.redis.connection.RedisClusterNode.Flag
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.springframework.data.redis.connection.RedisClusterNode.LinkState
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.springframework.data.redis.connection.RedisGeoCommands.DistanceUnit
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.springframework.data.redis.connection.RedisGeoCommands.GeoRadiusCommandArgs.Flag
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.springframework.data.redis.connection.RedisListCommands.Direction
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.springframework.data.redis.connection.RedisListCommands.Position
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.springframework.data.redis.connection.RedisNode.NodeType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.springframework.data.redis.connection.RedisServer.INFO
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.springframework.data.redis.connection.RedisServerCommands.FlushOption
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.springframework.data.redis.connection.RedisServerCommands.MigrateOption
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.springframework.data.redis.connection.RedisServerCommands.ShutdownOption
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.springframework.data.redis.connection.RedisStringCommands.BitOperation
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.springframework.data.redis.connection.RedisStringCommands.SetOption
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.springframework.data.redis.connection.RedisZSetCommands.ZAddArgs.Flag
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.springframework.data.redis.connection.ReturnType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.springframework.data.redis.connection.SortParameters.Order
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.springframework.data.redis.connection.ValueEncoding.RedisValueEncoding
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.springframework.data.redis.connection.zset.Aggregate
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.springframework.data.redis.core.index.RedisIndexDefinition.LowercaseIndexValueTransformer
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.springframework.data.redis.core.index.RedisIndexDefinition.NoOpValueTransformer
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.springframework.data.redis.core.PartialUpdate.UpdateCommand
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.springframework.data.redis.core.RedisCommand
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.springframework.data.redis.core.RedisKeyValueAdapter.EnableKeyspaceEvents
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.springframework.data.redis.core.RedisKeyValueAdapter.ShadowCopy
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.springframework.data.redis.core.types.RedisClientInfo.INFO
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.springframework.data.redis.domain.geo.Metrics
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.springframework.data.redis.stream.Task.State
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.springframework.data.redis.support.collections.RedisCollectionFactoryBean.CollectionType
-
Returns the enum constant of this class with the specified name.
- ValueOperations<K,
V> - Interface in org.springframework.data.redis.core -
Redis operations for simple (or in Redis terminology 'string') values.
- values() - Static method in enum class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldIncrBy.Overflow
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.springframework.data.redis.connection.ClusterInfo.Info
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.springframework.data.redis.connection.convert.MapToPropertiesConverter
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.springframework.data.redis.connection.DataType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.springframework.data.redis.connection.lettuce.observability.RedisObservation
-
Deprecated.Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.springframework.data.redis.connection.lettuce.RedisCredentialsProviderFactory.AbsentRedisCredentials
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.springframework.data.redis.connection.ReactiveClusterCommands.AddSlots
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.springframework.data.redis.connection.ReactiveListCommands.Direction
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.springframework.data.redis.connection.ReactiveStreamCommands.GroupCommand.GroupCommandAction
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.springframework.data.redis.connection.ReactiveZSetCommands.PopDirection
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRangeStoreCommand.RangeMode
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.springframework.data.redis.connection.RedisClusterCommands.AddSlots
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.springframework.data.redis.connection.RedisClusterNode.Flag
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.springframework.data.redis.connection.RedisClusterNode.LinkState
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.springframework.data.redis.connection.RedisGeoCommands.DistanceUnit
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.springframework.data.redis.connection.RedisGeoCommands.GeoRadiusCommandArgs.Flag
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.springframework.data.redis.connection.RedisListCommands.Direction
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.springframework.data.redis.connection.RedisListCommands.Position
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.springframework.data.redis.connection.RedisNode.NodeType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.springframework.data.redis.connection.RedisServer.INFO
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.springframework.data.redis.connection.RedisServerCommands.FlushOption
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.springframework.data.redis.connection.RedisServerCommands.MigrateOption
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.springframework.data.redis.connection.RedisServerCommands.ShutdownOption
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.springframework.data.redis.connection.RedisStringCommands.BitOperation
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.springframework.data.redis.connection.RedisStringCommands.SetOption
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.springframework.data.redis.connection.RedisZSetCommands.ZAddArgs.Flag
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.springframework.data.redis.connection.ReturnType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.springframework.data.redis.connection.SortParameters.Order
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.springframework.data.redis.connection.ValueEncoding.RedisValueEncoding
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.springframework.data.redis.connection.zset.Aggregate
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Method in interface org.springframework.data.redis.core.BoundHashOperations
-
Get entry set (values) of hash at the bound key.
- values() - Method in class org.springframework.data.redis.core.convert.Bucket
- values() - Static method in enum class org.springframework.data.redis.core.index.RedisIndexDefinition.LowercaseIndexValueTransformer
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.springframework.data.redis.core.index.RedisIndexDefinition.NoOpValueTransformer
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.springframework.data.redis.core.PartialUpdate.UpdateCommand
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.springframework.data.redis.core.RedisCommand
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.springframework.data.redis.core.RedisKeyValueAdapter.EnableKeyspaceEvents
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.springframework.data.redis.core.RedisKeyValueAdapter.ShadowCopy
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.springframework.data.redis.core.types.RedisClientInfo.INFO
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.springframework.data.redis.domain.geo.Metrics
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Method in class org.springframework.data.redis.repository.query.RedisOperationChain.PathAndValue
- values() - Static method in enum class org.springframework.data.redis.stream.Task.State
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Method in class org.springframework.data.redis.support.collections.DefaultRedisMap
- values() - Static method in enum class org.springframework.data.redis.support.collections.RedisCollectionFactoryBean.CollectionType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Method in class org.springframework.data.redis.support.collections.RedisProperties
- values(H) - Method in interface org.springframework.data.redis.core.HashOperations
-
Get entry set (values) of hash at
key
. - values(H) - Method in interface org.springframework.data.redis.core.ReactiveHashOperations
-
Get entry set (values) of hash at
key
. - values(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRemCommand
-
Creates a new
ReactiveZSetCommands.ZRemCommand
given aTuple
. - values(Collection<ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveHyperLogLogCommands.PfAddCommand
- values(Collection<ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveSetCommands.SAddCommand
-
Creates a new
ReactiveSetCommands.SAddCommand
given aCollection
of values. - values(Collection<ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveSetCommands.SRemCommand
-
Creates a new
ReactiveSetCommands.SRemCommand
given aCollection
of values. - values(Collection<ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRemCommand
- values(List<ByteBuffer>) - Method in class org.springframework.data.redis.connection.ReactiveListCommands.PushCommand
-
Applies a
List
of values. - values(List<ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveSetCommands.SMIsMemberCommand
-
Creates a new
ReactiveSetCommands.SMIsMemberCommand
given one or more values. - valuesIn(Collection<ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveHyperLogLogCommands.PfCountCommand
-
Creates a new
ReactiveHyperLogLogCommands.PfCountCommand
given aCollection
of keys. - valuesIn(Collection<ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveHyperLogLogCommands.PfMergeCommand
-
Creates a new
ReactiveHyperLogLogCommands.PfMergeCommand
given aCollection
of sourceKeys. - valuesWithin(Range<Long>) - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRangeCommand
-
Creates a new
ReactiveZSetCommands.ZRangeCommand
given aRange
to obtain elements ordered from the lowest to the highest score. - valuesWithin(Range<Long>) - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRemRangeByRankCommand
-
Creates a new
ReactiveZSetCommands.ZRemRangeByRankCommand
given aRange
. - valueTransformer() - Method in interface org.springframework.data.redis.core.index.IndexDefinition
- valueTransformer() - Method in class org.springframework.data.redis.core.index.RedisIndexDefinition
- valueWithin(Range<String>) - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRangeStoreCommand
-
Creates a new
ReactiveZSetCommands.ZRangeStoreCommand
given aRange
to obtain elements ordered from the lowest to the highest lexicographical value. - verifyPeer(SslVerifyMode) - Method in class org.springframework.data.redis.connection.lettuce.LettuceClientConfiguration.LettuceSslClientConfigurationBuilder
-
Configure peer verification.
W
- watch(byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- watch(byte[]...) - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
- watch(byte[]...) - Method in class org.springframework.data.redis.connection.jedis.JedisConnection
- watch(byte[]...) - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
- watch(byte[]...) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
- watch(byte[]...) - Method in interface org.springframework.data.redis.connection.RedisTxCommands
-
Watch given
keys
for modifications during transaction started withRedisTxCommands.multi()
. - watch(Collection<K>) - Method in interface org.springframework.data.redis.core.RedisOperations
-
Watch given
keys
for modifications during transaction started withRedisOperations.multi()
. - watch(Collection<K>) - Method in class org.springframework.data.redis.core.RedisTemplate
- watch(K) - Method in interface org.springframework.data.redis.core.RedisOperations
-
Watch given
key
for modifications during transaction started withRedisOperations.multi()
. - watch(K) - Method in class org.springframework.data.redis.core.RedisTemplate
- WATCH - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- Weights - Class in org.springframework.data.redis.connection.zset
-
Value object encapsulating a multiplication factor for each input sorted set.
- with(RedisGeoCommands.GeoSearchCommandArgs) - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoSearchCommand
-
Sets the command args.
- with(RedisGeoCommands.GeoSearchStoreCommandArgs) - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoSearchStoreCommand
-
Sets the command args.
- withArgs(RedisGeoCommands.GeoRadiusCommandArgs) - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusByMemberCommand
-
Applies command
RedisGeoCommands.GeoRadiusCommandArgs
. - withArgs(RedisGeoCommands.GeoRadiusCommandArgs) - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusCommand
-
Applies command
RedisGeoCommands.GeoRadiusCommandArgs
. - withCacheConfiguration(String, RedisCacheConfiguration) - Method in class org.springframework.data.redis.cache.RedisCacheManager.RedisCacheManagerBuilder
-
Registers the given
cache name
andRedisCacheConfiguration
used to create and configure aRedisCache
on startup. - withConversionService(ConversionService) - Method in class org.springframework.data.redis.cache.RedisCacheConfiguration
-
Define the
ConversionService
used for cache key toString
conversion. - withCoord() - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusByMemberCommand
-
Enables coordinate retrieval.
- withCoord() - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusCommand
-
Enables coordinate retrieval.
- WITHCOORD - Enum constant in enum class org.springframework.data.redis.connection.RedisGeoCommands.GeoRadiusCommandArgs.Flag
- withCord() - Static method in interface org.springframework.data.redis.connection.RedisGeoCommands.GeoCommandArgs.GeoCommandFlag
- withDist() - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusByMemberCommand
-
Enables distance retrieval.
- withDist() - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusCommand
-
Enables distance retrieval.
- withDist() - Static method in interface org.springframework.data.redis.connection.RedisGeoCommands.GeoCommandArgs.GeoCommandFlag
- WITHDIST - Enum constant in enum class org.springframework.data.redis.connection.RedisGeoCommands.GeoRadiusCommandArgs.Flag
- withExpiration(Expiration) - Method in class org.springframework.data.redis.connection.ReactiveStringCommands.GetExCommand
-
Applies
Expiration
. - withFlag(RedisGeoCommands.GeoRadiusCommandArgs.Flag) - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusByMemberCommand
-
Applies command
flags
. - withFlag(RedisGeoCommands.GeoRadiusCommandArgs.Flag) - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusCommand
-
Applies command
flags
. - withFlags(Set<RedisClusterNode.Flag>) - Method in class org.springframework.data.redis.connection.RedisClusterNode.RedisClusterNodeBuilder
-
Set flags for node.
- withId(String) - Method in class org.springframework.data.redis.connection.RedisClusterNode.RedisClusterNodeBuilder
- withId(String) - Method in class org.springframework.data.redis.connection.RedisNode.RedisNodeBuilder
-
Set id of server.
- withId(String) - Method in class org.springframework.data.redis.connection.stream.StreamRecords.RecordBuilder
-
Configure a record Id given a
String
. - withId(RecordId) - Method in interface org.springframework.data.redis.connection.stream.ByteBufferRecord
- withId(RecordId) - Method in interface org.springframework.data.redis.connection.stream.ByteRecord
- withId(RecordId) - Method in interface org.springframework.data.redis.connection.stream.MapRecord
- withId(RecordId) - Method in interface org.springframework.data.redis.connection.stream.ObjectRecord
- withId(RecordId) - Method in interface org.springframework.data.redis.connection.stream.Record
- withId(RecordId) - Method in class org.springframework.data.redis.connection.stream.StreamRecords.RecordBuilder
-
Configure a
RecordId
. - withId(RecordId) - Method in interface org.springframework.data.redis.connection.stream.StringRecord
- within(Range<Long>) - Method in class org.springframework.data.redis.connection.ReactiveRedisConnection.RangeCommand
-
Applies a
Range
. - within(Range<Long>) - Method in class org.springframework.data.redis.connection.ReactiveStringCommands.BitCountCommand
-
Applies the
Range
. - within(Range<Long>) - Method in class org.springframework.data.redis.connection.ReactiveStringCommands.BitPosCommand
- within(Range<String>) - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.RangeCommand
-
Applies a
Range
. - within(Circle) - Static method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusCommand
-
Creates a new
ReactiveGeoCommands.GeoRadiusCommand
given aCircle
. - within(Distance) - Static method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusByMemberCommand
-
Creates a new
ReactiveGeoCommands.GeoRadiusByMemberCommand
given aDistance
. - within(Distance) - Static method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusCommand
-
Creates a new
ReactiveGeoCommands.GeoRadiusCommand
given aDistance
. - within(GeoShape) - Static method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoSearchCommand
-
Creates a new
ReactiveGeoCommands.GeoSearchCommand
given aGeoShape
. - within(GeoShape) - Static method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoSearchStoreCommand
-
Creates a new
ReactiveGeoCommands.GeoSearchStoreCommand
given aGeoShape
. - withinFeet(double) - Static method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusByMemberCommand
-
Creates a new
ReactiveGeoCommands.GeoRadiusByMemberCommand
given a distance inRedisGeoCommands.DistanceUnit.FEET
. - withinFeet(double) - Static method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusCommand
-
Creates a new
ReactiveGeoCommands.GeoRadiusCommand
given a distance inRedisGeoCommands.DistanceUnit.FEET
. - withInitialCacheConfigurations(Map<String, RedisCacheConfiguration>) - Method in class org.springframework.data.redis.cache.RedisCacheManager.RedisCacheManagerBuilder
-
Append a
Map
of cache name/RedisCacheConfiguration
pairs to be pre initialized. - withinKilometers(double) - Static method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusCommand
-
Creates a new
ReactiveGeoCommands.GeoRadiusCommand
given a distance inRedisGeoCommands.DistanceUnit.KILOMETERS
. - withinKiometers(double) - Static method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusByMemberCommand
-
Creates a new
ReactiveGeoCommands.GeoRadiusByMemberCommand
given a distance inRedisGeoCommands.DistanceUnit.KILOMETERS
. - withinMeters(double) - Static method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusByMemberCommand
-
Creates a new
ReactiveGeoCommands.GeoRadiusByMemberCommand
given a distance inRedisGeoCommands.DistanceUnit.METERS
. - withinMeters(double) - Static method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusCommand
-
Creates a new
ReactiveGeoCommands.GeoRadiusCommand
given a distance inRedisGeoCommands.DistanceUnit.METERS
. - withinMiles(double) - Static method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusByMemberCommand
-
Creates a new
ReactiveGeoCommands.GeoRadiusByMemberCommand
given a distance inRedisGeoCommands.DistanceUnit.MILES
. - withinMiles(double) - Static method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusCommand
-
Creates a new
ReactiveGeoCommands.GeoRadiusCommand
given a distance inRedisGeoCommands.DistanceUnit.MILES
. - withinRange(Range<?>) - Method in class org.springframework.data.redis.connection.stream.PendingMessages
-
Adds the range to the current
PendingMessages
. - withName(String) - Method in class org.springframework.data.redis.connection.RedisClusterNode.RedisClusterNodeBuilder
- withName(String) - Method in class org.springframework.data.redis.connection.RedisNode.RedisNodeBuilder
-
Define node name.
- withOptions(StreamReadOptions) - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.ReadCommand
-
Applies the given
StreamReadOptions
. - withOptions(ScanOptions) - Method in class org.springframework.data.redis.connection.ReactiveRedisConnection.KeyScanCommand
-
Applies
ScanOptions
. - withScores() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRangeByScoreCommand
-
Return the score along with each returned element.
- withScores() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRangeCommand
-
Return the score along with each returned element.
- withSetOption(RedisStringCommands.SetOption) - Method in class org.springframework.data.redis.connection.ReactiveStringCommands.SetCommand
-
Applies
RedisStringCommands.SetOption
. - withStatisticsCollector(CacheStatisticsCollector) - Method in interface org.springframework.data.redis.cache.RedisCacheWriter
-
Obtain a
RedisCacheWriter
using the givenCacheStatisticsCollector
to collect metrics. - withStreamKey(byte[]) - Method in interface org.springframework.data.redis.connection.stream.ByteRecord
-
Create a new
ByteRecord
with the associated stream key. - withStreamKey(String) - Method in interface org.springframework.data.redis.connection.stream.StringRecord
-
Create a new
StringRecord
with the associated stream key. - withStreamKey(ByteBuffer) - Method in interface org.springframework.data.redis.connection.stream.ByteBufferRecord
-
Create a new
ByteBufferRecord
with the associated stream key. - withStreamKey(SK) - Method in interface org.springframework.data.redis.connection.stream.MapRecord
- withStreamKey(SK) - Method in interface org.springframework.data.redis.connection.stream.ObjectRecord
- withStreamKey(SK) - Method in interface org.springframework.data.redis.connection.stream.Record
-
Create a new instance of
Record
with the given key to store the record at. - withValue(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveStringCommands.SetRangeCommand
-
Applies the value.
- WRAP - Enum constant in enum class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldIncrBy.Overflow
- write(ObjectMapper, Object) - Method in interface org.springframework.data.redis.serializer.JacksonObjectWriter
-
Write the object graph with the given root
source
as byte array. - write(Object, RedisData) - Method in class org.springframework.data.redis.core.convert.MappingRedisConverter
- write(T) - Method in interface org.springframework.data.redis.serializer.RedisElementWriter
-
Serialize a
element
to itsByteBuffer
representation. - write(T) - Method in interface org.springframework.data.redis.serializer.RedisSerializationContext.SerializationPair
-
Serialize the given
element
to itsByteBuffer
representation. - writePartialUpdate(PartialUpdate<?>, RedisData) - Method in class org.springframework.data.redis.core.convert.MappingRedisConverter
- writer(JacksonObjectWriter) - Method in class org.springframework.data.redis.serializer.GenericJackson2JsonRedisSerializer.GenericJackson2JsonRedisSerializerBuilder
-
Configure
JacksonObjectWriter
.
X
- xAck(byte[], String, String...) - Method in interface org.springframework.data.redis.connection.RedisStreamCommands
-
Acknowledge one or more records, identified via their id, as processed.
- xAck(byte[], String, RecordId...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.streamCommands()
}. - xAck(byte[], String, RecordId...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- xAck(byte[], String, RecordId...) - Method in interface org.springframework.data.redis.connection.RedisStreamCommands
-
Acknowledge one or more records, identified via their id, as processed.
- xAck(String, String, String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Acknowledge one or more record as processed.
- xAck(String, String, RecordId...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- xAck(String, String, RecordId...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
- xAck(ByteBuffer, String, String...) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
-
Acknowledge one or more records as processed.
- xAck(ByteBuffer, String, RecordId...) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
-
Acknowledge one or more records as processed.
- xAck(Publisher<ReactiveStreamCommands.AcknowledgeCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
-
Acknowledge one or more records as processed.
- xAdd(byte[], Map<byte[], byte[]>) - Method in interface org.springframework.data.redis.connection.RedisStreamCommands
-
Append a new record with the given
field/value pairs
as content to the stream stored atkey
. - xAdd(String, Map<String, String>) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Append a record to the stream
key
. - xAdd(ByteBuffer, Map<ByteBuffer, ByteBuffer>) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
-
Add stream record with given body to key.
- xAdd(Publisher<ReactiveStreamCommands.AddStreamRecord>) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
-
Add stream record with given body to key.
- xAdd(ByteBufferRecord) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
-
Add stream record with given body to key.
- xAdd(ByteBufferRecord, RedisStreamCommands.XAddOptions) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
-
Add stream record with the specified options.
- xAdd(MapRecord<byte[], byte[], byte[]>) - Method in interface org.springframework.data.redis.connection.RedisStreamCommands
-
Append the given
record
to the stream stored atRecord#getStream
. - xAdd(MapRecord<byte[], byte[], byte[]>, RedisStreamCommands.XAddOptions) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.streamCommands()
}. - xAdd(MapRecord<byte[], byte[], byte[]>, RedisStreamCommands.XAddOptions) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- xAdd(MapRecord<byte[], byte[], byte[]>, RedisStreamCommands.XAddOptions) - Method in interface org.springframework.data.redis.connection.RedisStreamCommands
-
Append the given
record
to the stream stored atRecord#getStream
. - xAdd(StringRecord) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Append the given
StringRecord
to the stream stored atRecord.getStream()
. - xAdd(StringRecord, RedisStreamCommands.XAddOptions) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- xAdd(StringRecord, RedisStreamCommands.XAddOptions) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Append the given
StringRecord
to the stream stored atRecord.getStream()
. - xClaim(byte[], String, String, Duration, RecordId...) - Method in interface org.springframework.data.redis.connection.RedisStreamCommands
-
Change the ownership of a pending message to the given new consumer.
- xClaim(byte[], String, String, RedisStreamCommands.XClaimOptions) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.streamCommands()
}. - xClaim(byte[], String, String, RedisStreamCommands.XClaimOptions) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- xClaim(byte[], String, String, RedisStreamCommands.XClaimOptions) - Method in interface org.springframework.data.redis.connection.RedisStreamCommands
-
Change the ownership of a pending message to the given new consumer.
- xClaim(String, String, String, Duration, RecordId...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Change the ownership of a pending message to the given new consumer.
- xClaim(String, String, String, RedisStreamCommands.XClaimOptions) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- xClaim(String, String, String, RedisStreamCommands.XClaimOptions) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Change the ownership of a pending message to the given new consumer.
- xClaim(ByteBuffer, String, String, Duration, RecordId...) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
-
Change the ownership of a pending message to the given new consumer.
- xClaim(ByteBuffer, String, String, RedisStreamCommands.XClaimOptions) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
-
Change the ownership of a pending message to the given new consumer.
- xClaim(Publisher<ReactiveStreamCommands.XClaimCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
-
Change the ownership of a pending message to the given new consumer.
- xClaimJustId(byte[], String, String, RedisStreamCommands.XClaimOptions) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.streamCommands()
}. - xClaimJustId(byte[], String, String, RedisStreamCommands.XClaimOptions) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- xClaimJustId(byte[], String, String, RedisStreamCommands.XClaimOptions) - Method in interface org.springframework.data.redis.connection.RedisStreamCommands
-
Change the ownership of a pending message to the given new consumer without increasing the delivered count.
- xClaimJustId(String, String, String, RedisStreamCommands.XClaimOptions) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- xClaimJustId(String, String, String, RedisStreamCommands.XClaimOptions) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Change the ownership of a pending message to the given new consumer without increasing the delivered count.
- xClaimJustId(ByteBuffer, String, String, RedisStreamCommands.XClaimOptions) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
-
Change the ownership of a pending message to the given new consumer without increasing the delivered count.
- xClaimJustId(Publisher<ReactiveStreamCommands.XClaimCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
-
Change the ownership of a pending message to the given new consumer without increasing the delivered count.
- xDel(byte[], String...) - Method in interface org.springframework.data.redis.connection.RedisStreamCommands
-
Removes the records with the given id's from the stream.
- xDel(byte[], RecordId...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.streamCommands()
}. - xDel(byte[], RecordId...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- xDel(byte[], RecordId...) - Method in interface org.springframework.data.redis.connection.RedisStreamCommands
-
Removes the records with the given id's from the stream.
- xDel(String, String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Removes the specified entries from the stream.
- xDel(String, RecordId...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- xDel(String, RecordId...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
- xDel(ByteBuffer, String...) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
-
Removes the specified entries from the stream.
- xDel(ByteBuffer, RecordId...) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
-
Removes the specified entries from the stream.
- xDel(Publisher<ReactiveStreamCommands.DeleteCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
-
Removes the specified entries from the stream.
- xGroup(Publisher<ReactiveStreamCommands.GroupCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
-
Execute the given
ReactiveStreamCommands.GroupCommand
to create, destroy,... groups. - xGroup(ReactiveStreamCommands.GroupCommand) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
-
Execute the given
ReactiveStreamCommands.GroupCommand
to create, destroy,... groups. - xGroupCreate(byte[], String, ReadOffset) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.streamCommands()
}. - xGroupCreate(byte[], String, ReadOffset) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- xGroupCreate(byte[], String, ReadOffset) - Method in interface org.springframework.data.redis.connection.RedisStreamCommands
-
Create a consumer group.
- xGroupCreate(byte[], String, ReadOffset, boolean) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.streamCommands()
}. - xGroupCreate(byte[], String, ReadOffset, boolean) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- xGroupCreate(byte[], String, ReadOffset, boolean) - Method in interface org.springframework.data.redis.connection.RedisStreamCommands
-
Create a consumer group.
- xGroupCreate(String, ReadOffset, String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- xGroupCreate(String, ReadOffset, String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Create a consumer group.
- xGroupCreate(String, ReadOffset, String, boolean) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- xGroupCreate(String, ReadOffset, String, boolean) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Create a consumer group.
- xGroupCreate(ByteBuffer, String, ReadOffset) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
-
Create a consumer group.
- xGroupCreate(ByteBuffer, String, ReadOffset, boolean) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
-
Create a consumer group.
- xGroupDelConsumer(byte[], String, String) - Method in interface org.springframework.data.redis.connection.RedisStreamCommands
-
Delete a consumer from a consumer group.
- xGroupDelConsumer(byte[], Consumer) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.streamCommands()
}. - xGroupDelConsumer(byte[], Consumer) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- xGroupDelConsumer(byte[], Consumer) - Method in interface org.springframework.data.redis.connection.RedisStreamCommands
-
Delete a consumer from a consumer group.
- xGroupDelConsumer(String, Consumer) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- xGroupDelConsumer(String, Consumer) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Delete a consumer from a consumer group.
- xGroupDelConsumer(ByteBuffer, String, String) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
-
Delete a consumer from a consumer group.
- xGroupDelConsumer(ByteBuffer, Consumer) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
-
Delete a consumer from a consumer group.
- xGroupDestroy(byte[], String) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.streamCommands()
}. - xGroupDestroy(byte[], String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- xGroupDestroy(byte[], String) - Method in interface org.springframework.data.redis.connection.RedisStreamCommands
-
Destroy a consumer group.
- xGroupDestroy(String, String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- xGroupDestroy(String, String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Destroy a consumer group.
- xGroupDestroy(ByteBuffer, String) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
-
Destroy a consumer group.
- xInfo(byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.streamCommands()
}. - xInfo(byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- xInfo(byte[]) - Method in interface org.springframework.data.redis.connection.RedisStreamCommands
-
Obtain general information about the stream stored at the specified key.
- xInfo(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- xInfo(String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Obtain general information about the stream stored at the specified key.
- xInfo(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
-
Obtain general information about the stream stored at the specified key.
- xInfo(Publisher<ReactiveStreamCommands.XInfoCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
-
Obtain general information about the stream stored at the specified key.
- XInfoConsumer(String, List<Object>) - Constructor for class org.springframework.data.redis.connection.stream.StreamInfo.XInfoConsumer
- xInfoConsumers(byte[], String) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.streamCommands()
}. - xInfoConsumers(byte[], String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- xInfoConsumers(byte[], String) - Method in interface org.springframework.data.redis.connection.RedisStreamCommands
-
Obtain information about every consumer in a specific consumer group for the stream stored at the specified key.
- xInfoConsumers(String, String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- xInfoConsumers(String, String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Obtain information about every consumer in a specific consumer group for the stream stored at the specified key.
- xInfoConsumers(ByteBuffer, String) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
-
Obtain information about every consumer in a specific consumer group for the stream stored at the specified key.
- xInfoConsumers(Publisher<ReactiveStreamCommands.XInfoCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
-
Obtain information about every consumer in a specific consumer group for the stream stored at the specified key.
- XInfoConsumers(String, List<Object>) - Constructor for class org.springframework.data.redis.connection.stream.StreamInfo.XInfoConsumers
- xInfoGroups(byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.streamCommands()
}. - xInfoGroups(byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- xInfoGroups(byte[]) - Method in interface org.springframework.data.redis.connection.RedisStreamCommands
-
Obtain information about consumer groups associated with the stream stored at the specified key.
- xInfoGroups(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- xInfoGroups(String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Obtain information about consumer groups associated with the stream stored at the specified key.
- xInfoGroups(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
-
Obtain general information about the stream stored at the specified key.
- xInfoGroups(Publisher<ReactiveStreamCommands.XInfoCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
-
Obtain general information about the stream stored at the specified key.
- xLen(byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.streamCommands()
}. - xLen(byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- xLen(byte[]) - Method in interface org.springframework.data.redis.connection.RedisStreamCommands
-
Get the length of a stream.
- xLen(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- xLen(String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get the length of a stream.
- xLen(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
-
Get the size of the stream stored at key.
- xLen(Publisher<ReactiveRedisConnection.KeyCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
-
Get the size of the stream stored at
ReactiveRedisConnection.KeyCommand.getKey()
- XOR - Enum constant in enum class org.springframework.data.redis.connection.RedisStringCommands.BitOperation
- xPending(byte[], String) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.streamCommands()
}. - xPending(byte[], String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- xPending(byte[], String) - Method in interface org.springframework.data.redis.connection.RedisStreamCommands
-
Obtain the
PendingMessagesSummary
for a given consumer group. - xPending(byte[], String, String) - Method in interface org.springframework.data.redis.connection.RedisStreamCommands
-
Obtained detailed information about all pending messages for a given consumer.
- xPending(byte[], String, String, Range<?>, Long) - Method in interface org.springframework.data.redis.connection.RedisStreamCommands
- xPending(byte[], String, Range<?>, Long) - Method in interface org.springframework.data.redis.connection.RedisStreamCommands
- xPending(byte[], String, RedisStreamCommands.XPendingOptions) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.streamCommands()
}. - xPending(byte[], String, RedisStreamCommands.XPendingOptions) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- xPending(byte[], String, RedisStreamCommands.XPendingOptions) - Method in interface org.springframework.data.redis.connection.RedisStreamCommands
- xPending(byte[], Consumer) - Method in interface org.springframework.data.redis.connection.RedisStreamCommands
-
Obtained detailed information about all pending messages for a given
Consumer
. - xPending(byte[], Consumer, Range<?>, Long) - Method in interface org.springframework.data.redis.connection.RedisStreamCommands
- xPending(String, String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- xPending(String, String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Obtain the
PendingMessagesSummary
for a given consumer group. - xPending(String, String, String, Range<String>, Long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- xPending(String, String, String, Range<String>, Long) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
- xPending(String, String, Range<String>, Long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- xPending(String, String, Range<String>, Long) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
- xPending(String, String, RedisStreamCommands.XPendingOptions) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- xPending(String, String, RedisStreamCommands.XPendingOptions) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
- xPending(ByteBuffer, String) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
-
Obtain the
PendingMessagesSummary
for a given consumer group. - xPending(ByteBuffer, String, String) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
-
Obtained detailed information about all pending messages for a given consumer.
- xPending(ByteBuffer, String, String, Range<?>, Long) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
- xPending(ByteBuffer, String, Range<?>, Long) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
- xPending(ByteBuffer, Consumer) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
-
Obtained detailed information about all pending messages for a given
Consumer
. - xPending(ByteBuffer, Consumer, Range<?>, Long) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
- xPending(Publisher<ReactiveStreamCommands.PendingRecordsCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
- xPendingSummary(Publisher<ReactiveStreamCommands.PendingRecordsCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
-
Obtain the
PendingMessagesSummary
for a given consumer group. - xRange(byte[], Range<String>) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.streamCommands()
}. - xRange(byte[], Range<String>) - Method in interface org.springframework.data.redis.connection.RedisStreamCommands
- xRange(byte[], Range<String>, Limit) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.streamCommands()
}. - xRange(byte[], Range<String>, Limit) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- xRange(byte[], Range<String>, Limit) - Method in interface org.springframework.data.redis.connection.RedisStreamCommands
- xRange(String, Range<String>) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Read records from a stream within a specific
RedisZSetCommands.Range
. - xRange(String, Range<String>, Limit) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- xRange(String, Range<String>, Limit) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Read records from a stream within a specific
RedisZSetCommands.Range
applying aLimit
. - xRange(ByteBuffer, Range<String>) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
-
Read records from a stream within a specific
Range
. - xRange(ByteBuffer, Range<String>, Limit) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
- xRange(Publisher<ReactiveStreamCommands.RangeCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
- xRead(StreamOffset<byte[]>...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.streamCommands()
}. - xRead(StreamOffset<byte[]>...) - Method in interface org.springframework.data.redis.connection.RedisStreamCommands
-
Read records from one or more
StreamOffset
s. - xRead(StreamOffset<ByteBuffer>...) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
-
Read records from one or more
StreamOffset
s. - xRead(StreamReadOptions, StreamOffset<byte[]>...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.streamCommands()
}. - xRead(StreamReadOptions, StreamOffset<byte[]>...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- xRead(StreamReadOptions, StreamOffset<byte[]>...) - Method in interface org.springframework.data.redis.connection.RedisStreamCommands
-
Read records from one or more
StreamOffset
s. - xRead(StreamReadOptions, StreamOffset<ByteBuffer>...) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
-
Read records from one or more
StreamOffset
s. - xReadAsString(StreamOffset<String>) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Read records from one or more
StreamOffset
s. - xReadAsString(StreamOffset<String>...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Read records from one or more
StreamOffset
s. - xReadAsString(StreamReadOptions, StreamOffset<String>) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Read records from one or more
StreamOffset
s. - xReadAsString(StreamReadOptions, StreamOffset<String>...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- xReadAsString(StreamReadOptions, StreamOffset<String>...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Read records from one or more
StreamOffset
s. - xReadGroup(Consumer, StreamOffset<byte[]>...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.streamCommands()
}. - xReadGroup(Consumer, StreamOffset<byte[]>...) - Method in interface org.springframework.data.redis.connection.RedisStreamCommands
-
Read records from one or more
StreamOffset
s using a consumer group. - xReadGroup(Consumer, StreamOffset<ByteBuffer>...) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
-
Read records from one or more
StreamOffset
s using a consumer group. - xReadGroup(Consumer, StreamReadOptions, StreamOffset<byte[]>...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.streamCommands()
}. - xReadGroup(Consumer, StreamReadOptions, StreamOffset<byte[]>...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- xReadGroup(Consumer, StreamReadOptions, StreamOffset<byte[]>...) - Method in interface org.springframework.data.redis.connection.RedisStreamCommands
-
Read records from one or more
StreamOffset
s using a consumer group. - xReadGroup(Consumer, StreamReadOptions, StreamOffset<ByteBuffer>...) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
-
Read records from one or more
StreamOffset
s using a consumer group. - xReadGroupAsString(Consumer, StreamOffset<String>) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Read records from one or more
StreamOffset
s using a consumer group. - xReadGroupAsString(Consumer, StreamOffset<String>...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Read records from one or more
StreamOffset
s using a consumer group. - xReadGroupAsString(Consumer, StreamReadOptions, StreamOffset<String>) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Read records from one or more
StreamOffset
s using a consumer group. - xReadGroupAsString(Consumer, StreamReadOptions, StreamOffset<String>...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- xReadGroupAsString(Consumer, StreamReadOptions, StreamOffset<String>...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Read records from one or more
StreamOffset
s using a consumer group. - xRevRange(byte[], Range<String>) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.streamCommands()
}. - xRevRange(byte[], Range<String>) - Method in interface org.springframework.data.redis.connection.RedisStreamCommands
-
Read records from a stream within a specific
Range
in reverse order. - xRevRange(byte[], Range<String>, Limit) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.streamCommands()
}. - xRevRange(byte[], Range<String>, Limit) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- xRevRange(byte[], Range<String>, Limit) - Method in interface org.springframework.data.redis.connection.RedisStreamCommands
- xRevRange(String, Range<String>) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Read records from a stream within a specific
RedisZSetCommands.Range
in reverse order. - xRevRange(String, Range<String>, Limit) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- xRevRange(String, Range<String>, Limit) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Read records from a stream within a specific
RedisZSetCommands.Range
applying aLimit
in reverse order. - xRevRange(ByteBuffer, Range<String>) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
-
Read records from a stream within a specific
Range
in reverse order. - xRevRange(ByteBuffer, Range<String>, Limit) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
- xRevRange(Publisher<ReactiveStreamCommands.RangeCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
- xTrim(byte[], long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.streamCommands()
}. - xTrim(byte[], long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- xTrim(byte[], long) - Method in interface org.springframework.data.redis.connection.RedisStreamCommands
-
Trims the stream to
count
elements. - xTrim(byte[], long, boolean) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.
- xTrim(byte[], long, boolean) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- xTrim(byte[], long, boolean) - Method in interface org.springframework.data.redis.connection.RedisStreamCommands
-
Trims the stream to
count
elements. - xTrim(String, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- xTrim(String, long) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Trims the stream to
count
elements. - xTrim(String, long, boolean) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- xTrim(String, long, boolean) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Trims the stream to
count
elements. - xTrim(ByteBuffer, long) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
-
Trims the stream to
count
elements. - xTrim(ByteBuffer, long, boolean) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
-
Trims the stream to
count
elements. - xTrim(Publisher<ReactiveStreamCommands.TrimCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
-
Trims the stream to
count
elements. - xx() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZAddCommand
-
Applies xx mode (Only update elements that already exist.
- xx() - Method in class org.springframework.data.redis.connection.RedisZSetCommands.ZAddArgs
-
Don't update already existing elements.
- XX - Enum constant in enum class org.springframework.data.redis.connection.RedisZSetCommands.ZAddArgs.Flag
-
Only update elements that already exist.
Z
- zAdd(byte[], double, byte[]) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Add
value
to a sorted set atkey
, or update itsscore
if it already exists. - zAdd(byte[], double, byte[], RedisZSetCommands.ZAddArgs) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zAdd(byte[], double, byte[], RedisZSetCommands.ZAddArgs) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zAdd(byte[], double, byte[], RedisZSetCommands.ZAddArgs) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
- zAdd(byte[], Set<Tuple>) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Add
tuples
to a sorted set atkey
, or update itsscore
if it already exists. - zAdd(byte[], Set<Tuple>, RedisZSetCommands.ZAddArgs) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zAdd(byte[], Set<Tuple>, RedisZSetCommands.ZAddArgs) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zAdd(byte[], Set<Tuple>, RedisZSetCommands.ZAddArgs) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
- zAdd(String, double, String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zAdd(String, double, String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Add
value
to a sorted set atkey
, or update itsscore
if it already exists. - zAdd(String, double, String, RedisZSetCommands.ZAddArgs) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zAdd(String, double, String, RedisZSetCommands.ZAddArgs) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
- zAdd(String, Set<StringRedisConnection.StringTuple>) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zAdd(String, Set<StringRedisConnection.StringTuple>) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Add
tuples
to a sorted set atkey
, or update itsscore
if it already exists. - zAdd(String, Set<StringRedisConnection.StringTuple>, RedisZSetCommands.ZAddArgs) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zAdd(String, Set<StringRedisConnection.StringTuple>, RedisZSetCommands.ZAddArgs) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
- zAdd(ByteBuffer, Double, ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Add value to a sorted set at key, or update its score if it already exists.
- zAdd(ByteBuffer, Collection<? extends Tuple>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Add a tuples to a sorted set at key, or update their score if it already exists.
- zAdd(Publisher<ReactiveZSetCommands.ZAddCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Add
ReactiveZSetCommands.ZAddCommand.getTuples()
to a sorted set atReactiveRedisConnection.KeyCommand.getKey()
, or update its score if it already exists. - ZADD - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- zCard() - Method in interface org.springframework.data.redis.core.BoundZSetOperations
-
Get the size of sorted set with the bound key.
- zCard(byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zCard(byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zCard(byte[]) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Get the size of sorted set with
key
. - zCard(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zCard(String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get the size of sorted set with
key
. - zCard(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Get the size of sorted set with key.
- zCard(K) - Method in interface org.springframework.data.redis.core.ZSetOperations
-
Get the size of sorted set with
key
. - zCard(Publisher<ReactiveRedisConnection.KeyCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Get the size of sorted set with .
- ZCARD - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- zCount(byte[], double, double) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zCount(byte[], double, double) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zCount(byte[], double, double) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Count number of elements within sorted set with scores between
min
andmax
. - zCount(byte[], Range<? extends Number>) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zCount(byte[], Range<? extends Number>) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zCount(byte[], Range<? extends Number>) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Count number of elements within sorted set with scores between
Range#min
andRange#max
. - zCount(String, double, double) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zCount(String, double, double) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Count number of elements within sorted set with scores between
min
andmax
. - zCount(ByteBuffer, Range<Double>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Count number of elements within sorted set with scores within
Range
. - zCount(Publisher<ReactiveZSetCommands.ZCountCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Count number of elements within sorted set with scores within
Range
. - ZCOUNT - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- zDiff(byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zDiff(byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zDiff(byte[]...) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Diff sorted
sets
. - zDiff(String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zDiff(String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Diff sorted
sets
. - zDiff(List<ByteBuffer>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Diff sorted sets.
- zDiff(Publisher<? extends ReactiveZSetCommands.ZDiffCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Diff sorted sets.
- zDiffStore(byte[], byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zDiffStore(byte[], byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zDiffStore(byte[], byte[]...) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Diff sorted
sets
and store result in destinationdestKey
. - zDiffStore(String, String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zDiffStore(String, String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Diff sorted
sets
and store result in destinationdestKey
. - zDiffStore(ByteBuffer, List<ByteBuffer>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Diff sorted sets and store result in destination destinationKey.
- zDiffStore(Publisher<ReactiveZSetCommands.ZDiffStoreCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Diff sorted sets and store result in destination destinationKey.
- zDiffWithScores(byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zDiffWithScores(byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zDiffWithScores(byte[]...) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Diff sorted
sets
. - zDiffWithScores(String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zDiffWithScores(String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Diff sorted
sets
. - zDiffWithScores(List<ByteBuffer>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Diff sorted sets.
- zDiffWithScores(Publisher<? extends ReactiveZSetCommands.ZDiffCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Diff sorted sets.
- zIncrBy(byte[], double, byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zIncrBy(byte[], double, byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zIncrBy(byte[], double, byte[]) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Increment the score of element with
value
in sorted set byincrement
. - zIncrBy(String, double, String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zIncrBy(String, double, String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Increment the score of element with
value
in sorted set byincrement
. - zIncrBy(ByteBuffer, Number, ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Increment the score of element with value in sorted set by increment.
- zIncrBy(Publisher<ReactiveZSetCommands.ZIncrByCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Increment the score of element with
ReactiveZSetCommands.ZIncrByCommand.getValue()
in sorted set byReactiveZSetCommands.ZIncrByCommand.getIncrement()
. - ZINCRBY - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- zInter(byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zInter(byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zInter(byte[]...) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Intersect sorted
sets
. - zInter(String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zInter(String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Intersect sorted
sets
. - zInter(List<ByteBuffer>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Intersect sorted sets.
- zInter(Publisher<? extends ReactiveZSetCommands.ZAggregateCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Intersect sorted sets by applying aggregateFunction and apply weights to individual sets.
- zInterStore(byte[], byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zInterStore(byte[], byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zInterStore(byte[], byte[]...) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Intersect sorted
sets
and store result in destinationdestKey
. - zInterStore(byte[], Aggregate, int[], byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zInterStore(byte[], Aggregate, int[], byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zInterStore(byte[], Aggregate, int[], byte[]...) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Intersect sorted
sets
and store result in destinationdestKey
. - zInterStore(byte[], Aggregate, Weights, byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zInterStore(byte[], Aggregate, Weights, byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zInterStore(byte[], Aggregate, Weights, byte[]...) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Intersect sorted
sets
and store result in destinationdestKey
. - zInterStore(String, String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zInterStore(String, String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Intersect sorted
sets
and store result in destinationkey
. - zInterStore(String, Aggregate, int[], String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zInterStore(String, Aggregate, int[], String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Intersect sorted
sets
and store result in destinationkey
. - zInterStore(ByteBuffer, List<ByteBuffer>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Intersect sorted sets and store result in destination destinationKey.
- zInterStore(ByteBuffer, List<ByteBuffer>, List<Double>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Intersect sorted sets and store result in destination destinationKey and apply weights to individual sets.
- zInterStore(ByteBuffer, List<ByteBuffer>, List<Double>, Aggregate) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Intersect sorted sets by applying aggregateFunction and store result in destination destinationKey and apply weights to individual sets.
- zInterStore(ByteBuffer, List<ByteBuffer>, Weights) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Intersect sorted sets and store result in destination destinationKey and apply weights to individual sets.
- zInterStore(ByteBuffer, List<ByteBuffer>, Weights, Aggregate) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Intersect sorted sets by applying aggregateFunction and store result in destination destinationKey and apply weights to individual sets.
- zInterStore(Publisher<? extends ReactiveZSetCommands.ZAggregateStoreCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Intersect sorted sets by applying aggregateFunction and store result in destination destinationKey and apply weights to individual sets.
- ZINTERSTORE - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- zInterWithScores(byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zInterWithScores(byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zInterWithScores(byte[]...) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Intersect sorted
sets
. - zInterWithScores(String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zInterWithScores(String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Intersect sorted
sets
. - zInterWithScores(List<ByteBuffer>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Intersect sorted sets.
- zInterWithScores(List<ByteBuffer>, List<Double>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Intersect sorted sets and apply weights to individual sets.
- zInterWithScores(List<ByteBuffer>, List<Double>, Aggregate) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Intersect sorted sets by applying aggregateFunction and apply weights to individual sets.
- zInterWithScores(List<ByteBuffer>, Weights) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Intersect sorted sets and apply weights to individual sets.
- zInterWithScores(List<ByteBuffer>, Weights, Aggregate) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Intersect sorted sets by applying aggregateFunction and apply weights to individual sets.
- zInterWithScores(Publisher<? extends ReactiveZSetCommands.ZAggregateCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Intersect sorted sets by applying aggregateFunction and apply weights to individual sets.
- zInterWithScores(Aggregate, int[], byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zInterWithScores(Aggregate, int[], byte[]...) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Intersect sorted
sets
. - zInterWithScores(Aggregate, int[], String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Intersect sorted
sets
. - zInterWithScores(Aggregate, Weights, byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zInterWithScores(Aggregate, Weights, byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zInterWithScores(Aggregate, Weights, byte[]...) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Intersect sorted
sets
. - zInterWithScores(Aggregate, Weights, String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zInterWithScores(Aggregate, Weights, String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Intersect sorted
sets
. - ZIPLIST - Enum constant in enum class org.springframework.data.redis.connection.ValueEncoding.RedisValueEncoding
-
Space saving representation for small lists, hashes and sorted sets.
- zLexCount(byte[], Range<byte[]>) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zLexCount(byte[], Range<byte[]>) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zLexCount(byte[], Range<byte[]>) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Count number of elements within sorted set with value between
Range#min
andRange#max
applying lexicographical ordering. - zLexCount(String, Range<String>) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zLexCount(String, Range<String>) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Count number of elements within sorted set with value between
Range#min
andRange#max
applying lexicographical ordering. - zLexCount(ByteBuffer, Range<String>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Count number of elements within sorted set with value between
Range#min
andRange#max
applying lexicographical ordering. - zLexCount(Publisher<ReactiveZSetCommands.ZLexCountCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Count number of elements within sorted set with value between
Range#min
andRange#max
applying lexicographical ordering. - zMScore(byte[], byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zMScore(byte[], byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zMScore(byte[], byte[]...) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Get the scores of elements with
values
from sorted set with keykey
. - zMScore(String, String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zMScore(String, String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get the scores of elements with
values
from sorted set with keykey
. - zMScore(ByteBuffer, Collection<ByteBuffer>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Get the scores of elements with values from sorted set with key key.
- zMScore(Publisher<ReactiveZSetCommands.ZMScoreCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Get the scores of elements with
ReactiveZSetCommands.ZMScoreCommand.getValues()
from sorted set with keyReactiveRedisConnection.KeyCommand.getKey()
- zPop(Publisher<ReactiveZSetCommands.ZPopCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Remove and return elements from sorted set at
keyCommand#getKey()
. - zPopMax(byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zPopMax(byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zPopMax(byte[]) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Remove and return the value with its score having the highest score from sorted set at
key
. - zPopMax(byte[], long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zPopMax(byte[], long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zPopMax(byte[], long) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Remove and return
count
values with their score having the highest score from sorted set atkey
. - zPopMax(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zPopMax(String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Remove and return the value with its score having the highest score from sorted set at
key
. - zPopMax(String, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zPopMax(String, long) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Remove and return
count
values with their score having the highest score from sorted set atkey
. - zPopMax(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Remove and return the value with its score having the highest score from sorted set at
key
. - zPopMax(ByteBuffer, long) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Remove and return
count
values with their score having the highest score from sorted set atkey
. - zPopMin(byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zPopMin(byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zPopMin(byte[]) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Remove and return the value with its score having the lowest score from sorted set at
key
. - zPopMin(byte[], long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zPopMin(byte[], long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zPopMin(byte[], long) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Remove and return
count
values with their score having the lowest score from sorted set atkey
. - zPopMin(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zPopMin(String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Remove and return the value with its score having the lowest score from sorted set at
key
. - zPopMin(String, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zPopMin(String, long) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Remove and return
count
values with their score having the lowest score from sorted set atkey
. - zPopMin(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Remove and return the value with its score having the lowest score from sorted set at
key
. - zPopMin(ByteBuffer, long) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Remove and return
count
values with their score having the lowest score from sorted set atkey
. - zRandMember(byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zRandMember(byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRandMember(byte[]) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Get random element from sorted set at
key
. - zRandMember(byte[], long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zRandMember(byte[], long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRandMember(byte[], long) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Get
count
random elements from sorted set atkey
. - zRandMember(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRandMember(String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get random element from sorted set at
key
. - zRandMember(String, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRandMember(String, long) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get
count
random elements from sorted set atkey
. - zRandMember(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Get random element from sorted set at
key
. - zRandMember(ByteBuffer, long) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Get
count
random elements from sorted set atkey
. - zRandMember(Publisher<ReactiveZSetCommands.ZRandMemberCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Get random elements from sorted set at
key
. - zRandMemberWithScore(byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zRandMemberWithScore(byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRandMemberWithScore(byte[]) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Get random element from sorted set at
key
. - zRandMemberWithScore(byte[], long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zRandMemberWithScore(byte[], long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRandMemberWithScore(byte[], long) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Get
count
random elements from sorted set atkey
. - zRandMemberWithScore(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRandMemberWithScore(String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get random element from sorted set at
key
. - zRandMemberWithScore(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Get random element from sorted set at
key
. - zRandMemberWithScore(ByteBuffer, long) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Get
count
random elements from sorted set atkey
. - zRandMemberWithScore(Publisher<ReactiveZSetCommands.ZRandMemberCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Get random elements from sorted set at
key
. - zRandMemberWithScores(String, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRandMemberWithScores(String, long) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get
count
random elements from sorted set atkey
. - zRange(byte[], long, long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zRange(byte[], long, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRange(byte[], long, long) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Get elements between
start
andend
from sorted set. - zRange(String, long, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRange(String, long, long) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get elements between
start
andend
from sorted set. - zRange(ByteBuffer, Range<Long>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Get elements in range from sorted set.
- zRange(Publisher<ReactiveZSetCommands.ZRangeCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Get set of
Tuple
s in range from sorted set. - ZRANGE - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- zRangeByLex(byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRangeByLex(byte[]) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Get all the elements in the sorted set at key in lexicographical ordering.
- zRangeByLex(byte[], Range<byte[]>) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRangeByLex(byte[], Range<byte[]>) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Get all the elements in
Range
from the sorted set at key in lexicographical ordering. - zRangeByLex(byte[], Range<byte[]>, Limit) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zRangeByLex(byte[], Range<byte[]>, Limit) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRangeByLex(byte[], Range<byte[]>, Limit) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Get all the elements in
Range
from the sorted set at key in lexicographical ordering. - zRangeByLex(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRangeByLex(String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get all the elements in the sorted set at key in lexicographical ordering.
- zRangeByLex(String, Range<String>) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRangeByLex(String, Range<String>) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get all the elements in
RedisZSetCommands.Range
from the sorted set at key in lexicographical ordering. - zRangeByLex(String, Range<String>, Limit) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRangeByLex(String, Range<String>, Limit) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get all the elements in
RedisZSetCommands.Range
from the sorted set at key in lexicographical ordering. - zRangeByLex(ByteBuffer, Range<String>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Get all elements in
Range
from the sorted set at key in lexicographical ordering. - zRangeByLex(ByteBuffer, Range<String>, Limit) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Get all elements in
Range
from the sorted set at key in lexicographical ordering. - zRangeByLex(Publisher<ReactiveZSetCommands.ZRangeByLexCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Get all elements in
Range
from the sorted set at key in lexicographical ordering. - zRangeByScore(byte[], double, double) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRangeByScore(byte[], double, double) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Get elements where score is between
min
andmax
from sorted set. - zRangeByScore(byte[], double, double, long, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRangeByScore(byte[], double, double, long, long) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Get elements in range from
start
toend
where score is betweenmin
andmax
from sorted set. - zRangeByScore(byte[], String, String) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zRangeByScore(byte[], String, String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRangeByScore(byte[], String, String) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Deprecated.since 3.0, use
RedisZSetCommands.zRangeByScore(byte[], org.springframework.data.domain.Range)
instead. - zRangeByScore(byte[], String, String, long, long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zRangeByScore(byte[], String, String, long, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRangeByScore(byte[], String, String, long, long) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Get elements in range from
start
toend
where score is betweenmin
andmax
from sorted set. - zRangeByScore(byte[], Range<? extends Number>) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRangeByScore(byte[], Range<? extends Number>) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Get elements where score is between
Range#min
andRange#max
from sorted set. - zRangeByScore(byte[], Range<? extends Number>, Limit) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zRangeByScore(byte[], Range<? extends Number>, Limit) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRangeByScore(byte[], Range<? extends Number>, Limit) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Get elements in range from
Limit#count
toLimit#offset
where score is betweenRange#min
andRange#max
from sorted set. - zRangeByScore(String, double, double) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRangeByScore(String, double, double) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get elements where score is between
min
andmax
from sorted set. - zRangeByScore(String, double, double, long, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRangeByScore(String, double, double, long, long) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get elements in range from
start
toend
where score is betweenmin
andmax
from sorted set. - zRangeByScore(String, String, String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRangeByScore(String, String, String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get elements where score is between
min
andmax
from sorted set. - zRangeByScore(String, String, String, long, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRangeByScore(String, String, String, long, long) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get elements in range from
start
toend
where score is betweenmin
andmax
from sorted set. - zRangeByScore(ByteBuffer, Range<Double>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Get elements in range from sorted set.
- zRangeByScore(ByteBuffer, Range<Double>, Limit) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Get elements in range from sorted set.
- zRangeByScore(Publisher<ReactiveZSetCommands.ZRangeByScoreCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Get
Tuple
s in range from sorted set. - ZRANGEBYSCORE - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- zRangeByScoreWithScores(byte[], double, double) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRangeByScoreWithScores(byte[], double, double) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
- zRangeByScoreWithScores(byte[], double, double, long, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRangeByScoreWithScores(byte[], double, double, long, long) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
- zRangeByScoreWithScores(byte[], Range<? extends Number>) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRangeByScoreWithScores(byte[], Range<? extends Number>) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
- zRangeByScoreWithScores(byte[], Range<? extends Number>, Limit) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zRangeByScoreWithScores(byte[], Range<? extends Number>, Limit) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRangeByScoreWithScores(byte[], Range<? extends Number>, Limit) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Get set of
Tuple
s in range fromLimit#offset
toLimit#offset + Limit#count
where score is betweenRange#min
andRange#max
from sorted set. - zRangeByScoreWithScores(String, double, double) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRangeByScoreWithScores(String, double, double) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
- zRangeByScoreWithScores(String, double, double, long, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRangeByScoreWithScores(String, double, double, long, long) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
- zRangeByScoreWithScores(ByteBuffer, Range<Double>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Get
Tuple
s in range from sorted set. - zRangeByScoreWithScores(ByteBuffer, Range<Double>, Limit) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Get
Tuple
s in range from sorted set. - zRangeStore(Publisher<ReactiveZSetCommands.ZRangeStoreCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Get set of
Tuple
s in range from sorted set. - zRangeStoreByLex(byte[], byte[], Range<byte[]>) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
This command is like ZRANGE , but stores the result in the dstKey destination key.
- zRangeStoreByLex(byte[], byte[], Range<byte[]>, Limit) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zRangeStoreByLex(byte[], byte[], Range<byte[]>, Limit) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRangeStoreByLex(byte[], byte[], Range<byte[]>, Limit) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
This command is like ZRANGE , but stores the result in the dstKey destination key.
- zRangeStoreByLex(String, String, Range<String>) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
This command is like ZRANGE , but stores the result in the dstKey destination key.
- zRangeStoreByLex(String, String, Range<String>, Limit) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRangeStoreByLex(String, String, Range<String>, Limit) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
This command is like ZRANGE , but stores the result in the dstKey destination key.
- zRangeStoreByLex(ByteBuffer, ByteBuffer, Range<String>, Limit) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Add elements from
srcKey
by lexicographical range todestKey
. - zRangeStoreByScore(byte[], byte[], Range<? extends Number>) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
This command is like ZRANGE, but stores the result in the dstKey destination key.
- zRangeStoreByScore(byte[], byte[], Range<? extends Number>, Limit) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zRangeStoreByScore(byte[], byte[], Range<? extends Number>, Limit) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRangeStoreByScore(byte[], byte[], Range<? extends Number>, Limit) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
This command is like ZRANGE, but stores the result in the dstKey destination key.
- zRangeStoreByScore(String, String, Range<? extends Number>) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
This command is like ZRANGE, but stores the result in the dstKey destination key.
- zRangeStoreByScore(String, String, Range<? extends Number>, Limit) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRangeStoreByScore(String, String, Range<? extends Number>, Limit) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
This command is like ZRANGE, but stores the result in the dstKey destination key.
- zRangeStoreByScore(ByteBuffer, ByteBuffer, Range<Double>, Limit) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Add elements from
srcKey
by score range todestKey
. - zRangeStoreRevByLex(byte[], byte[], Range<byte[]>) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
This command is like ZRANGE … REV , but stores the result in the dstKey destination key.
- zRangeStoreRevByLex(byte[], byte[], Range<byte[]>, Limit) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zRangeStoreRevByLex(byte[], byte[], Range<byte[]>, Limit) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRangeStoreRevByLex(byte[], byte[], Range<byte[]>, Limit) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
This command is like ZRANGE … REV , but stores the result in the dstKey destination key.
- zRangeStoreRevByLex(String, String, Range<String>) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
This command is like ZRANGE … REV , but stores the result in the dstKey destination key.
- zRangeStoreRevByLex(String, String, Range<String>, Limit) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRangeStoreRevByLex(String, String, Range<String>, Limit) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
This command is like ZRANGE … REV , but stores the result in the dstKey destination key.
- zRangeStoreRevByLex(ByteBuffer, ByteBuffer, Range<String>, Limit) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Add elements from
srcKey
by reverse lexicographical range todestKey
. - zRangeStoreRevByScore(byte[], byte[], Range<? extends Number>) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
This command is like ZRANGE … REV, but stores the result in the dstKey destination key.
- zRangeStoreRevByScore(byte[], byte[], Range<? extends Number>, Limit) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zRangeStoreRevByScore(byte[], byte[], Range<? extends Number>, Limit) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRangeStoreRevByScore(byte[], byte[], Range<? extends Number>, Limit) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
This command is like ZRANGE … REV, but stores the result in the dstKey destination key.
- zRangeStoreRevByScore(String, String, Range<? extends Number>) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
This command is like ZRANGE … REV, but stores the result in the dstKey destination key.
- zRangeStoreRevByScore(String, String, Range<? extends Number>, Limit) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRangeStoreRevByScore(String, String, Range<? extends Number>, Limit) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
This command is like ZRANGE … REV, but stores the result in the dstKey destination key.
- zRangeStoreRevByScore(ByteBuffer, ByteBuffer, Range<Double>, Limit) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Add elements from
srcKey
by reverse score range todestKey
. - zRangeWithScores(byte[], long, long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zRangeWithScores(byte[], long, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRangeWithScores(byte[], long, long) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
- zRangeWithScores(String, long, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRangeWithScores(String, long, long) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
- zRangeWithScores(ByteBuffer, Range<Long>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Get set of
Tuple
s in range from sorted set. - zRank(byte[], byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zRank(byte[], byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRank(byte[], byte[]) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Determine the index of element with
value
in a sorted set. - zRank(String, String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRank(String, String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Determine the index of element with
value
in a sorted set. - zRank(ByteBuffer, ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Determine the index of element with value in a sorted set.
- zRank(Publisher<ReactiveZSetCommands.ZRankCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Determine the index of element with value in a sorted set when scored by
ReactiveZSetCommands.ZRankCommand.getDirection()
. - ZRANK - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- zRem(byte[], byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zRem(byte[], byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRem(byte[], byte[]...) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Remove
values
from sorted set. - zRem(String, String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRem(String, String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Remove
values
from sorted set. - zRem(ByteBuffer, ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Remove value from sorted set.
- zRem(ByteBuffer, Collection<ByteBuffer>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Remove values from sorted set.
- zRem(Publisher<ReactiveZSetCommands.ZRemCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Remove
ReactiveZSetCommands.ZRemCommand.getValues()
from sorted set. - ZREM - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- zRemRange(byte[], long, long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zRemRange(byte[], long, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRemRange(byte[], long, long) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Remove elements in range between
start
andend
from sorted set withkey
. - zRemRange(String, long, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRemRange(String, long, long) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Remove elements in range between
start
andend
from sorted set withkey
. - zRemRangeByLex(byte[], Range<byte[]>) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zRemRangeByLex(byte[], Range<byte[]>) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRemRangeByLex(byte[], Range<byte[]>) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Remove all elements between the lexicographical
Range
. - zRemRangeByLex(String, Range<String>) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRemRangeByLex(String, Range<String>) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Remove all elements between the lexicographical
RedisZSetCommands.Range
. - zRemRangeByLex(ByteBuffer, Range<String>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Remove elements in
Range
from sorted set with key. - zRemRangeByLex(Publisher<ReactiveZSetCommands.ZRemRangeByLexCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Remove elements in
Range
from sorted set withReactiveRedisConnection.KeyCommand.getKey()
. - zRemRangeByRank(ByteBuffer, Range<Long>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Remove elements in
Range
from sorted set with key. - zRemRangeByRank(Publisher<ReactiveZSetCommands.ZRemRangeByRankCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Remove elements in
Range
from sorted set withReactiveRedisConnection.KeyCommand.getKey()
. - ZREMRANGEBYRANK - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- zRemRangeByScore(byte[], double, double) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zRemRangeByScore(byte[], double, double) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRemRangeByScore(byte[], double, double) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Remove elements with scores between
min
andmax
from sorted set withkey
. - zRemRangeByScore(byte[], Range<? extends Number>) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zRemRangeByScore(byte[], Range<? extends Number>) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRemRangeByScore(byte[], Range<? extends Number>) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Remove elements with scores between
Range#min
andRange#max
from sorted set withkey
. - zRemRangeByScore(String, double, double) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRemRangeByScore(String, double, double) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Remove elements with scores between
min
andmax
from sorted set withkey
. - zRemRangeByScore(ByteBuffer, Range<Double>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Remove elements in
Range
from sorted set with key. - zRemRangeByScore(Publisher<ReactiveZSetCommands.ZRemRangeByScoreCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Remove elements in
Range
from sorted set withReactiveRedisConnection.KeyCommand.getKey()
. - ZREMRANGEBYSCORE - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- zRevRange(byte[], long, long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zRevRange(byte[], long, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRevRange(byte[], long, long) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Get elements in range from
start
toend
from sorted set ordered from high to low. - zRevRange(String, long, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRevRange(String, long, long) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get elements in range from
start
toend
from sorted set ordered from high to low. - zRevRange(ByteBuffer, Range<Long>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Get elements in range from sorted set in reverse score ordering.
- ZREVRANGE - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- zRevRangeByLex(byte[]) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Get all the elements in the sorted set at key in reversed lexicographical ordering.
- zRevRangeByLex(byte[], Range<byte[]>) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Get all the elements in
Range
from the sorted set at key in reversed lexicographical ordering. - zRevRangeByLex(byte[], Range<byte[]>, Limit) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zRevRangeByLex(byte[], Range<byte[]>, Limit) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRevRangeByLex(byte[], Range<byte[]>, Limit) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Get all the elements in
Range
from the sorted set at key in reversed lexicographical ordering. - zRevRangeByLex(String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get all the elements in the sorted set at key in reversed lexicographical ordering.
- zRevRangeByLex(String, Range<String>) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get all the elements in
RedisZSetCommands.Range
from the sorted set at key in reversed lexicographical ordering. - zRevRangeByLex(String, Range<String>, Limit) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRevRangeByLex(String, Range<String>, Limit) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get all the elements in
RedisZSetCommands.Range
from the sorted set at key in reversed lexicographical ordering. - zRevRangeByLex(ByteBuffer, Range<String>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Get all elements in
Range
from the sorted set at key in lexicographical ordering. - zRevRangeByLex(ByteBuffer, Range<String>, Limit) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Get all elements in
Range
from the sorted set at key in lexicographical ordering. - zRevRangeByScore(byte[], double, double) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRevRangeByScore(byte[], double, double) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Get elements where score is between
min
andmax
from sorted set ordered from high to low. - zRevRangeByScore(byte[], double, double, long, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRevRangeByScore(byte[], double, double, long, long) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Get elements in range from
start
toend
where score is betweenmin
andmax
from sorted set ordered high -> low. - zRevRangeByScore(byte[], Range<? extends Number>) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRevRangeByScore(byte[], Range<? extends Number>) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Get elements where score is between
Range#min
andRange#max
from sorted set ordered from high to low. - zRevRangeByScore(byte[], Range<? extends Number>, Limit) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zRevRangeByScore(byte[], Range<? extends Number>, Limit) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRevRangeByScore(byte[], Range<? extends Number>, Limit) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Get elements in range from
Limit#offset
toLimit#offset + Limit#count
where score is betweenRange#min
andRange#max
from sorted set ordered high -> low. - zRevRangeByScore(String, double, double) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRevRangeByScore(String, double, double) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get elements where score is between
min
andmax
from sorted set ordered from high to low. - zRevRangeByScore(String, double, double, long, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRevRangeByScore(String, double, double, long, long) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get elements in range from
start
toend
where score is betweenmin
andmax
from sorted set ordered high -> low. - zRevRangeByScore(ByteBuffer, Range<Double>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Get elements in range from sorted set in reverse score ordering.
- zRevRangeByScore(ByteBuffer, Range<Double>, Limit) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Get elements in range from sorted set in reverse score ordering.
- ZREVRANGEBYSCORE - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- zRevRangeByScoreWithScores(byte[], double, double) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRevRangeByScoreWithScores(byte[], double, double) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
- zRevRangeByScoreWithScores(byte[], double, double, long, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRevRangeByScoreWithScores(byte[], double, double, long, long) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Get set of
Tuple
in range fromstart
toend
where score is betweenmin
andmax
from sorted set ordered high -> low. - zRevRangeByScoreWithScores(byte[], Range<? extends Number>) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRevRangeByScoreWithScores(byte[], Range<? extends Number>) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Get set of
Tuple
where score is betweenRange#min
andRange#max
from sorted set ordered from high to low. - zRevRangeByScoreWithScores(byte[], Range<? extends Number>, Limit) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zRevRangeByScoreWithScores(byte[], Range<? extends Number>, Limit) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRevRangeByScoreWithScores(byte[], Range<? extends Number>, Limit) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Get set of
Tuple
in range fromLimit#offset
toLimit#count
where score is betweenRange#min
andRange#max
from sorted set ordered high -> low. - zRevRangeByScoreWithScores(String, double, double) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRevRangeByScoreWithScores(String, double, double) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
- zRevRangeByScoreWithScores(String, double, double, long, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRevRangeByScoreWithScores(String, double, double, long, long) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get set of
Tuple
in range fromstart
toend
where score is betweenmin
andmax
from sorted set ordered high -> low. - zRevRangeByScoreWithScores(ByteBuffer, Range<Double>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Get set of
Tuple
s in range from sorted set in reverse score ordering. - zRevRangeByScoreWithScores(ByteBuffer, Range<Double>, Limit) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Get
Tuple
s in range from sorted set in reverse score ordering. - zRevRangeWithScores(byte[], long, long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zRevRangeWithScores(byte[], long, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRevRangeWithScores(byte[], long, long) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
- zRevRangeWithScores(String, long, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRevRangeWithScores(String, long, long) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
- zRevRangeWithScores(ByteBuffer, Range<Long>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Get set of
Tuple
s in range from sorted set in reverse score ordering. - zRevRank(byte[], byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zRevRank(byte[], byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRevRank(byte[], byte[]) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Determine the index of element with
value
in a sorted set when scored high to low. - zRevRank(String, String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRevRank(String, String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Determine the index of element with
value
in a sorted set when scored high to low. - zRevRank(ByteBuffer, ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Determine the index of element with value in a sorted set when scored high to low.
- ZREVRANK - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- zScan(byte[], ScanOptions) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zScan(byte[], ScanOptions) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zScan(byte[], ScanOptions) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Use a
Cursor
to iterate over elements in sorted set atkey
. - zScan(String, ScanOptions) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zScan(String, ScanOptions) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Use a
Cursor
to iterate over elements in sorted set atkey
. - zScan(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Use a
Flux
to iterate over members in the sorted set atkey
. - zScan(ByteBuffer, ScanOptions) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
- zScan(Publisher<ReactiveRedisConnection.KeyScanCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Use a
Flux
to iterate over members in the sorted set atkey
. - ZSCAN - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- zScore(byte[], byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zScore(byte[], byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zScore(byte[], byte[]) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Get the score of element with
value
from sorted set with keykey
. - zScore(String, String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zScore(String, String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Get the score of element with
value
from sorted set with keykey
. - zScore(ByteBuffer, ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Get the score of element with value from sorted set with key key.
- zScore(Publisher<ReactiveZSetCommands.ZScoreCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Get the score of element with
ReactiveZSetCommands.ZScoreCommand.getValue()
from sorted set with keyReactiveRedisConnection.KeyCommand.getKey()
- ZSCORE - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- ZSET - Enum constant in enum class org.springframework.data.redis.connection.DataType
- ZSET - Enum constant in enum class org.springframework.data.redis.support.collections.RedisCollectionFactoryBean.CollectionType
- zSetCommands() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zSetCommands() - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
- zSetCommands() - Method in class org.springframework.data.redis.connection.jedis.JedisConnection
- zSetCommands() - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
- zSetCommands() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
- zSetCommands() - Method in interface org.springframework.data.redis.connection.ReactiveRedisClusterConnection
- zSetCommands() - Method in interface org.springframework.data.redis.connection.ReactiveRedisConnection
-
Get
ReactiveZSetCommands
. - zSetCommands() - Method in interface org.springframework.data.redis.connection.RedisCommandsProvider
-
Get
RedisZSetCommands
. - ZSetOperations<K,
V> - Interface in org.springframework.data.redis.core -
Redis ZSet/sorted set specific operations.
- ZSetOperations.TypedTuple<V> - Interface in org.springframework.data.redis.core
-
Typed ZSet tuple.
- zUnion(byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zUnion(byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zUnion(byte[]...) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Union sorted
sets
. - zUnion(String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zUnion(String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Union sorted
sets
. - zUnion(List<ByteBuffer>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Union sorted sets.
- zUnion(Publisher<? extends ReactiveZSetCommands.ZAggregateCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Union sorted sets by applying aggregateFunction and apply weights to individual sets.
- zUnionStore(byte[], byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zUnionStore(byte[], byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zUnionStore(byte[], byte[]...) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Union sorted
sets
. - zUnionStore(byte[], Aggregate, int[], byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zUnionStore(byte[], Aggregate, int[], byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zUnionStore(byte[], Aggregate, int[], byte[]...) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Union sorted
sets
and store result in destinationdestKey
. - zUnionStore(byte[], Aggregate, Weights, byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zUnionStore(byte[], Aggregate, Weights, byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zUnionStore(byte[], Aggregate, Weights, byte[]...) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Union sorted
sets
and store result in destinationdestKey
. - zUnionStore(String, String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zUnionStore(String, String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Union sorted
sets
and store result in destinationkey
. - zUnionStore(String, Aggregate, int[], String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zUnionStore(String, Aggregate, int[], String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Union sorted
sets
and store result in destinationkey
. - zUnionStore(ByteBuffer, List<ByteBuffer>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Union sorted sets and store result in destination destinationKey.
- zUnionStore(ByteBuffer, List<ByteBuffer>, List<Double>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Union sorted sets and store result in destination destinationKey and apply weights to individual sets.
- zUnionStore(ByteBuffer, List<ByteBuffer>, List<Double>, Aggregate) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Union sorted sets by applying aggregateFunction and store result in destination destinationKey and apply weights to individual sets.
- zUnionStore(ByteBuffer, List<ByteBuffer>, Weights) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Union sorted sets and store result in destination destinationKey and apply weights to individual sets.
- zUnionStore(ByteBuffer, List<ByteBuffer>, Weights, Aggregate) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Union sorted sets by applying aggregateFunction and store result in destination destinationKey and apply weights to individual sets.
- zUnionStore(Publisher<? extends ReactiveZSetCommands.ZAggregateStoreCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Union sorted sets by applying aggregateFunction and store result in destination destinationKey and apply weights to individual sets.
- ZUNIONSTORE - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- zUnionWithScores(byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zUnionWithScores(byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zUnionWithScores(byte[]...) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Union sorted
sets
. - zUnionWithScores(String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zUnionWithScores(String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Union sorted
sets
. - zUnionWithScores(List<ByteBuffer>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Union sorted sets.
- zUnionWithScores(List<ByteBuffer>, List<Double>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Union sorted sets and apply weights to individual sets.
- zUnionWithScores(List<ByteBuffer>, List<Double>, Aggregate) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Union sorted sets by applying aggregateFunction and apply weights to individual sets.
- zUnionWithScores(List<ByteBuffer>, Weights) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Union sorted sets and apply weights to individual sets.
- zUnionWithScores(List<ByteBuffer>, Weights, Aggregate) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Union sorted sets by applying aggregateFunction and apply weights to individual sets.
- zUnionWithScores(Publisher<? extends ReactiveZSetCommands.ZAggregateCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
-
Union sorted sets by applying aggregateFunction and apply weights to individual sets.
- zUnionWithScores(Aggregate, int[], byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zUnionWithScores(Aggregate, int[], byte[]...) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Union sorted
sets
. - zUnionWithScores(Aggregate, int[], String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Union sorted
sets
. - zUnionWithScores(Aggregate, Weights, byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
-
Deprecated.in favor of
RedisCommandsProvider.zSetCommands()
}. - zUnionWithScores(Aggregate, Weights, byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zUnionWithScores(Aggregate, Weights, byte[]...) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
-
Union sorted
sets
. - zUnionWithScores(Aggregate, Weights, String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zUnionWithScores(Aggregate, Weights, String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
-
Union sorted
sets
.
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
RedisCommandsProvider.stringCommands()
}.