Index

A B C D E F G H I J K L M N O P Q R S T U V W X Z 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form

A

AbsentByteBufferResponse(I) - Constructor for class org.springframework.data.redis.connection.ReactiveRedisConnection.AbsentByteBufferResponse
 
AbstractBitFieldSubCommand() - Constructor for class org.springframework.data.redis.connection.BitFieldSubCommands.AbstractBitFieldSubCommand
 
AbstractRedisCollection<E> - Class in org.springframework.data.redis.support.collections
Base implementation for RedisCollection.
AbstractRedisCollection(String, RedisOperations<String, E>) - Constructor for class org.springframework.data.redis.support.collections.AbstractRedisCollection
Constructs a new AbstractRedisCollection instance.
AbstractRedisConnection - Class in org.springframework.data.redis.connection
 
AbstractRedisConnection() - Constructor for class org.springframework.data.redis.connection.AbstractRedisConnection
 
AbstractSubscription - Class in org.springframework.data.redis.connection.util
Base implementation for a subscription handling the channel/pattern registration so subclasses only have to deal with the actual registration/unregistration.
AbstractSubscription(MessageListener) - Constructor for class org.springframework.data.redis.connection.util.AbstractSubscription
 
AbstractSubscription(MessageListener, byte[][], byte[][]) - Constructor for class org.springframework.data.redis.connection.util.AbstractSubscription
Constructs a new AbstractSubscription instance.
accumulateAndGet(double, DoubleBinaryOperator) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicDouble
Atomically update the current value using the given accumulator function.
accumulateAndGet(int, IntBinaryOperator) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicInteger
Atomically update the current value using the given accumulator function.
accumulateAndGet(long, LongBinaryOperator) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicLong
Atomically update the current value using the given accumulator function.
acknowledge(String, String...) - Method in interface org.springframework.data.redis.core.BoundStreamOperations
Acknowledge one or more records as processed.
acknowledge(String, Record<K, ?>) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
Acknowledge the given record as processed.
acknowledge(String, Record<K, ?>) - Method in interface org.springframework.data.redis.core.StreamOperations
Acknowledge the given record as processed.
acknowledge(K, String, String...) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
Acknowledge one or more records as processed.
acknowledge(K, String, String...) - Method in interface org.springframework.data.redis.core.StreamOperations
Acknowledge one or more records as processed.
acknowledge(K, String, RecordId...) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
Acknowledge one or more records as processed.
acknowledge(K, String, RecordId...) - Method in interface org.springframework.data.redis.core.StreamOperations
Acknowledge one or more records as processed.
add(byte[]) - Method in class org.springframework.data.redis.connection.util.ByteArraySet
 
add(int, E) - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
 
add(E) - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
 
add(E) - Method in class org.springframework.data.redis.support.collections.DefaultRedisSet
 
add(E) - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
 
add(E) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
Adds an element to the set with a default score.
add(E, double) - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
 
add(E, double) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
Adds an element to the set with the given score, or updates the score if the element exists.
add(Iterable<RedisGeoCommands.GeoLocation<M>>) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
add(Map<HK, HV>) - Method in interface org.springframework.data.redis.core.BoundStreamOperations
Append a record to the stream key.
add(Map<HK, HV>, RedisStreamCommands.XAddOptions) - Method in interface org.springframework.data.redis.core.BoundStreamOperations
Append a record to the stream key with the specified options.
add(Map<M, Point>) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
Add Map of member / Point pairs to key.
add(Set<ZSetOperations.TypedTuple<V>>) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
Add tuples to a sorted set at the bound key, or update its score if it already exists.
add(K, Iterable<RedisGeoCommands.GeoLocation<M>>) - Method in interface org.springframework.data.redis.core.GeoOperations
add(K, Iterable<RedisGeoCommands.GeoLocation<M>>) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
add(K, Map<? extends HK, ? extends HV>) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
Append a record to the stream key.
add(K, Map<? extends HK, ? extends HV>) - Method in interface org.springframework.data.redis.core.StreamOperations
Append a record to the stream key.
add(K, Map<? extends HK, ? extends HV>, RedisStreamCommands.XAddOptions) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
Append a record to the stream key with the specified options.
add(K, Map<? extends HK, ? extends HV>, RedisStreamCommands.XAddOptions) - Method in interface org.springframework.data.redis.core.StreamOperations
Append a record to the stream key with the specified options.
add(K, Map<M, Point>) - Method in interface org.springframework.data.redis.core.GeoOperations
Add Map of member / Point pairs to key.
add(K, Map<M, Point>) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
Add Map of member / Point pairs to key.
add(K, Set<ZSetOperations.TypedTuple<V>>) - Method in interface org.springframework.data.redis.core.ZSetOperations
Add tuples to a sorted set at key, or update its score if it already exists.
add(K, Publisher<? extends Collection<RedisGeoCommands.GeoLocation<M>>>) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
add(K, Publisher<? extends Map<? extends HK, ? extends HV>>) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
Append one or more records to the stream key.
add(K, Point, M) - Method in interface org.springframework.data.redis.core.GeoOperations
Add Point with given member name to key.
add(K, Point, M) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
Add Point with given member name to key.
add(K, RedisGeoCommands.GeoLocation<M>) - Method in interface org.springframework.data.redis.core.GeoOperations
add(K, RedisGeoCommands.GeoLocation<M>) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
add(K, V...) - Method in interface org.springframework.data.redis.core.HyperLogLogOperations
Adds the given values to the key.
add(K, V...) - Method in interface org.springframework.data.redis.core.ReactiveHyperLogLogOperations
Adds the given values to the key.
add(K, V...) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
Add given values to set at key.
add(K, V...) - Method in interface org.springframework.data.redis.core.SetOperations
Add given values to set at key.
add(K, V, double) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
Add value to a sorted set at key, or update its score if it already exists.
add(K, V, double) - Method in interface org.springframework.data.redis.core.ZSetOperations
Add value to a sorted set at key, or update its score if it already exists.
add(Point, M) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
Add Point with given member name to key.
add(RedisGeoCommands.GeoLocation<M>) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
add(MapRecord<K, ? extends HK, ? extends HV>) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
Append a record, backed by a Map holding the field/value pairs, to the stream.
add(MapRecord<K, ? extends HK, ? extends HV>) - Method in interface org.springframework.data.redis.core.StreamOperations
Append a record, backed by a Map holding the field/value pairs, to the stream.
add(MapRecord<K, ? extends HK, ? extends HV>, RedisStreamCommands.XAddOptions) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
Append a record, backed by a Map holding the field/value pairs, to the stream with the specified options.
add(MapRecord<K, ? extends HK, ? extends HV>, RedisStreamCommands.XAddOptions) - Method in interface org.springframework.data.redis.core.StreamOperations
Append a record, backed by a Map holding the field/value pairs, to the stream with the specified options.
add(Record<K, ?>) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
Append the record, backed by the given value, to the stream.
add(Record<K, ?>) - Method in interface org.springframework.data.redis.core.StreamOperations
Append the record, backed by the given value, to the stream.
add(Record<K, ?>, RedisStreamCommands.XAddOptions) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
Append the record, backed by the given value, to the stream with the specified options.
add(Record<K, ?>, RedisStreamCommands.XAddOptions) - Method in interface org.springframework.data.redis.core.StreamOperations
Append the record, backed by the given value, to the stream with the specified options.
add(ByteArrayWrapper) - Method in class org.springframework.data.redis.connection.util.ByteArraySet
 
add(V...) - Method in interface org.springframework.data.redis.core.BoundSetOperations
Add given values to set at the bound key.
add(V, double) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
Add value to a sorted set at the bound key, or update its score if it already exists.
addAll(int, Collection<? extends E>) - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
 
addAll(Iterable<byte[]>) - Method in class org.springframework.data.redis.connection.util.ByteArraySet
 
addAll(Collection<? extends E>) - Method in class org.springframework.data.redis.support.collections.AbstractRedisCollection
 
addAll(Collection<? extends ByteArrayWrapper>) - Method in class org.springframework.data.redis.connection.util.ByteArraySet
 
addAll(K, Collection<? extends ZSetOperations.TypedTuple<V>>) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
Add tuples to a sorted set at key, or update their score if it already exists.
addAndGet(double) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicDouble
Atomically add the given value to current value.
addAndGet(int) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicInteger
Atomically add the given value to current value.
addAndGet(long) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicLong
Atomically add the given value to current value.
addCacheKeyConverter(Converter<?, String>) - Method in class org.springframework.data.redis.cache.RedisCacheConfiguration
Adds a Converter to extract the String representation of a cache key if no suitable Object.toString() method is present.
addClusterNode(RedisNode) - Method in class org.springframework.data.redis.connection.RedisClusterConfiguration
Add a cluster node to configuration.
addCondition(IndexDefinition.Condition<?>) - Method in class org.springframework.data.redis.core.index.RedisIndexDefinition
 
addFirst(E) - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
 
addFirst(E) - Method in interface org.springframework.data.redis.support.collections.RedisList
addGetPattern(byte[]) - Method in class org.springframework.data.redis.connection.DefaultSortParameters
 
addIfAbsent(E) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
Adds an element to the set using the default score if the element does not already exists.
addIfAbsent(E, double) - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
 
addIfAbsent(E, double) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
Adds an element to the set with the given score if the element does not already exists.
addIfAbsent(Set<ZSetOperations.TypedTuple<V>>) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
Add tuples to a sorted set at the bound key if it does not already exists.
addIfAbsent(K, Set<ZSetOperations.TypedTuple<V>>) - Method in interface org.springframework.data.redis.core.ZSetOperations
Add tuples to a sorted set at key if it does not already exists.
addIfAbsent(K, V, double) - Method in interface org.springframework.data.redis.core.ZSetOperations
Add value to a sorted set at key if it does not already exists.
addIfAbsent(V, double) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
Add value to a sorted set at the bound key if it does not already exists.
addIndexDefinition(IndexDefinition) - Method in class org.springframework.data.redis.core.index.IndexConfiguration
 
addIndexDefinition(IndexDefinition) - Method in interface org.springframework.data.redis.core.index.IndexDefinitionRegistry
Add given IndexDefinition.
addIndexedData(Collection<IndexedData>) - Method in class org.springframework.data.redis.core.convert.RedisData
 
addIndexedData(IndexedData) - Method in class org.springframework.data.redis.core.convert.RedisData
 
addKeyspaceSettings(KeyspaceConfiguration.KeyspaceSettings) - Method in class org.springframework.data.redis.core.convert.KeyspaceConfiguration
addLast(E) - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
 
addLast(E) - Method in interface org.springframework.data.redis.support.collections.RedisList
addMessageListener(MessageListener, Collection<? extends Topic>) - Method in class org.springframework.data.redis.listener.RedisMessageListenerContainer
Adds a message listener to the (potentially running) container.
addMessageListener(MessageListener, Topic) - Method in class org.springframework.data.redis.listener.RedisMessageListenerContainer
Adds a message listener to the (potentially running) container.
addNode(String, int) - Method in class org.springframework.data.redis.connection.RedisStaticMasterReplicaConfiguration
Add a node to the list of nodes given hostName.
ADDRESS_PORT - Enum constant in enum class org.springframework.data.redis.core.types.RedisClientInfo.INFO
 
