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 forRedisCollection.
- AbstractRedisCollection(String, RedisOperations<String, E>) - Constructor for class org.springframework.data.redis.support.collections.AbstractRedisCollection
- 
Constructs a newAbstractRedisCollectioninstance.
- 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 newAbstractSubscriptioninstance.
- accumulateAndGet(double, DoubleBinaryOperator) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicDouble
- 
Atomically update the current value using the givenaccumulator function.
- accumulateAndGet(int, IntBinaryOperator) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicInteger
- 
Atomically update the current value using the givenaccumulator function.
- accumulateAndGet(long, LongBinaryOperator) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicLong
- 
Atomically update the current value using the givenaccumulator 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
- 
AddRedisGeoCommands.GeoLocations to key
- add(Map<HK, HV>) - Method in interface org.springframework.data.redis.core.BoundStreamOperations
- 
Append a record to the streamkey.
- add(Map<M, Point>) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
- 
AddMapof member /Pointpairs to key.
- add(Set<ZSetOperations.TypedTuple<V>>) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
- 
Addtuplesto a sorted set at the bound key, or update itsscoreif it already exists.
- add(K, Iterable<RedisGeoCommands.GeoLocation<M>>) - Method in interface org.springframework.data.redis.core.GeoOperations
- 
AddRedisGeoCommands.GeoLocations to key
- add(K, Iterable<RedisGeoCommands.GeoLocation<M>>) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
- 
AddRedisGeoCommands.GeoLocations to key
- add(K, Map<? extends HK, ? extends HV>) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
- 
Append a record to the streamkey.
- add(K, Map<? extends HK, ? extends HV>) - Method in interface org.springframework.data.redis.core.StreamOperations
- 
Append a record to the streamkey.
- add(K, Map<M, Point>) - Method in interface org.springframework.data.redis.core.GeoOperations
- 
AddMapof member /Pointpairs to key.
- add(K, Map<M, Point>) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
- 
AddMapof member /Pointpairs to key.
- add(K, Set<ZSetOperations.TypedTuple<V>>) - Method in interface org.springframework.data.redis.core.ZSetOperations
- 
Addtuplesto a sorted set atkey, or update itsscoreif it already exists.
- add(K, Publisher<? extends Collection<RedisGeoCommands.GeoLocation<M>>>) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
- 
AddRedisGeoCommands.GeoLocations 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 streamkey.
- add(K, Point, M) - Method in interface org.springframework.data.redis.core.GeoOperations
- 
AddPointwith given member name to key.
- add(K, Point, M) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
- 
AddPointwith given member name to key.
- add(K, RedisGeoCommands.GeoLocation<M>) - Method in interface org.springframework.data.redis.core.GeoOperations
- 
AddRedisGeoCommands.GeoLocationto key.
- add(K, RedisGeoCommands.GeoLocation<M>) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
- 
AddRedisGeoCommands.GeoLocationto 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 givenvaluesto set atkey.
- add(K, V...) - Method in interface org.springframework.data.redis.core.SetOperations
- 
Add givenvaluesto set atkey.
- add(K, V, double) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- 
Addvalueto a sorted set atkey, or update itsscoreif it already exists.
- add(K, V, double) - Method in interface org.springframework.data.redis.core.ZSetOperations
- 
Addvalueto a sorted set atkey, or update itsscoreif it already exists.
- add(Point, M) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
- 
AddPointwith given member name to key.
- add(RedisGeoCommands.GeoLocation<M>) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
- 
AddRedisGeoCommands.GeoLocationto key.
- add(MapRecord<K, ? extends HK, ? extends HV>) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
- 
Append a record, backed by aMapholding 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 aMapholding the field/value pairs, to the stream.
- add(Record<K, ?>) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
- 
Append the record, backed by the given value, to the stream.
- add(Record<K, ?>) - Method in interface org.springframework.data.redis.core.StreamOperations
- 
Append the record, backed by the given value, to the stream.
- add(ByteArrayWrapper) - Method in class org.springframework.data.redis.connection.util.ByteArraySet
- add(V...) - Method in interface org.springframework.data.redis.core.BoundSetOperations
- 
Add givenvaluesto set at the bound key.
- add(V, double) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
- 
Addvalueto a sorted set at the bound key, or update itsscoreif 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
- 
Addtuplesto 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 aConverterto extract theStringrepresentation 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
- 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 thedefault scoreif 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
- 
Addtuplesto 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
- 
Addtuplesto a sorted set atkeyif it does not already exists.
- addIfAbsent(K, V, double) - Method in interface org.springframework.data.redis.core.ZSetOperations
- 
Addvalueto a sorted set atkeyif it does not already exists.
- addIfAbsent(V, double) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
- 
Addvalueto 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 givenIndexDefinition.
- 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
- 
AddKeyspaceConfiguration.KeyspaceSettingsfor type.
- addLast(E) - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- addMessageListener(MessageListener, Collection<? extends Topic>) - Method in class org.springframework.data.redis.listener.RedisMessageListenerContainer
- 
Adds a message listener to the (potentially running) container.
- addMessageListener(MessageListener, Topic) - Method in class org.springframework.data.redis.listener.RedisMessageListenerContainer
- 
Adds a message listener to the (potentially running) container.
- addNode(String, int) - Method in class org.springframework.data.redis.connection.RedisStaticMasterReplicaConfiguration
- 
Add anodeto 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 inRedisClusterNode.SlotRangeto 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 specificAggregatefunction.
- aggregateUsing(Aggregate) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZAggregateStoreCommand
- 
Applies a specificAggregatefunction.
- aggregateUsing(Aggregate) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZInterStoreCommand
- 
Applies a specificAggregatefunction.
- aggregateUsing(Aggregate) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZUnionStoreCommand
- 
Applies a specificAggregatefunction.
- all() - Static method in class org.springframework.data.redis.connection.ReactiveListCommands.LRemCommand
- 
Creates a newReactiveListCommands.LRemCommandto 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 avaluetokey.
- append(String) - Method in interface org.springframework.data.redis.core.BoundValueOperations
- 
Append avalueto 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 avaluetokey.
- 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 avaluetokey.
- append(K, String) - Method in interface org.springframework.data.redis.core.ValueOperations
- 
Append avaluetokey.
- 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 aRedisURI.
- 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 theListof weights.
- applyWeights(List<Double>) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZAggregateStoreCommand
- 
Applies theListof weights.
- applyWeights(List<Double>) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZInterStoreCommand
- 
Applies theCollectionof weights.
- applyWeights(List<Double>) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZUnionStoreCommand
- 
Applies theListof weights.
- applyWeights(Weights) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZAggregateCommand
- 
Applies theWeights.
- applyWeights(Weights) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZAggregateStoreCommand
- 
Applies theWeights.
- applyWeights(Weights) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZInterStoreCommand
- 
Applies theWeights.
- applyWeights(Weights) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZUnionStoreCommand
- 
Applies theWeights.
- 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
- 
AppliesapproximateTrimming.
- 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 aConsumer.
- 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 theBucket.
- 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 theNOACKflag 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 theRecordIdsignalling 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 thisTaskbecomes active.
B
- basePackageClasses() - Element in annotation interface org.springframework.data.redis.repository.configuration.EnableRedisRepositories
- 
Type-safe alternative toEnableRedisRepositories.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
- 
RedisPersistentEntityimplementation.
- BasicRedisPersistentEntity(TypeInformation<T>, KeySpaceResolver, TimeToLiveAccessor) - Constructor for class org.springframework.data.redis.core.mapping.BasicRedisPersistentEntity
- 
Creates newBasicRedisPersistentEntity.
- batchSize(int) - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamMessageListenerContainerOptionsBuilder
- 
Configure a batch size for theCOUNToption during reading.
- batchSize(int) - Method in class org.springframework.data.redis.stream.StreamReceiver.StreamReceiverOptionsBuilder
- 
Configure a batch size for theCOUNToption during reading.
- BatchStrategies - Class in org.springframework.data.redis.cache
- BatchStrategy - Interface in org.springframework.data.redis.cache
- 
ABatchStrategyto 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 newBeanUtilsHashMapperfor 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 ofRedisCommandsProvider.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 ofRedisCommandsProvider.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 ofRedisCommandsProvider.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 ofRedisCommandsProvider.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 aRedisConnectionfrom the givenRedisConnectionFactoryand 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 aRedisConnectionfrom the givenRedisConnectionFactoryand 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 newReactiveStringCommands.GetBitCommandgiven a key.
- bit(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveStringCommands.SetBitCommand
- 
Creates a newReactiveStringCommands.SetBitCommandgiven a key.
- bitCount(byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 atkey.
- bitCount(byte[], long, long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 atkeybetweenstartandend.
- 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 atkey.
- 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 atkeybetweenstartandend.
- 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 newReactiveStringCommands.BitCountCommandgiven 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 givenkey.
- bitField(byte[], BitFieldSubCommands) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 givenkey.
- bitField(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveStringCommands.BitFieldCommand
- 
Creates a newReactiveStringCommands.BitFieldCommandgiven 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 givenkey.
- 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 givenkey.
- 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 givenkey.
- 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 givenkey.
- 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 actualBITFIELDcommand representation holding severalBitFieldSubCommands.BitFieldSubCommands to execute.
- BitFieldSubCommands.AbstractBitFieldSubCommand - Class in org.springframework.data.redis.connection
- BitFieldSubCommands.BitFieldGet - Class in org.springframework.data.redis.connection
- 
TheGETsub command used withBitFieldSubCommands.
- BitFieldSubCommands.BitFieldGetBuilder - Class in org.springframework.data.redis.connection
- BitFieldSubCommands.BitFieldIncrBy - Class in org.springframework.data.redis.connection
- 
TheINCRBYsub 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
- 
TheSETsub 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 ofBitFieldSubCommands.
- BitFieldSubCommands.BitFieldType - Class in org.springframework.data.redis.connection
- 
The actual Redis bitfield type representation for signed and unsigned integers used withBitFieldSubCommands.BitFieldSubCommand.
- BitFieldSubCommands.Offset - Class in org.springframework.data.redis.connection
- 
Offset used inside aBitFieldSubCommands.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 ofRedisCommandsProvider.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 givenbitin a string.
- bitPos(byte[], boolean, Range<Long>) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 givenbitin a string.
- bitPos(String, boolean) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
- 
Return the position of the first bit set to givenbitin 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 givenbitin a string.
- bitPos(ByteBuffer, boolean) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
- 
Return the position of the first bit set to givenbitin 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 givenbitin 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 givenbitin 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 ofRedisCommandsProvider.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 thefromargument) of the list stored atsourceKey, and pushes the element at the first/last element (head/tail depending on thetoargument) 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 thefromargument) of the list stored atsourceKey, and pushes the element at the first/last element (head/tail depending on thetoargument) 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 thefromargument) of the list stored atsourceKey, and pushes the element at the first/last element (head/tail depending on thetoargument) 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 thefromargument) of the list stored atsourceKey, and pushes the element at the first/last element (head/tail depending on thetoargument) of the list stored atdestinationKey.
- block(Duration) - Method in class org.springframework.data.redis.connection.stream.StreamReadOptions
- 
Use a blocking read and supply thetimeoutafter which the call will terminate if no message was read.
- blockingFor(long, TimeUnit) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.BZPopCommand
- 
Applies atimeout.
- blockingFor(Duration) - Method in class org.springframework.data.redis.connection.ReactiveListCommands.BPopCommand
- 
Applies atimeout.
- blockingFor(Duration) - Method in class org.springframework.data.redis.connection.ReactiveListCommands.BRPopLPushCommand
- 
Applies atimeout.
- blockingFor(Duration) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.BZPopCommand
- 
Applies atimeout.
- 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 ofRedisCommandsProvider.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 atkeys.
- 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 atkeys(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 newReactiveStreamCommands.AddStreamRecordgivenbody.
- 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 
- 
GeoOperationsbound 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 newBoundingBoxfrom the given width, height andMetric.
- BoundingBox(Distance, Distance) - Constructor for class org.springframework.data.redis.domain.geo.BoundingBox
- 
Creates a newBoundingBoxfrom 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 topReactiveListCommands.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 ofRedisCommandsProvider.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 atkeys.
- 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 atkeys(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 ofRedisCommandsProvider.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 atsrcKey, append it todstKeyand 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 atsrcKey, append it todstKeyand 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 atReactiveRedisConnection.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 withRedisData.
- 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 aBucket.
- 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 configuredbufferSize.
- build() - Method in class org.springframework.data.redis.cache.RedisCacheManager.RedisCacheManagerBuilder
- 
Create new instance ofRedisCacheManagerwith 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 theJedisClientConfigurationwith the configuration applied from this builder.
- build() - Method in interface org.springframework.data.redis.connection.jedis.JedisClientConfiguration.JedisPoolingClientConfigurationBuilder
- 
Build theJedisClientConfigurationwith the configuration applied from this builder.
- build() - Method in interface org.springframework.data.redis.connection.jedis.JedisClientConfiguration.JedisSslClientConfigurationBuilder
- 
Build theJedisClientConfigurationwith the configuration applied from this builder.
- build() - Method in class org.springframework.data.redis.connection.lettuce.LettuceClientConfiguration.LettuceClientConfigurationBuilder
- 
Build theLettuceClientConfigurationwith the configuration applied from this builder.
- build() - Method in class org.springframework.data.redis.connection.lettuce.LettuceClientConfiguration.LettuceSslClientConfigurationBuilder
- 
Build theLettuceClientConfigurationwith 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 theRedisNode.
- 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 newScanOptionsobjects.
- build() - Method in interface org.springframework.data.redis.serializer.RedisSerializationContext.RedisSerializationContextBuilder
- 
Builds aRedisSerializationContext.
- build() - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.ConsumerStreamReadRequestBuilder
- 
Build a new instance ofStreamMessageListenerContainer.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 ofStreamMessageListenerContainer.StreamReadRequest.
- build() - Method in class org.springframework.data.redis.stream.StreamReceiver.StreamReceiverOptionsBuilder
- 
Build newStreamReceiver.StreamReceiverOptions.
- builder() - Static method in class org.springframework.data.redis.cache.RedisCacheManager
- 
Factory method returning a Builder used to construct and configure aRedisCacheManager.
- builder() - Static method in interface org.springframework.data.redis.connection.jedis.JedisClientConfiguration
- 
Creates a newJedisClientConfiguration.JedisClientConfigurationBuilderto buildJedisClientConfigurationto be used with the jedis client.
- builder() - Static method in interface org.springframework.data.redis.connection.lettuce.LettuceClientConfiguration
- 
Creates a newLettuceClientConfiguration.LettuceClientConfigurationBuilderto buildLettuceClientConfigurationto be used with the Lettuce client.
- builder() - Static method in interface org.springframework.data.redis.connection.lettuce.LettucePoolingClientConfiguration
- 
Creates a newLettucePoolingClientConfiguration.LettucePoolingClientConfigurationBuilderto buildLettucePoolingClientConfigurationto be used with the Lettuce client.
- 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 aRedisCacheManagerusing the givenRedisCacheWriter.
- builder(RedisConnectionFactory) - Static method in class org.springframework.data.redis.cache.RedisCacheManager
- 
Factory method returning a Builder used to construct and configure aRedisCacheManagerusing 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 bywidthandheight.
- byBox(BoundingBox) - Static method in interface org.springframework.data.redis.domain.geo.GeoShape
- 
Create a shape used as predicate for geo queries from aBoundingBox.
- 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 aradiusaround 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 newRedisSerializationContextusing abyte[]serialization.
- byteArray() - Static method in interface org.springframework.data.redis.serializer.RedisSerializationContext.SerializationPair
- 
Creates a pass throughRedisSerializationContext.SerializationPairto pass-thrubyteobjects.
- byteArray() - Static method in interface org.springframework.data.redis.serializer.RedisSerializer
- 
Obtain aRedisSerializerthat 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 newRedisSerializationContextusing aByteBufferserialization.
- byteBuffer() - Static method in interface org.springframework.data.redis.serializer.RedisSerializationContext.SerializationPair
- 
Creates a pass throughRedisSerializationContext.SerializationPairto pass-thruByteBufferobjects.
- ByteBufferRecord - Interface in org.springframework.data.redis.connection.stream
- 
ARecordwithin 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
- 
ARecordwithin 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 withbytearrays.
- bZPop(Publisher<ReactiveZSetCommands.BZPopCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
- 
Remove and return elements from sorted set atkeyCommand#getKey().
- bZPopMax(byte[], long, TimeUnit) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 atkey.
- 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 atkey.
- 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 atkey.
- bZPopMin(byte[], long, TimeUnit) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 atkey.
- 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 atkey.
- 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 atkey.
C
- cacheDefaults() - Method in class org.springframework.data.redis.cache.RedisCacheManager.RedisCacheManagerBuilder
- 
Returns the defaultRedisCacheConfiguration.
- cacheDefaults(RedisCacheConfiguration) - Method in class org.springframework.data.redis.cache.RedisCacheManager.RedisCacheManagerBuilder
- 
Define a defaultRedisCacheConfigurationapplied to dynamically createdRedisCaches.
- CacheKeyPrefix - Interface in org.springframework.data.redis.cache
- 
CacheKeyPrefixis 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 aRedisCache.
- CacheStatisticsCollector - Interface in org.springframework.data.redis.cache
- 
The statistics collector supports capturing of relevantRedisCacheoperations such as hits & misses.
- CacheStatisticsProvider - Interface in org.springframework.data.redis.cache
- 
Interface to be implemented by objects that exposeCacheStatisticsidentified bycacheName.
- cacheWriter(RedisCacheWriter) - Method in class org.springframework.data.redis.cache.RedisCacheManager.RedisCacheManagerBuilder
- 
Configure aRedisCacheWriter.
- 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 cancellationPredicateto 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 valuetypecan be serialized by this serializer.
- CdiBean<T> - Class in org.springframework.data.redis.repository.cdi
- 
Base class forBeanwrappers.
- CdiBean(Set<Annotation>, Class<T>, BeanManager) - Constructor for class org.springframework.data.redis.repository.cdi.CdiBean
- 
Creates a newCdiBean.
- CdiBean(Set<Annotation>, Set<Type>, Class<T>, BeanManager) - Constructor for class org.springframework.data.redis.repository.cdi.CdiBean
- 
Creates a newCdiBean.
- 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 newReactiveSubscription.ChannelMessage.
- ChannelTopic - Class in org.springframework.data.redis.listener
- 
Channel Topicimplementation mapping to a Redis channel.
- ChannelTopic(String) - Constructor for class org.springframework.data.redis.listener.ChannelTopic
- 
Constructs a newChannelTopicinstance.
- 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 providedkeyPattern.
- 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 aclientNameto be set withCLIENT SETNAME.
- clientName(String) - Method in class org.springframework.data.redis.connection.lettuce.LettuceClientConfiguration.LettuceClientConfigurationBuilder
- 
Configure aclientNameto 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
- 
ConfigureClientOptions.
- 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
- 
ConfigureClientResources.
- 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 givenRedisClusterNode.
- clusterAddSlots(RedisClusterNode, int...) - Method in interface org.springframework.data.redis.connection.RedisClusterCommands
- 
Assign slots to givenRedisClusterNode.
- 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
- 
AssignRedisClusterNode.SlotRange.getSlotsArray()to givenRedisClusterNode.
- clusterAddSlots(RedisClusterNode, RedisClusterNode.SlotRange) - Method in interface org.springframework.data.redis.connection.RedisClusterCommands
- 
AssignRedisClusterNode.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 newClusterCommandExecutionFailureException.
- ClusterCommandExecutionFailureException(List<? extends Throwable>) - Constructor for exception org.springframework.data.redis.connection.ClusterCommandExecutionFailureException
- 
Creates newClusterCommandExecutionFailureException.
- ClusterCommandExecutor - Class in org.springframework.data.redis.connection
- 
ClusterCommandExecutortakes 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 instance ofClusterCommandExecutor.
- 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.MultiNodeResultholds allClusterCommandExecutor.NodeResultof a command executed on multipleRedisClusterNode.
- ClusterCommandExecutor.NodeResult<T> - Class in org.springframework.data.redis.connection
- 
ClusterCommandExecutor.NodeResultencapsulates the actual value returned by aClusterCommandExecutor.ClusterCommandCallbackon 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
- 
GetRedisGeoCommands.
- 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 fromRedisClusterNode.
- clusterDeleteSlots(RedisClusterNode, int...) - Method in interface org.springframework.data.redis.connection.RedisClusterCommands
- 
Remove slots fromRedisClusterNode.
- 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
- 
RemovesRedisClusterNode.SlotRange.getSlotsArray()from givenRedisClusterNode.
- clusterDeleteSlotsInRange(RedisClusterNode, RedisClusterNode.SlotRange) - Method in interface org.springframework.data.redis.connection.RedisClusterCommands
- 
RemovesRedisClusterNode.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 theRedisClusterNodeserving given key.
- clusterGetNodeForKey(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveClusterCommands
- 
Find theRedisClusterNodeserving 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 theRedisClusterNodeserving given slot.
- clusterGetNodeForSlot(int) - Method in interface org.springframework.data.redis.connection.RedisClusterCommands
- 
Find theRedisClusterNodeserving 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 givenkey.
- clusterGetSlotForKey(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveClusterCommands
- 
Find the slot for a givenkey.
- ClusterInfo - Class in org.springframework.data.redis.connection
- 
ClusterInfogives access to cluster information such ascluster_stateandcluster_slots_assignedprovided by theCLUSTER INFOcommand.
- ClusterInfo(Properties) - Constructor for class org.springframework.data.redis.connection.ClusterInfo
- 
Creates newClusterInfofor 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
- 
ClusterNodeResourceProviderprovides 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
- 
ClusterRedirectExceptionindicates 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 newClusterRedirectException.
- 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
- 
DataAccessResourceFailureExceptionindicating 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 newClusterStateFailureException.
- ClusterStateFailureException(String, Throwable) - Constructor for exception org.springframework.data.redis.ClusterStateFailureException
- 
Creates newClusterStateFailureException.
- ClusterTopology - Class in org.springframework.data.redis.connection
- 
ClusterTopologyholds snapshot like information aboutRedisClusterNodes.
- ClusterTopology(Set<RedisClusterNode>) - Constructor for class org.springframework.data.redis.connection.ClusterTopology
- 
Creates new instance ofClusterTopology.
- ClusterTopologyProvider - Interface in org.springframework.data.redis.connection
- 
ClusterTopologyProvidermanages 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
- 
GetRedisCommands.
- commands(BitFieldSubCommands) - Method in class org.springframework.data.redis.connection.ReactiveStringCommands.BitFieldCommand
- 
Applies theBitFieldSubCommands.
- 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
- 
CompositeIndexResolverimplementation that iterates over a given collection of delegateIndexResolverinstances.
- CompositeIndexResolver(Collection<IndexResolver>) - Constructor for class org.springframework.data.redis.core.convert.CompositeIndexResolver
- 
Create newCompositeIndexResolver.
- 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 theprefixfor the actual cache key stored in Redis.
- computePrefixWith(CacheKeyPrefix) - Method in class org.springframework.data.redis.cache.RedisCacheConfiguration
- 
Use the givenCacheKeyPrefixto 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 givenbytearrays into one.
- concatAll(byte[]...) - Static method in class org.springframework.data.redis.util.ByteUtils
- 
Concatenate the givenbytearrays 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 JacksonObjectMappercreated by thisGenericJackson2JsonRedisSerializerand used to de/serializeobjectsas JSON.
- configureKeyConverters(Consumer<ConverterRegistry>) - Method in class org.springframework.data.redis.cache.RedisCacheConfiguration
- 
Configure the underlyingConversionServiceused 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 aRedisConnection
- 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 aConsumerto consume stream messages within a consumer group.
- consumer(Consumer) - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamReadRequestBuilder
- 
Configure aConsumerto 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 thisRedisClusterNode.SlotRangecontains 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 beconvertedbefore 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 
- 
ConvertingCursorwraps a given cursor and applies givenConverterto 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
- 
Convertkeyto aStringrepresentation used for cache key creation.
- convertLettuceAccessException(Exception) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
- convertQuery(SortQuery<K>, RedisSerializer<String>) - Static method in class org.springframework.data.redis.core.query.QueryUtils
- convertToList(Collection<String>) - Static method in class org.springframework.data.redis.connection.util.DecodeUtils
- convertToSet(Collection<String>) - Static method in class org.springframework.data.redis.connection.util.DecodeUtils
- copy(byte[], byte[], boolean) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 givensourceKeytotargetKey.
- 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 givensourceKeytotargetKey.
- copy(ByteBuffer, ByteBuffer, boolean) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
- 
Copy givenkeyto a targetkey.
- copy(K, K, boolean) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
- 
Copy givensourceKeytotargetKey.
- 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 givensourceKeytotargetKey.
- 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 betweenminandmax.
- 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 currentScanOptions.ScanOptionsBuilderconfigured 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 betweenminandmax.
- count(K, Range<Double>) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- 
Count number of elements within sorted set with scores betweenminandmax.
- 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 ofkeysthat 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 newBitFieldSubCommands.
- create() - Static method in interface org.springframework.data.redis.serializer.JacksonObjectReader
- 
Create a defaultJacksonObjectReaderdelegating toObjectMapper.readValue(InputStream, JavaType).
- create() - Static method in interface org.springframework.data.redis.serializer.JacksonObjectWriter
- 
Create a defaultJacksonObjectWriterdelegating 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, uncappedRedisListinstance.
- create(String, RedisOperations<String, E>) - Static method in interface org.springframework.data.redis.support.collections.RedisSet
- 
Constructs a newRedisSetinstance.
- create(String, RedisOperations<String, E>) - Static method in interface org.springframework.data.redis.support.collections.RedisZSet
- 
Constructs a newRedisZSetinstance 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 newRedisZSetinstance.
- create(String, RedisOperations<String, E>, int) - Static method in interface org.springframework.data.redis.support.collections.RedisList
- 
Constructs a newRedisListinstance.
- 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 newBitFieldSubCommandswith Multiple BitFieldSubCommand.
- create(BitFieldSubCommands.BitFieldType, BitFieldSubCommands.Offset) - Static method in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldGet
- 
Creates a newBitFieldSubCommands.BitFieldGet.
- create(BitFieldSubCommands.BitFieldType, BitFieldSubCommands.Offset, long) - Static method in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldIncrBy
- 
Creates a newBitFieldSubCommands.BitFieldIncrBy.
- create(BitFieldSubCommands.BitFieldType, BitFieldSubCommands.Offset, long) - Static method in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldSet
- 
Creates a newBitFieldSubCommands.BitFieldSet.
- create(BitFieldSubCommands.BitFieldType, BitFieldSubCommands.Offset, long, BitFieldSubCommands.BitFieldIncrBy.Overflow) - Static method in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldIncrBy
- 
Creates a newBitFieldSubCommands.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 newStreamReceivergivenReactiveRedisConnectionFactoryandStreamReceiver.StreamReceiverOptions.
- create(RedisConnectionFactory) - Static method in class org.springframework.data.redis.cache.RedisCacheManager
- 
Factory method used to construct a newRedisCacheManagerusing the givenRedisConnectionFactorywith caching defaults applied.
- 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, uncappedDefaultRedisListinstance.
- create(BoundListOperations<String, E>, int) - Static method in interface org.springframework.data.redis.support.collections.RedisList
- 
Constructs a newDefaultRedisListinstance.
- 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 aRedisCredentialsProviderfor 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
- createFlux(ReactiveRedisCallback<T>) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
- 
Create a reusable Flux for aReactiveRedisCallback.
- 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 thelatest offset.
- createGroup(K, String) - Method in interface org.springframework.data.redis.core.StreamOperations
- 
Create a consumer group at thelatest 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 aReactiveRedisCallback.
- 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 aRedisConfigurationbased on aRedisURIaccording to the following: IfRedisURIcontains sentinels, aRedisSentinelConfigurationis returned IfRedisURIhas a configured socket aRedisSocketConfigurationis returned Otherwise aRedisStandaloneConfigurationis returned
- createRedisConfiguration(String) - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
- 
Creates aRedisConfigurationbased on aURIaccording to the following: IfredisUricontains sentinels, aRedisSentinelConfigurationis returned IfredisUrihas a configured socket aRedisSocketConfigurationis returned Otherwise aRedisStandaloneConfigurationis 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
- 
CreatesJedisPool.
- createRedisSentinelPool(RedisSentinelConfiguration) - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
- 
CreatesJedisSentinelPool.
- 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 aRedisCredentialsProviderfor 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 aClusterTopologyProvidergivenJedisCluster.
- 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 aSCANcommand.
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 ofRedisCommandsProvider.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 ofRedisCommandsProvider.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 anotherRedisConnection.
- 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 ofRedisCommandsProvider.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 ofkeyby 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 ofkeyby 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 newReactiveNumberCommands.DecrByCommandgiven 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 ofRedisCommandsProvider.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 ofkeybyvalue.
- 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 ofkeybyvalue.
- 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 bydelta.
- decrement(K) - Method in interface org.springframework.data.redis.core.ReactiveValueOperations
- 
Decrements the number stored atkeyby one.
- decrement(K) - Method in interface org.springframework.data.redis.core.ValueOperations
- 
Decrement an integer value stored as string value underkeyby one.
- decrement(K, long) - Method in interface org.springframework.data.redis.core.ReactiveValueOperations
- 
Decrements the number stored atkeybydelta.
- decrement(K, long) - Method in interface org.springframework.data.redis.core.ValueOperations
- 
Decrement an integer value stored as string value underkeybydelta.
- 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 theRedisKeyValueAdapter.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_RECOVERY_INTERVAL - Static variable in class org.springframework.data.redis.listener.RedisMessageListenerContainer
- 
The default recovery interval: 5000 ms = 5 seconds.
- DEFAULT_SUBSCRIPTION_REGISTRATION_WAIT_TIME - Static variable in class org.springframework.data.redis.listener.RedisMessageListenerContainer
- 
The default subscription wait time: 2000 ms = 2 seconds.
- DEFAULT_THREAD_NAME_PREFIX - Static variable in class org.springframework.data.redis.listener.RedisMessageListenerContainer
- 
Default thread name prefix: "RedisListeningContainer-".
- DEFAULT_TYPE_HINTS - Static variable in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoObject
- DEFAULT_TYPE_KEY - Static variable in class org.springframework.data.redis.core.convert.DefaultRedisTypeMapper
- DEFAULT_USE_PREFIX - Static variable in class org.springframework.data.redis.cache.RedisCacheConfiguration
- defaultCacheConfig() - Static method in class org.springframework.data.redis.cache.RedisCacheConfiguration
- 
DefaultRedisCacheConfigurationusing the following: key expiration eternal cache null values yes prefix cache keys yes default prefix [the actual cache name] key serializerStringRedisSerializervalue serializerJdkSerializationRedisSerializerconversion serviceDefaultFormattingConversionServicewithdefaultcache key converters
- defaultCacheConfig(ClassLoader) - Static method in class org.springframework.data.redis.cache.RedisCacheConfiguration
- 
Create defaultRedisCacheConfigurationgivenClassLoaderusing the following: key expiration eternal cache null values yes prefix cache keys yes default prefix [the actual cache name] key serializerStringRedisSerializervalue serializerJdkSerializationRedisSerializerconversion serviceDefaultFormattingConversionServicewithdefaultcache key converters
- defaultConfiguration() - Static method in interface org.springframework.data.redis.connection.jedis.JedisClientConfiguration
- 
Creates a defaultJedisClientConfiguration.
- defaultConfiguration() - Static method in interface org.springframework.data.redis.connection.lettuce.LettuceClientConfiguration
- 
Creates a defaultLettuceClientConfigurationwith: SSL no Peer Verification yes Start TLS no Client OptionsClientOptionswith enabledTimeoutOptionsClient 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 defaultLettucePoolingClientConfigurationwith SSL no Peer Verification yes Start TLS no Client OptionsClientOptionswith enabledTimeoutOptionsClient 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 ofReactiveScriptExecutor.
- DefaultReactiveScriptExecutor(ReactiveRedisConnectionFactory, RedisSerializationContext<K, ?>) - Constructor for class org.springframework.data.redis.core.script.DefaultReactiveScriptExecutor
- 
Creates a newDefaultReactiveScriptExecutorgivenReactiveRedisConnectionFactoryandRedisSerializationContext.
- DefaultRedisList<E> - Class in org.springframework.data.redis.support.collections
- 
Default implementation forRedisList.
- DefaultRedisList(String, RedisOperations<String, E>) - Constructor for class org.springframework.data.redis.support.collections.DefaultRedisList
- 
Constructs a new, uncappedDefaultRedisListinstance.
- DefaultRedisList(String, RedisOperations<String, E>, int) - Constructor for class org.springframework.data.redis.support.collections.DefaultRedisList
- 
Constructs a newDefaultRedisListinstance.
- DefaultRedisList(BoundListOperations<String, E>) - Constructor for class org.springframework.data.redis.support.collections.DefaultRedisList
- 
Constructs a new, uncappedDefaultRedisListinstance.
- DefaultRedisList(BoundListOperations<String, E>, int) - Constructor for class org.springframework.data.redis.support.collections.DefaultRedisList
- 
Constructs a newDefaultRedisListinstance.
- DefaultRedisMap<K,V> - Class in org.springframework.data.redis.support.collections 
- 
Default implementation forRedisMap.
- DefaultRedisMap(String, RedisOperations<String, ?>) - Constructor for class org.springframework.data.redis.support.collections.DefaultRedisMap
- 
Constructs a newDefaultRedisMapinstance.
- DefaultRedisMap(BoundHashOperations<String, K, V>) - Constructor for class org.springframework.data.redis.support.collections.DefaultRedisMap
- 
Constructs a newDefaultRedisMapinstance.
- DefaultRedisScript<T> - Class in org.springframework.data.redis.core.script
- 
Default implementation ofRedisScript.
- DefaultRedisScript() - Constructor for class org.springframework.data.redis.core.script.DefaultRedisScript
- 
Creates a newDefaultRedisScript
- DefaultRedisScript(String) - Constructor for class org.springframework.data.redis.core.script.DefaultRedisScript
- 
Creates a newDefaultRedisScript
- DefaultRedisScript(String, Class<T>) - Constructor for class org.springframework.data.redis.core.script.DefaultRedisScript
- 
Creates a newDefaultRedisScript
- DefaultRedisSet<E> - Class in org.springframework.data.redis.support.collections
- 
Default implementation forRedisSet.
- DefaultRedisSet(String, RedisOperations<String, E>) - Constructor for class org.springframework.data.redis.support.collections.DefaultRedisSet
- 
Constructs a newDefaultRedisSetinstance.
- DefaultRedisSet(BoundSetOperations<String, E>) - Constructor for class org.springframework.data.redis.support.collections.DefaultRedisSet
- 
Constructs a newDefaultRedisSetinstance.
- DefaultRedisTypeMapper - Class in org.springframework.data.redis.core.convert
- 
Default implementation ofRedisTypeMapperallowing configuration of the key to lookup and store type information viaBucket.BucketPropertyPathin buckets.
- DefaultRedisTypeMapper() - Constructor for class org.springframework.data.redis.core.convert.DefaultRedisTypeMapper
- 
Create a newDefaultRedisTypeMapperusingDefaultRedisTypeMapper.DEFAULT_TYPE_KEYto exchange type hints.
- DefaultRedisTypeMapper(String) - Constructor for class org.springframework.data.redis.core.convert.DefaultRedisTypeMapper
- 
Create a newDefaultRedisTypeMappergiventypeKeyto exchange type hints.
- DefaultRedisTypeMapper(String, List<? extends TypeInformationMapper>) - Constructor for class org.springframework.data.redis.core.convert.DefaultRedisTypeMapper
- 
Create a newDefaultRedisTypeMappergiventypeKeyto exchange type hints andListofTypeInformationMapper.
- 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 forRedisZSet.
- DefaultRedisZSet(String, RedisOperations<String, E>) - Constructor for class org.springframework.data.redis.support.collections.DefaultRedisZSet
- 
Constructs a newDefaultRedisZSetinstance with a default score of 1.
- DefaultRedisZSet(String, RedisOperations<String, E>, double) - Constructor for class org.springframework.data.redis.support.collections.DefaultRedisZSet
- 
Constructs a newDefaultRedisZSetinstance.
- DefaultRedisZSet(BoundZSetOperations<String, E>) - Constructor for class org.springframework.data.redis.support.collections.DefaultRedisZSet
- 
Constructs a newDefaultRedisZSetinstance with a default score of '1'.
- DefaultRedisZSet(BoundZSetOperations<String, E>, double) - Constructor for class org.springframework.data.redis.support.collections.DefaultRedisZSet
- 
Constructs a newDefaultRedisZSetinstance.
- DefaultScriptExecutor<K> - Class in org.springframework.data.redis.core.script
- 
Default implementation ofScriptExecutor.
- DefaultScriptExecutor(RedisTemplate<K, ?>) - Constructor for class org.springframework.data.redis.core.script.DefaultScriptExecutor
- DefaultSortParameters - Class in org.springframework.data.redis.connection
- 
Default implementation forSortParameters.
- DefaultSortParameters() - Constructor for class org.springframework.data.redis.connection.DefaultSortParameters
- 
Constructs a newDefaultSortParametersinstance.
- DefaultSortParameters(byte[], SortParameters.Range, byte[][], SortParameters.Order, Boolean) - Constructor for class org.springframework.data.redis.connection.DefaultSortParameters
- 
Constructs a newDefaultSortParametersinstance.
- DefaultSortParameters(SortParameters.Range, SortParameters.Order, Boolean) - Constructor for class org.springframework.data.redis.connection.DefaultSortParameters
- 
Constructs a newDefaultSortParametersinstance.
- DefaultStringRedisConnection - Class in org.springframework.data.redis.connection
- 
Default implementation ofStringRedisConnection.
- DefaultStringRedisConnection(RedisConnection) - Constructor for class org.springframework.data.redis.connection.DefaultStringRedisConnection
- 
Constructs a newDefaultStringRedisConnectioninstance.
- DefaultStringRedisConnection(RedisConnection, RedisSerializer<String>) - Constructor for class org.springframework.data.redis.connection.DefaultStringRedisConnection
- 
Constructs a newDefaultStringRedisConnectioninstance.
- DefaultStringTuple - Class in org.springframework.data.redis.connection
- 
Default implementation forStringRedisConnection.StringTupleinterface.
- DefaultStringTuple(byte[], String, Double) - Constructor for class org.springframework.data.redis.connection.DefaultStringTuple
- 
Constructs a newDefaultStringTupleinstance.
- DefaultStringTuple(String, double) - Constructor for class org.springframework.data.redis.connection.DefaultStringTuple
- 
Constructs a newDefaultStringTupleinstance.
- DefaultStringTuple(Tuple, String) - Constructor for class org.springframework.data.redis.connection.DefaultStringTuple
- 
Constructs a newDefaultStringTupleinstance.
- DefaultTuple - Class in org.springframework.data.redis.connection.zset
- 
Default implementation forTupleinterface.
- DefaultTuple(byte[], Double) - Constructor for class org.springframework.data.redis.connection.zset.DefaultTuple
- 
Constructs a newDefaultTupleinstance.
- 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 newDefaultTypedTupleinstance.
- del(byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.keyCommands().
- del(byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- del(byte[]...) - Method in interface org.springframework.data.redis.connection.RedisKeyCommands
- 
Delete givenkeys.
- 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 givenkeys.
- 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 hashhashKeys.
- delete(Object...) - Method in interface org.springframework.data.redis.core.BoundHashOperations
- 
Delete given hashkeysat 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 givenkeys.
- 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 givenkey.
- delete(K) - Method in class org.springframework.data.redis.core.RedisTemplate
- delete(K...) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
- 
Delete givenkey.
- 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 givenkeys.
- 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 givenRecordfrom the stream.
- delete(Record<K, ?>) - Method in interface org.springframework.data.redis.core.StreamOperations
- 
Removes a givenRecordfrom 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
- 
Deserializekeywith 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
- 
Deserializekeywith 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 actualcache value.
- deserializeRecord(ByteBufferRecord) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
- 
Deserialize aByteBufferRecordusing the configured serialization context into aMapRecord.
- deserializeRecord(ByteRecord) - Method in interface org.springframework.data.redis.core.StreamOperations
- 
Deserialize aByteRecordusing 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
- 
Convertercapable 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 otherRedisSets.
- 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 otherRedisZSets.
- diff(Collection<K>) - Method in interface org.springframework.data.redis.core.BoundSetOperations
- 
Deprecated.since 3.0, useBoundSetOperations.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, useBoundSetOperations.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 anotherRedisSet.
- 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 anotherRedisZSet.
- 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, useBoundSetOperations.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, useBoundSetOperations.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 andkeys.
- difference(Collection<K>) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
- 
Diff sortedsets.
- difference(Collection<K>) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
- 
Diff all sets for givenkeys.
- difference(Collection<K>) - Method in interface org.springframework.data.redis.core.SetOperations
- 
Diff all sets for givenkeys.
- difference(K) - Method in interface org.springframework.data.redis.core.BoundSetOperations
- 
Diff all sets for given the bound key andkey.
- difference(K) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
- 
Diff sortedsets.
- difference(K, Collection<K>) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
- 
Diff all sets for givenkeyandotherKeys.
- difference(K, Collection<K>) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- 
Diff sortedsets.
- difference(K, Collection<K>) - Method in interface org.springframework.data.redis.core.SetOperations
- 
Diff all sets for givenkeyandotherKeys.
- difference(K, Collection<K>) - Method in interface org.springframework.data.redis.core.ZSetOperations
- 
Diff sortedsets.
- difference(K, K) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
- 
Diff all sets for givenkeyandotherKey.
- difference(K, K) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- 
Diff sortedsets.
- difference(K, K) - Method in interface org.springframework.data.redis.core.SetOperations
- 
Diff all sets for givenkeyandotherKey.
- difference(K, K) - Method in interface org.springframework.data.redis.core.ZSetOperations
- 
Diff sortedsets.
- differenceAndStore(Collection<K>, K) - Method in interface org.springframework.data.redis.core.BoundSetOperations
- 
Diff all sets for given the bound key andkeysand store result indestKey.
- differenceAndStore(Collection<K>, K) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
- 
Diff sortedsetsand store result in destinationdestKey.
- differenceAndStore(Collection<K>, K) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
- 
Diff all sets for givenkeysand store result indestKey.
- differenceAndStore(Collection<K>, K) - Method in interface org.springframework.data.redis.core.SetOperations
- 
Diff all sets for givenkeysand store result indestKey.
- differenceAndStore(K, Collection<K>, K) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
- 
Diff all sets for givenkeyandotherKeysand store result indestKey.
- differenceAndStore(K, Collection<K>, K) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- 
Diff sortedsetsand store result in destinationdestKey.
- differenceAndStore(K, Collection<K>, K) - Method in interface org.springframework.data.redis.core.SetOperations
- 
Diff all sets for givenkeyandotherKeysand store result indestKey.
- differenceAndStore(K, Collection<K>, K) - Method in interface org.springframework.data.redis.core.ZSetOperations
- 
Diff sortedsetsand store result in destinationdestKey.
- differenceAndStore(K, K) - Method in interface org.springframework.data.redis.core.BoundSetOperations
- 
Diff all sets for given the bound key andkeysand store result indestKey.
- differenceAndStore(K, K) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
- 
Diff sortedsetsand store result in destinationdestKey.
- differenceAndStore(K, K, K) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
- 
Diff all sets for givenkeyandotherKeyand store result indestKey.
- differenceAndStore(K, K, K) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- 
Diff sortedsetsand store result in destinationdestKey.
- differenceAndStore(K, K, K) - Method in interface org.springframework.data.redis.core.SetOperations
- 
Diff all sets for givenkeyandotherKeyand store result indestKey.
- differenceWithScores(Collection<K>) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
- 
Diff sortedsets.
- differenceWithScores(K) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
- 
Diff sortedsets.
- differenceWithScores(K, Collection<K>) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- 
Diff sortedsets.
- differenceWithScores(K, Collection<K>) - Method in interface org.springframework.data.redis.core.ZSetOperations
- 
Diff sortedsets.
- differenceWithScores(K, K) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- 
Diff sortedsets.
- differenceWithScores(K, K) - Method in interface org.springframework.data.redis.core.ZSetOperations
- 
Diff sortedsets.
- 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 otherRedisZSets.
- 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 anotherRedisZSet.
- DigestUtils - Class in org.springframework.data.redis.core.script
- 
Utilties for working withMessageDigest
- 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
- 
DisableRedisCachecreation at runtime for unconfigured, 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 afterRedisTxCommands.multi().
- discard() - Method in interface org.springframework.data.redis.core.RedisOperations
- 
Discard all commands issued afterRedisOperations.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 theDistancebetween member1 and member2.
- distance(K, M, M) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
- 
Get theDistancebetween member1 and member2.
- distance(K, M, M, Metric) - Method in interface org.springframework.data.redis.core.GeoOperations
- 
Get theDistancebetween member1 and member2 in the givenMetric.
- distance(K, M, M, Metric) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
- 
Get theDistancebetween member1 and member2 in the givenMetric.
- distance(M, M) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
- 
Get theDistancebetween member1 and member2.
- distance(M, M, Metric) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
- 
Get theDistancebetween member1 and member2 in the givenMetric.
- distanceConverterForMetric(Metric) - Static method in class org.springframework.data.redis.connection.convert.Converters
- 
Convertercapable of converting Double intoDistanceusing givenMetric.
- distinctRandomMembers(long) - Method in interface org.springframework.data.redis.core.BoundSetOperations
- 
Getcountdistinct random elements from set at the bound key.
- distinctRandomMembers(long) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
- 
Getcountdistinct random elements from set at the bound key.
- distinctRandomMembers(K, long) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
- 
Getcountdistinct random elements from set atkey.
- distinctRandomMembers(K, long) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- 
Getcountdistinct random elements from set atkey.
- distinctRandomMembers(K, long) - Method in interface org.springframework.data.redis.core.SetOperations
- 
Getcountdistinct random elements from set atkey.
- distinctRandomMembers(K, long) - Method in interface org.springframework.data.redis.core.ZSetOperations
- 
Getcountdistinct random elements from set atkey.
- distinctRandomMembersWithScore(long) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
- 
Getcountdistinct random elements with their score from set at the bound key.
- distinctRandomMembersWithScore(K, long) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- 
Getcountdistinct random elements with their score from set atkey.
- distinctRandomMembersWithScore(K, long) - Method in interface org.springframework.data.redis.core.ZSetOperations
- 
Getcountdistinct 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 callingScanCursor.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 forLettuceClusterConnectioncreation.
- doCreateLettuceConnection(StatefulRedisConnection<byte[], byte[]>, LettuceConnectionProvider, long, int) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
- 
Customization hook forLettuceConnectioncreation.
- doCreateSubscription(MessageListener, StatefulRedisPubSubConnection<byte[], byte[]>, LettuceConnectionProvider) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
- 
Customization hook to create aLettuceSubscription.
- 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 aRedisConnectionfrom 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 byReactiveRedisTemplate.execute(ReactiveRedisCallback)with an active Redis connection.
- doInRedis(RedisClusterConnection) - Method in interface org.springframework.data.redis.core.RedisClusterCallback
- 
Gets called byClusterOperationswith an active Redis connection.
- doInRedis(RedisConnection) - Method in interface org.springframework.data.redis.core.RedisCallback
- 
Method called byRedisTemplatewith 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
- 
Customization hook when callingScanCursor.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[], long, 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
- 
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 byReactiveRedisOperations.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 ofRedisCommandsProvider.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 atkey.
- dump(K) - Method in interface org.springframework.data.redis.core.RedisOperations
- 
Retrieve serialized version of the value stored atkey.
- 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
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
- 
Returnsmessagevia server roundtrip.
- echo(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- echo(String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
- 
Returnsmessagevia 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 newReactiveListCommands.LIndexCommandgiven an index.
- elementAt(long) - Static method in class org.springframework.data.redis.connection.ReactiveListCommands.LSetCommand
- 
Creates a newReactiveListCommands.LSetCommandgiven 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, emptyRedisClusterNode.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 emptyStreamReadOptionsinstance.
- enableCreateOnMissingCache() - Method in class org.springframework.data.redis.cache.RedisCacheManager.RedisCacheManagerBuilder
- 
EnablesRedisCachecreation at runtime for unconfigured, undeclared caches.
- enableKeyspaceEvents() - Element in annotation interface org.springframework.data.redis.repository.configuration.EnableRedisRepositories
- 
Configure usage ofKeyExpirationEventMessageListener.
- 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.
- 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 ofRedisCommandsProvider.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 givenkey.
- 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 givenkey.
- encodingOf(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
- 
Get the type of internal representation used for storing the value at the givenkey.
- 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 atkey.
- entries(H) - Method in interface org.springframework.data.redis.core.ReactiveHashOperations
- 
Get entire hash stored atkey.
- 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.
- 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.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.DefaultTypedTuple
- equals(Object) - Method in class org.springframework.data.redis.core.index.IndexDefinition.IndexingContext
- equals(Object) - Method in class org.springframework.data.redis.core.index.RedisIndexDefinition
- equals(Object) - Method in class org.springframework.data.redis.core.index.SpelIndexDefinition
- equals(Object) - Method in class org.springframework.data.redis.core.types.RedisClientInfo
- equals(Object) - Method in class org.springframework.data.redis.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.PatternTopic
- equals(Object) - Method in class org.springframework.data.redis.repository.query.RedisOperationChain.PathAndValue
- equals(Object) - Method in class org.springframework.data.redis.support.collections.AbstractRedisCollection
- equals(Object) - Method in class org.springframework.data.redis.support.collections.DefaultRedisMap
- equals(Object) - Method in class org.springframework.data.redis.support.collections.RedisProperties
- errorHandler(ErrorHandler) - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.ConsumerStreamReadRequestBuilder
- 
Configure aErrorHandlerto be notified onread, deserialization, and listener errors.
- errorHandler(ErrorHandler) - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamMessageListenerContainerOptionsBuilder
- 
Configure aErrorHandlerto be notified onerrors.
- errorHandler(ErrorHandler) - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamReadRequestBuilder
- 
Configure aErrorHandlerto be notified onerrors.
- eval(byte[], ReturnType, int, byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 givenscript.
- 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 givenscript.
- eval(ByteBuffer, ReturnType, int, ByteBuffer...) - Method in interface org.springframework.data.redis.connection.ReactiveScriptingCommands
- 
Evaluate givenscript.
- 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 ofRedisCommandsProvider.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 givenscriptSha.
- evalSha(String, ReturnType, int, byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 givenscriptSha.
- 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 givenscriptSha.
- evalSha(String, ReturnType, int, ByteBuffer...) - Method in interface org.springframework.data.redis.connection.ReactiveScriptingCommands
- 
Evaluate givenscriptSha.
- 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 anExceptioninto 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 withRedisTxCommands.multi().
- exec() - Method in interface org.springframework.data.redis.core.RedisOperations
- 
Executes all queued commands in a transaction started withRedisOperations.multi().
- exec() - Method in class org.springframework.data.redis.core.RedisTemplate
- 
Execute a transaction, using the defaultRedisSerializers 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 providedRedisSerializerto 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(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 thekeyprovided 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 inkeysprovided appending allargson 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
- 
ExecuteRedisCallbackvia 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 givenRedisScript.
- execute(RedisScript<T>) - Method in interface org.springframework.data.redis.core.script.ReactiveScriptExecutor
- 
Execute the givenRedisScript
- execute(RedisScript<T>, List<K>) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
- 
Executes the givenRedisScript.
- execute(RedisScript<T>, List<K>) - Method in interface org.springframework.data.redis.core.script.ReactiveScriptExecutor
- 
Execute the givenRedisScript
- execute(RedisScript<T>, List<K>, Object...) - Method in interface org.springframework.data.redis.core.RedisOperations
- 
Executes the givenRedisScript
- 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.ScriptExecutor
- 
Executes the givenRedisScript
- execute(RedisScript<T>, List<K>, List<?>) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
- 
Executes the givenRedisScript
- 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 givenRedisScript
- execute(RedisScript<T>, List<K>, List<?>, RedisElementWriter<?>, RedisElementReader<T>) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
- 
Executes the givenRedisScript, using the providedRedisSerializers 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 givenRedisScript, using the providedRedisSerializers 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 givenRedisScript, using the providedRedisSerializers 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 givenRedisScript, using the providedRedisSerializers 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
- 
RunClusterCommandExecutor.ClusterCommandCallbackon all reachable master nodes.
- executeCommandOnArbitraryNode(ClusterCommandExecutor.ClusterCommandCallback<?, T>) - Method in class org.springframework.data.redis.connection.ClusterCommandExecutor
- 
RunClusterCommandExecutor.ClusterCommandCallbackon 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 sameReactiveRedisConnection.
- 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
- 
RunClusterCommandExecutor.MultiKeyClusterCommandCallbackwith 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 newRedisConnectionto 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 ofRedisCommandsProvider.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 givenkeyexists.
- exists(byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 givenkeysexist.
- exists(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- exists(String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
- 
Determine if givenkeyexists.
- 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 givenkeysexist.
- 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 holds a value with its associatedTimeUnit.
- Expiration(long, TimeUnit) - Constructor for class org.springframework.data.redis.core.types.Expiration
- 
Creates newExpiration.
- expire(byte[], long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 givenkeyin 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 givenkeyin seconds.
- expire(ByteBuffer, Duration) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
- 
Set time to live for givenkeyin 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 givenkey.
- 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 givenkey.
- 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 givenkey.
- 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 ofRedisCommandsProvider.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 givenkeyas 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 givenkeyas a UNIX timestamp.
- expireAt(ByteBuffer, Instant) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
- 
Set the expiration for givenkeyas 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 givenkeyas 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 givenkeyas a date timestamp.
- expireAt(K, Date) - Method in interface org.springframework.data.redis.core.RedisOperations
- 
Set the expiration for givenkeyas 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 givenkeyas 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
- 
AppliesExpiration.
- extract(String) - Method in class org.springframework.data.redis.core.convert.Bucket
- 
Extracts a bucket containing key/value pairs with theprefix.
- extractAllKeysFor(String) - Method in class org.springframework.data.redis.core.convert.Bucket
- 
Get all the keys matching a given path.
- extractBytes(ByteBuffer) - Static method in class org.springframework.data.redis.util.ByteUtils
- 
Extract/Transfer bytes from the givenByteBufferinto an array by duplicating the buffer and fetching its content.
- extractMessage(Message) - Method in class org.springframework.data.redis.listener.adapter.MessageListenerAdapter
- 
Extract the message body from the given Redis message.
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 givenkey, otherwise returnsRedisCommand.UNKNOWNif 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 newReactiveGeoCommands.GeoDistCommandforRedisGeoCommands.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 newReactiveHashCommands.HDelCommandgiven afield name.
- field(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveHashCommands.HExistsCommand
- 
Creates a newReactiveHashCommands.HExistsCommandgiven afield name.
- field(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveHashCommands.HGetCommand
- 
Creates a newReactiveHashCommands.HGetCommandgiven afield name.
- fields(Collection<ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveHashCommands.HDelCommand
- 
Creates a newReactiveHashCommands.HDelCommandgiven aCollectionof field names.
- fields(Collection<ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveHashCommands.HGetCommand
- 
Creates a newReactiveHashCommands.HGetCommandgiven aCollectionof field names.
- fieldValues(Map<ByteBuffer, ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveHashCommands.HSetCommand
- 
Creates a newReactiveHashCommands.HSetCommandgiven aMapof 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 forReactiveListCommands.Direction.LEFT.
- first() - Static method in enum class org.springframework.data.redis.connection.RedisListCommands.Direction
- 
Alias forRedisListCommands.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 newReactiveListCommands.LRemCommandto first count values.
- firstEntryId() - Method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoStream
- 
The id of the streams first entry.
- 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 ofRedisCommandsProvider.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 ofRedisCommandsProvider.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 ofRedisCommandsProvider.serverCommands().
- flushAll(RedisClusterNode, RedisServerCommands.FlushOption) - Method in interface org.springframework.data.redis.connection.ReactiveClusterServerCommands
- 
Delete all all keys from all databases using the specifiedRedisServerCommands.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 ofRedisCommandsProvider.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 specifiedRedisServerCommands.FlushOption.
- flushAll(RedisServerCommands.FlushOption) - Method in interface org.springframework.data.redis.connection.RedisServerCommands
- 
Delete all all keys from all databases using the specifiedRedisServerCommands.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 ofRedisCommandsProvider.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 ofRedisCommandsProvider.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 ofRedisCommandsProvider.serverCommands().
- flushDb(RedisClusterNode, RedisServerCommands.FlushOption) - Method in interface org.springframework.data.redis.connection.ReactiveClusterServerCommands
- 
Delete all keys of the currently selected database using the specifiedRedisServerCommands.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 specifiedRedisServerCommands.FlushOption.
- flushDb(RedisServerCommands.FlushOption) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 specifiedRedisServerCommands.FlushOption.
- flushDb(RedisServerCommands.FlushOption) - Method in interface org.springframework.data.redis.connection.RedisServerCommands
- 
Delete all keys of the currently selected database using the specifiedRedisServerCommands.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 ifLettuceConnection.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 availableStreamInfo.XInfoConsumerof thisStreamInfo.XInfoConsumers.
- forEach(Consumer<? super StreamInfo.XInfoGroup>) - Method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoGroups
- 
Performs the given action on every availableStreamInfo.XInfoGroupof 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 newExpirationwith the providedTimeUnit.
- from(String) - Static method in class org.springframework.data.redis.connection.stream.ReadOffset
- 
Read all arriving elements from the stream starting atoffset.
- 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 thekeythe hash is stored at.
- from(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveListCommands.BRPopLPushCommand
- 
Creates a newReactiveListCommands.BRPopLPushCommandgiven 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 newReactiveListCommands.RPopLPushCommandgiven 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 newReactiveListCommands.LMoveCommandgiven asourceKey.
- from(Duration) - Static method in class org.springframework.data.redis.core.types.Expiration
- 
Creates newExpirationwith the providedDuration.
- 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 centerPoint.
- 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 atRecordId.
- from(StreamOffset<ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveStreamCommands.ReadCommand
- 
Creates a newReactiveStreamCommands.ReadCommandgiven aStreamOffset.
- from(StreamOffset<ByteBuffer>...) - Static method in class org.springframework.data.redis.connection.ReactiveStreamCommands.ReadCommand
- 
Creates a newReactiveStreamCommands.ReadCommandgiven aStreamOffsets.
- from(Bucket) - Static method in class org.springframework.data.redis.core.convert.Bucket.BucketPropertyPath
- 
Creates a top-levelBucket.BucketPropertyPathgivenBucket.
- 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 newRedisElementReaderusing givenRedisSerializer.
- from(RedisSerializer<T>) - Static method in interface org.springframework.data.redis.serializer.RedisElementWriter
- 
Create newRedisElementWriterusing 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 underlyingConversionService.
- fromCacheWriter(RedisCacheWriter) - Static method in class org.springframework.data.redis.cache.RedisCacheManager.RedisCacheManagerBuilder
- 
Factory method returning a new Builder used to create and configure aRedisCacheManagerusing the givenRedisCacheWriter.
- fromCircle(Circle) - Static method in interface org.springframework.data.redis.domain.geo.GeoReference
- 
Creates aGeoReferencefrom 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 aRedisCacheManagerusing the givenRedisConnectionFactory.
- fromCoordinate(double, double) - Static method in interface org.springframework.data.redis.domain.geo.GeoReference
- 
Creates aGeoReferencefrom a WGS84 longitude/latitude coordinate.
- fromCoordinate(Point) - Static method in interface org.springframework.data.redis.domain.geo.GeoReference
- 
Creates aGeoReferencefrom a WGS84 longitude/latitude coordinate.
- fromCoordinate(RedisGeoCommands.GeoLocation<?>) - Static method in interface org.springframework.data.redis.domain.geo.GeoReference
- 
Creates aGeoReferencefrom 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 ahash(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 ahash(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 theRange.
- 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 ofStreamInfo.XInfoGroups.
- fromList(List<Object>) - Static method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoStream
- 
Factory method to create a new instance ofStreamInfo.XInfoStream.
- fromMember(RedisGeoCommands.GeoLocation<T>) - Static method in interface org.springframework.data.redis.domain.geo.GeoReference
- 
Creates aGeoReferencefrom ageoset member.
- fromMember(T) - Static method in interface org.springframework.data.redis.domain.geo.GeoReference
- 
Creates aGeoReferencefrom a geoset member.
- fromSerializer(RedisSerializer<T>) - Static method in interface org.springframework.data.redis.serializer.RedisSerializationContext
- 
Creates a newRedisSerializationContextusing the givenRedisSerializer.
- fromSerializer(RedisSerializer<T>) - Static method in interface org.springframework.data.redis.serializer.RedisSerializationContext.SerializationPair
- 
Creates aRedisSerializationContext.SerializationPairadapter givenRedisSerializer.
- fromSetCount(int) - Static method in class org.springframework.data.redis.connection.zset.Weights
- 
Creates equalWeightsfor a number of input setscountwith 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 ahostAndPortstring intoRedisNode.
- fromString(String) - Static method in class org.springframework.data.redis.core.types.RedisClientInfo.RedisClientInfoBuilder
- 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 newFutureResultfor given object actually holding the result itself.
- FutureResult(T, Converter) - Constructor for class org.springframework.data.redis.connection.FutureResult
- 
Create newFutureResultfor 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 newFutureResultfor 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-basedRedisSerializerthat mapsobjectsto JSON using dynamic typing.
- GenericJackson2JsonRedisSerializer() - Constructor for class org.springframework.data.redis.serializer.GenericJackson2JsonRedisSerializer
- 
CreatesGenericJackson2JsonRedisSerializerand configuresObjectMapperfor default typing.
- GenericJackson2JsonRedisSerializer(ObjectMapper) - Constructor for class org.springframework.data.redis.serializer.GenericJackson2JsonRedisSerializer
- 
Setting a custom-configuredObjectMapperis 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-configuredObjectMapperis one way to take further control of the JSON serialization process.
- GenericJackson2JsonRedisSerializer(String) - Constructor for class org.springframework.data.redis.serializer.GenericJackson2JsonRedisSerializer
- 
CreatesGenericJackson2JsonRedisSerializerand configuresObjectMapperfor default typing using the given name.
- GenericJackson2JsonRedisSerializer(String, JacksonObjectReader, JacksonObjectWriter) - Constructor for class org.springframework.data.redis.serializer.GenericJackson2JsonRedisSerializer
- 
CreatesGenericJackson2JsonRedisSerializerand configuresObjectMapperfor default typing using the given name.
- 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 ofRedisCommandsProvider.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
- 
AddRedisGeoCommands.GeoLocations to key
- geoAdd(byte[], Map<byte[], Point>) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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
- 
AddMapof member /Pointpairs to key.
- geoAdd(byte[], Point, byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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
- 
AddPointwith 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
- 
AddRedisGeoCommands.GeoLocationto 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
- 
AddRedisGeoCommands.GeoLocations 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
- 
AddMapof member /Pointpairs to key.
- 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
- 
AddPointwith 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
- 
AddRedisGeoCommands.GeoLocationto key.
- geoAdd(ByteBuffer, Collection<RedisGeoCommands.GeoLocation<ByteBuffer>>) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
- 
AddRedisGeoCommands.GeoLocationto key.
- geoAdd(ByteBuffer, Point, ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
- 
AddPointwith given member to key.
- geoAdd(ByteBuffer, RedisGeoCommands.GeoLocation<ByteBuffer>) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
- 
AddRedisGeoCommands.GeoLocationto key.
- geoAdd(Publisher<ReactiveGeoCommands.GeoAddCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
- 
AddRedisGeoCommands.GeoLocations 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
- 
GetRedisGeoCommands.
- 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 ofRedisCommandsProvider.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 theDistancebetween member1 and member2.
- geoDist(byte[], byte[], byte[], Metric) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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
- 
Get theDistancebetween member1 and member2 in the givenMetric.
- 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 theDistancebetween 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
- 
Get theDistancebetween member1 and member2 in the givenMetric.
- geoDist(ByteBuffer, ByteBuffer, ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
- 
Get theDistancebetween from and to.
- geoDist(ByteBuffer, ByteBuffer, ByteBuffer, Metric) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
- 
Get theDistancebetween from and to.
- geoDist(Publisher<ReactiveGeoCommands.GeoDistCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
- 
Get theDistancebetween 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 ofRedisCommandsProvider.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 newGeoIndexDefinition.
- GeoIndexDefinition(String, String, String) - Constructor for class org.springframework.data.redis.core.index.GeoIndexDefinition
- 
Creates newGeoIndexDefinition.
- 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
- 
IndexedDataimplementation 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 ofRedisCommandsProvider.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 thePointrepresentation 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 thePointrepresentation of positions for one or more members.
- geoPos(ByteBuffer, ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
- 
Get thePointrepresentation of positions for the members.
- geoPos(ByteBuffer, Collection<ByteBuffer>) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
- 
Get thePointrepresentation of positions for one or more members.
- geoPos(Publisher<ReactiveGeoCommands.GeoPosCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
- 
Get thePointrepresentation 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 ofRedisCommandsProvider.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 givenCircle.
- geoRadius(byte[], Circle, RedisGeoCommands.GeoRadiusCommandArgs) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 givenCircleapplyingRedisGeoCommands.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 givenCircle.
- 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 givenCircleapplyingRedisGeoCommands.GeoRadiusCommandArgs.
- geoRadius(ByteBuffer, Circle) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
- 
Get the members within the boundaries of a givenCircle.
- geoRadius(ByteBuffer, Circle, RedisGeoCommands.GeoRadiusCommandArgs) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
- 
Get the members within the boundaries of a givenCircleapplying given parameters.
- geoRadius(Publisher<ReactiveGeoCommands.GeoRadiusCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
- 
Get the members within the boundaries of a givenCircleapplying 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 ofRedisCommandsProvider.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 givenDistance.
- geoRadiusByMember(byte[], byte[], Distance, RedisGeoCommands.GeoRadiusCommandArgs) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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, givenDistanceandRedisGeoCommands.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 givenDistance.
- 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 givenDistanceandRedisGeoCommands.GeoRadiusCommandArgs.
- geoRadiusByMember(ByteBuffer, ByteBuffer, Distance) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
- 
Get the members within givenDistancefrom member applying given parameters.
- geoRadiusByMember(ByteBuffer, ByteBuffer, Distance, RedisGeoCommands.GeoRadiusCommandArgs) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
- 
Get the members within givenDistancefrom member applying given parameters.
- geoRadiusByMember(Publisher<ReactiveGeoCommands.GeoRadiusByMemberCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
- 
Get the members within givenDistancefrom 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
- 
GetConvertercapable of converingGeoWithinintoGeoResults.
- GeoReference<T> - Interface in org.springframework.data.redis.domain.geo
- 
Reference point forGEOSEARCHandGEOSEARCHSTOREcommands.
- 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 ofRedisCommandsProvider.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 ofRedisCommandsProvider.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 givenshape.
- 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 givenshape.
- 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 givenshape.
- geoSearch(Publisher<ReactiveGeoCommands.GeoSearchCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
- 
Get the members within givenGeoShapefromGeoReferenceapplying given parameters.
- geoSearchStore(byte[], byte[], GeoReference<byte[]>, GeoShape, RedisGeoCommands.GeoSearchStoreCommandArgs) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 givenshapeand 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 givenshapeand 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 givenshapeand store the result atdestKey.
- geoSearchStore(Publisher<ReactiveGeoCommands.GeoSearchStoreCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
- 
Store the members within givenGeoShapefromGeoReferenceapplying given parameters in a new geo set.
- GeoShape - Interface in org.springframework.data.redis.domain.geo
- 
Search predicate forGEOSEARCHandGEOSEARCHSTOREcommands.
- 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 ofRedisCommandsProvider.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 ofkey.
- get(int) - Method in class org.springframework.data.redis.connection.stream.PendingMessages
- 
Get thePendingMessageat the given position.
- get(int) - Method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoConsumers
- 
Returns theStreamInfo.XInfoConsumerelement at the given index.
- get(int) - Method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoGroups
- 
Returns theStreamInfo.XInfoGroupelement 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 betweenbeginandend.
- get(H, Object) - Method in interface org.springframework.data.redis.core.HashOperations
- 
Get value for givenhashKeyfrom hash atkey.
- get(H, Object) - Method in interface org.springframework.data.redis.core.ReactiveHashOperations
- 
Get value for givenhashKeyfrom hash atkey.
- get(Object) - Method in interface org.springframework.data.redis.core.BoundHashOperations
- 
Get value for givenkeyfrom the hash at the bound key.
- get(Object) - Method in interface org.springframework.data.redis.core.ReactiveValueOperations
- 
Get the value ofkey.
- get(Object) - Method in interface org.springframework.data.redis.core.ValueOperations
- 
Get the value ofkey.
- 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 ofkey.
- get(String) - Method in class org.springframework.data.redis.core.convert.Bucket.BucketPropertyPath
- 
Retrieve a value atkeyconsidering 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(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 ofkeybetweenbeginandend.
- get(K, long, long) - Method in interface org.springframework.data.redis.core.ValueOperations
- 
Get a substring of value ofkeybetweenbeginandend.
- 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 newBitFieldSubCommandsadding givenBitFieldSubCommands.BitFieldGetto the sub commands.
- get(BitFieldSubCommands.BitFieldType) - Method in class org.springframework.data.redis.connection.BitFieldSubCommands
- 
Obtain a newBitFieldSubCommands.BitFieldGetBuilderfor creating and adding aBitFieldSubCommands.BitFieldGetsub 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 wherelink-stateis connected andflagsdoes not contain fail or fail?.
- getActiveNodes() - Method in class org.springframework.data.redis.connection.ClusterTopology
- 
Get all nodes (master and replica) in cluster wherelink-stateis connected andflagsdoes not contain fail or fail?.
- getActiveSubscriptions() - Method in class org.springframework.data.redis.listener.ReactiveRedisMessageListenerContainer
- 
Return the currently activesubscriptions.
- 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 givenaccumulator function.
- getAndAccumulate(int, IntBinaryOperator) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicInteger
- 
Atomically update the current value using the givenaccumulator function.
- getAndAccumulate(long, LongBinaryOperator) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicLong
- 
Atomically update the current value using the givenaccumulator 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 atkeyand delete the key.
- getAndDelete(K) - Method in interface org.springframework.data.redis.core.ValueOperations
- 
Return the value atkeyand 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 applyingtimeout.
- getAndExpire(Duration) - Method in interface org.springframework.data.redis.core.BoundValueOperations
- 
Return the value at the bound key and expire the key by applyingtimeout.
- getAndExpire(K, long, TimeUnit) - Method in interface org.springframework.data.redis.core.ValueOperations
- 
Return the value atkeyand expire the key by applyingtimeout.
- getAndExpire(K, Duration) - Method in interface org.springframework.data.redis.core.ReactiveValueOperations
- 
Return the value atkeyand expire the key by applyingtimeout.
- getAndExpire(K, Duration) - Method in interface org.springframework.data.redis.core.ValueOperations
- 
Return the value atkeyand 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 atkeyand persist the key.
- getAndPersist(K) - Method in interface org.springframework.data.redis.core.ValueOperations
- 
Return the value atkeyand 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
- 
Setvalueofkeyand return its old value.
- getAndSet(K, V) - Method in interface org.springframework.data.redis.core.ValueOperations
- 
Setvalueofkeyand return its old value.
- getAndSet(V) - Method in interface org.springframework.data.redis.core.BoundValueOperations
- 
Setvalueof 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 givenupdate function.
- getAndUpdate(IntUnaryOperator) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicInteger
- 
Atomically update the current value using the givenupdate function.
- getAndUpdate(LongUnaryOperator) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicLong
- 
Atomically update the current value using the givenupdate 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 theCOUNToption during reads.
- getBatchSize() - Method in class org.springframework.data.redis.stream.StreamReceiver.StreamReceiverOptions
- 
Batch size polling using theCOUNToption 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 ofRedisCommandsProvider.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 atoffsetof 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 atoffsetof 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 atoffsetof value atkey.
- getBit(K, long) - Method in interface org.springframework.data.redis.core.ValueOperations
- 
Get the bit value atoffsetof 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 fromByteBufferwithout consuming it.
- getCacheConfiguration() - Method in class org.springframework.data.redis.cache.RedisCache
- 
GetRedisCacheConfigurationused.
- getCacheConfigurationFor(String) - Method in class org.springframework.data.redis.cache.RedisCacheManager.RedisCacheManagerBuilder
- 
Get theRedisCacheConfigurationfor 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
- 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 ofRedisCommandsProvider.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 ofRedisCommandsProvider.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 ofRedisCommandsProvider.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 theClientResourcesto reuse infrastructure.
- getCluster() - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
- getClusterCommandExecutor() - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
- getClusterCommandExecutor() - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
- getClusterConfiguration() - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
- getClusterConfiguration() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
- getClusterConnection() - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
- getClusterConnection() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
- getClusterConnection() - Method in interface org.springframework.data.redis.connection.RedisConnectionFactory
- 
Provides a suitable connection for interacting with Redis Cluster.
- getClusterNodes() - Method in class org.springframework.data.redis.connection.RedisClusterConfiguration
- getClusterNodes() - Method in interface org.springframework.data.redis.connection.RedisConfiguration.ClusterConfiguration
- 
Returns anCollections.unmodifiableSet(Set)of cluster nodes.
- getClusterSize() - Method in class org.springframework.data.redis.connection.ClusterInfo
- getCmd() - Method in class org.springframework.data.redis.core.PartialUpdate.PropertyUpdate
- 
Get the associatedPartialUpdate.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 ofRedisCommandsProvider.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 givenpatternfrom server.
- getConfig(String) - Method in interface org.springframework.data.redis.connection.RedisServerCommands
- 
Load configuration parameters for givenpatternfrom server.
- getConfig(RedisClusterNode, String) - Method in interface org.springframework.data.redis.connection.DefaultedRedisClusterConnection
- 
Deprecated.in favor ofRedisCommandsProvider.serverCommands().
- getConfig(RedisClusterNode, String) - Method in interface org.springframework.data.redis.connection.ReactiveClusterServerCommands
- 
Load configuration parameters for givenpatternfrom 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 theSetof 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
- 
Provides a suitable connection for interacting with Redis.
- getConnection() - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
- 
Creates aMonowhich emits a newReactiveRedisConnection.
- getConnection(Class<T>) - Method in interface org.springframework.data.redis.connection.lettuce.LettuceConnectionProvider
- 
Request a connection givenconnectionType.
- getConnection(Class<T>, RedisURI) - Method in interface org.springframework.data.redis.connection.lettuce.LettuceConnectionProvider.TargetAware
- 
Request a connection givenconnectionTypefor a specificRedisURI.
- getConnection(RedisConnectionFactory) - Static method in class org.springframework.data.redis.core.RedisConnectionUtils
- 
Obtain aRedisConnectionfrom the givenRedisConnectionFactory.
- getConnection(RedisConnectionFactory, boolean) - Static method in class org.springframework.data.redis.core.RedisConnectionUtils
- 
Obtain aRedisConnectionfrom the givenRedisConnectionFactory.
- getConnectionAsync(Class<T>) - Method in interface org.springframework.data.redis.connection.lettuce.LettuceConnectionProvider
- 
Request asynchronously a connection givenconnectionType.
- getConnectionAsync(Class<T>, RedisURI) - Method in interface org.springframework.data.redis.connection.lettuce.LettuceConnectionProvider.TargetAware
- 
Request asynchronously a connection givenconnectionTypefor 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
- 
TheConsumerto 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
- getConversionService() - Method in class org.springframework.data.redis.cache.RedisCacheConfiguration
- getConversionService() - Method in class org.springframework.data.redis.core.convert.MappingRedisConverter
- getConverted(TimeUnit) - Method in class org.springframework.data.redis.core.types.Expiration
- 
Get the expiration time converted into the desiredtargetTimeUnit.
- getConverter() - Method in class org.springframework.data.redis.connection.FutureResult
- getConverter() - Method in class org.springframework.data.redis.core.RedisKeyValueAdapter
- 
Get theRedisConverterin use.
- getConverter() - Method in class org.springframework.data.redis.core.RedisKeyValueTemplate
- 
Obtain the underlying redis specificEntityConverter.
- getConvertersToRegister() - Static method in class org.springframework.data.redis.core.convert.Jsr310Converters
- 
Returns theConvertersto 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
- getCursorId() - Method in interface org.springframework.data.redis.core.Cursor
- 
Get the reference cursor.
- getCursorId() - Method in class org.springframework.data.redis.core.ScanCursor
- getCursorId() - Method in class org.springframework.data.redis.core.ScanIteration
- 
The cursor id to be used for subsequent requests.
- getDatabase() - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
- 
Returns the index of the database.
- getDatabase() - Method in class org.springframework.data.redis.connection.lettuce.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 currentRedisConfigurationisdatabase awareor 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 theRedisPasswordused 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 defaultRedisCacheConfigurationapplied to newRedisCacheinstances on creation when custom, non-specificRedisCacheConfigurationwas 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 ofRedisCommandsProvider.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 atkeyand 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 atkeyand delete the key.
- getDel(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
- 
Return the value atkeyand delete the key.
- getDel(Publisher<ReactiveRedisConnection.KeyCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
- 
Return the value atkeyand delete the key.
- getDelegate() - Method in interface org.springframework.data.redis.connection.DecoratedRedisConnection
- 
Gets the underlyingRedisConnection.
- 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 givenBeanfrom 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
- 
Indicatesshared connectionsshould 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 theconsumer.
- getElement() - Method in class org.springframework.data.redis.connection.ReactiveListCommands.LPosCommand
- getEntityInformation(Class<T>) - Method in class org.springframework.data.redis.repository.support.RedisRepositoryFactory
- getErrorHandler() - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamMessageListenerContainerOptions
- getErrorHandler() - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamReadRequest
- getEvents() - Method in class org.springframework.data.redis.core.types.RedisClientInfo
- 
Get file descriptor events.
- getEx(byte[], Expiration) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 atkeyand 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 atkeyand expire the key by applyingExpiration.
- getEx(ByteBuffer, Expiration) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
- 
Return the value atkeyand expire the key by applyingExpiration.
- getEx(Publisher<ReactiveStringCommands.GetExCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
- 
Return the value atkeyand 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 theExpirationto 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 expiration time.
- 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 forkey.
- 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 forkeyin 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 forkeyin 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 thePersistentPropertythat 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 newRedisSystemExceptionwrapping 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 class org.springframework.data.redis.support.collections.DefaultRedisList
- getFirstEntry() - Method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoStream
- 
The streams first entry.
- getFirstNonNullNotEmptyOrDefault(T) - Method in class org.springframework.data.redis.connection.ClusterCommandExecutor.MultiNodeResult
- getFirstValue() - Method in class org.springframework.data.redis.repository.query.RedisOperationChain.PathAndValue
- getFlags() - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusByMemberCommand
- getFlags() - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusCommand
- getFlags() - Method in class org.springframework.data.redis.connection.RedisClusterNode
- getFlags() - Method in 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 theHashMapperfor a specific type.
- getHashMapper(Class<V>) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
- 
Get theHashMapperfor a specific type.
- getHashMapper(Class<V>) - Method in interface org.springframework.data.redis.core.StreamOperations
- 
Get theHashMapperfor 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.PartialUpdate
- 
Get the id of the element to update.
- getId() - Method in class org.springframework.data.redis.core.RedisKeyExpiredEvent
- 
Get the expired objects id.
- getId() - Method in class org.springframework.data.redis.repository.cdi.CdiBean
- getIdAsString() - Method in class org.springframework.data.redis.connection.stream.PendingMessage
- getIdentifyingAnnotations() - Method in class org.springframework.data.redis.repository.configuration.RedisRepositoryConfigurationExtension
- getIdle() - Method in class org.springframework.data.redis.core.types.RedisClientInfo
- 
Get idle time of the connection in seconds.
- getIdleTime() - Method in class org.springframework.data.redis.connection.RedisStreamCommands.XClaimOptions
- 
Get the IDLE ms time.
- getIdRange() - Method in class org.springframework.data.redis.connection.stream.PendingMessagesSummary
- 
Get the range between the smallest and greatest ID among the pending messages.
- getIds() - Method in class org.springframework.data.redis.connection.RedisStreamCommands.XClaimOptions
- 
Get theListof ID.
- getIdsAsStringArray() - Method in class org.springframework.data.redis.connection.RedisStreamCommands.XClaimOptions
- 
Get the ID array asstrings.
- 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 ofIndexDefinitionfor 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 theStringrepresentation 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 aMapofcache namestoRedisCacheConfigurationobjects as the initial set ofRedis cachesto 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 JacksonJavaTypefor the specific class.
- getJedis() - Method in class org.springframework.data.redis.connection.jedis.JedisConnection
- getJedis(RedisNode) - Method in class org.springframework.data.redis.connection.jedis.JedisConnection
- getKey() - Method in class org.springframework.data.redis.connection.ClusterCommandExecutor.NodeResult
- getKey() - Method in class org.springframework.data.redis.connection.ReactiveHyperLogLogCommands.PfCountCommand
- getKey() - Method in class org.springframework.data.redis.connection.ReactiveListCommands.BPopCommand
- getKey() - Method in class org.springframework.data.redis.connection.ReactiveListCommands.PopResult
- getKey() - Method in interface org.springframework.data.redis.connection.ReactiveRedisConnection.Command
- getKey() - Method in class org.springframework.data.redis.connection.ReactiveRedisConnection.KeyCommand
- getKey() - Method in class org.springframework.data.redis.connection.ReactiveSetCommands.SDiffCommand
- getKey() - Method in class org.springframework.data.redis.connection.ReactiveSetCommands.SInterCommand
- getKey() - Method in class org.springframework.data.redis.connection.ReactiveSetCommands.SUnionCommand
- getKey() - Method in class org.springframework.data.redis.connection.ReactiveStringCommands.MSetCommand
- getKey() - Method in class org.springframework.data.redis.connection.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
- 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 theRedisClusterNodethat 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 theKeyspaceConfiguration.KeyspaceSettingsfor 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 class org.springframework.data.redis.support.collections.DefaultRedisList
- getLastCommand() - Method in class org.springframework.data.redis.core.types.RedisClientInfo
- 
Get last command played.
- getLastEntry() - Method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoStream
- 
The streams first entry.
- getLastOkPingReply() - Method in class org.springframework.data.redis.connection.RedisServer
- getLastPingSent() - Method in class org.springframework.data.redis.connection.RedisServer
- getLastReset() - Method in interface org.springframework.data.redis.cache.CacheStatistics
- 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 mappedRedisOperationChainto query secondary indexes givenExample.
- getMappingConfiguration() - Method in class org.springframework.data.redis.core.mapping.RedisMappingContext
- 
Get theMappingConfigurationused.
- 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
- 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 nativeAbstractRedisClientused 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 theRedisClusterNodethe command was executed on.
- getNodes() - Method in class org.springframework.data.redis.connection.ClusterTopology
- 
Get allRedisClusterNodes.
- 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 configuredObjectMapperused internally by thisGenericJackson2JsonRedisSerializerto de/serializeobjectsas 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 theScanOptionsto 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 configuredRedisPasswordif the currentRedisConfigurationispassword awareor 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 theBucket.BucketPropertyPathleading 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.
- 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 theBLOCKoption during reads.
- getPollTimeout() - Method in class org.springframework.data.redis.stream.StreamReceiver.StreamReceiverOptions
- 
Timeout for blocking polling using theBLOCKoption 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 theBucket.BucketPropertyPathfor 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
- 
TheRangepending messages have been loaded.
- getRange(byte[], long, long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 ofkeybetweenstartandend.
- 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 ofkeybetweenstartandend.
- 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
- getRequiredConnectionFactory() - Method in class org.springframework.data.redis.core.RedisAccessor
- 
Returns the requiredRedisConnectionFactory, throwing anIllegalStateExceptionif theRedisConnectionFactoryis not set.
- getRequiredEndpoint() - Method in class org.springframework.data.redis.connection.lettuce.observability.LettuceObservationContext
- 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 nativeAbstractRedisClientused 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
- 
Provides a suitable connection for interacting with Redis Sentinel.
- getSentinelConnection(RedisNode) - Method in class org.springframework.data.redis.connection.AbstractRedisConnection
- 
GetRedisSentinelCommandsconnected 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 theRedisPasswordto 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 anCollections.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 itRecordId.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 ofRedisCommandsProvider.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
- 
Setvalueofkeyand 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
- 
Setvalueofkeyand 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 defaultObjectHashMapperinstance, 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 multipleLettuceConnections 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 servedRedisClusterNode.SlotRange.
- getSlots() - Method in class org.springframework.data.redis.connection.RedisClusterNode.SlotRange
- 
Gets all slots in thisRedisClusterNode.SlotRangemanaged 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 theRedisClusterNodes (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 theCacheStatisticssnapshot 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 theListof 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 targetRedisConnectionof 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
- 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 itRecordId.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
- getTimeToLiveAccessor() - Method in class org.springframework.data.redis.core.mapping.BasicRedisPersistentEntity
- getTimeToLiveAccessor() - Method in interface org.springframework.data.redis.core.mapping.RedisPersistentEntity
- 
Get theTimeToLiveAccessorassociated 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 time unit for the expiration 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.PatternTopic
- 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 knownClusterTopology.
- 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 theconsumer.
- 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
- getTransaction() - Method in class org.springframework.data.redis.connection.jedis.JedisConnection
- getTtl() - Method in class org.springframework.data.redis.cache.RedisCacheConfiguration
- 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
- 
TheBitFieldSubCommands.BitFieldTypeto 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.
- getWeight(int) - Method in class org.springframework.data.redis.connection.zset.Weights
- 
Retrieve the weight atindex.
- 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
- hasExplictTimeToLiveProperty() - Method in class org.springframework.data.redis.core.mapping.BasicRedisPersistentEntity
- hasExplictTimeToLiveProperty() - Method in interface org.springframework.data.redis.core.mapping.RedisPersistentEntity
- 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 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.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.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.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.PatternTopic
- 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
- 
GetReactiveHashCommands.
- hashCommands() - Method in interface org.springframework.data.redis.connection.RedisCommandsProvider
- 
GetRedisHashCommands.
- hashKey(RedisElementReader<?>, RedisElementWriter<?>) - Method in interface org.springframework.data.redis.serializer.RedisSerializationContext.RedisSerializationContextBuilder
- 
Set the hash keyRedisElementReaderandRedisElementWriter.
- hashKey(RedisSerializationContext.SerializationPair<?>) - Method in interface org.springframework.data.redis.serializer.RedisSerializationContext.RedisSerializationContextBuilder
- 
Set the hash keyRedisSerializationContext.SerializationPair.
- hashKey(RedisSerializer<?>) - Method in interface org.springframework.data.redis.serializer.RedisSerializationContext.RedisSerializationContextBuilder
- 
Set the hash keyRedisSerializationContext.SerializationPairgiven 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 aHashMapperfor 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 valueRedisElementReaderandRedisElementWriter.
- hashValue(RedisSerializationContext.SerializationPair<?>) - Method in interface org.springframework.data.redis.serializer.RedisSerializationContext.RedisSerializationContextBuilder
- 
Set the hash valueRedisSerializationContext.SerializationPair.
- hashValue(RedisSerializer<?>) - Method in interface org.springframework.data.redis.serializer.RedisSerializationContext.RedisSerializationContextBuilder
- 
Set the hash valueRedisSerializationContext.SerializationPairgiven 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 givenkeyspace.
- 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 givenkeyspaceand propertypath.
- hasKey(H, Object) - Method in interface org.springframework.data.redis.core.HashOperations
- 
Determine if given hashhashKeyexists.
- hasKey(H, Object) - Method in interface org.springframework.data.redis.core.ReactiveHashOperations
- 
Determine if given hashhashKeyexists.
- hasKey(Object) - Method in interface org.springframework.data.redis.core.BoundHashOperations
- 
Determine if given hashkeyexists at the bound key.
- hasKey(K) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
- 
Determine if givenkeyexists.
- hasKey(K) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
- hasKey(K) - Method in interface org.springframework.data.redis.core.RedisOperations
- 
Determine if givenkeyexists.
- 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 insecor requiresmsecrepresentation.
- 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 specificKeyspaceConfiguration.KeyspaceSettingsare 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 whetherpathis associated with a non-nullvalue.
- hDel(byte[], byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 hashfields.
- 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 hashfields.
- 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 ofRedisCommandsProvider.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 hashfieldexists.
- 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 hashfieldexists.
- 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 ofRedisCommandsProvider.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 givenfieldfrom 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 givenfieldfrom 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 ofRedisCommandsProvider.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 atkey.
- 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 atkey.
- 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 ofRedisCommandsProvider.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
- 
Incrementvalueof a hashfieldby the givendelta.
- hIncrBy(byte[], byte[], long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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
- 
Incrementvalueof a hashfieldby 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
- 
Incrementvalueof a hashfieldby 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
- 
Incrementvalueof a hashfieldby 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 ofRedisCommandsProvider.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 atkey.
- 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 atkey.
- 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 atkey.
- 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 atkey.
- 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 ofRedisCommandsProvider.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 givenfieldsfrom 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 givenfieldsfrom 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 ofRedisCommandsProvider.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 inhashes
- 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 inhashes
- 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 ofRedisCommandsProvider.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 atkey.
- hRandField(byte[], long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 atkey.
- 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 atkey.
- 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 atkey.
- hRandField(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveHashCommands
- 
Return a random field from the hash stored atkey.
- hRandField(ByteBuffer, long) - Method in interface org.springframework.data.redis.connection.ReactiveHashCommands
- 
Return a random field from the hash stored atkey.
- 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 ofRedisCommandsProvider.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 atkey.
- hRandFieldWithValues(byte[], long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 atkey.
- 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 atkey.
- 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 atkey.
- hRandFieldWithValues(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveHashCommands
- 
Return a random field from the hash along with its value stored atkey.
- hRandFieldWithValues(ByteBuffer, long) - Method in interface org.springframework.data.redis.connection.ReactiveHashCommands
- 
Return a random field from the hash along with its value stored atkey.
- 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 ofRedisCommandsProvider.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 aCursorto 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 aCursorto iterate over entries in hash atkey.
- hScan(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveHashCommands
- 
Use aFluxto 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 aFluxto 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 ofRedisCommandsProvider.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 thevalueof 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 thevalueof 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 ofRedisCommandsProvider.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 thevalueof a hashfieldonly iffielddoes 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 thevalueof a hashfieldonly iffielddoes 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 ofRedisCommandsProvider.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 withfieldin 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 withfieldin the hash stored atkey.
- hStrLen(ByteBuffer, ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveHashCommands
- 
Get the length of the value associated withfield.
- hStrLen(Publisher<ReactiveHashCommands.HStrLenCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveHashCommands
- 
Get the length of the value associated withfield.
- hVals(byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 atfield.
- 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 atfield.
- 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 aConverterthat 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 ofRedisCommandsProvider.keyCommands().
- idletime(byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- idletime(byte[]) - Method in interface org.springframework.data.redis.connection.RedisKeyCommands
- 
Get theDurationsince the object stored at the givenkeyis idle.
- idletime(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- idletime(String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
- 
Get theDurationsince the object stored at the givenkeyis idle.
- idletime(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
- 
Get theDurationsince the object stored at the givenkeyis 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
- includeCoordinates() - Method in class org.springframework.data.redis.connection.RedisGeoCommands.GeoRadiusCommandArgs
- 
Sets theRedisGeoCommands.GeoRadiusCommandArgs.Flag.WITHCOORDflag to also return the longitude, latitude coordinates of the matching items.
- includeCoordinates() - Method in class org.springframework.data.redis.connection.RedisGeoCommands.GeoSearchCommandArgs
- 
Sets theRedisGeoCommands.GeoRadiusCommandArgs.Flag.WITHCOORDflag to also return the longitude, latitude coordinates of the matching items.
- includeDistance() - Method in class org.springframework.data.redis.connection.RedisGeoCommands.GeoRadiusCommandArgs
- 
Sets theRedisGeoCommands.GeoRadiusCommandArgs.Flag.WITHDISTflag 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 theRedisGeoCommands.GeoRadiusCommandArgs.Flag.WITHDISTflag 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 ofRedisCommandsProvider.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 ofkeyby 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 ofkeyby 1.
- incr(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveNumberCommands.HIncrByCommand
- 
Creates a newReactiveNumberCommands.HIncrByCommandgiven 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 newReactiveNumberCommands.IncrByCommandgiven 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 newBitFieldSubCommandsadding givenBitFieldSubCommands.BitFieldIncrByto the sub commands.
- incr(BitFieldSubCommands.BitFieldType) - Method in class org.springframework.data.redis.connection.BitFieldSubCommands
- 
Obtain a newBitFieldSubCommands.BitFieldIncrByBuilderfor creating and adding aBitFieldSubCommands.BitFieldIncrBysub 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 ofRedisCommandsProvider.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 ofkeybydelta.
- incrBy(byte[], long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 ofkeybydelta.
- 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 ofkeybydelta.
- 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 ofkeybydelta.
- 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 bydelta.
- increment(long) - Method in interface org.springframework.data.redis.core.BoundValueOperations
- 
Increment an integer value stored as string value under the bound key bydelta.
- increment(HK, double) - Method in interface org.springframework.data.redis.core.BoundHashOperations
- 
Incrementvalueof a hashkeyby the givendeltaat the bound key.
- increment(HK, long) - Method in interface org.springframework.data.redis.core.BoundHashOperations
- 
Incrementvalueof a hashkeyby the givendeltaat the bound key.
- increment(H, HK, double) - Method in interface org.springframework.data.redis.core.HashOperations
- 
Incrementvalueof a hashhashKeyby the givendelta.
- increment(H, HK, double) - Method in interface org.springframework.data.redis.core.ReactiveHashOperations
- 
Incrementvalueof a hashhashKeyby the givendelta.
- increment(H, HK, long) - Method in interface org.springframework.data.redis.core.HashOperations
- 
Incrementvalueof a hashhashKeyby the givendelta.
- increment(H, HK, long) - Method in interface org.springframework.data.redis.core.ReactiveHashOperations
- 
Incrementvalueof a hashhashKeyby 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 atkeyby one.
- increment(K) - Method in interface org.springframework.data.redis.core.ValueOperations
- 
Increment an integer value stored as string value underkeyby one.
- increment(K, double) - Method in interface org.springframework.data.redis.core.ReactiveValueOperations
- 
Increment the string representing a floating point number stored atkeybydelta.
- increment(K, double) - Method in interface org.springframework.data.redis.core.ValueOperations
- 
Increment a floating point number value stored as string value underkeybydelta.
- 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
- 
Incrementvalueof the hashkeyby the givendelta.
- increment(K, long) - Method in interface org.springframework.data.redis.core.ReactiveValueOperations
- 
Increments the number stored atkeybydelta.
- increment(K, long) - Method in interface org.springframework.data.redis.core.ValueOperations
- 
Increment an integer value stored as string value underkeybydelta.
- 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
- 
Incrementvalueof the hashkeyby 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 withvaluein sorted set byincrement.
- incrementScore(K, V, double) - Method in interface org.springframework.data.redis.core.ZSetOperations
- 
Increment the score of element withvaluein sorted set byincrement.
- incrementScore(V, double) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
- 
Increment the score of element withvaluein sorted set byincrement.
- index(long) - Method in interface org.springframework.data.redis.core.BoundListOperations
- 
Get element atindexform list at the bound key.
- index(K, long) - Method in interface org.springframework.data.redis.core.ListOperations
- 
Get element atindexform list atkey.
- index(K, long) - Method in interface org.springframework.data.redis.core.ReactiveListOperations
- 
Get element atindexform 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
- 
IndexConfigurationallows programmatic setup of indexes.
- IndexConfiguration() - Constructor for class org.springframework.data.redis.core.index.IndexConfiguration
- 
Creates new emptyIndexConfiguration.
- IndexDefinition - Interface in org.springframework.data.redis.core.index
- 
IndexDefinitionallow 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
- 
IndexDefinitionProvidergive access toIndexDefinitions for creating secondary index structures.
- IndexDefinitionRegistry - Interface in org.springframework.data.redis.core.index
- 
Registry that allows addingIndexDefinition.
- 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
- 
IndexedDatarepresents 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 newReactiveZSetCommands.ZRankCommandgiven amemberto 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 atkey.
- 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 atkey.
- 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 atkey.
- IndexResolver - Interface in org.springframework.data.redis.core.convert
- 
IndexResolverextracts secondary index structures to be applied on a given path,PersistentPropertyand value.
- IndexValueTransformer - Interface in org.springframework.data.redis.core.index
- 
Converterimplementation 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 ofRedisCommandsProvider.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 ofRedisCommandsProvider.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 givenselection.
- info(String) - Method in interface org.springframework.data.redis.connection.RedisServerCommands
- 
Load server information for givenselection.
- 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 ofRedisCommandsProvider.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 ofRedisCommandsProvider.serverCommands().
- info(RedisClusterNode, String) - Method in interface org.springframework.data.redis.connection.ReactiveClusterServerCommands
- 
Load server information for givenselection.
- 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 ifnative connection sharingis 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.
- initialCacheNames(Set<String>) - Method in class org.springframework.data.redis.cache.RedisCacheManager.RedisCacheManagerBuilder
- 
Append aSetof 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
- 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 asLong
- 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 otherRedisSets.
- 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 otherRedisZSets.
- intersect(Collection<K>) - Method in interface org.springframework.data.redis.core.BoundSetOperations
- 
Returns the members intersecting all given sets at the bound key andkeys.
- intersect(Collection<K>) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
- 
Intersect sortedsets.
- intersect(Collection<K>) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
- 
Returns the members intersecting all given sets atkeys.
- intersect(Collection<K>) - Method in interface org.springframework.data.redis.core.SetOperations
- 
Returns the members intersecting all given sets atkeys.
- intersect(K) - Method in interface org.springframework.data.redis.core.BoundSetOperations
- 
Returns the members intersecting all given sets at the bound key andkey.
- intersect(K) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
- 
Intersect sortedsets.
- intersect(K, Collection<K>) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
- 
Returns the members intersecting all given sets atkeyandotherKeys.
- intersect(K, Collection<K>) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- 
Intersect sortedsets.
- intersect(K, Collection<K>) - Method in interface org.springframework.data.redis.core.SetOperations
- 
Returns the members intersecting all given sets atkeyandotherKeys.
- intersect(K, Collection<K>) - Method in interface org.springframework.data.redis.core.ZSetOperations
- 
Intersect sortedsets.
- intersect(K, K) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
- 
Returns the members intersecting all given sets atkeyandotherKey.
- intersect(K, K) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- 
Intersect sortedsets.
- intersect(K, K) - Method in interface org.springframework.data.redis.core.SetOperations
- 
Returns the members intersecting all given sets atkeyandotherKey.
- intersect(K, K) - Method in interface org.springframework.data.redis.core.ZSetOperations
- 
Intersect sortedsets.
- 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 anotherRedisSet.
- 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 anotherRedisZSet.
- 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 andkeysand store result indestKey.
- intersectAndStore(Collection<K>, K) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
- 
Intersect sorted sets at the bound key andotherKeysand store result in destinationdestKey.
- intersectAndStore(Collection<K>, K) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
- 
Intersect all given sets atkeysand store result indestKey.
- intersectAndStore(Collection<K>, K) - Method in interface org.springframework.data.redis.core.SetOperations
- 
Intersect all given sets atkeysand store result indestKey.
- intersectAndStore(Collection<K>, K, Aggregate) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
- 
Intersect sorted sets at the bound key andotherKeysand 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 andotherKeysand store result in destinationdestKey.
- intersectAndStore(K, Collection<K>, K) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
- 
Intersect all given sets atkeyandotherKeysand store result indestKey.
- intersectAndStore(K, Collection<K>, K) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- 
Intersect sorted sets atkeyandotherKeysand store result in destinationdestKey.
- intersectAndStore(K, Collection<K>, K) - Method in interface org.springframework.data.redis.core.SetOperations
- 
Intersect all given sets atkeyandotherKeysand store result indestKey.
- intersectAndStore(K, Collection<K>, K) - Method in interface org.springframework.data.redis.core.ZSetOperations
- 
Intersect sorted sets atkeyandotherKeysand store result in destinationdestKey.
- intersectAndStore(K, Collection<K>, K, Aggregate) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- 
Intersect sorted sets atkeyandotherKeysand store result in destinationdestKey.
- intersectAndStore(K, Collection<K>, K, Aggregate) - Method in interface org.springframework.data.redis.core.ZSetOperations
- 
Intersect sorted sets atkeyandotherKeysand store result in destinationdestKey.
- intersectAndStore(K, Collection<K>, K, Aggregate, Weights) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- 
Intersect sorted sets atkeyandotherKeysand store result in destinationdestKey.
- intersectAndStore(K, Collection<K>, K, Aggregate, Weights) - Method in interface org.springframework.data.redis.core.ZSetOperations
- 
Intersect sorted sets atkeyandotherKeysand store result in destinationdestKey.
- intersectAndStore(K, K) - Method in interface org.springframework.data.redis.core.BoundSetOperations
- 
Intersect all given sets at the bound key andkeyand store result indestKey.
- intersectAndStore(K, K) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
- 
Intersect sorted sets at the bound key andotherKeyand store result in destinationdestKey.
- intersectAndStore(K, K, K) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
- 
Intersect all given sets atkeyandotherKeyand store result indestKey.
- intersectAndStore(K, K, K) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- 
Intersect sorted sets atkeyandotherKeyand store result in destinationdestKey.
- intersectAndStore(K, K, K) - Method in interface org.springframework.data.redis.core.SetOperations
- 
Intersect all given sets atkeyandotherKeyand store result indestKey.
- intersectAndStore(K, K, K) - Method in interface org.springframework.data.redis.core.ZSetOperations
- 
Intersect sorted sets atkeyandotherKeyand 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 otherRedisZSets.
- intersectWithScores(Collection<K>) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
- 
Intersect sortedsets.
- intersectWithScores(Collection<K>, Aggregate, Weights) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
- 
Intersect sortedsets.
- intersectWithScores(K) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
- 
Intersect sortedsets.
- intersectWithScores(K, Collection<K>) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- 
Intersect sortedsets.
- intersectWithScores(K, Collection<K>) - Method in interface org.springframework.data.redis.core.ZSetOperations
- 
Intersect sortedsets.
- intersectWithScores(K, Collection<K>, Aggregate) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- 
Intersect sorted sets atkeyandotherKeys.
- intersectWithScores(K, Collection<K>, Aggregate) - Method in interface org.springframework.data.redis.core.ZSetOperations
- 
Intersect sorted sets atkeyandotherKeys.
- intersectWithScores(K, Collection<K>, Aggregate, Weights) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- 
Intersect sortedsets.
- intersectWithScores(K, Collection<K>, Aggregate, Weights) - Method in interface org.springframework.data.redis.core.ZSetOperations
- 
Intersect sortedsets.
- intersectWithScores(K, K) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- 
Intersect sortedsets.
- intersectWithScores(K, K) - Method in interface org.springframework.data.redis.core.ZSetOperations
- 
Intersect sortedsets.
- 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 anotherRedisZSet.
- 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 whetherRedis cachesare 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
- 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
- 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
- isEnableDefaultSerializer() - Method in class org.springframework.data.redis.core.RedisTemplate
- 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 to expose the native Redis connection to RedisCallback code, or rather a connection proxy (the default).
- isFinished(long) - Method in class org.springframework.data.redis.core.ScanCursor
- 
Check whethercursorIdis 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
- 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 containsvalue.
- isMember(Object...) - Method in interface org.springframework.data.redis.core.BoundSetOperations
- 
Check if set at at the bound key contains one or morevalues.
- isMember(K, Object) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
- 
Check if set atkeycontainsvalue.
- isMember(K, Object) - Method in interface org.springframework.data.redis.core.SetOperations
- 
Check if set atkeycontainsvalue.
- isMember(K, Object...) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
- 
Check if set atkeycontains one or morevalues.
- isMember(K, Object...) - Method in interface org.springframework.data.redis.core.SetOperations
- 
Check if set atkeycontains 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
- 
StringRedisSerializerto 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
- 
Returntrueif 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
- 
Comparesthe givenStringrepresenting the Redis command to theEnum.toString()representation ofRedisCommandas well as anyRedisCommand.alias.
- isReturnTotalChanged() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZAddCommand
- 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
- isSingleton() - Method in class org.springframework.data.redis.support.collections.RedisCollectionFactoryBean
- 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.
- 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 givenkeyis 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 thekeyis 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 thekeyis 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
- isVerifyPeer() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
- 
Returns whether to verify certificate validity/hostname check when SSL is used.
- 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 theStreamInfo.XInfoConsumerelements.
- iterator() - Method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoGroups
- 
Returns an iterator over theStreamInfo.XInfoGroupelements.
- 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
- 
ObjectMapperbasedHashMapperimplementation that allows flattening.
- Jackson2HashMapper(boolean) - Constructor for class org.springframework.data.redis.hash.Jackson2HashMapper
- 
Creates newJackson2HashMapperwith a defaultObjectMapper.
- Jackson2HashMapper(ObjectMapper, boolean) - Constructor for class org.springframework.data.redis.hash.Jackson2HashMapper
- 
Creates newJackson2HashMapperinitialized 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 newJackson2JsonRedisSerializerfor the given targetJavaType.
- Jackson2JsonRedisSerializer(ObjectMapper, JavaType) - Constructor for class org.springframework.data.redis.serializer.Jackson2JsonRedisSerializer
- 
Creates a newJackson2JsonRedisSerializerfor the given targetJavaType.
- Jackson2JsonRedisSerializer(ObjectMapper, JavaType, JacksonObjectReader, JacksonObjectWriter) - Constructor for class org.springframework.data.redis.serializer.Jackson2JsonRedisSerializer
- 
Creates a newJackson2JsonRedisSerializerfor the given targetJavaType.
- Jackson2JsonRedisSerializer(ObjectMapper, Class<T>) - Constructor for class org.springframework.data.redis.serializer.Jackson2JsonRedisSerializer
- 
Creates a newJackson2JsonRedisSerializerfor the given targetClass.
- Jackson2JsonRedisSerializer(Class<T>) - Constructor for class org.springframework.data.redis.serializer.Jackson2JsonRedisSerializer
- 
Creates a newJackson2JsonRedisSerializerfor 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 newRedisSerializationContextusing aJdkSerializationRedisSerializer.
- java() - Static method in interface org.springframework.data.redis.serializer.RedisSerializer
- 
Obtain aRedisSerializerusing java serialization.
- java(ClassLoader) - Static method in interface org.springframework.data.redis.serializer.RedisSerializationContext
- 
Creates a newRedisSerializationContextusing aJdkSerializationRedisSerializerwith givenClassLoaderto resolvestypeof the keys and values stored in Redis.
- java(ClassLoader) - Static method in interface org.springframework.data.redis.serializer.RedisSerializer
- 
Obtain aRedisSerializerusing java serialization with the givenClassLoader.
- JdkSerializationRedisSerializer - Class in org.springframework.data.redis.serializer
- 
Java Serialization Redis serializer.
- JdkSerializationRedisSerializer() - Constructor for class org.springframework.data.redis.serializer.JdkSerializationRedisSerializer
- 
Creates a newJdkSerializationRedisSerializerusing the default class loader.
- JdkSerializationRedisSerializer(ClassLoader) - Constructor for class org.springframework.data.redis.serializer.JdkSerializationRedisSerializer
- 
Creates a newJdkSerializationRedisSerializerusing aClassLoader.
- JdkSerializationRedisSerializer(Converter<Object, byte[]>, Converter<byte[], Object>) - Constructor for class org.springframework.data.redis.serializer.JdkSerializationRedisSerializer
- 
Creates a newJdkSerializationRedisSerializerusing aconvertersto serialize and deserialize objects.
- JedisClientConfiguration - Interface in org.springframework.data.redis.connection.jedis
- 
Redis client configuration for jedis.
- JedisClientConfiguration.DefaultJedisClientConfigurationBuilder - Class in org.springframework.data.redis.connection.jedis
- 
DefaultJedisClientConfiguration.JedisClientConfigurationBuilderimplementation to build an immutableJedisClientConfiguration.
- JedisClientConfiguration.JedisClientConfigurationBuilder - Interface in org.springframework.data.redis.connection.jedis
- 
Builder forJedisClientConfiguration.
- JedisClientConfiguration.JedisPoolingClientConfigurationBuilder - Interface in org.springframework.data.redis.connection.jedis
- 
Builder for Pooling-relatedJedisClientConfiguration.
- JedisClientConfiguration.JedisSslClientConfigurationBuilder - Interface in org.springframework.data.redis.connection.jedis
- 
Builder for SSL-relatedJedisClientConfiguration.
- JedisClusterConnection - Class in org.springframework.data.redis.connection.jedis
- 
RedisClusterConnectionimplementation on top ofJedisCluster.
 Uses the nativeJedisClusterapi where possible and falls back to direct node communication usingJediswhere needed.
- JedisClusterConnection(JedisCluster) - Constructor for class org.springframework.data.redis.connection.jedis.JedisClusterConnection
- 
Create newJedisClusterConnectionutilizing native connections viaJedisCluster.
- JedisClusterConnection(JedisCluster, ClusterCommandExecutor) - Constructor for class org.springframework.data.redis.connection.jedis.JedisClusterConnection
- 
Create newJedisClusterConnectionutilizing native connections viaJedisClusterrunning commands across the cluster via givenClusterCommandExecutor.
- JedisClusterConnection(JedisCluster, ClusterCommandExecutor, ClusterTopologyProvider) - Constructor for class org.springframework.data.redis.connection.jedis.JedisClusterConnection
- 
Create newJedisClusterConnectionutilizing native connections viaJedisClusterrunning commands across the cluster via givenClusterCommandExecutorand using the givenClusterTopologyProvider.
- JedisClusterConnection.JedisClusterCommandCallback<T> - Interface in org.springframework.data.redis.connection.jedis
- 
JedisspecificClusterCommandExecutor.ClusterCommandCallback.
- JedisClusterConnection.JedisClusterTopologyProvider - Class in org.springframework.data.redis.connection.jedis
- 
Jedis specific implementation ofClusterTopologyProvider.
- JedisClusterConnection.JedisMultiKeyClusterCommandCallback<T> - Interface in org.springframework.data.redis.connection.jedis
- 
JedisspecificClusterCommandExecutor.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
- 
RedisConnectionimplementation on top of Jedis library.
- JedisConnection(Jedis) - Constructor for class org.springframework.data.redis.connection.jedis.JedisConnection
- 
Constructs a newJedisConnectioninstance.
- JedisConnection(Jedis, Pool<Jedis>, int) - Constructor for class org.springframework.data.redis.connection.jedis.JedisConnection
- 
Constructs a newJedisConnectioninstance backed by a jedis pool.
- JedisConnection(Jedis, Pool<Jedis>, int, String) - Constructor for class org.springframework.data.redis.connection.jedis.JedisConnection
- 
Constructs a newJedisConnectioninstance backed by a jedis pool.
- JedisConnection(Jedis, Pool<Jedis>, JedisClientConfig, JedisClientConfig) - Constructor for class org.springframework.data.redis.connection.jedis.JedisConnection
- 
Constructs a newJedisConnectioninstance backed by a jedis pool.
- 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 newJedisConnectionFactoryinstance with default settings (default connection pooling).
- JedisConnectionFactory(RedisClusterConfiguration) - Constructor for class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
- 
Constructs a newJedisConnectionFactoryinstance using the givenRedisClusterConfigurationapplied to create aJedisCluster.
- JedisConnectionFactory(RedisClusterConfiguration, JedisClientConfiguration) - Constructor for class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
- 
Constructs a newJedisConnectionFactoryinstance using the givenRedisClusterConfigurationandJedisClientConfiguration.
- JedisConnectionFactory(RedisClusterConfiguration, JedisPoolConfig) - Constructor for class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
- 
Constructs a newJedisConnectionFactoryinstance using the givenRedisClusterConfigurationapplied to create aJedisCluster.
- JedisConnectionFactory(RedisSentinelConfiguration) - Constructor for class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
- 
Constructs a newJedisConnectionFactoryinstance using the givenJedisPoolConfigapplied toJedisSentinelPool.
- JedisConnectionFactory(RedisSentinelConfiguration, JedisClientConfiguration) - Constructor for class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
- 
Constructs a newJedisConnectionFactoryinstance using the givenRedisSentinelConfigurationandJedisClientConfiguration.
- JedisConnectionFactory(RedisSentinelConfiguration, JedisPoolConfig) - Constructor for class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
- 
Constructs a newJedisConnectionFactoryinstance using the givenJedisPoolConfigapplied toJedisSentinelPool.
- JedisConnectionFactory(RedisStandaloneConfiguration) - Constructor for class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
- 
Constructs a newJedisConnectionFactoryinstance using the givenRedisStandaloneConfiguration.
- JedisConnectionFactory(RedisStandaloneConfiguration, JedisClientConfiguration) - Constructor for class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
- 
Constructs a newJedisConnectionFactoryinstance using the givenRedisStandaloneConfigurationandJedisClientConfiguration.
- JedisConnectionFactory(JedisPoolConfig) - Constructor for class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
- 
Constructs a newJedisConnectionFactoryinstance using the given pool configuration.
- JedisExceptionConverter - Class in org.springframework.data.redis.connection.jedis
- 
Converts Exceptions thrown from Jedis toDataAccessExceptions
- 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 expectedReturnType
- 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 aRedisSerializerthat can read and write JSON using Jackson.
- Jsr310Converters - Class in org.springframework.data.redis.core.convert
- 
Helper class to register JSR-310 specificConverterimplementations.
- Jsr310Converters() - Constructor for class org.springframework.data.redis.core.convert.Jsr310Converters
- just(RedisElementReader<? extends T>, RedisElementWriter<? extends T>) - Static method in interface org.springframework.data.redis.serializer.RedisSerializationContext.SerializationPair
- 
Creates aRedisSerializationContext.SerializationPairadapter givenRedisElementReaderandRedisElementWriter.
- just(RedisSerializationContext.SerializationPair<T>) - Static method in interface org.springframework.data.redis.serializer.RedisSerializationContext
- 
Creates a newRedisSerializationContextusing the givenRedisSerializationContext.SerializationPair.
K
- keepTtl() - Static method in class org.springframework.data.redis.core.types.Expiration
- 
Obtain anExpirationthat indicates to keep the existing one.
- 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 newReactiveKeyCommands.CopyCommandgiven akey.
- key(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveKeyCommands.ExpireAtCommand
- 
Creates a newReactiveKeyCommands.ExpireAtCommandgiven akey.
- key(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveKeyCommands.ExpireCommand
- 
Creates a newReactiveKeyCommands.ExpireCommandgiven akey.
- key(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveKeyCommands.MoveCommand
- 
Creates a newReactiveKeyCommands.MoveCommandgiven akey.
- key(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveKeyCommands.RenameCommand
- 
Creates a newReactiveKeyCommands.RenameCommandgiven akey.
- key(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveRedisConnection.KeyScanCommand
- 
Creates a newReactiveRedisConnection.KeyScanCommandgiven akey.
- key(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveRedisConnection.RangeCommand
- 
Creates a newReactiveRedisConnection.RangeCommandgiven akey.
- key(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveStringCommands.AppendCommand
- 
Creates a newReactiveStringCommands.AppendCommandgiven a key.
- key(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveStringCommands.GetExCommand
- 
Creates a newReactiveStringCommands.GetExCommandgiven akey.
- key(RedisElementReader<K>, RedisElementWriter<K>) - Method in interface org.springframework.data.redis.serializer.RedisSerializationContext.RedisSerializationContextBuilder
- 
Set the keyRedisElementReaderandRedisElementWriter.
- key(RedisSerializationContext.SerializationPair<K>) - Method in interface org.springframework.data.redis.serializer.RedisSerializationContext.RedisSerializationContextBuilder
- 
Set the keyRedisSerializationContext.SerializationPair.
- key(RedisSerializer<K>) - Method in interface org.springframework.data.redis.serializer.RedisSerializationContext.RedisSerializationContextBuilder
- 
Set the keyRedisSerializationContext.SerializationPairgiven aRedisSerializer.
- KeyBoundCursor<T> - Class in org.springframework.data.redis.core
- KeyBoundCursor(byte[], long, ScanOptions) - Constructor for class org.springframework.data.redis.core.KeyBoundCursor
- 
Crates newScanCursor
- KeyCommand(ByteBuffer) - Constructor for class org.springframework.data.redis.connection.ReactiveRedisConnection.KeyCommand
- 
Creates a newReactiveRedisConnection.KeyCommandgiven 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
- 
GetReactiveKeyCommands.
- keyCommands() - Method in interface org.springframework.data.redis.connection.RedisCommandsProvider
- 
GetRedisKeyCommands.
- KeyExpirationEventMessageListener - Class in org.springframework.data.redis.listener
- 
MessageListenerpublishingRedisKeyExpiredEvents viaApplicationEventPublisherby listening to Redis keyspace notifications for key expirations.
- KeyExpirationEventMessageListener(RedisMessageListenerContainer) - Constructor for class org.springframework.data.redis.listener.KeyExpirationEventMessageListener
- 
Creates newMessageListenerfor__keyevent@*__:expiredmessages.
- 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 ofRedisCommandsProvider.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 givenpattern.
- keys(H) - Method in interface org.springframework.data.redis.core.HashOperations
- 
Get key set (fields) of hash atkey.
- keys(H) - Method in interface org.springframework.data.redis.core.ReactiveHashOperations
- 
Get key set (fields) of hash atkey.
- 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 givenpattern.
- 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 newReactiveSetCommands.SDiffCommandgiven aCollectionof keys.
- keys(Collection<ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveSetCommands.SDiffStoreCommand
- 
Creates a newReactiveSetCommands.SDiffStoreCommandgiven aCollectionof keys.
- keys(Collection<ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveSetCommands.SInterCommand
- 
Creates a newReactiveSetCommands.SInterCommandgiven aCollectionof keys.
- keys(Collection<ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveSetCommands.SInterStoreCommand
- 
Creates a newReactiveSetCommands.SInterStoreCommandgiven aCollectionof keys.
- keys(Collection<ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveSetCommands.SUnionCommand
- 
Creates a newReactiveSetCommands.SUnionCommandgiven aCollectionof keys.
- keys(Collection<ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveSetCommands.SUnionStoreCommand
- 
Creates a newReactiveSetCommands.SUnionStoreCommandgiven aCollectionof keys.
- keys(K) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
- 
Find all keys matching the givenpattern.
- 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 givenpattern.
- 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 fromRedisNode.
- 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
- 
KeyspaceConfigurationallows 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
- 
BaseMessageListenerimplementation for listening to Redis keyspace notifications.
- KeyspaceEventMessageListener(RedisMessageListenerContainer) - Constructor for class org.springframework.data.redis.listener.KeyspaceEventMessageListener
- 
Creates newKeyspaceEventMessageListener.
- 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 theKeyValueOperationsbean to be used with the repositories detected.
- killClient(String, int) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 inclient.
- 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 newReactiveGeoCommands.GeoDistCommandforRedisGeoCommands.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 forReactiveListCommands.Direction.RIGHT.
- last() - Static method in enum class org.springframework.data.redis.connection.RedisListCommands.Direction
- 
Alias forRedisListCommands.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 newReactiveListCommands.LRemCommandto 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 atkey.
- 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 atkey.
- 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 atkey.
- lastSave() - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 successfulReactiveServerCommands.bgSave()operation in seconds.
- lastSave() - Method in interface org.springframework.data.redis.connection.RedisServerCommands
- 
Get time of lastRedisServerCommands.bgSave()operation in seconds.
- lastSave(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.DefaultedRedisClusterConnection
- 
Deprecated.in favor ofRedisCommandsProvider.serverCommands().
- lastSave(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.ReactiveClusterServerCommands
- 
Get time unix timestamp of last successfulReactiveServerCommands.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 newReactiveListCommands.BPopCommandfor right push (BLPOP).
- left() - Static method in class org.springframework.data.redis.connection.ReactiveListCommands.PopCommand
- 
Creates a newReactiveListCommands.PopCommandfor right push (LPOP).
- left() - Static method in class org.springframework.data.redis.connection.ReactiveListCommands.PushCommand
- 
Creates a newReactiveListCommands.PushCommandfor 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 atkey.
- 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 atkey.
- leftPop(K) - Method in interface org.springframework.data.redis.core.ReactiveListOperations
- 
Removes and returns first element in list stored atkey.
- leftPop(K, long) - Method in interface org.springframework.data.redis.core.ListOperations
- 
Removes and returns first elements in list stored atkey.
- leftPop(K, long, TimeUnit) - Method in interface org.springframework.data.redis.core.ListOperations
- 
Removes and returns first element from lists stored atkey.
- leftPop(K, Duration) - Method in interface org.springframework.data.redis.core.ListOperations
- 
Removes and returns first element from lists stored atkey.
- leftPop(K, Duration) - Method in interface org.springframework.data.redis.core.ReactiveListOperations
- 
Removes and returns first element from lists stored atkey.
- leftPush(K, V) - Method in interface org.springframework.data.redis.core.ListOperations
- 
Prependvaluetokey.
- leftPush(K, V) - Method in interface org.springframework.data.redis.core.ReactiveListOperations
- 
Prependvaluetokey.
- leftPush(K, V, V) - Method in interface org.springframework.data.redis.core.ListOperations
- 
Insertvaluetokeybeforepivot.
- leftPush(K, V, V) - Method in interface org.springframework.data.redis.core.ReactiveListOperations
- 
Insertvaluetokeybeforepivot.
- leftPush(V) - Method in interface org.springframework.data.redis.core.BoundListOperations
- 
Prependvalueto the bound key.
- leftPush(V, V) - Method in interface org.springframework.data.redis.core.BoundListOperations
- 
Prependvaluesto the bound key beforevalue.
- leftPushAll(K, Collection<V>) - Method in interface org.springframework.data.redis.core.ListOperations
- 
Prependvaluestokey.
- leftPushAll(K, Collection<V>) - Method in interface org.springframework.data.redis.core.ReactiveListOperations
- 
Prependvaluestokey.
- leftPushAll(K, V...) - Method in interface org.springframework.data.redis.core.ListOperations
- 
Prependvaluestokey.
- leftPushAll(K, V...) - Method in interface org.springframework.data.redis.core.ReactiveListOperations
- 
Prependvaluestokey.
- leftPushAll(V...) - Method in interface org.springframework.data.redis.core.BoundListOperations
- 
Prependvaluesto the bound key.
- leftPushIfPresent(K, V) - Method in interface org.springframework.data.redis.core.ListOperations
- 
Prependvaluestokeyonly if the list exists.
- leftPushIfPresent(K, V) - Method in interface org.springframework.data.redis.core.ReactiveListOperations
- 
Prependvaluestokeyonly if the list exists.
- leftPushIfPresent(V) - Method in interface org.springframework.data.redis.core.BoundListOperations
- 
Prependvaluesto the bound key only if the list exists.
- lengthOf(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveHashCommands.HStrLenCommand
- 
Specify thefieldwithin the hash to get the length of thevalueof.ø
- lengthOfValue(HK) - Method in interface org.springframework.data.redis.core.BoundHashOperations
- 
Returns the length of the value associated withhashKey.
- lengthOfValue(H, HK) - Method in interface org.springframework.data.redis.core.HashOperations
- 
Returns the length of the value associated withhashKey.
- 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-relatedLettuceClientConfiguration.
- LettuceClusterConnection - Class in org.springframework.data.redis.connection.lettuce
- 
RedisClusterConnectionimplementation 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 newLettuceClusterConnectiongiven a sharedStatefulRedisClusterConnectionandLettuceConnectionProviderrunning commands across the cluster via givenClusterCommandExecutor.
- LettuceClusterConnection(RedisClusterClient) - Constructor for class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
- 
Creates newLettuceClusterConnectionusingRedisClusterClientwith defaulttimeoutand a freshClusterCommandExecutorthat gets destroyed on close.
- LettuceClusterConnection(RedisClusterClient, ClusterCommandExecutor) - Constructor for class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
- 
Creates newLettuceClusterConnectionwith defaulttimeoutusingRedisClusterClientrunning commands across the cluster via givenClusterCommandExecutor.
- LettuceClusterConnection(RedisClusterClient, ClusterCommandExecutor, Duration) - Constructor for class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
- 
Creates newLettuceClusterConnectionwith given commandtimeoutusingRedisClusterClientrunning commands across the cluster via givenClusterCommandExecutor.
- LettuceClusterConnection(LettuceConnectionProvider) - Constructor for class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
- 
Creates newLettuceClusterConnectionusingLettuceConnectionProviderrunning commands across the cluster via givenClusterCommandExecutor.
- LettuceClusterConnection(LettuceConnectionProvider, ClusterCommandExecutor) - Constructor for class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
- 
Creates newLettuceClusterConnectionusingLettuceConnectionProviderrunning commands across the cluster via givenClusterCommandExecutor.
- LettuceClusterConnection(LettuceConnectionProvider, ClusterCommandExecutor, Duration) - Constructor for class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
- 
Creates newLettuceClusterConnectionusingLettuceConnectionProviderrunning commands across the cluster via givenClusterCommandExecutor.
- LettuceClusterConnection.LettuceClusterCommandCallback<T> - Interface in org.springframework.data.redis.connection.lettuce
- 
Lettuce specific implementation ofClusterCommandExecutor.ClusterCommandCallback.
- LettuceClusterConnection.LettuceMultiKeyClusterCommandCallback<T> - Interface in org.springframework.data.redis.connection.lettuce
- 
Lettuce specific implementation ofClusterCommandExecutor.MultiKeyClusterCommandCallback.
- LettuceConnection - Class in org.springframework.data.redis.connection.lettuce
- 
RedisConnectionimplementation on top of Lettuce Redis client.
- LettuceConnection(long, RedisClient) - Constructor for class org.springframework.data.redis.connection.lettuce.LettuceConnection
- 
Instantiates a new lettuce connection.
- LettuceConnection(StatefulRedisConnection<byte[], byte[]>, long, AbstractRedisClient, int) - Constructor for class org.springframework.data.redis.connection.lettuce.LettuceConnection
- LettuceConnection(StatefulRedisConnection<byte[], byte[]>, long, RedisClient) - Constructor for class org.springframework.data.redis.connection.lettuce.LettuceConnection
- 
Instantiates a new lettuce connection.
- LettuceConnection(StatefulRedisConnection<byte[], byte[]>, LettuceConnectionProvider, long, int) - Constructor for class org.springframework.data.redis.connection.lettuce.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 newLettuceConnectionFactoryinstance with default settings.
- LettuceConnectionFactory(String, int) - Constructor for class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
- 
Constructs a newLettuceConnectionFactoryinstance with default settings.
- LettuceConnectionFactory(RedisClusterConfiguration) - Constructor for class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
- 
Constructs a newLettuceConnectionFactoryinstance using the givenRedisClusterConfigurationapplied to create aRedisClusterClient.
- LettuceConnectionFactory(RedisClusterConfiguration, LettuceClientConfiguration) - Constructor for class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
- 
Constructs a newLettuceConnectionFactoryinstance using the givenRedisClusterConfigurationandLettuceClientConfiguration.
- LettuceConnectionFactory(RedisConfiguration) - Constructor for class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
- 
Constructs a newLettuceConnectionFactoryinstance using the givenRedisSocketConfiguration.
- LettuceConnectionFactory(RedisConfiguration, LettuceClientConfiguration) - Constructor for class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
- 
Constructs a newLettuceConnectionFactoryinstance using the givenRedisStaticMasterReplicaConfigurationandLettuceClientConfiguration.
- LettuceConnectionFactory(RedisSentinelConfiguration) - Constructor for class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
- 
Constructs a newLettuceConnectionFactoryinstance using the givenRedisSentinelConfiguration.
- LettuceConnectionFactory(RedisSentinelConfiguration, LettuceClientConfiguration) - Constructor for class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
- 
Constructs a newLettuceConnectionFactoryinstance using the givenRedisSentinelConfigurationandLettuceClientConfiguration.
- LettuceConnectionFactory(RedisStandaloneConfiguration) - Constructor for class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
- 
Constructs a newLettuceConnectionFactoryinstance with default settings.
- LettuceConnectionFactory(RedisStandaloneConfiguration, LettuceClientConfiguration) - Constructor for class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
- 
Constructs a newLettuceConnectionFactoryinstance using the givenRedisStandaloneConfigurationandLettuceClientConfiguration.
- 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 toLettuceConnectionProviderfor 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 toDataAccessExceptions
- LettuceExceptionConverter() - Constructor for class org.springframework.data.redis.connection.lettuce.LettuceExceptionConverter
- LettuceObservationContext - Class in org.springframework.data.redis.connection.lettuce.observability
- 
MicrometerObservation.Contextholding Lettuce contextual details.
- LettuceObservationContext(String) - Constructor for class org.springframework.data.redis.connection.lettuce.observability.LettuceObservationContext
- 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 toLettuceClientConfiguration.
- 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 aLettuceSentinelConnectionusing a suppliedRedisClient.
- LettuceSentinelConnection(StatefulRedisSentinelConnection<String, String>) - Constructor for class org.springframework.data.redis.connection.lettuce.LettuceSentinelConnection
- 
Creates aLettuceSentinelConnectionusing 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 aLettuceSentinelConnectionwith a client for the suppliedhostandportand reuse existingClientResources.
- LettuceSentinelConnection(LettuceConnectionProvider) - Constructor for class org.springframework.data.redis.connection.lettuce.LettuceSentinelConnection
- 
Creates aLettuceSentinelConnectionusing aLettuceConnectionProvider.
- LettuceSentinelConnection(RedisNode) - Constructor for class org.springframework.data.redis.connection.lettuce.LettuceSentinelConnection
- 
Creates aLettuceSentinelConnectionwith 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 newLettuceSubscriptiongivenMessageListener,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 betweenRange.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 betweenRange.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 betweenRange.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 betweenRange#minandRange#maxapplying 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 useBoundZSetOperations.lexCount(Range)instead.
- lexWithin(Range<String>) - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRemRangeByLexCommand
- 
Creates a newReactiveZSetCommands.ZRemRangeByLexCommandgiven 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 aLimit.
- 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 aLimit.
- 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 theLimit.
- limitTo(Limit) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRangeByScoreCommand
- 
Applies theLimit.
- lIndex(byte[], long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 atindexform 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 atindexform 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 atReactiveListCommands.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 ofRedisCommandsProvider.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
- 
InsertvalueRedisListCommands.Position.BEFOREorRedisListCommands.Position.AFTERexistingpivotforkey.
- 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
- 
InsertvalueRedisListCommands.Position.BEFOREorRedisListCommands.Position.AFTERexistingpivotforkey.
- lInsert(ByteBuffer, RedisListCommands.Position, ByteBuffer, ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveListCommands
- 
Insert valueRedisListCommands.Position.BEFOREorRedisListCommands.Position.AFTERexisting 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
- 
GetReactiveListCommands.
- listCommands() - Method in interface org.springframework.data.redis.connection.RedisCommandsProvider
- 
GetRedisListCommands.
- 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 Redischannelsand emitmessagesreceived for those.
- listenToChannelLater(String...) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
- 
Subscribe to the given Redischannelsand emitmessagesreceived 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 givenpatternand emitmessagesreceived for those.
- listenToPatternLater(String...) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
- 
Subscribe to the Redis channels matching the givenpatternand emitmessagesreceived 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 thewhere frompart for theLMOVEcommand.
- ListOperations.MoveTo<K> - Class in org.springframework.data.redis.core
- 
Value object representing thewhere tofrom part for theLMOVEcommand.
- 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 byCONFIG GET) from aListtoProperties.
- lLen(byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 atkey.
- 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 atkey.
- 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 atReactiveRedisConnection.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 ofRedisCommandsProvider.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 thefromargument) of the list stored atsourceKey, and pushes the element at the first/last element (head/tail depending on thetoargument) 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 thefromargument) of the list stored atsourceKey, and pushes the element at the first/last element (head/tail depending on thetoargument) 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 thefromargument) of the list stored atsourceKey, and pushes the element at the first/last element (head/tail depending on thetoargument) 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 thefromargument) of the list stored atsourceKey, and pushes the element at the first/last element (head/tail depending on thetoargument) 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
- location(RedisGeoCommands.GeoLocation<ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoAddCommand
- 
Creates a newReactiveGeoCommands.GeoAddCommandgivenRedisGeoCommands.GeoLocation.
- locations(Collection<RedisGeoCommands.GeoLocation<ByteBuffer>>) - Static method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoAddCommand
- 
Creates a newReactiveGeoCommands.GeoAddCommandgiven an index.
- lockingRedisCacheWriter(RedisConnectionFactory) - Static method in interface org.springframework.data.redis.cache.RedisCacheWriter
- 
Create newRedisCacheWriterwith locking behavior.
- lockingRedisCacheWriter(RedisConnectionFactory, BatchStrategy) - Static method in interface org.springframework.data.redis.cache.RedisCacheWriter
- 
Create newRedisCacheWriterwith 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 theRedisClusterNodematching given nodeId.
- lookup(String, int) - Method in class org.springframework.data.redis.connection.ClusterTopology
- 
Get theRedisClusterNodematching 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 ofRedisCommandsProvider.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 atkey.
- lPop(byte[], long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 atkey.
- 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 atkey.
- 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 atkey.
- 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 firstcountelements 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 ofRedisCommandsProvider.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 atReactiveRedisConnection.KeyCommand.getKey().
- lPos(ReactiveListCommands.LPosCommand) - Method in interface org.springframework.data.redis.connection.ReactiveListCommands
- 
Get indices of the element from list atReactiveRedisConnection.KeyCommand.getKey().
- lPosOf(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveListCommands.LPosCommand
- 
Creates a newReactiveListCommands.LPosCommandfor given element.
- lPush(byte[], byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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
- 
Prependvaluestokey.
- lPush(String, String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- lPush(String, String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
- 
Prependvaluestokey.
- 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 ofRedisCommandsProvider.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
- 
Prependvaluestokeyonly 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
- 
Prependvaluestokeyonly 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 ofRedisCommandsProvider.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 betweenstartandendfrom 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 betweenstartandendfrom 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 inReactiveRedisConnection.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 ofRedisCommandsProvider.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 firstcountoccurrences ofvaluefrom 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 firstcountoccurrences ofvaluefrom 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 theReactiveListCommands.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 ofRedisCommandsProvider.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 thevaluelist 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 thevaluelist 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 theReactiveListCommands.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 ofRedisCommandsProvider.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 atkeyto elements betweenstartandend.
- 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 atkeyto elements betweenstartandend.
- 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 atReactiveRedisConnection.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 fromMapRecordtoObjectRecords.
- map(MapRecord<K, HK, HV>, Class<V>) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
- 
Map records fromMapRecordtoObjectRecord.
- map(MapRecord<K, HK, HV>, Class<V>) - Method in interface org.springframework.data.redis.core.StreamOperations
- 
Map record fromMapRecordtoObjectRecord.
- 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 givenmapFunctionto each and every entry in the backing collection to create a newMapRecord.
- MappingConfiguration - Class in org.springframework.data.redis.core.convert
- 
MappingConfigurationis 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 newMappingConfiguration.
- MappingRedisConverter - Class in org.springframework.data.redis.core.convert
- 
RedisConverterimplementation creating flat binary map structure out of a given domain type.
- MappingRedisConverter(RedisMappingContext) - Constructor for class org.springframework.data.redis.core.convert.MappingRedisConverter
- 
Creates newMappingRedisConverter.
- MappingRedisConverter(RedisMappingContext, IndexResolver, ReferenceResolver) - Constructor for class org.springframework.data.redis.core.convert.MappingRedisConverter
- 
Creates newMappingRedisConverterand defaultsRedisMappingContextwhen null.
- MappingRedisConverter(RedisMappingContext, IndexResolver, ReferenceResolver, RedisTypeMapper) - Constructor for class org.springframework.data.redis.core.convert.MappingRedisConverter
- 
Creates newMappingRedisConverterand defaultsRedisMappingContextwhen 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 
- 
RedisEntityInformationimplementation using aRedisPersistentEntityinstance 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 
- 
ARecordwithin 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 fromMaptoProperties.
- 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 themapper functionto 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 aCollectionof monitored masters and their state.
- match(byte[]) - Method in class org.springframework.data.redis.core.ScanOptions.ScanOptionsBuilder
- 
Returns the currentScanOptions.ScanOptionsBuilderconfigured with the givenpattern.
- match(String) - Method in class org.springframework.data.redis.core.ScanOptions.ScanOptionsBuilder
- 
Returns the currentScanOptions.ScanOptionsBuilderconfigured 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 newReactiveZSetCommands.BZPopCommandfor max pop (ZPOPMAX).
- max() - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZPopCommand
- 
Creates a newReactiveZSetCommands.ZPopCommandfor 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 asStringamong 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 newReactiveGeoCommands.GeoHashCommandgiven a member.
- member(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoPosCommand
- 
Creates a newReactiveGeoCommands.GeoPosCommandgiven 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 newReactiveSetCommands.SPopCommandforcountmembers.
- members(Collection<ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoHashCommand
- 
Creates a newReactiveGeoCommands.GeoHashCommandgiven aCollectionof values.
- members(Collection<ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoPosCommand
- 
Creates a newReactiveGeoCommands.GeoPosCommandgiven aCollectionof values.
- members(K) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
- 
Get all elements of set atkey.
- members(K) - Method in interface org.springframework.data.redis.core.SetOperations
- 
Get all elements of set atkey.
- mergeArrays(byte[], byte[]...) - Static method in class org.springframework.data.redis.util.ByteUtils
- 
Merge multiplebytearrays 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 newMessageListenerAdapterwith default settings.
- MessageListenerAdapter(Object) - Constructor for class org.springframework.data.redis.listener.adapter.MessageListenerAdapter
- 
Create a newMessageListenerAdapterfor the given delegate.
- MessageListenerAdapter(Object, String) - Constructor for class org.springframework.data.redis.listener.adapter.MessageListenerAdapter
- 
Create a newMessageListenerAdapterfor the given delegate.
- messageListenerContainerRef() - Element in annotation interface org.springframework.data.redis.repository.configuration.EnableRedisRepositories
- 
Configure the name of theRedisMessageListenerContainerbean 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 newReactiveGeoCommands.GeoDistCommandforRedisGeoCommands.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
- 
Metrics supported by Redis.
- mGet(byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.stringCommands()}.
- mGet(byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- mGet(byte[]...) - Method in interface org.springframework.data.redis.connection.RedisStringCommands
- 
Get multiplekeys.
- mGet(String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- mGet(String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
- 
Get multiplekeys.
- 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
- MicrometerTracingAdapter - Class in org.springframework.data.redis.connection.lettuce.observability
- 
Tracingadapter using Micrometer'sObservation.
- MicrometerTracingAdapter(ObservationRegistry, String) - Constructor for class org.springframework.data.redis.connection.lettuce.observability.MicrometerTracingAdapter
- 
Create a newMicrometerTracingAdapterinstance.
- MicrometerTracingAdapter(ObservationRegistry, String, boolean) - Constructor for class org.springframework.data.redis.connection.lettuce.observability.MicrometerTracingAdapter
- 
Create a newMicrometerTracingAdapterinstance.
- MicrometerTracingAdapter.MicrometerTracer - Class in org.springframework.data.redis.connection.lettuce.observability
- 
Tracerimplementation based on Micrometer'sObservationRegistry.
- migrate(byte[], RedisNode, int, RedisServerCommands.MigrateOption) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 ofRedisCommandsProvider.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 newReactiveGeoCommands.GeoDistCommandforRedisGeoCommands.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 newExpirationwithTimeUnit.MILLISECONDS.
- millisecondsToTimeUnit(long, TimeUnit) - Static method in class org.springframework.data.redis.connection.convert.Converters
- 
Convertsmillisecondsto the givenTimeUnit.
- millisecondsToTimeUnit(TimeUnit) - Static method in class org.springframework.data.redis.connection.convert.Converters
- 
Creates a newConverterto convert from milliseconds to the givenTimeUnit.
- min() - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.BZPopCommand
- 
Creates a newReactiveZSetCommands.BZPopCommandfor min pop (ZPOPMIN).
- min() - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZPopCommand
- 
Creates a newReactiveZSetCommands.ZPopCommandfor 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
- 
ApplyMINIDtrimming strategy, that evicts entries with IDs lower than the one specified.
- minId(RecordId) - Method in class org.springframework.data.redis.connection.RedisStreamCommands.XAddOptions
- 
ApplyMINIDtrimming 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 givenDuration.
- 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 asStringamong 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 specifiedRedisNode.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 ofRedisCommandsProvider.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 givenkeyto 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 givenkeyto database withindex.
- move(ByteBuffer, int) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
- 
Move givenkeyto database withindex.
- move(K, int) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
- 
Move givenkeyto 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 givenkeyto 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 thefromargument) of the list stored atsourceKey, and pushes the element at the first/last element (head/tail depending on thetoargument) 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 thefromargument) of the list stored atsourceKey, and pushes the element at the first/last element (head/tail depending on thetoargument) 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 thefromargument) of the list stored atsourceKey, and pushes the element at the first/last element (head/tail depending on thetoargument) 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 thefromargument) of the list stored atsourceKey, and pushes the element at the first/last element (head/tail depending on thetoargument) 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 thefromargument) of the list stored atsourceKey, and pushes the element at the first/last element (head/tail depending on thetoargument) of the list stored atdestinationKey.
- move(K, V) - Method in interface org.springframework.data.redis.core.BoundSetOperations
- 
Movevaluefrom the bound key todestKey
- move(K, V, K) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
- 
MovevaluefromkeytodestKey
- move(K, V, K) - Method in interface org.springframework.data.redis.core.SetOperations
- 
MovevaluefromkeytodestKey
- 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 thefromargument) of the list stored at the bound key, and pushes the element at the first/last element (head/tail depending on thetoargument) 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 thefromargument) of the list stored at the bound key, and pushes the element at the first/last element (head/tail depending on thetoargument) 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 thefromargument) of the list stored at the bound key, and pushes the element at the first/last element (head/tail depending on thetoargument) 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 thefromargument) of the list stored atsourceKey, and pushes the element at the first/last element (head/tail depending on thetoargument) 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 thefromargument) of the list stored atsourceKey, and pushes the element at the first/last element (head/tail depending on thetoargument) 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 thefromargument) of the list stored atsourceKey, and pushes the element at the first/last element (head/tail depending on thetoargument) 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 thefromargument) of the list stored atsourceKey, and pushes the element at the first/last element (head/tail depending on thetoargument) 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 thedestinationPositionargument) 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 thedestinationPositionargument) 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 thedestinationPositionargument) 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 thedestinationPositionargument) 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 thedestinationPositionargument) 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 thedestinationPositionargument) of the list stored atdestination.
- moveNext(Iterator<T>) - Method in class org.springframework.data.redis.core.ScanCursor
- 
Fetch the next item from the underlyingIterable.
- mset(Map<ByteBuffer, ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveStringCommands.MSetCommand
- 
Creates a newReactiveStringCommands.MSetCommandgiven aMapof key-value tuples.
- mSet(Map<byte[], byte[]>) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 intuple.
- 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 ofRedisCommandsProvider.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 intupleonly 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 intupleonly 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 intuple.
- 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 givenhashKeysfrom hash atkey.
- multiGet(H, Collection<HK>) - Method in interface org.springframework.data.redis.core.ReactiveHashOperations
- 
Get values for givenhashKeysfrom hash atkey.
- multiGet(Collection<HK>) - Method in interface org.springframework.data.redis.core.BoundHashOperations
- 
Get values for givenkeysfrom the hash at the bound key.
- multiGet(Collection<K>) - Method in interface org.springframework.data.redis.core.ReactiveValueOperations
- 
Get multiplekeys.
- multiGet(Collection<K>) - Method in interface org.springframework.data.redis.core.ValueOperations
- 
Get multiplekeys.
- 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 newWeightsobject that contains all weights multiplied bymultiplier
- multiply(int) - Method in class org.springframework.data.redis.connection.zset.Weights
- 
Creates a newWeightsobject 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 intuple.
- 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 intuple.
- 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 intupleonly 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 intupleonly 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 thekeysfrom the keyspace.
- mUnlink(Publisher<List<ByteBuffer>>) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
- 
Unlink thekeysfrom 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.
- 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 givenStringmap.
- newGeoRadiusArgs() - Static method in class org.springframework.data.redis.connection.RedisGeoCommands.GeoRadiusCommandArgs
- 
Create newRedisGeoCommands.GeoRadiusCommandArgs.
- newGeoSearchArgs() - Static method in class org.springframework.data.redis.connection.RedisGeoCommands.GeoSearchCommandArgs
- 
Create newRedisGeoCommands.GeoSearchCommandArgs.
- newGeoSearchStoreArgs() - Static method in class org.springframework.data.redis.connection.RedisGeoCommands.GeoSearchStoreCommandArgs
- 
Create newRedisGeoCommands.GeoSearchStoreCommandArgs.
- newPartialUpdate(Object, Class<S>) - Static method in class org.springframework.data.redis.core.PartialUpdate
- 
Create newPartialUpdatefor 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 ofStreamRecords.RecordBuilderto fluently createrecords.
- newRedisClusterNode() - Static method in class org.springframework.data.redis.connection.RedisClusterNode
- 
GetRedisClusterNode.RedisClusterNodeBuilderfor creating newRedisClusterNode.
- newRedisNode() - Static method in class org.springframework.data.redis.connection.RedisNode
- 
GetRedisNode.RedisNodeBuilderfor creating newRedisNode.
- newSerializationContext() - Static method in interface org.springframework.data.redis.serializer.RedisSerializationContext
- 
Creates a newRedisSerializationContext.RedisSerializationContextBuilder.
- newSerializationContext(RedisSerializationContext.SerializationPair<?>) - Static method in interface org.springframework.data.redis.serializer.RedisSerializationContext
- 
Creates a newRedisSerializationContext.RedisSerializationContextBuilderusing a given defaultRedisSerializationContext.SerializationPair.
- newSerializationContext(RedisSerializer<?>) - Static method in interface org.springframework.data.redis.serializer.RedisSerializationContext
- 
Creates a newRedisSerializationContext.RedisSerializationContextBuilderusing a given defaultRedisSerializer.
- newServerFrom(Properties) - Static method in class org.springframework.data.redis.connection.RedisServer
- 
Creates a newRedisServerfrom 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
- nextSpan(TraceContext) - Method in class org.springframework.data.redis.connection.lettuce.observability.MicrometerTracingAdapter.MicrometerTracer
- NO_OP_SUBSCRIPTION_LISTENER - Static variable in interface org.springframework.data.redis.connection.SubscriptionListener
- 
EmptySubscriptionListener.
- noack() - Method in class org.springframework.data.redis.connection.stream.StreamReadOptions
- 
Enable auto-acknowledgement by setting theNOACKflag 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 anodeto 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 newClusterCommandExecutor.NodeResult.
- NodeResult(RedisClusterNode, T, byte[]) - Constructor for class org.springframework.data.redis.connection.ClusterCommandExecutor.NodeResult
- 
Create newClusterCommandExecutor.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 absentRedisPassword.
- 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 defaultKeyScanOptionswithout setting a limit or matching a pattern.
- NONE - Static variable in class org.springframework.data.redis.core.ScanOptions
- 
Constant to apply defaultScanOptionswithout setting a limit or matching a pattern.
- nonLockingRedisCacheWriter(RedisConnectionFactory) - Static method in interface org.springframework.data.redis.cache.RedisCacheWriter
- 
Create newRedisCacheWriterwithout locking behavior.
- nonLockingRedisCacheWriter(RedisConnectionFactory, BatchStrategy) - Static method in interface org.springframework.data.redis.cache.RedisCacheWriter
- 
Create newRedisCacheWriterwithout 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
- 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 newObjectRecordbacked by the given value.
- ObjectHashMapper - Class in org.springframework.data.redis.hash
- 
HashMapperbased onMappingRedisConverter.
- ObjectHashMapper() - Constructor for class org.springframework.data.redis.hash.ObjectHashMapper
- 
Creates newObjectHashMapper.
- ObjectHashMapper(CustomConversions) - Constructor for class org.springframework.data.redis.hash.ObjectHashMapper
- 
Creates newObjectHashMapper.
- ObjectHashMapper(RedisConverter) - Constructor for class org.springframework.data.redis.hash.ObjectHashMapper
- 
Creates a newObjectHashMapperusing the givenRedisConverterfor conversion.
- 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 
- 
ARecordwithin 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 binarykeyintoMappingRedisConverter.BinaryKeyspaceIdentifier.
- of(byte[], Double) - Static method in interface org.springframework.data.redis.connection.zset.Tuple
- 
Create a newTuple.
- of(char[]) - Static method in class org.springframework.data.redis.connection.RedisPassword
- 
Create aRedisPasswordfrom achararray.
- 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, long) - Static method in class org.springframework.data.redis.connection.stream.RecordId
- 
Create a new instance ofRecordIdusing the provided String formatted as <millisecondsTime>-<sequenceNumber>.
- of(String) - Static method in class org.springframework.data.redis.connection.RedisPassword
- 
Create aRedisPasswordfrom aString.
- of(String) - Static method in class org.springframework.data.redis.connection.stream.RecordId
- 
Obtain an instance ofRecordIdusing the provided String formatted as <millisecondsTime>-<sequenceNumber>.
- of(String) - Static method in interface org.springframework.data.redis.connection.ValueEncoding
- 
Get theValueEncodingfor givenencoding.
- of(String) - Static method in class org.springframework.data.redis.core.convert.MappingRedisConverter.KeyspaceIdentifier
- 
Parse akeyintoMappingRedisConverter.KeyspaceIdentifier.
- 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 newChannelTopicfor channel subscriptions.
- of(String) - Static method in class org.springframework.data.redis.listener.PatternTopic
- 
Create a newPatternTopicfor 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(Resource) - Static method in interface org.springframework.data.redis.core.script.RedisScript
- 
Creates newRedisScript(with throw away result) from the givenResource.
- of(Resource, Class<T>) - Static method in interface org.springframework.data.redis.core.script.RedisScript
- 
Creates newRedisScriptfromResource.
- of(ByteBufferRecord) - Static method in class org.springframework.data.redis.connection.ReactiveStreamCommands.AddStreamRecord
- 
Creates a newReactiveStreamCommands.AddStreamRecordgivenbody.
- of(MapRecord<byte[], byte[], byte[]>) - Static method in interface org.springframework.data.redis.connection.stream.ByteRecord
- 
Convert a binaryMapRecordinto 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 binaryMapRecordinto aByteRecord.
- of(V) - Static method in interface org.springframework.data.redis.connection.stream.Record
- 
Create a newObjectRecordinstance backed by the given value.
- of(V, Double) - Static method in interface org.springframework.data.redis.core.ZSetOperations.TypedTuple
- 
Create a newZSetOperations.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
- 
TurnKeyExpirationEventMessageListenerusage 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 aMapRecord.
- ofObject(V) - Method in class org.springframework.data.redis.connection.stream.StreamRecords.RecordBuilder
- 
Create anObjectRecord.
- ofStrings(Map<String, String>) - Method in class org.springframework.data.redis.connection.stream.StreamRecords.RecordBuilder
- 
Create aStringRecord.
- 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 theKeyExpirationEventMessageListeneron first insert having expiration time set.
- ON_STARTUP - Enum constant in enum class org.springframework.data.redis.core.RedisKeyValueAdapter.EnableKeyspaceEvents
- 
Initializes theKeyExpirationEventMessageListeneron 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 newReactiveSetCommands.SPopCommandfor a single member.
- onErrorResume(Function<? super Throwable, ? extends Publisher<Void>>) - Method in class org.springframework.data.redis.stream.StreamReceiver.StreamReceiverOptionsBuilder
- 
Configure a resumeFunctionto 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 RedisMessageListenerentry 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 aRecord.
- 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 theCursorprior 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 aRedisSerializationContext.
- 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 aRedisSerializationContext.
- 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 aRedisSerializationContext.
- 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 aRedisSerializationContext.
- 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 aRedisSerializationContext.
- 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 aRedisSerializationContext.
- 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 aRedisSerializationContext.
- 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 thejava.util.atomicpackage in Redis.
- org.springframework.data.redis.support.collections - package org.springframework.data.redis.support.collections
- 
Package providing implementations for most of thejava.utilcollections 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 theBitFieldSubCommands.BitFieldIncrBy.Overflowto be used for this and any subsequentBitFieldSubCommands.BitFieldIncrBycommands.
- overwrite(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveStringCommands.SetRangeCommand
- 
Creates a newReactiveStringCommands.SetRangeCommandgiven 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, uninitializedOxmSerializer.
- 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 ofbyte[]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 ofbyte[]andByteBufferbased on the sourcePath and a typeHintMap
- PartialUpdate<T> - Class in org.springframework.data.redis.core
- 
PartialUpdateallows 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 newPartialUpdatefor given id and type.
- PartialUpdate(Object, T) - Constructor for class org.springframework.data.redis.core.PartialUpdate
- 
Create newPartialUpdatefor 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
- 
PassThroughExceptionTranslationStrategyreturns null for unknownExceptions.
- 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
- 
IndexDefinitionthat 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
- 
IndexResolverimplementation considering properties annotated withIndexedor paths set up inIndexConfiguration.
- PathIndexResolver() - Constructor for class org.springframework.data.redis.core.convert.PathIndexResolver
- 
Creates newPathIndexResolverwith emptyIndexConfiguration.
- PathIndexResolver(RedisMappingContext) - Constructor for class org.springframework.data.redis.core.convert.PathIndexResolver
- 
Creates newPathIndexResolverwith 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 newReactiveSubscription.PatternMessage.
- PatternTopic - Class in org.springframework.data.redis.listener
- PatternTopic(String) - Constructor for class org.springframework.data.redis.listener.PatternTopic
- 
Constructs a newPatternTopicinstance.
- 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 thePendingMessagesSummaryfor a given consumer group.
- pending(K, String) - Method in interface org.springframework.data.redis.core.StreamOperations
- 
Obtain thePendingMessagesSummaryfor a given consumer group.
- pending(K, String, Range<?>, long) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
- 
Obtain detailed information about pendingmessagesfor a givenRangewithin a consumer group.
- pending(K, String, Range<?>, long) - Method in interface org.springframework.data.redis.core.StreamOperations
- 
Obtain detailed information about pendingmessagesfor a givenRangewithin a consumer group.
- pending(K, Consumer) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
- 
Obtained detailed information about all pending messages for a givenConsumer.
- pending(K, Consumer) - Method in interface org.springframework.data.redis.core.StreamOperations
- 
Obtained detailed information about all pending messages for a givenConsumer.
- 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 givenRangeand 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 newReactiveStringCommands.BitOpCommandgiven 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 ofRedisCommandsProvider.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 givenkey.
- 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 givenkey.
- persist(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
- 
Remove the expiration from givenkey.
- persist(K) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
- 
Remove the expiration from givenkey.
- 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 givenkey.
- 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 givenkey.
- PERSIST - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- persistent() - Static method in class org.springframework.data.redis.core.types.Expiration
- 
Creates new persistentExpiration.
- pExpire(byte[], long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 givenkeyin 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 givenkeyin milliseconds.
- pExpire(ByteBuffer, Duration) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
- 
Set time to live for givenkeyin 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 ofRedisCommandsProvider.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 givenkeyas 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 givenkeyas a UNIX timestamp in milliseconds.
- pExpireAt(ByteBuffer, Instant) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
- 
Set the expiration for givenkeyas a UNIX timestamp.
- pExpireAt(Publisher<ReactiveKeyCommands.ExpireAtCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
- 
Set one-by-one the expiration for givenkeyas 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 ofRedisCommandsProvider.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 ofRedisCommandsProvider.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 ofRedisCommandsProvider.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 theBLOCKoption during reading.
- pollTimeout(Duration) - Method in class org.springframework.data.redis.stream.StreamReceiver.StreamReceiverOptionsBuilder
- 
Configure a poll timeout for theBLOCKoption 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 theGenericObjectPoolConfigused 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 newPoolExceptioninstance.
- PoolException(String, Throwable) - Constructor for exception org.springframework.data.redis.connection.PoolException
- 
Constructs a newPoolExceptioninstance.
- 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 atkey.
- pop(K) - Method in interface org.springframework.data.redis.core.SetOperations
- 
Remove and return a random member from set atkey.
- pop(K, long) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
- 
Remove and returncountrandom members from set atkey.
- pop(K, long) - Method in interface org.springframework.data.redis.core.SetOperations
- 
Remove and returncountrandom 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 atReactiveRedisConnection.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 atReactiveRedisConnection.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 returncountvalues 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 atkey.
- 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 atkey.
- popMax(K, long) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- 
Remove and returncountvalues 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 returncountvalues 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 atkey.
- 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 atkey.
- 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 atkey.
- 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 returncountvalues 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 atkey.
- 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 atkey.
- popMin(K, long) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- 
Remove and returncountvalues 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 returncountvalues 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 atkey.
- 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 atkey.
- 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 atkey.
- 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 thePointrepresentation of positions for one or more members.
- position(K, M...) - Method in interface org.springframework.data.redis.core.GeoOperations
- 
Get thePointrepresentation of positions for one or more members.
- position(K, M...) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
- 
Get thePointrepresentation of positions for one or more members.
- position(M...) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
- 
Get thePointrepresentation of positions for one or more members.
- POSITIVE_INFINITY_BYTES - Static variable in class org.springframework.data.redis.connection.lettuce.LettuceConverters
- 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 thePublisher.
- 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 thecache namewith the given value.
- prefixed(String) - Static method in interface org.springframework.data.redis.cache.CacheKeyPrefix
- 
Creates aCacheKeyPrefixscheme that prefixes cache keys with the givenprefix.
- preProcessCacheValue(Object) - Method in class org.springframework.data.redis.cache.RedisCache
- 
Customization hook called before passing object toRedisSerializer.
- 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 ofRedisCommandsProvider.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 thevalueand expiration inmillisecondsforkey.
- 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 thevalueand expiration inmillisecondsforkey.
- pSetEX(ByteBuffer, ByteBuffer, Expiration) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
- 
Set key value pair andExpiration.
- pSetEX(Publisher<ReactiveStringCommands.SetCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
- 
Set key value pairs andExpiration.
- 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 givenpatterns.
- pSubscribe(ByteBuffer...) - Method in interface org.springframework.data.redis.connection.ReactiveSubscription
- 
Subscribes to the channelpatternsand 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 ofRedisCommandsProvider.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 forkeyin milliseconds.
- pTtl(byte[], TimeUnit) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 forkeyin 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 forkeyin 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 forkeyin and convert it to the givenTimeUnit.
- pTtl(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
- 
Get the time to live forkeyin 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 givenmessageto the givenchannel.
- publish(Publisher<ReactiveSubscription.ChannelMessage<ByteBuffer, ByteBuffer>>) - Method in interface org.springframework.data.redis.connection.ReactivePubSubCommands
- 
Publishes the given messages to theappropriate channels.
- publishEvent(RedisKeyExpiredEvent) - Method in class org.springframework.data.redis.listener.KeyExpirationEventMessageListener
- 
Publish the event in case anApplicationEventPublisheris 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 byReactiveSubscription.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 thevalueof a hashkeyat the bound key.
- put(H, HK, HV) - Method in interface org.springframework.data.redis.core.HashOperations
- 
Set thevalueof a hashhashKey.
- put(H, HK, HV) - Method in interface org.springframework.data.redis.core.ReactiveHashOperations
- 
Set thevalueof 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 avalueatkeyconsidering top-level/nesting.
- put(String, byte[]) - Method in class org.springframework.data.redis.core.convert.Bucket
- 
AddStringrepresentation 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 an 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 inm.
- 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 inm.
- 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 inmat 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 thevalueof a hashkeyonly ifkeydoes not exist.
- putIfAbsent(H, HK, HV) - Method in interface org.springframework.data.redis.core.HashOperations
- 
Set thevalueof a hashhashKeyonly ifhashKeydoes not exist.
- putIfAbsent(H, HK, HV) - Method in interface org.springframework.data.redis.core.ReactiveHashOperations
- 
Set thevalueof a hashhashKeyonly ifhashKeydoes 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 RedisQuery-by-Exampleoperations.
- 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 theQueryLookupStrategyto be used for lookup queries for query methods.
- QueryUtils - Class in org.springframework.data.redis.core.query
- 
Utilities forSortQueryimplementations.
- 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 applyingMetric.
- 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 applyingMetric.
- 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 applyingMetricandRedisGeoCommands.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 applyingMetricandRedisGeoCommands.GeoRadiusCommandArgs.
- radius(K, Circle) - Method in interface org.springframework.data.redis.core.GeoOperations
- 
Get the members within the boundaries of a givenCircle.
- radius(K, Circle) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
- 
Get the members within the boundaries of a givenCircle.
- radius(K, Circle, RedisGeoCommands.GeoRadiusCommandArgs) - Method in interface org.springframework.data.redis.core.GeoOperations
- 
Get the members within the boundaries of a givenCircleapplyingRedisGeoCommands.GeoRadiusCommandArgs.
- radius(K, Circle, RedisGeoCommands.GeoRadiusCommandArgs) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
- 
Get the members within the boundaries of a givenCircleapplyingRedisGeoCommands.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 applyingMetric.
- 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 applyingMetricandRedisGeoCommands.GeoRadiusCommandArgs.
- radius(Circle) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
- 
Get the members within the boundaries of a givenCircle.
- radius(Circle, RedisGeoCommands.GeoRadiusCommandArgs) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
- 
Get the members within the boundaries of a givenCircleapplyingRedisGeoCommands.GeoRadiusCommandArgs.
- RadiusShape - Class in org.springframework.data.redis.domain.geo
- 
Radius defined byDistance.
- 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 atkey.
- randomEntries(H, long) - Method in interface org.springframework.data.redis.core.ReactiveHashOperations
- 
Return random entries from the hash stored atkey.
- 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 atkey.
- randomEntry(H) - Method in interface org.springframework.data.redis.core.ReactiveHashOperations
- 
Return a random entry from the hash stored atkey.
- randomKey() - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 atkey.
- randomKey(H) - Method in interface org.springframework.data.redis.core.ReactiveHashOperations
- 
Return a random hash key (aka field) from the hash stored atkey.
- 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 fromRedisNode.
- 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 atkey.
- randomKeys(H, long) - Method in interface org.springframework.data.redis.core.ReactiveHashOperations
- 
Return random hash keys (aka fields) from the hash stored atkey.
- 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 atkey.
- randomMember(K) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- 
Get random element from set atkey.
- randomMember(K) - Method in interface org.springframework.data.redis.core.SetOperations
- 
Get random element from set atkey.
- randomMember(K) - Method in interface org.springframework.data.redis.core.ZSetOperations
- 
Get random element from set atkey.
- randomMembers(long) - Method in interface org.springframework.data.redis.core.BoundSetOperations
- 
Getcountrandom elements from set at the bound key.
- randomMembers(long) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
- 
Getcountrandom elements from set at the bound key.
- randomMembers(K, long) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
- 
Getcountrandom elements from set atkey.
- randomMembers(K, long) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- 
Getcountrandom elements from set atkey.
- randomMembers(K, long) - Method in interface org.springframework.data.redis.core.SetOperations
- 
Getcountrandom elements from set atkey.
- randomMembers(K, long) - Method in interface org.springframework.data.redis.core.ZSetOperations
- 
Getcountrandom elements from set atkey.
- randomMembersWithScore(long) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
- 
Getcountrandom elements with their score from set at the bound key.
- randomMembersWithScore(K, long) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- 
Getcountrandom elements with their score from set atkey.
- randomMembersWithScore(K, long) - Method in interface org.springframework.data.redis.core.ZSetOperations
- 
Getcountrandom 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 atkey.
- randomMemberWithScore(K) - Method in interface org.springframework.data.redis.core.ZSetOperations
- 
Get random element with its score from set atkey.
- 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 betweenbeginandendfrom list at the bound key.
- range(long, long) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
- 
Get elements betweenstartandendfrom 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 betweenstartandendfrom list at the bound key.
- range(long, long) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
- 
Get elements betweenstartandendfrom 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 specificRange.
- range(Class<V>, K, Range<String>) - Method in interface org.springframework.data.redis.core.StreamOperations
- 
Read all records from a stream within a specificRangeasObjectRecord.
- range(Class<V>, K, Range<String>, Limit) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
- 
Read records from a stream within a specificRangeapplying aLimit.
- 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 betweenbeginandendfrom list atkey.
- range(K, long, long) - Method in interface org.springframework.data.redis.core.ReactiveListOperations
- 
Get elements betweenbeginandendfrom list atkey.
- range(K, long, long) - Method in interface org.springframework.data.redis.core.ZSetOperations
- 
Get elements betweenstartandendfrom sorted set.
- range(K, Range<Long>) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- 
Get elements betweenstartandendfrom sorted set.
- range(K, Range<String>) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
- 
Read records from a stream within a specificRange.
- range(K, Range<String>) - Method in interface org.springframework.data.redis.core.StreamOperations
- 
Read records from a stream within a specificRange.
- range(K, Range<String>, Limit) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
- 
Read records from a stream within a specificRangeapplying aLimit.
- range(K, Range<String>, Limit) - Method in interface org.springframework.data.redis.core.StreamOperations
- 
Read records from a stream within a specificRangeapplying aLimit.
- range(Range<?>, Long) - Static method in class org.springframework.data.redis.connection.RedisStreamCommands.XPendingOptions
- 
Create newRedisStreamCommands.XPendingOptionswith givenRangeand limit.
- range(Range<String>) - Method in interface org.springframework.data.redis.core.BoundStreamOperations
- 
Read records from a stream within a specificRange.
- range(Range<String>, Long) - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.PendingRecordsCommand
- 
Create newReactiveStreamCommands.PendingRecordsCommandwith givenRangeand limit.
- range(Range<String>, Limit) - Method in interface org.springframework.data.redis.core.BoundStreamOperations
- 
Read records from a stream within a specificRangeapplying aLimit.
- 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 atdstKeywith 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 atdstKey, 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 atdstKeywith lexicographical ordering from ZSET atsrcKeywith a value betweenRange.getLowerBound()andRange.getUpperBound().
- rangeAndStoreByLex(K, K, Range<String>) - Method in interface org.springframework.data.redis.core.ZSetOperations
- 
Store all elements atdstKeywith lexicographical ordering from ZSET atsrcKeywith a value betweenRange.getLowerBound()andRange.getUpperBound().
- rangeAndStoreByLex(K, K, Range<String>, Limit) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- 
Store n elements atdstKey, where n =Limit.getCount(), starting atLimit.getOffset()with lexicographical ordering from ZSET atsrcKeywith a value betweenRange.getLowerBound()andRange.getUpperBound().
- rangeAndStoreByLex(K, K, Range<String>, Limit) - Method in interface org.springframework.data.redis.core.ZSetOperations
- 
Store n elements atdstKey, where n =Limit.getCount(), starting atLimit.getOffset()with lexicographical ordering from ZSET atsrcKeywith a value betweenRange.getLowerBound()andRange.getUpperBound().
- rangeAndStoreByLex(K, Range<String>) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
- 
Store all elements atdstKeywith 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 atdstKey, 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 atdstKeywith 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 atdstKey, 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 atdstKeywith ordering by score from ZSET atsrcKeywith 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 atdstKey, where n =Limit.getCount(), starting atLimit.getOffset()with ordering by score from ZSET atsrcKeywith a score betweenRange.getLowerBound()andRange.getUpperBound().
- rangeAndStoreByScore(K, K, Range<Double>) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- 
Store all elements atdstKeywith ordering by score from ZSET atsrcKeywith a score betweenRange.getLowerBound()andRange.getUpperBound().
- rangeAndStoreByScore(K, K, Range<Double>, Limit) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- 
Store n elements atdstKey, where n =Limit.getCount(), starting atLimit.getOffset()with ordering by score from ZSET atsrcKeywith a score betweenRange.getLowerBound()andRange.getUpperBound().
- rangeAndStoreByScore(K, Range<? extends Number>) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
- 
Store all elements atdstKeywith 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 atdstKey, 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 atkeywith 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 atkeywith 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 atkeywith 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 atkeywith 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 useZSetOperations.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 useZSetOperations.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 betweenRange.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 betweenRange.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 useBoundZSetOperations.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 useRedisZSet.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 useBoundZSetOperations.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 useRedisZSet.rangeByLex(Range, Limit)instead.
- rangeByScore(double, double) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
- 
Get elements where score is betweenminandmaxfrom 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 betweenminandmaxfrom sorted set.
- rangeByScore(K, double, double) - Method in interface org.springframework.data.redis.core.ZSetOperations
- 
Get elements where score is betweenminandmaxfrom sorted set.
- rangeByScore(K, double, double, long, long) - Method in interface org.springframework.data.redis.core.ZSetOperations
- 
Get elements in range fromstarttoendwhere score is betweenminandmaxfrom sorted set.
- rangeByScore(K, Range<Double>) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- 
Get elements where score is betweenminandmaxfrom sorted set.
- rangeByScore(K, Range<Double>, Limit) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- 
Get elements in range fromstarttoendwhere score is betweenminandmaxfrom 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 withvaluein 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 withvaluein a sorted set.
- rank(K, Object) - Method in interface org.springframework.data.redis.core.ZSetOperations
- 
Determine the index of element withvaluein 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 useRedisSerializationContext.byteArray()instead.
- raw() - Static method in interface org.springframework.data.redis.serializer.RedisSerializationContext.SerializationPair
- 
Deprecated.since 2.2. Please use eitherRedisSerializationContext.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 newByteBufferRecordfor the given raw field/value pairs.
- rawBytes(Map<byte[], byte[]>) - Static method in class org.springframework.data.redis.connection.stream.StreamRecords
- 
Create a newByteRecordfor 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
- 
GEOADDcommand parameters.
- ReactiveGeoCommands.GeoDistCommand - Class in org.springframework.data.redis.connection
- 
GEODISTcommand parameters.
- ReactiveGeoCommands.GeoHashCommand - Class in org.springframework.data.redis.connection
- 
GEOHASHcommand parameters.
- ReactiveGeoCommands.GeoPosCommand - Class in org.springframework.data.redis.connection
- 
GEOPOScommand parameters.
- ReactiveGeoCommands.GeoRadiusByMemberCommand - Class in org.springframework.data.redis.connection
- 
GEORADIUSBYMEMBERcommand parameters.
- ReactiveGeoCommands.GeoRadiusCommand - Class in org.springframework.data.redis.connection
- 
GEORADIUScommand parameters.
- ReactiveGeoCommands.GeoSearchCommand - Class in org.springframework.data.redis.connection
- 
GEOSEARCHcommand parameters.
- ReactiveGeoCommands.GeoSearchStoreCommand - Class in org.springframework.data.redis.connection
- 
GEOSEARCHSTOREcommand 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
- 
HEXISTSReactiveRedisConnection.Command.
- ReactiveHashCommands.HGetCommand - Class in org.springframework.data.redis.connection
- ReactiveHashCommands.HRandFieldCommand - Class in org.springframework.data.redis.connection
- 
HRANDFIELDReactiveRedisConnection.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 
- 
Redis map specific operations working on a hash.
- ReactiveHyperLogLogCommands - Interface in org.springframework.data.redis.connection
- 
Redis HyperLogLog commands executed using reactive infrastructure.
- ReactiveHyperLogLogCommands.PfAddCommand - Class in org.springframework.data.redis.connection
- 
PFADDcommand parameters.
- ReactiveHyperLogLogCommands.PfCountCommand - Class in org.springframework.data.redis.connection
- 
PFCOUNTcommand parameters.
- ReactiveHyperLogLogCommands.PfMergeCommand - Class in org.springframework.data.redis.connection
- 
PFMERGEcommand parameters.
- ReactiveHyperLogLogOperations<K,V> - Interface in org.springframework.data.redis.core 
- 
Redis cardinality specific operations 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
- 
MOVEcommand parameters.
- ReactiveKeyCommands.ExpireAtCommand - Class in org.springframework.data.redis.connection
- 
EXPIREAT/PEXPIREATcommand parameters.
- ReactiveKeyCommands.ExpireCommand - Class in org.springframework.data.redis.connection
- 
EXPIRE/PEXPIREcommand parameters.
- ReactiveKeyCommands.MoveCommand - Class in org.springframework.data.redis.connection
- 
MOVEcommand parameters.
- ReactiveKeyCommands.RenameCommand - Class in org.springframework.data.redis.connection
- 
RENAMEcommand 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
- 
BLMOVEcommand parameters.
- ReactiveListCommands.BPopCommand - Class in org.springframework.data.redis.connection
- ReactiveListCommands.BRPopLPushCommand - Class in org.springframework.data.redis.connection
- 
BRPOPLPUSHcommand parameters.
- ReactiveListCommands.Direction - Enum Class in org.springframework.data.redis.connection
- ReactiveListCommands.LIndexCommand - Class in org.springframework.data.redis.connection
- 
LINDEXcommand parameters.
- ReactiveListCommands.LInsertCommand - Class in org.springframework.data.redis.connection
- 
LINSERTcommand parameters.
- ReactiveListCommands.LMoveCommand - Class in org.springframework.data.redis.connection
- 
LMOVEcommand parameters.
- ReactiveListCommands.LPosCommand - Class in org.springframework.data.redis.connection
- 
LPOScommand parameters.
- ReactiveListCommands.LRemCommand - Class in org.springframework.data.redis.connection
- 
LREMcommand parameters.
- ReactiveListCommands.LSetCommand - Class in org.springframework.data.redis.connection
- 
LSETcommand 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
- 
RPOPLPUSHcommand parameters.
- ReactiveListOperations<K,V> - Interface in org.springframework.data.redis.core 
- 
Redis list specific operations.
- 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
- 
DECRBYcommand parameters.
- ReactiveNumberCommands.HIncrByCommand<T extends Number> - Class in org.springframework.data.redis.connection
- 
HINCRBYcommand parameters.
- ReactiveNumberCommands.IncrByCommand<T extends Number> - Class in org.springframework.data.redis.connection
- 
INCRBYcommand 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-levelReactiveRedisConnection.
- 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.CommandResponseimplementation forByteBufferresponses for absent keys.
- ReactiveRedisConnection.BooleanResponse<I> - Class in org.springframework.data.redis.connection
- 
ReactiveRedisConnection.CommandResponseimplementation forBooleanresponses.
- ReactiveRedisConnection.ByteBufferResponse<I> - Class in org.springframework.data.redis.connection
- 
ReactiveRedisConnection.CommandResponseimplementation forByteBufferresponses.
- 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.Commandfor key-bound operations.
- ReactiveRedisConnection.KeyScanCommand - Class in org.springframework.data.redis.connection
- ReactiveRedisConnection.MultiValueResponse<I,O> - Class in org.springframework.data.redis.connection 
- 
ReactiveRedisConnection.CommandResponseimplementation forListresponses.
- ReactiveRedisConnection.NumericResponse<I,O extends Number> - Class in org.springframework.data.redis.connection 
- 
ReactiveRedisConnection.CommandResponseimplementation fornumericresponses.
- 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 ofReactiveSubscription.ChannelMessagefor messages received via Redis Pub/Sub listeners.
- ReactiveRedisMessageListenerContainer(ReactiveRedisConnectionFactory) - Constructor for class org.springframework.data.redis.listener.ReactiveRedisMessageListenerContainer
- 
Create a newReactiveRedisMessageListenerContainergivenReactiveRedisConnectionFactory.
- ReactiveRedisOperations<K,V> - Interface in org.springframework.data.redis.core 
- 
Interface that specified a basic set of Redis operations, implemented byReactiveRedisTemplate.
- ReactiveRedisSessionCallback<K,V, T> - Interface in org.springframework.data.redis.core 
- 
Generic callback interface for code that wants to use the sameReactiveRedisConnectionavoiding 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 implementingReactiveRedisOperations.
- ReactiveRedisTemplate(ReactiveRedisConnectionFactory, RedisSerializationContext<K, V>) - Constructor for class org.springframework.data.redis.core.ReactiveRedisTemplate
- 
Creates newReactiveRedisTemplateusing givenReactiveRedisConnectionFactoryandRedisSerializationContext.
- ReactiveRedisTemplate(ReactiveRedisConnectionFactory, RedisSerializationContext<K, V>, boolean) - Constructor for class org.springframework.data.redis.core.ReactiveRedisTemplate
- 
Creates newReactiveRedisTemplateusing givenReactiveRedisConnectionFactoryandRedisSerializationContext.
- ReactiveScriptExecutor<K> - Interface in org.springframework.data.redis.core.script
- 
ExecutesRedisScripts 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
- 
SADDcommand parameters.
- ReactiveSetCommands.SDiffCommand - Class in org.springframework.data.redis.connection
- 
SDIFFcommand parameters.
- ReactiveSetCommands.SDiffStoreCommand - Class in org.springframework.data.redis.connection
- 
SDIFFSTOREcommand parameters.
- ReactiveSetCommands.SInterCommand - Class in org.springframework.data.redis.connection
- 
SINTERcommand parameters.
- ReactiveSetCommands.SInterStoreCommand - Class in org.springframework.data.redis.connection
- 
SINTERSTOREcommand parameters.
- ReactiveSetCommands.SIsMemberCommand - Class in org.springframework.data.redis.connection
- 
SISMEMBERcommand parameters.
- ReactiveSetCommands.SMIsMemberCommand - Class in org.springframework.data.redis.connection
- 
SMISMEMBERcommand parameters.
- ReactiveSetCommands.SMoveCommand - Class in org.springframework.data.redis.connection
- 
SMOVEcommand parameters.
- ReactiveSetCommands.SPopCommand - Class in org.springframework.data.redis.connection
- 
SPOPcommand parameters.
- ReactiveSetCommands.SRandMembersCommand - Class in org.springframework.data.redis.connection
- 
SRANDMEMBERcommand parameters.
- ReactiveSetCommands.SRemCommand - Class in org.springframework.data.redis.connection
- 
SREMcommand parameters.
- ReactiveSetCommands.SUnionCommand - Class in org.springframework.data.redis.connection
- 
SUNIONcommand parameters.
- ReactiveSetCommands.SUnionStoreCommand - Class in org.springframework.data.redis.connection
- 
SUNIONSTOREcommand parameters.
- ReactiveSetOperations<K,V> - Interface in org.springframework.data.redis.core 
- 
Redis set specific operations.
- 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
- 
XACKcommand parameters.
- ReactiveStreamCommands.AddStreamRecord - Class in org.springframework.data.redis.connection
- 
XADDcommand parameters.
- ReactiveStreamCommands.DeleteCommand - Class in org.springframework.data.redis.connection
- 
XDELcommand 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/XREVRANGEcommand parameters.
- ReactiveStreamCommands.ReadCommand - Class in org.springframework.data.redis.connection
- 
XRANGE/XREVRANGEcommand parameters.
- ReactiveStreamCommands.TrimCommand - Class in org.springframework.data.redis.connection
- 
XTRIMcommand parameters.
- ReactiveStreamCommands.XClaimCommand - Class in org.springframework.data.redis.connection
- 
XCLAIMcommand parameters.
- ReactiveStreamCommands.XInfoCommand - Class in org.springframework.data.redis.connection
- ReactiveStreamOperations<K,HK, HV> - Interface in org.springframework.data.redis.core 
- 
Redis stream specific operations.
- ReactiveStringCommands - Interface in org.springframework.data.redis.connection
- 
Redis String commands executed using reactive infrastructure.
- ReactiveStringCommands.AppendCommand - Class in org.springframework.data.redis.connection
- 
APPENDcommand parameters.
- ReactiveStringCommands.BitCountCommand - Class in org.springframework.data.redis.connection
- 
BITCOUNTcommand parameters.
- ReactiveStringCommands.BitFieldCommand - Class in org.springframework.data.redis.connection
- 
BITFIELDcommand parameters.
- ReactiveStringCommands.BitOpCommand - Class in org.springframework.data.redis.connection
- 
BITOPcommand parameters.
- ReactiveStringCommands.BitPosCommand - Class in org.springframework.data.redis.connection
- ReactiveStringCommands.GetBitCommand - Class in org.springframework.data.redis.connection
- 
GETBITcommand parameters.
- ReactiveStringCommands.GetExCommand - Class in org.springframework.data.redis.connection
- 
ReactiveRedisConnection.CommandforGETEX.
- ReactiveStringCommands.MSetCommand - Class in org.springframework.data.redis.connection
- 
MSETcommand parameters.
- ReactiveStringCommands.SetBitCommand - Class in org.springframework.data.redis.connection
- 
SETBITcommand parameters.
- ReactiveStringCommands.SetCommand - Class in org.springframework.data.redis.connection
- 
SETcommand parameters.
- ReactiveStringCommands.SetRangeCommand - Class in org.springframework.data.redis.connection
- 
SETRANGEcommand parameters.
- ReactiveStringRedisTemplate - Class in org.springframework.data.redis.core
- 
String-focusedextension ofReactiveRedisTemplate.
- ReactiveStringRedisTemplate(ReactiveRedisConnectionFactory) - Constructor for class org.springframework.data.redis.core.ReactiveStringRedisTemplate
- 
Creates newReactiveRedisTemplateusing givenReactiveRedisConnectionFactoryapplying defaultStringserialization.
- ReactiveStringRedisTemplate(ReactiveRedisConnectionFactory, RedisSerializationContext<String, String>) - Constructor for class org.springframework.data.redis.core.ReactiveStringRedisTemplate
- 
Creates newReactiveRedisTemplateusing givenReactiveRedisConnectionFactoryandRedisSerializationContext.
- ReactiveStringRedisTemplate(ReactiveRedisConnectionFactory, RedisSerializationContext<String, String>, boolean) - Constructor for class org.springframework.data.redis.core.ReactiveStringRedisTemplate
- 
Creates newReactiveRedisTemplateusing givenReactiveRedisConnectionFactoryandRedisSerializationContext.
- 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.Messagerepresents 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
- 
ZADDcommand parameters.
- ReactiveZSetCommands.ZAggregateCommand - Class in org.springframework.data.redis.connection
- 
ZINTER/ZUNIONcommand parameters.
- ReactiveZSetCommands.ZAggregateStoreCommand - Class in org.springframework.data.redis.connection
- 
ZINTERSTORE/ZUNIONSTOREcommand parameters.
- ReactiveZSetCommands.ZCountCommand - Class in org.springframework.data.redis.connection
- 
ZCOUNTcommand parameters.
- ReactiveZSetCommands.ZDiffCommand - Class in org.springframework.data.redis.connection
- 
ZDIFFcommand parameters.
- ReactiveZSetCommands.ZDiffStoreCommand - Class in org.springframework.data.redis.connection
- 
ZDIFFSTOREcommand parameters.
- ReactiveZSetCommands.ZIncrByCommand - Class in org.springframework.data.redis.connection
- 
ZINCRBYcommand parameters.
- ReactiveZSetCommands.ZInterStoreCommand - Class in org.springframework.data.redis.connection
- 
ZINTERSTOREcommand parameters.
- ReactiveZSetCommands.ZLexCountCommand - Class in org.springframework.data.redis.connection
- 
ZLEXCOUNTcommand parameters.
- ReactiveZSetCommands.ZMScoreCommand - Class in org.springframework.data.redis.connection
- 
ZMSCOREcommand parameters.
- ReactiveZSetCommands.ZPopCommand - Class in org.springframework.data.redis.connection
- 
ZPOPMIN/ZPOPMAX command parameters.
- ReactiveZSetCommands.ZRandMemberCommand - Class in org.springframework.data.redis.connection
- 
ZRANDMEMBERcommand 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
- 
ZRANGESTOREcommand 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
- 
ZREMcommand parameters.
- ReactiveZSetCommands.ZRemRangeByLexCommand - Class in org.springframework.data.redis.connection
- 
ZREMRANGEBYLEXcommand parameters.
- ReactiveZSetCommands.ZRemRangeByRankCommand - Class in org.springframework.data.redis.connection
- 
ZREMRANGEBYRANKcommand parameters.
- ReactiveZSetCommands.ZRemRangeByScoreCommand - Class in org.springframework.data.redis.connection
- 
ZREMRANGEBYSCOREcommand parameters.
- ReactiveZSetCommands.ZScoreCommand - Class in org.springframework.data.redis.connection
- 
ZSCOREcommand parameters.
- ReactiveZSetCommands.ZUnionStoreCommand - Class in org.springframework.data.redis.connection
- 
ZUNIONSTOREcommand parameters.
- ReactiveZSetOperations<K,V> - Interface in org.springframework.data.redis.core 
- 
Redis ZSet/sorted set specific operations.
- 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 theJavaType.
- 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 moreStreamOffsets 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 moreStreamOffsets 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 moreStreamOffsets 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 moreStreamOffsets using a consumer group asObjectRecord.
- read(Class<V>, StreamOffset<K>) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
- 
Read records from aStreamOffsetasObjectRecord.
- read(Class<V>, StreamOffset<K>...) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
- 
Read records from one or moreStreamOffsets asObjectRecord.
- read(Class<V>, StreamOffset<K>...) - Method in interface org.springframework.data.redis.core.StreamOperations
- 
Read records from one or moreStreamOffsets asObjectRecord.
- read(Class<V>, StreamReadOptions, StreamOffset<K>...) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
- 
Read records from one or moreStreamOffsets asObjectRecord.
- read(Class<V>, StreamReadOptions, StreamOffset<K>...) - Method in interface org.springframework.data.redis.core.StreamOperations
- 
Read records from one or moreStreamOffsets asObjectRecord.
- read(ByteBuffer) - Method in interface org.springframework.data.redis.serializer.RedisElementReader
- 
Deserialize aByteBufferinto the according type.
- read(ByteBuffer) - Method in interface org.springframework.data.redis.serializer.RedisSerializationContext.SerializationPair
- 
Deserialize aByteBufferinto the according type.
- read(Publisher<ReactiveStreamCommands.ReadCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
- 
Read records from one or moreStreamOffsets.
- read(Consumer, ReadOffset) - Method in interface org.springframework.data.redis.core.BoundStreamOperations
- 
Read records starting fromReadOffset. using a consumer group.
- read(Consumer, StreamOffset<K>...) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
- 
Read records from one or moreStreamOffsets using a consumer group.
- read(Consumer, StreamOffset<K>...) - Method in interface org.springframework.data.redis.core.StreamOperations
- 
Read records from one or moreStreamOffsets using a consumer group.
- read(Consumer, StreamReadOptions, ReadOffset) - Method in interface org.springframework.data.redis.core.BoundStreamOperations
- 
Read records starting fromReadOffset. using a consumer group.
- read(Consumer, StreamReadOptions, StreamOffset<K>...) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
- 
Read records from one or moreStreamOffsets using a consumer group.
- read(Consumer, StreamReadOptions, StreamOffset<K>...) - Method in interface org.springframework.data.redis.core.StreamOperations
- 
Read records from one or moreStreamOffsets using a consumer group.
- read(ReadOffset) - Method in interface org.springframework.data.redis.core.BoundStreamOperations
- 
Read records fromReadOffset.
- read(StreamOffset<K>) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
- 
Read records from aStreamOffsetasObjectRecord.
- read(StreamOffset<K>...) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
- 
Read records from one or moreStreamOffsets.
- read(StreamOffset<K>...) - Method in interface org.springframework.data.redis.core.StreamOperations
- 
Read records from one or moreStreamOffsets.
- read(StreamReadOptions, ReadOffset) - Method in interface org.springframework.data.redis.core.BoundStreamOperations
- 
Read records starting fromReadOffset.
- read(StreamReadOptions, StreamOffset<K>...) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
- 
Read records from one or moreStreamOffsets.
- read(StreamReadOptions, StreamOffset<K>...) - Method in interface org.springframework.data.redis.core.StreamOperations
- 
Read records from one or moreStreamOffsets.
- ReadCommand(List<StreamOffset<ByteBuffer>>, StreamReadOptions, Consumer) - Constructor for class org.springframework.data.redis.connection.ReactiveStreamCommands.ReadCommand
- readFrom(ReadFrom) - Method in class org.springframework.data.redis.connection.lettuce.LettuceClientConfiguration.LettuceClientConfigurationBuilder
- 
ConfigureReadFrom.
- 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 emittingmessages.
- receive(Iterable<? extends Topic>, SubscriptionListener) - Method in class org.springframework.data.redis.listener.ReactiveRedisMessageListenerContainer
- 
Subscribe to one or moreTopics 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 moreTopics 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 moreTopics 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 moreChannelTopics and receive a stream ofReactiveSubscription.ChannelMessage.
- receive(PatternTopic...) - Method in class org.springframework.data.redis.listener.ReactiveRedisMessageListenerContainer
- 
Subscribe to one or morePatternTopics 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 moreTopics and receive a stream ofReactiveSubscription.ChannelMessage.
- receiveLater(ChannelTopic...) - Method in class org.springframework.data.redis.listener.ReactiveRedisMessageListenerContainer
- 
Subscribe to one or moreChannelTopics and receive a stream ofReactiveSubscription.ChannelMessageonce the returnedMonocompletes.
- receiveLater(PatternTopic...) - Method in class org.springframework.data.redis.listener.ReactiveRedisMessageListenerContainer
- 
Subscribe to one or morePatternTopics and receive a stream ofReactiveSubscription.PatternMessageonce the returnedMonocompletes.
- Record<S,V> - Interface in org.springframework.data.redis.connection.stream 
- 
A single entry in the stream consisting of theentry-idand the actual entry-value (typically a collection offield/value pairs).
- RecordId - Class in org.springframework.data.redis.connection.stream
- 
The id of a singleRecordwithin 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
- 
Timer created around a Redis command execution.
- RedisAccessor - Class in org.springframework.data.redis.core
- 
Base class forRedisTemplatedefining common properties.
- RedisAccessor() - Constructor for class org.springframework.data.redis.core.RedisAccessor
- RedisAssertions - Class in org.springframework.data.redis.util
- 
Abstract utility class for common assertions used in Spring Data Redis.
- RedisAssertions() - Constructor for class org.springframework.data.redis.util.RedisAssertions
- 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 newRedisAtomicDoubleinstance.
- RedisAtomicDouble(String, RedisConnectionFactory, double) - Constructor for class org.springframework.data.redis.support.atomic.RedisAtomicDouble
- 
Constructs a newRedisAtomicDoubleinstance with ainitialValuethat overwrites the existing value.
- RedisAtomicDouble(String, RedisOperations<String, Double>) - Constructor for class org.springframework.data.redis.support.atomic.RedisAtomicDouble
- 
Constructs a newRedisAtomicDoubleinstance.
- RedisAtomicDouble(String, RedisOperations<String, Double>, double) - Constructor for class org.springframework.data.redis.support.atomic.RedisAtomicDouble
- 
Constructs a newRedisAtomicDoubleinstance with ainitialValuethat 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 newRedisAtomicIntegerinstance.
- RedisAtomicInteger(String, RedisConnectionFactory, int) - Constructor for class org.springframework.data.redis.support.atomic.RedisAtomicInteger
- 
Constructs a newRedisAtomicIntegerinstance with ainitialValuethat overwrites the existing value.
- RedisAtomicInteger(String, RedisOperations<String, Integer>) - Constructor for class org.springframework.data.redis.support.atomic.RedisAtomicInteger
- 
Constructs a newRedisAtomicIntegerinstance.
- RedisAtomicInteger(String, RedisOperations<String, Integer>, int) - Constructor for class org.springframework.data.redis.support.atomic.RedisAtomicInteger
- 
Constructs a newRedisAtomicIntegerinstance instance with ainitialValuethat 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 newRedisAtomicLonginstance.
- RedisAtomicLong(String, RedisConnectionFactory, long) - Constructor for class org.springframework.data.redis.support.atomic.RedisAtomicLong
- 
Constructs a newRedisAtomicLonginstance with ainitialValuethat overwrites the existing value atredisCounter.
- RedisAtomicLong(String, RedisOperations<String, Long>) - Constructor for class org.springframework.data.redis.support.atomic.RedisAtomicLong
- 
Constructs a newRedisAtomicLonginstance.
- RedisAtomicLong(String, RedisOperations<String, Long>, long) - Constructor for class org.springframework.data.redis.support.atomic.RedisAtomicLong
- 
Constructs a newRedisAtomicLonginstance with ainitialValuethat overwrites the existing value.
- RedisCache - Class in org.springframework.data.redis.cache
- 
Cacheimplementation using for Redis as the underlying store for cache data.
- RedisCache(String, RedisCacheWriter, RedisCacheConfiguration) - Constructor for class org.springframework.data.redis.cache.RedisCache
- 
Create a newRedisCache.
- RedisCacheConfiguration - Class in org.springframework.data.redis.cache
- 
ImmutableRedisCacheConfigurationused to customizeRedisCachebehaviour, such as caching null values, computing cache key prefixes and handling binary serialization.
- RedisCacheManager - Class in org.springframework.data.redis.cache
- 
CacheManagerbacked by aRedisCache.
- RedisCacheManager(RedisCacheWriter, RedisCacheConfiguration) - Constructor for class org.springframework.data.redis.cache.RedisCacheManager
- 
Creates a newRedisCacheManagerinitialized with the givenRedisCacheWriterand a defaultRedisCacheConfiguration.
- RedisCacheManager(RedisCacheWriter, RedisCacheConfiguration, boolean, String...) - Constructor for class org.springframework.data.redis.cache.RedisCacheManager
- 
Creates a newRedisCacheManagerinitialized with the givenRedisCacheWriterand defaultRedisCacheConfiguration, and 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 newRedisCacheManagerinitialized with the givenRedisCacheWriterand a defaultRedisCacheConfiguration, and whether to allowRedisCachecreation at runtime.
- RedisCacheManager(RedisCacheWriter, RedisCacheConfiguration, String...) - Constructor for class org.springframework.data.redis.cache.RedisCacheManager
- 
Creates a newRedisCacheManagerinitialized with the givenRedisCacheWriterand a defaultRedisCacheConfiguration, along with an optional, initial set ofcache namesused to createRedis cacheson 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.
- RedisCacheManager.RedisCacheManagerBuilder - Class in org.springframework.data.redis.cache
- 
Builder for creating aRedisCacheManager.
- RedisCacheWriter - Interface in org.springframework.data.redis.cache
- 
RedisCacheWriterprovides low level access to Redis commands (SET, SETNX, GET, EXPIRE,...) used for caching.
- 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
- 
RedisClientInfoprovides general and statistical information about client connections.
- RedisClientInfo(Properties) - Constructor for class org.springframework.data.redis.core.types.RedisClientInfo
- 
CreateRedisClientInfofromProperties.
- 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 toRedisClusterCommandsand the segregated command interfaces.
- RedisClusterConfiguration - Class in org.springframework.data.redis.connection
- 
Configuration class used for setting upRedisConnectionviaRedisConnectionFactoryusing connecting to Redis Cluster.
- RedisClusterConfiguration() - Constructor for class org.springframework.data.redis.connection.RedisClusterConfiguration
- 
Creates newRedisClusterConfiguration.
- RedisClusterConfiguration(Collection<String>) - Constructor for class org.springframework.data.redis.connection.RedisClusterConfiguration
- 
CreatesRedisClusterConfigurationfor given hostPort combinations.
- RedisClusterConfiguration(PropertySource<?>) - Constructor for class org.springframework.data.redis.connection.RedisClusterConfiguration
- 
CreatesRedisClusterConfigurationlooking up values in givenPropertySource.
- RedisClusterConnection - Interface in org.springframework.data.redis.connection
- 
RedisClusterConnectionallows 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 newRedisClusterNodewith an id and emptyRedisClusterNode.SlotRange.
- RedisClusterNode(String, int) - Constructor for class org.springframework.data.redis.connection.RedisClusterNode
- 
Creates newRedisClusterNodewith emptyRedisClusterNode.SlotRange.
- RedisClusterNode(String, int, RedisClusterNode.SlotRange) - Constructor for class org.springframework.data.redis.connection.RedisClusterNode
- 
Creates newRedisClusterNodewith givenRedisClusterNode.SlotRange.
- RedisClusterNode(RedisClusterNode.SlotRange) - Constructor for class org.springframework.data.redis.connection.RedisClusterNode
- 
Creates newRedisClusterNodewith 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 newRedisClusterNode.
- 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 theCollectioncontract.
- 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
- 
Enumerationof 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 toRedisCommandsand 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
- 
RedisConfigurationpart suitable for configurations that may use authentication when connecting.
- RedisConfiguration.WithDatabaseIndex - Interface in org.springframework.data.redis.connection
- 
RedisConfigurationpart suitable for configurations that use a specific database.
- RedisConfiguration.WithDomainSocket - Interface in org.springframework.data.redis.connection
- 
RedisConfigurationpart suitable for configurations that use native domain sockets for connecting.
- RedisConfiguration.WithHostAndPort - Interface in org.springframework.data.redis.connection
- 
RedisConfigurationpart suitable for configurations that use host/port combinations for connecting.
- RedisConfiguration.WithPassword - Interface in org.springframework.data.redis.connection
- 
RedisConfigurationpart 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 obtainingRedisConnectionfrom aRedisConnectionFactory.
- RedisConnectionUtils() - Constructor for class org.springframework.data.redis.core.RedisConnectionUtils
- RedisConnectionUtils.RedisConnectionProxy - Interface in org.springframework.data.redis.core
- 
Subinterface ofRedisConnectionto be implemented byRedisConnectionproxies.
- RedisConverter - Interface in org.springframework.data.redis.core.convert
- 
Redis specificEntityConverter.
- redisCredentialsProviderFactory(RedisCredentialsProviderFactory) - Method in class org.springframework.data.redis.connection.lettuce.LettuceClientConfiguration.LettuceClientConfigurationBuilder
- 
Configure aRedisCredentialsProviderFactoryto obtainRedisCredentialsProviderinstances 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 createRedisCredentialsProviderfrom aRedisConfiguration.
- RedisCredentialsProviderFactory.AbsentRedisCredentials - Enum Class in org.springframework.data.redis.connection.lettuce
- 
Default anonymousRedisCredentialswithout 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 emptyRedisCustomConversionsobject.
- RedisCustomConversions(List<?>) - Constructor for class org.springframework.data.redis.core.convert.RedisCustomConversions
- 
Creates a newRedisCustomConversionsinstance registering the given converters.
- RedisData - Class in org.springframework.data.redis.core.convert
- 
Data object holdingBucketrepresenting 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
- 
Metrics supported by Redis.
- RedisGeoCommands.GeoCommandArgs - Interface in org.springframework.data.redis.connection
- 
Arguments to be used withRedisGeoCommands.
- 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.GeoLocationrepresenting aPointassociated with a name.
- RedisGeoCommands.GeoRadiusCommandArgs - Class in org.springframework.data.redis.connection
- 
Additional arguments (like count/sort/...) to be used withRedisGeoCommands.
- 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 withRedisGeoCommands.
- RedisGeoCommands.GeoSearchStoreCommandArgs - Class in org.springframework.data.redis.connection
- 
Additional arguments (like count/sort/...) to be used withRedisGeoCommands.
- RedisHash - Annotation Interface in org.springframework.data.redis.core
- 
RedisHashmarks 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 aRuntimeHintsinstance 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
- 
BaseIndexDefinitionimplementation.
- RedisIndexDefinition(String, String, String) - Constructor for class org.springframework.data.redis.core.index.RedisIndexDefinition
- 
Creates newRedisIndexDefinition.
- 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/deadSubscription.
- RedisInvalidSubscriptionException(String) - Constructor for exception org.springframework.data.redis.connection.RedisInvalidSubscriptionException
- 
Constructs a newRedisInvalidSubscriptionExceptioninstance.
- RedisInvalidSubscriptionException(String, Throwable) - Constructor for exception org.springframework.data.redis.connection.RedisInvalidSubscriptionException
- 
Constructs a newRedisInvalidSubscriptionExceptioninstance.
- RedisKeyCommands - Interface in org.springframework.data.redis.connection
- 
Key-specific commands supported by Redis.
- RedisKeyExpiredEvent<T> - Class in org.springframework.data.redis.core
- 
RedisKeyExpiredEventis a Redis specificApplicationEventpublished when a particular key in Redis expires.
- RedisKeyExpiredEvent(byte[]) - Constructor for class org.springframework.data.redis.core.RedisKeyExpiredEvent
- 
Creates newRedisKeyExpiredEvent.
- RedisKeyExpiredEvent(byte[], Object) - Constructor for class org.springframework.data.redis.core.RedisKeyExpiredEvent
- 
Creates newRedisKeyExpiredEvent
- RedisKeyExpiredEvent(String, byte[], Object) - Constructor for class org.springframework.data.redis.core.RedisKeyExpiredEvent
- 
Creates newRedisKeyExpiredEvent
- RedisKeyspaceEvent - Class in org.springframework.data.redis.core
- 
Redis specificApplicationEventpublished when a key expires in Redis.
- RedisKeyspaceEvent(byte[]) - Constructor for class org.springframework.data.redis.core.RedisKeyspaceEvent
- 
Creates newRedisKeyspaceEvent.
- RedisKeyspaceEvent(String, byte[]) - Constructor for class org.springframework.data.redis.core.RedisKeyspaceEvent
- 
Creates newRedisKeyspaceEvent.
- RedisKeyValueAdapter - Class in org.springframework.data.redis.core
- 
Redis specificKeyValueAdapterimplementation.
- RedisKeyValueAdapter() - Constructor for class org.springframework.data.redis.core.RedisKeyValueAdapter
- 
Default constructor.
- RedisKeyValueAdapter(RedisOperations<?, ?>) - Constructor for class org.springframework.data.redis.core.RedisKeyValueAdapter
- 
Creates newRedisKeyValueAdapterwith defaultRedisMappingContextand defaultRedisCustomConversions.
- RedisKeyValueAdapter(RedisOperations<?, ?>, RedisConverter) - Constructor for class org.springframework.data.redis.core.RedisKeyValueAdapter
- 
Creates newRedisKeyValueAdapterwith specificRedisConverter.
- RedisKeyValueAdapter(RedisOperations<?, ?>, RedisMappingContext) - Constructor for class org.springframework.data.redis.core.RedisKeyValueAdapter
- 
Creates newRedisKeyValueAdapterwith defaultRedisCustomConversions.
- RedisKeyValueAdapter(RedisOperations<?, ?>, RedisMappingContext, CustomConversions) - Constructor for class org.springframework.data.redis.core.RedisKeyValueAdapter
- 
Creates newRedisKeyValueAdapter.
- 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 publishingRedisKeyspaceEvent.
- RedisKeyValueAdapterBean - Class in org.springframework.data.redis.repository.cdi
- 
CdiBeanto createRedisKeyValueAdapterinstances.
- RedisKeyValueAdapterBean(Bean<RedisOperations<?, ?>>, Set<Annotation>, BeanManager) - Constructor for class org.springframework.data.redis.repository.cdi.RedisKeyValueAdapterBean
- 
Creates a newRedisKeyValueAdapterBean.
- RedisKeyValueCallback() - Constructor for class org.springframework.data.redis.core.RedisKeyValueTemplate.RedisKeyValueCallback
- RedisKeyValueTemplate - Class in org.springframework.data.redis.core
- 
Redis specific implementation ofKeyValueTemplate.
- RedisKeyValueTemplate(RedisKeyValueAdapter, RedisMappingContext) - Constructor for class org.springframework.data.redis.core.RedisKeyValueTemplate
- 
Create newRedisKeyValueTemplate.
- RedisKeyValueTemplate.RedisKeyValueCallback<T> - Class in org.springframework.data.redis.core
- 
Redis specificKeyValueCallback.
- RedisKeyValueTemplateBean - Class in org.springframework.data.redis.repository.cdi
- 
CdiBeanto createRedisKeyValueTemplateinstances.
- RedisKeyValueTemplateBean(Bean<RedisKeyValueAdapter>, Set<Annotation>, BeanManager) - Constructor for class org.springframework.data.redis.repository.cdi.RedisKeyValueTemplateBean
- 
Creates a newRedisKeyValueTemplateBean.
- RedisList<E> - Interface in org.springframework.data.redis.support.collections
- 
Redis extension for theListcontract.
- 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 newRedisListenerExecutionFailedExceptioninstance.
- RedisListenerExecutionFailedException(String, Throwable) - Constructor for exception org.springframework.data.redis.listener.adapter.RedisListenerExecutionFailedException
- 
Constructs a newRedisListenerExecutionFailedExceptioninstance.
- 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 specificMappingContext.
- RedisMappingContext() - Constructor for class org.springframework.data.redis.core.mapping.RedisMappingContext
- 
Creates newRedisMappingContextwith emptyMappingConfiguration.
- RedisMappingContext(MappingConfiguration) - Constructor for class org.springframework.data.redis.core.mapping.RedisMappingContext
- 
Creates newRedisMappingContext.
- 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 newRedisNode.
- RedisNodeBuilder() - Constructor for class org.springframework.data.redis.connection.RedisNode.RedisNodeBuilder
- RedisObservation - Enum Class in org.springframework.data.redis.connection.lettuce.observability
- 
A Redis-basedObservation.
- 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 byRedisTemplate.
- 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 specificPersistentEntity.
- RedisPersistentProperty - Class in org.springframework.data.redis.core.mapping
- 
Redis specificPersistentPropertyimplementation.
- RedisPersistentProperty(Property, PersistentEntity<?, RedisPersistentProperty>, SimpleTypeHolder) - Constructor for class org.springframework.data.redis.core.mapping.RedisPersistentProperty
- 
Creates newRedisPersistentProperty.
- 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 newRedisPipelineExceptioninstance 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 newRedisPipelineExceptioninstance using a default message.
- RedisPipelineException(String, Throwable, List<Object>) - Constructor for exception org.springframework.data.redis.connection.RedisPipelineException
- 
Constructs a newRedisPipelineExceptioninstance.
- RedisPipelineException(String, List<Object>) - Constructor for exception org.springframework.data.redis.connection.RedisPipelineException
- 
Constructs a newRedisPipelineExceptioninstance.
- RedisProperties - Class in org.springframework.data.redis.support.collections
- 
Propertiesextension for a Redis back-store.
- RedisProperties(String, RedisOperations<String, ?>) - Constructor for class org.springframework.data.redis.support.collections.RedisProperties
- 
Constructs a newRedisPropertiesinstance.
- RedisProperties(Properties, String, RedisOperations<String, ?>) - Constructor for class org.springframework.data.redis.support.collections.RedisProperties
- 
Constructs a newRedisPropertiesinstance.
- RedisProperties(Properties, BoundHashOperations<String, String, String>) - Constructor for class org.springframework.data.redis.support.collections.RedisProperties
- 
Constructs a newRedisPropertiesinstance.
- RedisProperties(BoundHashOperations<String, String, String>) - Constructor for class org.springframework.data.redis.support.collections.RedisProperties
- 
Constructs a newRedisPropertiesinstance.
- RedisPubSubCommands - Interface in org.springframework.data.redis.connection
- 
PubSub-specific Redis commands.
- RedisQueryCreator - Class in org.springframework.data.redis.repository.query
- 
AbstractQueryCreatorimplementation 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 specificImportBeanDefinitionRegistrar.
- RedisRepositoriesRegistrar() - Constructor for class org.springframework.data.redis.repository.configuration.RedisRepositoriesRegistrar
- RedisRepositoryBean<T> - Class in org.springframework.data.redis.repository.cdi
- 
CdiRepositoryBeanto 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 newCdiRepositoryBean.
- RedisRepositoryConfigurationExtension - Class in org.springframework.data.redis.repository.configuration
- 
RepositoryConfigurationExtensionfor 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
- 
RepositoryFactorySupportspecific 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 org.springframework.data.repository.Repository<S,ID>, S, ID> - Class in org.springframework.data.redis.repository.support 
- 
Adapter for SpringsFactoryBeaninterface to allow easy setup ofRedisRepositoryFactoryvia Spring configuration.
- RedisRepositoryFactoryBean(Class<? extends T>) - Constructor for class org.springframework.data.redis.repository.support.RedisRepositoryFactoryBean
- 
Creates a newRedisRepositoryFactoryBeanfor the given repository interface.
- RedisRuntimeHints - Class in org.springframework.data.redis.aot
- 
RuntimeHintsRegistrarfor 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 for setting upRedisConnectionviaRedisConnectionFactoryusing connecting to Redis Sentinel(s).
- RedisSentinelConfiguration() - Constructor for class org.springframework.data.redis.connection.RedisSentinelConfiguration
- 
Creates newRedisSentinelConfiguration.
- RedisSentinelConfiguration(String, Set<String>) - Constructor for class org.springframework.data.redis.connection.RedisSentinelConfiguration
- 
CreatesRedisSentinelConfigurationfor given hostPort combinations.
- RedisSentinelConfiguration(PropertySource<?>) - Constructor for class org.springframework.data.redis.connection.RedisSentinelConfiguration
- 
CreatesRedisSentinelConfigurationlooking up values in givenPropertySource.
- 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 forRedisSerializationContext.
- 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 theSetcontract.
- 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 upRedisConnectionviaRedisConnectionFactoryconnecting to single Redis using a local unix domain socket.
- RedisSocketConfiguration() - Constructor for class org.springframework.data.redis.connection.RedisSocketConfiguration
- 
Create a new defaultRedisSocketConfiguration.
- RedisSocketConfiguration(String) - Constructor for class org.springframework.data.redis.connection.RedisSocketConfiguration
- 
Create a newRedisSocketConfigurationgivensocket.
- RedisStandaloneConfiguration - Class in org.springframework.data.redis.connection
- 
Configuration class used for setting upRedisConnectionviaRedisConnectionFactoryusing connecting to a single node Redis installation.
- RedisStandaloneConfiguration() - Constructor for class org.springframework.data.redis.connection.RedisStandaloneConfiguration
- 
Create a new defaultRedisStandaloneConfiguration.
- RedisStandaloneConfiguration(String) - Constructor for class org.springframework.data.redis.connection.RedisStandaloneConfiguration
- 
Create a newRedisStandaloneConfigurationgivenhostName.
- 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 upRedisConnectionviaRedisConnectionFactoryusing 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 newRedisConfiguration.StaticMasterReplicaConfigurationgivenhostName.
- 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
- 
SETcommand 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 newRedisSubscribedConnectionExceptioninstance.
- RedisSubscribedConnectionException(String, Throwable) - Constructor for exception org.springframework.data.redis.connection.RedisSubscribedConnectionException
- 
Constructs a newRedisSubscribedConnectionExceptioninstance.
- 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 newRedisTemplateinstance.
- redisTemplateRef() - Element in annotation interface org.springframework.data.redis.repository.configuration.EnableRedisRepositories
- 
Configures the bean name of theRedisOperationsto 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-specificTypeMapperexposing thatBucket.BucketPropertyPaths 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, useLimitinstead.
- RedisZSetCommands.Range - Class in org.springframework.data.redis.connection
- 
Deprecated.since 3.0, useRangeorRedisZSetCommands.Range.toRange()instead.
- RedisZSetCommands.Range.Boundary - Class in org.springframework.data.redis.connection
- 
Deprecated.
- RedisZSetCommands.ZAddArgs - Class in org.springframework.data.redis.connection
- 
ZADDspecific 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 ofRedisCommandsProvider.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 specifiedkey.
- 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 specifiedkey.
- refcount(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
- 
Get the number of references of the value associated with the specifiedkey.
- ReferenceResolver - Interface in org.springframework.data.redis.core.convert
- 
ReferenceResolverretrieves Objects marked withReferencefrom Redis.
- ReferenceResolverImpl - Class in org.springframework.data.redis.core.convert
- 
ReferenceResolverusingRedisKeyValueAdapterto 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 cachekey converters.
- registerHints(RuntimeHints, ClassLoader) - Method in class org.springframework.data.redis.aot.RedisRuntimeHints
- registerNullValueSerializer(ObjectMapper, String) - Static method in class org.springframework.data.redis.serializer.GenericJackson2JsonRedisSerializer
- 
RegisterGenericJackson2JsonRedisSerializer.NullValueSerializerin the givenObjectMapperwith an optionalclassPropertyTypeName.
- release(StatefulConnection<?, ?>) - Method in interface org.springframework.data.redis.connection.lettuce.LettuceConnectionProvider
- 
Release theconnection.
- releaseAsync(StatefulConnection<?, ?>) - Method in interface org.springframework.data.redis.connection.lettuce.LettuceConnectionProvider
- 
Release asynchronously theconnection.
- releaseConnection(RedisConnection, RedisConnectionFactory) - Static method in class org.springframework.data.redis.core.RedisConnectionUtils
- 
Closes the givenRedisConnection, 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 betweenstartandendfrom sorted set.
- remove(long, Object) - Method in interface org.springframework.data.redis.core.BoundListOperations
- 
Removes the firstcountoccurrences ofvaluefrom the list stored at the bound key.
- remove(H, Object...) - Method in interface org.springframework.data.redis.core.ReactiveHashOperations
- 
Delete given hashhashKeysfrom 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 givenvaluesfrom set at the bound key and return the number of removed elements.
- remove(Object...) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
- 
Removevaluesfrom 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 dotpath.
- 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 firstcountoccurrences ofvaluefrom the list stored atkey.
- remove(K, long, Object) - Method in interface org.springframework.data.redis.core.ReactiveListOperations
- 
Removes the firstcountoccurrences ofvaluefrom the list stored atkey.
- remove(K, Object...) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
- 
Remove givenvaluesfrom set atkeyand return the number of removed elements.
- remove(K, Object...) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- 
Removevaluesfrom sorted set.
- remove(K, Object...) - Method in interface org.springframework.data.redis.core.SetOperations
- 
Remove givenvaluesfrom set atkeyand return the number of removed elements.
- remove(K, Object...) - Method in interface org.springframework.data.redis.core.ZSetOperations
- 
Removevaluesfrom 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 givenSubscriptionfrom 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 betweenminandmaxfrom sorted set with the bound key.
- removeFirst() - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- removeFirstOccurrence(Object) - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
- RemoveIndexedData - Class in org.springframework.data.redis.core.convert
- 
RemoveIndexedDatarepresents 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
- 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 betweenstartandendfrom sorted set with the bound key.
- removeRange(K, long, long) - Method in interface org.springframework.data.redis.core.ZSetOperations
- 
Remove elements in range betweenstartandendfrom sorted set withkey.
- removeRange(K, Range<Long>) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- 
Remove elements in range betweenstartandendfrom sorted set withkey.
- removeRangeByLex(K, Range<String>) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- 
Remove elements in range from sorted set withkey.
- removeRangeByLex(K, Range<String>) - Method in interface org.springframework.data.redis.core.ZSetOperations
- 
Remove elements inRangefrom 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 useZSetOperations.removeRangeByLex(Object, Range)instead;
- removeRangeByLex(Range<String>) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
- 
Remove elements inRangefrom 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 useBoundZSetOperations.removeRangeByLex(Range).
- removeRangeByScore(double, double) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
- 
Remove elements with scores betweenminandmaxfrom sorted set with the bound key.
- removeRangeByScore(K, double, double) - Method in interface org.springframework.data.redis.core.ZSetOperations
- 
Remove elements with scores betweenminandmaxfrom sorted set withkey.
- removeRangeByScore(K, Range<Double>) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- 
Remove elements with scores betweenminandmaxfrom sorted set withkey.
- rename(byte[], byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 keyoldKeytonewKey.
- 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 keyoldKeytonewKey.
- 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 keyoldKeytonewKey.
- 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 keyoldKeytonewKey.
- 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 keyoldKeytonewKeyonly ifnewKeydoes 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 keyoldKeytonewKeyonly ifnewKeydoes 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 ofRedisCommandsProvider.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 keyoldKeytonewKeyonly ifnewKeydoes 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 keyoldKeytonewKeyonly ifnewKeydoes 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
- 
Appliesreplace.
- 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 ofRedisCommandsProvider.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 ofRedisCommandsProvider.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 theFactoryBeanclass 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.
- requireObject(T, String, Object...) - Static method in class org.springframework.data.redis.util.RedisAssertions
- 
Asserts the givenObjectis not null.
- requireObject(T, Supplier<String>) - Static method in class org.springframework.data.redis.util.RedisAssertions
- 
Asserts the givenObjectis not null.
- requiresArguments() - Method in enum class org.springframework.data.redis.core.RedisCommand
- requiresExactNumberOfArguments() - Method in enum class org.springframework.data.redis.core.RedisCommand
- 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 ofRedisCommandsProvider.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 ofRedisCommandsProvider.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 ofRedisCommandsProvider.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
- 
GetListof all individualClusterCommandExecutor.NodeResult.value.
- resultsAsListSortBy(byte[]...) - Method in class org.springframework.data.redis.connection.ClusterCommandExecutor.MultiNodeResult
- 
GetListof all individualClusterCommandExecutor.NodeResult.value.
- retainAll(Collection<?>) - Method in class org.springframework.data.redis.connection.util.ByteArraySet
- 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
- reverseIndexOf(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRankCommand
- 
Creates a newReactiveZSetCommands.ZIncrByCommandgiven amemberto obtain its reversed rank (ordering high to low).
- reverseRange(long, long) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
- 
Get elements in range fromstarttoendfrom 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 fromstarttoendfrom 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 specificRangein 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 specificRangein 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 specificRangeapplying aLimitin 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 specificRangeapplying aLimitin reverse order asObjectRecord.
- reverseRange(K, long, long) - Method in interface org.springframework.data.redis.core.ZSetOperations
- 
Get elements in range fromstarttoendfrom sorted set ordered from high to low.
- reverseRange(K, Range<Long>) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- 
Get elements in range fromstarttoendfrom 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 specificRangein reverse order.
- reverseRange(K, Range<String>) - Method in interface org.springframework.data.redis.core.StreamOperations
- 
Read records from a stream within a specificRangein reverse order.
- reverseRange(K, Range<String>, Limit) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
- 
Read records from a stream within a specificRangeapplying aLimitin reverse order.
- reverseRange(K, Range<String>, Limit) - Method in interface org.springframework.data.redis.core.StreamOperations
- 
Read records from a stream within a specificRangeapplying aLimitin reverse order.
- reverseRange(Range<String>) - Method in interface org.springframework.data.redis.core.BoundStreamOperations
- 
Read records from a stream within a specificRangein reverse order.
- reverseRange(Range<String>, Limit) - Method in interface org.springframework.data.redis.core.BoundStreamOperations
- 
Read records from a stream within a specificRangeapplying aLimitin reverse order.
- reverseRangeAndStoreByLex(String, Range<String>) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
- 
Store all elements atdstKeywith 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 atdstKey, 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 atdstKeywith reverse lexicographical ordering from ZSET atsrcKeywith a value betweenRange.getLowerBound()andRange.getUpperBound().
- reverseRangeAndStoreByLex(K, K, Range<String>) - Method in interface org.springframework.data.redis.core.ZSetOperations
- 
Store all elements atdstKeywith reverse lexicographical ordering from ZSET atsrcKeywith a value betweenRange.getLowerBound()andRange.getUpperBound().
- reverseRangeAndStoreByLex(K, K, Range<String>, Limit) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- 
Store n elements atdstKey, where n =Limit.getCount(), starting atLimit.getOffset()with reverse lexicographical ordering from ZSET atsrcKeywith a value betweenRange.getLowerBound()andRange.getUpperBound().
- reverseRangeAndStoreByLex(K, K, Range<String>, Limit) - Method in interface org.springframework.data.redis.core.ZSetOperations
- 
Store n elements atdstKey, where n =Limit.getCount(), starting atLimit.getOffset()with reverse lexicographical ordering from ZSET atsrcKeywith a value betweenRange.getLowerBound()andRange.getUpperBound().
- reverseRangeAndStoreByLex(K, Range<String>) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
- 
Store all elements atdstKeywith 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 atdstKey, 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 atdstKeywith 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 atdstKey, 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 atdstKeywith reverse ordering by score from ZSET atsrcKeywith 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 atdstKey, where n =Limit.getCount(), starting atLimit.getOffset()with reverse ordering by score from ZSET atsrcKeywith a score betweenRange.getLowerBound()andRange.getUpperBound().
- reverseRangeAndStoreByScore(K, K, Range<Double>) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- 
Store all elements atdstKeywith reverse ordering by score from ZSET atsrcKeywith a score betweenRange.getLowerBound()andRange.getUpperBound().
- reverseRangeAndStoreByScore(K, K, Range<Double>, Limit) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- 
Store n elements atdstKey, where n =Limit.getCount(), starting atLimit.getOffset()with reverse ordering by score from ZSET atsrcKeywith a score betweenRange.getLowerBound()andRange.getUpperBound().
- reverseRangeAndStoreByScore(K, Range<? extends Number>) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
- 
Store all elements atdstKeywith 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 atdstKey, 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 atkeywith 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 atkeywith 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 atkeywith 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 atkeywith 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 useZSetOperations.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 useZSetOperations.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 betweenRange.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 betweenRange.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 useBoundZSetOperations.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 useRedisZSet.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 useBoundZSetOperations.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 useRedisZSet.reverseRangeByLex(Range, Limit)instead.
- reverseRangeByScore(double, double) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
- 
Get elements where score is betweenminandmaxfrom 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 betweenminandmaxfrom 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 betweenminandmaxfrom 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 fromstarttoendwhere score is betweenminandmaxfrom sorted set ordered high -> low.
- reverseRangeByScore(K, Range<Double>) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- 
Get elements where score is betweenminandmaxfrom 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 fromstarttoendwhere score is betweenminandmaxfrom 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 ofTuplein range fromstarttoendwhere score is betweenminandmaxfrom 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 ofTuplein range fromstarttoendwhere score is betweenminandmaxfrom 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 withvaluein 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 withvaluein 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 withvaluein a sorted set when scored high to low.
- reverseScoresWithin(Range<Double>) - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRangeByScoreCommand
- 
Creates a newReactiveZSetCommands.ZRangeByScoreCommandgiven aRangeto 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 newReactiveZSetCommands.ZRangeStoreCommandgiven aRangeto 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 newReactiveZSetCommands.ZRangeByLexCommandgiven aRangeofStringto obtain elements in reverse lexicographical ordering.
- reverseValuesWithin(Range<Long>) - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRangeCommand
- 
Creates a newReactiveZSetCommands.ZRangeCommandgiven aRangeto 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 newReactiveZSetCommands.ZRangeStoreCommandgiven aRangeto obtain elements ordered from the highest to the lowest lexicographical value.
- rewriteConfig() - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 theredis.conffile.
- rewriteConfig(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.DefaultedRedisClusterConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 newReactiveListCommands.BPopCommandfor right push (BRPOP).
- right() - Static method in class org.springframework.data.redis.connection.ReactiveListCommands.PopCommand
- 
Creates a newReactiveListCommands.PopCommandfor right push (RPOP).
- right() - Static method in class org.springframework.data.redis.connection.ReactiveListCommands.PushCommand
- 
Creates a newReactiveListCommands.PushCommandfor 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 atkey.
- 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 atkey.
- rightPop(K) - Method in interface org.springframework.data.redis.core.ReactiveListOperations
- 
Removes and returns last element in list stored atkey.
- rightPop(K, long) - Method in interface org.springframework.data.redis.core.ListOperations
- 
Removes and returns last elements in list stored atkey.
- rightPop(K, long, TimeUnit) - Method in interface org.springframework.data.redis.core.ListOperations
- 
Removes and returns last element from lists stored atkey.
- rightPop(K, Duration) - Method in interface org.springframework.data.redis.core.ListOperations
- 
Removes and returns last element from lists stored atkey.
- rightPop(K, Duration) - Method in interface org.springframework.data.redis.core.ReactiveListOperations
- 
Removes and returns last element from lists stored atkey.
- rightPopAndLeftPush(K, K) - Method in interface org.springframework.data.redis.core.ListOperations
- 
Remove the last element from list atsourceKey, append it todestinationKeyand return its value.
- rightPopAndLeftPush(K, K) - Method in interface org.springframework.data.redis.core.ReactiveListOperations
- 
Remove the last element from list atsourceKey, append it todestinationKeyand return its value.
- rightPopAndLeftPush(K, K, long, TimeUnit) - Method in interface org.springframework.data.redis.core.ListOperations
- 
Remove the last element from list atsourceKey, append it todestinationKeyand return its value.
 Blocks connection until element available ortimeoutreached.
- rightPopAndLeftPush(K, K, Duration) - Method in interface org.springframework.data.redis.core.ListOperations
- 
Remove the last element from list atsourceKey, append it todestinationKeyand return its value.
 Blocks connection until element available ortimeoutreached.
- rightPopAndLeftPush(K, K, Duration) - Method in interface org.springframework.data.redis.core.ReactiveListOperations
- 
Remove the last element from list atsrcKey, append it todstKeyand return its value.
 Results return once an element available ortimeoutreached.
- rightPush(K, V) - Method in interface org.springframework.data.redis.core.ListOperations
- 
Appendvaluetokey.
- rightPush(K, V) - Method in interface org.springframework.data.redis.core.ReactiveListOperations
- 
Appendvaluetokey.
- rightPush(K, V, V) - Method in interface org.springframework.data.redis.core.ListOperations
- 
Insertvaluetokeyafterpivot.
- rightPush(K, V, V) - Method in interface org.springframework.data.redis.core.ReactiveListOperations
- 
Insertvaluetokeyafterpivot.
- rightPush(V) - Method in interface org.springframework.data.redis.core.BoundListOperations
- 
Appendvalueto the bound key.
- rightPush(V, V) - Method in interface org.springframework.data.redis.core.BoundListOperations
- 
Appendvaluesto the bound key beforevalue.
- rightPushAll(K, Collection<V>) - Method in interface org.springframework.data.redis.core.ListOperations
- 
Appendvaluestokey.
- rightPushAll(K, Collection<V>) - Method in interface org.springframework.data.redis.core.ReactiveListOperations
- 
Appendvaluestokey.
- rightPushAll(K, V...) - Method in interface org.springframework.data.redis.core.ListOperations
- 
Appendvaluestokey.
- rightPushAll(K, V...) - Method in interface org.springframework.data.redis.core.ReactiveListOperations
- 
Appendvaluestokey.
- rightPushAll(V...) - Method in interface org.springframework.data.redis.core.BoundListOperations
- 
Appendvaluesto the bound key.
- rightPushIfPresent(K, V) - Method in interface org.springframework.data.redis.core.ListOperations
- 
Appendvaluestokeyonly if the list exists.
- rightPushIfPresent(K, V) - Method in interface org.springframework.data.redis.core.ReactiveListOperations
- 
Appendvaluestokeyonly if the list exists.
- rightPushIfPresent(V) - Method in interface org.springframework.data.redis.core.BoundListOperations
- 
Appendvaluesto 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 ofRedisCommandsProvider.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 atkey.
- rPop(byte[], long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 atkey.
- 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 atkey.
- 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 atkey.
- 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 lastcountelements 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 ofRedisCommandsProvider.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 atsrcKey, append it todstKeyand 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 atsrcKey, append it todstKeyand 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 atReactiveRedisConnection.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 ofRedisCommandsProvider.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
- 
Appendvaluestokey.
- rPush(String, String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- rPush(String, String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
- 
Appendvaluestokey.
- 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 ofRedisCommandsProvider.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
- 
Appendvaluestokeyonly 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
- 
Appendvaluestokeyonly 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 ofRedisCommandsProvider.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 givenvaluesto 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 givenvaluesto 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 givenReactiveSetCommands.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 ofRedisCommandsProvider.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 ofRedisCommandsProvider.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 aFluxto iterate over keys.
- scan() - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
- 
Use aFluxto 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
- 
ABatchStrategyusing aSCANcursors and potentially multipleDELcommands to remove all matching keys.
- scan(H) - Method in interface org.springframework.data.redis.core.ReactiveHashOperations
- 
Use aFluxto iterate over entries in the hash atkey.
- scan(H, ScanOptions) - Method in interface org.springframework.data.redis.core.HashOperations
- 
Use aCursorto 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 aFluxto iterate over entries in the set atkey.
- scan(K) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- 
Use aFluxto 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 aCursorto iterate over entries set atkey.
- scan(K, ScanOptions) - Method in interface org.springframework.data.redis.core.ZSetOperations
- 
Use aCursorto 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 aCursorto iterate over keys.
- scan(KeyScanOptions) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
- 
Use aFluxto iterate over keys.
- scan(KeyScanOptions) - Method in interface org.springframework.data.redis.connection.RedisKeyCommands
- 
Use aCursorto iterate over keys.
- scan(ScanOptions) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.keyCommands().
- scan(ScanOptions) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- scan(ScanOptions) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
- 
Use aFluxto iterate over keys.
- scan(ScanOptions) - Method in interface org.springframework.data.redis.connection.RedisKeyCommands
- 
Use aCursorto iterate over keys.
- scan(ScanOptions) - Method in interface org.springframework.data.redis.core.BoundHashOperations
- 
Use aCursorto iterate over entries in hash at the bound key.
- scan(ScanOptions) - Method in interface org.springframework.data.redis.core.BoundSetOperations
- 
Use aCursorto iterate over entries in set atkey.
- scan(ScanOptions) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
- 
Use aCursorto iterate over entries in zset at the bound key.
- scan(ScanOptions) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
- 
Use aFluxto 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 aCursorto 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 agnosticCursorimplementation continuously loading additional results from Redis server until reaching its starting pointzero.
- ScanCursor() - Constructor for class org.springframework.data.redis.core.ScanCursor
- ScanCursor(long) - Constructor for class org.springframework.data.redis.core.ScanCursor
- 
Crates newScanCursorwithScanOptions.NONE
- ScanCursor(long, ScanOptions) - Constructor for class org.springframework.data.redis.core.ScanCursor
- 
Crates newScanCursor
- ScanCursor(ScanOptions) - Constructor for class org.springframework.data.redis.core.ScanCursor
- 
Crates newScanCursorwithid=0.
- ScanIteration<T> - Class in org.springframework.data.redis.core
- 
ScanIterationholds the values contained in Redis Multibulk reply on exectuting SCAN command.
- ScanIteration(long, 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 newScanOptions.ScanOptionsBuilder.
- scanOptions(DataType) - Static method in class org.springframework.data.redis.core.KeyScanOptions
- 
Static factory method that returns a newScanOptions.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 ofRedisCommandsProvider.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 atkey.
- 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 atkey.
- 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 atReactiveRedisConnection.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 withvaluefrom 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 withvaluesfrom sorted set with key the bound key.
- score(K, Object) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- 
Get the score of element withvaluefrom sorted set with keykey.
- score(K, Object) - Method in interface org.springframework.data.redis.core.ZSetOperations
- 
Get the score of element withvaluefrom sorted set with keykey.
- score(K, Object...) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- 
Get the scores of elements withvaluesfrom sorted set with keykey.
- score(K, Object...) - Method in interface org.springframework.data.redis.core.ZSetOperations
- 
Get the scores of elements withvaluesfrom 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 newReactiveZSetCommands.ZIncrByCommandgiven amember.
- scoreOf(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZMScoreCommand
- 
Creates a newReactiveZSetCommands.ZMScoreCommandgiven amember.
- scoreOf(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZScoreCommand
- 
Creates a newReactiveZSetCommands.ZScoreCommandgiven amember.
- scoreOf(Collection<ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZMScoreCommand
- 
Creates a newReactiveZSetCommands.ZMScoreCommandgiven amembers.
- scoresWithin(Range<Double>) - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZCountCommand
- 
Creates a newReactiveZSetCommands.ZCountCommandgiven aRange.
- scoresWithin(Range<Double>) - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRangeByScoreCommand
- 
Creates a newReactiveZSetCommands.ZRangeByScoreCommandgiven aRangeto 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 newReactiveZSetCommands.ZRemRangeByScoreCommandgiven aRange.
- scoreWithin(Range<Double>) - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRangeStoreCommand
- 
Creates a newReactiveZSetCommands.ZRangeStoreCommandgiven aRangeto 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
- 
ExecutesRedisScripts
- scriptExists(String) - Method in interface org.springframework.data.redis.connection.ReactiveScriptingCommands
- 
Check if givenscriptShaexist in script cache.
- scriptExists(String...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 givenscriptShasexist in script cache.
- scriptExists(List<String>) - Method in interface org.springframework.data.redis.connection.ReactiveScriptingCommands
- 
Check if givenscriptShasexist in script cache.
- scriptFlush() - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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
- 
RuntimeExceptionthrown when issues occur withRedisScripts
- ScriptingException(String) - Constructor for exception org.springframework.data.redis.core.script.ScriptingException
- 
Constructs a newScriptingExceptioninstance.
- ScriptingException(String, Throwable) - Constructor for exception org.springframework.data.redis.core.script.ScriptingException
- 
Constructs a newScriptingExceptioninstance.
- scriptKill() - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 ofRedisCommandsProvider.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 ofRedisCommandsProvider.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 givenkeys.
- 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 givenkeys.
- 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 atReactiveSetCommands.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 ofRedisCommandsProvider.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 givenkeysand 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 givenkeysand 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 givenCircle.
- search(K, Circle) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
- 
Get the members within the boundaries of a givenCircle.
- search(K, GeoReference<M>, Distance) - Method in interface org.springframework.data.redis.core.GeoOperations
- 
Get the members usingGeoReferenceas 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 usingGeoReferenceas 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 usingGeoReferenceas center of the query within the boundaries of a givenradiusapplyingRedisGeoCommands.GeoRadiusCommandArgs.
- search(K, GeoReference<M>, Distance, RedisGeoCommands.GeoSearchCommandArgs) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
- 
Get the members usingGeoReferenceas center of the query within the boundaries of a givenradiusapplyingRedisGeoCommands.GeoRadiusCommandArgs.
- search(K, GeoReference<M>, BoundingBox) - Method in interface org.springframework.data.redis.core.GeoOperations
- 
Get the members usingGeoReferenceas 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 usingGeoReferenceas 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 usingGeoReferenceas 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 usingGeoReferenceas 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 usingGeoReferenceas center of the query within the boundaries of a givenpredicateapplyingRedisGeoCommands.GeoRadiusCommandArgs.
- search(K, GeoReference<M>, GeoShape, RedisGeoCommands.GeoSearchCommandArgs) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
- 
Get the members usingGeoReferenceas center of the query within the boundaries of a givenpredicateapplyingRedisGeoCommands.GeoRadiusCommandArgs.
- search(Circle) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
- 
Get the members within the boundaries of a givenCircle.
- search(GeoReference<M>, Distance) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
- 
Get the members usingGeoReferenceas 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 usingGeoReferenceas center of the query within the boundaries of a givenradiusapplyingRedisGeoCommands.GeoRadiusCommandArgs.
- search(GeoReference<M>, BoundingBox) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
- 
Get the members usingGeoReferenceas 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 usingGeoReferenceas 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 usingGeoReferenceas center of the query within the boundaries of a givenpredicateapplyingRedisGeoCommands.GeoRadiusCommandArgs.
- searchAndStore(K, K, Circle) - Method in interface org.springframework.data.redis.core.GeoOperations
- 
Get the members within the boundaries of a givenCircleand store results atdestKey.
- searchAndStore(K, K, Circle) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
- 
Get the members within the boundaries of a givenCircleand store results atdestKey.
- searchAndStore(K, K, GeoReference<M>, Distance) - Method in interface org.springframework.data.redis.core.GeoOperations
- 
Get the members usingGeoReferenceas center of the query within the boundaries of a givenradiusand store results atdestKey.
- searchAndStore(K, K, GeoReference<M>, Distance) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
- 
Get the members usingGeoReferenceas center of the query within the boundaries of a givenradiusand store results atdestKey.
- searchAndStore(K, K, GeoReference<M>, Distance, RedisGeoCommands.GeoSearchStoreCommandArgs) - Method in interface org.springframework.data.redis.core.GeoOperations
- 
Get the members usingGeoReferenceas center of the query within the boundaries of a givenradiusapplyingRedisGeoCommands.GeoRadiusCommandArgsand store results atdestKey.
- searchAndStore(K, K, GeoReference<M>, Distance, RedisGeoCommands.GeoSearchStoreCommandArgs) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
- 
Get the members usingGeoReferenceas center of the query within the boundaries of a givenradiusapplyingRedisGeoCommands.GeoRadiusCommandArgsand store results atdestKey.
- searchAndStore(K, K, GeoReference<M>, BoundingBox) - Method in interface org.springframework.data.redis.core.GeoOperations
- 
Get the members usingGeoReferenceas 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 usingGeoReferenceas 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 usingGeoReferenceas center of the query within the boundaries of a given bounding box applyingRedisGeoCommands.GeoRadiusCommandArgsand store results atdestKey.
- searchAndStore(K, K, GeoReference<M>, BoundingBox, RedisGeoCommands.GeoSearchStoreCommandArgs) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
- 
Get the members usingGeoReferenceas center of the query within the boundaries of a given bounding box applyingRedisGeoCommands.GeoRadiusCommandArgsand store results atdestKey.
- searchAndStore(K, K, GeoReference<M>, GeoShape, RedisGeoCommands.GeoSearchStoreCommandArgs) - Method in interface org.springframework.data.redis.core.GeoOperations
- 
Get the members usingGeoReferenceas center of the query within the boundaries of a givenpredicateapplyingRedisGeoCommands.GeoRadiusCommandArgsand store results atdestKey.
- searchAndStore(K, K, GeoReference<M>, GeoShape, RedisGeoCommands.GeoSearchStoreCommandArgs) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
- 
Get the members usingGeoReferenceas center of the query within the boundaries of a givenpredicateapplyingRedisGeoCommands.GeoRadiusCommandArgsand store results atdestKey.
- searchAndStore(K, Circle) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
- 
Get the members within the boundaries of a givenCircleand store results atdestKey.
- searchAndStore(K, GeoReference<M>, Distance) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
- 
Get the members usingGeoReferenceas center of the query within the boundaries of a givenradiusand store results atdestKey.
- searchAndStore(K, GeoReference<M>, Distance, RedisGeoCommands.GeoSearchStoreCommandArgs) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
- 
Get the members usingGeoReferenceas center of the query within the boundaries of a givenradiusapplyingRedisGeoCommands.GeoRadiusCommandArgsand store results atdestKey.
- searchAndStore(K, GeoReference<M>, BoundingBox) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
- 
Get the members usingGeoReferenceas 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 usingGeoReferenceas center of the query within the boundaries of a given bounding box applyingRedisGeoCommands.GeoRadiusCommandArgsand store results atdestKey.
- searchAndStore(K, GeoReference<M>, GeoShape, RedisGeoCommands.GeoSearchStoreCommandArgs) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
- 
Get the members usingGeoReferenceas center of the query within the boundaries of a givenpredicateapplyingRedisGeoCommands.GeoRadiusCommandArgsand store results atdestKey.
- seconds(long) - Static method in class org.springframework.data.redis.core.types.Expiration
- 
Creates newExpirationwithTimeUnit.SECONDS.
- secondsToDuration(Long) - Static method in class org.springframework.data.redis.connection.convert.Converters
- 
Convert the given nullable seconds to aDurationor null.
- secondsToTimeUnit(long, TimeUnit) - Static method in class org.springframework.data.redis.connection.convert.Converters
- 
Convertssecondsto the givenTimeUnit.
- secondsToTimeUnit(TimeUnit) - Static method in class org.springframework.data.redis.connection.convert.Converters
- 
Creates a newConverterto convert from seconds to the givenTimeUnit.
- 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 positivedbIndex.
- 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 newSerializationExceptioninstance.
- SerializationException(String, Throwable) - Constructor for exception org.springframework.data.redis.serializer.SerializationException
- 
Constructs a newSerializationExceptioninstance.
- 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
- 
Serializekeywith 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 givencache key.
- serializeCacheValue(Object) - Method in class org.springframework.data.redis.cache.RedisCache
- 
Serialize thevalueto cache as an array of bytes.
- serializeKeysWith(RedisSerializationContext.SerializationPair<String>) - Method in class org.springframework.data.redis.cache.RedisCacheConfiguration
- 
Define theRedisSerializationContext.SerializationPairused 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 theRedisSerializationContext.SerializationPairused 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
- 
GetRedisServerCommands.
- serverCommands() - Method in interface org.springframework.data.redis.connection.RedisCommandsProvider
- 
GetRedisServerCommands.
- servesSlot(int) - Method in class org.springframework.data.redis.connection.RedisClusterNode
- 
Determines whether thisRedisClusterNodemanages the identifiedslotin 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 ofRedisCommandsProvider.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
- 
Setvalueforkey.
- set(byte[], byte[], Expiration, RedisStringCommands.SetOption) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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
- 
Setvalueforkeyapplying timeouts fromexpirationif 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 thevaluelist 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
- 
Setvalueforkey.
- 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
- 
Setvalueforkeyapplying timeouts fromexpirationif set and inserting/updating values depending onoption.
- set(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveStringCommands.SetCommand
- 
Creates a newReactiveStringCommands.SetCommandgiven 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 thevaluelist element atindex.
- set(K, long, V) - Method in interface org.springframework.data.redis.core.ReactiveListOperations
- 
Set thevaluelist element atindex.
- set(K, V) - Method in interface org.springframework.data.redis.core.ReactiveValueOperations
- 
Setvalueforkey.
- set(K, V) - Method in interface org.springframework.data.redis.core.ValueOperations
- 
Setvalueforkey.
- set(K, V, long) - Method in interface org.springframework.data.redis.core.ReactiveValueOperations
- 
Overwrite parts ofkeystarting at the specifiedoffsetwith givenvalue.
- set(K, V, long) - Method in interface org.springframework.data.redis.core.ValueOperations
- 
Overwrite parts ofkeystarting at the specifiedoffsetwith givenvalue.
- set(K, V, long, TimeUnit) - Method in interface org.springframework.data.redis.core.ValueOperations
- 
Set thevalueand expirationtimeoutforkey.
- set(K, V, Duration) - Method in interface org.springframework.data.redis.core.ReactiveValueOperations
- 
Set thevalueand expirationtimeoutforkey.
- set(K, V, Duration) - Method in interface org.springframework.data.redis.core.ValueOperations
- 
Set thevalueand expirationtimeoutforkey.
- set(Publisher<ReactiveStringCommands.SetCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
- 
Set each and every item separately by invokingReactiveStringCommands.SetCommand.
- set(BitFieldSubCommands.BitFieldSet) - Method in class org.springframework.data.redis.connection.BitFieldSubCommands
- 
Create newBitFieldSubCommandsadding givenBitFieldSubCommands.BitFieldSetto the sub commands.
- set(BitFieldSubCommands.BitFieldType) - Method in class org.springframework.data.redis.connection.BitFieldSubCommands
- 
Obtain a newBitFieldSubCommands.BitFieldSetBuilderfor creating and adding aBitFieldSubCommands.BitFieldSetsub command.
- set(V) - Method in interface org.springframework.data.redis.core.BoundValueOperations
- 
Setvaluefor the bound key.
- set(V, long) - Method in interface org.springframework.data.redis.core.BoundValueOperations
- 
Overwrite parts of the bound key starting at the specifiedoffsetwith givenvalue.
- set(V, long, TimeUnit) - Method in interface org.springframework.data.redis.core.BoundValueOperations
- 
Set thevalueand expirationtimeoutfor the bound key.
- set(V, Duration) - Method in interface org.springframework.data.redis.core.BoundValueOperations
- 
Set thevalueand expirationtimeoutfor 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
- setBeanClassLoader(ClassLoader) - Method in class org.springframework.data.redis.core.RedisTemplate
- 
Set theClassLoaderto be used for the defaultJdkSerializationRedisSerializerin case no otherRedisSerializeris 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 ofRedisCommandsProvider.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 atoffsetin 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 atoffsetin 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 atoffsetin value stored atkey.
- setBit(K, long, boolean) - Method in interface org.springframework.data.redis.core.ValueOperations
- 
Sets the bit atoffsetin 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 ofRedisCommandsProvider.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 usingJedisClientConfiguration.
- setClientName(String) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
- 
Deprecated.configure the client name usingLettuceClientConfiguration.
- 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, configureClientResourcesusingLettuceClientConfiguration.
- 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
- 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
- 
GetReactiveSetCommands.
- setCommands() - Method in interface org.springframework.data.redis.connection.RedisCommandsProvider
- 
GetRedisSetCommands.
- setConfig(String, String) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 forparamtovalue.
- setConfig(String, String) - Method in interface org.springframework.data.redis.connection.RedisServerCommands
- 
Set server configuration forparamtovalue.
- setConfig(RedisClusterNode, String, String) - Method in interface org.springframework.data.redis.connection.DefaultedRedisClusterConnection
- 
Deprecated.in favor ofRedisCommandsProvider.serverCommands().
- setConfig(RedisClusterNode, String, String) - Method in interface org.springframework.data.redis.connection.ReactiveClusterServerCommands
- 
Set server configuration forparamtovalue.
- 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 theConversionServiceto 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
- 
SetCustomConversionsto be applied.
- setDatabase(int) - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
- 
Deprecated.since 2.0, configure the database index usingRedisStandaloneConfigurationorRedisSentinelConfiguration.
- setDatabase(int) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
- 
Sets the index of the database used by this connection factory.
- 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 ofshared connections.
- setEnableDefaultSerializer(boolean) - Method in class org.springframework.data.redis.core.RedisTemplate
- setEnableKeyspaceEvents(RedisKeyValueAdapter.EnableKeyspaceEvents) - Method in class org.springframework.data.redis.core.RedisKeyValueAdapter
- 
Configure usage ofKeyExpirationEventMessageListener.
- setEnableTransactionSupport(boolean) - Method in class org.springframework.data.redis.core.RedisTemplate
- 
If set totrueRedisTemplatewill participate 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
- 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 ofRedisCommandsProvider.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 thevalueand expiration insecondsforkey.
- 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 thevalueand expiration insecondsforkey.
- setEX(ByteBuffer, ByteBuffer, Expiration) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
- 
Set key value pair andExpiration.
- setEX(Publisher<ReactiveStringCommands.SetCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
- 
Set key value pairs andExpiration.
- SETEX - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
- setExposeConnection(boolean) - Method in class org.springframework.data.redis.core.RedisTemplate
- 
Sets whether to expose the Redis connection toRedisCallbackcode.
- 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 usingRedisStandaloneConfiguration.
- setHostName(String) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
- 
Deprecated.since 2.0, configure the hostname usingRedisStandaloneConfiguration.
- 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
- 
Setkeyto hold the stringvalueifkeyis absent.
- setIfAbsent(K, V) - Method in interface org.springframework.data.redis.core.ValueOperations
- 
Setkeyto hold the stringvalueifkeyis absent.
- setIfAbsent(K, V, long, TimeUnit) - Method in interface org.springframework.data.redis.core.ValueOperations
- 
Setkeyto hold the stringvalueand expirationtimeoutifkeyis absent.
- setIfAbsent(K, V, Duration) - Method in interface org.springframework.data.redis.core.ReactiveValueOperations
- 
Setkeyto hold the stringvalueand expirationtimeoutifkeyis absent.
- setIfAbsent(K, V, Duration) - Method in interface org.springframework.data.redis.core.ValueOperations
- 
Setkeyto hold the stringvalueand expirationtimeoutifkeyis absent.
- setIfAbsent(V) - Method in interface org.springframework.data.redis.core.BoundValueOperations
- 
Set the bound key to hold the stringvalueif 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 stringvalueand expirationtimeoutif the bound key is absent.
- setIfAbsent(V, Duration) - Method in interface org.springframework.data.redis.core.BoundValueOperations
- 
Set bound key to hold the stringvalueand expirationtimeoutif the bound key is absent.
- setIfPresent(K, V) - Method in interface org.springframework.data.redis.core.ReactiveValueOperations
- 
Setkeyto hold the stringvalueifkeyis present.
- setIfPresent(K, V) - Method in interface org.springframework.data.redis.core.ValueOperations
- 
Setkeyto hold the stringvalueifkeyis present.
- setIfPresent(K, V, long, TimeUnit) - Method in interface org.springframework.data.redis.core.ValueOperations
- 
Setkeyto hold the stringvalueand expirationtimeoutifkeyis present.
- setIfPresent(K, V, Duration) - Method in interface org.springframework.data.redis.core.ReactiveValueOperations
- 
Setkeyto hold the stringvalueand expirationtimeoutifkeyis present.
- setIfPresent(K, V, Duration) - Method in interface org.springframework.data.redis.core.ValueOperations
- 
Setkeyto hold the stringvalueand expirationtimeoutifkeyis present.
- setIfPresent(V) - Method in interface org.springframework.data.redis.core.BoundValueOperations
- 
Set the bound key to hold the stringvalueif 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 stringvalueand expirationtimeoutif the bound key is present.
- setIfPresent(V, Duration) - Method in interface org.springframework.data.redis.core.BoundValueOperations
- 
Set the bound key to hold the stringvalueand expirationtimeoutif 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 onMOVEDorASK.
- 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 is2000ms, that is, 2 second.
- setMessageListenerContainer(RedisMessageListenerContainer) - Method in class org.springframework.data.redis.core.RedisKeyValueAdapter
- 
Configure aRedisMessageListenerContainerto 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 ofRedisCommandsProvider.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
- 
Setvalueforkey, only ifkeydoes 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
- 
Setvalueforkey, only ifkeydoes 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, useconstructor creationto 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 aRedisPasswordfor givenString.
- setPassword(String) - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
- 
Deprecated.since 2.0, configure the password usingRedisStandaloneConfiguration,RedisSentinelConfigurationorRedisClusterConfiguration.
- setPassword(String) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
- 
Deprecated.since 2.0, configure the password usingRedisStandaloneConfiguration,RedisSentinelConfigurationorRedisClusterConfiguration.
- setPassword(String) - Method in interface org.springframework.data.redis.connection.RedisConfiguration.WithAuthentication
- 
Create and set aRedisPasswordfor 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 aRedisPasswordfor 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
- 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, configureJedisPoolConfigusingJedisClientConfiguration.
- setPort(int) - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
- 
Deprecated.since 2.0, configure the port usingRedisStandaloneConfiguration.
- setPort(int) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
- 
Deprecated.since 2.0, configure the port usingRedisStandaloneConfiguration.
- 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 ofRedisCommandsProvider.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 ofkeystarting at the specifiedoffsetwith 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 ofkeystarting at the specifiedoffsetwith 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 ofReactiveRedisConnection.KeyCommand.keystarting 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 intervalBackOffrecovery 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 newReactiveZSetCommands.ZDiffCommandgiven aCollectionof keys.
- sets(List<ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZAggregateCommand
- 
Creates a newReactiveZSetCommands.ZAggregateCommandgiven aListof keys.
- sets(List<ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZAggregateStoreCommand
- 
Creates a newReactiveZSetCommands.ZAggregateStoreCommandgiven aListof keys.
- sets(List<ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZInterStoreCommand
- 
Creates a newReactiveZSetCommands.ZInterStoreCommandgiven aListof keys.
- sets(List<ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZUnionStoreCommand
- 
Creates a newReactiveZSetCommands.ZUnionStoreCommandgiven aListof 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 aRedisPasswordto be used when authenticating with Redis Sentinel from the givenCharactersequence.
- setSentinelPassword(String) - Method in interface org.springframework.data.redis.connection.RedisConfiguration.SentinelConfiguration
- 
Create and set aRedisPasswordto be used when authenticating with Redis Sentinel from the givenString.
- setSentinelPassword(RedisPassword) - Method in interface org.springframework.data.redis.connection.RedisConfiguration.SentinelConfiguration
- 
Set aRedisPasswordto 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 givenString.
- 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 multipleLettuceConnections 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 usingLettuceClientConfiguration.
- 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 usingLettuceClientConfiguration.
- 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 usingJedisClientConfiguration.
- setTimeout(long) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
- 
Deprecated.since 2.0, configure the timeout usingLettuceClientConfiguration.
- 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 inTimeUnit.SECONDS.
- setTimeToLive(Long, TimeUnit) - Method in class org.springframework.data.redis.core.convert.RedisData
- 
Set the time before expiration converting the given arguments toTimeUnit.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 theTopics 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 theTypeConverterto 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 withJedisClientConfiguration.
- 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 givenString.
- 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 withJedisClientConfiguration.
- setUseSsl(boolean) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
- 
Deprecated.since 2.0, configure SSL usage usingLettuceClientConfiguration.
- setValidateConnection(boolean) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
- 
Enables validation of the shared native Lettuce connection on calls toLettuceConnectionFactory.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 usingLettuceClientConfiguration.
- 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 publishingkeyspace events.
- shouldBeAutoGenerated() - Method in class org.springframework.data.redis.connection.stream.RecordId
- shouldUseCachedValue() - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection.JedisClusterTopologyProvider
- 
Returns whetherJedisClusterConnection.JedisClusterTopologyProvider.getTopology()should return the cachedClusterTopology.
- shutdown() - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 ofRedisCommandsProvider.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 ofRedisCommandsProvider.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 signedBitFieldSubCommands.BitFieldType.
- simple() - Static method in interface org.springframework.data.redis.cache.CacheKeyPrefix
- 
Creates a defaultCacheKeyPrefixscheme that prefixes cache keys with thenameof the cache followed by double colons.
- SimpleIndexDefinition - Class in org.springframework.data.redis.core.index
- 
PathBasedRedisIndexDefinitionfor including property values in a secondary index.
- SimpleIndexDefinition(String, String) - Constructor for class org.springframework.data.redis.core.index.SimpleIndexDefinition
- 
Creates newSimpleIndexDefinition.
- SimpleIndexDefinition(String, String, String) - Constructor for class org.springframework.data.redis.core.index.SimpleIndexDefinition
- 
Creates newSimpleIndexDefinition.
- SimpleIndexedPropertyValue - Class in org.springframework.data.redis.core.convert
- 
IndexedDataimplementation indicating storage of data within a Redis Set.
- SimpleIndexedPropertyValue(String, String, Object) - Constructor for class org.springframework.data.redis.core.convert.SimpleIndexedPropertyValue
- 
Creates newSimpleIndexedPropertyValue.
- singleValue() - Static method in class org.springframework.data.redis.connection.ReactiveSetCommands.SRandMembersCommand
- 
Creates a newReactiveSetCommands.SRandMembersCommandto retrieve one random member.
- singleValue() - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRandMemberCommand
- 
Creates a newReactiveZSetCommands.ZRandMemberCommandto retrieve one random member.
- sInter(byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 atkeys.
- 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 atkeys.
- 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 atReactiveSetCommands.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 ofRedisCommandsProvider.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 atkeysand 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 atkeysand 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 ofRedisCommandsProvider.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 atkeycontainsvalue.
- 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 atkeycontainsvalue.
- 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 atReactiveRedisConnection.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 ofStreamInfo.XInfoConsumeravailable.
- size() - Method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoGroups
- 
Returns the number ofStreamInfo.XInfoGroupavailable.
- 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 atkey.
- size(H) - Method in interface org.springframework.data.redis.core.ReactiveHashOperations
- 
Get size of hash atkey.
- size(K) - Method in interface org.springframework.data.redis.core.ListOperations
- 
Get the size of list stored atkey.
- size(K) - Method in interface org.springframework.data.redis.core.ReactiveListOperations
- 
Get the size of list stored atkey.
- size(K) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
- 
Get size of set atkey.
- 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 atkey.
- size(K) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- 
Returns the number of elements of the sorted set stored with givenkey.
- size(K) - Method in interface org.springframework.data.redis.core.SetOperations
- 
Get size of set atkey.
- 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 atkey.
- size(K) - Method in interface org.springframework.data.redis.core.ZSetOperations
- 
Returns the number of elements of the sorted set stored with givenkey.
- 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 ofRedisCommandsProvider.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 atkey.
- 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 atkey.
- 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 atReactiveRedisConnection.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 ofRedisCommandsProvider.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 atkeycontains 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 atkeycontains one or morevalues.
- sMIsMember(ByteBuffer, List<ByteBuffer>) - Method in interface org.springframework.data.redis.connection.ReactiveSetCommands
- 
Check if set atkeycontains one or morevalues.
- sMIsMember(Publisher<ReactiveSetCommands.SMIsMemberCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveSetCommands
- 
Check if set atReactiveRedisConnection.KeyCommand.getKey()containsReactiveSetCommands.SMIsMemberCommand.getValues().
- sMove(byte[], byte[], byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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
- 
MovevaluefromsrcKeytodestKey
- 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
- 
MovevaluefromsrcKeytodestKey
- 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 ofRedisCommandsProvider.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 forkey.
- sort(byte[], SortParameters, byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 forkeyand 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 forkey.
- 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 forkeyand 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 sortSort.Direction.
- sort(Sort.Direction) - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusCommand
- 
Applies the distance sortSort.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 forquery.
- 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 forqueryand 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 forqueryapplyingBulkMapper.
- 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 forqueryapplyingRedisSerializer.
- 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 ofSortParameters).
- SortQueryBuilder<K> - Class in org.springframework.data.redis.core.query
- 
Simple builder class for constructingSortQuery.
- sourceKeys(Collection<ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZDiffStoreCommand
- 
Creates a newReactiveZSetCommands.ZDiffStoreCommandgiven aCollectionof keys.
- SpelIndexDefinition - Class in org.springframework.data.redis.core.index
- 
SpelIndexDefinitiondefines index that is evaluated based on aSpelExpressionrequires theSpelIndexResolverto be evaluated.
- SpelIndexDefinition(String, String, String) - Constructor for class org.springframework.data.redis.core.index.SpelIndexDefinition
- 
Creates newSpelIndexDefinition.
- 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 defaultSpelExpressionParser.
- 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
- 
Splitsourceinto partitioned arrays using delimiterc.
- sPop(byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 atkey.
- sPop(byte[], long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 returncountrandom 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 atkey.
- 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 returncountrandom 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 returncountrandom 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 atReactiveRedisConnection.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 ofRedisCommandsProvider.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 atkey.
- sRandMember(byte[], long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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
- 
Getcountrandom 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 atkey.
- sRandMember(String, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- sRandMember(String, long) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
- 
Getcountrandom 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
- 
GetReactiveSetCommands.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 ofRedisCommandsProvider.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 givenvaluesfrom set atkeyand 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 givenvaluesfrom set atkeyand 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 givenReactiveSetCommands.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 ofRedisCommandsProvider.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 aCursorto 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 aCursorto iterate over elements in set atkey.
- sScan(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveSetCommands
- 
Use aFluxto 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 aFluxto 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.listener.RedisMessageListenerContainer
- 
Startup the container and subscribe to topics iflistenerswere 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 thehaystackstarts with the givenprefix.
- startsWith(byte[], byte[], int) - Static method in class org.springframework.data.redis.util.ByteUtils
- 
Tests if thehaystackbeginning at the specifiedoffsetstarts 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.listener.RedisMessageListenerContainer
- 
Stop the message listener container and cancel any subscriptions if the container islistening.
- stop(Runnable) - Method in class org.springframework.data.redis.listener.RedisMessageListenerContainer
- 
Stop the message listener container and cancel any subscriptions if the container islistening.
- 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 theRedisGeoCommands.GeoRadiusCommandArgs.Flag.STOREDISTflag 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 sequentialStreamofStreamInfo.XInfoConsumer.
- stream() - Method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoGroups
- 
Returns a sequentialStreamofStreamInfo.XInfoGroup.
- stream(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveStreamCommands.AcknowledgeCommand
- 
Creates a newReactiveStreamCommands.AcknowledgeCommandgiven akey.
- stream(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveStreamCommands.DeleteCommand
- 
Creates a newReactiveStreamCommands.DeleteCommandgiven akey.
- stream(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveStreamCommands.RangeCommand
- 
Creates a newReactiveStreamCommands.RangeCommandgiven akey.
- stream(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveStreamCommands.TrimCommand
- 
Creates a newReactiveStreamCommands.TrimCommandgiven 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
- 
GetRedisStreamCommands.
- 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 ofmessages.
- 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 aConsumer.
- StreamMessageListenerContainer.ConsumerStreamReadRequestBuilder<K> - Class in org.springframework.data.redis.stream
- 
Builder to build aStreamMessageListenerContainer.ConsumerStreamReadRequest.
- StreamMessageListenerContainer.StreamMessageListenerContainerOptions<K,V extends Record<K, ?>> - Class in org.springframework.data.redis.stream 
- 
Options forStreamMessageListenerContainer.
- 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 aStreamMessageListenerContainer.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 forStreamReceiver.
- StreamReceiver.StreamReceiverOptionsBuilder<K,V extends Record<K, ?>> - Class in org.springframework.data.redis.stream 
- 
Builder forStreamReceiver.StreamReceiverOptions.
- StreamRecords - Class in org.springframework.data.redis.connection.stream
- 
StreamRecordsprovides utilities to create specificRecordinstances.
- StreamRecords.RecordBuilder<S> - Class in org.springframework.data.redis.connection.stream
- 
Builder forRecord.
- string() - Static method in interface org.springframework.data.redis.serializer.RedisSerializationContext
- 
Creates a newRedisSerializationContextusing 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 newByteBufferRecordfor the given raw field/value pairs.
- string(RedisElementReader<String>, RedisElementWriter<String>) - Method in interface org.springframework.data.redis.serializer.RedisSerializationContext.RedisSerializationContextBuilder
- 
Set the stringRedisElementReaderandRedisElementWriter.
- string(RedisSerializationContext.SerializationPair<String>) - Method in interface org.springframework.data.redis.serializer.RedisSerializationContext.RedisSerializationContextBuilder
- 
Set the stringRedisSerializationContext.SerializationPair.
- string(RedisSerializer<String>) - Method in interface org.springframework.data.redis.serializer.RedisSerializationContext.RedisSerializationContextBuilder
- 
Set the stringRedisSerializationContext.SerializationPairgiven 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
- 
GetRedisStringCommands.
- StringRecord - Interface in org.springframework.data.redis.connection.stream
- StringRedisConnection - Interface in org.springframework.data.redis.connection
- 
Convenience extension ofRedisConnectionthat accepts and returnsStrings 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
- 
SimpleStringto byte[] (and back) serializer.
- StringRedisSerializer() - Constructor for class org.springframework.data.redis.serializer.StringRedisSerializer
- 
Creates a newStringRedisSerializerusingUTF-8.
- StringRedisSerializer(Charset) - Constructor for class org.springframework.data.redis.serializer.StringRedisSerializer
- 
Creates a newStringRedisSerializerusing the givenCharsetto 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 newStringRedisTemplateinstance.
- StringRedisTemplate(RedisConnectionFactory) - Constructor for class org.springframework.data.redis.core.StringRedisTemplate
- 
Constructs a newStringRedisTemplateinstance ready to be used.
- stringsWithin(Range<String>) - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZLexCountCommand
- 
Creates a newReactiveZSetCommands.ZLexCountCommandgiven aRangeofStringto retrieve elements count.
- stringsWithin(Range<String>) - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRangeByLexCommand
- 
Creates a newReactiveZSetCommands.ZRangeByLexCommandgiven aRangeofStringto 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 toDataTypes
- StringToDataTypeConverter() - Constructor for class org.springframework.data.redis.connection.convert.StringToDataTypeConverter
- StringToPropertiesConverter - Class in org.springframework.data.redis.connection.convert
- 
Converts Strings toProperties
- 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 ofRedisCommandsProvider.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 atkey.
- 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 atkey.
- 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 givenchannels.
- subscribe(ByteBuffer...) - Method in interface org.springframework.data.redis.connection.ReactiveSubscription
- 
Subscribes to thechannelsand 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
- 
TheSubscriptionis 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 ofRedisCommandsProvider.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 givenkeys.
- 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 givenkeys.
- 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 atReactiveSetCommands.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 ofRedisCommandsProvider.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 givenkeysand 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 givenkeysand 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
- 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 actualTaskto run within theStreamMessageListenerContainer.
- Task.State - Enum Class in org.springframework.data.redis.stream
- 
TheTask.Statedefining the lifecycle phase the actualTask.
- time() - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.serverCommands().
- time() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- time() - Method in interface org.springframework.data.redis.connection.ReactiveServerCommands
- 
Request server timestamp usingTIMEcommand inTimeUnit.MILLISECONDS.
- time() - Method in interface org.springframework.data.redis.connection.RedisServerCommands
- 
Request server timestamp usingTIMEcommand 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 ofRedisCommandsProvider.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 usingTIMEcommand.
- time(TimeUnit) - Method in interface org.springframework.data.redis.connection.RedisServerCommands
- 
Request server timestamp usingTIMEcommand.
- time(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.DefaultedRedisClusterConnection
- 
Deprecated.in favor ofRedisCommandsProvider.serverCommands().
- time(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.ReactiveClusterServerCommands
- 
Request server timestamp usingTIMEcommand.
- 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 ofRedisCommandsProvider.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 thetimeout.
- 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
- 
TimeToLivemarks a single numeric property on aggregate root to be used for setting expirations in Redis.
- TimeToLiveAccessor - Interface in org.springframework.data.redis.core
- 
TimeToLiveAccessorextracts 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 thetargetKey.
- 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 thedestinationKey.
- 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
- 
ConvertBitFieldSubCommandsintoBitFieldArgs.
- 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 underlyingConversionService.
- toBytes(Object) - Method in class org.springframework.data.redis.core.RedisKeyValueAdapter
- 
Convert given source to binary representation using the underlyingConversionService.
- 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 ofCLUSTER NODESinto 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
- 
ConvertRedisGeoCommands.GeoCommandArgsintoGeoArgs.
- toGeoArgs(RedisGeoCommands.GeoRadiusCommandArgs) - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
- 
ConvertRedisGeoCommands.GeoRadiusCommandArgsintoGeoArgs.
- toGeoArgsUnit(Metric) - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
- 
ConvertMetricintoGeoArgs.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 anobjectto 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 theRange.
- 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 aLimitto 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 givenHashMapperto 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 binaryMapRecordinto anObjectRecord.
- toObjectRecord(HashMapper<? super OV, ? super K, ? super V>) - Method in interface org.springframework.data.redis.connection.stream.MapRecord
- 
Apply the givenHashMapperto 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
- 
DataRetrievalFailureExceptionthrown when following cluster redirects exceeds the max number of edges.
- TooManyClusterRedirectionsException(String) - Constructor for exception org.springframework.data.redis.TooManyClusterRedirectionsException
- 
Creates newTooManyClusterRedirectionsException.
- TooManyClusterRedirectionsException(String, Throwable) - Constructor for exception org.springframework.data.redis.TooManyClusterRedirectionsException
- 
Creates newTooManyClusterRedirectionsException.
- toOptional() - Method in class org.springframework.data.redis.connection.RedisPassword
- 
Adopt the password toOptionalcontaining 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 byCONFIG GET) from aListtoProperties.
- 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 aRangeobject from this range.
- toRange(Range<T>) - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
- 
Convert aRedisZSetCommands.Rangeto a lettuceRange.
- toRange(Range<T>, boolean) - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
- 
Convert aRangeto 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 aRangeto a lettuceRangeand 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 ofCLUSTER NODESintoRedisClusterNodes.
- toSetOfRedisClusterNodes(Collection<String>) - Static method in class org.springframework.data.redis.connection.convert.Converters
- 
Converts lines from the result ofCLUSTER NODESintoRedisClusterNodes.
- toSortArgs(SortParameters) - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
- 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.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.PatternTopic
- 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 givensecondsandmicroseconds.
- toTimeMillis(String, String, TimeUnit) - Static method in class org.springframework.data.redis.connection.convert.Converters
- 
Returns the timestamp constructed from the givensecondsandmicroseconds.
- 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 ofRedisCommandsProvider.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 givenkey(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 givenkey(s).
- touch(Collection<ByteBuffer>) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
- 
Alter the last access time of givenkey(s).
- touch(Publisher<Collection<ByteBuffer>>) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
- 
Alter the last access time of givenkey(s).
- transactionAware() - Method in class org.springframework.data.redis.cache.RedisCacheManager.RedisCacheManagerBuilder
- 
EnableRedisCaches 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 ofFutureResults.
- 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 givenExceptionintoDataAccessException.
- 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 betweenstartandend.
- trim(long) - Method in interface org.springframework.data.redis.core.BoundStreamOperations
- 
Trims the stream tocountelements.
- trim(long, boolean) - Method in interface org.springframework.data.redis.core.BoundStreamOperations
- 
Trims the stream tocountelements.
- trim(long, long) - Method in interface org.springframework.data.redis.core.BoundListOperations
- 
Trim list at the bound key to elements betweenstartandend.
- 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 betweenstartandend.
- trim(K, long) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
- 
Trims the stream tocountelements.
- trim(K, long) - Method in interface org.springframework.data.redis.core.StreamOperations
- 
Trims the stream tocountelements.
- trim(K, long, boolean) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
- 
Trims the stream tocountelements.
- trim(K, long, boolean) - Method in interface org.springframework.data.redis.core.StreamOperations
- 
Trims the stream tocountelements.
- trim(K, long, long) - Method in interface org.springframework.data.redis.core.ListOperations
- 
Trim list atkeyto elements betweenstartandend.
- trim(K, long, long) - Method in interface org.springframework.data.redis.core.ReactiveListOperations
- 
Trim list atkeyto elements betweenstartandend.
- ttl(byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 forkeyin seconds.
- ttl(byte[], TimeUnit) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 forkeyin 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 forkeyin 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 forkeyin and convert it to the givenTimeUnit.
- ttl(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
- 
Get the time to live forkeyin 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 newReactiveZSetCommands.ZAddCommandgiven 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 ofRedisCommandsProvider.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 atkey.
- 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 atkey.
- type(String) - Method in class org.springframework.data.redis.core.ScanOptions.ScanOptionsBuilder
- 
Returns the currentScanOptions.ScanOptionsBuilderconfigured 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 atkey.
- 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 atkey.
- 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 currentScanOptions.ScanOptionsBuilderconfigured with the giventype.
- TYPE - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
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 newRedisStreamCommands.XPendingOptionswith 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 newRedisStreamCommands.XPendingOptionswith 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 otherRedisSets.
- 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 otherRedisZSets.
- union(Collection<K>) - Method in interface org.springframework.data.redis.core.BoundSetOperations
- 
Union all sets at givenkeysandkeys.
- union(Collection<K>) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
- 
Union sortedsets.
- union(Collection<K>) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
- 
Union all sets at givenkeys.
- union(Collection<K>) - Method in interface org.springframework.data.redis.core.SetOperations
- 
Union all sets at givenkeys.
- union(K) - Method in interface org.springframework.data.redis.core.BoundSetOperations
- 
Union all sets at givenkeyandkey.
- union(K) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
- 
Union sortedsets.
- union(K, Collection<K>) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
- 
Union all sets at givenkeysandotherKeys.
- union(K, Collection<K>) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- 
Union sortedsets.
- union(K, Collection<K>) - Method in interface org.springframework.data.redis.core.SetOperations
- 
Union all sets at givenkeysandotherKeys.
- union(K, Collection<K>) - Method in interface org.springframework.data.redis.core.ZSetOperations
- 
Union sortedsets.
- union(K, K) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
- 
Union all sets at givenkeysandotherKey.
- union(K, K) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- 
Union sortedsets.
- union(K, K) - Method in interface org.springframework.data.redis.core.SetOperations
- 
Union all sets at givenkeysandotherKey.
- union(K, K) - Method in interface org.springframework.data.redis.core.ZSetOperations
- 
Union sortedsets.
- 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 anotherRedisSet.
- 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 anotherRedisZSet.
- 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 andkeysand store result indestKey.
- unionAndStore(Collection<K>, K) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
- 
Union sorted sets at the bound key andotherKeysand store result in destinationdestKey.
- unionAndStore(Collection<K>, K) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
- 
Union all sets at givenkeysand store result indestKey.
- unionAndStore(Collection<K>, K) - Method in interface org.springframework.data.redis.core.SetOperations
- 
Union all sets at givenkeysand store result indestKey.
- unionAndStore(Collection<K>, K, Aggregate) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
- 
Union sorted sets at the bound key andotherKeysand 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 andotherKeysand store result in destinationdestKey.
- unionAndStore(K, Collection<K>, K) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
- 
Union all sets at givenkeyandotherKeysand store result indestKey.
- unionAndStore(K, Collection<K>, K) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- 
Union sorted sets atkeyandotherKeysand store result in destinationdestKey.
- unionAndStore(K, Collection<K>, K) - Method in interface org.springframework.data.redis.core.SetOperations
- 
Union all sets at givenkeyandotherKeysand store result indestKey.
- unionAndStore(K, Collection<K>, K) - Method in interface org.springframework.data.redis.core.ZSetOperations
- 
Union sorted sets atkeyandotherKeysand store result in destinationdestKey.
- unionAndStore(K, Collection<K>, K, Aggregate) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- 
Union sorted sets atkeyandotherKeysand store result in destinationdestKey.
- unionAndStore(K, Collection<K>, K, Aggregate) - Method in interface org.springframework.data.redis.core.ZSetOperations
- 
Union sorted sets atkeyandotherKeysand store result in destinationdestKey.
- unionAndStore(K, Collection<K>, K, Aggregate, Weights) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- 
Union sorted sets atkeyandotherKeysand store result in destinationdestKey.
- unionAndStore(K, Collection<K>, K, Aggregate, Weights) - Method in interface org.springframework.data.redis.core.ZSetOperations
- 
Union sorted sets atkeyandotherKeysand store result in destinationdestKey.
- unionAndStore(K, K) - Method in interface org.springframework.data.redis.core.BoundSetOperations
- 
Union all sets at given the bound key andkeyand store result indestKey.
- unionAndStore(K, K) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
- 
Union sorted sets at the bound key andotherKeysand store result in destinationdestKey.
- unionAndStore(K, K, K) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
- 
Union all sets at givenkeyandotherKeyand store result indestKey.
- unionAndStore(K, K, K) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- 
Union sorted sets atkeyandotherKeysand store result in destinationdestKey.
- unionAndStore(K, K, K) - Method in interface org.springframework.data.redis.core.SetOperations
- 
Union all sets at givenkeyandotherKeyand store result indestKey.
- unionAndStore(K, K, K) - Method in interface org.springframework.data.redis.core.ZSetOperations
- 
Union sorted sets atkeyandotherKeysand 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 otherRedisZSets.
- unionWithScores(Collection<K>) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
- 
Union sortedsets.
- unionWithScores(Collection<K>, Aggregate) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
- 
Union sorted sets at the bound key andotherKeys.
- unionWithScores(Collection<K>, Aggregate, Weights) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
- 
Union sortedsets.
- unionWithScores(K) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
- 
Union sortedsets.
- unionWithScores(K, Collection<K>) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- 
Union sortedsets.
- unionWithScores(K, Collection<K>) - Method in interface org.springframework.data.redis.core.ZSetOperations
- 
Union sortedsets.
- unionWithScores(K, Collection<K>, Aggregate) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- 
Union sorted sets atkeyandotherKeys.
- unionWithScores(K, Collection<K>, Aggregate) - Method in interface org.springframework.data.redis.core.ZSetOperations
- 
Union sorted sets atkeyandotherKeys.
- unionWithScores(K, Collection<K>, Aggregate, Weights) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- 
Union sortedsets.
- unionWithScores(K, Collection<K>, Aggregate, Weights) - Method in interface org.springframework.data.redis.core.ZSetOperations
- 
Union sortedsets.
- unionWithScores(K, K) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
- 
Union sortedsets.
- unionWithScores(K, K) - Method in interface org.springframework.data.redis.core.ZSetOperations
- 
Union sortedsets.
- 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 anotherRedisZSet.
- unit() - Element in annotation interface org.springframework.data.redis.core.TimeToLive
- 
TimeUnitunit to use.
- unixTimestamp(long, TimeUnit) - Static method in class org.springframework.data.redis.core.types.Expiration
- 
Creates newExpirationwith 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 ofRedisCommandsProvider.keyCommands().
- unlink(byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- unlink(byte[]...) - Method in interface org.springframework.data.redis.connection.RedisKeyCommands
- 
Unlink thekeysfrom 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 thekeysfrom the keyspace.
- unlink(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
- 
Unlink thekeyfrom the keyspace.
- unlink(Collection<K>) - Method in interface org.springframework.data.redis.core.RedisOperations
- 
Unlink thekeysfrom 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 thekeyfrom 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 thekeyfrom 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 thekeysfrom 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 thekeyfrom the keyspace.
- unsigned(int) - Static method in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldType
- 
Create new unsignedBitFieldSubCommands.BitFieldType.
- unsubscribe() - Method in interface org.springframework.data.redis.connection.ReactiveSubscription
- 
Cancels the current subscription for allchannels.
- 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 previouslyRedisTxCommands.watch(byte[]...)keys.
- unwatch() - Method in interface org.springframework.data.redis.core.RedisOperations
- 
Flushes all the previouslyRedisOperations.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 givenupdate function.
- updateAndGet(IntUnaryOperator) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicInteger
- 
Atomically update the current value using the givenupdate function.
- updateAndGet(LongUnaryOperator) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicLong
- 
Atomically update the current value using the givenupdate 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
- 
StringRedisSerializerto use 7 bit ASCII, a.k.a.
- 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
- 
StringRedisSerializerto 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 givenargument countagainst 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 theEnableRedisRepositories.basePackages()attribute.
- value(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveHashCommands.HSetCommand
- 
Creates a newReactiveHashCommands.HSetCommandgiven akey.
- value(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveHyperLogLogCommands.PfAddCommand
- 
Creates a newReactiveHyperLogLogCommands.PfAddCommandgiven avalue.
- value(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveListCommands.LInsertCommand
- 
Creates a newReactiveListCommands.LInsertCommandgiven 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 newReactiveSetCommands.SAddCommandgiven a value.
- value(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveSetCommands.SIsMemberCommand
- 
Creates a newReactiveSetCommands.SIsMemberCommandgiven a value.
- value(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveSetCommands.SMoveCommand
- 
Creates a newReactiveSetCommands.SMoveCommandgiven a value.
- value(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveSetCommands.SRemCommand
- 
Creates a newReactiveSetCommands.SRemCommandgiven 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 valueRedisElementReaderandRedisElementWriter.
- value(RedisSerializationContext.SerializationPair<V>) - Method in interface org.springframework.data.redis.serializer.RedisSerializationContext.RedisSerializationContextBuilder
- 
Set the valueRedisSerializationContext.SerializationPair.
- value(RedisSerializer<V>) - Method in interface org.springframework.data.redis.serializer.RedisSerializationContext.RedisSerializationContextBuilder
- 
Set the valueRedisSerializationContext.SerializationPairgiven 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 newReactiveSetCommands.SRandMembersCommandgiven the number of values to retrieve.
- valueCount(long) - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRandMemberCommand
- 
Creates a newReactiveZSetCommands.ZRandMemberCommandgiven the number of values to retrieve.
- ValueEncoding - Interface in org.springframework.data.redis.connection
- 
ValueEncodingis 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
- 
DefaultValueEncodingimplementation of encodings used in Redis.
- valueIn(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveHyperLogLogCommands.PfCountCommand
- 
Creates a newReactiveHyperLogLogCommands.PfCountCommandgiven 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
- 
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
- 
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 atkey.
- values(H) - Method in interface org.springframework.data.redis.core.ReactiveHashOperations
- 
Get entry set (values) of hash atkey.
- values(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRemCommand
- 
Creates a newReactiveZSetCommands.ZRemCommandgiven 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 newReactiveSetCommands.SAddCommandgiven aCollectionof values.
- values(Collection<ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveSetCommands.SRemCommand
- 
Creates a newReactiveSetCommands.SRemCommandgiven aCollectionof 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 aListof values.
- values(List<ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveSetCommands.SMIsMemberCommand
- 
Creates a newReactiveSetCommands.SMIsMemberCommandgiven one or more values.
- valuesIn(Collection<ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveHyperLogLogCommands.PfCountCommand
- 
Creates a newReactiveHyperLogLogCommands.PfCountCommandgiven aCollectionof keys.
- valuesIn(Collection<ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveHyperLogLogCommands.PfMergeCommand
- 
Creates a newReactiveHyperLogLogCommands.PfMergeCommandgiven aCollectionof sourceKeys.
- valuesWithin(Range<Long>) - Static method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRangeCommand
- 
Creates a newReactiveZSetCommands.ZRangeCommandgiven aRangeto 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 newReactiveZSetCommands.ZRemRangeByRankCommandgiven 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 newReactiveZSetCommands.ZRangeStoreCommandgiven aRangeto obtain elements ordered from the lowest to the highest lexicographical value.
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 givenkeysfor modifications during transaction started withRedisTxCommands.multi().
- watch(Collection<K>) - Method in interface org.springframework.data.redis.core.RedisOperations
- 
Watch givenkeysfor 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 givenkeyfor 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 commandRedisGeoCommands.GeoRadiusCommandArgs.
- withArgs(RedisGeoCommands.GeoRadiusCommandArgs) - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusCommand
- 
Applies commandRedisGeoCommands.GeoRadiusCommandArgs.
- withCacheConfiguration(String, RedisCacheConfiguration) - Method in class org.springframework.data.redis.cache.RedisCacheManager.RedisCacheManagerBuilder
- 
Registers the givencache nameandRedisCacheConfigurationused to create and configure aRedisCacheon startup.
- withConversionService(ConversionService) - Method in class org.springframework.data.redis.cache.RedisCacheConfiguration
- 
Define theConversionServiceused for cache key toStringconversion.
- 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
- 
AppliesExpiration.
- withFlag(RedisGeoCommands.GeoRadiusCommandArgs.Flag) - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusByMemberCommand
- 
Applies commandflags.
- withFlag(RedisGeoCommands.GeoRadiusCommandArgs.Flag) - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusCommand
- 
Applies commandflags.
- 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 aString.
- 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 aRecordId.
- 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 aRange.
- within(Range<Long>) - Method in class org.springframework.data.redis.connection.ReactiveStringCommands.BitCountCommand
- 
Applies theRange.
- 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 aRange.
- within(Circle) - Static method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusCommand
- 
Creates a newReactiveGeoCommands.GeoRadiusCommandgiven aCircle.
- within(Distance) - Static method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusByMemberCommand
- 
Creates a newReactiveGeoCommands.GeoRadiusByMemberCommandgiven aDistance.
- within(Distance) - Static method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusCommand
- 
Creates a newReactiveGeoCommands.GeoRadiusCommandgiven aDistance.
- within(GeoShape) - Static method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoSearchCommand
- 
Creates a newReactiveGeoCommands.GeoSearchCommandgiven aGeoShape.
- within(GeoShape) - Static method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoSearchStoreCommand
- 
Creates a newReactiveGeoCommands.GeoSearchStoreCommandgiven aGeoShape.
- withinFeet(double) - Static method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusByMemberCommand
- 
Creates a newReactiveGeoCommands.GeoRadiusByMemberCommandgiven a distance inRedisGeoCommands.DistanceUnit.FEET.
- withinFeet(double) - Static method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusCommand
- 
Creates a newReactiveGeoCommands.GeoRadiusCommandgiven a distance inRedisGeoCommands.DistanceUnit.FEET.
- withInitialCacheConfigurations(Map<String, RedisCacheConfiguration>) - Method in class org.springframework.data.redis.cache.RedisCacheManager.RedisCacheManagerBuilder
- 
Append aMapof cache name/RedisCacheConfigurationpairs to be pre initialized.
- withinKilometers(double) - Static method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusCommand
- 
Creates a newReactiveGeoCommands.GeoRadiusCommandgiven a distance inRedisGeoCommands.DistanceUnit.KILOMETERS.
- withinKiometers(double) - Static method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusByMemberCommand
- 
Creates a newReactiveGeoCommands.GeoRadiusByMemberCommandgiven a distance inRedisGeoCommands.DistanceUnit.KILOMETERS.
- withinMeters(double) - Static method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusByMemberCommand
- 
Creates a newReactiveGeoCommands.GeoRadiusByMemberCommandgiven a distance inRedisGeoCommands.DistanceUnit.METERS.
- withinMeters(double) - Static method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusCommand
- 
Creates a newReactiveGeoCommands.GeoRadiusCommandgiven a distance inRedisGeoCommands.DistanceUnit.METERS.
- withinMiles(double) - Static method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusByMemberCommand
- 
Creates a newReactiveGeoCommands.GeoRadiusByMemberCommandgiven a distance inRedisGeoCommands.DistanceUnit.MILES.
- withinMiles(double) - Static method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusCommand
- 
Creates a newReactiveGeoCommands.GeoRadiusCommandgiven a distance inRedisGeoCommands.DistanceUnit.MILES.
- withinRange(Range<?>) - Method in class org.springframework.data.redis.connection.stream.PendingMessages
- 
Adds the range to the currentPendingMessages.
- 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 givenStreamReadOptions.
- withOptions(ScanOptions) - Method in class org.springframework.data.redis.connection.ReactiveRedisConnection.KeyScanCommand
- 
AppliesScanOptions.
- 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
- 
AppliesRedisStringCommands.SetOption.
- withStatisticsCollector(CacheStatisticsCollector) - Method in interface org.springframework.data.redis.cache.RedisCacheWriter
- 
Obtain aRedisCacheWriterusing the givenCacheStatisticsCollectorto collect metrics.
- withStreamKey(byte[]) - Method in interface org.springframework.data.redis.connection.stream.ByteRecord
- 
Create a newByteRecordwith the associated stream key.
- withStreamKey(String) - Method in interface org.springframework.data.redis.connection.stream.StringRecord
- 
Create a newStringRecordwith the associated stream key.
- withStreamKey(ByteBuffer) - Method in interface org.springframework.data.redis.connection.stream.ByteBufferRecord
- 
Create a newByteBufferRecordwith 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 ofRecordwith 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 rootsourceas 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 aelementto itsByteBufferrepresentation.
- write(T) - Method in interface org.springframework.data.redis.serializer.RedisSerializationContext.SerializationPair
- 
Serialize the givenelementto itsByteBufferrepresentation.
- writePartialUpdate(PartialUpdate<?>, RedisData) - Method in class org.springframework.data.redis.core.convert.MappingRedisConverter
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 ofRedisCommandsProvider.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 givenfield/value pairsas 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 streamkey.
- 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(MapRecord<byte[], byte[], byte[]>) - Method in interface org.springframework.data.redis.connection.RedisStreamCommands
- 
Append the givenrecordto the stream stored atRecord#getStream.
- xAdd(MapRecord<byte[], byte[], byte[]>, RedisStreamCommands.XAddOptions) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 givenrecordto the stream stored atRecord#getStream.
- xAdd(StringRecord) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
- 
Append the givenStringRecordto 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 givenStringRecordto 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 ofRedisCommandsProvider.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 ofRedisCommandsProvider.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 ofRedisCommandsProvider.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 givenReactiveStreamCommands.GroupCommandto create, destroy,... groups.
- xGroup(ReactiveStreamCommands.GroupCommand) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
- 
Execute the givenReactiveStreamCommands.GroupCommandto create, destroy,... groups.
- xGroupCreate(byte[], String, ReadOffset) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 ofRedisCommandsProvider.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 ofRedisCommandsProvider.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 ofRedisCommandsProvider.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 ofRedisCommandsProvider.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 ofRedisCommandsProvider.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 ofRedisCommandsProvider.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 ofRedisCommandsProvider.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 atReactiveRedisConnection.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 ofRedisCommandsProvider.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 thePendingMessagesSummaryfor 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
- 
Obtain detailed information about pendingmessagesfor a givenRangeand consumer within a consumer group.
- xPending(byte[], String, Range<?>, Long) - Method in interface org.springframework.data.redis.connection.RedisStreamCommands
- 
Obtain detailed information about pendingmessagesfor a givenRangewithin a consumer group.
- xPending(byte[], String, RedisStreamCommands.XPendingOptions) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 givenConsumer.
- 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 thePendingMessagesSummaryfor 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
- 
Obtain detailed information about pendingmessagesfor a givenRangewithin a consumer group.
- 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
- 
Obtain detailed information about pendingmessagesfor a givenRangewithin a consumer group.
- 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 thePendingMessagesSummaryfor 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
- 
Obtain detailed information about pendingmessagesfor a givenRangeand consumer within a consumer group.
- xPending(ByteBuffer, String, Range<?>, Long) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
- 
Obtain detailed information about pendingmessagesfor a givenRangewithin a consumer group.
- xPending(ByteBuffer, Consumer) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
- 
Obtained detailed information about all pending messages for a givenConsumer.
- 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 thePendingMessagesSummaryfor a given consumer group.
- xRange(byte[], Range<String>) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.streamCommands()}.
- xRange(byte[], Range<String>) - Method in interface org.springframework.data.redis.connection.RedisStreamCommands
- 
Retrieve allrecordswithin a specificRangefrom the stream stored at key.
- xRange(byte[], Range<String>, Limit) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 specificRedisZSetCommands.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 specificRedisZSetCommands.Rangeapplying aLimit.
- xRange(ByteBuffer, Range<String>) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
- 
Read records from a stream within a specificRange.
- xRange(ByteBuffer, Range<String>, Limit) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
- 
Read records from a stream within a specificRangeapplying aLimit.
- xRange(Publisher<ReactiveStreamCommands.RangeCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
- 
Read records from a stream within a specificRangeapplying aLimit.
- xRead(StreamOffset<byte[]>...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.streamCommands()}.
- xRead(StreamOffset<byte[]>...) - Method in interface org.springframework.data.redis.connection.RedisStreamCommands
- 
Read records from one or moreStreamOffsets.
- xRead(StreamOffset<ByteBuffer>...) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
- 
Read records from one or moreStreamOffsets.
- xRead(StreamReadOptions, StreamOffset<byte[]>...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 moreStreamOffsets.
- xRead(StreamReadOptions, StreamOffset<ByteBuffer>...) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
- 
Read records from one or moreStreamOffsets.
- xReadAsString(StreamOffset<String>) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
- 
Read records from one or moreStreamOffsets.
- xReadAsString(StreamOffset<String>...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
- 
Read records from one or moreStreamOffsets.
- xReadAsString(StreamReadOptions, StreamOffset<String>) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
- 
Read records from one or moreStreamOffsets.
- 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 moreStreamOffsets.
- xReadGroup(Consumer, StreamOffset<byte[]>...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.streamCommands()}.
- xReadGroup(Consumer, StreamOffset<byte[]>...) - Method in interface org.springframework.data.redis.connection.RedisStreamCommands
- 
Read records from one or moreStreamOffsets using a consumer group.
- xReadGroup(Consumer, StreamOffset<ByteBuffer>...) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
- 
Read records from one or moreStreamOffsets using a consumer group.
- xReadGroup(Consumer, StreamReadOptions, StreamOffset<byte[]>...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 moreStreamOffsets using a consumer group.
- xReadGroup(Consumer, StreamReadOptions, StreamOffset<ByteBuffer>...) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
- 
Read records from one or moreStreamOffsets using a consumer group.
- xReadGroupAsString(Consumer, StreamOffset<String>) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
- 
Read records from one or moreStreamOffsets using a consumer group.
- xReadGroupAsString(Consumer, StreamOffset<String>...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
- 
Read records from one or moreStreamOffsets using a consumer group.
- xReadGroupAsString(Consumer, StreamReadOptions, StreamOffset<String>) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
- 
Read records from one or moreStreamOffsets 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 moreStreamOffsets using a consumer group.
- xRevRange(byte[], Range<String>) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.streamCommands()}.
- xRevRange(byte[], Range<String>) - Method in interface org.springframework.data.redis.connection.RedisStreamCommands
- 
Read records from a stream within a specificRangein reverse order.
- xRevRange(byte[], Range<String>, Limit) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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
- 
Read records from a stream within a specificRangeapplying aLimitin reverse order.
- xRevRange(String, Range<String>) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
- 
Read records from a stream within a specificRedisZSetCommands.Rangein 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 specificRedisZSetCommands.Rangeapplying aLimitin reverse order.
- xRevRange(ByteBuffer, Range<String>) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
- 
Read records from a stream within a specificRangein reverse order.
- xRevRange(ByteBuffer, Range<String>, Limit) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
- 
Read records from a stream within a specificRangeapplying aLimitin reverse order.
- xRevRange(Publisher<ReactiveStreamCommands.RangeCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
- 
Read records from a stream within a specificRangeapplying aLimitin reverse order.
- xTrim(byte[], long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 tocountelements.
- 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 tocountelements.
- 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 tocountelements.
- 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 tocountelements.
- xTrim(ByteBuffer, long) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
- 
Trims the stream tocountelements.
- xTrim(ByteBuffer, long, boolean) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
- 
Trims the stream tocountelements.
- xTrim(Publisher<ReactiveStreamCommands.TrimCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveStreamCommands
- 
Trims the stream tocountelements.
- 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
- 
Addvalueto a sorted set atkey, or update itsscoreif it already exists.
- zAdd(byte[], double, byte[], RedisZSetCommands.ZAddArgs) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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
- 
Addtuplesto a sorted set atkey, or update itsscoreif it already exists.
- zAdd(byte[], Set<Tuple>, RedisZSetCommands.ZAddArgs) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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
- 
Addvalueto a sorted set atkey, or update itsscoreif 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
- 
Addtuplesto a sorted set atkey, or update itsscoreif 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
- 
AddReactiveZSetCommands.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 ofRedisCommandsProvider.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 withkey.
- 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 withkey.
- 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 withkey.
- 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 ofRedisCommandsProvider.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 betweenminandmax.
- zCount(byte[], Range<? extends Number>) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 betweenRange#minandRange#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 betweenminandmax.
- zCount(ByteBuffer, Range<Double>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
- 
Count number of elements within sorted set with scores withinRange.
- zCount(Publisher<ReactiveZSetCommands.ZCountCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
- 
Count number of elements within sorted set with scores withinRange.
- 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 ofRedisCommandsProvider.zSetCommands()}.
- zDiff(byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zDiff(byte[]...) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
- 
Diff sortedsets.
- zDiff(String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zDiff(String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
- 
Diff sortedsets.
- 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 ofRedisCommandsProvider.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 sortedsetsand 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 sortedsetsand 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 ofRedisCommandsProvider.zSetCommands()}.
- zDiffWithScores(byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zDiffWithScores(byte[]...) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
- 
Diff sortedsets.
- zDiffWithScores(String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zDiffWithScores(String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
- 
Diff sortedsets.
- 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 ofRedisCommandsProvider.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 withvaluein 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 withvaluein 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 withReactiveZSetCommands.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 ofRedisCommandsProvider.zSetCommands()}.
- zInter(byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zInter(byte[]...) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
- 
Intersect sortedsets.
- zInter(String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zInter(String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
- 
Intersect sortedsets.
- 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 ofRedisCommandsProvider.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 sortedsetsand store result in destinationdestKey.
- zInterStore(byte[], Aggregate, int[], byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 sortedsetsand store result in destinationdestKey.
- zInterStore(byte[], Aggregate, Weights, byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 sortedsetsand 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 sortedsetsand 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 sortedsetsand 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 ofRedisCommandsProvider.zSetCommands()}.
- zInterWithScores(byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zInterWithScores(byte[]...) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
- 
Intersect sortedsets.
- zInterWithScores(String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zInterWithScores(String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
- 
Intersect sortedsets.
- 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 ofRedisCommandsProvider.zSetCommands()}.
- zInterWithScores(Aggregate, int[], byte[]...) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
- 
Intersect sortedsets.
- zInterWithScores(Aggregate, int[], String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
- 
Intersect sortedsets.
- zInterWithScores(Aggregate, Weights, byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 sortedsets.
- 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 sortedsets.
- 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 ofRedisCommandsProvider.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 betweenRange#minandRange#maxapplying 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 betweenRange#minandRange#maxapplying lexicographical ordering.
- zLexCount(ByteBuffer, Range<String>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
- 
Count number of elements within sorted set with value betweenRange#minandRange#maxapplying lexicographical ordering.
- zLexCount(Publisher<ReactiveZSetCommands.ZLexCountCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
- 
Count number of elements within sorted set with value betweenRange#minandRange#maxapplying lexicographical ordering.
- zMScore(byte[], byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 withvaluesfrom 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 withvaluesfrom 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 withReactiveZSetCommands.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 atkeyCommand#getKey().
- zPopMax(byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 atkey.
- zPopMax(byte[], long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 returncountvalues 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 atkey.
- 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 returncountvalues 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 atkey.
- zPopMax(ByteBuffer, long) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
- 
Remove and returncountvalues 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 ofRedisCommandsProvider.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 atkey.
- zPopMin(byte[], long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 returncountvalues 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 atkey.
- 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 returncountvalues 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 atkey.
- zPopMin(ByteBuffer, long) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
- 
Remove and returncountvalues 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 ofRedisCommandsProvider.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 atkey.
- zRandMember(byte[], long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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
- 
Getcountrandom 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 atkey.
- zRandMember(String, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRandMember(String, long) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
- 
Getcountrandom elements from sorted set atkey.
- zRandMember(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
- 
Get random element from sorted set atkey.
- zRandMember(ByteBuffer, long) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
- 
Getcountrandom elements from sorted set atkey.
- zRandMember(Publisher<ReactiveZSetCommands.ZRandMemberCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
- 
Get random elements from sorted set atkey.
- zRandMemberWithScore(byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 atkey.
- zRandMemberWithScore(byte[], long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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
- 
Getcountrandom 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 atkey.
- zRandMemberWithScore(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
- 
Get random element from sorted set atkey.
- zRandMemberWithScore(ByteBuffer, long) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
- 
Getcountrandom elements from sorted set atkey.
- zRandMemberWithScore(Publisher<ReactiveZSetCommands.ZRandMemberCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
- 
Get random elements from sorted set atkey.
- zRandMemberWithScores(String, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zRandMemberWithScores(String, long) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
- 
Getcountrandom elements from sorted set atkey.
- zRange(byte[], long, long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 betweenstartandendfrom 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 betweenstartandendfrom 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 ofTuples 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 inRangefrom 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 ofRedisCommandsProvider.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 inRangefrom 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 inRedisZSetCommands.Rangefrom 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 inRedisZSetCommands.Rangefrom the sorted set at key in lexicographical ordering.
- zRangeByLex(ByteBuffer, Range<String>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
- 
Get all elements inRangefrom 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 inRangefrom the sorted set at key in lexicographical ordering.
- zRangeByLex(Publisher<ReactiveZSetCommands.ZRangeByLexCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
- 
Get all elements inRangefrom 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 betweenminandmaxfrom 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 fromstarttoendwhere score is betweenminandmaxfrom sorted set.
- zRangeByScore(byte[], String, String) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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, useRedisZSetCommands.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 ofRedisCommandsProvider.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 fromstarttoendwhere score is betweenminandmaxfrom 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 betweenRange#minandRange#maxfrom sorted set.
- zRangeByScore(byte[], Range<? extends Number>, Limit) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 fromLimit#counttoLimit#offsetwhere score is betweenRange#minandRange#maxfrom 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 betweenminandmaxfrom 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 fromstarttoendwhere score is betweenminandmaxfrom 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 betweenminandmaxfrom 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 fromstarttoendwhere score is betweenminandmaxfrom 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
- 
GetTuples 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 ofRedisCommandsProvider.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 ofTuples in range fromLimit#offsettoLimit#offset + Limit#countwhere score is betweenRange#minandRange#maxfrom 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
- 
GetTuples in range from sorted set.
- zRangeByScoreWithScores(ByteBuffer, Range<Double>, Limit) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
- 
GetTuples in range from sorted set.
- zRangeStore(Publisher<ReactiveZSetCommands.ZRangeStoreCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
- 
Get set ofTuples 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 ofRedisCommandsProvider.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 fromsrcKeyby 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 ofRedisCommandsProvider.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 fromsrcKeyby 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 ofRedisCommandsProvider.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 fromsrcKeyby 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 ofRedisCommandsProvider.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 fromsrcKeyby reverse score range todestKey.
- zRangeWithScores(byte[], long, long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 ofTuples in range from sorted set.
- zRank(byte[], byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 withvaluein 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 withvaluein 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 byReactiveZSetCommands.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 ofRedisCommandsProvider.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
- 
Removevaluesfrom 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
- 
Removevaluesfrom 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
- 
RemoveReactiveZSetCommands.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 ofRedisCommandsProvider.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 betweenstartandendfrom 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 betweenstartandendfrom sorted set withkey.
- zRemRangeByLex(byte[], Range<byte[]>) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 lexicographicalRange.
- 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 lexicographicalRedisZSetCommands.Range.
- zRemRangeByLex(ByteBuffer, Range<String>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
- 
Remove elements inRangefrom sorted set with key.
- zRemRangeByLex(Publisher<ReactiveZSetCommands.ZRemRangeByLexCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
- 
Remove elements inRangefrom sorted set withReactiveRedisConnection.KeyCommand.getKey().
- zRemRangeByRank(ByteBuffer, Range<Long>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
- 
Remove elements inRangefrom sorted set with key.
- zRemRangeByRank(Publisher<ReactiveZSetCommands.ZRemRangeByRankCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
- 
Remove elements inRangefrom 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 ofRedisCommandsProvider.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 betweenminandmaxfrom sorted set withkey.
- zRemRangeByScore(byte[], Range<? extends Number>) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 betweenRange#minandRange#maxfrom 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 betweenminandmaxfrom sorted set withkey.
- zRemRangeByScore(ByteBuffer, Range<Double>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
- 
Remove elements inRangefrom sorted set with key.
- zRemRangeByScore(Publisher<ReactiveZSetCommands.ZRemRangeByScoreCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
- 
Remove elements inRangefrom 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 ofRedisCommandsProvider.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 fromstarttoendfrom 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 fromstarttoendfrom 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 inRangefrom 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 ofRedisCommandsProvider.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 inRangefrom 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 inRedisZSetCommands.Rangefrom 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 inRedisZSetCommands.Rangefrom 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 inRangefrom 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 inRangefrom 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 betweenminandmaxfrom 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 fromstarttoendwhere score is betweenminandmaxfrom 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 betweenRange#minandRange#maxfrom 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 ofRedisCommandsProvider.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 fromLimit#offsettoLimit#offset + Limit#countwhere score is betweenRange#minandRange#maxfrom 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 betweenminandmaxfrom 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 fromstarttoendwhere score is betweenminandmaxfrom 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 ofTuplein range fromstarttoendwhere score is betweenminandmaxfrom 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 ofTuplewhere score is betweenRange#minandRange#maxfrom 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 ofRedisCommandsProvider.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 ofTuplein range fromLimit#offsettoLimit#countwhere score is betweenRange#minandRange#maxfrom 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 ofTuplein range fromstarttoendwhere score is betweenminandmaxfrom sorted set ordered high -> low.
- zRevRangeByScoreWithScores(ByteBuffer, Range<Double>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
- 
Get set ofTuples in range from sorted set in reverse score ordering.
- zRevRangeByScoreWithScores(ByteBuffer, Range<Double>, Limit) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
- 
GetTuples 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 ofRedisCommandsProvider.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 ofTuples in range from sorted set in reverse score ordering.
- zRevRank(byte[], byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 withvaluein 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 withvaluein 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 ofRedisCommandsProvider.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 aCursorto 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 aCursorto iterate over elements in sorted set atkey.
- zScan(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
- 
Use aFluxto 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 aFluxto 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 ofRedisCommandsProvider.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 withvaluefrom 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 withvaluefrom 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 withReactiveZSetCommands.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
- 
GetReactiveZSetCommands.
- zSetCommands() - Method in interface org.springframework.data.redis.connection.RedisCommandsProvider
- 
GetRedisZSetCommands.
- 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 ofRedisCommandsProvider.zSetCommands()}.
- zUnion(byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zUnion(byte[]...) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
- 
Union sortedsets.
- zUnion(String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zUnion(String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
- 
Union sortedsets.
- 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 ofRedisCommandsProvider.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 sortedsets.
- zUnionStore(byte[], Aggregate, int[], byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 sortedsetsand store result in destinationdestKey.
- zUnionStore(byte[], Aggregate, Weights, byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 sortedsetsand 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 sortedsetsand 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 sortedsetsand 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 ofRedisCommandsProvider.zSetCommands()}.
- zUnionWithScores(byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zUnionWithScores(byte[]...) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
- 
Union sortedsets.
- zUnionWithScores(String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
- zUnionWithScores(String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
- 
Union sortedsets.
- 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 ofRedisCommandsProvider.zSetCommands()}.
- zUnionWithScores(Aggregate, int[], byte[]...) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
- 
Union sortedsets.
- zUnionWithScores(Aggregate, int[], String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
- 
Union sortedsets.
- zUnionWithScores(Aggregate, Weights, byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
- 
Deprecated.in favor ofRedisCommandsProvider.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 sortedsets.
- 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 sortedsets.
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
RedisCommandsProvider.stringCommands()}.