addSentinel(RedisNode) - Method in class org.springframework.data.redis.connection.RedisSentinelConfiguration
Add sentinel.
addSlots(RedisClusterNode, int...) - Method in interface org.springframework.data.redis.core.ClusterOperations
Add slots to given node;
addSlots(RedisClusterNode, RedisClusterNode.SlotRange) - Method in interface org.springframework.data.redis.core.ClusterOperations
Add slots in RedisClusterNode.SlotRange to given node.
after(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveListCommands.LInsertCommand
Applies the after pivot.
AFTER - Enum constant in enum class org.springframework.data.redis.connection.RedisListCommands.Position
 
afterPropertiesSet() - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
 
afterPropertiesSet() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
 
afterPropertiesSet() - Method in class org.springframework.data.redis.core.convert.MappingRedisConverter
 
afterPropertiesSet() - Method in class org.springframework.data.redis.core.RedisAccessor
 
afterPropertiesSet() - Method in class org.springframework.data.redis.core.RedisKeyValueAdapter
 
afterPropertiesSet() - Method in class org.springframework.data.redis.core.RedisTemplate
 
afterPropertiesSet() - Method in class org.springframework.data.redis.core.script.DefaultRedisScript
 
afterPropertiesSet() - Method in class org.springframework.data.redis.listener.adapter.MessageListenerAdapter
 
afterPropertiesSet() - Method in class org.springframework.data.redis.listener.KeyspaceEventMessageListener
 
afterPropertiesSet() - Method in class org.springframework.data.redis.listener.RedisMessageListenerContainer
 
afterPropertiesSet() - Method in class org.springframework.data.redis.serializer.OxmSerializer
 
afterPropertiesSet() - Method in class org.springframework.data.redis.support.collections.RedisCollectionFactoryBean
 
Aggregate - Enum Class in org.springframework.data.redis.connection.zset
Sort aggregation operations.
aggregateUsing(Aggregate) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZAggregateCommand
Applies a specific Aggregate function.
aggregateUsing(Aggregate) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZAggregateStoreCommand
Applies a specific Aggregate function.
aggregateUsing(Aggregate) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZInterStoreCommand
Applies a specific Aggregate function.
aggregateUsing(Aggregate) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZUnionStoreCommand
Applies a specific Aggregate function.
all() - Static method in class org.springframework.data.redis.connection.ReactiveListCommands.LRemCommand
Creates a new ReactiveListCommands.LRemCommand to delete all values.
allowCreateOnMissingCache(boolean) - Method in class org.springframework.data.redis.cache.RedisCacheManager.RedisCacheManagerBuilder
Configure whether to allow cache creation at runtime.
alpha() - Method in class org.springframework.data.redis.connection.DefaultSortParameters
 
alphabetical(boolean) - Method in class org.springframework.data.redis.core.query.SortQueryBuilder
 
alphabetical(boolean) - Method in interface org.springframework.data.redis.core.query.SortCriterion
 
and() - Method in class org.springframework.data.redis.connection.jedis.JedisClientConfiguration.DefaultJedisClientConfigurationBuilder
 
and() - Method in interface org.springframework.data.redis.connection.jedis.JedisClientConfiguration.JedisPoolingClientConfigurationBuilder
and() - Method in interface org.springframework.data.redis.connection.jedis.JedisClientConfiguration.JedisSslClientConfigurationBuilder
and() - Method in class org.springframework.data.redis.connection.lettuce.LettuceClientConfiguration.LettuceSslClientConfigurationBuilder
and() - Method in class org.springframework.data.redis.connection.lettuce.LettucePoolingClientConfiguration.LettucePoolingSslClientConfigurationBuilder
 
and(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoDistCommand
Applies the to member.
and(Part, RedisOperationChain, Iterator<Object>) - Method in class org.springframework.data.redis.repository.query.RedisQueryCreator
 
AND - Enum constant in enum class org.springframework.data.redis.connection.RedisStringCommands.BitOperation
 
andSaveAs(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveStringCommands.BitOpCommand
Applies the key to store the result at.
ANONYMOUS - Enum constant in enum class org.springframework.data.redis.connection.lettuce.RedisCredentialsProviderFactory.AbsentRedisCredentials
 
any() - Static method in interface org.springframework.data.redis.connection.RedisGeoCommands.GeoCommandArgs.GeoCommandFlag
 
ANY - Enum constant in enum class org.springframework.data.redis.connection.RedisGeoCommands.GeoRadiusCommandArgs.Flag
 
append(byte[], byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
Deprecated.
append(byte[], byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
append(byte[], byte[]) - Method in interface org.springframework.data.redis.connection.RedisStringCommands
Append a value to key.
append(String) - Method in interface org.springframework.data.redis.core.BoundValueOperations
Append a value to the bound key.
append(String, String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
append(String, String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
Append a value to key.
append(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveStringCommands.AppendCommand
Applies the value to append.
append(ByteBuffer, ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
Append a value to key.
append(K, String) - Method in interface org.springframework.data.redis.core.ReactiveValueOperations
Append a value to key.
append(K, String) - Method in interface org.springframework.data.redis.core.ValueOperations
Append a value to key.
append(Publisher<ReactiveStringCommands.AppendCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
APPEND - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
 
apply(RedisURI) - Method in class org.springframework.data.redis.connection.lettuce.LettuceClientConfiguration.LettuceClientConfigurationBuilder
Apply SSL settings, command timeout, and client name from a RedisURI.
apply(Function<Double, Double>) - Method in class org.springframework.data.redis.connection.zset.Weights
Creates a new Weights object that contains all weights with Function applied.
applyWeights(List<Double>) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZAggregateCommand
Applies the List of weights.
applyWeights(List<Double>) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZAggregateStoreCommand
Applies the List of weights.
applyWeights(List<Double>) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZInterStoreCommand
Applies the Collection of weights.
applyWeights(List<Double>) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZUnionStoreCommand
Applies the List of weights.
applyWeights(Weights) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZAggregateCommand
Applies the Weights.
applyWeights(Weights) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZAggregateStoreCommand
Applies the Weights.
applyWeights(Weights) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZInterStoreCommand
Applies the Weights.
applyWeights(Weights) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZUnionStoreCommand
Applies the Weights.
approximate() - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.TrimCommand
Applies approximate trimming.
approximate(boolean) - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.TrimCommand
Applies approximateTrimming.
approximateTrimming(boolean) - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.AddStreamRecord
Apply efficient trimming for capped streams using the ~ flag.
approximateTrimming(boolean) - Method in class org.springframework.data.redis.connection.RedisStreamCommands.XAddOptions
Apply efficient trimming for capped streams using the ~ flag.
as(Consumer) - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.ReadCommand
Applies a Consumer.
asc() - Method in class org.springframework.data.redis.connection.DefaultSortParameters
 
ASC - Enum constant in enum class org.springframework.data.redis.connection.SortParameters.Order
 
asMap() - Method in class org.springframework.data.redis.core.convert.Bucket
Key/value pairs contained in the Bucket.
asRawSet() - Method in class org.springframework.data.redis.connection.util.ByteArraySet
 
asString() - Method in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldType
Get the Redis Command representation.
asString() - Method in class org.springframework.data.redis.connection.BitFieldSubCommands.Offset
 
asString() - Method in class org.springframework.data.redis.connection.RedisNode
 
ASYNC - Enum constant in enum class org.springframework.data.redis.connection.RedisServerCommands.FlushOption
 
at(ReadOffset) - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.GroupCommand
 
at(GeoReference<ByteBuffer>) - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoSearchCommand
Sets the geoset key.
at(GeoReference<ByteBuffer>) - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoSearchStoreCommand
Sets the geoset key.
atOffset(long) - Method in class org.springframework.data.redis.connection.ReactiveStringCommands.GetBitCommand
Applies the offset index.
atOffset(long) - Method in class org.springframework.data.redis.connection.ReactiveStringCommands.SetBitCommand
Applies the offset index.
atPosition(long) - Method in class org.springframework.data.redis.connection.ReactiveStringCommands.SetRangeCommand
Applies the index.
AUTH - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
 
autoAcknowledge() - Method in class org.springframework.data.redis.connection.stream.StreamReadOptions
Enable auto-acknowledgement by setting the NOACK flag when reading in the context of a consumer group.
autoAcknowledge(boolean) - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.ConsumerStreamReadRequestBuilder
Configure auto-acknowledgement for stream message consumption.
autoGenerate() - Static method in class org.springframework.data.redis.connection.stream.RecordId
Obtain the RecordId signalling the server to auto generate an entry-id on insert (XADD).
await(Duration) - Method in interface org.springframework.data.redis.stream.Subscription
Synchronous, blocking call returns once the Subscription becomes active or timeout exceeds.
awaitStart(Duration) - Method in interface org.springframework.data.redis.stream.Task
Synchronous, blocking call that awaits until this Task becomes active.

B

basePackageClasses() - Element in annotation interface org.springframework.data.redis.repository.configuration.EnableRedisRepositories
Type-safe alternative to EnableRedisRepositories.basePackages() for specifying the packages to scan for annotated components.
basePackages() - Element in annotation interface org.springframework.data.redis.repository.configuration.EnableRedisRepositories
Base packages to scan for annotated components.
BasicRedisPersistentEntity<T> - Class in org.springframework.data.redis.core.mapping
RedisPersistentEntity implementation.
BasicRedisPersistentEntity(TypeInformation<T>, KeySpaceResolver, TimeToLiveAccessor) - Constructor for class org.springframework.data.redis.core.mapping.BasicRedisPersistentEntity
batchSize(int) - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamMessageListenerContainerOptionsBuilder
Configure a batch size for the COUNT option during reading.
batchSize(int) - Method in class org.springframework.data.redis.stream.StreamReceiver.StreamReceiverOptionsBuilder
Configure a batch size for the COUNT option during reading.
BatchStrategies - Class in org.springframework.data.redis.cache
Collection of predefined BatchStrategy implementations using the Redis KEYS or SCAN command.
BatchStrategy - Interface in org.springframework.data.redis.cache
A BatchStrategy to be used with RedisCacheWriter.
beanManager - Variable in class org.springframework.data.redis.repository.cdi.CdiBean
 
BeanUtilsHashMapper<T> - Class in org.springframework.data.redis.hash
HashMapper based on Apache Commons BeanUtils project.
BeanUtilsHashMapper(Class<T>) - Constructor for class org.springframework.data.redis.hash.BeanUtilsHashMapper
Create a new BeanUtilsHashMapper for the given type.
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.
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.
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.
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.
bgSave(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.ReactiveClusterServerCommands
Start background saving of db on server.
bgSave(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.RedisClusterServerCommands
 
bgSave(RedisClusterNode) - Method in interface org.springframework.data.redis.core.ClusterOperations
Start background saving of db on given node.
BGSAVE - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
 
bindConnection(RedisConnectionFactory) - Static method in class org.springframework.data.redis.core.RedisConnectionUtils
Obtain a RedisConnection from the given RedisConnectionFactory and binds the connection to the current thread to be used in closure-scope, if none is already bound.
bindConnection(RedisConnectionFactory, boolean) - Static method in class org.springframework.data.redis.core.RedisConnectionUtils
Obtain a RedisConnection from the given RedisConnectionFactory and binds the connection to the current thread to be used in closure-scope, if none is already bound.
bit(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveStringCommands.GetBitCommand
Creates a new ReactiveStringCommands.GetBitCommand given a key.
bit(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveStringCommands.SetBitCommand
Creates a new ReactiveStringCommands.SetBitCommand given a key.
bitCount(byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
Deprecated.
bitCount(byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
bitCount(byte[]) - Method in interface org.springframework.data.redis.connection.RedisStringCommands
Count the number of set bits (population counting) in value stored at key.
bitCount(byte[], long, long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
Deprecated.
bitCount(byte[], long, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
bitCount(byte[], long, long) - Method in interface org.springframework.data.redis.connection.RedisStringCommands
Count the number of set bits (population counting) of value stored at key between start and end.
bitCount(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
bitCount(String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
Count the number of set bits (population counting) in value stored at key.
bitCount(String, long, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
bitCount(String, long, long) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
Count the number of set bits (population counting) of value stored at key between start and end.
bitCount(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
Count the number of set bits (population counting) in value stored at key.
bitCount(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveStringCommands.BitCountCommand
Creates a new ReactiveStringCommands.BitCountCommand given a key.
bitCount(ByteBuffer, long, long) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
Count the number of set bits (population counting) of value stored at key between start and end.
bitCount(Publisher<ReactiveStringCommands.BitCountCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
Count the number of set bits (population counting) of value stored at key between start and end.
BITCOUNT - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
 
bitfield(String, BitFieldSubCommands) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
bitfield(String, BitFieldSubCommands) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
Get / Manipulate specific integer fields of varying bit widths and arbitrary non (necessary) aligned offset stored at a given key.
bitField(byte[], BitFieldSubCommands) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
Deprecated.
bitField(byte[], BitFieldSubCommands) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
bitField(byte[], BitFieldSubCommands) - Method in interface org.springframework.data.redis.connection.RedisStringCommands
Get / Manipulate specific integer fields of varying bit widths and arbitrary non (necessary) aligned offset stored at a given key.
bitField(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveStringCommands.BitFieldCommand
Creates a new ReactiveStringCommands.BitFieldCommand given a key.
bitField(ByteBuffer, BitFieldSubCommands) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
Get / Manipulate specific integer fields of varying bit widths and arbitrary non (necessary) aligned offset stored at a given key.
bitField(K, BitFieldSubCommands) - Method in interface org.springframework.data.redis.core.ReactiveValueOperations
Get / Manipulate specific integer fields of varying bit widths and arbitrary non (necessary) aligned offset stored at a given key.
bitField(K, BitFieldSubCommands) - Method in interface org.springframework.data.redis.core.ValueOperations
Get / Manipulate specific integer fields of varying bit widths and arbitrary non (necessary) aligned offset stored at a given key.
bitField(Publisher<ReactiveStringCommands.BitFieldCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
Get / Manipulate specific integer fields of varying bit widths and arbitrary non (necessary) aligned offset stored at a given key.
BitFieldGet() - Constructor for class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldGet
 
BitFieldIncrBy() - Constructor for class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldIncrBy
 
BitFieldSet() - Constructor for class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldSet
 
BitFieldSubCommands - Class in org.springframework.data.redis.connection
The actual BITFIELD command representation holding several BitFieldSubCommands.BitFieldSubCommands to execute.
BitFieldSubCommands.AbstractBitFieldSubCommand - Class in org.springframework.data.redis.connection
 
BitFieldSubCommands.BitFieldGet - Class in org.springframework.data.redis.connection
The GET sub command used with BitFieldSubCommands.
BitFieldSubCommands.BitFieldGetBuilder - Class in org.springframework.data.redis.connection
 
BitFieldSubCommands.BitFieldIncrBy - Class in org.springframework.data.redis.connection
The INCRBY sub command used with BitFieldSubCommands.
BitFieldSubCommands.BitFieldIncrBy.Overflow - Enum Class in org.springframework.data.redis.connection
 
BitFieldSubCommands.BitFieldIncrByBuilder - Class in org.springframework.data.redis.connection
 
BitFieldSubCommands.BitFieldSet - Class in org.springframework.data.redis.connection
The SET sub command used with BitFieldSubCommands.
BitFieldSubCommands.BitFieldSetBuilder - Class in org.springframework.data.redis.connection
 
BitFieldSubCommands.BitFieldSubCommand - Interface in org.springframework.data.redis.connection
Sub command to be used as part of BitFieldSubCommands.
BitFieldSubCommands.BitFieldType - Class in org.springframework.data.redis.connection
The actual Redis bitfield type representation for signed and unsigned integers used with BitFieldSubCommands.BitFieldSubCommand.
BitFieldSubCommands.Offset - Class in org.springframework.data.redis.connection
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.
bitOp(RedisStringCommands.BitOperation, byte[], byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
bitOp(RedisStringCommands.BitOperation, byte[], byte[]...) - Method in interface org.springframework.data.redis.connection.RedisStringCommands
Perform bitwise operations between strings.
bitOp(RedisStringCommands.BitOperation, String, String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
bitOp(RedisStringCommands.BitOperation, String, String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
Perform bitwise operations between strings.
BITOP - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
 
bitPos(byte[], boolean) - Method in interface org.springframework.data.redis.connection.RedisStringCommands
Return the position of the first bit set to given bit in a string.
bitPos(byte[], boolean, Range<Long>) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
Deprecated.
bitPos(byte[], boolean, Range<Long>) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
bitPos(byte[], boolean, Range<Long>) - Method in interface org.springframework.data.redis.connection.RedisStringCommands
Return the position of the first bit set to given bit in a string.
bitPos(String, boolean) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
Return the position of the first bit set to given bit in a string.
bitPos(String, boolean, Range<Long>) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
bitPos(String, boolean, Range<Long>) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
Return the position of the first bit set to given bit in a string.
bitPos(ByteBuffer, boolean) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
Return the position of the first bit set to given bit in a string.
bitPos(ByteBuffer, boolean, Range<Long>) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
Return the position of the first bit set to given bit in a string.
bitPos(Publisher<ReactiveStringCommands.BitPosCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
Emmit the the position of the first bit set to given bit in a string.
BITPOS - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
 
bLMove(byte[], byte[], RedisListCommands.Direction, RedisListCommands.Direction, double) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
Deprecated.
bLMove(byte[], byte[], RedisListCommands.Direction, RedisListCommands.Direction, double) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
bLMove(byte[], byte[], RedisListCommands.Direction, RedisListCommands.Direction, double) - Method in interface org.springframework.data.redis.connection.RedisListCommands
Atomically returns and removes the first/last element (head/tail depending on the from argument) of the list stored at sourceKey, and pushes the element at the first/last element (head/tail depending on the to argument) of the list stored at destinationKey.
bLMove(String, String, RedisListCommands.Direction, RedisListCommands.Direction, double) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
bLMove(String, String, RedisListCommands.Direction, RedisListCommands.Direction, double) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
Atomically returns and removes the first/last element (head/tail depending on the from argument) of the list stored at sourceKey, and pushes the element at the first/last element (head/tail depending on the to argument) of the list stored at destinationKey.
bLMove(ByteBuffer, ByteBuffer, ReactiveListCommands.Direction, ReactiveListCommands.Direction, Duration) - Method in interface org.springframework.data.redis.connection.ReactiveListCommands
Atomically returns and removes the first/last element (head/tail depending on the from argument) of the list stored at sourceKey, and pushes the element at the first/last element (head/tail depending on the to argument) of the list stored at destinationKey.
bLMove(Publisher<ReactiveListCommands.BLMoveCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveListCommands
Atomically returns and removes the first/last element (head/tail depending on the from argument) of the list stored at sourceKey, and pushes the element at the first/last element (head/tail depending on the to argument) of the list stored at destinationKey.
block(Duration) - Method in class org.springframework.data.redis.connection.stream.StreamReadOptions
Use a blocking read and supply the timeout after which the call will terminate if no message was read.
blockingFor(long, TimeUnit) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.BZPopCommand
Applies a timeout.
blockingFor(Duration) - Method in class org.springframework.data.redis.connection.ReactiveListCommands.BPopCommand
Applies a timeout.
blockingFor(Duration) - Method in class org.springframework.data.redis.connection.ReactiveListCommands.BRPopLPushCommand
Applies a timeout.
blockingFor(Duration) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.BZPopCommand
Applies a timeout.
blPop(List<ByteBuffer>, Duration) - Method in interface org.springframework.data.redis.connection.ReactiveListCommands
Removes and returns first element from lists stored at keys.
bLPop(int, byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
Deprecated.
bLPop(int, byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
bLPop(int, byte[]...) - Method in interface org.springframework.data.redis.connection.RedisListCommands
Removes and returns first element from lists stored at keys.
bLPop(int, String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
bLPop(int, String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
Removes and returns first element from lists stored at keys (see: DefaultedRedisConnection.lPop(byte[])).
BLPOP - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
 
body(Map<ByteBuffer, ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveStreamCommands.AddStreamRecord
BOOLEAN - Enum constant in enum class org.springframework.data.redis.connection.ReturnType
Returned as Boolean
BooleanResponse(I, Boolean) - Constructor for class org.springframework.data.redis.connection.ReactiveRedisConnection.BooleanResponse
 
BoundGeoOperations<K,M> - Interface in org.springframework.data.redis.core
GeoOperations bound to a certain key.
boundGeoOps(K) - Method in interface org.springframework.data.redis.core.RedisOperations
Returns geospatial specific operations interface bound to the given key.
boundGeoOps(K) - Method in class org.springframework.data.redis.core.RedisTemplate
 
BoundHashOperations<H,HK,HV> - Interface in org.springframework.data.redis.core
Hash operations bound to a certain key.
boundHashOps(K) - Method in interface org.springframework.data.redis.core.RedisOperations
Returns the operations performed on hash values bound to the given key.
boundHashOps(K) - Method in class org.springframework.data.redis.core.RedisTemplate
 
BoundingBox - Class in org.springframework.data.redis.domain.geo
Represents a geospatial bounding box defined by width and height.
BoundingBox(double, double, Metric) - Constructor for class org.springframework.data.redis.domain.geo.BoundingBox
Creates a new BoundingBox from the given width, height and Metric.
BoundingBox(Distance, Distance) - Constructor for class org.springframework.data.redis.domain.geo.BoundingBox
Creates a new BoundingBox from the given width and height.
BoundKeyOperations<K> - Interface in org.springframework.data.redis.core
Operations over a Redis key.
BoundListOperations<K,V> - Interface in org.springframework.data.redis.core
List operations bound to a certain key.
boundListOps(K) - Method in interface org.springframework.data.redis.core.RedisOperations
Returns the operations performed on list values bound to the given key.
boundListOps(K) - Method in class org.springframework.data.redis.core.RedisTemplate
 
BoundSetOperations<K,V> - Interface in org.springframework.data.redis.core
Set operations bound to a certain key.
boundSetOps(K) - Method in interface org.springframework.data.redis.core.RedisOperations
Returns the operations performed on set values bound to the given key.
boundSetOps(K) - Method in class org.springframework.data.redis.core.RedisTemplate
 
BoundStreamOperations<K,HK,HV> - Interface in org.springframework.data.redis.core
Redis stream specific operations bound to a certain key.
boundStreamOps(K) - Method in interface org.springframework.data.redis.core.RedisOperations
Returns the operations performed on Streams bound to the given key.
boundStreamOps(K) - Method in class org.springframework.data.redis.core.RedisTemplate
 
BoundValueOperations<K,V> - Interface in org.springframework.data.redis.core
Value (or String in Redis terminology) operations bound to a certain key.
boundValueOps(K) - Method in interface org.springframework.data.redis.core.RedisOperations
Returns the operations performed on simple values (or Strings in Redis terminology) bound to the given key.
boundValueOps(K) - Method in class org.springframework.data.redis.core.RedisTemplate
 
BoundZSetOperations<K,V> - Interface in org.springframework.data.redis.core
ZSet (or SortedSet) operations bound to a certain key.
boundZSetOps(K) - Method in interface org.springframework.data.redis.core.RedisOperations
Returns the operations performed on zset values (also known as sorted sets) bound to the given key.
boundZSetOps(K) - Method in class org.springframework.data.redis.core.RedisTemplate
 
BoxShape - Class in org.springframework.data.redis.domain.geo
Bounding box defined by width and height.
BoxShape(BoundingBox) - Constructor for class org.springframework.data.redis.domain.geo.BoxShape
 
bPop(Publisher<ReactiveListCommands.BPopCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveListCommands
Removes and returns the top ReactiveListCommands.BPopCommand.getDirection() element from lists stored at ReactiveListCommands.BPopCommand.getKeys().
Blocks connection until element available or ReactiveListCommands.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.
bRPop(int, byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
bRPop(int, byte[]...) - Method in interface org.springframework.data.redis.connection.RedisListCommands
Removes and returns last element from lists stored at keys.
bRPop(int, String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
bRPop(int, String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
Removes and returns last element from lists stored at keys (see: DefaultedRedisConnection.rPop(byte[])).
BRPOP - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
 
bRPopLPush(int, byte[], byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
Deprecated.
bRPopLPush(int, byte[], byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
bRPopLPush(int, byte[], byte[]) - Method in interface org.springframework.data.redis.connection.RedisListCommands
Remove the last element from list at srcKey, append it to dstKey and return its value.
bRPopLPush(int, String, String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
bRPopLPush(int, String, String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
Remove the last element from list at srcKey, append it to dstKey and return its value (see DefaultedRedisConnection.rPopLPush(byte[], byte[])).
bRPopLPush(ByteBuffer, ByteBuffer, Duration) - Method in interface org.springframework.data.redis.connection.ReactiveListCommands
Remove the last element from list at source, append it to destination and return its value.
bRPopLPush(Publisher<ReactiveListCommands.BRPopLPushCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveListCommands
Remove the last element from list at ReactiveRedisConnection.KeyCommand.getKey(), append it to ReactiveListCommands.BRPopLPushCommand.getDestination() and return its value.
BRPOPLPUSH - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
 
Bucket - Class in org.springframework.data.redis.core.convert
Bucket is the data bag for Redis hash structures to be used with RedisData.
Bucket() - Constructor for class org.springframework.data.redis.core.convert.Bucket
Creates a new empty bucket.
Bucket.BucketPropertyPath - Class in org.springframework.data.redis.core.convert
Value object representing a path within a Bucket.
BUFFER_FREE_SPACE - Enum constant in enum class org.springframework.data.redis.connection.RedisServer.INFO
 
BUFFER_FREE_SPACE - Enum constant in enum class org.springframework.data.redis.core.types.RedisClientInfo.INFO
 
BUFFER_LENGTH - Enum constant in enum class org.springframework.data.redis.connection.RedisServer.INFO
 
BUFFER_LENGTH - Enum constant in enum class org.springframework.data.redis.core.types.RedisClientInfo.INFO
 
buffered(int) - Static method in interface org.springframework.data.redis.connection.lettuce.LettuceConnection.PipeliningFlushPolicy
Return a policy to buffer commands and to flush once reaching the configured bufferSize.
build() - Method in class org.springframework.data.redis.cache.RedisCacheManager.RedisCacheManagerBuilder
Create new instance of RedisCacheManager with configuration options applied.
build() - Method in class org.springframework.data.redis.connection.jedis.JedisClientConfiguration.DefaultJedisClientConfigurationBuilder
 
build() - Method in interface org.springframework.data.redis.connection.jedis.JedisClientConfiguration.JedisClientConfigurationBuilder
Build the JedisClientConfiguration with the configuration applied from this builder.
build() - Method in interface org.springframework.data.redis.connection.jedis.JedisClientConfiguration.JedisPoolingClientConfigurationBuilder
Build the JedisClientConfiguration with the configuration applied from this builder.
build() - Method in interface org.springframework.data.redis.connection.jedis.JedisClientConfiguration.JedisSslClientConfigurationBuilder
Build the JedisClientConfiguration with the configuration applied from this builder.
build() - Method in class org.springframework.data.redis.connection.lettuce.LettuceClientConfiguration.LettuceClientConfigurationBuilder
Build the LettuceClientConfiguration with the configuration applied from this builder.
build() - Method in class org.springframework.data.redis.connection.lettuce.LettuceClientConfiguration.LettuceSslClientConfigurationBuilder
Build the LettuceClientConfiguration with the configuration applied from this builder.
build() - Method in class org.springframework.data.redis.connection.lettuce.LettucePoolingClientConfiguration.LettucePoolingClientConfigurationBuilder
 
build() - Method in class org.springframework.data.redis.connection.lettuce.LettucePoolingClientConfiguration.LettucePoolingSslClientConfigurationBuilder
 
build() - Method in class org.springframework.data.redis.connection.RedisClusterNode.RedisClusterNodeBuilder
 
build() - Method in class org.springframework.data.redis.connection.RedisNode.RedisNodeBuilder
Get the RedisNode.
build() - Method in class org.springframework.data.redis.core.query.SortQueryBuilder
 
build() - Method in interface org.springframework.data.redis.core.query.SortCriterion
 
build() - Method in class org.springframework.data.redis.core.ScanOptions.ScanOptionsBuilder
Builds a new ScanOptions objects.
build() - Method in class org.springframework.data.redis.serializer.GenericJackson2JsonRedisSerializer.GenericJackson2JsonRedisSerializerBuilder
Creates a new instance of GenericJackson2JsonRedisSerializer with configuration options applied.
build() - Method in interface org.springframework.data.redis.serializer.RedisSerializationContext.RedisSerializationContextBuilder
build() - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.ConsumerStreamReadRequestBuilder
build() - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamMessageListenerContainerOptionsBuilder
build() - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamReadRequestBuilder
build() - Method in class org.springframework.data.redis.stream.StreamReceiver.StreamReceiverOptionsBuilder
builder() - Static method in class org.springframework.data.redis.cache.RedisCacheManager
Factory method returning a Builder used to construct and configure a RedisCacheManager.
builder() - Static method in interface org.springframework.data.redis.connection.jedis.JedisClientConfiguration
Creates a new JedisClientConfiguration.JedisClientConfigurationBuilder to build JedisClientConfiguration to be used with the jedis client.
builder() - Static method in interface org.springframework.data.redis.connection.lettuce.LettuceClientConfiguration
Creates a new LettuceClientConfiguration.LettuceClientConfigurationBuilder to build LettuceClientConfiguration to be used with the Lettuce client.
builder() - Static method in interface org.springframework.data.redis.connection.lettuce.LettucePoolingClientConfiguration
builder() - Static method in class org.springframework.data.redis.serializer.GenericJackson2JsonRedisSerializer
Factory method returning a Builder used to construct and configure a GenericJackson2JsonRedisSerializer.
builder() - Static method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamMessageListenerContainerOptions
 
builder() - Static method in class org.springframework.data.redis.stream.StreamReceiver.StreamReceiverOptions
 
builder(RedisCacheWriter) - Static method in class org.springframework.data.redis.cache.RedisCacheManager
Factory method returning a Builder used to construct and configure a RedisCacheManager initialized with the given RedisCacheWriter.
builder(RedisConnectionFactory) - Static method in class org.springframework.data.redis.cache.RedisCacheManager
Factory method returning a Builder used to construct and configure a RedisCacheManager initialized with the given RedisConnectionFactory.
builder(StreamOffset<K>) - Static method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamReadRequest
 
builder(HashMapper<T, byte[], byte[]>) - Static method in class org.springframework.data.redis.stream.StreamReceiver.StreamReceiverOptions
 
BulkMapper<T,V> - Interface in org.springframework.data.redis.core
Mapper translating Redis bulk value responses (typically returned by a sort query) to actual objects.
by(byte[]) - Method in class org.springframework.data.redis.connection.DefaultSortParameters
 
by(long) - Method in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldIncrByBuilder
Set the value used for increasing.
by(Number) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZIncrByCommand
Applies the numeric increment.
by(String) - Method in class org.springframework.data.redis.core.query.SortQueryBuilder
 
by(T) - Method in class org.springframework.data.redis.connection.ReactiveNumberCommands.DecrByCommand
Applies the numeric value.
by(T) - Method in class org.springframework.data.redis.connection.ReactiveNumberCommands.HIncrByCommand
Applies the numeric value.
by(T) - Method in class org.springframework.data.redis.connection.ReactiveNumberCommands.IncrByCommand
Applies the numeric value.
byBox(double, double, RedisGeoCommands.DistanceUnit) - Static method in interface org.springframework.data.redis.domain.geo.GeoShape
Create a shape used as predicate for geo queries from a bounding box with specified by width and height.
byBox(BoundingBox) - Static method in interface org.springframework.data.redis.domain.geo.GeoShape
Create a shape used as predicate for geo queries from a BoundingBox.
ByLex - Enum constant in enum class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRangeStoreCommand.RangeMode
 
byRadius(Distance) - Static method in interface org.springframework.data.redis.domain.geo.GeoShape
Create a shape used as predicate for geo queries from a radius around the query center point.
ByScore - Enum constant in enum class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRangeStoreCommand.RangeMode
 
byteArray() - Static method in interface org.springframework.data.redis.serializer.RedisSerializationContext
Creates a new RedisSerializationContext using a byte[] serialization.
byteArray() - Static method in interface org.springframework.data.redis.serializer.RedisSerializationContext.SerializationPair
Creates a pass through RedisSerializationContext.SerializationPair to pass-thru byte objects.
byteArray() - Static method in interface org.springframework.data.redis.serializer.RedisSerializer
Obtain a RedisSerializer that passes thru byte[].
ByteArraySet - Class in org.springframework.data.redis.connection.util
 
ByteArraySet() - Constructor for class org.springframework.data.redis.connection.util.ByteArraySet
 
ByteArraySet(Collection<byte[]>) - Constructor for class org.springframework.data.redis.connection.util.ByteArraySet
 
ByteArrayWrapper - Class in org.springframework.data.redis.connection.util
Simple wrapper class used for wrapping arrays so they can be used as keys inside maps.
ByteArrayWrapper(byte[]) - Constructor for class org.springframework.data.redis.connection.util.ByteArrayWrapper
 
ByteArrayWrapper(ByteBuffer) - Constructor for class org.springframework.data.redis.connection.util.ByteArrayWrapper
 
byteBuffer() - Static method in interface org.springframework.data.redis.serializer.RedisSerializationContext
Creates a new RedisSerializationContext using a ByteBuffer serialization.
byteBuffer() - Static method in interface org.springframework.data.redis.serializer.RedisSerializationContext.SerializationPair
Creates a pass through RedisSerializationContext.SerializationPair to pass-thru ByteBuffer objects.
ByteBufferRecord - Interface in org.springframework.data.redis.connection.stream
A Record within the stream backed by a collection of binary field/value pairs.
ByteBufferResponse(I, ByteBuffer) - Constructor for class org.springframework.data.redis.connection.ReactiveRedisConnection.ByteBufferResponse
 
ByteRecord - Interface in org.springframework.data.redis.connection.stream
A Record within the stream backed by a collection of binary field/value pairs.
bytesSetToGeoResultsConverter() - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
Get Converter capable of Set of Byte into GeoResults.
ByteUtils - Class in org.springframework.data.redis.util
Some handy methods for dealing with byte arrays.
bZPop(Publisher<ReactiveZSetCommands.BZPopCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
Remove and return elements from sorted set at keyCommand#getKey().
bZPopMax(byte[], long, TimeUnit) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
Deprecated.
bZPopMax(byte[], long, TimeUnit) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
bZPopMax(byte[], long, TimeUnit) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
Remove and return the value with its score having the highest score from sorted set at key.
bZPopMax(String, long, TimeUnit) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
bZPopMax(String, long, TimeUnit) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
Remove and return the value with its score having the highest score from sorted set at key.
bZPopMax(ByteBuffer, Duration) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
Remove and return the value with its score having the highest score from sorted set at key.
bZPopMin(byte[], long, TimeUnit) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
Deprecated.
bZPopMin(byte[], long, TimeUnit) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
bZPopMin(byte[], long, TimeUnit) - Method in interface org.springframework.data.redis.connection.RedisZSetCommands
Remove and return the value with its score having the lowest score from sorted set at key.
bZPopMin(String, long, TimeUnit) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
bZPopMin(String, long, TimeUnit) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
Remove and return the value with its score having the lowest score from sorted set at key.
bZPopMin(ByteBuffer, Duration) - Method in interface org.springframework.data.redis.connection.ReactiveZSetCommands
Remove and return the value with its score having the lowest score from sorted set at key.

C

cacheDefaults() - Method in class org.springframework.data.redis.cache.RedisCacheManager.RedisCacheManagerBuilder
Returns the default RedisCacheConfiguration.
cacheDefaults(RedisCacheConfiguration) - Method in class org.springframework.data.redis.cache.RedisCacheManager.RedisCacheManagerBuilder
Define a default RedisCacheConfiguration applied to dynamically created RedisCaches.
CacheKeyPrefix - Interface in org.springframework.data.redis.cache
CacheKeyPrefix is a callback hook for creating custom prefixes prepended to the actual key stored in Redis.
CacheStatistics - Interface in org.springframework.data.redis.cache
Cache statistics for a RedisCache.
CacheStatisticsCollector - Interface in org.springframework.data.redis.cache
The statistics collector supports capturing of relevant RedisCache operations such as hits & misses.
CacheStatisticsProvider - Interface in org.springframework.data.redis.cache
Interface to be implemented by objects that expose CacheStatistics identified by cacheName.
cacheWriter(RedisCacheWriter) - Method in class org.springframework.data.redis.cache.RedisCacheManager.RedisCacheManagerBuilder
Configure a RedisCacheWriter.
calculateSlot(byte[]) - Static method in class org.springframework.data.redis.connection.ClusterSlotHashUtil
Calculate the slot from the given key.
calculateSlot(String) - Static method in class org.springframework.data.redis.connection.ClusterSlotHashUtil
Calculate the slot from the given key.
cancel() - Method in interface org.springframework.data.redis.connection.ReactiveSubscription
Unsubscribe from all channels and patterns and request termination of all active message streams.
cancel() - Method in interface org.springframework.data.redis.stream.Cancelable
Abort and free resources.
Cancelable - Interface in org.springframework.data.redis.stream
Cancelable allows stopping long running tasks and freeing underlying resources.
CANCELLED - Enum constant in enum class org.springframework.data.redis.stream.Task.State
 
cancelOnError(Predicate<Throwable>) - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.ConsumerStreamReadRequestBuilder
Configure a cancellation Predicate to be notified on read, deserialization, and listener errors.
cancelOnError(Predicate<Throwable>) - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamReadRequestBuilder
Configure a cancellation Predicate to be notified on errors.
canEqual(Object) - Method in class org.springframework.data.redis.core.convert.GeoIndexedPropertyValue
 
canSerialize(Class<?>) - Method in interface org.springframework.data.redis.serializer.RedisSerializer
Check whether the given value type can be serialized by this serializer.
CdiBean<T> - Class in org.springframework.data.redis.repository.cdi
Base class for Bean wrappers.
CdiBean(Set<Annotation>, Class<T>, BeanManager) - Constructor for class org.springframework.data.redis.repository.cdi.CdiBean
Creates a new CdiBean.
CdiBean(Set<Annotation>, Set<Type>, Class<T>, BeanManager) - Constructor for class org.springframework.data.redis.repository.cdi.CdiBean
Creates a new CdiBean.
ch() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZAddCommand
Applies ch mode (Modify the return value from the number of new elements added, to the total number of elements changed).
ch() - Method in class org.springframework.data.redis.connection.RedisZSetCommands.ZAddArgs
Only update elements that already exist.
CH - Enum constant in enum class org.springframework.data.redis.connection.RedisZSetCommands.ZAddArgs.Flag
Modify the return value from the number of new elements added, to the total number of elements changed.
CHANNEL_SUBSCRIBTIONS - Enum constant in enum class org.springframework.data.redis.core.types.RedisClientInfo.INFO
 
ChannelMessage(C, M) - Constructor for class org.springframework.data.redis.connection.ReactiveSubscription.ChannelMessage
ChannelTopic - Class in org.springframework.data.redis.listener
Channel Topic implementation mapping to a Redis channel.
ChannelTopic(String) - Constructor for class org.springframework.data.redis.listener.ChannelTopic
Constructs a new ChannelTopic instance.
CHARSET - Static variable in class org.springframework.data.redis.core.convert.Bucket
Encoding used for converting Byte to and from String.
checkResult(Object) - Method in class org.springframework.data.redis.support.collections.AbstractRedisCollection
 
claim(K, String, String, Duration, RecordId...) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
Changes the ownership of a pending message so that the new owner is the consumer specified as the command argument.
claim(K, String, String, Duration, RecordId...) - Method in interface org.springframework.data.redis.core.StreamOperations
Changes the ownership of a pending message so that the new owner is the consumer specified as the command argument.
claim(K, String, String, RedisStreamCommands.XClaimOptions) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
Changes the ownership of a pending message so that the new owner is the consumer specified as the command argument.
claim(K, String, String, RedisStreamCommands.XClaimOptions) - Method in interface org.springframework.data.redis.core.StreamOperations
Changes the ownership of a pending message so that the new owner is the consumer specified as the command argument.
clean(String, byte[]) - Method in interface org.springframework.data.redis.cache.RedisCacheWriter
Remove all keys following the given pattern.
cleanCache(RedisConnection, String, byte[]) - Method in interface org.springframework.data.redis.cache.BatchStrategy
Remove all keys following the given pattern.
clear() - Method in class org.springframework.data.redis.cache.RedisCache
 
clear() - Method in class org.springframework.data.redis.connection.util.ByteArraySet
 
clear() - Method in class org.springframework.data.redis.core.RedisKeyValueAdapter
 
clear() - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
 
clear() - Method in class org.springframework.data.redis.support.collections.DefaultRedisMap
 
clear() - Method in class org.springframework.data.redis.support.collections.DefaultRedisSet
 
clear() - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
 
clear() - Method in class org.springframework.data.redis.support.collections.RedisProperties
 
clear(String) - Method in class org.springframework.data.redis.cache.RedisCache
Clear keys that match the given keyPattern.
clearStatistics() - Method in class org.springframework.data.redis.cache.RedisCache
Reset all statistics counters and gauges for this cache.
clearStatistics(String) - Method in interface org.springframework.data.redis.cache.RedisCacheWriter
Reset all statistics counters and gauges for this cache.
CLIENT_GETNAME - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
 
CLIENT_KILL - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
 
CLIENT_LIST - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
 
CLIENT_PAUSE - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
 
CLIENT_SETNAME - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
 
clientName(String) - Method in class org.springframework.data.redis.connection.jedis.JedisClientConfiguration.DefaultJedisClientConfigurationBuilder
 
clientName(String) - Method in interface org.springframework.data.redis.connection.jedis.JedisClientConfiguration.JedisClientConfigurationBuilder
Configure a clientName to be set with CLIENT SETNAME.
clientName(String) - Method in class org.springframework.data.redis.connection.lettuce.LettuceClientConfiguration.LettuceClientConfigurationBuilder
Configure a clientName to be set with CLIENT SETNAME.
clientName(String) - Method in class org.springframework.data.redis.connection.lettuce.LettucePoolingClientConfiguration.LettucePoolingClientConfigurationBuilder
 
clientOptions(ClientOptions) - Method in class org.springframework.data.redis.connection.lettuce.LettuceClientConfiguration.LettuceClientConfigurationBuilder
Configure ClientOptions.
clientOptions(ClientOptions) - Method in class org.springframework.data.redis.connection.lettuce.LettucePoolingClientConfiguration.LettucePoolingClientConfigurationBuilder
 
clientResources(ClientResources) - Method in class org.springframework.data.redis.connection.lettuce.LettuceClientConfiguration.LettuceClientConfigurationBuilder
Configure ClientResources.
clientResources(ClientResources) - Method in class org.springframework.data.redis.connection.lettuce.LettucePoolingClientConfiguration.LettucePoolingClientConfigurationBuilder
 
clone() - Method in class org.springframework.data.redis.connection.RedisGeoCommands.GeoRadiusCommandArgs
 
clone() - Method in class org.springframework.data.redis.connection.RedisGeoCommands.GeoSearchCommandArgs
 
clone() - Method in class org.springframework.data.redis.connection.RedisGeoCommands.GeoSearchStoreCommandArgs
 
clone() - Method in class org.springframework.data.redis.support.collections.RedisProperties
 
close() - Method in class org.springframework.data.redis.connection.AbstractRedisConnection
 
close() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
close() - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
 
close() - Method in class org.springframework.data.redis.connection.jedis.JedisConnection
 
close() - Method in class org.springframework.data.redis.connection.jedis.JedisSentinelConnection
 
close() - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
 
close() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
 
close() - Method in class org.springframework.data.redis.connection.lettuce.LettuceSentinelConnection
 
close() - Method in interface org.springframework.data.redis.connection.ReactiveRedisConnection
 
close() - Method in interface org.springframework.data.redis.connection.RedisConnection
Closes or quits the connection.
close() - Method in interface org.springframework.data.redis.connection.Subscription
Shutdown the subscription and free any resources held.
close() - Method in class org.springframework.data.redis.connection.util.AbstractSubscription
 
close() - Method in class org.springframework.data.redis.core.ConvertingCursor
 
close() - Method in class org.springframework.data.redis.core.ScanCursor
 
closeLater() - Method in interface org.springframework.data.redis.connection.ReactiveRedisConnection
Asynchronously close the connection and release associated resources.
closePipeline() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
closePipeline() - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
 
closePipeline() - Method in class org.springframework.data.redis.connection.jedis.JedisConnection
 
closePipeline() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
 
closePipeline() - Method in interface org.springframework.data.redis.connection.RedisConnection
Executes the commands in the pipeline and returns their result.
clusterAddSlots(RedisClusterNode, int...) - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
 
clusterAddSlots(RedisClusterNode, int...) - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
 
clusterAddSlots(RedisClusterNode, int...) - Method in interface org.springframework.data.redis.connection.ReactiveClusterCommands
Assign slots to given RedisClusterNode.
clusterAddSlots(RedisClusterNode, int...) - Method in interface org.springframework.data.redis.connection.RedisClusterCommands
Assign slots to given RedisClusterNode.
clusterAddSlots(RedisClusterNode, RedisClusterNode.SlotRange) - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
 
clusterAddSlots(RedisClusterNode, RedisClusterNode.SlotRange) - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
 
clusterAddSlots(RedisClusterNode, RedisClusterNode.SlotRange) - Method in interface org.springframework.data.redis.connection.ReactiveClusterCommands
clusterAddSlots(RedisClusterNode, RedisClusterNode.SlotRange) - Method in interface org.springframework.data.redis.connection.RedisClusterCommands
ClusterCommandExecutionFailureException - Exception in org.springframework.data.redis.connection
Exception thrown when at least one call to a clustered redis environment fails.
ClusterCommandExecutionFailureException(Throwable) - Constructor for exception org.springframework.data.redis.connection.ClusterCommandExecutionFailureException
ClusterCommandExecutionFailureException(List<? extends Throwable>) - Constructor for exception org.springframework.data.redis.connection.ClusterCommandExecutionFailureException
ClusterCommandExecutor - Class in org.springframework.data.redis.connection
ClusterCommandExecutor takes care of running commands across the known cluster nodes.
ClusterCommandExecutor(ClusterTopologyProvider, ClusterNodeResourceProvider, ExceptionTranslationStrategy) - Constructor for class org.springframework.data.redis.connection.ClusterCommandExecutor
ClusterCommandExecutor(ClusterTopologyProvider, ClusterNodeResourceProvider, ExceptionTranslationStrategy, AsyncTaskExecutor) - Constructor for class org.springframework.data.redis.connection.ClusterCommandExecutor
 
ClusterCommandExecutor.ClusterCommandCallback<T,S> - Interface in org.springframework.data.redis.connection
Callback interface for Redis 'low level' code using the cluster client directly.
ClusterCommandExecutor.MultiKeyClusterCommandCallback<T,S> - Interface in org.springframework.data.redis.connection
Callback interface for Redis 'low level' code using the cluster client to execute multi key commands.
ClusterCommandExecutor.MultiNodeResult<T> - Class in org.springframework.data.redis.connection
ClusterCommandExecutor.NodeResult<T> - Class in org.springframework.data.redis.connection
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
clusterCountKeysInSlot(int) - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
 
clusterCountKeysInSlot(int) - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
 
clusterCountKeysInSlot(int) - Method in interface org.springframework.data.redis.connection.ReactiveClusterCommands
Count the number of keys assigned to one slot.
clusterCountKeysInSlot(int) - Method in interface org.springframework.data.redis.connection.RedisClusterCommands
Count the number of keys assigned to one slot.
clusterDeleteSlots(RedisClusterNode, int...) - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
 
clusterDeleteSlots(RedisClusterNode, int...) - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
 
clusterDeleteSlots(RedisClusterNode, int...) - Method in interface org.springframework.data.redis.connection.ReactiveClusterCommands
Remove slots from RedisClusterNode.
clusterDeleteSlots(RedisClusterNode, int...) - Method in interface org.springframework.data.redis.connection.RedisClusterCommands
Remove slots from RedisClusterNode.
clusterDeleteSlotsInRange(RedisClusterNode, RedisClusterNode.SlotRange) - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
 
clusterDeleteSlotsInRange(RedisClusterNode, RedisClusterNode.SlotRange) - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
 
clusterDeleteSlotsInRange(RedisClusterNode, RedisClusterNode.SlotRange) - Method in interface org.springframework.data.redis.connection.ReactiveClusterCommands
clusterDeleteSlotsInRange(RedisClusterNode, RedisClusterNode.SlotRange) - Method in interface org.springframework.data.redis.connection.RedisClusterCommands
clusterForget(RedisClusterNode) - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
 
clusterForget(RedisClusterNode) - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
 
clusterForget(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.ReactiveClusterCommands
Remove given node from cluster.
clusterForget(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.RedisClusterCommands
Remove given node from cluster.
clusterGetClusterInfo() - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
 
clusterGetClusterInfo() - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
 
clusterGetClusterInfo() - Method in interface org.springframework.data.redis.connection.ReactiveClusterCommands
Get cluster information.
clusterGetClusterInfo() - Method in interface org.springframework.data.redis.connection.RedisClusterCommands
Get cluster information.
clusterGetKeysInSlot(int, int) - Method in interface org.springframework.data.redis.connection.ReactiveClusterCommands
Get keys served by slot.
clusterGetKeysInSlot(int, Integer) - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
 
clusterGetKeysInSlot(int, Integer) - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
 
clusterGetKeysInSlot(int, Integer) - Method in interface org.springframework.data.redis.connection.RedisClusterCommands
Get keys served by slot.
clusterGetMasterReplicaMap() - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
 
clusterGetMasterReplicaMap() - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
 
clusterGetMasterReplicaMap() - Method in interface org.springframework.data.redis.connection.ReactiveClusterCommands
Retrieve information about masters and their connected replicas.
clusterGetMasterReplicaMap() - Method in interface org.springframework.data.redis.connection.RedisClusterCommands
Retrieve information about masters and their connected replicas.
clusterGetNodeForKey(byte[]) - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
 
clusterGetNodeForKey(byte[]) - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
 
clusterGetNodeForKey(byte[]) - Method in interface org.springframework.data.redis.connection.RedisClusterCommands
Find the RedisClusterNode serving given key.
clusterGetNodeForKey(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveClusterCommands
Find the RedisClusterNode serving given key.
clusterGetNodeForSlot(int) - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
 
clusterGetNodeForSlot(int) - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
 
clusterGetNodeForSlot(int) - Method in interface org.springframework.data.redis.connection.ReactiveClusterCommands
Find the RedisClusterNode serving given slot.
clusterGetNodeForSlot(int) - Method in interface org.springframework.data.redis.connection.RedisClusterCommands
Find the RedisClusterNode serving given slot.
clusterGetNodes() - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
 
clusterGetNodes() - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
 
clusterGetNodes() - Method in interface org.springframework.data.redis.connection.ReactiveClusterCommands
Retrieve cluster node information such as id, host, port and slots.
clusterGetNodes() - Method in interface org.springframework.data.redis.connection.RedisClusterCommands
Retrieve cluster node information such as id, host, port and slots.
clusterGetReplicas(RedisClusterNode) - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
 
clusterGetReplicas(RedisClusterNode) - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
 
clusterGetReplicas(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.ReactiveClusterCommands
Retrieve information about connected replicas for given master node.
clusterGetReplicas(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.RedisClusterCommands
Retrieve information about connected replicas for given master node.
clusterGetSlotForKey(byte[]) - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
 
clusterGetSlotForKey(byte[]) - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
 
clusterGetSlotForKey(byte[]) - Method in interface org.springframework.data.redis.connection.RedisClusterCommands
Find the slot for a given key.
clusterGetSlotForKey(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveClusterCommands
Find the slot for a given key.
ClusterInfo - Class in org.springframework.data.redis.connection
ClusterInfo gives access to cluster information such as cluster_state and cluster_slots_assigned provided by the CLUSTER INFO command.
ClusterInfo(Properties) - Constructor for class org.springframework.data.redis.connection.ClusterInfo
Creates new ClusterInfo for given Properties.
ClusterInfo.Info - Enum Class in org.springframework.data.redis.connection
 
clusterMeet(RedisClusterNode) - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
 
clusterMeet(RedisClusterNode) - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
 
clusterMeet(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.ReactiveClusterCommands
Add given node to cluster.
clusterMeet(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.RedisClusterCommands
Add given node to cluster.
clusterNode(String, Integer) - Method in class org.springframework.data.redis.connection.RedisClusterConfiguration
 
clusterNode(RedisNode) - Method in class org.springframework.data.redis.connection.RedisClusterConfiguration
 
ClusterNodeResourceProvider - Interface in org.springframework.data.redis.connection
ClusterNodeResourceProvider provides access to low level client api to directly execute operations against a Redis instance.
ClusterOperations<K,V> - Interface in org.springframework.data.redis.core
Redis operations for cluster specific operations.
ClusterRedirectException - Exception in org.springframework.data.redis
ClusterRedirectException indicates that a requested slot is not served by the targeted server but can be obtained on another one.
ClusterRedirectException(int, String, int, Throwable) - Constructor for exception org.springframework.data.redis.ClusterRedirectException
clusterReplicate(RedisClusterNode, RedisClusterNode) - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
 
clusterReplicate(RedisClusterNode, RedisClusterNode) - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
 
clusterReplicate(RedisClusterNode, RedisClusterNode) - Method in interface org.springframework.data.redis.connection.ReactiveClusterCommands
Assign a replica to given master.
clusterReplicate(RedisClusterNode, RedisClusterNode) - Method in interface org.springframework.data.redis.connection.RedisClusterCommands
Assign a replica to given master.
clusterSetSlot(RedisClusterNode, int, ReactiveClusterCommands.AddSlots) - Method in interface org.springframework.data.redis.connection.ReactiveClusterCommands
 
clusterSetSlot(RedisClusterNode, int, RedisClusterCommands.AddSlots) - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
 
clusterSetSlot(RedisClusterNode, int, RedisClusterCommands.AddSlots) - Method in class org.springframework.data.redis.connection.lettuce.LettuceClusterConnection
 
clusterSetSlot(RedisClusterNode, int, RedisClusterCommands.AddSlots) - Method in interface org.springframework.data.redis.connection.RedisClusterCommands
 
ClusterSlotHashUtil - Class in org.springframework.data.redis.connection
Utility class encapsulating functionality commonly used for cluster slot hashing.
ClusterSlotHashUtil() - Constructor for class org.springframework.data.redis.connection.ClusterSlotHashUtil
 
ClusterStateFailureException - Exception in org.springframework.data.redis
DataAccessResourceFailureException indicating the current local snapshot of cluster state does no longer represent the actual remote state.
ClusterStateFailureException(String) - Constructor for exception org.springframework.data.redis.ClusterStateFailureException
ClusterStateFailureException(String, Throwable) - Constructor for exception org.springframework.data.redis.ClusterStateFailureException
ClusterTopology - Class in org.springframework.data.redis.connection
ClusterTopology holds snapshot like information about RedisClusterNodes.
ClusterTopology(Set<RedisClusterNode>) - Constructor for class org.springframework.data.redis.connection.ClusterTopology
Creates new instance of ClusterTopology.
ClusterTopologyProvider - Interface in org.springframework.data.redis.connection
ClusterTopologyProvider manages the current cluster topology and makes sure to refresh cluster information.
code() - Method in enum class org.springframework.data.redis.connection.DataType
Returns the code associated with the current enum.
CollectionUtils - Class in org.springframework.data.redis.support.collections
Utility class used mainly for type conversion by the default collection implementations.
CollectionUtils() - Constructor for class org.springframework.data.redis.support.collections.CollectionUtils
 
CommandResponse(I, O) - Constructor for class org.springframework.data.redis.connection.ReactiveRedisConnection.CommandResponse
 
commands() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
commands() - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
 
commands() - Method in class org.springframework.data.redis.connection.jedis.JedisConnection
 
commands() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
 
commands() - Method in interface org.springframework.data.redis.connection.RedisCommandsProvider
commands(BitFieldSubCommands) - Method in class org.springframework.data.redis.connection.ReactiveStringCommands.BitFieldCommand
Applies the BitFieldSubCommands.
commandTimeout(Duration) - Method in class org.springframework.data.redis.connection.lettuce.LettuceClientConfiguration.LettuceClientConfigurationBuilder
Configure a command timeout.
commandTimeout(Duration) - Method in class org.springframework.data.redis.connection.lettuce.LettucePoolingClientConfiguration.LettucePoolingClientConfigurationBuilder
 
compareAndSet(double, double) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicDouble
Atomically set the value to the given updated value if the current value == the expected value.
compareAndSet(int, int) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicInteger
Atomically set the value to the given updated value if the current value == the expected value.
compareAndSet(long, long) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicLong
Atomically set the value to the given updated value if the current value == the expected value.
compareTo(Double) - Method in class org.springframework.data.redis.connection.zset.DefaultTuple
 
compareTo(Double) - Method in class org.springframework.data.redis.core.DefaultTypedTuple
 
compareTo(ByteArrayWrapper) - Method in class org.springframework.data.redis.connection.util.ByteArrayWrapper
 
compareTo(ZSetOperations.TypedTuple<V>) - Method in class org.springframework.data.redis.core.DefaultTypedTuple
 
complete(RedisOperationChain, Sort) - Method in class org.springframework.data.redis.repository.query.RedisQueryCreator
 
CompositeIndexResolver - Class in org.springframework.data.redis.core.convert
Composite IndexResolver implementation that iterates over a given collection of delegate IndexResolver instances.
CompositeIndexResolver(Collection<IndexResolver>) - Constructor for class org.springframework.data.redis.core.convert.CompositeIndexResolver
CompositeValueTransformer(Collection<IndexValueTransformer>) - Constructor for class org.springframework.data.redis.core.index.RedisIndexDefinition.CompositeValueTransformer
 
compute(String) - Method in interface org.springframework.data.redis.cache.CacheKeyPrefix
Compute the prefix for the actual cache key stored in Redis.
computePrefixWith(CacheKeyPrefix) - Method in class org.springframework.data.redis.cache.RedisCacheConfiguration
Use the given CacheKeyPrefix to compute the prefix for the actual Redis key given the cache name as function input.
concat(byte[], byte[]) - Static method in class org.springframework.data.redis.util.ByteUtils
Concatenate the given byte arrays into one.
concatAll(byte[]...) - Static method in class org.springframework.data.redis.util.ByteUtils
Concatenate the given byte arrays into one.
CONFIG_EPOCH - Enum constant in enum class org.springframework.data.redis.connection.RedisServer.INFO
 
CONFIG_GET - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
 
CONFIG_RESETSTAT - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
 
CONFIG_REWRITE - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
 
CONFIG_SET - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
 
ConfigurableIndexDefinitionProvider - Interface in org.springframework.data.redis.core.index
configure(Consumer<ObjectMapper>) - Method in class org.springframework.data.redis.serializer.GenericJackson2JsonRedisSerializer
Builder method used to configure and customize the internal Jackson ObjectMapper created by this GenericJackson2JsonRedisSerializer and used to de/serialize objects as JSON.
configureKeyConverters(Consumer<ConverterRegistry>) - Method in class org.springframework.data.redis.cache.RedisCacheConfiguration
Configure the underlying ConversionService used to extract the cache key.
CONNECTED - Enum constant in enum class org.springframework.data.redis.connection.RedisClusterNode.LinkState
 
CONNECTION_AGE - Enum constant in enum class org.springframework.data.redis.core.types.RedisClientInfo.INFO
 
CONNECTION_IDLE - Enum constant in enum class org.springframework.data.redis.core.types.RedisClientInfo.INFO
 
CONNECTION_NAME - Enum constant in enum class org.springframework.data.redis.core.types.RedisClientInfo.INFO
 
ConnectionUtils - Class in org.springframework.data.redis.connection
Utilities for examining a RedisConnection
ConnectionUtils() - Constructor for class org.springframework.data.redis.connection.ConnectionUtils
 
connectTimeout(Duration) - Method in class org.springframework.data.redis.connection.jedis.JedisClientConfiguration.DefaultJedisClientConfigurationBuilder
 
connectTimeout(Duration) - Method in interface org.springframework.data.redis.connection.jedis.JedisClientConfiguration.JedisClientConfigurationBuilder
Configure a connection timeout.
considerNestedRepositories() - Element in annotation interface org.springframework.data.redis.repository.configuration.EnableRedisRepositories
Configures whether nested repository-interfaces (e.g. defined as inner classes) should be discovered by the repositories infrastructure.
consumer(String) - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.PendingRecordsCommand
Append given consumer.
consumer(String) - Method in class org.springframework.data.redis.connection.RedisStreamCommands.XPendingOptions
Append given consumer.
consumer(Consumer) - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.ConsumerStreamReadRequestBuilder
Configure a Consumer to consume stream messages within a consumer group.
consumer(Consumer) - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamReadRequestBuilder
Configure a Consumer to consume stream messages within a consumer group.
Consumer - Class in org.springframework.data.redis.connection.stream
Value object representing a Stream consumer within a consumer group.
consumerCount() - Method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoGroup
The total number of consumers in the consumer group.
consumerName() - Method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoConsumer
The consumer name.
consumers(K, String) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
Obtain information about every consumer in a specific consumer group for the stream stored at the specified key.
consumers(K, String) - Method in interface org.springframework.data.redis.core.StreamOperations
Obtain information about every consumer in a specific consumer group for the stream stored at the specified key.
consumersIn(String) - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.XInfoCommand
 
contains(int) - Method in class org.springframework.data.redis.connection.RedisClusterNode.SlotRange
Determines whether this RedisClusterNode.SlotRange contains the given slot, which implies this cluster nodes manages the slot holding data stored in Redis.
contains(Object) - Method in class org.springframework.data.redis.connection.util.ByteArraySet
 
contains(Object) - Method in class org.springframework.data.redis.support.collections.DefaultRedisSet
 
contains(Object) - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
 
contains(Object) - Method in class org.springframework.data.redis.support.collections.RedisProperties
 
contains(Object, String) - Method in class org.springframework.data.redis.core.RedisKeyValueAdapter
 
contains(RedisZSetCommands.ZAddArgs.Flag) - Method in class org.springframework.data.redis.connection.RedisZSetCommands.ZAddArgs
Only update elements that already exist.
containsAll(Collection<?>) - Method in class org.springframework.data.redis.connection.util.ByteArraySet
 
containsAll(Collection<?>) - Method in class org.springframework.data.redis.support.collections.AbstractRedisCollection
 
containsAll(Collection<?>) - Method in class org.springframework.data.redis.support.collections.DefaultRedisSet
 
containsKey(Object) - Method in class org.springframework.data.redis.support.collections.DefaultRedisMap
 
containsKey(Object) - Method in class org.springframework.data.redis.support.collections.RedisProperties
 
containsValue(Object) - Method in class org.springframework.data.redis.support.collections.DefaultRedisMap
 
containsValue(Object) - Method in class org.springframework.data.redis.support.collections.RedisProperties
 
conversionRequired() - Method in class org.springframework.data.redis.connection.FutureResult
Indicate whether or not the actual result needs to be converted before handing over.
convert(Exception) - Method in class org.springframework.data.redis.connection.jedis.JedisExceptionConverter
 
convert(Exception) - Method in class org.springframework.data.redis.connection.lettuce.LettuceExceptionConverter
 
convert(Long) - Method in class org.springframework.data.redis.connection.convert.LongToBooleanConverter
 
convert(Object) - Method in class org.springframework.data.redis.connection.FutureResult
Converts the given result if a converter is specified, else returns the result
convert(Object) - Method in class org.springframework.data.redis.connection.jedis.JedisScriptReturnConverter
 
convert(Object) - Method in class org.springframework.data.redis.core.index.RedisIndexDefinition.CompositeValueTransformer
 
convert(Object) - Method in enum class org.springframework.data.redis.core.index.RedisIndexDefinition.LowercaseIndexValueTransformer
 
convert(Object) - Method in enum class org.springframework.data.redis.core.index.RedisIndexDefinition.NoOpValueTransformer
 
convert(String) - Method in class org.springframework.data.redis.connection.convert.StringToDataTypeConverter
 
convert(String) - Method in class org.springframework.data.redis.connection.convert.StringToPropertiesConverter
 
convert(String[]) - Method in class org.springframework.data.redis.connection.convert.StringToRedisClientInfoConverter
 
convert(Collection<S>) - Method in class org.springframework.data.redis.connection.convert.SetConverter
 
convert(List<Object>) - Method in class org.springframework.data.redis.connection.convert.TransactionResultConverter
 
convert(List<S>) - Method in class org.springframework.data.redis.connection.convert.ListConverter
 
convert(Map<?, ?>) - Method in enum class org.springframework.data.redis.connection.convert.MapToPropertiesConverter
 
convert(Map<S, S>) - Method in class org.springframework.data.redis.connection.convert.MapConverter
 
convert(Set<S>) - Method in class org.springframework.data.redis.connection.convert.SetConverter
 
convertAndSend(String, Object) - Method in interface org.springframework.data.redis.core.RedisOperations
Publishes the given message to the given channel.
convertAndSend(String, Object) - Method in class org.springframework.data.redis.core.RedisTemplate
 
convertAndSend(String, V) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
Publishes the given message to the given channel.
convertAndSend(String, V) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
 
converter - Variable in class org.springframework.data.redis.connection.FutureResult
 
Converters - Class in org.springframework.data.redis.connection.convert
Common type converters.
Converters() - Constructor for class org.springframework.data.redis.connection.convert.Converters
 
ConvertingCursor<S,T> - Class in org.springframework.data.redis.core
ConvertingCursor wraps a given cursor and applies given Converter to items prior to returning them.
ConvertingCursor(Cursor<S>, Converter<S, T>) - Constructor for class org.springframework.data.redis.core.ConvertingCursor
 
convertJedisAccessException(Exception) - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
 
convertJedisAccessException(Exception) - Method in class org.springframework.data.redis.connection.jedis.JedisConnection
 
convertKey(Object) - Method in class org.springframework.data.redis.cache.RedisCache
Convert key to a String used in cache key creation.
convertLettuceAccessException(Exception) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
 
convertQuery(SortQuery<K>, RedisSerializer<String>) - Static method in class org.springframework.data.redis.core.query.QueryUtils
 
convertToList(Collection<String>) - Static method in class org.springframework.data.redis.connection.util.DecodeUtils
 
convertToSet(Collection<String>) - Static method in class org.springframework.data.redis.connection.util.DecodeUtils
 
copy(byte[], byte[], boolean) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
Deprecated.
copy(byte[], byte[], boolean) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
copy(byte[], byte[], boolean) - Method in interface org.springframework.data.redis.connection.RedisKeyCommands
Copy given sourceKey to targetKey.
copy(String, String, boolean) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
copy(String, String, boolean) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
Copy given sourceKey to targetKey.
copy(ByteBuffer, ByteBuffer, boolean) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
Copy given key to a target key.
copy(K, K, boolean) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
Copy given sourceKey to targetKey.
copy(K, K, boolean) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
 
copy(K, K, boolean) - Method in interface org.springframework.data.redis.core.RedisOperations
Copy given sourceKey to targetKey.
copy(K, K, boolean) - Method in class org.springframework.data.redis.core.RedisTemplate
 
copy(Publisher<ReactiveKeyCommands.CopyCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
Copy keys one-by-one.
COPY - Enum constant in enum class org.springframework.data.redis.connection.RedisServerCommands.MigrateOption
 
CopyCommand(ByteBuffer, ByteBuffer, boolean, Integer) - Constructor for class org.springframework.data.redis.connection.ReactiveKeyCommands.CopyCommand
 
count(double, double) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
Count number of elements within sorted set with scores between min and max.
count(int) - Method in class org.springframework.data.redis.connection.Limit
 
count(long) - Method in class org.springframework.data.redis.connection.ReactiveHashCommands.HRandFieldCommand
Applies the count.
count(long) - Method in class org.springframework.data.redis.connection.ReactiveListCommands.PopCommand
Applies the key.
count(long) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.BZPopCommand
Applies the key.
count(long) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZPopCommand
Applies the key.
count(long) - Method in class org.springframework.data.redis.connection.stream.StreamReadOptions
Limit the number of messages returned per stream.
count(long) - Method in class org.springframework.data.redis.core.ScanOptions.ScanOptionsBuilder
Returns the current ScanOptions.ScanOptionsBuilder configured with the given count.
count(Integer) - Method in class org.springframework.data.redis.connection.ReactiveListCommands.LPosCommand
Applies the count parameter specifying the number of matches to return.
count(String) - Method in class org.springframework.data.redis.core.RedisKeyValueAdapter
 
count(K, double, double) - Method in interface org.springframework.data.redis.core.ZSetOperations
Count number of elements within sorted set with scores between min and max.
count(K, Range<Double>) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
Count number of elements within sorted set with scores between min and max.
count(Example<S>) - Method in class org.springframework.data.redis.repository.support.QueryByExampleRedisExecutor
 
countExistingKeys(Collection<K>) - Method in interface org.springframework.data.redis.core.RedisOperations
Count the number of keys that exist.
countExistingKeys(Collection<K>) - Method in class org.springframework.data.redis.core.RedisTemplate
 
create() - Static method in interface org.springframework.data.redis.cache.CacheStatisticsCollector
 
create() - Static method in class org.springframework.data.redis.connection.BitFieldSubCommands
Creates a new BitFieldSubCommands.
create() - Static method in interface org.springframework.data.redis.serializer.JacksonObjectReader
Create a default JacksonObjectReader delegating to ObjectMapper.readValue(InputStream, JavaType).
create() - Static method in interface org.springframework.data.redis.serializer.JacksonObjectWriter
Create a default JacksonObjectWriter delegating to ObjectMapper.writeValueAsBytes(Object).
create(CreationalContext<KeyValueOperations>) - Method in class org.springframework.data.redis.repository.cdi.RedisKeyValueTemplateBean
 
create(CreationalContext<RedisKeyValueAdapter>) - Method in class org.springframework.data.redis.repository.cdi.RedisKeyValueAdapterBean
 
create(CreationalContext<T>, Class<T>) - Method in class org.springframework.data.redis.repository.cdi.RedisRepositoryBean
 
create(String, RedisOperations<String, E>) - Static method in interface org.springframework.data.redis.support.collections.RedisList
Constructs a new, uncapped RedisList instance.
create(String, RedisOperations<String, E>) - Static method in interface org.springframework.data.redis.support.collections.RedisSet
Constructs a new RedisSet instance.
create(String, RedisOperations<String, E>) - Static method in interface org.springframework.data.redis.support.collections.RedisZSet
Constructs a new RedisZSet instance with a default score of 1.
create(String, RedisOperations<String, E>, double) - Static method in interface org.springframework.data.redis.support.collections.RedisZSet
Constructs a new RedisZSet instance.
create(String, RedisOperations<String, E>, int) - Static method in interface org.springframework.data.redis.support.collections.RedisList
Factory method used to construct a new RedisList from a Redis list reference by the given key.
create(K, ReadOffset) - Static method in class org.springframework.data.redis.connection.stream.StreamOffset
Create a StreamOffset given key and ReadOffset.
create(BitFieldSubCommands.BitFieldSubCommand...) - Static method in class org.springframework.data.redis.connection.BitFieldSubCommands
Creates a new BitFieldSubCommands with Multiple BitFieldSubCommand.
create(BitFieldSubCommands.BitFieldType, BitFieldSubCommands.Offset) - Static method in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldGet
create(BitFieldSubCommands.BitFieldType, BitFieldSubCommands.Offset, long) - Static method in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldIncrBy
create(BitFieldSubCommands.BitFieldType, BitFieldSubCommands.Offset, long) - Static method in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldSet
create(BitFieldSubCommands.BitFieldType, BitFieldSubCommands.Offset, long, BitFieldSubCommands.BitFieldIncrBy.Overflow) - Static method in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldIncrBy
create(ReactiveRedisConnectionFactory) - Static method in interface org.springframework.data.redis.stream.StreamReceiver
create(ReactiveRedisConnectionFactory, StreamReceiver.StreamReceiverOptions<K, V>) - Static method in interface org.springframework.data.redis.stream.StreamReceiver
create(RedisConnectionFactory) - Static method in class org.springframework.data.redis.cache.RedisCacheManager
Factory method used to construct a new RedisCacheManager initialized with the given RedisConnectionFactory and using defaults for caching.
create(RedisConnectionFactory) - Static method in interface org.springframework.data.redis.stream.StreamMessageListenerContainer
create(RedisConnectionFactory, StreamMessageListenerContainer.StreamMessageListenerContainerOptions<K, V>) - Static method in interface org.springframework.data.redis.stream.StreamMessageListenerContainer
create(BoundListOperations<String, E>) - Static method in interface org.springframework.data.redis.support.collections.RedisList
Constructs a new, uncapped DefaultRedisList instance.
create(BoundListOperations<String, E>, int) - Static method in interface org.springframework.data.redis.support.collections.RedisList
Constructs a new DefaultRedisList.
create(Part, Iterator<Object>) - Method in class org.springframework.data.redis.repository.query.RedisQueryCreator
 
create(S, Map<K, V>) - Static method in interface org.springframework.data.redis.connection.stream.MapRecord
Creates a new MapRecord associated with the stream key and value.
create(S, V) - Static method in interface org.springframework.data.redis.connection.stream.ObjectRecord
Creates a new ObjectRecord associated with the stream key and value.
CREATE - 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
Creates JedisCluster for given RedisClusterConfiguration and GenericObjectPoolConfig.
createCredentialsProvider(RedisConfiguration) - Method in interface org.springframework.data.redis.connection.lettuce.RedisCredentialsProviderFactory
Create a RedisCredentialsProvider for data node authentication given RedisConfiguration.
CREATED - Enum constant in enum class org.springframework.data.redis.stream.Task.State
 
createDefaultTaskExecutor() - Method in class org.springframework.data.redis.listener.RedisMessageListenerContainer
Creates a default TaskExecutor.
createEndpoint(SocketAddress) - Method in class org.springframework.data.redis.connection.lettuce.observability.MicrometerTracingAdapter
Deprecated.
 
createFlux(ReactiveRedisCallback<T>) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
Create a reusable Flux for a ReactiveRedisCallback.
createGroup(String) - Static method in class org.springframework.data.redis.connection.ReactiveStreamCommands.GroupCommand
 
createGroup(K, String) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
Create a consumer group at the latest offset.
createGroup(K, String) - Method in interface org.springframework.data.redis.core.StreamOperations
Create a consumer group at the latest offset.
createGroup(K, ReadOffset, String) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
Create a consumer group.
createGroup(K, ReadOffset, String) - Method in interface org.springframework.data.redis.core.StreamOperations
Create a consumer group.
createGroup(ReadOffset, String) - Method in interface org.springframework.data.redis.core.BoundStreamOperations
Create a consumer group.
createKey(String, String) - Method in class org.springframework.data.redis.core.RedisKeyValueAdapter
Creates a new key using the given keyspace and id.
createMono(ReactiveRedisCallback<T>) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
Create a reusable Mono for a ReactiveRedisCallback.
createPersistentEntity(TypeInformation<T>) - Method in class org.springframework.data.redis.core.mapping.RedisMappingContext
 
createPersistentProperty(Property, RedisPersistentEntity<?>, SimpleTypeHolder) - Method in class org.springframework.data.redis.core.mapping.RedisMappingContext
 
createRedisCache(String, RedisCacheConfiguration) - Method in class org.springframework.data.redis.cache.RedisCacheManager
Creates a new RedisCache with given name and RedisCacheConfiguration.
createRedisConfiguration(RedisURI) - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
Creates a RedisConfiguration based on a RedisURI according to the following: If RedisURI contains sentinels, a RedisSentinelConfiguration is returned If RedisURI has a configured socket a RedisSocketConfiguration is returned Otherwise a RedisStandaloneConfiguration is returned
createRedisConfiguration(String) - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
Creates a RedisConfiguration based on a URI according to the following: If redisUri contains sentinels, a RedisSentinelConfiguration is returned If redisUri has a configured socket a RedisSocketConfiguration is returned Otherwise a RedisStandaloneConfiguration is returned
createRedisConnectionProxy(ReactiveRedisConnection) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
 
createRedisConnectionProxy(RedisConnection) - Method in class org.springframework.data.redis.core.RedisTemplate
 
createRedisPool() - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
Creates JedisPool.
createRedisSentinelPool(RedisSentinelConfiguration) - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
Creates JedisSentinelPool.
createRepositoryFactory(KeyValueOperations, Class<? extends AbstractQueryCreator<?, ?>>, Class<? extends RepositoryQuery>) - Method in class org.springframework.data.redis.repository.support.RedisRepositoryFactoryBean
 
createSentinelCredentialsProvider(RedisSentinelConfiguration) - Method in interface org.springframework.data.redis.connection.lettuce.RedisCredentialsProviderFactory
Create a RedisCredentialsProvider for Sentinel node authentication given RedisSentinelConfiguration.
createSubscription() - Method in interface org.springframework.data.redis.connection.ReactivePubSubCommands
Creates a subscription for this connection.
createSubscription(SubscriptionListener) - Method in interface org.springframework.data.redis.connection.ReactivePubSubCommands
Creates a subscription for this connection.
createTopologyProvider(JedisCluster) - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
Template method to create a ClusterTopologyProvider given JedisCluster.
CURRENT_EPOCH - Enum constant in enum class org.springframework.data.redis.connection.ClusterInfo.Info
 
Cursor<T> - Interface in org.springframework.data.redis.core
Cursor abstraction to scan over the keyspace or elements within a data structure using a variant of a SCAN command.
Cursor.CursorId - Class in org.springframework.data.redis.core
Value class representing a cursor identifier.
CursorId() - Constructor for class org.springframework.data.redis.core.Cursor.CursorId
 

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.
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.
dbSize(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.ReactiveClusterServerCommands
Get the total number of available keys in currently selected database.
dbSize(RedisClusterNode) - Method in interface org.springframework.data.redis.connection.RedisClusterServerCommands
 
DBSIZE - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
 
decode(byte[]) - Static method in class org.springframework.data.redis.connection.util.DecodeUtils
 
decodeMap(Map<byte[], byte[]>) - Static method in class org.springframework.data.redis.connection.util.DecodeUtils
 
decodeMultiple(byte[]...) - Static method in class org.springframework.data.redis.connection.util.DecodeUtils
 
DecodeUtils - Class in org.springframework.data.redis.connection.util
Simple class containing various decoding utilities.
DecodeUtils() - Constructor for class org.springframework.data.redis.connection.util.DecodeUtils
 
DecoratedRedisConnection - Interface in org.springframework.data.redis.connection
Specifies that the connection decorates another RedisConnection.
DecoratingStringHashMapper<T> - Class in org.springframework.data.redis.hash
Delegating hash mapper used for flattening objects into Strings.
DecoratingStringHashMapper(HashMapper<T, ?, ?>) - Constructor for class org.springframework.data.redis.hash.DecoratingStringHashMapper
 
decr(byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
Deprecated.
decr(byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
decr(byte[]) - Method in interface org.springframework.data.redis.connection.RedisStringCommands
Decrement an integer value stored as string value of key by 1.
decr(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
decr(String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
Decrement an integer value stored as string value of key by 1.
decr(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveNumberCommands
Decrement value of key by 1.
decr(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveNumberCommands.DecrByCommand
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.
decrBy(byte[], long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
decrBy(byte[], long) - Method in interface org.springframework.data.redis.connection.RedisStringCommands
Decrement an integer value stored as string value of key by value.
decrBy(String, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
decrBy(String, long) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
Decrement an integer value stored as string value of key by value.
decrBy(ByteBuffer, T) - Method in interface org.springframework.data.redis.connection.ReactiveNumberCommands
Decrement value of key by value.
decrBy(Publisher<ReactiveNumberCommands.DecrByCommand<T>>) - Method in interface org.springframework.data.redis.connection.ReactiveNumberCommands
Decrement value of key by value.
DECRBY - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
 
decrement() - Method in interface org.springframework.data.redis.core.BoundValueOperations
Decrement an integer value stored as string value under the bound key by one.
decrement(long) - Method in interface org.springframework.data.redis.core.BoundValueOperations
Decrement an integer value stored as string value under the bound key by delta.
decrement(K) - Method in interface org.springframework.data.redis.core.ReactiveValueOperations
Decrements the number stored at key by one.
decrement(K) - Method in interface org.springframework.data.redis.core.ValueOperations
Decrement an integer value stored as string value under key by one.
decrement(K, long) - Method in interface org.springframework.data.redis.core.ReactiveValueOperations
Decrements the number stored at key by delta.
decrement(K, long) - Method in interface org.springframework.data.redis.core.ValueOperations
Decrement an integer value stored as string value under key by delta.
decrementAndGet() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicDouble
Atomically decrement by one the current value.
decrementAndGet() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicInteger
Atomically decrement by one the current value.
decrementAndGet() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicLong
Atomically decrement by one the current value.
DEFAULT - Enum constant in enum class org.springframework.data.redis.core.RedisKeyValueAdapter.ShadowCopy
Store shadow copies of expiring entities depending on the RedisKeyValueAdapter.EnableKeyspaceEvents.
DEFAULT_ALLOW_RUNTIME_CACHE_CREATION - Static variable in class org.springframework.data.redis.cache.RedisCacheManager
 
DEFAULT_CACHE_NULL_VALUES - Static variable in class org.springframework.data.redis.cache.RedisCacheConfiguration
 
DEFAULT_CHARSET - Static variable in class org.springframework.data.redis.serializer.Jackson2JsonRedisSerializer
Deprecated, for removal: This API element is subject to removal in a future version.
since 3.0 for removal.
DEFAULT_ENABLE_TIME_TO_IDLE_EXPIRATION - Static variable in class org.springframework.data.redis.cache.RedisCacheConfiguration
 
DEFAULT_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
Default RedisCacheConfiguration using the following: key expiration eternal cache null values yes prefix cache keys yes default prefix [the actual cache name] key serializer StringRedisSerializer value serializer JdkSerializationRedisSerializer conversion service DefaultFormattingConversionService with default cache key converters
defaultCacheConfig(ClassLoader) - Static method in class org.springframework.data.redis.cache.RedisCacheConfiguration
Create default RedisCacheConfiguration given ClassLoader using the following: key expiration eternal cache null values yes prefix cache keys yes default prefix [the actual cache name] key serializer StringRedisSerializer value serializer JdkSerializationRedisSerializer conversion service DefaultFormattingConversionService with default cache key converters
defaultConfiguration() - Static method in interface org.springframework.data.redis.connection.jedis.JedisClientConfiguration
Creates a default JedisClientConfiguration.
defaultConfiguration() - Static method in interface org.springframework.data.redis.connection.lettuce.LettuceClientConfiguration
Creates a default LettuceClientConfiguration with: SSL no Peer Verification yes Start TLS no Client Options ClientOptions with enabled TimeoutOptions Client Resources none Client name none Read From none Connect Timeout 60 Seconds Shutdown Timeout 100 Milliseconds Shutdown Quiet Period 100 Milliseconds
defaultConfiguration() - Static method in interface org.springframework.data.redis.connection.lettuce.LettucePoolingClientConfiguration
Creates a default LettucePoolingClientConfiguration with SSL no Peer Verification yes Start TLS no Client Options ClientOptions with enabled TimeoutOptions Client Resources none Client name none Read From none Connect Timeout 60 Seconds Shutdown Timeout 100 Milliseconds Shutdown Quiet Period 100 Milliseconds pool config default GenericObjectPoolConfig
DefaultedRedisClusterConnection - Interface in org.springframework.data.redis.connection
Deprecated.
DefaultedRedisConnection - Interface in org.springframework.data.redis.connection
Deprecated.
DefaultMessage - Class in org.springframework.data.redis.connection
Default message implementation.
DefaultMessage(byte[], byte[]) - Constructor for class org.springframework.data.redis.connection.DefaultMessage
 
DefaultReactiveScriptExecutor<K> - Class in org.springframework.data.redis.core.script
Default implementation of ReactiveScriptExecutor.
DefaultReactiveScriptExecutor(ReactiveRedisConnectionFactory, RedisSerializationContext<K, ?>) - Constructor for class org.springframework.data.redis.core.script.DefaultReactiveScriptExecutor
DefaultRedisList<E> - Class in org.springframework.data.redis.support.collections
Default implementation for RedisList.
DefaultRedisList(String, RedisOperations<String, E>) - Constructor for class org.springframework.data.redis.support.collections.DefaultRedisList
Constructs a new, uncapped DefaultRedisList instance.
DefaultRedisList(String, RedisOperations<String, E>, int) - Constructor for class org.springframework.data.redis.support.collections.DefaultRedisList
Constructs a new DefaultRedisList instance constrained to the given max size.
DefaultRedisList(BoundListOperations<String, E>) - Constructor for class org.springframework.data.redis.support.collections.DefaultRedisList
Constructs a new, uncapped DefaultRedisList instance.
DefaultRedisList(BoundListOperations<String, E>, int) - Constructor for class org.springframework.data.redis.support.collections.DefaultRedisList
Constructs a new DefaultRedisList instance constrained to the given max size.
DefaultRedisMap<K,V> - Class in org.springframework.data.redis.support.collections
Default implementation for RedisMap.
DefaultRedisMap(String, RedisOperations<String, ?>) - Constructor for class org.springframework.data.redis.support.collections.DefaultRedisMap
Constructs a new DefaultRedisMap instance.
DefaultRedisMap(BoundHashOperations<String, K, V>) - Constructor for class org.springframework.data.redis.support.collections.DefaultRedisMap
Constructs a new DefaultRedisMap instance.
DefaultRedisScript<T> - Class in org.springframework.data.redis.core.script
Default implementation of RedisScript.
DefaultRedisScript() - Constructor for class org.springframework.data.redis.core.script.DefaultRedisScript
Creates a new DefaultRedisScript
DefaultRedisScript(String) - Constructor for class org.springframework.data.redis.core.script.DefaultRedisScript
Creates a new DefaultRedisScript
DefaultRedisScript(String, Class<T>) - Constructor for class org.springframework.data.redis.core.script.DefaultRedisScript
Creates a new DefaultRedisScript
DefaultRedisSet<E> - Class in org.springframework.data.redis.support.collections
Default implementation for RedisSet.
DefaultRedisSet(String, RedisOperations<String, E>) - Constructor for class org.springframework.data.redis.support.collections.DefaultRedisSet
Constructs a new DefaultRedisSet instance.
DefaultRedisSet(BoundSetOperations<String, E>) - Constructor for class org.springframework.data.redis.support.collections.DefaultRedisSet
Constructs a new DefaultRedisSet instance.
DefaultRedisTypeMapper - Class in org.springframework.data.redis.core.convert
Default implementation of RedisTypeMapper allowing configuration of the key to lookup and store type information via Bucket.BucketPropertyPath in buckets.
DefaultRedisTypeMapper() - Constructor for class org.springframework.data.redis.core.convert.DefaultRedisTypeMapper
Create a new DefaultRedisTypeMapper using DefaultRedisTypeMapper.DEFAULT_TYPE_KEY to exchange type hints.
DefaultRedisTypeMapper(String) - Constructor for class org.springframework.data.redis.core.convert.DefaultRedisTypeMapper
Create a new DefaultRedisTypeMapper given typeKey to exchange type hints.
DefaultRedisTypeMapper(String, List<? extends TypeInformationMapper>) - Constructor for class org.springframework.data.redis.core.convert.DefaultRedisTypeMapper
Create a new DefaultRedisTypeMapper given typeKey to exchange type hints and List of TypeInformationMapper.
DefaultRedisTypeMapper(String, MappingContext<? extends PersistentEntity<?, ?>, ?>) - Constructor for class org.springframework.data.redis.core.convert.DefaultRedisTypeMapper
Create a new DefaultRedisTypeMapper given typeKey to exchange type hints and MappingContext.
DefaultRedisZSet<E> - Class in org.springframework.data.redis.support.collections
Default implementation for RedisZSet.
DefaultRedisZSet(String, RedisOperations<String, E>) - Constructor for class org.springframework.data.redis.support.collections.DefaultRedisZSet
Constructs a new DefaultRedisZSet instance with a default score of 1.
DefaultRedisZSet(String, RedisOperations<String, E>, double) - Constructor for class org.springframework.data.redis.support.collections.DefaultRedisZSet
Constructs a new DefaultRedisZSet instance.
DefaultRedisZSet(BoundZSetOperations<String, E>) - Constructor for class org.springframework.data.redis.support.collections.DefaultRedisZSet
Constructs a new DefaultRedisZSet instance with a default score of '1'.
DefaultRedisZSet(BoundZSetOperations<String, E>, double) - Constructor for class org.springframework.data.redis.support.collections.DefaultRedisZSet
Constructs a new DefaultRedisZSet instance.
DefaultScriptExecutor<K> - Class in org.springframework.data.redis.core.script
Default implementation of ScriptExecutor.
DefaultScriptExecutor(RedisTemplate<K, ?>) - Constructor for class org.springframework.data.redis.core.script.DefaultScriptExecutor
 
DefaultSortParameters - Class in org.springframework.data.redis.connection
Default implementation for SortParameters.
DefaultSortParameters() - Constructor for class org.springframework.data.redis.connection.DefaultSortParameters
Constructs a new DefaultSortParameters instance.
DefaultSortParameters(byte[], SortParameters.Range, byte[][], SortParameters.Order, Boolean) - Constructor for class org.springframework.data.redis.connection.DefaultSortParameters
Constructs a new DefaultSortParameters instance.
DefaultSortParameters(SortParameters.Range, SortParameters.Order, Boolean) - Constructor for class org.springframework.data.redis.connection.DefaultSortParameters
Constructs a new DefaultSortParameters instance.
DefaultStringRedisConnection - Class in org.springframework.data.redis.connection
Default implementation of StringRedisConnection.
DefaultStringRedisConnection(RedisConnection) - Constructor for class org.springframework.data.redis.connection.DefaultStringRedisConnection
Constructs a new DefaultStringRedisConnection instance.
DefaultStringRedisConnection(RedisConnection, RedisSerializer<String>) - Constructor for class org.springframework.data.redis.connection.DefaultStringRedisConnection
Constructs a new DefaultStringRedisConnection instance.
DefaultStringTuple - Class in org.springframework.data.redis.connection
Default implementation for StringRedisConnection.StringTuple interface.
DefaultStringTuple(byte[], String, Double) - Constructor for class org.springframework.data.redis.connection.DefaultStringTuple
Constructs a new DefaultStringTuple instance.
DefaultStringTuple(String, double) - Constructor for class org.springframework.data.redis.connection.DefaultStringTuple
Constructs a new DefaultStringTuple instance.
DefaultStringTuple(Tuple, String) - Constructor for class org.springframework.data.redis.connection.DefaultStringTuple
Constructs a new DefaultStringTuple instance.
DefaultTuple - Class in org.springframework.data.redis.connection.zset
Default implementation for Tuple interface.
DefaultTuple(byte[], Double) - Constructor for class org.springframework.data.redis.connection.zset.DefaultTuple
Constructs a new DefaultTuple.
DefaultTypedTuple<V> - Class in org.springframework.data.redis.core
Default implementation of TypedTuple.
DefaultTypedTuple(V, Double) - Constructor for class org.springframework.data.redis.core.DefaultTypedTuple
Constructs a new DefaultTypedTuple instance.
defaultTyping(boolean) - Method in class org.springframework.data.redis.serializer.GenericJackson2JsonRedisSerializer.GenericJackson2JsonRedisSerializerBuilder
Enable or disable default typing.
del(byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
Deprecated.
del(byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
del(byte[]...) - Method in interface org.springframework.data.redis.connection.RedisKeyCommands
Delete given keys.
del(String) - Method in class org.springframework.data.redis.core.PartialUpdate
Remove the value reachable via given path.
del(String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
del(String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
Delete given keys.
del(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
Delete key.
del(Publisher<ReactiveRedisConnection.KeyCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
Delete keys one by one.
DEL - Enum constant in enum class org.springframework.data.redis.core.PartialUpdate.UpdateCommand
 
DEL - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
 
delete(H) - Method in interface org.springframework.data.redis.core.ReactiveHashOperations
Removes the given key.
delete(H, Object...) - Method in interface org.springframework.data.redis.core.HashOperations
Delete given hash hashKeys.
delete(Object...) - Method in interface org.springframework.data.redis.core.BoundHashOperations
Delete given hash keys at the bound key.
delete(Object, String) - Method in class org.springframework.data.redis.core.RedisKeyValueAdapter
 
delete(Object, String, Class<T>) - Method in class org.springframework.data.redis.core.RedisKeyValueAdapter
 
delete(String...) - Method in interface org.springframework.data.redis.core.BoundStreamOperations
Removes the specified entries from the stream.
delete(Collection<K>) - Method in interface org.springframework.data.redis.core.RedisOperations
Delete given keys.
delete(Collection<K>) - Method in class org.springframework.data.redis.core.RedisTemplate
 
delete(K) - Method in interface org.springframework.data.redis.core.HyperLogLogOperations
Removes the given key.
delete(K) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
Removes the given key.
delete(K) - Method in interface org.springframework.data.redis.core.ReactiveHyperLogLogOperations
Removes the given key.
delete(K) - Method in interface org.springframework.data.redis.core.ReactiveListOperations
Removes the given key.
delete(K) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
Removes the given key.
delete(K) - Method in interface org.springframework.data.redis.core.ReactiveValueOperations
Removes the given key.
delete(K) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
Removes the given key.
delete(K) - Method in interface org.springframework.data.redis.core.RedisOperations
Delete given key.
delete(K) - Method in class org.springframework.data.redis.core.RedisTemplate
 
delete(K...) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
Delete given key.
delete(K...) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
 
delete(K, String...) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
Removes the specified records from the stream.
delete(K, String...) - Method in interface org.springframework.data.redis.core.StreamOperations
Removes the specified records from the stream.
delete(K, RecordId...) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
Removes the specified records from the stream.
delete(K, RecordId...) - Method in interface org.springframework.data.redis.core.StreamOperations
Removes the specified records from the stream.
delete(Publisher<K>) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
Delete given keys.
delete(Publisher<K>) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
 
delete(Record<K, ?>) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
Removes a given Record from the stream.
delete(Record<K, ?>) - Method in interface org.springframework.data.redis.core.StreamOperations
Removes a given Record from the stream.
DELETE_CONSUMER - Enum constant in enum class org.springframework.data.redis.connection.ReactiveStreamCommands.GroupCommand.GroupCommandAction
 
deleteAllOf(String) - Method in class org.springframework.data.redis.core.RedisKeyValueAdapter
 
deleteConsumer(String) - Static method in class org.springframework.data.redis.connection.ReactiveStreamCommands.GroupCommand
 
deleteConsumer(K, Consumer) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
Delete a consumer from a consumer group.
deleteConsumer(K, Consumer) - Method in interface org.springframework.data.redis.core.StreamOperations
Delete a consumer from a consumer group.
deleteConsumer(Consumer) - Static method in class org.springframework.data.redis.connection.ReactiveStreamCommands.GroupCommand
 
deleteConsumer(Consumer) - Method in interface org.springframework.data.redis.core.BoundStreamOperations
Delete a consumer from a consumer group.
DELIMITER - Static variable in class org.springframework.data.redis.core.convert.MappingRedisConverter.BinaryKeyspaceIdentifier
 
DELIMITER - Static variable in class org.springframework.data.redis.core.convert.MappingRedisConverter.KeyspaceIdentifier
 
desc() - Method in class org.springframework.data.redis.connection.DefaultSortParameters
 
DESC - Enum constant in enum class org.springframework.data.redis.connection.SortParameters.Order
 
descendingIterator() - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
 
deserialize(byte[]) - Method in class org.springframework.data.redis.serializer.GenericJackson2JsonRedisSerializer
 
deserialize(byte[]) - Method in class org.springframework.data.redis.serializer.GenericToStringSerializer
 
deserialize(byte[]) - Method in class org.springframework.data.redis.serializer.Jackson2JsonRedisSerializer
 
deserialize(byte[]) - Method in class org.springframework.data.redis.serializer.JdkSerializationRedisSerializer
 
deserialize(byte[]) - Method in class org.springframework.data.redis.serializer.OxmSerializer
 
deserialize(byte[]) - Method in interface org.springframework.data.redis.serializer.RedisSerializer
Deserialize an object from the given binary data.
deserialize(byte[]) - Method in class org.springframework.data.redis.serializer.StringRedisSerializer
 
deserialize(byte[], Class<T>) - Method in class org.springframework.data.redis.serializer.GenericJackson2JsonRedisSerializer
Deserialized the array of bytes containing JSON as an Object of the given, required type.
deserialize(Collection<byte[]>, RedisSerializer<T>) - Static method in class org.springframework.data.redis.serializer.SerializationUtils
 
deserialize(List<byte[]>, RedisSerializer<T>) - Static method in class org.springframework.data.redis.serializer.SerializationUtils
 
deserialize(Map<byte[], byte[]>, RedisSerializer<HK>, RedisSerializer<HV>) - Static method in class org.springframework.data.redis.serializer.SerializationUtils
 
deserialize(Map<byte[], byte[]>, RedisSerializer<T>) - Static method in class org.springframework.data.redis.serializer.SerializationUtils
 
deserialize(Set<byte[]>, RedisSerializer<T>) - Static method in class org.springframework.data.redis.serializer.SerializationUtils
 
deserialize(RedisSerializer<? extends K>, RedisSerializer<? extends HK>, RedisSerializer<? extends HV>) - Method in interface org.springframework.data.redis.connection.stream.ByteBufferRecord
Deserialize key with the streamSerializer, field names with the fieldSerializer and values with the valueSerializer.
deserialize(RedisSerializer<? extends K>, RedisSerializer<? extends HK>, RedisSerializer<? extends HV>) - Method in interface org.springframework.data.redis.connection.stream.ByteRecord
Deserialize key with the streamSerializer, field names with the fieldSerializer and values with the valueSerializer.
deserialize(RedisSerializer<T>) - Method in interface org.springframework.data.redis.connection.stream.ByteBufferRecord
Deserialize key and field/value pairs with the given RedisSerializer.
deserialize(RedisSerializer<T>) - Method in interface org.springframework.data.redis.connection.stream.ByteRecord
Deserialize key and field/value pairs with the given RedisSerializer.
deserializeCacheValue(byte[]) - Method in class org.springframework.data.redis.cache.RedisCache
Deserialize the given the array of bytes to the actual cache value.
deserializeRecord(ByteBufferRecord) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
Deserialize a ByteBufferRecord using the configured serialization context into a MapRecord.
deserializeRecord(ByteRecord) - Method in interface org.springframework.data.redis.core.StreamOperations
Deserialize a ByteRecord using the configured serializers into a MapRecord.
deserializeResult(RedisElementReader<T>, Flux<T>) - Method in class org.springframework.data.redis.core.script.DefaultReactiveScriptExecutor
 
deserializeResult(RedisSerializer<T>, Object) - Method in class org.springframework.data.redis.core.script.DefaultScriptExecutor
 
deserializingGeoResultsConverter(RedisSerializer<V>) - Static method in class org.springframework.data.redis.connection.convert.Converters
Converter capable of deserializing GeoResults.
destroy() - Method in class org.springframework.data.redis.connection.ClusterCommandExecutor
 
destroy() - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
 
destroy() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
 
destroy() - Method in class org.springframework.data.redis.core.RedisKeyValueAdapter
 
destroy() - Method in class org.springframework.data.redis.listener.KeyspaceEventMessageListener
 
destroy() - Method in class org.springframework.data.redis.listener.ReactiveRedisMessageListenerContainer
 
destroy() - Method in class org.springframework.data.redis.listener.RedisMessageListenerContainer
Destroy the container and stop it.
destroy(KeyValueOperations, CreationalContext<KeyValueOperations>) - Method in class org.springframework.data.redis.repository.cdi.RedisKeyValueTemplateBean
 
destroy(RedisKeyValueAdapter, CreationalContext<RedisKeyValueAdapter>) - Method in class org.springframework.data.redis.repository.cdi.RedisKeyValueAdapterBean
 
destroy(T, CreationalContext<T>) - Method in class org.springframework.data.redis.repository.cdi.CdiBean
 
DESTROY - Enum constant in enum class org.springframework.data.redis.connection.ReactiveStreamCommands.GroupCommand.GroupCommandAction
 
destroyGroup(String) - Static method in class org.springframework.data.redis.connection.ReactiveStreamCommands.GroupCommand
 
destroyGroup(String) - Method in interface org.springframework.data.redis.core.BoundStreamOperations
Destroy a consumer group.
destroyGroup(K, String) - Method in interface org.springframework.data.redis.core.ReactiveStreamOperations
Destroy a consumer group.
destroyGroup(K, String) - Method in interface org.springframework.data.redis.core.StreamOperations
Destroy a consumer group.
destroyLater() - Method in class org.springframework.data.redis.listener.ReactiveRedisMessageListenerContainer
 
diff(Collection<? extends RedisSet<?>>) - Method in class org.springframework.data.redis.support.collections.DefaultRedisSet
 
diff(Collection<? extends RedisSet<?>>) - Method in interface org.springframework.data.redis.support.collections.RedisSet
Diff this set and other RedisSets.
diff(Collection<? extends RedisZSet<?>>) - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
 
diff(Collection<? extends RedisZSet<?>>) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
Diff this set and other RedisZSets.
diff(Collection<K>) - Method in interface org.springframework.data.redis.core.BoundSetOperations
Deprecated.
since 3.0, use BoundSetOperations.difference(Collection) instead to follow a consistent method naming scheme.
diff(K) - Method in interface org.springframework.data.redis.core.BoundSetOperations
Deprecated.
since 3.0, use BoundSetOperations.difference(Object) instead to follow a consistent method naming scheme.
diff(RedisSet<?>) - Method in class org.springframework.data.redis.support.collections.DefaultRedisSet
 
diff(RedisSet<?>) - Method in interface org.springframework.data.redis.support.collections.RedisSet
Diff this set and another RedisSet.
diff(RedisZSet<?>) - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
 
diff(RedisZSet<?>) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
Diff this set and another RedisZSet.
diffAndStore(Collection<? extends RedisSet<?>>, String) - Method in class org.springframework.data.redis.support.collections.DefaultRedisSet
 
diffAndStore(Collection<? extends RedisSet<?>>, String) - Method in interface org.springframework.data.redis.support.collections.RedisSet
Create a new RedisSet by diffing this sorted set and the collection RedisSet and store result in destination destKey.
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
Create a new RedisZSet by diffing this sorted set and the collection RedisZSet and store result in destination destKey.
diffAndStore(Collection<K>, K) - Method in interface org.springframework.data.redis.core.BoundSetOperations
Deprecated.
since 3.0, use BoundSetOperations.differenceAndStore(Collection, Object) instead to follow a consistent method naming scheme.
diffAndStore(K, K) - Method in interface org.springframework.data.redis.core.BoundSetOperations
Deprecated.
since 3.0, use BoundSetOperations.differenceAndStore(Object, Object) instead to follow a consistent method naming scheme..
diffAndStore(RedisSet<?>, String) - Method in class org.springframework.data.redis.support.collections.DefaultRedisSet
 
diffAndStore(RedisSet<?>, String) - Method in interface org.springframework.data.redis.support.collections.RedisSet
Create a new RedisSet by diffing this sorted set and RedisSet and store result in destination destKey.
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
Create a new RedisZSet by diffing this sorted set and RedisZSet and store result in destination destKey.
difference(Collection<K>) - Method in interface org.springframework.data.redis.core.BoundSetOperations
Diff all sets for given the bound key and keys.
difference(Collection<K>) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
Diff sorted sets.
difference(Collection<K>) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
Diff all sets for given keys.
difference(Collection<K>) - Method in interface org.springframework.data.redis.core.SetOperations
Diff all sets for given keys.
difference(K) - Method in interface org.springframework.data.redis.core.BoundSetOperations
Diff all sets for given the bound key and key.
difference(K) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
Diff sorted sets.
difference(K, Collection<K>) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
Diff all sets for given key and otherKeys.
difference(K, Collection<K>) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
Diff sorted sets.
difference(K, Collection<K>) - Method in interface org.springframework.data.redis.core.SetOperations
Diff all sets for given key and otherKeys.
difference(K, Collection<K>) - Method in interface org.springframework.data.redis.core.ZSetOperations
Diff sorted sets.
difference(K, K) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
Diff all sets for given key and otherKey.
difference(K, K) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
Diff sorted sets.
difference(K, K) - Method in interface org.springframework.data.redis.core.SetOperations
Diff all sets for given key and otherKey.
difference(K, K) - Method in interface org.springframework.data.redis.core.ZSetOperations
Diff sorted sets.
differenceAndStore(Collection<K>, K) - Method in interface org.springframework.data.redis.core.BoundSetOperations
Diff all sets for given the bound key and keys and store result in destKey.
differenceAndStore(Collection<K>, K) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
Diff sorted sets and store result in destination destKey.
differenceAndStore(Collection<K>, K) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
Diff all sets for given keys and store result in destKey.
differenceAndStore(Collection<K>, K) - Method in interface org.springframework.data.redis.core.SetOperations
Diff all sets for given keys and store result in destKey.
differenceAndStore(K, Collection<K>, K) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
Diff all sets for given key and otherKeys and store result in destKey.
differenceAndStore(K, Collection<K>, K) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
Diff sorted sets and store result in destination destKey.
differenceAndStore(K, Collection<K>, K) - Method in interface org.springframework.data.redis.core.SetOperations
Diff all sets for given key and otherKeys and store result in destKey.
differenceAndStore(K, Collection<K>, K) - Method in interface org.springframework.data.redis.core.ZSetOperations
Diff sorted sets and store result in destination destKey.
differenceAndStore(K, K) - Method in interface org.springframework.data.redis.core.BoundSetOperations
Diff all sets for given the bound key and keys and store result in destKey.
differenceAndStore(K, K) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
Diff sorted sets and store result in destination destKey.
differenceAndStore(K, K, K) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
Diff all sets for given key and otherKey and store result in destKey.
differenceAndStore(K, K, K) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
Diff sorted sets and store result in destination destKey.
differenceAndStore(K, K, K) - Method in interface org.springframework.data.redis.core.SetOperations
Diff all sets for given key and otherKey and store result in destKey.
differenceWithScores(Collection<K>) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
Diff sorted sets.
differenceWithScores(K) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
Diff sorted sets.
differenceWithScores(K, Collection<K>) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
Diff sorted sets.
differenceWithScores(K, Collection<K>) - Method in interface org.springframework.data.redis.core.ZSetOperations
Diff sorted sets.
differenceWithScores(K, K) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
Diff sorted sets.
differenceWithScores(K, K) - Method in interface org.springframework.data.redis.core.ZSetOperations
Diff sorted sets.
diffWithScores(Collection<? extends RedisZSet<?>>) - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
 
diffWithScores(Collection<? extends RedisZSet<?>>) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
Diff this set and other RedisZSets.
diffWithScores(RedisZSet<?>) - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
 
diffWithScores(RedisZSet<?>) - Method in interface org.springframework.data.redis.support.collections.RedisZSet
Diff this set and another RedisZSet.
DigestUtils - Class in org.springframework.data.redis.core.script
Utilties for working with MessageDigest
DigestUtils() - Constructor for class org.springframework.data.redis.core.script.DigestUtils
 
disableCachingNullValues() - Method in class org.springframework.data.redis.cache.RedisCacheConfiguration
Disable caching null values.
disableCreateOnMissingCache() - Method in class org.springframework.data.redis.cache.RedisCacheManager.RedisCacheManagerBuilder
Disable RedisCache creation at runtime for non-configured, undeclared caches.
disableKeyPrefix() - Method in class org.springframework.data.redis.cache.RedisCacheConfiguration
Disable using cache key prefixes.
disablePeerVerification() - Method in class org.springframework.data.redis.connection.lettuce.LettuceClientConfiguration.LettuceSslClientConfigurationBuilder
Disable peer verification.
disablePeerVerification() - Method in class org.springframework.data.redis.connection.lettuce.LettucePoolingClientConfiguration.LettucePoolingSslClientConfigurationBuilder
 
discard() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
discard() - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
 
discard() - Method in class org.springframework.data.redis.connection.jedis.JedisConnection
 
discard() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
 
discard() - Method in interface org.springframework.data.redis.connection.RedisTxCommands
Discard all commands issued after RedisTxCommands.multi().
discard() - Method in interface org.springframework.data.redis.core.RedisOperations
Discard all commands issued after RedisOperations.multi().
discard() - Method in class org.springframework.data.redis.core.RedisTemplate
 
DISCARD - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
 
DISCONNECTED - Enum constant in enum class org.springframework.data.redis.connection.RedisClusterNode.LinkState
 
distance(K, M, M) - Method in interface org.springframework.data.redis.core.GeoOperations
Get the Distance between member1 and member2.
distance(K, M, M) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
Get the Distance between member1 and member2.
distance(K, M, M, Metric) - Method in interface org.springframework.data.redis.core.GeoOperations
Get the Distance between member1 and member2 in the given Metric.
distance(K, M, M, Metric) - Method in interface org.springframework.data.redis.core.ReactiveGeoOperations
Get the Distance between member1 and member2 in the given Metric.
distance(M, M) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
Get the Distance between member1 and member2.
distance(M, M, Metric) - Method in interface org.springframework.data.redis.core.BoundGeoOperations
Get the Distance between member1 and member2 in the given Metric.
distanceConverterForMetric(Metric) - Static method in class org.springframework.data.redis.connection.convert.Converters
Converter capable of converting Double into Distance using given Metric.
distinctRandomMembers(long) - Method in interface org.springframework.data.redis.core.BoundSetOperations
Get count distinct random elements from set at the bound key.
distinctRandomMembers(long) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
Get count distinct random elements from set at the bound key.
distinctRandomMembers(K, long) - Method in interface org.springframework.data.redis.core.ReactiveSetOperations
Get count distinct random elements from set at key.
distinctRandomMembers(K, long) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
Get count distinct random elements from set at key.
distinctRandomMembers(K, long) - Method in interface org.springframework.data.redis.core.SetOperations
Get count distinct random elements from set at key.
distinctRandomMembers(K, long) - Method in interface org.springframework.data.redis.core.ZSetOperations
Get count distinct random elements from set at key.
distinctRandomMembersWithScore(long) - Method in interface org.springframework.data.redis.core.BoundZSetOperations
Get count distinct random elements with their score from set at the bound key.
distinctRandomMembersWithScore(K, long) - Method in interface org.springframework.data.redis.core.ReactiveZSetOperations
Get count distinct random elements with their score from set at key.
distinctRandomMembersWithScore(K, long) - Method in interface org.springframework.data.redis.core.ZSetOperations
Get count distinct random elements with their score from set at key.
DO_NOT_CACHE_NULL_VALUES - Static variable in class org.springframework.data.redis.cache.RedisCacheConfiguration
 
DO_NOT_USE_PREFIX - Static variable in class org.springframework.data.redis.cache.RedisCacheConfiguration
 
doClose() - Method in class org.springframework.data.redis.connection.lettuce.LettuceSubscription
 
doClose() - Method in class org.springframework.data.redis.connection.util.AbstractSubscription
Shutdown the subscription and free any resources held.
doClose() - Method in class org.springframework.data.redis.core.ScanCursor
Customization hook for cleaning up resources on when calling ScanCursor.close().
doCreateConnectionProvider(AbstractRedisClient, RedisCodec<?, ?>) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
Create a LettuceConnectionProvider given AbstractRedisClient and RedisCodec.
doCreateLettuceClusterConnection(StatefulRedisClusterConnection<byte[], byte[]>, LettuceConnectionProvider, ClusterTopologyProvider, ClusterCommandExecutor, Duration) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
Customization hook for LettuceClusterConnection creation.
doCreateLettuceConnection(StatefulRedisConnection<byte[], byte[]>, LettuceConnectionProvider, long, int) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
Customization hook for LettuceConnection creation.
doCreateSubscription(MessageListener, StatefulRedisPubSubConnection<byte[], byte[]>, LettuceConnectionProvider) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
Customization hook to create a LettuceSubscription.
doGetAsyncDedicatedConnection() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
 
doGetConnection(RedisConnectionFactory, boolean, boolean, boolean) - Static method in class org.springframework.data.redis.core.RedisConnectionUtils
Actually obtain a RedisConnection from the given RedisConnectionFactory.
doHandleMessage(Message) - Method in class org.springframework.data.redis.listener.KeyExpirationEventMessageListener
 
doHandleMessage(Message) - Method in class org.springframework.data.redis.listener.KeyspaceEventMessageListener
Handle the actual message
doInCluster(T) - Method in interface org.springframework.data.redis.connection.ClusterCommandExecutor.ClusterCommandCallback
 
doInCluster(T, byte[]) - Method in interface org.springframework.data.redis.connection.ClusterCommandExecutor.MultiKeyClusterCommandCallback
 
doInit(Jedis) - Method in class org.springframework.data.redis.connection.jedis.JedisSentinelConnection
Do what ever is required to establish the connection to redis.
doInKeyValue(KeyValueAdapter) - Method in class org.springframework.data.redis.core.RedisKeyValueTemplate.RedisKeyValueCallback
 
doInRedis(ReactiveRedisConnection) - Method in interface org.springframework.data.redis.core.ReactiveRedisCallback
Gets called by ReactiveRedisTemplate.execute(ReactiveRedisCallback) with an active Redis connection.
doInRedis(RedisClusterConnection) - Method in interface org.springframework.data.redis.core.RedisClusterCallback
Gets called by ClusterOperations with an active Redis connection.
doInRedis(RedisConnection) - Method in interface org.springframework.data.redis.core.RedisCallback
Method called by RedisTemplate with an active RedisConnection.
doInRedis(RedisKeyValueAdapter) - Method in class org.springframework.data.redis.core.RedisKeyValueTemplate.RedisKeyValueCallback
 
doOpen(long) - Method in class org.springframework.data.redis.core.ScanCursor
Deprecated, for removal: This API element is subject to removal in a future version.
since 3.3.0, use ScanCursor.doOpen(CursorId) instead.
doOpen(Cursor.CursorId) - Method in class org.springframework.data.redis.core.ScanCursor
Customization hook when calling ScanCursor.open().
doPartialUpdate(PartialUpdate<?>) - Method in class org.springframework.data.redis.core.RedisKeyValueTemplate
 
doPsubscribe(byte[]...) - Method in class org.springframework.data.redis.connection.lettuce.LettuceSubscription
 
doPsubscribe(byte[]...) - Method in class org.springframework.data.redis.connection.util.AbstractSubscription
Subscribe to the given patterns
doPUnsubscribe(boolean, byte[]...) - Method in class org.springframework.data.redis.connection.lettuce.LettuceSubscription
 
doPUnsubscribe(boolean, byte[]...) - Method in class org.springframework.data.redis.connection.util.AbstractSubscription
Pattern unsubscribe.
doRegister(RedisMessageListenerContainer) - Method in class org.springframework.data.redis.listener.KeyExpirationEventMessageListener
 
doRegister(RedisMessageListenerContainer) - Method in class org.springframework.data.redis.listener.KeyspaceEventMessageListener
Register instance within the container.
doScan(byte[], Cursor.CursorId, ScanOptions) - Method in class org.springframework.data.redis.core.KeyBoundCursor
 
doScan(long, ScanOptions) - Method in class org.springframework.data.redis.core.KeyBoundCursor
 
doScan(long, ScanOptions) - Method in class org.springframework.data.redis.core.ScanCursor
Deprecated.
since 3.3.0, cursorId, can exceed Long.MAX_VALUE.
doScan(Cursor.CursorId, ScanOptions) - Method in class org.springframework.data.redis.core.KeyBoundCursor
 
doScan(Cursor.CursorId, ScanOptions) - Method in class org.springframework.data.redis.core.ScanCursor
Performs the actual scan command using the native client implementation.
doSubscribe(byte[]...) - Method in class org.springframework.data.redis.connection.lettuce.LettuceSubscription
 
doSubscribe(byte[]...) - Method in class org.springframework.data.redis.connection.util.AbstractSubscription
Subscribe to the given channels.
doubleValue() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicDouble
 
doubleValue() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicInteger
 
doubleValue() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicLong
 
doUnsubscribe(boolean, byte[]...) - Method in class org.springframework.data.redis.connection.lettuce.LettuceSubscription
 
doUnsubscribe(boolean, byte[]...) - Method in class org.springframework.data.redis.connection.util.AbstractSubscription
Channel unsubscribe.
doWithOperations(ReactiveRedisOperations<K, V>) - Method in interface org.springframework.data.redis.core.ReactiveRedisSessionCallback
Gets called by ReactiveRedisOperations.executeInSession(ReactiveRedisSessionCallback) with an active Redis connection.
DOWN_AFTER_MILLISECONDS - Enum constant in enum class org.springframework.data.redis.connection.RedisServer.INFO
 
drainTo(Collection<? super E>) - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
 
drainTo(Collection<? super E>, int) - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
 
dump(byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
Deprecated.
dump(byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
dump(byte[]) - Method in interface org.springframework.data.redis.connection.RedisKeyCommands
Retrieve serialized version of the value stored at key.
dump(K) - Method in interface org.springframework.data.redis.core.RedisOperations
Retrieve serialized version of the value stored at key.
dump(K) - Method in class org.springframework.data.redis.core.RedisTemplate
Executes the Redis dump command and returns the results.
DUMP - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
 
duration() - Method in record class org.springframework.data.redis.cache.FixedDurationTtlFunction
Returns the value of the duration record component.

E

echo(byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
echo(byte[]) - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
 
echo(byte[]) - Method in class org.springframework.data.redis.connection.jedis.JedisConnection
 
echo(byte[]) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
 
echo(byte[]) - Method in interface org.springframework.data.redis.connection.RedisConnectionCommands
Returns message via server roundtrip.
echo(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
echo(String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
Returns message via server roundtrip.
ECHO - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
 
element() - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
 
elementAt(long) - Static method in class org.springframework.data.redis.connection.ReactiveListCommands.LIndexCommand
Creates a new ReactiveListCommands.LIndexCommand given an index.
elementAt(long) - Static method in class org.springframework.data.redis.connection.ReactiveListCommands.LSetCommand
Creates a new ReactiveListCommands.LSetCommand given an index.
elements() - Method in class org.springframework.data.redis.support.collections.RedisProperties
 
empty() - Static method in class org.springframework.data.redis.connection.RedisClusterNode.SlotRange
Factory method used to construct a new, empty RedisClusterNode.SlotRange.
empty() - Static method in class org.springframework.data.redis.connection.RedisZSetCommands.ZAddArgs
 
empty() - Static method in class org.springframework.data.redis.connection.stream.StreamReadOptions
Creates an empty StreamReadOptions instance.
enableCreateOnMissingCache() - Method in class org.springframework.data.redis.cache.RedisCacheManager.RedisCacheManagerBuilder
Enables RedisCache creation at runtime for unconfigured, undeclared caches.
enableKeyspaceEvents() - Element in annotation interface org.springframework.data.redis.repository.configuration.EnableRedisRepositories
EnableRedisRepositories - Annotation Interface in org.springframework.data.redis.repository.configuration
Annotation to activate Redis repositories.
enableStatistics() - Method in class org.springframework.data.redis.cache.RedisCacheManager.RedisCacheManagerBuilder
Enables cache statistics.
enableTimeToIdle() - Method in class org.springframework.data.redis.cache.RedisCacheConfiguration
Enables time-to-idle (TTI) expiration on Cache read operations, such as Cache.get(Object).
encode(String) - Static method in class org.springframework.data.redis.connection.util.DecodeUtils
 
encodeMap(Map<String, byte[]>) - Static method in class org.springframework.data.redis.connection.util.DecodeUtils
 
ENCODING - Static variable in class org.springframework.data.redis.support.collections.AbstractRedisCollection
 
encodingOf(byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
Deprecated.
encodingOf(byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
encodingOf(byte[]) - Method in interface org.springframework.data.redis.connection.RedisKeyCommands
Get the type of internal representation used for storing the value at the given key.
encodingOf(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
encodingOf(String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
Get the type of internal representation used for storing the value at the given key.
encodingOf(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
Get the type of internal representation used for storing the value at the given key.
entries() - Method in interface org.springframework.data.redis.core.BoundHashOperations
Get entire hash at the bound key.
entries(H) - Method in interface org.springframework.data.redis.core.HashOperations
Get entire hash stored at key.
entries(H) - Method in interface org.springframework.data.redis.core.ReactiveHashOperations
Get entire hash stored at key.
entries(String) - Method in class org.springframework.data.redis.core.RedisKeyValueAdapter
 
entryIds(String...) - Static method in interface org.springframework.data.redis.connection.StringRedisConnection
 
entryOf(K, V) - Static method in class org.springframework.data.redis.connection.convert.Converters
Create an Map.Entry from key and value.
entrySet() - Method in class org.springframework.data.redis.core.convert.Bucket
A set view of the mappings contained in this bucket.
entrySet() - Method in class org.springframework.data.redis.support.collections.DefaultRedisMap
 
entrySet() - Method in class org.springframework.data.redis.support.collections.RedisProperties
 
entryTtl(Duration) - Method in class org.springframework.data.redis.cache.RedisCacheConfiguration
Set the ttl to apply for cache entries.
entryTtl(RedisCacheWriter.TtlFunction) - Method in class org.springframework.data.redis.cache.RedisCacheConfiguration
Set the TTL function to compute the time to live for cache entries.
equals(Object) - Method in record class org.springframework.data.redis.cache.FixedDurationTtlFunction
Indicates whether some other object is "equal to" this one.
equals(Object) - Method in class org.springframework.data.redis.connection.BitFieldSubCommands.AbstractBitFieldSubCommand
 
equals(Object) - Method in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldIncrBy
 
equals(Object) - Method in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldSet
 
equals(Object) - Method in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldType
 
equals(Object) - Method in class org.springframework.data.redis.connection.BitFieldSubCommands
 
equals(Object) - Method in class org.springframework.data.redis.connection.BitFieldSubCommands.Offset
 
equals(Object) - Method in class org.springframework.data.redis.connection.ClusterCommandExecutor.NodeResult
 
equals(Object) - Method in class org.springframework.data.redis.connection.DefaultStringTuple
 
equals(Object) - Method in class org.springframework.data.redis.connection.ReactiveRedisConnection.CommandResponse
 
equals(Object) - Method in class org.springframework.data.redis.connection.ReactiveSubscription.ChannelMessage
 
equals(Object) - Method in class org.springframework.data.redis.connection.ReactiveSubscription.PatternMessage
 
equals(Object) - Method in class org.springframework.data.redis.connection.RedisClusterConfiguration
 
equals(Object) - Method in class org.springframework.data.redis.connection.RedisNode
 
equals(Object) - Method in class org.springframework.data.redis.connection.RedisPassword
 
equals(Object) - Method in class org.springframework.data.redis.connection.RedisSentinelConfiguration
 
equals(Object) - Method in class org.springframework.data.redis.connection.RedisSocketConfiguration
 
equals(Object) - Method in class org.springframework.data.redis.connection.RedisStandaloneConfiguration
 
equals(Object) - Method in class org.springframework.data.redis.connection.RedisStaticMasterReplicaConfiguration
 
equals(Object) - Method in class org.springframework.data.redis.connection.RedisStreamCommands.XAddOptions
 
equals(Object) - Method in class org.springframework.data.redis.connection.RedisZSetCommands.ZAddArgs
 
equals(Object) - Method in class org.springframework.data.redis.connection.stream.Consumer
 
equals(Object) - Method in class org.springframework.data.redis.connection.stream.ReadOffset
 
equals(Object) - Method in class org.springframework.data.redis.connection.stream.RecordId
 
equals(Object) - Method in class org.springframework.data.redis.connection.stream.StreamOffset
 
equals(Object) - Method in class org.springframework.data.redis.connection.stream.StreamReadOptions
 
equals(Object) - Method in class org.springframework.data.redis.connection.util.ByteArrayWrapper
 
equals(Object) - Method in class org.springframework.data.redis.connection.zset.DefaultTuple
 
equals(Object) - Method in class org.springframework.data.redis.connection.zset.Weights
 
equals(Object) - Method in class org.springframework.data.redis.core.convert.GeoIndexedPropertyValue
 
equals(Object) - Method in class org.springframework.data.redis.core.convert.SimpleIndexedPropertyValue
 
equals(Object) - Method in class org.springframework.data.redis.core.Cursor.CursorId
 
equals(Object) - Method in class org.springframework.data.redis.core.DefaultTypedTuple
 
equals(Object) - Method in class org.springframework.data.redis.core.index.IndexDefinition.IndexingContext
 
equals(Object) - Method in class org.springframework.data.redis.core.index.RedisIndexDefinition
 
equals(Object) - Method in class org.springframework.data.redis.core.index.SpelIndexDefinition
 
equals(Object) - Method in class org.springframework.data.redis.core.types.Expiration
 
equals(Object) - Method in class org.springframework.data.redis.core.types.RedisClientInfo
 
equals(Object) - Method in class org.springframework.data.redis.domain.geo.BoundingBox
 
equals(Object) - Method in class org.springframework.data.redis.domain.geo.GeoLocation
 
equals(Object) - Method in class org.springframework.data.redis.domain.geo.GeoReference.GeoCoordinateReference
 
equals(Object) - Method in class org.springframework.data.redis.domain.geo.GeoReference.GeoMemberReference
 
equals(Object) - Method in class org.springframework.data.redis.listener.ChannelTopic
 
equals(Object) - Method in class org.springframework.data.redis.repository.query.RedisOperationChain.PathAndValue
 
equals(Object) - Method in class org.springframework.data.redis.support.collections.AbstractRedisCollection
 
equals(Object) - Method in class org.springframework.data.redis.support.collections.DefaultRedisMap
 
equals(Object) - Method in class org.springframework.data.redis.support.collections.RedisProperties
 
errorHandler(ErrorHandler) - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.ConsumerStreamReadRequestBuilder
errorHandler(ErrorHandler) - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamMessageListenerContainerOptionsBuilder
Configure a ErrorHandler to be notified on errors.
errorHandler(ErrorHandler) - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamReadRequestBuilder
Configure a ErrorHandler to be notified on errors.
eval(byte[], ReturnType, int, byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
eval(byte[], ReturnType, int, byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
eval(byte[], ReturnType, int, byte[]...) - Method in interface org.springframework.data.redis.connection.RedisScriptingCommands
Evaluate given script.
eval(String, ReturnType, int, String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
NOTE: This method will not deserialize Strings returned by Lua scripts, as they may not be encoded with the same serializer used here.
eval(String, ReturnType, int, String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
Evaluate given script.
eval(ByteBuffer, ReturnType, int, ByteBuffer...) - Method in interface org.springframework.data.redis.connection.ReactiveScriptingCommands
Evaluate given script.
eval(ReactiveRedisConnection, RedisScript<T>, ReturnType, int, ByteBuffer[], RedisElementReader<T>) - Method in class org.springframework.data.redis.core.script.DefaultReactiveScriptExecutor
 
eval(RedisConnection, RedisScript<T>, ReturnType, int, byte[][], RedisSerializer<T>) - Method in class org.springframework.data.redis.core.script.DefaultScriptExecutor
 
EVAL - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
 
evalSha(byte[], ReturnType, int, byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
evalSha(byte[], ReturnType, int, byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
evalSha(byte[], ReturnType, int, byte[]...) - Method in interface org.springframework.data.redis.connection.RedisScriptingCommands
Evaluate given scriptSha.
evalSha(String, ReturnType, int, byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
evalSha(String, ReturnType, int, byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
evalSha(String, ReturnType, int, byte[]...) - Method in interface org.springframework.data.redis.connection.RedisScriptingCommands
Evaluate given scriptSha.
evalSha(String, ReturnType, int, String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
NOTE: This method will not deserialize Strings returned by Lua scripts, as they may not be encoded with the same serializer used here.
evalSha(String, ReturnType, int, String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
Evaluate given scriptSha.
evalSha(String, ReturnType, int, ByteBuffer...) - Method in interface org.springframework.data.redis.connection.ReactiveScriptingCommands
Evaluate given scriptSha.
EVALSHA - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
 
EVENTS - Enum constant in enum class org.springframework.data.redis.core.types.RedisClientInfo.INFO
 
evict(Object) - Method in class org.springframework.data.redis.cache.RedisCache
 
ExampleQueryMapper - Class in org.springframework.data.redis.repository.query
Mapper for Query-by-Example examples to an actual query.
ExampleQueryMapper(MappingContext<RedisPersistentEntity<?>, RedisPersistentProperty>, IndexResolver) - Constructor for class org.springframework.data.redis.repository.query.ExampleQueryMapper
ExceptionTranslationStrategy - Interface in org.springframework.data.redis
Potentially translates an Exception into appropriate DataAccessException.
excludeFilters() - Element in annotation interface org.springframework.data.redis.repository.configuration.EnableRedisRepositories
Specifies which types are not eligible for component scanning.
exec() - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
exec() - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
 
exec() - Method in class org.springframework.data.redis.connection.jedis.JedisConnection
 
exec() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
 
exec() - Method in interface org.springframework.data.redis.connection.RedisTxCommands
Executes all queued commands in a transaction started with RedisTxCommands.multi().
exec() - Method in interface org.springframework.data.redis.core.RedisOperations
Executes all queued commands in a transaction started with RedisOperations.multi().
exec() - Method in class org.springframework.data.redis.core.RedisTemplate
Execute a transaction, using the default RedisSerializers to deserialize any results that are byte[]s or Collections or Maps of byte[]s or Tuples.
exec(RedisSerializer<?>) - Method in interface org.springframework.data.redis.core.RedisOperations
Execute a transaction, using the provided RedisSerializer to deserialize any results that are byte[]s or Collections of byte[]s.
exec(RedisSerializer<?>) - Method in class org.springframework.data.redis.core.RedisTemplate
 
EXEC - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
 
execRaw() - Method in class org.springframework.data.redis.core.RedisTemplate
 
execute(Object[]) - Method in class org.springframework.data.redis.repository.query.RedisPartTreeQuery
 
execute(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
execute(String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
'Native' or 'raw' execution of the given command along-side the given arguments.
execute(String, byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
execute(String, byte[]...) - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
 
execute(String, byte[]...) - Method in class org.springframework.data.redis.connection.jedis.JedisConnection
 
execute(String, byte[]...) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
 
execute(String, byte[]...) - Method in interface org.springframework.data.redis.connection.RedisCommands
Native or raw execution of the given Redis command along with the given arguments.
execute(String, byte[], Collection<byte[]>) - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
 
execute(String, byte[], Collection<byte[]>) - Method in interface org.springframework.data.redis.connection.RedisClusterConnection
Execute the given command for the key provided potentially appending args.
execute(String, CommandOutput, byte[]...) - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
'Native' or 'raw' execution of the given command along-side the given arguments.
execute(String, String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
execute(String, String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
'Native' or 'raw' execution of the given command along-side the given arguments.
execute(String, Collection<byte[]>, Collection<byte[]>) - Method in class org.springframework.data.redis.connection.jedis.JedisClusterConnection
Execute the given command for each key in keys provided appending all args on each invocation.
execute(ReactiveRedisCallback<T>) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
Executes the given action within a Redis connection.
execute(ReactiveRedisCallback<T>) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
 
execute(ReactiveRedisCallback<T>, boolean) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
Executes the given action object within a connection that can be exposed or not.
execute(RedisCallback<T>) - Method in class org.springframework.data.redis.core.RedisKeyValueAdapter
Execute RedisCallback via underlying RedisOperations.
execute(RedisCallback<T>) - Method in interface org.springframework.data.redis.core.RedisOperations
Executes the given action within a Redis connection.
execute(RedisCallback<T>) - Method in class org.springframework.data.redis.core.RedisTemplate
 
execute(RedisCallback<T>, boolean) - Method in class org.springframework.data.redis.core.RedisTemplate
Executes the given action object within a connection, which can be exposed or not.
execute(RedisCallback<T>, boolean, boolean) - Method in class org.springframework.data.redis.core.RedisTemplate
Executes the given action object within a connection that can be exposed or not.
execute(RedisOperations<K, V>) - Method in interface org.springframework.data.redis.core.SessionCallback
Executes all the given operations inside the same session.
execute(RedisScript<T>) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
Executes the given RedisScript.
execute(RedisScript<T>) - Method in interface org.springframework.data.redis.core.script.ReactiveScriptExecutor
Execute the given RedisScript
execute(RedisScript<T>, List<K>) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
Executes the given RedisScript.
execute(RedisScript<T>, List<K>) - Method in interface org.springframework.data.redis.core.script.ReactiveScriptExecutor
Execute the given RedisScript
execute(RedisScript<T>, List<K>, Object...) - Method in interface org.springframework.data.redis.core.RedisOperations
Executes the given RedisScript
execute(RedisScript<T>, List<K>, Object...) - Method in class org.springframework.data.redis.core.RedisTemplate
 
execute(RedisScript<T>, List<K>, Object...) - Method in class org.springframework.data.redis.core.script.DefaultScriptExecutor
 
execute(RedisScript<T>, List<K>, Object...) - Method in interface org.springframework.data.redis.core.script.ScriptExecutor
Executes the given RedisScript
execute(RedisScript<T>, List<K>, List<?>) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
Executes the given RedisScript
execute(RedisScript<T>, List<K>, List<?>) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
 
execute(RedisScript<T>, List<K>, List<?>) - Method in class org.springframework.data.redis.core.script.DefaultReactiveScriptExecutor
 
execute(RedisScript<T>, List<K>, List<?>) - Method in interface org.springframework.data.redis.core.script.ReactiveScriptExecutor
Executes the given RedisScript
execute(RedisScript<T>, List<K>, List<?>, RedisElementWriter<?>, RedisElementReader<T>) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
Executes the given RedisScript, using the provided RedisSerializers to serialize the script arguments and result.
execute(RedisScript<T>, List<K>, List<?>, RedisElementWriter<?>, RedisElementReader<T>) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
 
execute(RedisScript<T>, List<K>, List<?>, RedisElementWriter<?>, RedisElementReader<T>) - Method in class org.springframework.data.redis.core.script.DefaultReactiveScriptExecutor
 
execute(RedisScript<T>, List<K>, List<?>, RedisElementWriter<?>, RedisElementReader<T>) - Method in interface org.springframework.data.redis.core.script.ReactiveScriptExecutor
Executes the given RedisScript, using the provided RedisSerializers to serialize the script arguments and result.
execute(RedisScript<T>, RedisSerializer<?>, RedisSerializer<T>, List<K>, Object...) - Method in interface org.springframework.data.redis.core.RedisOperations
Executes the given RedisScript, using the provided RedisSerializers to serialize the script arguments and result.
execute(RedisScript<T>, RedisSerializer<?>, RedisSerializer<T>, List<K>, Object...) - Method in class org.springframework.data.redis.core.RedisTemplate
 
execute(RedisScript<T>, RedisSerializer<?>, RedisSerializer<T>, List<K>, Object...) - Method in class org.springframework.data.redis.core.script.DefaultScriptExecutor
 
execute(RedisScript<T>, RedisSerializer<?>, RedisSerializer<T>, List<K>, Object...) - Method in interface org.springframework.data.redis.core.script.ScriptExecutor
Executes the given RedisScript, using the provided RedisSerializers to serialize the script arguments and result.
execute(SessionCallback<T>) - Method in interface org.springframework.data.redis.core.RedisOperations
Executes a Redis session.
execute(SessionCallback<T>) - Method in class org.springframework.data.redis.core.RedisTemplate
 
executeCommandAsyncOnNodes(ClusterCommandExecutor.ClusterCommandCallback<S, T>, Iterable<RedisClusterNode>) - Method in class org.springframework.data.redis.connection.ClusterCommandExecutor
 
executeCommandOnAllNodes(ClusterCommandExecutor.ClusterCommandCallback<S, T>) - Method in class org.springframework.data.redis.connection.ClusterCommandExecutor
Run ClusterCommandExecutor.ClusterCommandCallback on all reachable master nodes.
executeCommandOnArbitraryNode(ClusterCommandExecutor.ClusterCommandCallback<?, T>) - Method in class org.springframework.data.redis.connection.ClusterCommandExecutor
executeCommandOnSingleNode(ClusterCommandExecutor.ClusterCommandCallback<S, T>, RedisClusterNode) - Method in class org.springframework.data.redis.connection.ClusterCommandExecutor
executeInSession(ReactiveRedisSessionCallback<K, V, T>) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
Executes the given action within a Redis session using the same ReactiveRedisConnection.
executeInSession(ReactiveRedisSessionCallback<K, V, T>) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
 
executeMultiKeyCommand(ClusterCommandExecutor.MultiKeyClusterCommandCallback<S, T>, Iterable<byte[]>) - Method in class org.springframework.data.redis.connection.ClusterCommandExecutor
Run ClusterCommandExecutor.MultiKeyClusterCommandCallback with on a curated set of nodes serving one or more keys.
executePipelined(RedisCallback<?>) - Method in interface org.springframework.data.redis.core.RedisOperations
Executes the given action object on a pipelined connection, returning the results.
executePipelined(RedisCallback<?>) - Method in class org.springframework.data.redis.core.RedisTemplate
 
executePipelined(RedisCallback<?>, RedisSerializer<?>) - Method in interface org.springframework.data.redis.core.RedisOperations
Executes the given action object on a pipelined connection, returning the results using a dedicated serializer.
executePipelined(RedisCallback<?>, RedisSerializer<?>) - Method in class org.springframework.data.redis.core.RedisTemplate
 
executePipelined(SessionCallback<?>) - Method in interface org.springframework.data.redis.core.RedisOperations
Executes the given Redis session on a pipelined connection.
executePipelined(SessionCallback<?>) - Method in class org.springframework.data.redis.core.RedisTemplate
 
executePipelined(SessionCallback<?>, RedisSerializer<?>) - Method in interface org.springframework.data.redis.core.RedisOperations
Executes the given Redis session on a pipelined connection, returning the results using a dedicated serializer.
executePipelined(SessionCallback<?>, RedisSerializer<?>) - Method in class org.springframework.data.redis.core.RedisTemplate
 
executeWithStickyConnection(RedisCallback<T>) - Method in interface org.springframework.data.redis.core.RedisOperations
Allocates and binds a new RedisConnection to the actual return type of the method.
executeWithStickyConnection(RedisCallback<T>) - Method in class org.springframework.data.redis.core.RedisTemplate
 
executor(Executor) - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamMessageListenerContainerOptionsBuilder
Configure a Executor to run stream polling Tasks.
exists(byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
Deprecated.
exists(byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
exists(byte[]) - Method in interface org.springframework.data.redis.connection.RedisKeyCommands
Determine if given key exists.
exists(byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
Deprecated.
exists(byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
exists(byte[]...) - Method in interface org.springframework.data.redis.connection.RedisKeyCommands
Count how many of the given keys exist.
exists(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
exists(String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
Determine if given key exists.
exists(String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
exists(String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
Count how many of the given keys exist.
exists(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
Determine if given key exists.
exists(Publisher<ReactiveRedisConnection.KeyCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
Determine if given key exists.
exists(Example<S>) - Method in class org.springframework.data.redis.repository.support.QueryByExampleRedisExecutor
 
EXISTS - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
 
Expiration - Class in org.springframework.data.redis.core.types
Expiration holds a numeric value with an associated TimeUnit.
Expiration(long, TimeUnit) - Constructor for class org.springframework.data.redis.core.types.Expiration
Creates new Expiration.
expire(byte[], long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
Deprecated.
expire(byte[], long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
expire(byte[], long) - Method in interface org.springframework.data.redis.connection.RedisKeyCommands
Set time to live for given key in seconds.
expire(long, TimeUnit) - Method in interface org.springframework.data.redis.core.BoundKeyOperations
Sets the key time-to-live/expiration.
expire(long, TimeUnit) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicDouble
 
expire(long, TimeUnit) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicInteger
 
expire(long, TimeUnit) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicLong
 
expire(long, TimeUnit) - Method in class org.springframework.data.redis.support.collections.AbstractRedisCollection
 
expire(long, TimeUnit) - Method in class org.springframework.data.redis.support.collections.DefaultRedisMap
 
expire(long, TimeUnit) - Method in class org.springframework.data.redis.support.collections.RedisProperties
 
expire(String, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
expire(String, long) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
Set time to live for given key in seconds.
expire(ByteBuffer, Duration) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
Set time to live for given key in seconds.
expire(Duration) - Method in interface org.springframework.data.redis.core.BoundKeyOperations
Sets the key time-to-live/expiration.
expire(K, long, TimeUnit) - Method in interface org.springframework.data.redis.core.RedisOperations
Set time to live for given key.
expire(K, long, TimeUnit) - Method in class org.springframework.data.redis.core.RedisTemplate
 
expire(K, Duration) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
Set time to live for given key.
expire(K, Duration) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
 
expire(K, Duration) - Method in interface org.springframework.data.redis.core.RedisOperations
Set time to live for given key.
expire(Publisher<ReactiveKeyCommands.ExpireCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
Expire keys one by one.
EXPIRE - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
 
expireAt(byte[], long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
Deprecated.
expireAt(byte[], long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
expireAt(byte[], long) - Method in interface org.springframework.data.redis.connection.RedisKeyCommands
Set the expiration for given key as a UNIX timestamp.
expireAt(String, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
expireAt(String, long) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
Set the expiration for given key as a UNIX timestamp.
expireAt(ByteBuffer, Instant) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
Set the expiration for given key as a UNIX timestamp.
expireAt(Instant) - Method in interface org.springframework.data.redis.core.BoundKeyOperations
Sets the key time-to-live/expiration.
expireAt(Date) - Method in interface org.springframework.data.redis.core.BoundKeyOperations
Sets the key time-to-live/expiration.
expireAt(Date) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicDouble
 
expireAt(Date) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicInteger
 
expireAt(Date) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicLong
 
expireAt(Date) - Method in class org.springframework.data.redis.support.collections.AbstractRedisCollection
 
expireAt(Date) - Method in class org.springframework.data.redis.support.collections.DefaultRedisMap
 
expireAt(Date) - Method in class org.springframework.data.redis.support.collections.RedisProperties
 
expireAt(K, Instant) - Method in interface org.springframework.data.redis.core.ReactiveRedisOperations
Set the expiration for given key as a expireAt timestamp.
expireAt(K, Instant) - Method in class org.springframework.data.redis.core.ReactiveRedisTemplate
 
expireAt(K, Instant) - Method in interface org.springframework.data.redis.core.RedisOperations
Set the expiration for given key as a date timestamp.
expireAt(K, Date) - Method in interface org.springframework.data.redis.core.RedisOperations
Set the expiration for given key as a date timestamp.
expireAt(K, Date) - Method in class org.springframework.data.redis.core.RedisTemplate
 
expireAt(Publisher<ReactiveKeyCommands.ExpireAtCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveKeyCommands
Set one-by-one the expiration for given key as a UNIX timestamp.
EXPIREAT - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
 
expiring(Expiration) - Method in class org.springframework.data.redis.connection.ReactiveStringCommands.SetCommand
Applies Expiration.
extract(String) - Method in class org.springframework.data.redis.core.convert.Bucket
Extracts a bucket containing key/value pairs with the prefix.
extractAllKeysFor(String) - Method in class org.springframework.data.redis.core.convert.Bucket
Get all the keys matching a given path.
extractBytes(ByteBuffer) - Static method in class org.springframework.data.redis.util.ByteUtils
Deprecated.
Since 3.2. Use ByteUtils.getBytes(ByteBuffer) instead.
extractMessage(Message) - Method in class org.springframework.data.redis.listener.adapter.MessageListenerAdapter
Extract the message body from the given Redis message.

F

FAIL - Enum constant in enum class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldIncrBy.Overflow
 
FAIL - Enum constant in enum class org.springframework.data.redis.connection.RedisClusterNode.Flag
 
failover(NamedNode) - Method in class org.springframework.data.redis.connection.jedis.JedisSentinelConnection
 
failover(NamedNode) - Method in class org.springframework.data.redis.connection.lettuce.LettuceSentinelConnection
 
failover(NamedNode) - Method in interface org.springframework.data.redis.connection.RedisSentinelCommands
Force a failover as if the master was not reachable.
FAILOVER_TIMEOUT - Enum constant in enum class org.springframework.data.redis.connection.RedisServer.INFO
 
failsafeCommandLookup(String) - Static method in enum class org.springframework.data.redis.core.RedisCommand
Returns the command represented by the given key, otherwise returns RedisCommand.UNKNOWN if no matching command could be found.
FallbackExceptionTranslationStrategy - Class in org.springframework.data.redis
FallbackExceptionTranslationStrategy(Converter<Exception, DataAccessException>) - Constructor for class org.springframework.data.redis.FallbackExceptionTranslationStrategy
 
feet() - Static method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoDistCommand
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
field(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveHashCommands.HExistsCommand
field(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveHashCommands.HGetCommand
fields(Collection<ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveHashCommands.HDelCommand
Creates a new ReactiveHashCommands.HDelCommand given a Collection of field names.
fields(Collection<ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveHashCommands.HGetCommand
Creates a new ReactiveHashCommands.HGetCommand given a Collection of field names.
fieldValues(Map<ByteBuffer, ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveHashCommands.HSetCommand
Creates a new ReactiveHashCommands.HSetCommand given a Map of field values.
FILE_DESCRIPTOR - Enum constant in enum class org.springframework.data.redis.core.types.RedisClientInfo.INFO
 
find(RedisCallback<?>, Class<T>) - Method in class org.springframework.data.redis.core.RedisKeyValueTemplate
Retrieve entities by resolving their ids and converting them into required type.
findAll(Example<S>) - Method in class org.springframework.data.redis.repository.support.QueryByExampleRedisExecutor
 
findAll(Example<S>, Pageable) - Method in class org.springframework.data.redis.repository.support.QueryByExampleRedisExecutor
 
findAll(Example<S>, Sort) - Method in class org.springframework.data.redis.repository.support.QueryByExampleRedisExecutor
 
findBy(Example<S>, Function<FluentQuery.FetchableFluentQuery<S>, R>) - Method in class org.springframework.data.redis.repository.support.QueryByExampleRedisExecutor
 
findOne(Example<S>) - Method in class org.springframework.data.redis.repository.support.QueryByExampleRedisExecutor
 
first() - Static method in enum class org.springframework.data.redis.connection.ReactiveListCommands.Direction
first() - Static method in enum class org.springframework.data.redis.connection.RedisListCommands.Direction
first() - Method in class org.springframework.data.redis.support.collections.DefaultRedisZSet
 
first() - Method in interface org.springframework.data.redis.support.collections.RedisZSet
Returns the first (lowest) element currently in this sorted set.
first(long) - Static method in class org.springframework.data.redis.connection.ReactiveListCommands.LRemCommand
Creates a new ReactiveListCommands.LRemCommand to first count values.
firstEntryId() - Method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoStream
The id of the streams first entry.
FixedDurationTtlFunction - Record Class in org.springframework.data.redis.cache
RedisCacheWriter.TtlFunction implementation returning the given, predetermined Duration used for per cache entry time-to-live (TTL) expiration.
FixedDurationTtlFunction(Duration) - Constructor for record class org.springframework.data.redis.cache.FixedDurationTtlFunction
Creates an instance of a FixedDurationTtlFunction record class.
flags - Variable in class org.springframework.data.redis.connection.RedisGeoCommands.GeoSearchCommandArgs
 
FLAGS - Enum constant in enum class org.springframework.data.redis.connection.RedisServer.INFO
 
FLAGS - Enum constant in enum class org.springframework.data.redis.core.types.RedisClientInfo.INFO
 
floatValue() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicDouble
 
floatValue() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicInteger
 
floatValue() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicLong
 
flushAll() - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
Deprecated.
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.
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.
flushAll(RedisClusterNode, RedisServerCommands.FlushOption) - Method in interface org.springframework.data.redis.connection.ReactiveClusterServerCommands
Delete all all keys from all databases using the specified RedisServerCommands.FlushOption.
flushAll(RedisClusterNode, RedisServerCommands.FlushOption) - Method in interface org.springframework.data.redis.connection.RedisClusterServerCommands
 
flushAll(RedisServerCommands.FlushOption) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
Deprecated.
flushAll(RedisServerCommands.FlushOption) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
flushAll(RedisServerCommands.FlushOption) - Method in interface org.springframework.data.redis.connection.ReactiveServerCommands
Delete all all keys from all databases using the specified RedisServerCommands.FlushOption.
flushAll(RedisServerCommands.FlushOption) - Method in interface org.springframework.data.redis.connection.RedisServerCommands
Delete all all keys from all databases using the specified RedisServerCommands.FlushOption.
FLUSHALL - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
 
flushDb() - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
Deprecated.
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.
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.
flushDb(RedisClusterNode, RedisServerCommands.FlushOption) - Method in interface org.springframework.data.redis.connection.ReactiveClusterServerCommands
Delete all keys of the currently selected database using the specified RedisServerCommands.FlushOption.
flushDb(RedisClusterNode, RedisServerCommands.FlushOption) - Method in interface org.springframework.data.redis.connection.RedisClusterServerCommands
 
flushDb(RedisClusterNode, RedisServerCommands.FlushOption) - Method in interface org.springframework.data.redis.core.ClusterOperations
Flush db on node using the specified RedisServerCommands.FlushOption.
flushDb(RedisServerCommands.FlushOption) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
Deprecated.
flushDb(RedisServerCommands.FlushOption) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
flushDb(RedisServerCommands.FlushOption) - Method in interface org.springframework.data.redis.connection.ReactiveServerCommands
Delete all keys of the currently selected database using the specified RedisServerCommands.FlushOption.
flushDb(RedisServerCommands.FlushOption) - Method in interface org.springframework.data.redis.connection.RedisServerCommands
Delete all keys of the currently selected database using the specified RedisServerCommands.FlushOption.
FLUSHDB - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
 
flushEachCommand() - Static method in interface org.springframework.data.redis.connection.lettuce.LettuceConnection.PipeliningFlushPolicy
Return a policy to flush after each command (default behavior).
flushOnClose() - Static method in interface org.springframework.data.redis.connection.lettuce.LettuceConnection.PipeliningFlushPolicy
Return a policy to flush only if LettuceConnection.closePipeline() is called.
force() - Method in class org.springframework.data.redis.connection.RedisStreamCommands.XClaimOptions
Forces creation of a pending message entry in the PEL even if it does not already exist as long a the given stream record id is valid.
forEach(Consumer<? super StreamInfo.XInfoConsumer>) - Method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoConsumers
Performs the given action on every available StreamInfo.XInfoConsumer of this StreamInfo.XInfoConsumers.
forEach(Consumer<? super StreamInfo.XInfoGroup>) - Method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoGroups
Performs the given action on every available StreamInfo.XInfoGroup of this StreamInfo.XInfoGroups.
forget(RedisClusterNode) - Method in interface org.springframework.data.redis.core.ClusterOperations
Remove the node from the cluster.
forKey(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoDistCommand
Applies the Geo set key member.
forKey(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusByMemberCommand
Applies the Geo set key.
forKey(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusCommand
Applies the Geo set key.
forKey(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveHashCommands.HSetCommand
Applies the key.
forKey(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveListCommands.LInsertCommand
Applies the key.
forKey(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveListCommands.LSetCommand
Applies the key.
forKey(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveNumberCommands.HIncrByCommand
Applies the key.
forKey(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZCountCommand
Applies the key.
forKey(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZLexCountCommand
Applies the key.
forKey(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZMScoreCommand
Applies the key.
forKey(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZScoreCommand
Applies the key.
forRecords(String...) - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.AcknowledgeCommand
Applies the recordIds.
forRecords(RecordId...) - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.AcknowledgeCommand
Applies the recordIds.
forStream(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.GroupCommand
 
forType(BitFieldSubCommands.BitFieldType) - Method in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldGetBuilder
 
forType(BitFieldSubCommands.BitFieldType) - Method in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldIncrByBuilder
 
forType(BitFieldSubCommands.BitFieldType) - Method in class org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldSetBuilder
 
from(long, TimeUnit) - Static method in class org.springframework.data.redis.core.types.Expiration
Creates new Expiration with the provided TimeUnit.
from(String) - Static method in class org.springframework.data.redis.connection.stream.ReadOffset
Read all arriving elements from the stream starting at offset.
from(String, String) - Static method in class org.springframework.data.redis.connection.stream.Consumer
Create a new consumer.
from(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusByMemberCommand
Sets the member.
from(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveHashCommands.HDelCommand
Applies the hash key.
from(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveHashCommands.HGetCommand
Applies the hash key.
from(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveHashCommands.HStrLenCommand
Define the key the hash is stored at.
from(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveListCommands.BRPopLPushCommand
Creates a new ReactiveListCommands.BRPopLPushCommand given a sourceKey.
from(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveListCommands.LIndexCommand
Applies the key.
from(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveListCommands.LPosCommand
Applies the key.
from(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveListCommands.LRemCommand
Applies the key.
from(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveListCommands.PopCommand
Applies the key.
from(ByteBuffer) - Static method in class org.springframework.data.redis.connection.ReactiveListCommands.RPopLPushCommand
Creates a new ReactiveListCommands.RPopLPushCommand given a sourceKey.
from(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveSetCommands.SMoveCommand
Applies the source key.
from(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveSetCommands.SPopCommand
Applies the key.
from(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveSetCommands.SRandMembersCommand
Applies the key.
from(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveSetCommands.SRemCommand
Applies the key.
from(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.BZPopCommand
Applies the key.
from(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZPopCommand
Applies the key.
from(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRandMemberCommand
Applies the key.
from(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRangeByLexCommand
Applies the key.
from(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRangeByScoreCommand
Applies the key.
from(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRangeCommand
Applies the key.
from(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRangeStoreCommand
Applies the key.
from(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRemCommand
Applies the key.
from(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRemRangeByLexCommand
Applies the key.
from(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRemRangeByRankCommand
Applies the key.
from(ByteBuffer) - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZRemRangeByScoreCommand
Applies the key.
from(ByteBuffer, ReactiveListCommands.Direction) - Static method in class org.springframework.data.redis.connection.ReactiveListCommands.LMoveCommand
from(Duration) - Static method in class org.springframework.data.redis.core.types.Expiration
Creates a new Expiration with the given, required Duration.
from(List<ByteBuffer>) - Method in class org.springframework.data.redis.connection.ReactiveListCommands.BPopCommand
Applies the value.
from(Point) - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusCommand
Sets the center Point.
from(Record<K, ?>) - Static method in class org.springframework.data.redis.connection.stream.StreamOffset
Create a StreamOffset from the given record id as reference to create the ReadOffset.from(String).
from(RecordId) - Static method in class org.springframework.data.redis.connection.stream.ReadOffset
Read all arriving elements from the stream starting at RecordId.
from(StreamOffset<ByteBuffer>) - Static method in class org.springframework.data.redis.connection.ReactiveStreamCommands.ReadCommand
from(StreamOffset<ByteBuffer>...) - Static method in class org.springframework.data.redis.connection.ReactiveStreamCommands.ReadCommand
from(Bucket) - Static method in class org.springframework.data.redis.core.convert.Bucket.BucketPropertyPath
Creates a top-level Bucket.BucketPropertyPath given Bucket.
from(Bucket, String) - Static method in class org.springframework.data.redis.core.convert.Bucket.BucketPropertyPath
Creates a Bucket.BucketPropertyPath given Bucket and prefix.
from(RedisSerializer<T>) - Static method in interface org.springframework.data.redis.serializer.RedisElementReader
Create new RedisElementReader using given RedisSerializer.
from(RedisSerializer<T>) - Static method in interface org.springframework.data.redis.serializer.RedisElementWriter
Create new RedisElementWriter using given RedisSerializer.
fromBytes(byte[], Class<T>) - Method in class org.springframework.data.redis.core.convert.MappingRedisConverter
Convert given binary representation to desired target type using the underlying ConversionService.
fromCacheWriter(RedisCacheWriter) - Static method in class org.springframework.data.redis.cache.RedisCacheManager.RedisCacheManagerBuilder
Factory method returning a new Builder used to create and configure a RedisCacheManager using the given RedisCacheWriter.
fromCircle(Circle) - Static method in interface org.springframework.data.redis.domain.geo.GeoReference
fromCode(String) - Static method in enum class org.springframework.data.redis.connection.DataType
Utility method for converting an enum code to an actual enum.
fromConnectionFactory(RedisConnectionFactory) - Static method in class org.springframework.data.redis.cache.RedisCacheManager.RedisCacheManagerBuilder
Factory method returning a new Builder used to create and configure a RedisCacheManager using the given RedisConnectionFactory.
fromCoordinate(double, double) - Static method in interface org.springframework.data.redis.domain.geo.GeoReference
Creates a GeoReference from a WGS84 longitude/latitude coordinate.
fromCoordinate(Point) - Static method in interface org.springframework.data.redis.domain.geo.GeoReference
Creates a GeoReference from a WGS84 longitude/latitude coordinate.
fromCoordinate(RedisGeoCommands.GeoLocation<?>) - Static method in interface org.springframework.data.redis.domain.geo.GeoReference
Creates a GeoReference from a WGS84 longitude/latitude coordinate.
fromGroup(String) - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.GroupCommand
 
fromHash(Map) - Method in class org.springframework.data.redis.hash.DecoratingStringHashMapper
 
fromHash(Map<byte[], byte[]>) - Method in class org.springframework.data.redis.hash.ObjectHashMapper
 
fromHash(Map<byte[], byte[]>, Class<T>) - Method in class org.springframework.data.redis.hash.ObjectHashMapper
Convert a hash (map) to an object and return the casted result.
fromHash(Map<String, Object>) - Method in class org.springframework.data.redis.hash.Jackson2HashMapper
 
fromHash(Map<String, String>) - Method in class org.springframework.data.redis.hash.BeanUtilsHashMapper
 
fromHash(Map<K, V>) - Method in interface org.springframework.data.redis.hash.HashMapper
Convert a hash (map) to an object.
fromHead(K) - Static method in class org.springframework.data.redis.core.ListOperations.MoveFrom
 
fromIndex(long) - Method in class org.springframework.data.redis.connection.ReactiveRedisConnection.RangeCommand
Applies a lower bound to the Range.
fromJavaType(Class<?>) - Static method in enum class org.springframework.data.redis.connection.ReturnType
 
fromList(String, List<Object>) - Static method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoConsumers
 
fromList(List<Object>) - Static method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoGroup
 
fromList(List<Object>) - Static method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoGroups
Factory method to create a new instance of StreamInfo.XInfoGroups.
fromList(List<Object>) - Static method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoStream
Factory method to create a new instance of StreamInfo.XInfoStream.
fromMember(RedisGeoCommands.GeoLocation<T>) - Static method in interface org.springframework.data.redis.domain.geo.GeoReference
Creates a GeoReference from a geoset member.
fromMember(T) - Static method in interface org.springframework.data.redis.domain.geo.GeoReference
Creates a GeoReference from a geoset member.
fromSerializer(RedisSerializer<T>) - Static method in interface org.springframework.data.redis.serializer.RedisSerializationContext
Creates a new RedisSerializationContext using the given RedisSerializer.
fromSerializer(RedisSerializer<T>) - Static method in interface org.springframework.data.redis.serializer.RedisSerializationContext.SerializationPair
fromSetCount(int) - Static method in class org.springframework.data.redis.connection.zset.Weights
Creates equal Weights for a number of input sets count with a weight of one.
fromStart(K) - Static method in class org.springframework.data.redis.connection.stream.StreamOffset
Create a StreamOffset given stream starting at ReadOffset#from("0-0").
fromString(String) - Static method in class org.springframework.data.redis.connection.RedisNode
Parse a hostAndPort string into RedisNode.
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 new FutureResult for given object actually holding the result itself.
FutureResult(T, Converter) - Constructor for class org.springframework.data.redis.connection.FutureResult
Create new FutureResult for given object actually holding the result itself and a converter capable of transforming the result via FutureResult.convert(Object).
FutureResult(T, Converter, Supplier<?>) - Constructor for class org.springframework.data.redis.connection.FutureResult
Create new FutureResult for given object actually holding the result itself and a converter capable of transforming the result via FutureResult.convert(Object).

G

GenericJackson2JsonRedisSerializer - Class in org.springframework.data.redis.serializer
Generic Jackson 2-based RedisSerializer that maps objects to and from JSON using dynamic typing.
GenericJackson2JsonRedisSerializer() - Constructor for class org.springframework.data.redis.serializer.GenericJackson2JsonRedisSerializer
Creates GenericJackson2JsonRedisSerializer initialized with an ObjectMapper configured for default typing.
GenericJackson2JsonRedisSerializer(ObjectMapper) - Constructor for class org.springframework.data.redis.serializer.GenericJackson2JsonRedisSerializer
Setting a custom-configured ObjectMapper is one way to take further control of the JSON serialization process.
GenericJackson2JsonRedisSerializer(ObjectMapper, JacksonObjectReader, JacksonObjectWriter) - Constructor for class org.springframework.data.redis.serializer.GenericJackson2JsonRedisSerializer
Setting a custom-configured ObjectMapper is one way to take further control of the JSON serialization process.
GenericJackson2JsonRedisSerializer(String) - Constructor for class org.springframework.data.redis.serializer.GenericJackson2JsonRedisSerializer
Creates GenericJackson2JsonRedisSerializer initialized with an ObjectMapper configured for default typing using the given name.
GenericJackson2JsonRedisSerializer(String, JacksonObjectReader, JacksonObjectWriter) - Constructor for class org.springframework.data.redis.serializer.GenericJackson2JsonRedisSerializer
Creates GenericJackson2JsonRedisSerializer initialized with an ObjectMapper configured for default typing using the given name along with the given, required JacksonObjectReader and JacksonObjectWriter used to read/write Objects de/serialized as JSON.
GenericJackson2JsonRedisSerializer.GenericJackson2JsonRedisSerializerBuilder - Class in org.springframework.data.redis.serializer
Builder for configuring and creating a GenericJackson2JsonRedisSerializer.
GenericToStringSerializer<T> - Class in org.springframework.data.redis.serializer
Generic String to byte[] (and back) serializer.
GenericToStringSerializer(Class<T>) - Constructor for class org.springframework.data.redis.serializer.GenericToStringSerializer
 
GenericToStringSerializer(Class<T>, Charset) - Constructor for class org.springframework.data.redis.serializer.GenericToStringSerializer
 
geoAdd(byte[], Iterable<RedisGeoCommands.GeoLocation<byte[]>>) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
Deprecated.
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
geoAdd(byte[], Map<byte[], Point>) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
Deprecated.
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
Add Map of member / Point pairs to key.
geoAdd(byte[], Point, byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
Deprecated.
geoAdd(byte[], Point, byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
geoAdd(byte[], Point, byte[]) - Method in interface org.springframework.data.redis.connection.RedisGeoCommands
Add Point with given member name to key.
geoAdd(byte[], RedisGeoCommands.GeoLocation<byte[]>) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
geoAdd(byte[], RedisGeoCommands.GeoLocation<byte[]>) - Method in interface org.springframework.data.redis.connection.RedisGeoCommands
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
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
Add Map of member / Point pairs 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
Add Point with given member name to key.
geoAdd(String, RedisGeoCommands.GeoLocation<String>) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
geoAdd(String, RedisGeoCommands.GeoLocation<String>) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
geoAdd(ByteBuffer, Collection<RedisGeoCommands.GeoLocation<ByteBuffer>>) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
geoAdd(ByteBuffer, Point, ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
Add Point with given member to key.
geoAdd(ByteBuffer, RedisGeoCommands.GeoLocation<ByteBuffer>) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
geoAdd(Publisher<ReactiveGeoCommands.GeoAddCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
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
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.
geoDist(byte[], byte[], byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
geoDist(byte[], byte[], byte[]) - Method in interface org.springframework.data.redis.connection.RedisGeoCommands
Get the Distance between member1 and member2.
geoDist(byte[], byte[], byte[], Metric) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
Deprecated.
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 the Distance between member1 and member2 in the given Metric.
geoDist(String, String, String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
geoDist(String, String, String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
Get the Distance between member1 and member2.
geoDist(String, String, String, Metric) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
geoDist(String, String, String, Metric) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
Get the Distance between member1 and member2 in the given Metric.
geoDist(ByteBuffer, ByteBuffer, ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
Get the Distance between from and to.
geoDist(ByteBuffer, ByteBuffer, ByteBuffer, Metric) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
Get the Distance between from and to.
geoDist(Publisher<ReactiveGeoCommands.GeoDistCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
Get the Distance between from and to.
GEODIST - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
 
geoHash(byte[], byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
Deprecated.
geoHash(byte[], byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
geoHash(byte[], byte[]...) - Method in interface org.springframework.data.redis.connection.RedisGeoCommands
Get Geohash representation of the position for one or more members.
geoHash(String, String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
geoHash(String, String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
Get geohash representation of the position for one or more members.
geoHash(ByteBuffer, ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
Get geohash representation of the position for the one member.
geoHash(ByteBuffer, Collection<ByteBuffer>) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
Get geohash representation of the position for one or more members.
geoHash(Publisher<ReactiveGeoCommands.GeoHashCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
Get geohash representation of the position for one or more members.
GEOHASH - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
 
GeoIndexDefinition - Class in org.springframework.data.redis.core.index
 
GeoIndexDefinition(String, String) - Constructor for class org.springframework.data.redis.core.index.GeoIndexDefinition
Creates new GeoIndexDefinition.
GeoIndexDefinition(String, String, String) - Constructor for class org.springframework.data.redis.core.index.GeoIndexDefinition
Creates new GeoIndexDefinition.
GeoIndexed - Annotation Interface in org.springframework.data.redis.core.index
Mark properties value to be included in a secondary index.
GeoIndexedPropertyValue - Class in org.springframework.data.redis.core.convert
IndexedData implementation indicating storage of data within a Redis GEO structure.
GeoIndexedPropertyValue(String, String, Point) - Constructor for class org.springframework.data.redis.core.convert.GeoIndexedPropertyValue
 
geoIndexName(String) - Static method in class org.springframework.data.redis.core.convert.GeoIndexedPropertyValue
 
GeoLocation<T> - Class in org.springframework.data.redis.domain.geo
 
GeoLocation(T, Point) - Constructor for class org.springframework.data.redis.connection.RedisGeoCommands.GeoLocation
 
GeoLocation(T, Point) - Constructor for class org.springframework.data.redis.domain.geo.GeoLocation
 
GeoMemberReference(T) - Constructor for class org.springframework.data.redis.domain.geo.GeoReference.GeoMemberReference
 
GeoOperations<K,M> - Interface in org.springframework.data.redis.core
Redis operations for geo commands.
geoPos(byte[], byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
Deprecated.
geoPos(byte[], byte[]...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
geoPos(byte[], byte[]...) - Method in interface org.springframework.data.redis.connection.RedisGeoCommands
Get the Point representation of positions for one or more members.
geoPos(String, String...) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
geoPos(String, String...) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
Get the Point representation of positions for one or more members.
geoPos(ByteBuffer, ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
Get the Point representation of positions for the members.
geoPos(ByteBuffer, Collection<ByteBuffer>) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
Get the Point representation of positions for one or more members.
geoPos(Publisher<ReactiveGeoCommands.GeoPosCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
Get the Point representation of positions for one or more members.
GEOPOS - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
 
geoRadius(byte[], Circle) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
Deprecated.
geoRadius(byte[], Circle) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
geoRadius(byte[], Circle) - Method in interface org.springframework.data.redis.connection.RedisGeoCommands
Get the members within the boundaries of a given Circle.
geoRadius(byte[], Circle, RedisGeoCommands.GeoRadiusCommandArgs) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
Deprecated.
geoRadius(byte[], Circle, RedisGeoCommands.GeoRadiusCommandArgs) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
geoRadius(byte[], Circle, RedisGeoCommands.GeoRadiusCommandArgs) - Method in interface org.springframework.data.redis.connection.RedisGeoCommands
Get the members within the boundaries of a given Circle applying RedisGeoCommands.GeoRadiusCommandArgs.
geoRadius(String, Circle) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
geoRadius(String, Circle) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
Get the members within the boundaries of a given Circle.
geoRadius(String, Circle, RedisGeoCommands.GeoRadiusCommandArgs) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
geoRadius(String, Circle, RedisGeoCommands.GeoRadiusCommandArgs) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
Get the members within the boundaries of a given Circle applying RedisGeoCommands.GeoRadiusCommandArgs.
geoRadius(ByteBuffer, Circle) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
Get the members within the boundaries of a given Circle.
geoRadius(ByteBuffer, Circle, RedisGeoCommands.GeoRadiusCommandArgs) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
Get the members within the boundaries of a given Circle applying given parameters.
geoRadius(Publisher<ReactiveGeoCommands.GeoRadiusCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
Get the members within the boundaries of a given Circle applying given parameters.
GEORADIUS - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
 
geoRadiusByMember(byte[], byte[], double) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
geoRadiusByMember(byte[], byte[], double) - Method in interface org.springframework.data.redis.connection.RedisGeoCommands
Get the members within the circle defined by the members coordinates and given radius.
geoRadiusByMember(byte[], byte[], Distance) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
Deprecated.
geoRadiusByMember(byte[], byte[], Distance) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
geoRadiusByMember(byte[], byte[], Distance) - Method in interface org.springframework.data.redis.connection.RedisGeoCommands
Get the members within the circle defined by the members coordinates and given Distance.
geoRadiusByMember(byte[], byte[], Distance, RedisGeoCommands.GeoRadiusCommandArgs) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
Deprecated.
geoRadiusByMember(byte[], byte[], Distance, RedisGeoCommands.GeoRadiusCommandArgs) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
geoRadiusByMember(byte[], byte[], Distance, RedisGeoCommands.GeoRadiusCommandArgs) - Method in interface org.springframework.data.redis.connection.RedisGeoCommands
Get the members within the circle defined by the members coordinates, given Distance and RedisGeoCommands.GeoRadiusCommandArgs.
geoRadiusByMember(String, String, double) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
geoRadiusByMember(String, String, double) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
Get the members within the circle defined by the members coordinates and given radius.
geoRadiusByMember(String, String, Distance) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
geoRadiusByMember(String, String, Distance) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
Get the members within the circle defined by the members coordinates and given Distance.
geoRadiusByMember(String, String, Distance, RedisGeoCommands.GeoRadiusCommandArgs) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
geoRadiusByMember(String, String, Distance, RedisGeoCommands.GeoRadiusCommandArgs) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
Get the members within the circle defined by the members coordinates and given Distance and RedisGeoCommands.GeoRadiusCommandArgs.
geoRadiusByMember(ByteBuffer, ByteBuffer, Distance) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
Get the members within given Distance from member applying given parameters.
geoRadiusByMember(ByteBuffer, ByteBuffer, Distance, RedisGeoCommands.GeoRadiusCommandArgs) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
Get the members within given Distance from member applying given parameters.
geoRadiusByMember(Publisher<ReactiveGeoCommands.GeoRadiusByMemberCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
Get the members within given Distance from member applying given parameters.
GEORADIUSBYMEMBER - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
 
geoRadiusResponseToGeoResultsConverter(Metric) - Static method in class org.springframework.data.redis.connection.lettuce.LettuceConverters
Get Converter capable of convering GeoWithin into GeoResults.
GeoReference<T> - Interface in org.springframework.data.redis.domain.geo
Reference point for GEOSEARCH and GEOSEARCHSTORE commands.
GeoReference.GeoCoordinateReference<T> - Class in org.springframework.data.redis.domain.geo
 
GeoReference.GeoMemberReference<T> - Class in org.springframework.data.redis.domain.geo
 
geoRemove(byte[], byte[]...) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
Deprecated.
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.
geoSearch(byte[], GeoReference<byte[]>, GeoShape, RedisGeoCommands.GeoSearchCommandArgs) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
geoSearch(byte[], GeoReference<byte[]>, GeoShape, RedisGeoCommands.GeoSearchCommandArgs) - Method in interface org.springframework.data.redis.connection.RedisGeoCommands
Return the members of a geo set which are within the borders of the area specified by a given shape.
geoSearch(String, GeoReference<String>, GeoShape, RedisGeoCommands.GeoSearchCommandArgs) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
geoSearch(String, GeoReference<String>, GeoShape, RedisGeoCommands.GeoSearchCommandArgs) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
Return the members of a geo set which are within the borders of the area specified by a given shape.
geoSearch(ByteBuffer, GeoReference<ByteBuffer>, GeoShape, RedisGeoCommands.GeoSearchCommandArgs) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
Return the members of a geo set which are within the borders of the area specified by a given shape.
geoSearch(Publisher<ReactiveGeoCommands.GeoSearchCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
Get the members within given GeoShape from GeoReference applying given parameters.
geoSearchStore(byte[], byte[], GeoReference<byte[]>, GeoShape, RedisGeoCommands.GeoSearchStoreCommandArgs) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
Deprecated.
geoSearchStore(byte[], byte[], GeoReference<byte[]>, GeoShape, RedisGeoCommands.GeoSearchStoreCommandArgs) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
geoSearchStore(byte[], byte[], GeoReference<byte[]>, GeoShape, RedisGeoCommands.GeoSearchStoreCommandArgs) - Method in interface org.springframework.data.redis.connection.RedisGeoCommands
Query the members of a geo set which are within the borders of the area specified by a given shape and store the result at destKey.
geoSearchStore(String, String, GeoReference<String>, GeoShape, RedisGeoCommands.GeoSearchStoreCommandArgs) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
geoSearchStore(String, String, GeoReference<String>, GeoShape, RedisGeoCommands.GeoSearchStoreCommandArgs) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
Query the members of a geo set which are within the borders of the area specified by a given shape and store the result at destKey.
geoSearchStore(ByteBuffer, ByteBuffer, GeoReference<ByteBuffer>, GeoShape, RedisGeoCommands.GeoSearchStoreCommandArgs) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
Query the members of a geo set which are within the borders of the area specified by a given shape and store the result at destKey.
geoSearchStore(Publisher<ReactiveGeoCommands.GeoSearchStoreCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveGeoCommands
Store the members within given GeoShape from GeoReference applying given parameters in a new geo set.
GeoShape - Interface in org.springframework.data.redis.domain.geo
Search predicate for GEOSEARCH and GEOSEARCHSTORE commands.
get() - Method in class org.springframework.data.redis.connection.FutureResult
 
get() - Method in class org.springframework.data.redis.connection.RedisPassword
Return the password value if present.
get() - Method in interface org.springframework.data.redis.core.BoundValueOperations
Get the value of the bound key.
get() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicDouble
Get the current value.
get() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicInteger
Get the current value.
get() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicLong
Get the current value.
get(byte[]) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
Deprecated.
get(byte[]) - Method in class org.springframework.data.redis.connection.DefaultSortParameters
 
get(byte[]) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
get(byte[]) - Method in interface org.springframework.data.redis.connection.RedisStringCommands
Get the value of key.
get(int) - Method in class org.springframework.data.redis.connection.stream.PendingMessages
Get the PendingMessage at the given position.
get(int) - Method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoConsumers
Returns the StreamInfo.XInfoConsumer element at the given index.
get(int) - Method in class org.springframework.data.redis.connection.stream.StreamInfo.XInfoGroups
Returns the StreamInfo.XInfoGroup element at the given index.
get(int) - Method in class org.springframework.data.redis.support.collections.DefaultRedisList
 
get(long, long) - Method in interface org.springframework.data.redis.core.BoundValueOperations
Get a substring of value of the bound key between begin and end.
get(H, Object) - Method in interface org.springframework.data.redis.core.HashOperations
Get value for given hashKey from hash at key.
get(H, Object) - Method in interface org.springframework.data.redis.core.ReactiveHashOperations
Get value for given hashKey from hash at key.
get(Object) - Method in interface org.springframework.data.redis.core.BoundHashOperations
Get value for given key from the hash at the bound key.
get(Object) - Method in interface org.springframework.data.redis.core.ReactiveValueOperations
Get the value of key.
get(Object) - Method in interface org.springframework.data.redis.core.ValueOperations
Get the value of key.
get(Object) - Method in class org.springframework.data.redis.support.collections.DefaultRedisMap
 
get(Object) - Method in class org.springframework.data.redis.support.collections.RedisProperties
 
get(Object, String) - Method in class org.springframework.data.redis.core.RedisKeyValueAdapter
 
get(Object, String, Class<T>) - Method in class org.springframework.data.redis.core.RedisKeyValueAdapter
 
get(Object, Callable<T>) - Method in class org.springframework.data.redis.cache.RedisCache
 
get(String) - Method in class org.springframework.data.redis.connection.ClusterInfo
 
get(String) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
get(String) - Method in class org.springframework.data.redis.connection.RedisServer
 
get(String) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
Get the value of key.
get(String) - Method in class org.springframework.data.redis.core.convert.Bucket.BucketPropertyPath
Retrieve a value at key considering top-level/nesting.
get(String) - Method in class org.springframework.data.redis.core.convert.Bucket
Get value assigned with path.
get(String) - Method in class org.springframework.data.redis.core.query.SortQueryBuilder
 
get(String) - Method in interface org.springframework.data.redis.core.query.SortCriterion
 
get(String) - Method in class org.springframework.data.redis.core.types.RedisClientInfo
 
get(String, byte[]) - Method in interface org.springframework.data.redis.cache.RedisCacheWriter
Get the binary value representation from Redis stored for the given key.
get(String, byte[], Duration) - Method in interface org.springframework.data.redis.cache.RedisCacheWriter
Get the binary value representation from Redis stored for the given key and set the given TTL expiration for the cache entry.
get(String, byte[], Supplier<byte[]>, Duration, boolean) - Method in interface org.springframework.data.redis.cache.RedisCacheWriter
Get the binary value representation from Redis stored for the given key and set the given TTL expiration for the cache entry, obtaining the value from valueLoader if necessary.
get(ByteBuffer) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
Get single element stored at key.
get(K, long, long) - Method in interface org.springframework.data.redis.core.ReactiveValueOperations
Get a substring of value of key between begin and end.
get(K, long, long) - Method in interface org.springframework.data.redis.core.ValueOperations
Get a substring of value of key between begin and end.
get(Publisher<ReactiveRedisConnection.KeyCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
Get elements one by one.
get(BitFieldSubCommands.BitFieldGet) - Method in class org.springframework.data.redis.connection.BitFieldSubCommands
Create new BitFieldSubCommands adding given BitFieldSubCommands.BitFieldGet to the sub commands.
get(BitFieldSubCommands.BitFieldType) - Method in class org.springframework.data.redis.connection.BitFieldSubCommands
Obtain a new BitFieldSubCommands.BitFieldGetBuilder for creating and adding a BitFieldSubCommands.BitFieldGet sub command.
get(ClusterInfo.Info) - Method in class org.springframework.data.redis.connection.ClusterInfo
 
get(RedisServer.INFO) - Method in class org.springframework.data.redis.connection.RedisServer
 
get(RedisClientInfo.INFO) - Method in class org.springframework.data.redis.core.types.RedisClientInfo
 
GET - Enum constant in enum class org.springframework.data.redis.core.RedisCommand
 
getAbbreviation() - Method in enum class org.springframework.data.redis.connection.RedisGeoCommands.DistanceUnit
 
getAbbreviation() - Method in enum class org.springframework.data.redis.domain.geo.Metrics
 
getAction() - Method in class org.springframework.data.redis.connection.ReactiveStreamCommands.GroupCommand
 
getActiveMasterNodes() - Method in class org.springframework.data.redis.connection.ClusterTopology
Get all master nodes in cluster where link-state is connected and flags does not contain fail or fail?.
getActiveNodes() - Method in class org.springframework.data.redis.connection.ClusterTopology
Get all nodes (master and replica) in cluster where link-state is connected and flags does not contain fail or fail?.
getActiveSubscriptions() - Method in class org.springframework.data.redis.listener.ReactiveRedisMessageListenerContainer
Return the currently active subscriptions.
getAddressPort() - Method in class org.springframework.data.redis.core.types.RedisClientInfo
Get address/port of the client.
getAge() - Method in class org.springframework.data.redis.core.types.RedisClientInfo
Get total duration of the connection in seconds.
getAggregateFunction() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZAggregateCommand
 
getAggregateFunction() - Method in class org.springframework.data.redis.connection.ReactiveZSetCommands.ZAggregateStoreCommand
 
getAllOf(String) - Method in class org.springframework.data.redis.core.RedisKeyValueAdapter
 
getAllOf(String, Class<T>) - Method in class org.springframework.data.redis.core.RedisKeyValueAdapter
 
getAllOf(String, Class<T>, long, int) - Method in class org.springframework.data.redis.core.RedisKeyValueAdapter
Get all elements for given keyspace.
getAllowCacheNullValues() - Method in class org.springframework.data.redis.cache.RedisCacheConfiguration
 
getAndAccumulate(double, DoubleBinaryOperator) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicDouble
Atomically update the current value using the given accumulator function.
getAndAccumulate(int, IntBinaryOperator) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicInteger
Atomically update the current value using the given accumulator function.
getAndAccumulate(long, LongBinaryOperator) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicLong
Atomically update the current value using the given accumulator function.
getAndAdd(double) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicDouble
Atomically add the given value to current value.
getAndAdd(int) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicInteger
Atomically add the given value to current value.
getAndAdd(long) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicLong
Atomically add the given value to current value.
getAndDecrement() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicDouble
Atomically decrement by one the current value.
getAndDecrement() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicInteger
Atomically decrement by one the current value.
getAndDecrement() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicLong
Atomically decrement by one the current value.
getAndDelete() - Method in interface org.springframework.data.redis.core.BoundValueOperations
Return the value at the bound key and delete the key.
getAndDelete(K) - Method in interface org.springframework.data.redis.core.ReactiveValueOperations
Return the value at key and delete the key.
getAndDelete(K) - Method in interface org.springframework.data.redis.core.ValueOperations
Return the value at key and delete the key.
getAndExpire(long, TimeUnit) - Method in interface org.springframework.data.redis.core.BoundValueOperations
Return the value at the bound key and expire the key by applying timeout.
getAndExpire(Duration) - Method in interface org.springframework.data.redis.core.BoundValueOperations
Return the value at the bound key and expire the key by applying timeout.
getAndExpire(K, long, TimeUnit) - Method in interface org.springframework.data.redis.core.ValueOperations
Return the value at key and expire the key by applying timeout.
getAndExpire(K, Duration) - Method in interface org.springframework.data.redis.core.ReactiveValueOperations
Return the value at key and expire the key by applying timeout.
getAndExpire(K, Duration) - Method in interface org.springframework.data.redis.core.ValueOperations
Return the value at key and expire the key by applying timeout.
getAndIncrement() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicDouble
Atomically increment by one the current value.
getAndIncrement() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicInteger
Atomically increment by one the current value.
getAndIncrement() - Method in class org.springframework.data.redis.support.atomic.RedisAtomicLong
Atomically increment by one the current value.
getAndPersist() - Method in interface org.springframework.data.redis.core.BoundValueOperations
Return the value at the bound key and persist the key.
getAndPersist(K) - Method in interface org.springframework.data.redis.core.ReactiveValueOperations
Return the value at key and persist the key.
getAndPersist(K) - Method in interface org.springframework.data.redis.core.ValueOperations
Return the value at key and persist the key.
getAndSet(double) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicDouble
Set to the given value and return the old value.
getAndSet(int) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicInteger
Set to the given value and return the old value.
getAndSet(long) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicLong
Set to the given value and return the old value.
getAndSet(K, V) - Method in interface org.springframework.data.redis.core.ReactiveValueOperations
Set value of key and return its old value.
getAndSet(K, V) - Method in interface org.springframework.data.redis.core.ValueOperations
Set value of key and return its old value.
getAndSet(V) - Method in interface org.springframework.data.redis.core.BoundValueOperations
Set value of the bound key and return its old value.
getAndUpdate(DoubleUnaryOperator) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicDouble
Atomically update the current value using the given update function.
getAndUpdate(IntUnaryOperator) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicInteger
Atomically update the current value using the given update function.
getAndUpdate(LongUnaryOperator) - Method in class org.springframework.data.redis.support.atomic.RedisAtomicLong
Atomically update the current value using the given update function.
getAnnotation() - Method in class org.springframework.data.redis.repository.configuration.RedisRepositoriesRegistrar
 
getArgs() - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusByMemberCommand
 
getArgs() - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoRadiusCommand
 
getArgs() - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoSearchCommand
 
getArgs() - Method in class org.springframework.data.redis.connection.ReactiveGeoCommands.GeoSearchStoreCommand
 
getArray() - Method in class org.springframework.data.redis.connection.util.ByteArrayWrapper
Returns the array.
getAsyncDedicatedConnection() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnection
 
getBatchSize() - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamMessageListenerContainerOptions
Batch size polling using the COUNT option during reads.
getBatchSize() - Method in class org.springframework.data.redis.stream.StreamReceiver.StreamReceiverOptions
Batch size polling using the COUNT option during reads.
getBeanClass() - Method in class org.springframework.data.redis.repository.cdi.CdiBean
 
getBit() - Method in class org.springframework.data.redis.connection.ReactiveStringCommands.BitPosCommand
 
getBit(byte[], long) - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
Deprecated.
getBit(byte[], long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
getBit(byte[], long) - Method in interface org.springframework.data.redis.connection.RedisStringCommands
Get the bit value at offset of value at key.
getBit(String, long) - Method in class org.springframework.data.redis.connection.DefaultStringRedisConnection
 
getBit(String, long) - Method in interface org.springframework.data.redis.connection.StringRedisConnection
Get the bit value at offset of value at key.
getBit(ByteBuffer, long) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
Get the bit value at offset of value at key.
getBit(K, long) - Method in interface org.springframework.data.redis.core.ReactiveValueOperations
« Get the bit value at offset of value at key.
getBit(K, long) - Method in interface org.springframework.data.redis.core.ValueOperations
Get the bit value at offset of value at key.
getBit(Publisher<ReactiveStringCommands.GetBitCommand>) - Method in interface org.springframework.data.redis.connection.ReactiveStringCommands
Get the bit value at offset of value at key.
GETBIT - 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
Convert a String into a ByteBuffer using StandardCharsets.UTF_8.
getByteBuffer(String, Charset) - Static method in class org.springframework.data.redis.util.ByteUtils
Convert a String into a ByteBuffer using the given Charset.
getBytePattern() - Method in class org.springframework.data.redis.core.ScanOptions
 
getBytes(ByteBuffer) - Static method in class org.springframework.data.redis.util.ByteUtils
Extract a byte array from ByteBuffer without consuming it.
getCacheConfiguration() - Method in class org.springframework.data.redis.cache.RedisCache
Get the RedisCacheConfiguration used to configure this RedisCache on initialization.
getCacheConfigurationFor(String) - Method in class org.springframework.data.redis.cache.RedisCacheManager.RedisCacheManagerBuilder
Get the RedisCacheConfiguration for a given cache by its name.
getCacheConfigurations() - Method in class org.springframework.data.redis.cache.RedisCacheManager
Return an unmodifiable Map containing caches name mapped to the RedisCache configuration.
getCacheName() - Method in interface org.springframework.data.redis.cache.CacheStatistics
 
getCacheStatistics(String) - Method in interface org.springframework.data.redis.cache.CacheStatisticsProvider
Obtain snapshot of the captured statistics.
getCacheWriter() - Method in class org.springframework.data.redis.cache.RedisCache
Gets the configured RedisCacheWriter used to adapt Redis for cache operations.
getCacheWriter() - Method in class org.springframework.data.redis.cache.RedisCacheManager
Returns a reference to the configured RedisCacheWriter used to perform RedisCache operations, such as reading from and writing to the cache.
getCancelSubscriptionOnError() - Method in class org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamReadRequest
 
getChannel() - Method in class org.springframework.data.redis.connection.DefaultMessage
 
getChannel() - Method in interface org.springframework.data.redis.connection.Message
Returns the channel associated with the message.
getChannel() - Method in class org.springframework.data.redis.connection.ReactiveSubscription.ChannelMessage
 
getChannel() - Method in interface org.springframework.data.redis.connection.ReactiveSubscription.Message
Get the channel the message published to.
getChannel() - Method in class org.springframework.data.redis.core.RedisKeyspaceEvent
 
getChannels() - Method in interface org.springframework.data.redis.connection.ReactiveSubscription
Returns the (named) channels for this subscription.
getChannels() - Method in interface org.springframework.data.redis.connection.Subscription
Returns the (named) channels for this subscription.
getChannels() - Method in class org.springframework.data.redis.connection.util.AbstractSubscription
 
getChannelSubscribtions() - Method in class org.springframework.data.redis.core.types.RedisClientInfo
Get number of channel subscriptions.
getClientConfiguration() - Method in class org.springframework.data.redis.connection.jedis.JedisConnectionFactory
 
getClientConfiguration() - Method in class org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory
 
getClientList() - Method in interface org.springframework.data.redis.connection.DefaultedRedisConnection
Deprecated.
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.
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.
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.