- AbstractInvocationHandler - Class in io.lettuce.core.internal
-
Abstract base class for invocation handlers.
- AbstractInvocationHandler() - Constructor for class io.lettuce.core.internal.AbstractInvocationHandler
-
- AbstractInvocationHandler.MethodTranslator - Class in io.lettuce.core.internal
-
- AbstractRedisAsyncCommands<K,V> - Class in io.lettuce.core
-
An asynchronous and thread-safe API for a Redis connection.
- AbstractRedisAsyncCommands(StatefulConnection<K, V>, RedisCodec<K, V>) - Constructor for class io.lettuce.core.AbstractRedisAsyncCommands
-
Initialize a new instance.
- AbstractRedisClient - Class in io.lettuce.core
-
Base Redis client.
- AbstractRedisClient(ClientResources) - Constructor for class io.lettuce.core.AbstractRedisClient
-
Create a new instance with client resources.
- AbstractRedisReactiveCommands<K,V> - Class in io.lettuce.core
-
A reactive and thread-safe API for a Redis connection.
- AbstractRedisReactiveCommands(StatefulConnection<K, V>, RedisCodec<K, V>) - Constructor for class io.lettuce.core.AbstractRedisReactiveCommands
-
Initialize a new instance.
- acceptEither(CompletionStage<? extends T>, Consumer<? super T>) - Method in interface io.lettuce.core.ConnectionFuture
-
- acceptEitherAsync(CompletionStage<? extends T>, Consumer<? super T>) - Method in interface io.lettuce.core.ConnectionFuture
-
- acceptEitherAsync(CompletionStage<? extends T>, Consumer<? super T>, Executor) - Method in interface io.lettuce.core.ConnectionFuture
-
- acquire() - Method in interface io.lettuce.core.support.AsyncPool
-
- acquire() - Method in class io.lettuce.core.support.BoundedAsyncPool
-
- activated() - Method in class io.lettuce.core.cluster.StatefulRedisClusterConnectionImpl
-
- Activated() - Constructor for class io.lettuce.core.ConnectionEvents.Activated
-
- activated() - Method in interface io.lettuce.core.protocol.ConnectionFacade
-
Callback for a connection activated event.
- activated() - Method in class io.lettuce.core.pubsub.StatefulRedisPubSubConnectionImpl
-
- activated() - Method in class io.lettuce.core.RedisChannelHandler
-
Notification when the connection becomes active (connected).
- activated() - Method in class io.lettuce.core.sentinel.StatefulRedisSentinelConnectionImpl
-
- activated() - Method in class io.lettuce.core.StatefulRedisConnectionImpl
-
- adapt(ChannelFuture, CompletableFuture<Void>) - Static method in class io.lettuce.core.internal.Futures
-
- adaptAnnotation(A) - Method in class io.lettuce.core.dynamic.support.MethodParameter
-
A template method to post-process a given annotation instance before returning it to the caller.
- adaptAnnotationArray(Annotation[]) - Method in class io.lettuce.core.dynamic.support.MethodParameter
-
A template method to post-process a given annotation array before returning it to the caller.
- AdaptiveRefreshTriggeredEvent - Class in io.lettuce.core.event.cluster
-
Event when a topology refresh is about to start by an adaptive refresh trigger.
- AdaptiveRefreshTriggeredEvent(Supplier<Partitions>, Runnable) - Constructor for class io.lettuce.core.event.cluster.AdaptiveRefreshTriggeredEvent
-
- adaptiveRefreshTriggersTimeout(Duration) - Method in class io.lettuce.core.cluster.ClusterTopologyRefreshOptions.Builder
-
Set the timeout for adaptive topology updates.
- adaptiveRefreshTriggersTimeout(long, TimeUnit) - Method in class io.lettuce.core.cluster.ClusterTopologyRefreshOptions.Builder
-
- add(RedisClusterNode) - Method in class io.lettuce.core.cluster.models.partitions.Partitions
-
- add(RedisCommand<K, V, ?>) - Method in class io.lettuce.core.output.MultiOutput
-
- add(Map<K, V>) - Method in class io.lettuce.core.protocol.CommandArgs
-
Add a map (hash) argument.
- add(String) - Method in class io.lettuce.core.protocol.CommandArgs
-
Add a string argument.
- add(char[]) - Method in class io.lettuce.core.protocol.CommandArgs
-
Add a string as char-array.
- add(long) - Method in class io.lettuce.core.protocol.CommandArgs
-
Add an 64-bit integer (long) argument.
- add(double) - Method in class io.lettuce.core.protocol.CommandArgs
-
Add a double argument.
- add(byte[]) - Method in class io.lettuce.core.protocol.CommandArgs
-
Add a byte-array argument.
- add(CommandKeyword) - Method in class io.lettuce.core.protocol.CommandArgs
-
- add(CommandType) - Method in class io.lettuce.core.protocol.CommandArgs
-
- add(ProtocolKeyword) - Method in class io.lettuce.core.protocol.CommandArgs
-
- addAlias(RedisURI) - Method in class io.lettuce.core.cluster.models.partitions.RedisClusterNode
-
- addAll(Collection<? extends RedisClusterNode>) - Method in class io.lettuce.core.cluster.models.partitions.Partitions
-
Add all
nodes
from the given collection and update the read-view/caches.
- addInterceptor(MethodInterceptor) - Method in class io.lettuce.core.dynamic.intercept.InvocationProxyFactory
-
- addInterface(Class<?>) - Method in class io.lettuce.core.dynamic.intercept.InvocationProxyFactory
-
Add a interface type that should be implemented by the resulting invocation proxy.
- addKey(K) - Method in class io.lettuce.core.protocol.CommandArgs
-
Adds a key argument.
- addKeys(Iterable<K>) - Method in class io.lettuce.core.protocol.CommandArgs
-
Add multiple key arguments.
- addKeys(K...) - Method in class io.lettuce.core.protocol.CommandArgs
-
Add multiple key arguments.
- addListener(RedisConnectionStateListener) - Method in class io.lettuce.core.AbstractRedisClient
-
Add a listener for the RedisConnectionState.
- addListener(RedisClusterPubSubListener<K, V>) - Method in interface io.lettuce.core.cluster.pubsub.StatefulRedisClusterPubSubConnection
-
- addListener(RedisClusterPubSubListener<K, V>) - Method in class io.lettuce.core.cluster.PubSubClusterEndpoint
-
- addListener(RedisConnectionStateListener) - Method in class io.lettuce.core.ConnectionEvents
-
- addListener(RedisPubSubListener<K, V>) - Method in class io.lettuce.core.pubsub.PubSubEndpoint
-
- addListener(RedisPubSubListener<K, V>) - Method in interface io.lettuce.core.pubsub.StatefulRedisPubSubConnection
-
- addListener(RedisPubSubListener<K, V>) - Method in class io.lettuce.core.pubsub.StatefulRedisPubSubConnectionImpl
-
Add a new listener.
- addListener(CloseEvents.CloseListener) - Method in class io.lettuce.core.RedisChannelHandler
-
- addPartition(RedisClusterNode) - Method in class io.lettuce.core.cluster.models.partitions.Partitions
-
Adds a partition without updating the read view/cache.
- addr(String) - Method in class io.lettuce.core.KillArgs
-
Kill the client at addr
.
- addr(String) - Static method in class io.lettuce.core.KillArgs.Builder
-
- addValue(V) - Method in class io.lettuce.core.protocol.CommandArgs
-
Add a value argument.
- addValues(Iterable<V>) - Method in class io.lettuce.core.protocol.CommandArgs
-
Add multiple value arguments.
- addValues(V...) - Method in class io.lettuce.core.protocol.CommandArgs
-
Add multiple value arguments.
- after() - Method in class io.lettuce.core.cluster.event.ClusterTopologyChangedEvent
-
Returns the cluster topology view after the topology changed.
- afterBootstrapInitialized(Bootstrap) - Method in interface io.lettuce.core.resource.NettyCustomizer
-
Hook invoked each time the driver creates a new Connection and configures a new instance of Bootstrap for it.
- afterChannelInitialized(Channel) - Method in interface io.lettuce.core.resource.NettyCustomizer
-
Hook invoked each time the driver initializes the channel.
- afterDecode(ChannelHandlerContext, RedisCommand<?, ?, ?>) - Method in class io.lettuce.core.protocol.CommandHandler
-
Hook method called after command completion.
- afterDecode(ChannelHandlerContext, RedisCommand<?, ?, ?>) - Method in class io.lettuce.core.pubsub.PubSubCommandHandler
-
- afterPropertiesSet() - Method in class io.lettuce.core.support.LettuceFactoryBeanSupport
-
- afterPropertiesSet() - Method in class io.lettuce.core.support.RedisClientFactoryBean
-
- afterPropertiesSet() - Method in class io.lettuce.core.support.RedisClusterClientFactoryBean
-
- all() - Method in interface io.lettuce.core.cluster.api.async.RedisAdvancedClusterAsyncCommands
-
Select all known cluster nodes.
- all() - Method in interface io.lettuce.core.cluster.api.sync.RedisAdvancedClusterCommands
-
Select all known cluster nodes.
- all() - Method in interface io.lettuce.core.cluster.pubsub.api.async.RedisClusterPubSubAsyncCommands
-
Select all known cluster nodes.
- all() - Method in interface io.lettuce.core.cluster.pubsub.api.reactive.RedisClusterPubSubReactiveCommands
-
Select all known cluster nodes.
- all() - Method in interface io.lettuce.core.cluster.pubsub.api.sync.RedisClusterPubSubCommands
-
Select all known cluster nodes.
- allConnections() - Method in class io.lettuce.core.masterslave.MasterSlaveConnectionProvider
-
Deprecated.
- allocate(Class<T>) - Method in class io.lettuce.core.resource.DefaultEventLoopGroupProvider
-
- allocate(Class<T>) - Method in interface io.lettuce.core.resource.EventLoopGroupProvider
-
- allocateBuffer(ChannelHandlerContext, Object, boolean) - Method in class io.lettuce.core.protocol.CommandEncoder
-
- allOf(Collection<? extends CompletableFuture<?>>) - Static method in class io.lettuce.core.internal.Futures
-
- alpha() - Method in class io.lettuce.core.SortArgs
-
Apply lexicographically sort.
- alpha() - Static method in class io.lettuce.core.SortArgs.Builder
-
- annotate(String) - Method in class io.lettuce.core.tracing.Tracer.Span
-
Associates an event that explains latency with the current system time.
- AnnotationCommandSegmentFactory - Class in io.lettuce.core.dynamic.segment
-
- AnnotationCommandSegmentFactory() - Constructor for class io.lettuce.core.dynamic.segment.AnnotationCommandSegmentFactory
-
- AnnotationParameterNameDiscoverer - Class in io.lettuce.core.dynamic.support
-
- AnnotationParameterNameDiscoverer() - Constructor for class io.lettuce.core.dynamic.support.AnnotationParameterNameDiscoverer
-
- AnnotationRedisCodecResolver - Class in io.lettuce.core.dynamic.codec
-
- AnnotationRedisCodecResolver(List<RedisCodec<?, ?>>) - Constructor for class io.lettuce.core.dynamic.codec.AnnotationRedisCodecResolver
-
- AnnotationRedisCodecResolver.ParameterWrappers - Class in io.lettuce.core.dynamic.codec
-
Parameter wrapper support for types that encapsulate one or more parameter values.
- ANY - Static variable in class io.lettuce.core.ReadFrom
-
Setting to read from any node.
- append(K, V) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- append(K, V) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- append(K, V) - Method in interface io.lettuce.core.api.async.RedisStringAsyncCommands
-
Append a value to a key.
- append(K, V) - Method in interface io.lettuce.core.api.reactive.RedisStringReactiveCommands
-
Append a value to a key.
- append(K, V) - Method in interface io.lettuce.core.api.sync.RedisStringCommands
-
Append a value to a key.
- append(K, V) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionStringAsyncCommands
-
Append a value to a key.
- append(K, V) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionStringCommands
-
Append a value to a key.
- applyBounds(Duration, Duration, Duration) - Static method in class io.lettuce.core.resource.Delay
-
- applyToEither(CompletionStage<? extends T>, Function<? super T, U>) - Method in interface io.lettuce.core.ConnectionFuture
-
- applyToEitherAsync(CompletionStage<? extends T>, Function<? super T, U>) - Method in interface io.lettuce.core.ConnectionFuture
-
- applyToEitherAsync(CompletionStage<? extends T>, Function<? super T, U>, Executor) - Method in interface io.lettuce.core.ConnectionFuture
-
- approximateTrimming() - Method in class io.lettuce.core.XAddArgs
-
Apply efficient trimming for capped streams using the ~
flag.
- approximateTrimming(boolean) - Method in class io.lettuce.core.XAddArgs
-
Apply efficient trimming for capped streams using the ~
flag.
- args - Variable in class io.lettuce.core.protocol.Command
-
- ArrayOutput<K,V> - Class in io.lettuce.core.output
-
List
of objects and lists to support dynamic nested structures (List with mixed content of values and
sublists).
- ArrayOutput(RedisCodec<K, V>) - Constructor for class io.lettuce.core.output.ArrayOutput
-
- arrayToDelimitedString(Object[], String) - Static method in class io.lettuce.core.LettuceStrings
-
Convert a String
array into a delimited String
(e.g.
- as(Class<?>) - Method in class io.lettuce.core.dynamic.support.ResolvableType
-
- asc() - Method in class io.lettuce.core.GeoArgs
-
Sort results ascending.
- asc() - Method in class io.lettuce.core.GeoRadiusStoreArgs
-
Sort results ascending.
- asc() - Method in class io.lettuce.core.SortArgs
-
Apply numeric sort in ascending order.
- asc() - Static method in class io.lettuce.core.SortArgs.Builder
-
- ASCII - Static variable in class io.lettuce.core.codec.StringCodec
-
- ASCII - Static variable in class io.lettuce.core.protocol.LettuceCharsets
-
Deprecated.
US-ASCII charset.
- asCollection() - Method in class io.lettuce.core.dynamic.support.ResolvableType
-
Convenience method to return this type as a resolvable
Collection
type.
- asking() - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- asking() - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- asking() - Method in interface io.lettuce.core.cluster.api.async.RedisClusterAsyncCommands
-
The asking command is required after a -ASK
redirection.
- asking() - Method in interface io.lettuce.core.cluster.api.reactive.RedisClusterReactiveCommands
-
The asking command is required after a -ASK
redirection.
- asking() - Method in interface io.lettuce.core.cluster.api.sync.RedisClusterCommands
-
The asking command is required after a -ASK
redirection.
- asMap() - Method in interface io.lettuce.core.cluster.api.async.AsyncExecutions
-
- asMap() - Method in interface io.lettuce.core.cluster.api.NodeSelectionSupport
-
- asMap() - Method in interface io.lettuce.core.cluster.api.sync.Executions
-
- asMap() - Method in class io.lettuce.core.dynamic.support.ResolvableType
-
Convenience method to return this type as a resolvable
Map
type.
- assertState(boolean, String) - Static method in class io.lettuce.core.internal.LettuceAssert
-
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the
calling method.
- assertState(boolean, Supplier<String>) - Static method in class io.lettuce.core.internal.LettuceAssert
-
Ensures the truth of an expression involving the state of the calling instance, but not involving any parameters to the
calling method.
- asString() - Method in class io.lettuce.core.dynamic.segment.CommandSegment
-
- async() - Method in interface io.lettuce.core.api.StatefulRedisConnection
-
- async() - Method in interface io.lettuce.core.cluster.api.StatefulRedisClusterConnection
-
- async() - Method in interface io.lettuce.core.cluster.pubsub.StatefulRedisClusterPubSubConnection
-
- async - Variable in class io.lettuce.core.cluster.StatefulRedisClusterConnectionImpl
-
- async() - Method in class io.lettuce.core.cluster.StatefulRedisClusterConnectionImpl
-
- async() - Method in interface io.lettuce.core.pubsub.StatefulRedisPubSubConnection
-
- async() - Method in class io.lettuce.core.pubsub.StatefulRedisPubSubConnectionImpl
-
- async() - Method in interface io.lettuce.core.sentinel.api.StatefulRedisSentinelConnection
-
- async - Variable in class io.lettuce.core.sentinel.StatefulRedisSentinelConnectionImpl
-
- async() - Method in class io.lettuce.core.sentinel.StatefulRedisSentinelConnectionImpl
-
- async - Variable in class io.lettuce.core.StatefulRedisConnectionImpl
-
- async() - Method in class io.lettuce.core.StatefulRedisConnectionImpl
-
- AsyncCloseable - Interface in io.lettuce.core.internal
-
- AsyncCommand<K,V,T> - Class in io.lettuce.core.protocol
-
An asynchronous redis command and its result.
- AsyncCommand(RedisCommand<K, V, T>) - Constructor for class io.lettuce.core.protocol.AsyncCommand
-
- AsyncCommand(RedisCommand<K, V, T>, int) - Constructor for class io.lettuce.core.protocol.AsyncCommand
-
- AsyncConnectionPoolSupport - Class in io.lettuce.core.support
-
- AsyncConnectionProvider<K,T extends AsyncCloseable,F extends CompletionStage<T>> - Class in io.lettuce.core.internal
-
Non-blocking provider for connection objects.
- AsyncConnectionProvider(Function<? extends K, ? extends F>) - Constructor for class io.lettuce.core.internal.AsyncConnectionProvider
-
- AsyncExecutions<T> - Interface in io.lettuce.core.cluster.api.async
-
Result holder for a command that was executed asynchronously on multiple nodes.
- AsyncNodeSelection<K,V> - Interface in io.lettuce.core.cluster.api.async
-
Node selection with access to asynchronous executed commands on the set.
- AsyncObjectFactory<T> - Interface in io.lettuce.core.support
-
An interface defining life-cycle methods for instances to be served by an pool.
- AsyncPool<T> - Interface in io.lettuce.core.support
-
- AT_LEAST_JDK_8 - Static variable in class io.lettuce.core.JavaRuntime
-
Constant whether the current JDK is Java 8 or higher.
- auth(String) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- auth(String) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- auth(String) - Method in interface io.lettuce.core.api.async.RedisAsyncCommands
-
Authenticate to the server.
- auth(String) - Method in interface io.lettuce.core.api.reactive.RedisReactiveCommands
-
Authenticate to the server.
- auth(String) - Method in interface io.lettuce.core.api.sync.RedisCommands
-
Authenticate to the server.
- auth(String) - Method in interface io.lettuce.core.cluster.api.async.RedisClusterAsyncCommands
-
Authenticate to the server.
- auth(String) - Method in interface io.lettuce.core.cluster.api.reactive.RedisClusterReactiveCommands
-
Authenticate to the server.
- auth(String) - Method in interface io.lettuce.core.cluster.api.sync.RedisClusterCommands
-
Authenticate to the server.
- auth(CharSequence) - Method in class io.lettuce.core.MigrateArgs
-
Set AUTH password
option.
- auth(char[]) - Method in class io.lettuce.core.MigrateArgs
-
Set AUTH password
option.
- auth(CharSequence) - Static method in class io.lettuce.core.MigrateArgs.Builder
-
Creates new
MigrateArgs
with
AUTH
(target authentication) enabled.
- auth(char[]) - Static method in class io.lettuce.core.MigrateArgs.Builder
-
Creates new
MigrateArgs
with
AUTH
(target authentication) enabled.
- authAsync(char[]) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- autoReconnect(boolean) - Method in class io.lettuce.core.ClientOptions.Builder
-
Enables or disables auto reconnection on connection loss.
- autoReconnect(boolean) - Method in class io.lettuce.core.cluster.ClusterClientOptions.Builder
-
- await(long, TimeUnit) - Method in class io.lettuce.core.protocol.AsyncCommand
-
Wait up to the specified time for the command output to become available.
- await(long, TimeUnit) - Method in interface io.lettuce.core.RedisFuture
-
Wait up to the specified time for the command output to become available.
- awaitAll(Duration, Future<?>...) - Static method in class io.lettuce.core.LettuceFutures
-
Wait until futures are complete or the supplied timeout is reached.
- awaitAll(long, TimeUnit, Future<?>...) - Static method in class io.lettuce.core.LettuceFutures
-
Wait until futures are complete or the supplied timeout is reached.
- awaitOrCancel(RedisFuture<T>, long, TimeUnit) - Static method in class io.lettuce.core.LettuceFutures
-
Wait until futures are complete or the supplied timeout is reached.
- Base16 - Class in io.lettuce.core.codec
-
High-performance base16 (AKA hex) codec.
- BaseNodeSelectionAsyncCommands<K,V> - Interface in io.lettuce.core.cluster.api.async
-
Asynchronous executed commands on a node selection for basic commands.
- BaseNodeSelectionCommands<K,V> - Interface in io.lettuce.core.cluster.api.sync
-
Synchronous executed commands on a node selection for basic commands.
- BasePool - Class in io.lettuce.core.support
-
- BasePool(BasePoolConfig) - Constructor for class io.lettuce.core.support.BasePool
-
- BasePoolConfig - Class in io.lettuce.core.support
-
Base configuration for an object pool declaring options for object validation.
- BasePoolConfig(boolean, boolean, boolean) - Constructor for class io.lettuce.core.support.BasePoolConfig
-
- BasePoolConfig.Builder - Class in io.lettuce.core.support
-
- BaseRedisAsyncCommands<K,V> - Interface in io.lettuce.core.api.async
-
Asynchronous executed commands for basic commands.
- BaseRedisCommandBuilder<K,V> - Class in io.lettuce.core.protocol
-
- BaseRedisCommandBuilder(RedisCodec<K, V>) - Constructor for class io.lettuce.core.protocol.BaseRedisCommandBuilder
-
- BaseRedisCommands<K,V> - Interface in io.lettuce.core.api.sync
-
Synchronous executed commands for basic commands.
- BaseRedisReactiveCommands<K,V> - Interface in io.lettuce.core.api.reactive
-
Reactive executed commands for basic commands.
- batch(RedisCommand<Object, Object, Object>, CommandBatching) - Method in interface io.lettuce.core.dynamic.Batcher
-
- Batcher - Interface in io.lettuce.core.dynamic
-
Command batcher to enqueue commands and flush a batch once a flush is requested or a configured command threshold is reached.
- BatchException - Exception in io.lettuce.core.dynamic.batch
-
Batch exception to collect multiple errors from batched command execution.
- BatchException(List<RedisCommand<?, ?, ?>>) - Constructor for exception io.lettuce.core.dynamic.batch.BatchException
-
- BatchExecutor - Interface in io.lettuce.core.dynamic.batch
-
Batch executor interface to enforce command queue flushing using
BatchSize
.
- BatchSize - Annotation Type in io.lettuce.core.dynamic.batch
-
Redis command method annotation declaring a command interface to use batching with a specified batchSize
.
- before() - Method in class io.lettuce.core.cluster.event.ClusterTopologyChangedEvent
-
Returns the cluster topology view before the topology changed.
- bgrewriteaof() - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- bgrewriteaof() - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- bgrewriteaof() - Method in interface io.lettuce.core.api.async.RedisServerAsyncCommands
-
Asynchronously rewrite the append-only file.
- bgrewriteaof() - Method in interface io.lettuce.core.api.reactive.RedisServerReactiveCommands
-
Asynchronously rewrite the append-only file.
- bgrewriteaof() - Method in interface io.lettuce.core.api.sync.RedisServerCommands
-
Asynchronously rewrite the append-only file.
- bgrewriteaof() - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionServerAsyncCommands
-
Asynchronously rewrite the append-only file.
- bgrewriteaof() - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionServerCommands
-
Asynchronously rewrite the append-only file.
- bgsave() - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- bgsave() - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- bgsave() - Method in interface io.lettuce.core.api.async.RedisServerAsyncCommands
-
Asynchronously save the dataset to disk.
- bgsave() - Method in interface io.lettuce.core.api.reactive.RedisServerReactiveCommands
-
Asynchronously save the dataset to disk.
- bgsave() - Method in interface io.lettuce.core.api.sync.RedisServerCommands
-
Asynchronously save the dataset to disk.
- bgsave() - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionServerAsyncCommands
-
Asynchronously save the dataset to disk.
- bgsave() - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionServerCommands
-
Asynchronously save the dataset to disk.
- bitcount(K) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- bitcount(K, long, long) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- bitcount(K) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- bitcount(K, long, long) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- bitcount(K) - Method in interface io.lettuce.core.api.async.RedisStringAsyncCommands
-
Count set bits in a string.
- bitcount(K, long, long) - Method in interface io.lettuce.core.api.async.RedisStringAsyncCommands
-
Count set bits in a string.
- bitcount(K) - Method in interface io.lettuce.core.api.reactive.RedisStringReactiveCommands
-
Count set bits in a string.
- bitcount(K, long, long) - Method in interface io.lettuce.core.api.reactive.RedisStringReactiveCommands
-
Count set bits in a string.
- bitcount(K) - Method in interface io.lettuce.core.api.sync.RedisStringCommands
-
Count set bits in a string.
- bitcount(K, long, long) - Method in interface io.lettuce.core.api.sync.RedisStringCommands
-
Count set bits in a string.
- bitcount(K) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionStringAsyncCommands
-
Count set bits in a string.
- bitcount(K, long, long) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionStringAsyncCommands
-
Count set bits in a string.
- bitcount(K) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionStringCommands
-
Count set bits in a string.
- bitcount(K, long, long) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionStringCommands
-
Count set bits in a string.
- bitfield(K, BitFieldArgs) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- bitfield(K, BitFieldArgs) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- bitfield(K, BitFieldArgs) - Method in interface io.lettuce.core.api.async.RedisStringAsyncCommands
-
Execute BITFIELD
with its subcommands.
- bitfield(K, BitFieldArgs) - Method in interface io.lettuce.core.api.reactive.RedisStringReactiveCommands
-
Execute BITFIELD
with its subcommands.
- bitfield(K, BitFieldArgs) - Method in interface io.lettuce.core.api.sync.RedisStringCommands
-
Execute BITFIELD
with its subcommands.
- bitfield(K, BitFieldArgs) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionStringAsyncCommands
-
Execute BITFIELD
with its subcommands.
- bitfield(K, BitFieldArgs) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionStringCommands
-
Execute BITFIELD
with its subcommands.
- BitFieldArgs - Class in io.lettuce.core
-
Argument list builder for the Redis
BITFIELD command.
- BitFieldArgs() - Constructor for class io.lettuce.core.BitFieldArgs
-
- BitFieldArgs.BitFieldType - Class in io.lettuce.core
-
Represents a bit field type with details about signed/unsigned and the number of bits.
- BitFieldArgs.Builder - Class in io.lettuce.core
-
- BitFieldArgs.Offset - Class in io.lettuce.core
-
Represents a bit field offset.
- BitFieldArgs.OverflowType - Enum in io.lettuce.core
-
Represents the overflow types for the OVERFLOW
subcommand argument.
- bitopAnd(K, K...) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- bitopAnd(K, K...) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- bitopAnd(K, K...) - Method in interface io.lettuce.core.api.async.RedisStringAsyncCommands
-
Perform bitwise AND between strings.
- bitopAnd(K, K...) - Method in interface io.lettuce.core.api.reactive.RedisStringReactiveCommands
-
Perform bitwise AND between strings.
- bitopAnd(K, K...) - Method in interface io.lettuce.core.api.sync.RedisStringCommands
-
Perform bitwise AND between strings.
- bitopAnd(K, K...) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionStringAsyncCommands
-
Perform bitwise AND between strings.
- bitopAnd(K, K...) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionStringCommands
-
Perform bitwise AND between strings.
- bitopNot(K, K) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- bitopNot(K, K) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- bitopNot(K, K) - Method in interface io.lettuce.core.api.async.RedisStringAsyncCommands
-
Perform bitwise NOT between strings.
- bitopNot(K, K) - Method in interface io.lettuce.core.api.reactive.RedisStringReactiveCommands
-
Perform bitwise NOT between strings.
- bitopNot(K, K) - Method in interface io.lettuce.core.api.sync.RedisStringCommands
-
Perform bitwise NOT between strings.
- bitopNot(K, K) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionStringAsyncCommands
-
Perform bitwise NOT between strings.
- bitopNot(K, K) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionStringCommands
-
Perform bitwise NOT between strings.
- bitopOr(K, K...) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- bitopOr(K, K...) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- bitopOr(K, K...) - Method in interface io.lettuce.core.api.async.RedisStringAsyncCommands
-
Perform bitwise OR between strings.
- bitopOr(K, K...) - Method in interface io.lettuce.core.api.reactive.RedisStringReactiveCommands
-
Perform bitwise OR between strings.
- bitopOr(K, K...) - Method in interface io.lettuce.core.api.sync.RedisStringCommands
-
Perform bitwise OR between strings.
- bitopOr(K, K...) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionStringAsyncCommands
-
Perform bitwise OR between strings.
- bitopOr(K, K...) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionStringCommands
-
Perform bitwise OR between strings.
- bitopXor(K, K...) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- bitopXor(K, K...) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- bitopXor(K, K...) - Method in interface io.lettuce.core.api.async.RedisStringAsyncCommands
-
Perform bitwise XOR between strings.
- bitopXor(K, K...) - Method in interface io.lettuce.core.api.reactive.RedisStringReactiveCommands
-
Perform bitwise XOR between strings.
- bitopXor(K, K...) - Method in interface io.lettuce.core.api.sync.RedisStringCommands
-
Perform bitwise XOR between strings.
- bitopXor(K, K...) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionStringAsyncCommands
-
Perform bitwise XOR between strings.
- bitopXor(K, K...) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionStringCommands
-
Perform bitwise XOR between strings.
- bitpos(K, boolean) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- bitpos(K, boolean, long) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- bitpos(K, boolean, long, long) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- bitpos(K, boolean) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- bitpos(K, boolean, long) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- bitpos(K, boolean, long, long) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- bitpos(K, boolean) - Method in interface io.lettuce.core.api.async.RedisStringAsyncCommands
-
Find first bit set or clear in a string.
- bitpos(K, boolean, long) - Method in interface io.lettuce.core.api.async.RedisStringAsyncCommands
-
Find first bit set or clear in a string.
- bitpos(K, boolean, long, long) - Method in interface io.lettuce.core.api.async.RedisStringAsyncCommands
-
Find first bit set or clear in a string.
- bitpos(K, boolean) - Method in interface io.lettuce.core.api.reactive.RedisStringReactiveCommands
-
Find first bit set or clear in a string.
- bitpos(K, boolean, long) - Method in interface io.lettuce.core.api.reactive.RedisStringReactiveCommands
-
Find first bit set or clear in a string.
- bitpos(K, boolean, long, long) - Method in interface io.lettuce.core.api.reactive.RedisStringReactiveCommands
-
Find first bit set or clear in a string.
- bitpos(K, boolean) - Method in interface io.lettuce.core.api.sync.RedisStringCommands
-
Find first bit set or clear in a string.
- bitpos(K, boolean, long) - Method in interface io.lettuce.core.api.sync.RedisStringCommands
-
Find first bit set or clear in a string.
- bitpos(K, boolean, long, long) - Method in interface io.lettuce.core.api.sync.RedisStringCommands
-
Find first bit set or clear in a string.
- bitpos(K, boolean) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionStringAsyncCommands
-
Find first bit set or clear in a string.
- bitpos(K, boolean, long) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionStringAsyncCommands
-
Find first bit set or clear in a string.
- bitpos(K, boolean, long, long) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionStringAsyncCommands
-
Find first bit set or clear in a string.
- bitpos(K, boolean) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionStringCommands
-
Find first bit set or clear in a string.
- bitpos(K, boolean, long) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionStringCommands
-
Find first bit set or clear in a string.
- bitpos(K, boolean, long, long) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionStringCommands
-
Find first bit set or clear in a string.
- block(long) - Method in class io.lettuce.core.XReadArgs
-
Perform a blocking read and wait up to milliseconds
for a new stream message.
- block(Duration) - Method in class io.lettuce.core.XReadArgs
-
Perform a blocking read and wait up to a
timeout
for a new stream message.
- block(long) - Static method in class io.lettuce.core.XReadArgs.Builder
-
- block(Duration) - Static method in class io.lettuce.core.XReadArgs.Builder
-
- blpop(long, K...) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- blpop(long, K...) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- blpop(long, K...) - Method in interface io.lettuce.core.api.async.RedisListAsyncCommands
-
Remove and get the first element in a list, or block until one is available.
- blpop(long, K...) - Method in interface io.lettuce.core.api.reactive.RedisListReactiveCommands
-
Remove and get the first element in a list, or block until one is available.
- blpop(long, K...) - Method in interface io.lettuce.core.api.sync.RedisListCommands
-
Remove and get the first element in a list, or block until one is available.
- blpop(long, K...) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionListAsyncCommands
-
Remove and get the first element in a list, or block until one is available.
- blpop(long, K...) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionListCommands
-
Remove and get the first element in a list, or block until one is available.
- BooleanListOutput<K,V> - Class in io.lettuce.core.output
-
- BooleanListOutput(RedisCodec<K, V>) - Constructor for class io.lettuce.core.output.BooleanListOutput
-
- BooleanOutput<K,V> - Class in io.lettuce.core.output
-
Boolean output.
- BooleanOutput(RedisCodec<K, V>) - Constructor for class io.lettuce.core.output.BooleanOutput
-
- bootstrap(Bootstrap) - Method in class io.lettuce.core.ConnectionBuilder
-
- bootstrap() - Method in class io.lettuce.core.ConnectionBuilder
-
- bounded(GenericObjectPoolConfig<?>) - Static method in class io.lettuce.core.support.CommonsPool2ConfigConverter
-
- BoundedAsyncPool<T> - Class in io.lettuce.core.support
-
Bounded asynchronous object pool.
- BoundedAsyncPool(AsyncObjectFactory<T>, BoundedPoolConfig) - Constructor for class io.lettuce.core.support.BoundedAsyncPool
-
- BoundedPoolConfig - Class in io.lettuce.core.support
-
- BoundedPoolConfig(boolean, boolean, boolean, int, int, int) - Constructor for class io.lettuce.core.support.BoundedPoolConfig
-
- BoundedPoolConfig.Builder - Class in io.lettuce.core.support
-
- BraveEndpoint(Endpoint) - Constructor for class io.lettuce.core.tracing.BraveTracing.BraveEndpoint
-
- BraveTracing - Class in io.lettuce.core.tracing
-
Tracing
integration with OpenZipkin's Brave
Tracer
.
- BraveTracing.BraveEndpoint - Class in io.lettuce.core.tracing
-
Endpoint
implementation for Zipkin's Endpoint
.
- BraveTracing.BraveTraceContext - Class in io.lettuce.core.tracing
-
- BraveTracing.Builder - Class in io.lettuce.core.tracing
-
- brpop(long, K...) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- brpop(long, K...) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- brpop(long, K...) - Method in interface io.lettuce.core.api.async.RedisListAsyncCommands
-
Remove and get the last element in a list, or block until one is available.
- brpop(long, K...) - Method in interface io.lettuce.core.api.reactive.RedisListReactiveCommands
-
Remove and get the last element in a list, or block until one is available.
- brpop(long, K...) - Method in interface io.lettuce.core.api.sync.RedisListCommands
-
Remove and get the last element in a list, or block until one is available.
- brpop(long, K...) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionListAsyncCommands
-
Remove and get the last element in a list, or block until one is available.
- brpop(long, K...) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionListCommands
-
Remove and get the last element in a list, or block until one is available.
- brpoplpush(long, K, K) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- brpoplpush(long, K, K) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- brpoplpush(long, K, K) - Method in interface io.lettuce.core.api.async.RedisListAsyncCommands
-
Pop a value from a list, push it to another list and return it; or block until one is available.
- brpoplpush(long, K, K) - Method in interface io.lettuce.core.api.reactive.RedisListReactiveCommands
-
Pop a value from a list, push it to another list and return it; or block until one is available.
- brpoplpush(long, K, K) - Method in interface io.lettuce.core.api.sync.RedisListCommands
-
Pop a value from a list, push it to another list and return it; or block until one is available.
- brpoplpush(long, K, K) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionListAsyncCommands
-
Pop a value from a list, push it to another list and return it; or block until one is available.
- brpoplpush(long, K, K) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionListCommands
-
Pop a value from a list, push it to another list and return it; or block until one is available.
- BUF_ALLOCATOR - Static variable in class io.lettuce.core.AbstractRedisClient
-
- buffer(String) - Static method in class io.lettuce.core.protocol.LettuceCharsets
-
Deprecated.
Create a ByteBuffer from a string using ASCII encoding.
- bufferUsageRatio(int) - Method in class io.lettuce.core.ClientOptions.Builder
-
- bufferUsageRatio(int) - Method in class io.lettuce.core.cluster.ClusterClientOptions.Builder
-
- build(CommandArgs<K, V>) - Method in class io.lettuce.core.BitFieldArgs
-
- build() - Method in class io.lettuce.core.ClientOptions.Builder
-
- build() - Method in class io.lettuce.core.cluster.ClusterClientOptions.Builder
-
- build() - Method in class io.lettuce.core.cluster.ClusterTopologyRefreshOptions.Builder
-
- build(CommandArgs<K, V>) - Method in interface io.lettuce.core.CompositeArgument
-
Build command arguments and contribute arguments to
CommandArgs
.
- build() - Method in class io.lettuce.core.ConnectionBuilder
-
- build(SocketAddress) - Method in class io.lettuce.core.ConnectionBuilder
-
- build() - Method in class io.lettuce.core.event.DefaultEventPublisherOptions.Builder
-
- build(CommandArgs<K, V>) - Method in class io.lettuce.core.GeoArgs
-
- build(CommandArgs<K, V>) - Method in class io.lettuce.core.GeoRadiusStoreArgs
-
- build(CommandArgs<K, V>) - Method in class io.lettuce.core.KillArgs
-
- build() - Method in interface io.lettuce.core.metrics.CommandLatencyCollectorOptions.Builder
-
- build() - Method in class io.lettuce.core.metrics.DefaultCommandLatencyCollectorOptions.Builder
-
- build(CommandArgs<K, V>) - Method in class io.lettuce.core.MigrateArgs
-
- build() - Method in class io.lettuce.core.RedisURI.Builder
-
- build() - Method in interface io.lettuce.core.resource.ClientResources.Builder
-
- build() - Method in class io.lettuce.core.resource.DefaultClientResources.Builder
-
- build(CommandArgs<K, V>) - Method in class io.lettuce.core.ScanArgs
-
- build(CommandArgs<K, V>) - Method in class io.lettuce.core.SetArgs
-
- build() - Method in class io.lettuce.core.SocketOptions.Builder
-
- build(CommandArgs<K, V>) - Method in class io.lettuce.core.SortArgs
-
- build() - Method in class io.lettuce.core.SslConnectionBuilder
-
Deprecated.
- build(SocketAddress) - Method in class io.lettuce.core.SslConnectionBuilder
-
- build() - Method in class io.lettuce.core.SslOptions.Builder
-
- build() - Method in class io.lettuce.core.support.BoundedPoolConfig.Builder
-
- build() - Method in class io.lettuce.core.TimeoutOptions.Builder
-
- build() - Method in class io.lettuce.core.tracing.BraveTracing.Builder
-
- build(CommandArgs<K, V>) - Method in class io.lettuce.core.XAddArgs
-
- build(CommandArgs<K, V>) - Method in class io.lettuce.core.XClaimArgs
-
- build(CommandArgs<K, V>) - Method in class io.lettuce.core.XGroupCreateArgs
-
- build(CommandArgs<K, V>) - Method in class io.lettuce.core.XReadArgs
-
- build(CommandArgs<K, V>) - Method in class io.lettuce.core.ZAddArgs
-
- build(CommandArgs<K, V>) - Method in class io.lettuce.core.ZStoreArgs
-
- builder() - Static method in class io.lettuce.core.ClientOptions
-
- Builder() - Constructor for class io.lettuce.core.ClientOptions.Builder
-
- builder() - Static method in class io.lettuce.core.cluster.ClusterClientOptions
-
- builder(ClientOptions) - Static method in class io.lettuce.core.cluster.ClusterClientOptions
-
- Builder() - Constructor for class io.lettuce.core.cluster.ClusterClientOptions.Builder
-
- builder() - Static method in class io.lettuce.core.cluster.ClusterTopologyRefreshOptions
-
- builder() - Static method in class io.lettuce.core.event.DefaultEventPublisherOptions
-
- builder() - Static method in interface io.lettuce.core.metrics.CommandLatencyCollectorOptions
-
- builder() - Static method in class io.lettuce.core.metrics.DefaultCommandLatencyCollectorOptions
-
- builder() - Static method in class io.lettuce.core.RedisURI
-
- builder() - Static method in interface io.lettuce.core.resource.ClientResources
-
- builder() - Static method in class io.lettuce.core.resource.DefaultClientResources
-
- builder() - Static method in class io.lettuce.core.SocketOptions
-
- builder() - Static method in class io.lettuce.core.SslOptions
-
- Builder() - Constructor for class io.lettuce.core.support.BasePoolConfig.Builder
-
- builder() - Static method in class io.lettuce.core.support.BoundedPoolConfig
-
- Builder() - Constructor for class io.lettuce.core.support.BoundedPoolConfig.Builder
-
- builder() - Static method in class io.lettuce.core.TimeoutOptions
-
- Builder() - Constructor for class io.lettuce.core.TimeoutOptions.Builder
-
- builder() - Static method in class io.lettuce.core.tracing.BraveTracing
-
- buildHandlers() - Method in class io.lettuce.core.ConnectionBuilder
-
- buildHandlers() - Method in class io.lettuce.core.SslConnectionBuilder
-
- by(String) - Static method in class io.lettuce.core.SortArgs.Builder
-
- by(String) - Method in class io.lettuce.core.SortArgs
-
Sort keys by an external list.
- ByteArrayCodec - Class in io.lettuce.core.codec
-
A
RedisCodec
that uses plain byte arrays without further transformations.
- ByteArrayCodec() - Constructor for class io.lettuce.core.codec.ByteArrayCodec
-
- ByteArrayOutput<K,V> - Class in io.lettuce.core.output
-
Byte array output.
- ByteArrayOutput(RedisCodec<K, V>) - Constructor for class io.lettuce.core.output.ByteArrayOutput
-
- bytes - Variable in enum io.lettuce.core.BitFieldArgs.OverflowType
-
- bytes - Variable in enum io.lettuce.core.protocol.CommandKeyword
-
- bytes - Variable in enum io.lettuce.core.protocol.CommandType
-
- bzpopmax(long, K...) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- bzpopmax(long, K...) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- bzpopmax(long, K...) - Method in interface io.lettuce.core.api.async.RedisSortedSetAsyncCommands
-
Removes and returns a member with the highest scores in the sorted set stored at one of the keys.
- bzpopmax(long, K...) - Method in interface io.lettuce.core.api.reactive.RedisSortedSetReactiveCommands
-
Removes and returns a member with the highest scores in the sorted set stored at one of the keys.
- bzpopmax(long, K...) - Method in interface io.lettuce.core.api.sync.RedisSortedSetCommands
-
Removes and returns a member with the highest scores in the sorted set stored at one of the keys.
- bzpopmax(long, K...) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionSortedSetAsyncCommands
-
Removes and returns a member with the highest scores in the sorted set stored at one of the keys.
- bzpopmax(long, K...) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionSortedSetCommands
-
Removes and returns a member with the highest scores in the sorted set stored at one of the keys.
- bzpopmin(long, K...) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- bzpopmin(long, K...) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- bzpopmin(long, K...) - Method in interface io.lettuce.core.api.async.RedisSortedSetAsyncCommands
-
Removes and returns a member with the lowest scores in the sorted set stored at one of the keys.
- bzpopmin(long, K...) - Method in interface io.lettuce.core.api.reactive.RedisSortedSetReactiveCommands
-
Removes and returns a member with the lowest scores in the sorted set stored at one of the keys.
- bzpopmin(long, K...) - Method in interface io.lettuce.core.api.sync.RedisSortedSetCommands
-
Removes and returns a member with the lowest scores in the sorted set stored at one of the keys.
- bzpopmin(long, K...) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionSortedSetAsyncCommands
-
Removes and returns a member with the lowest scores in the sorted set stored at one of the keys.
- bzpopmin(long, K...) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionSortedSetCommands
-
Removes and returns a member with the lowest scores in the sorted set stored at one of the keys.
- cancel() - Method in class io.lettuce.core.output.MultiOutput
-
- cancel(boolean) - Method in class io.lettuce.core.protocol.AsyncCommand
-
- cancel() - Method in class io.lettuce.core.protocol.AsyncCommand
-
- cancel() - Method in class io.lettuce.core.protocol.Command
-
- cancel() - Method in class io.lettuce.core.protocol.CommandWrapper
-
- cancel() - Method in interface io.lettuce.core.protocol.RedisCommand
-
Cancel a command.
- cancelCommandsOnReconnectFailure(boolean) - Method in class io.lettuce.core.ClientOptions.Builder
-
Allows cancelling queued commands in case a reconnect fails.Defaults to false.
- cancelCommandsOnReconnectFailure(boolean) - Method in class io.lettuce.core.cluster.ClusterClientOptions.Builder
-
- canComplete(RedisCommand<?, ?, ?>) - Method in class io.lettuce.core.protocol.CommandHandler
-
Decoding hook: Can the command be completed.
- canComplete(RedisCommand<?, ?, ?>) - Method in class io.lettuce.core.pubsub.PubSubCommandHandler
-
- canConsume(Parameter) - Method in class io.lettuce.core.dynamic.segment.CommandSegment
-
Check whether this segment can consume the
Parameter
by applying parameter substitution.
- canDecode(ByteBuf) - Method in class io.lettuce.core.protocol.CommandHandler
-
Decoding hook: Can the buffer be decoded to a command.
- canDecode(ByteBuf) - Method in class io.lettuce.core.pubsub.PubSubCommandHandler
-
- CGLIB_CLASS_SEPARATOR - Static variable in class io.lettuce.core.internal.LettuceClassUtils
-
The CGLIB class separator character "$$"
- ch() - Static method in class io.lettuce.core.ZAddArgs.Builder
-
- ch() - Method in class io.lettuce.core.ZAddArgs
-
Modify the return value from the number of new elements added, to the total number of elements changed.
- channel - Variable in class io.lettuce.core.protocol.DefaultEndpoint
-
- channel() - Method in class io.lettuce.core.pubsub.PubSubOutput
-
- channelActive(ChannelHandlerContext) - Method in class io.lettuce.core.protocol.CommandHandler
-
- channelActive(ChannelHandlerContext) - Method in class io.lettuce.core.protocol.ConnectionWatchdog
-
- channelGroup(ChannelGroup) - Method in class io.lettuce.core.ConnectionBuilder
-
- channelInactive(ChannelHandlerContext) - Method in class io.lettuce.core.protocol.CommandHandler
-
- channelInactive(ChannelHandlerContext) - Method in class io.lettuce.core.protocol.ConnectionWatchdog
-
- channelInactive(ChannelHandlerContext) - Method in class io.lettuce.core.pubsub.PubSubCommandHandler
-
- channelInitialized() - Method in interface io.lettuce.core.RedisChannelInitializer
-
- ChannelMessage<K,V> - Class in io.lettuce.core.pubsub.api.reactive
-
Message payload for a subscription to a channel.
- ChannelMessage(K, V) - Constructor for class io.lettuce.core.pubsub.api.reactive.ChannelMessage
-
- channelRead(ChannelHandlerContext, Object) - Method in class io.lettuce.core.protocol.CommandHandler
-
- channelRegistered(ChannelHandlerContext) - Method in class io.lettuce.core.protocol.CommandHandler
-
- channels - Variable in class io.lettuce.core.AbstractRedisClient
-
- channelType(ConnectionBuilder, ConnectionPoint) - Method in class io.lettuce.core.AbstractRedisClient
-
- channelUnregistered(ChannelHandlerContext) - Method in class io.lettuce.core.protocol.CommandHandler
-
- CipherCodec - Class in io.lettuce.core.codec
-
A crypto
RedisCodec
that that allows transparent encryption/decryption of values.
- CipherCodec.CipherSupplier - Interface in io.lettuce.core.codec
-
Represents a supplier of
Cipher
.
- CipherCodec.KeyDescriptor - Class in io.lettuce.core.codec
-
Descriptor to determine which crypto key to use.
- cipherSuites(String...) - Method in class io.lettuce.core.SslOptions.Builder
-
Sets the cipher suites to use.
- ClassTypeInformation<S> - Class in io.lettuce.core.dynamic.support
-
- clear() - Method in class io.lettuce.core.cluster.models.partitions.Partitions
-
Removes all
nodes
and update the read-view/caches.
- clear() - Method in interface io.lettuce.core.support.AsyncPool
-
Clear the pool.
- clear() - Method in class io.lettuce.core.support.BoundedAsyncPool
-
- clearAsync() - Method in interface io.lettuce.core.support.AsyncPool
-
Clear the pool.
- clearAsync() - Method in class io.lettuce.core.support.BoundedAsyncPool
-
- clearContext() - Static method in interface io.lettuce.core.tracing.Tracing
-
Clears the
Mono<TracerProvider>
from Reactor
Context
.
- clientGetname() - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- clientGetname() - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- clientGetname() - Method in interface io.lettuce.core.api.async.RedisServerAsyncCommands
-
Get the current connection name.
- clientGetname() - Method in interface io.lettuce.core.api.reactive.RedisServerReactiveCommands
-
Get the current connection name.
- clientGetname() - Method in interface io.lettuce.core.api.sync.RedisServerCommands
-
Get the current connection name.
- clientGetname() - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionServerAsyncCommands
-
Get the current connection name.
- clientGetname() - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionServerCommands
-
Get the current connection name.
- clientGetname() - Method in interface io.lettuce.core.sentinel.api.async.RedisSentinelAsyncCommands
-
Get the current connection name.
- clientGetname() - Method in interface io.lettuce.core.sentinel.api.reactive.RedisSentinelReactiveCommands
-
Get the current connection name.
- clientGetname() - Method in interface io.lettuce.core.sentinel.api.sync.RedisSentinelCommands
-
Get the current connection name.
- clientGetname() - Method in class io.lettuce.core.sentinel.RedisSentinelAsyncCommandsImpl
-
- clientGetname() - Method in class io.lettuce.core.sentinel.RedisSentinelReactiveCommandsImpl
-
- clientId() - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- clientId() - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- clientId() - Method in interface io.lettuce.core.api.async.RedisServerAsyncCommands
-
Get the id of the current connection.
- clientId() - Method in interface io.lettuce.core.api.reactive.RedisServerReactiveCommands
-
Get the id of the current connection.
- clientId() - Method in interface io.lettuce.core.api.sync.RedisServerCommands
-
Get the id of the current connection.
- clientId() - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionServerAsyncCommands
-
Get the id of the current connection.
- clientId() - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionServerCommands
-
Get the id of the current connection.
- clientKill(String) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- clientKill(KillArgs) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- clientKill(String) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- clientKill(KillArgs) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- clientKill(String) - Method in interface io.lettuce.core.api.async.RedisServerAsyncCommands
-
Kill the connection of a client identified by ip:port.
- clientKill(KillArgs) - Method in interface io.lettuce.core.api.async.RedisServerAsyncCommands
-
Kill connections of clients which are filtered by killArgs
- clientKill(String) - Method in interface io.lettuce.core.api.reactive.RedisServerReactiveCommands
-
Kill the connection of a client identified by ip:port.
- clientKill(KillArgs) - Method in interface io.lettuce.core.api.reactive.RedisServerReactiveCommands
-
Kill connections of clients which are filtered by killArgs
- clientKill(String) - Method in interface io.lettuce.core.api.sync.RedisServerCommands
-
Kill the connection of a client identified by ip:port.
- clientKill(KillArgs) - Method in interface io.lettuce.core.api.sync.RedisServerCommands
-
Kill connections of clients which are filtered by killArgs
- clientKill(String) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionServerAsyncCommands
-
Kill the connection of a client identified by ip:port.
- clientKill(KillArgs) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionServerAsyncCommands
-
Kill connections of clients which are filtered by killArgs
- clientKill(String) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionServerCommands
-
Kill the connection of a client identified by ip:port.
- clientKill(KillArgs) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionServerCommands
-
Kill connections of clients which are filtered by killArgs
- clientKill(String) - Method in interface io.lettuce.core.sentinel.api.async.RedisSentinelAsyncCommands
-
Kill the connection of a client identified by ip:port.
- clientKill(KillArgs) - Method in interface io.lettuce.core.sentinel.api.async.RedisSentinelAsyncCommands
-
Kill connections of clients which are filtered by killArgs
- clientKill(String) - Method in interface io.lettuce.core.sentinel.api.reactive.RedisSentinelReactiveCommands
-
Kill the connection of a client identified by ip:port.
- clientKill(KillArgs) - Method in interface io.lettuce.core.sentinel.api.reactive.RedisSentinelReactiveCommands
-
Kill connections of clients which are filtered by killArgs
- clientKill(String) - Method in interface io.lettuce.core.sentinel.api.sync.RedisSentinelCommands
-
Kill the connection of a client identified by ip:port.
- clientKill(KillArgs) - Method in interface io.lettuce.core.sentinel.api.sync.RedisSentinelCommands
-
Kill connections of clients which are filtered by killArgs
- clientKill(String) - Method in class io.lettuce.core.sentinel.RedisSentinelAsyncCommandsImpl
-
- clientKill(KillArgs) - Method in class io.lettuce.core.sentinel.RedisSentinelAsyncCommandsImpl
-
- clientKill(String) - Method in class io.lettuce.core.sentinel.RedisSentinelReactiveCommandsImpl
-
- clientKill(KillArgs) - Method in class io.lettuce.core.sentinel.RedisSentinelReactiveCommandsImpl
-
- clientList() - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- clientList() - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- clientList() - Method in interface io.lettuce.core.api.async.RedisServerAsyncCommands
-
Get the list of client connections.
- clientList() - Method in interface io.lettuce.core.api.reactive.RedisServerReactiveCommands
-
Get the list of client connections.
- clientList() - Method in interface io.lettuce.core.api.sync.RedisServerCommands
-
Get the list of client connections.
- clientList() - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionServerAsyncCommands
-
Get the list of client connections.
- clientList() - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionServerCommands
-
Get the list of client connections.
- clientList() - Method in interface io.lettuce.core.sentinel.api.async.RedisSentinelAsyncCommands
-
Get the list of client connections.
- clientList() - Method in interface io.lettuce.core.sentinel.api.reactive.RedisSentinelReactiveCommands
-
Get the list of client connections.
- clientList() - Method in interface io.lettuce.core.sentinel.api.sync.RedisSentinelCommands
-
Get the list of client connections.
- clientList() - Method in class io.lettuce.core.sentinel.RedisSentinelAsyncCommandsImpl
-
- clientList() - Method in class io.lettuce.core.sentinel.RedisSentinelReactiveCommandsImpl
-
- clientOptions - Variable in class io.lettuce.core.AbstractRedisClient
-
- ClientOptions - Class in io.lettuce.core
-
- ClientOptions(ClientOptions.Builder) - Constructor for class io.lettuce.core.ClientOptions
-
- ClientOptions(ClientOptions) - Constructor for class io.lettuce.core.ClientOptions
-
- clientOptions(ClientOptions) - Method in class io.lettuce.core.ConnectionBuilder
-
- clientOptions() - Method in class io.lettuce.core.ConnectionBuilder
-
- ClientOptions.Builder - Class in io.lettuce.core
-
- ClientOptions.DisconnectedBehavior - Enum in io.lettuce.core
-
Behavior of connections in disconnected state.
- clientPause(long) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- clientPause(long) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- clientPause(long) - Method in interface io.lettuce.core.api.async.RedisServerAsyncCommands
-
Stop processing commands from clients for some time.
- clientPause(long) - Method in interface io.lettuce.core.api.reactive.RedisServerReactiveCommands
-
Stop processing commands from clients for some time.
- clientPause(long) - Method in interface io.lettuce.core.api.sync.RedisServerCommands
-
Stop processing commands from clients for some time.
- clientPause(long) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionServerAsyncCommands
-
Stop processing commands from clients for some time.
- clientPause(long) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionServerCommands
-
Stop processing commands from clients for some time.
- clientPause(long) - Method in interface io.lettuce.core.sentinel.api.async.RedisSentinelAsyncCommands
-
Stop processing commands from clients for some time.
- clientPause(long) - Method in interface io.lettuce.core.sentinel.api.reactive.RedisSentinelReactiveCommands
-
Stop processing commands from clients for some time.
- clientPause(long) - Method in interface io.lettuce.core.sentinel.api.sync.RedisSentinelCommands
-
Stop processing commands from clients for some time.
- clientPause(long) - Method in class io.lettuce.core.sentinel.RedisSentinelAsyncCommandsImpl
-
- clientPause(long) - Method in class io.lettuce.core.sentinel.RedisSentinelReactiveCommandsImpl
-
- clientResources - Variable in class io.lettuce.core.AbstractRedisClient
-
- clientResources(ClientResources) - Method in class io.lettuce.core.ConnectionBuilder
-
- clientResources() - Method in class io.lettuce.core.ConnectionBuilder
-
- ClientResources - Interface in io.lettuce.core.resource
-
Strategy interface to provide all the infrastructure building blocks like environment settings and thread pools so that the
client can work with it properly.
- ClientResources.Builder - Interface in io.lettuce.core.resource
-
- ClientResourcesFactoryBean - Class in io.lettuce.core.support
-
- ClientResourcesFactoryBean() - Constructor for class io.lettuce.core.support.ClientResourcesFactoryBean
-
- clientSetname(K) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- clientSetname(K) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- clientSetname(K) - Method in interface io.lettuce.core.api.async.RedisServerAsyncCommands
-
Set the current connection name.
- clientSetname(K) - Method in interface io.lettuce.core.api.reactive.RedisServerReactiveCommands
-
Set the current connection name.
- clientSetname(K) - Method in interface io.lettuce.core.api.sync.RedisServerCommands
-
Set the current connection name.
- clientSetname(K) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionServerAsyncCommands
-
Set the current connection name.
- clientSetname(K) - Method in interface io.lettuce.core.cluster.api.async.RedisAdvancedClusterAsyncCommands
-
Set the current connection name on all cluster nodes with pipelining.
- clientSetname(K) - Method in interface io.lettuce.core.cluster.api.reactive.RedisAdvancedClusterReactiveCommands
-
Set the current connection name on all cluster nodes with pipelining.
- clientSetname(K) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionServerCommands
-
Set the current connection name.
- clientSetname(K) - Method in interface io.lettuce.core.cluster.api.sync.RedisAdvancedClusterCommands
-
Set the current connection name on all known cluster nodes with pipelining.
- clientSetname(K) - Method in class io.lettuce.core.cluster.RedisAdvancedClusterAsyncCommandsImpl
-
- clientSetname(K) - Method in class io.lettuce.core.cluster.RedisAdvancedClusterReactiveCommandsImpl
-
- clientSetname(K) - Method in interface io.lettuce.core.sentinel.api.async.RedisSentinelAsyncCommands
-
Set the current connection name.
- clientSetname(K) - Method in interface io.lettuce.core.sentinel.api.reactive.RedisSentinelReactiveCommands
-
Set the current connection name.
- clientSetname(K) - Method in interface io.lettuce.core.sentinel.api.sync.RedisSentinelCommands
-
Set the current connection name.
- clientSetname(K) - Method in class io.lettuce.core.sentinel.RedisSentinelAsyncCommandsImpl
-
- clientSetname(K) - Method in class io.lettuce.core.sentinel.RedisSentinelReactiveCommandsImpl
-
- clientUnblock(long, UnblockType) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- clientUnblock(long, UnblockType) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- clientUnblock(long, UnblockType) - Method in interface io.lettuce.core.api.async.RedisServerAsyncCommands
-
Unblock the specified blocked client.
- clientUnblock(long, UnblockType) - Method in interface io.lettuce.core.api.reactive.RedisServerReactiveCommands
-
Unblock the specified blocked client.
- clientUnblock(long, UnblockType) - Method in interface io.lettuce.core.api.sync.RedisServerCommands
-
Unblock the specified blocked client.
- clientUnblock(long, UnblockType) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionServerAsyncCommands
-
Unblock the specified blocked client.
- clientUnblock(long, UnblockType) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionServerCommands
-
Unblock the specified blocked client.
- clone() - Method in class io.lettuce.core.cluster.models.partitions.Partitions
-
- clone() - Method in class io.lettuce.core.cluster.models.partitions.RedisClusterNode
-
- close() - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- close() - Method in interface io.lettuce.core.api.StatefulConnection
-
Close the connection.
- close() - Method in class io.lettuce.core.internal.AsyncConnectionProvider
-
Close all connections.
- close(K) - Method in class io.lettuce.core.internal.AsyncConnectionProvider
-
Close a connection by its connection key
.
- close() - Method in class io.lettuce.core.masterslave.MasterSlaveConnectionProvider
-
Deprecated.
Close all connections.
- close() - Method in class io.lettuce.core.protocol.CommandExpiryWriter
-
- close() - Method in class io.lettuce.core.protocol.DefaultEndpoint
-
Close the connection.
- close() - Method in class io.lettuce.core.protocol.RedisStateMachine
-
Close the state machine to free resources.
- close() - Method in class io.lettuce.core.RedisChannelHandler
-
Close the connection (synchronous).
- close() - Method in interface io.lettuce.core.RedisChannelWriter
-
- close() - Method in class io.lettuce.core.resource.DirContextDnsResolver
-
- close() - Method in class io.lettuce.core.sentinel.RedisSentinelAsyncCommandsImpl
-
- close() - Method in class io.lettuce.core.sentinel.RedisSentinelReactiveCommandsImpl
-
- close() - Method in interface io.lettuce.core.support.AsyncPool
-
- close() - Method in class io.lettuce.core.support.BoundedAsyncPool
-
- closeableResources - Variable in class io.lettuce.core.AbstractRedisClient
-
- closeAsync() - Method in interface io.lettuce.core.api.StatefulConnection
-
Request to close the connection and return the
CompletableFuture
that is notified about its progress.
- closeAsync() - Method in interface io.lettuce.core.internal.AsyncCloseable
-
Requests to close this object and releases any system resources associated with it.
- closeAsync() - Method in class io.lettuce.core.masterslave.MasterSlaveConnectionProvider
-
Deprecated.
Close all connections asynchronously.
- closeAsync() - Method in class io.lettuce.core.protocol.CommandExpiryWriter
-
- closeAsync() - Method in class io.lettuce.core.protocol.DefaultEndpoint
-
- closeAsync() - Method in class io.lettuce.core.RedisChannelHandler
-
Close the connection (asynchronous).
- closeAsync() - Method in interface io.lettuce.core.RedisChannelWriter
-
- closeAsync() - Method in interface io.lettuce.core.support.AsyncPool
-
- closeAsync() - Method in class io.lettuce.core.support.BoundedAsyncPool
-
- closeStaleConnections(boolean) - Method in class io.lettuce.core.cluster.ClusterTopologyRefreshOptions.Builder
-
Flag, whether to close stale connections when refreshing the cluster topology.
- closeStaleConnections() - Method in class io.lettuce.core.masterslave.MasterSlaveConnectionProvider
-
Deprecated.
Close stale connections.
- clusterAddSlots(int...) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- clusterAddSlots(int...) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- clusterAddSlots(int...) - Method in interface io.lettuce.core.cluster.api.async.RedisClusterAsyncCommands
-
Adds slots to the cluster node.
- clusterAddSlots(int...) - Method in interface io.lettuce.core.cluster.api.reactive.RedisClusterReactiveCommands
-
Adds slots to the cluster node.
- clusterAddSlots(int...) - Method in interface io.lettuce.core.cluster.api.sync.RedisClusterCommands
-
Adds slots to the cluster node.
- clusterBumpepoch() - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- clusterBumpepoch() - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- clusterBumpepoch() - Method in interface io.lettuce.core.cluster.api.async.RedisClusterAsyncCommands
-
Generate a new config epoch, incrementing the current epoch, assign the new epoch to this node, WITHOUT any consensus and
persist the configuration on disk before sending packets with the new configuration.
- clusterBumpepoch() - Method in interface io.lettuce.core.cluster.api.reactive.RedisClusterReactiveCommands
-
Generate a new config epoch, incrementing the current epoch, assign the new epoch to this node, WITHOUT any consensus and
persist the configuration on disk before sending packets with the new configuration.
- clusterBumpepoch() - Method in interface io.lettuce.core.cluster.api.sync.RedisClusterCommands
-
Generate a new config epoch, incrementing the current epoch, assign the new epoch to this node, WITHOUT any consensus and
persist the configuration on disk before sending packets with the new configuration.
- ClusterClientOptions - Class in io.lettuce.core.cluster
-
- ClusterClientOptions(ClusterClientOptions.Builder) - Constructor for class io.lettuce.core.cluster.ClusterClientOptions
-
- ClusterClientOptions(ClusterClientOptions) - Constructor for class io.lettuce.core.cluster.ClusterClientOptions
-
- ClusterClientOptions.Builder - Class in io.lettuce.core.cluster
-
- clusterCountFailureReports(String) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- clusterCountFailureReports(String) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- clusterCountFailureReports(String) - Method in interface io.lettuce.core.cluster.api.async.RedisClusterAsyncCommands
-
Returns the number of failure reports for the specified node.
- clusterCountFailureReports(String) - Method in interface io.lettuce.core.cluster.api.reactive.RedisClusterReactiveCommands
-
Returns the number of failure reports for the specified node.
- clusterCountFailureReports(String) - Method in interface io.lettuce.core.cluster.api.sync.RedisClusterCommands
-
Returns the number of failure reports for the specified node.
- clusterCountKeysInSlot(int) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- clusterCountKeysInSlot(int) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- clusterCountKeysInSlot(int) - Method in interface io.lettuce.core.cluster.api.async.RedisClusterAsyncCommands
-
Returns the number of keys in the specified Redis Cluster hash slot
.
- clusterCountKeysInSlot(int) - Method in interface io.lettuce.core.cluster.api.reactive.RedisClusterReactiveCommands
-
Returns the number of keys in the specified Redis Cluster hash slot
.
- clusterCountKeysInSlot(int) - Method in interface io.lettuce.core.cluster.api.sync.RedisClusterCommands
-
Returns the number of keys in the specified Redis Cluster hash slot
.
- clusterCountKeysInSlot(int) - Method in class io.lettuce.core.cluster.RedisAdvancedClusterAsyncCommandsImpl
-
- clusterCountKeysInSlot(int) - Method in class io.lettuce.core.cluster.RedisAdvancedClusterReactiveCommandsImpl
-
- clusterDelSlots(int...) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- clusterDelSlots(int...) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- clusterDelSlots(int...) - Method in interface io.lettuce.core.cluster.api.async.RedisClusterAsyncCommands
-
Removes slots from the cluster node.
- clusterDelSlots(int...) - Method in interface io.lettuce.core.cluster.api.reactive.RedisClusterReactiveCommands
-
Removes slots from the cluster node.
- clusterDelSlots(int...) - Method in interface io.lettuce.core.cluster.api.sync.RedisClusterCommands
-
Removes slots from the cluster node.
- clusterFailover(boolean) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- clusterFailover(boolean) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- clusterFailover(boolean) - Method in interface io.lettuce.core.cluster.api.async.RedisClusterAsyncCommands
-
Failover a cluster node.
- clusterFailover(boolean) - Method in interface io.lettuce.core.cluster.api.reactive.RedisClusterReactiveCommands
-
Failover a cluster node.
- clusterFailover(boolean) - Method in interface io.lettuce.core.cluster.api.sync.RedisClusterCommands
-
Failover a cluster node.
- clusterFlushslots() - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- clusterFlushslots() - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- clusterFlushslots() - Method in interface io.lettuce.core.cluster.api.async.RedisClusterAsyncCommands
-
Delete all the slots associated with the specified node.
- clusterFlushslots() - Method in interface io.lettuce.core.cluster.api.reactive.RedisClusterReactiveCommands
-
Delete all the slots associated with the specified node.
- clusterFlushslots() - Method in interface io.lettuce.core.cluster.api.sync.RedisClusterCommands
-
Delete all the slots associated with the specified node.
- clusterForget(String) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- clusterForget(String) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- clusterForget(String) - Method in interface io.lettuce.core.cluster.api.async.RedisClusterAsyncCommands
-
Blacklist and remove the cluster node from the cluster.
- clusterForget(String) - Method in interface io.lettuce.core.cluster.api.reactive.RedisClusterReactiveCommands
-
Blacklist and remove the cluster node from the cluster.
- clusterForget(String) - Method in interface io.lettuce.core.cluster.api.sync.RedisClusterCommands
-
Blacklist and remove the cluster node from the cluster.
- clusterGetKeysInSlot(int, int) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- clusterGetKeysInSlot(int, int) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- clusterGetKeysInSlot(int, int) - Method in interface io.lettuce.core.cluster.api.async.RedisClusterAsyncCommands
-
Retrieve the list of keys within the slot
.
- clusterGetKeysInSlot(int, int) - Method in interface io.lettuce.core.cluster.api.reactive.RedisClusterReactiveCommands
-
Retrieve the list of keys within the slot
.
- clusterGetKeysInSlot(int, int) - Method in interface io.lettuce.core.cluster.api.sync.RedisClusterCommands
-
Retrieve the list of keys within the slot
.
- clusterGetKeysInSlot(int, int) - Method in class io.lettuce.core.cluster.RedisAdvancedClusterAsyncCommandsImpl
-
- clusterGetKeysInSlot(int, int) - Method in class io.lettuce.core.cluster.RedisAdvancedClusterReactiveCommandsImpl
-
- clusterInfo() - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- clusterInfo() - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- clusterInfo() - Method in interface io.lettuce.core.cluster.api.async.RedisClusterAsyncCommands
-
Get information and statistics about the cluster viewed by the current node.
- clusterInfo() - Method in interface io.lettuce.core.cluster.api.reactive.RedisClusterReactiveCommands
-
Get information and statistics about the cluster viewed by the current node.
- clusterInfo() - Method in interface io.lettuce.core.cluster.api.sync.RedisClusterCommands
-
Get information and statistics about the cluster viewed by the current node.
- clusterKeyslot(K) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- clusterKeyslot(K) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- clusterKeyslot(K) - Method in interface io.lettuce.core.cluster.api.async.RedisClusterAsyncCommands
-
Returns an integer identifying the hash slot the specified key hashes to.
- clusterKeyslot(K) - Method in interface io.lettuce.core.cluster.api.reactive.RedisClusterReactiveCommands
-
Returns an integer identifying the hash slot the specified key hashes to.
- clusterKeyslot(K) - Method in interface io.lettuce.core.cluster.api.sync.RedisClusterCommands
-
Returns an integer identifying the hash slot the specified key hashes to.
- clusterMeet(String, int) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- clusterMeet(String, int) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- clusterMeet(String, int) - Method in interface io.lettuce.core.cluster.api.async.RedisClusterAsyncCommands
-
Meet another cluster node to include the node into the cluster.
- clusterMeet(String, int) - Method in interface io.lettuce.core.cluster.api.reactive.RedisClusterReactiveCommands
-
Meet another cluster node to include the node into the cluster.
- clusterMeet(String, int) - Method in interface io.lettuce.core.cluster.api.sync.RedisClusterCommands
-
Meet another cluster node to include the node into the cluster.
- clusterMyId() - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- clusterMyId() - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- clusterMyId() - Method in interface io.lettuce.core.cluster.api.async.RedisClusterAsyncCommands
-
Obtain the nodeId for the currently connected node.
- clusterMyId() - Method in interface io.lettuce.core.cluster.api.reactive.RedisClusterReactiveCommands
-
Obtain the nodeId for the currently connected node.
- clusterMyId() - Method in interface io.lettuce.core.cluster.api.sync.RedisClusterCommands
-
Obtain the nodeId for the currently connected node.
- clusterNodes() - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- clusterNodes() - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- clusterNodes() - Method in interface io.lettuce.core.cluster.api.async.RedisClusterAsyncCommands
-
Obtain details about all cluster nodes.
- clusterNodes() - Method in interface io.lettuce.core.cluster.api.reactive.RedisClusterReactiveCommands
-
Obtain details about all cluster nodes.
- clusterNodes() - Method in interface io.lettuce.core.cluster.api.sync.RedisClusterCommands
-
Obtain details about all cluster nodes.
- ClusterPartitionParser - Class in io.lettuce.core.cluster.models.partitions
-
Parser for node information output of CLUSTER NODES
and CLUSTER SLAVES
.
- clusterReplicate(String) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- clusterReplicate(String) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- clusterReplicate(String) - Method in interface io.lettuce.core.cluster.api.async.RedisClusterAsyncCommands
-
Turn this node into a replica of the node with the id nodeId
.
- clusterReplicate(String) - Method in interface io.lettuce.core.cluster.api.reactive.RedisClusterReactiveCommands
-
Turn this node into a replica of the node with the id nodeId
.
- clusterReplicate(String) - Method in interface io.lettuce.core.cluster.api.sync.RedisClusterCommands
-
Turn this node into a replica of the node with the id nodeId
.
- clusterReset(boolean) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- clusterReset(boolean) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- clusterReset(boolean) - Method in interface io.lettuce.core.cluster.api.async.RedisClusterAsyncCommands
-
Reset a node performing a soft or hard reset:
All other nodes are forgotten
All the assigned / open slots are released
If the node is a replica, it turns into a master
Only for hard reset: a new Node ID is generated
Only for hard reset: currentEpoch and configEpoch are set to 0
The new configuration is saved and the cluster state updated
If the node was a replica, the whole data set is flushed away
- clusterReset(boolean) - Method in interface io.lettuce.core.cluster.api.reactive.RedisClusterReactiveCommands
-
Reset a node performing a soft or hard reset:
All other nodes are forgotten
All the assigned / open slots are released
If the node is a replica, it turns into a master
Only for hard reset: a new Node ID is generated
Only for hard reset: currentEpoch and configEpoch are set to 0
The new configuration is saved and the cluster state updated
If the node was a replica, the whole data set is flushed away
- clusterReset(boolean) - Method in interface io.lettuce.core.cluster.api.sync.RedisClusterCommands
-
Reset a node performing a soft or hard reset:
All other nodes are forgotten
All the assigned / open slots are released
If the node is a replica, it turns into a master
Only for hard reset: a new Node ID is generated
Only for hard reset: currentEpoch and configEpoch are set to 0
The new configuration is saved and the cluster state updated
If the node was a replica, the whole data set is flushed away
- clusterSaveconfig() - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- clusterSaveconfig() - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- clusterSaveconfig() - Method in interface io.lettuce.core.cluster.api.async.RedisClusterAsyncCommands
-
Forces a node to save the nodes.conf configuration on disk.
- clusterSaveconfig() - Method in interface io.lettuce.core.cluster.api.reactive.RedisClusterReactiveCommands
-
Forces a node to save the nodes.conf configuration on disk.
- clusterSaveconfig() - Method in interface io.lettuce.core.cluster.api.sync.RedisClusterCommands
-
Forces a node to save the nodes.conf configuration on disk.
- clusterSetConfigEpoch(long) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- clusterSetConfigEpoch(long) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- clusterSetConfigEpoch(long) - Method in interface io.lettuce.core.cluster.api.async.RedisClusterAsyncCommands
-
This command sets a specific config epoch in a fresh node.
- clusterSetConfigEpoch(long) - Method in interface io.lettuce.core.cluster.api.reactive.RedisClusterReactiveCommands
-
This command sets a specific config epoch in a fresh node.
- clusterSetConfigEpoch(long) - Method in interface io.lettuce.core.cluster.api.sync.RedisClusterCommands
-
This command sets a specific config epoch in a fresh node.
- clusterSetSlotImporting(int, String) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- clusterSetSlotImporting(int, String) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- clusterSetSlotImporting(int, String) - Method in interface io.lettuce.core.cluster.api.async.RedisClusterAsyncCommands
-
Flag a slot as IMPORTING (incoming) from the node specified in nodeId
.
- clusterSetSlotImporting(int, String) - Method in interface io.lettuce.core.cluster.api.reactive.RedisClusterReactiveCommands
-
Flag a slot as IMPORTING (incoming) from the node specified in nodeId
.
- clusterSetSlotImporting(int, String) - Method in interface io.lettuce.core.cluster.api.sync.RedisClusterCommands
-
Flag a slot as IMPORTING (incoming) from the node specified in nodeId
.
- clusterSetSlotMigrating(int, String) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- clusterSetSlotMigrating(int, String) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- clusterSetSlotMigrating(int, String) - Method in interface io.lettuce.core.cluster.api.async.RedisClusterAsyncCommands
-
Flag a slot as MIGRATING (outgoing) towards the node specified in nodeId
.
- clusterSetSlotMigrating(int, String) - Method in interface io.lettuce.core.cluster.api.reactive.RedisClusterReactiveCommands
-
Flag a slot as MIGRATING (outgoing) towards the node specified in nodeId
.
- clusterSetSlotMigrating(int, String) - Method in interface io.lettuce.core.cluster.api.sync.RedisClusterCommands
-
Flag a slot as MIGRATING (outgoing) towards the node specified in nodeId
.
- clusterSetSlotNode(int, String) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- clusterSetSlotNode(int, String) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- clusterSetSlotNode(int, String) - Method in interface io.lettuce.core.cluster.api.async.RedisClusterAsyncCommands
-
Assign a slot to a node.
- clusterSetSlotNode(int, String) - Method in interface io.lettuce.core.cluster.api.reactive.RedisClusterReactiveCommands
-
Assign a slot to a node.
- clusterSetSlotNode(int, String) - Method in interface io.lettuce.core.cluster.api.sync.RedisClusterCommands
-
Assign a slot to a node.
- clusterSetSlotStable(int) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- clusterSetSlotStable(int) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- clusterSetSlotStable(int) - Method in interface io.lettuce.core.cluster.api.async.RedisClusterAsyncCommands
-
Clears migrating / importing state from the slot.
- clusterSetSlotStable(int) - Method in interface io.lettuce.core.cluster.api.reactive.RedisClusterReactiveCommands
-
Clears migrating / importing state from the slot.
- clusterSetSlotStable(int) - Method in interface io.lettuce.core.cluster.api.sync.RedisClusterCommands
-
Clears migrating / importing state from the slot.
- clusterSlaves(String) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- clusterSlaves(String) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- clusterSlaves(String) - Method in interface io.lettuce.core.cluster.api.async.RedisClusterAsyncCommands
-
List replicas for a certain node identified by its nodeId
.
- clusterSlaves(String) - Method in interface io.lettuce.core.cluster.api.reactive.RedisClusterReactiveCommands
-
List replicas for a certain node identified by its nodeId
.
- clusterSlaves(String) - Method in interface io.lettuce.core.cluster.api.sync.RedisClusterCommands
-
List replicas for a certain node identified by its nodeId
.
- ClusterSlotRange - Class in io.lettuce.core.cluster.models.slots
-
Represents a range of slots together with its master and replicas.
- ClusterSlotRange() - Constructor for class io.lettuce.core.cluster.models.slots.ClusterSlotRange
-
- ClusterSlotRange(int, int, RedisClusterNode, List<RedisClusterNode>) - Constructor for class io.lettuce.core.cluster.models.slots.ClusterSlotRange
-
- clusterSlots() - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- clusterSlots() - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- clusterSlots() - Method in interface io.lettuce.core.cluster.api.async.RedisClusterAsyncCommands
-
Get array of cluster slots to node mappings.
- clusterSlots() - Method in interface io.lettuce.core.cluster.api.reactive.RedisClusterReactiveCommands
-
Get array of cluster slots to node mappings.
- clusterSlots() - Method in interface io.lettuce.core.cluster.api.sync.RedisClusterCommands
-
Get array of cluster slots to node mappings.
- ClusterSlotsParser - Class in io.lettuce.core.cluster.models.slots
-
- ClusterTopologyChangedEvent - Class in io.lettuce.core.cluster.event
-
Signals a discovered cluster topology change.
- ClusterTopologyChangedEvent(List<RedisClusterNode>, List<RedisClusterNode>) - Constructor for class io.lettuce.core.cluster.event.ClusterTopologyChangedEvent
-
- ClusterTopologyRefresh - Class in io.lettuce.core.cluster.topology
-
Utility to refresh the cluster topology view based on
Partitions
.
- ClusterTopologyRefresh(NodeConnectionFactory, ClientResources) - Constructor for class io.lettuce.core.cluster.topology.ClusterTopologyRefresh
-
- clusterTopologyRefreshActivated - Variable in class io.lettuce.core.cluster.RedisClusterClient
-
- clusterTopologyRefreshFuture - Variable in class io.lettuce.core.cluster.RedisClusterClient
-
- ClusterTopologyRefreshOptions - Class in io.lettuce.core.cluster
-
- ClusterTopologyRefreshOptions(ClusterTopologyRefreshOptions.Builder) - Constructor for class io.lettuce.core.cluster.ClusterTopologyRefreshOptions
-
- ClusterTopologyRefreshOptions(ClusterTopologyRefreshOptions) - Constructor for class io.lettuce.core.cluster.ClusterTopologyRefreshOptions
-
- ClusterTopologyRefreshOptions.Builder - Class in io.lettuce.core.cluster
-
- ClusterTopologyRefreshOptions.RefreshTrigger - Enum in io.lettuce.core.cluster
-
Available refresh triggers to signal early topology refreshing.
- codec - Variable in class io.lettuce.core.cluster.StatefulRedisClusterConnectionImpl
-
- codec - Variable in class io.lettuce.core.output.CommandOutput
-
- codec - Variable in class io.lettuce.core.protocol.BaseRedisCommandBuilder
-
- codec - Variable in class io.lettuce.core.protocol.CommandArgs
-
- codec - Variable in class io.lettuce.core.sentinel.StatefulRedisSentinelConnectionImpl
-
- codec - Variable in class io.lettuce.core.StatefulRedisConnectionImpl
-
- CodecAwareOutputFactoryResolver - Class in io.lettuce.core.dynamic.output
-
- CodecAwareOutputFactoryResolver(CommandOutputFactoryResolver, RedisCodec<?, ?>) - Constructor for class io.lettuce.core.dynamic.output.CodecAwareOutputFactoryResolver
-
- COLLECTION - Static variable in class io.lettuce.core.dynamic.support.ClassTypeInformation
-
- collectionToDelimitedString(Collection<?>, String, String, String) - Static method in class io.lettuce.core.LettuceStrings
-
- command() - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- command() - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- command() - Method in interface io.lettuce.core.api.async.RedisServerAsyncCommands
-
Returns an array reply of details about all Redis commands.
- command() - Method in interface io.lettuce.core.api.reactive.RedisServerReactiveCommands
-
Returns an array reply of details about all Redis commands.
- command() - Method in interface io.lettuce.core.api.sync.RedisServerCommands
-
Returns an array reply of details about all Redis commands.
- command() - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionServerAsyncCommands
-
Returns an array reply of details about all Redis commands.
- command() - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionServerCommands
-
Returns an array reply of details about all Redis commands.
- Command - Annotation Type in io.lettuce.core.dynamic.annotation
-
Redis command method annotation specifying a command string.
- Command<K,V,T> - Class in io.lettuce.core.protocol
-
- Command(ProtocolKeyword, CommandOutput<K, V, T>) - Constructor for class io.lettuce.core.protocol.Command
-
Create a new command with the supplied type.
- Command(ProtocolKeyword, CommandOutput<K, V, T>, CommandArgs<K, V>) - Constructor for class io.lettuce.core.protocol.Command
-
Create a new command with the supplied type and args.
- command - Variable in class io.lettuce.core.protocol.CommandWrapper
-
- COMMAND_INFO_SIZE - Static variable in class io.lettuce.core.models.command.CommandDetailParser
-
Number of array elements for a specific command.
- CommandArgs<K,V> - Class in io.lettuce.core.protocol
-
Redis command arguments.
- CommandArgs(RedisCodec<K, V>) - Constructor for class io.lettuce.core.protocol.CommandArgs
-
- CommandArgsAccessor - Class in io.lettuce.core.protocol
-
- CommandArgsAccessor() - Constructor for class io.lettuce.core.protocol.CommandArgsAccessor
-
- CommandBatching - Class in io.lettuce.core.dynamic.batch
-
Programmatic command batching API.
- CommandBatching() - Constructor for class io.lettuce.core.dynamic.batch.CommandBatching
-
- commandCount() - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- commandCount() - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- commandCount() - Method in interface io.lettuce.core.api.async.RedisServerAsyncCommands
-
Get total number of Redis commands.
- commandCount() - Method in interface io.lettuce.core.api.reactive.RedisServerReactiveCommands
-
Get total number of Redis commands.
- commandCount() - Method in interface io.lettuce.core.api.sync.RedisServerCommands
-
Get total number of Redis commands.
- commandCount() - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionServerAsyncCommands
-
Get total number of Redis commands.
- commandCount() - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionServerCommands
-
Get total number of Redis commands.
- CommandCreationException - Exception in io.lettuce.core.dynamic
-
Exception thrown if a command cannot be constructed from a
CommandMethod
.
- CommandCreationException(CommandMethod, String) - Constructor for exception io.lettuce.core.dynamic.CommandCreationException
-
- CommandDetail - Class in io.lettuce.core.models.command
-
- CommandDetail() - Constructor for class io.lettuce.core.models.command.CommandDetail
-
- CommandDetail(String, int, Set<CommandDetail.Flag>, int, int, int) - Constructor for class io.lettuce.core.models.command.CommandDetail
-
- CommandDetail.Flag - Enum in io.lettuce.core.models.command
-
- CommandDetailParser - Class in io.lettuce.core.models.command
-
- CommandEncoder - Class in io.lettuce.core.protocol
-
- CommandEncoder() - Constructor for class io.lettuce.core.protocol.CommandEncoder
-
- CommandEncoder(boolean) - Constructor for class io.lettuce.core.protocol.CommandEncoder
-
- CommandExpiryWriter - Class in io.lettuce.core.protocol
-
- CommandExpiryWriter(RedisChannelWriter, ClientOptions, ClientResources) - Constructor for class io.lettuce.core.protocol.CommandExpiryWriter
-
- commandHandler(Supplier<CommandHandler>) - Method in class io.lettuce.core.ConnectionBuilder
-
- CommandHandler - Class in io.lettuce.core.protocol
-
A netty
ChannelHandler
responsible for writing redis commands and reading responses from the server.
- CommandHandler(ClientOptions, ClientResources, Endpoint) - Constructor for class io.lettuce.core.protocol.CommandHandler
-
Initialize a new instance that handles commands from the supplied queue.
- CommandHandler.LifecycleState - Enum in io.lettuce.core.protocol
-
- commandInfo(String...) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- commandInfo(CommandType...) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- commandInfo(String...) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- commandInfo(CommandType...) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- commandInfo(String...) - Method in interface io.lettuce.core.api.async.RedisServerAsyncCommands
-
Returns an array reply of details about the requested commands.
- commandInfo(CommandType...) - Method in interface io.lettuce.core.api.async.RedisServerAsyncCommands
-
Returns an array reply of details about the requested commands.
- commandInfo(String...) - Method in interface io.lettuce.core.api.reactive.RedisServerReactiveCommands
-
Returns an array reply of details about the requested commands.
- commandInfo(CommandType...) - Method in interface io.lettuce.core.api.reactive.RedisServerReactiveCommands
-
Returns an array reply of details about the requested commands.
- commandInfo(String...) - Method in interface io.lettuce.core.api.sync.RedisServerCommands
-
Returns an array reply of details about the requested commands.
- commandInfo(CommandType...) - Method in interface io.lettuce.core.api.sync.RedisServerCommands
-
Returns an array reply of details about the requested commands.
- commandInfo(String...) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionServerAsyncCommands
-
Returns an array reply of details about the requested commands.
- commandInfo(CommandType...) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionServerAsyncCommands
-
Returns an array reply of details about the requested commands.
- commandInfo(String...) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionServerCommands
-
Returns an array reply of details about the requested commands.
- commandInfo(CommandType...) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionServerCommands
-
Returns an array reply of details about the requested commands.
- CommandKeyword - Enum in io.lettuce.core.protocol
-
Keyword modifiers for redis commands.
- CommandLatency(long, long, Map<Double, Long>) - Constructor for class io.lettuce.core.metrics.CommandMetrics.CommandLatency
-
- CommandLatencyCollector - Interface in io.lettuce.core.metrics
-
- commandLatencyCollector(CommandLatencyCollector) - Method in interface io.lettuce.core.resource.ClientResources.Builder
-
- commandLatencyCollector() - Method in interface io.lettuce.core.resource.ClientResources
-
- commandLatencyCollector(CommandLatencyCollector) - Method in class io.lettuce.core.resource.DefaultClientResources.Builder
-
- commandLatencyCollector() - Method in class io.lettuce.core.resource.DefaultClientResources
-
- CommandLatencyCollectorOptions - Interface in io.lettuce.core.metrics
-
Configuration interface for command latency collection.
- commandLatencyCollectorOptions(CommandLatencyCollectorOptions) - Method in interface io.lettuce.core.resource.ClientResources.Builder
-
- commandLatencyCollectorOptions(CommandLatencyCollectorOptions) - Method in class io.lettuce.core.resource.DefaultClientResources.Builder
-
- CommandLatencyCollectorOptions.Builder - Interface in io.lettuce.core.metrics
-
- CommandLatencyEvent - Class in io.lettuce.core.event.metrics
-
Event that transports command latency metrics.
- CommandLatencyEvent(Map<CommandLatencyId, CommandMetrics>) - Constructor for class io.lettuce.core.event.metrics.CommandLatencyEvent
-
- CommandLatencyId - Class in io.lettuce.core.metrics
-
Identifier for a command latency.
- CommandLatencyId(SocketAddress, SocketAddress, ProtocolKeyword) - Constructor for class io.lettuce.core.metrics.CommandLatencyId
-
- commandLatencyPublisherOptions(EventPublisherOptions) - Method in interface io.lettuce.core.resource.ClientResources.Builder
-
- commandLatencyPublisherOptions() - Method in interface io.lettuce.core.resource.ClientResources
-
- commandLatencyPublisherOptions(EventPublisherOptions) - Method in class io.lettuce.core.resource.DefaultClientResources.Builder
-
- commandLatencyPublisherOptions() - Method in class io.lettuce.core.resource.DefaultClientResources
-
- CommandMethod - Interface in io.lettuce.core.dynamic
-
Abstraction of a method that is designated to execute a Redis command method.
- CommandMethodSyntaxException - Exception in io.lettuce.core.dynamic
-
Exception thrown if the command syntax is invalid.
- CommandMethodSyntaxException(CommandMethod, String) - Constructor for exception io.lettuce.core.dynamic.CommandMethodSyntaxException
-
- CommandMetrics - Class in io.lettuce.core.metrics
-
Latency metrics for commands.
- CommandMetrics(long, TimeUnit, CommandMetrics.CommandLatency, CommandMetrics.CommandLatency) - Constructor for class io.lettuce.core.metrics.CommandMetrics
-
- CommandMetrics.CommandLatency - Class in io.lettuce.core.metrics
-
- CommandNaming - Annotation Type in io.lettuce.core.dynamic.annotation
-
Command naming strategy for Redis command methods.
- CommandNaming.LetterCase - Enum in io.lettuce.core.dynamic.annotation
-
- CommandNaming.Strategy - Enum in io.lettuce.core.dynamic.annotation
-
- CommandOutput<K,V,T> - Class in io.lettuce.core.output
-
Abstract representation of the output of a redis command.
- CommandOutput(RedisCodec<K, V>, T) - Constructor for class io.lettuce.core.output.CommandOutput
-
Initialize a new instance that encodes and decodes keys and values using the supplied codec.
- CommandOutputFactory - Interface in io.lettuce.core.dynamic.output
-
- CommandOutputFactoryResolver - Interface in io.lettuce.core.dynamic.output
-
- CommandOutputResolverSupport - Class in io.lettuce.core.dynamic.output
-
- CommandOutputResolverSupport() - Constructor for class io.lettuce.core.dynamic.output.CommandOutputResolverSupport
-
- commands() - Method in interface io.lettuce.core.cluster.api.NodeSelectionSupport
-
- commands(int) - Method in interface io.lettuce.core.cluster.api.NodeSelectionSupport
-
Obtain the connection/commands to a particular node.
- Commands - Interface in io.lettuce.core.dynamic
-
Marker interface for dynamic Redis commands.
- CommandSegment - Class in io.lettuce.core.dynamic.segment
-
Value object representing a segment within a Redis Command.
- CommandSegment() - Constructor for class io.lettuce.core.dynamic.segment.CommandSegment
-
- CommandSegment.ArgumentContribution - Class in io.lettuce.core.dynamic.segment
-
- CommandSegmentFactory - Interface in io.lettuce.core.dynamic.segment
-
- CommandSegments - Class in io.lettuce.core.dynamic.segment
-
- CommandSegments(List<CommandSegment>) - Constructor for class io.lettuce.core.dynamic.segment.CommandSegments
-
- commandType() - Method in class io.lettuce.core.metrics.CommandLatencyId
-
Returns the command type.
- CommandType - Enum in io.lettuce.core.protocol
-
Redis commands.
- CommandWrapper<K,V,T> - Class in io.lettuce.core.protocol
-
Wrapper for a command.
- CommandWrapper(RedisCommand<K, V, T>) - Constructor for class io.lettuce.core.protocol.CommandWrapper
-
- CommonsPool2ConfigConverter - Class in io.lettuce.core.support
-
- compareTo(CommandLatencyId) - Method in class io.lettuce.core.metrics.CommandLatencyId
-
- complete(int) - Method in class io.lettuce.core.output.ArrayOutput
-
- complete(int) - Method in class io.lettuce.core.output.CommandOutput
-
Mark the command output complete.
- complete(int) - Method in class io.lettuce.core.output.GeoWithinListOutput
-
- complete(int) - Method in class io.lettuce.core.output.ListOfMapsOutput
-
- complete(int) - Method in class io.lettuce.core.output.MultiOutput
-
- complete(int) - Method in class io.lettuce.core.output.NestedMultiOutput
-
- complete(int) - Method in class io.lettuce.core.output.ReplayOutput
-
- complete(int) - Method in class io.lettuce.core.output.StreamMessageListOutput
-
- complete(int) - Method in class io.lettuce.core.output.StreamReadOutput
-
- complete() - Method in class io.lettuce.core.protocol.AsyncCommand
-
Mark this command complete and notify all waiting threads.
- complete() - Method in class io.lettuce.core.protocol.Command
-
Mark this command complete and notify all waiting threads.
- complete(RedisCommand<?, ?, ?>) - Method in class io.lettuce.core.protocol.CommandHandler
-
Decoding hook: Complete a command.
- complete() - Method in class io.lettuce.core.protocol.CommandWrapper
-
- complete() - Method in interface io.lettuce.core.protocol.RedisCommand
-
Complete a command.
- complete(RedisCommand<?, ?, ?>) - Method in class io.lettuce.core.pubsub.PubSubCommandHandler
-
- CompleteableCommand<T> - Interface in io.lettuce.core.protocol
-
Extension to commands that provide registration of command completion callbacks.
- completed(SocketAddress, T) - Static method in interface io.lettuce.core.ConnectionFuture
-
- completeExceptionally(Throwable) - Method in class io.lettuce.core.protocol.AsyncCommand
-
- completeExceptionally(Throwable) - Method in class io.lettuce.core.protocol.Command
-
- completeExceptionally(Throwable) - Method in class io.lettuce.core.protocol.CommandWrapper
-
- completeExceptionally(Throwable) - Method in interface io.lettuce.core.protocol.RedisCommand
-
- completeResult() - Method in class io.lettuce.core.protocol.AsyncCommand
-
- CompositeArgument - Interface in io.lettuce.core
-
Interface for composite command argument objects.
- CompositeParameterNameDiscoverer - Class in io.lettuce.core.dynamic.support
-
- CompositeParameterNameDiscoverer(ParameterNameDiscoverer...) - Constructor for class io.lettuce.core.dynamic.support.CompositeParameterNameDiscoverer
-
- CompositeParameterNameDiscoverer(Collection<ParameterNameDiscoverer>) - Constructor for class io.lettuce.core.dynamic.support.CompositeParameterNameDiscoverer
-
- CompressionCodec - Class in io.lettuce.core.codec
-
A compressing/decompressing
RedisCodec
that wraps a typed
codec
and compresses values using GZIP
or Deflate.
- CompressionCodec.CompressionType - Enum in io.lettuce.core.codec
-
- computationThreadPoolSize(int) - Method in interface io.lettuce.core.resource.ClientResources.Builder
-
Sets the thread pool size (number of threads to use) for computation operations (default value is the number of
CPUs).
- computationThreadPoolSize() - Method in interface io.lettuce.core.resource.ClientResources
-
Returns the pool size (number of threads) for all computation tasks.
- computationThreadPoolSize(int) - Method in class io.lettuce.core.resource.DefaultClientResources.Builder
-
Sets the thread pool size (number of threads to use) for computation operations (default value is the number of
CPUs).
- computationThreadPoolSize() - Method in class io.lettuce.core.resource.DefaultClientResources
-
- configGet(String) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- configGet(String) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- configGet(String) - Method in interface io.lettuce.core.api.async.RedisServerAsyncCommands
-
Get the value of a configuration parameter.
- configGet(String) - Method in interface io.lettuce.core.api.reactive.RedisServerReactiveCommands
-
Get the value of a configuration parameter.
- configGet(String) - Method in interface io.lettuce.core.api.sync.RedisServerCommands
-
Get the value of a configuration parameter.
- configGet(String) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionServerAsyncCommands
-
Get the value of a configuration parameter.
- configGet(String) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionServerCommands
-
Get the value of a configuration parameter.
- configResetstat() - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- configResetstat() - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- configResetstat() - Method in interface io.lettuce.core.api.async.RedisServerAsyncCommands
-
Reset the stats returned by INFO.
- configResetstat() - Method in interface io.lettuce.core.api.reactive.RedisServerReactiveCommands
-
Reset the stats returned by INFO.
- configResetstat() - Method in interface io.lettuce.core.api.sync.RedisServerCommands
-
Reset the stats returned by INFO.
- configResetstat() - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionServerAsyncCommands
-
Reset the stats returned by INFO.
- configResetstat() - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionServerCommands
-
Reset the stats returned by INFO.
- configRewrite() - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- configRewrite() - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- configRewrite() - Method in interface io.lettuce.core.api.async.RedisServerAsyncCommands
-
Rewrite the configuration file with the in memory configuration.
- configRewrite() - Method in interface io.lettuce.core.api.reactive.RedisServerReactiveCommands
-
Rewrite the configuration file with the in memory configuration.
- configRewrite() - Method in interface io.lettuce.core.api.sync.RedisServerCommands
-
Rewrite the configuration file with the in memory configuration.
- configRewrite() - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionServerAsyncCommands
-
Rewrite the configuration file with the in memory configuration.
- configRewrite() - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionServerCommands
-
Rewrite the configuration file with the in memory configuration.
- configSet(String, String) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- configSet(String, String) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- configSet(String, String) - Method in interface io.lettuce.core.api.async.RedisServerAsyncCommands
-
Set a configuration parameter to the given value.
- configSet(String, String) - Method in interface io.lettuce.core.api.reactive.RedisServerReactiveCommands
-
Set a configuration parameter to the given value.
- configSet(String, String) - Method in interface io.lettuce.core.api.sync.RedisServerCommands
-
Set a configuration parameter to the given value.
- configSet(String, String) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionServerAsyncCommands
-
Set a configuration parameter to the given value.
- configSet(String, String) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionServerCommands
-
Set a configuration parameter to the given value.
- connect() - Method in class io.lettuce.core.cluster.RedisClusterClient
-
Connect to a Redis Cluster and treat keys and values as UTF-8 strings.
- connect(RedisCodec<K, V>) - Method in class io.lettuce.core.cluster.RedisClusterClient
-
Connect to a Redis Cluster.
- connect(RedisClient, RedisCodec<K, V>, RedisURI) - Static method in class io.lettuce.core.masterreplica.MasterReplica
-
Open a new connection to a Redis Master-Replica server/servers using the supplied
RedisURI
and the supplied
codec
to encode/decode keys.
- connect(RedisClient, RedisCodec<K, V>, Iterable<RedisURI>) - Static method in class io.lettuce.core.masterreplica.MasterReplica
-
Open a new connection to a Redis Master-Replica server/servers using the supplied
RedisURI
and the supplied
codec
to encode/decode keys.
- connect(RedisClient, RedisCodec<K, V>, RedisURI) - Static method in class io.lettuce.core.masterslave.MasterSlave
-
Deprecated.
Open a new connection to a Redis Master-Slave server/servers using the supplied
RedisURI
and the supplied
codec
to encode/decode keys.
- connect(RedisClient, RedisCodec<K, V>, Iterable<RedisURI>) - Static method in class io.lettuce.core.masterslave.MasterSlave
-
Deprecated.
Open a new connection to a Redis Master-Slave server/servers using the supplied
RedisURI
and the supplied
codec
to encode/decode keys.
- connect() - Method in class io.lettuce.core.RedisClient
-
Open a new connection to a Redis server that treats keys and values as UTF-8 strings.
- connect(RedisCodec<K, V>) - Method in class io.lettuce.core.RedisClient
-
Open a new connection to a Redis server.
- connect(RedisURI) - Method in class io.lettuce.core.RedisClient
-
Open a new connection to a Redis server using the supplied
RedisURI
that treats keys and values as UTF-8 strings.
- connect(RedisCodec<K, V>, RedisURI) - Method in class io.lettuce.core.RedisClient
-
Open a new connection to a Redis server using the supplied
RedisURI
and the supplied
codec
to
encode/decode keys.
- connectAsync(RedisCodec<K, V>) - Method in class io.lettuce.core.cluster.RedisClusterClient
-
Connect asynchronously to a Redis Cluster.
- connectAsync(RedisClient, RedisCodec<K, V>, RedisURI) - Static method in class io.lettuce.core.masterreplica.MasterReplica
-
Open asynchronously a new connection to a Redis Master-Replica server/servers using the supplied
RedisURI
and the
supplied
codec
to encode/decode keys.
- connectAsync(RedisClient, RedisCodec<K, V>, Iterable<RedisURI>) - Static method in class io.lettuce.core.masterreplica.MasterReplica
-
Open asynchronously a new connection to a Redis Master-Replica server/servers using the supplied
RedisURI
and the
supplied
codec
to encode/decode keys.
- connectAsync(RedisClient, RedisCodec<K, V>, RedisURI) - Static method in class io.lettuce.core.masterslave.MasterSlave
-
Deprecated.
Open asynchronously a new connection to a Redis Master-Slave server/servers using the supplied
RedisURI
and the
supplied
codec
to encode/decode keys.
- connectAsync(RedisClient, RedisCodec<K, V>, Iterable<RedisURI>) - Static method in class io.lettuce.core.masterslave.MasterSlave
-
Deprecated.
Open asynchronously a new connection to a Redis Master-Slave server/servers using the supplied
RedisURI
and the
supplied
codec
to encode/decode keys.
- connectAsync(RedisCodec<K, V>, RedisURI) - Method in class io.lettuce.core.RedisClient
-
Open asynchronously a new connection to a Redis server using the supplied
RedisURI
and the supplied
codec
to encode/decode keys.
- CONNECTED - Static variable in class io.lettuce.core.cluster.models.partitions.ClusterPartitionParser
-
- ConnectedEvent - Class in io.lettuce.core.event.connection
-
Event for a established TCP-level connection.
- ConnectedEvent(SocketAddress, SocketAddress) - Constructor for class io.lettuce.core.event.connection.ConnectedEvent
-
- connection(RedisChannelHandler<?, ?>) - Method in class io.lettuce.core.ConnectionBuilder
-
- connection() - Method in class io.lettuce.core.ConnectionBuilder
-
- ConnectionActivatedEvent - Class in io.lettuce.core.event.connection
-
- ConnectionActivatedEvent(SocketAddress, SocketAddress) - Constructor for class io.lettuce.core.event.connection.ConnectionActivatedEvent
-
- connectionBuilder(Mono<SocketAddress>, ConnectionBuilder, RedisURI) - Method in class io.lettuce.core.AbstractRedisClient
-
Populate connection builder with necessary resources.
- ConnectionBuilder - Class in io.lettuce.core
-
Connection builder for connections.
- ConnectionBuilder() - Constructor for class io.lettuce.core.ConnectionBuilder
-
- connectionBuilder() - Static method in class io.lettuce.core.ConnectionBuilder
-
- ConnectionDeactivatedEvent - Class in io.lettuce.core.event.connection
-
Event for a connection deactivation.
- ConnectionDeactivatedEvent(SocketAddress, SocketAddress) - Constructor for class io.lettuce.core.event.connection.ConnectionDeactivatedEvent
-
- ConnectionEvent - Interface in io.lettuce.core.event.connection
-
Interface for Connection-related events
- connectionEvents - Variable in class io.lettuce.core.AbstractRedisClient
-
- connectionEvents(ConnectionEvents) - Method in class io.lettuce.core.ConnectionBuilder
-
- ConnectionEvents - Class in io.lettuce.core
-
Close Events Facility.
- ConnectionEvents() - Constructor for class io.lettuce.core.ConnectionEvents
-
- ConnectionEvents.Activated - Class in io.lettuce.core
-
Internal event when a channel is activated.
- ConnectionEvents.PingBeforeActivate - Class in io.lettuce.core
-
Internal event when a channel is activated.
- ConnectionEvents.Reconnect - Class in io.lettuce.core
-
Internal event when a reconnect is initiated.
- ConnectionEvents.Reset - Class in io.lettuce.core
-
Internal event when a channel is closed.
- ConnectionFacade - Interface in io.lettuce.core.protocol
-
Represents a stateful connection facade.
- ConnectionFuture<T> - Interface in io.lettuce.core
-
A ConnectionFuture
represents the result of an asynchronous connection initialization.
- ConnectionId - Interface in io.lettuce.core
-
Connection identifier.
- ConnectionPoint - Interface in io.lettuce.core
-
Interface for a connection point described with a host and port or socket.
- ConnectionPoolSupport - Class in io.lettuce.core.support
-
- connectionTimeout() - Method in class io.lettuce.core.TimeoutOptions.Builder
-
- ConnectionWatchdog - Class in io.lettuce.core.protocol
-
A netty
ChannelHandler
responsible for monitoring the channel and reconnecting when the connection is lost.
- ConnectionWatchdog(Delay, ClientOptions, Bootstrap, Timer, EventExecutorGroup, Mono<SocketAddress>, ReconnectionListener, ConnectionFacade, EventBus) - Constructor for class io.lettuce.core.protocol.ConnectionWatchdog
-
Create a new watchdog that adds to new connections to the supplied
ChannelGroup
and establishes a new
Channel
when disconnected, while reconnect is true.
- ConnectionWrapping - Class in io.lettuce.core.support
-
Utility to wrap pooled connections for return-on-close.
- ConnectionWrapping() - Constructor for class io.lettuce.core.support.ConnectionWrapping
-
- connectPubSub() - Method in class io.lettuce.core.cluster.RedisClusterClient
-
Connect to a Redis Cluster using pub/sub connections and treat keys and values as UTF-8 strings.
- connectPubSub(RedisCodec<K, V>) - Method in class io.lettuce.core.cluster.RedisClusterClient
-
Connect to a Redis Cluster using pub/sub connections.
- connectPubSub() - Method in class io.lettuce.core.RedisClient
-
Open a new pub/sub connection to a Redis server that treats keys and values as UTF-8 strings.
- connectPubSub(RedisURI) - Method in class io.lettuce.core.RedisClient
-
Open a new pub/sub connection to a Redis server using the supplied
RedisURI
that treats keys and values as UTF-8
strings.
- connectPubSub(RedisCodec<K, V>) - Method in class io.lettuce.core.RedisClient
-
Open a new pub/sub connection to the Redis server using the supplied
RedisURI
and use the supplied
codec
to encode/decode keys and values.
- connectPubSub(RedisCodec<K, V>, RedisURI) - Method in class io.lettuce.core.RedisClient
-
Open a new pub/sub connection to the Redis server using the supplied
RedisURI
and use the supplied
codec
to encode/decode keys and values.
- connectPubSubAsync(RedisCodec<K, V>) - Method in class io.lettuce.core.cluster.RedisClusterClient
-
Connect asynchronously to a Redis Cluster using pub/sub connections.
- connectPubSubAsync(RedisCodec<K, V>, RedisURI) - Method in class io.lettuce.core.RedisClient
-
Open asynchronously a new pub/sub connection to the Redis server using the supplied
RedisURI
and use the supplied
codec
to encode/decode keys and values.
- connectSentinel() - Method in class io.lettuce.core.RedisClient
-
Open a connection to a Redis Sentinel that treats keys and values as UTF-8 strings.
- connectSentinel(RedisCodec<K, V>) - Method in class io.lettuce.core.RedisClient
-
Open a connection to a Redis Sentinel that treats keys and use the supplied
codec
to encode/decode
keys and values.
- connectSentinel(RedisURI) - Method in class io.lettuce.core.RedisClient
-
Open a connection to a Redis Sentinel using the supplied
RedisURI
that treats keys and values as UTF-8 strings.
- connectSentinel(RedisCodec<K, V>, RedisURI) - Method in class io.lettuce.core.RedisClient
-
Open a connection to a Redis Sentinel using the supplied
RedisURI
and use the supplied
codec
to encode/decode keys and values.
- connectSentinelAsync(RedisCodec<K, V>, RedisURI) - Method in class io.lettuce.core.RedisClient
-
Open asynchronously a connection to a Redis Sentinel using the supplied
RedisURI
and use the supplied
codec
to encode/decode keys and values.
- connectTimeout(Duration) - Method in class io.lettuce.core.SocketOptions.Builder
-
Set connection timeout.
- connectTimeout(long, TimeUnit) - Method in class io.lettuce.core.SocketOptions.Builder
-
- connectToNode(RedisCodec<K, V>, SocketAddress) - Method in interface io.lettuce.core.cluster.topology.NodeConnectionFactory
-
- connectToNodeAsync(RedisCodec<K, V>, SocketAddress) - Method in interface io.lettuce.core.cluster.topology.NodeConnectionFactory
-
- connectToNodeAsync(RedisCodec<K, V>, RedisURI) - Method in interface io.lettuce.core.masterslave.NodeConnectionFactory
-
Deprecated.
- constant(String) - Static method in class io.lettuce.core.dynamic.segment.CommandSegment
-
- constant(Duration) - Static method in class io.lettuce.core.resource.Delay
-
Creates a new ConstantDelay
.
- constant(int, TimeUnit) - Static method in class io.lettuce.core.resource.Delay
-
- Consumer<K> - Class in io.lettuce.core
-
Value object representing a Stream consumer within a consumer group.
- contains(Object) - Method in class io.lettuce.core.cluster.models.partitions.Partitions
-
Returns true if this
Partitions
contains the specified element.
- containsAll(Collection<?>) - Method in class io.lettuce.core.cluster.models.partitions.Partitions
-
Returns true if this collection contains all of the elements in the specified collection.
- contribute(MethodParametersAccessor) - Method in class io.lettuce.core.dynamic.segment.CommandSegment
-
- coordinates() - Static method in class io.lettuce.core.GeoArgs.Builder
-
Creates new
GeoArgs
with WITHCOORD enabled.
- copy() - Static method in class io.lettuce.core.MigrateArgs.Builder
-
- copy() - Method in class io.lettuce.core.MigrateArgs
-
Do not remove the key from the local instance by setting COPY
.
- copyOf(ClientOptions) - Static method in class io.lettuce.core.ClientOptions
-
Create a copy of options
- copyOf(ClusterClientOptions) - Static method in class io.lettuce.core.cluster.ClusterClientOptions
-
Create a copy of options.
- copyOf(ClusterTopologyRefreshOptions) - Static method in class io.lettuce.core.cluster.ClusterTopologyRefreshOptions
-
Create a copy of options.
- copyOf(SocketOptions) - Static method in class io.lettuce.core.SocketOptions
-
Create a copy of options
- copyOf(SslOptions) - Static method in class io.lettuce.core.SslOptions
-
Create a copy of options
- count(long) - Static method in class io.lettuce.core.GeoArgs.Builder
-
Creates new
GeoArgs
with COUNT set.
- count(long) - Static method in class io.lettuce.core.GeoRadiusStoreArgs.Builder
-
- count() - Method in class io.lettuce.core.protocol.CommandArgs
-
- count() - Method in class io.lettuce.core.pubsub.PubSubOutput
-
- count(long) - Static method in class io.lettuce.core.XReadArgs.Builder
-
- count(long) - Method in class io.lettuce.core.XReadArgs
-
Limit read to count
messages.
- CRC16 - Class in io.lettuce.core.codec
-
- crc16(byte[]) - Static method in class io.lettuce.core.codec.CRC16
-
Create a CRC16 checksum from the bytes.
- crc16(byte[], int, int) - Static method in class io.lettuce.core.codec.CRC16
-
Create a CRC16 checksum from the bytes.
- crc16(ByteBuffer) - Static method in class io.lettuce.core.codec.CRC16
-
Create a CRC16 checksum from the bytes.
- create() - Static method in class io.lettuce.core.ClientOptions
-
- create() - Static method in class io.lettuce.core.cluster.ClusterClientOptions
-
- create() - Static method in class io.lettuce.core.cluster.ClusterTopologyRefreshOptions
-
- create(RedisURI) - Static method in class io.lettuce.core.cluster.RedisClusterClient
-
- create(Iterable<RedisURI>) - Static method in class io.lettuce.core.cluster.RedisClusterClient
-
- create(String) - Static method in class io.lettuce.core.cluster.RedisClusterClient
-
Create a new client that connects to the supplied uri with default
ClientResources
.
- create(ClientResources, RedisURI) - Static method in class io.lettuce.core.cluster.RedisClusterClient
-
- create(ClientResources, String) - Static method in class io.lettuce.core.cluster.RedisClusterClient
-
Create a new client that connects to the supplied uri with shared
ClientResources
.You need to shut down the
ClientResources
upon shutting down your application.
- create(ClientResources, Iterable<RedisURI>) - Static method in class io.lettuce.core.cluster.RedisClusterClient
-
- create(String) - Static method in class io.lettuce.core.codec.CipherCodec.KeyDescriptor
-
- create(String, int) - Static method in class io.lettuce.core.codec.CipherCodec.KeyDescriptor
-
- create(String, int, Charset) - Static method in class io.lettuce.core.codec.CipherCodec.KeyDescriptor
-
- create(Method) - Static method in class io.lettuce.core.dynamic.DeclaredCommandMethod
-
- create(Duration) - Static method in class io.lettuce.core.dynamic.domain.Timeout
-
- create(long, TimeUnit) - Static method in class io.lettuce.core.dynamic.domain.Timeout
-
- create(RedisCodec<K, V>) - Method in interface io.lettuce.core.dynamic.output.CommandOutputFactory
-
- create() - Static method in class io.lettuce.core.event.DefaultEventPublisherOptions
-
- create(Number, Number) - Static method in class io.lettuce.core.GeoCoordinates
-
- create(long, long) - Static method in class io.lettuce.core.Limit
-
Creates a
Limit
given
offset
and
count
.
- create(CommandLatencyCollectorOptions) - Static method in interface io.lettuce.core.metrics.CommandLatencyCollector
-
- create() - Static method in interface io.lettuce.core.metrics.CommandLatencyCollectorOptions
-
- create(SocketAddress, SocketAddress, ProtocolKeyword) - Static method in class io.lettuce.core.metrics.CommandLatencyId
-
- create() - Static method in class io.lettuce.core.metrics.DefaultCommandLatencyCollectorOptions
-
- create(T, T) - Static method in class io.lettuce.core.Range
-
Create a new range from lower
and upper
boundary values.
- create() - Static method in class io.lettuce.core.RedisClient
-
- create(RedisURI) - Static method in class io.lettuce.core.RedisClient
-
- create(String) - Static method in class io.lettuce.core.RedisClient
-
Create a new client that connects to the supplied uri with default
ClientResources
.
- create(ClientResources) - Static method in class io.lettuce.core.RedisClient
-
- create(ClientResources, String) - Static method in class io.lettuce.core.RedisClient
-
Create a new client that connects to the supplied uri with shared
ClientResources
.You need to shut down the
ClientResources
upon shutting down your application.
- create(ClientResources, RedisURI) - Static method in class io.lettuce.core.RedisClient
-
- create(SocketAddress, Throwable) - Static method in exception io.lettuce.core.RedisConnectionException
-
- create(String, Throwable) - Static method in exception io.lettuce.core.RedisConnectionException
-
- create(Throwable) - Static method in exception io.lettuce.core.RedisConnectionException
-
- create(String, int) - Static method in class io.lettuce.core.RedisURI
-
Create a Redis URI from host and port.
- create(String) - Static method in class io.lettuce.core.RedisURI
-
Create a Redis URI from an URI string.
- create(URI) - Static method in class io.lettuce.core.RedisURI
-
Create a Redis URI from an URI string:
The uri must follow conventions of
URI
- create() - Static method in interface io.lettuce.core.resource.ClientResources
-
- create() - Static method in class io.lettuce.core.resource.DefaultClientResources
-
- create(DnsResolver, Function<HostAndPort, HostAndPort>) - Static method in class io.lettuce.core.resource.MappingSocketAddressResolver
-
- create(DnsResolver) - Static method in class io.lettuce.core.resource.SocketAddressResolver
-
- create() - Static method in class io.lettuce.core.SocketOptions
-
- create() - Static method in class io.lettuce.core.SslOptions
-
- create() - Method in interface io.lettuce.core.support.AsyncObjectFactory
-
Create an instance that can be served by the pool and wrap it in a
PooledObject
to be managed by the pool.
- create() - Static method in class io.lettuce.core.support.BoundedPoolConfig
-
- create() - Static method in class io.lettuce.core.TimeoutOptions
-
- create(TraceContext) - Static method in class io.lettuce.core.tracing.BraveTracing.BraveTraceContext
-
- create(Tracing) - Static method in class io.lettuce.core.tracing.BraveTracing
-
- createBoundedObjectPool(Supplier<CompletionStage<T>>, BoundedPoolConfig) - Static method in class io.lettuce.core.support.AsyncConnectionPoolSupport
-
- createBoundedObjectPool(Supplier<CompletionStage<T>>, BoundedPoolConfig, boolean) - Static method in class io.lettuce.core.support.AsyncConnectionPoolSupport
-
- createCommand(CommandType, CommandOutput<K, V, T>) - Method in class io.lettuce.core.protocol.BaseRedisCommandBuilder
-
- createCommand(CommandType, CommandOutput<K, V, T>, K) - Method in class io.lettuce.core.protocol.BaseRedisCommandBuilder
-
- createCommand(CommandType, CommandOutput<K, V, T>, K, V) - Method in class io.lettuce.core.protocol.BaseRedisCommandBuilder
-
- createCommand(CommandType, CommandOutput<K, V, T>, K, V[]) - Method in class io.lettuce.core.protocol.BaseRedisCommandBuilder
-
- createCommand(CommandType, CommandOutput<K, V, T>, CommandArgs<K, V>) - Method in class io.lettuce.core.protocol.BaseRedisCommandBuilder
-
- createCommandSegments(CommandMethod) - Method in class io.lettuce.core.dynamic.segment.AnnotationCommandSegmentFactory
-
- createCommandSegments(CommandMethod) - Method in interface io.lettuce.core.dynamic.segment.CommandSegmentFactory
-
- createConnectionWatchdog() - Method in class io.lettuce.core.ConnectionBuilder
-
- createDelay(long) - Method in class io.lettuce.core.resource.Delay
-
Calculate a specific delay based on the attempt.
- createDissolvingFlux(Supplier<RedisCommand<K, V, T>>) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- createEndpoint(SocketAddress) - Method in class io.lettuce.core.tracing.BraveTracing
-
- createEndpoint(SocketAddress) - Method in interface io.lettuce.core.tracing.Tracing
-
- createEventLoopGroup(Class<T>, int) - Static method in class io.lettuce.core.resource.DefaultEventLoopGroupProvider
-
- createExecutionException(String) - Static method in class io.lettuce.core.ExceptionFactory
-
- createExecutionException(String, Throwable) - Static method in class io.lettuce.core.ExceptionFactory
-
- createFlux(Supplier<RedisCommand<K, V, T>>) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- createGenericObjectPool(Supplier<T>, GenericObjectPoolConfig<T>) - Static method in class io.lettuce.core.support.ConnectionPoolSupport
-
- createGenericObjectPool(Supplier<T>, GenericObjectPoolConfig<T>, boolean) - Static method in class io.lettuce.core.support.ConnectionPoolSupport
-
- createInstance() - Method in class io.lettuce.core.support.ClientResourcesFactoryBean
-
- createInstance() - Method in class io.lettuce.core.support.RedisClientFactoryBean
-
- createInstance() - Method in class io.lettuce.core.support.RedisClusterClientFactoryBean
-
- createMono(CommandType, CommandOutput<K, V, T>, CommandArgs<K, V>) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- createMono(Supplier<RedisCommand<K, V, T>>) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- createParameter(Method, int) - Method in class io.lettuce.core.dynamic.parameter.ExecutionSpecificParameters
-
- createParameter(Method, int) - Method in class io.lettuce.core.dynamic.parameter.Parameters
-
- createProxy(ClassLoader) - Method in class io.lettuce.core.dynamic.intercept.InvocationProxyFactory
-
- createSoftReferenceObjectPool(Supplier<T>) - Static method in class io.lettuce.core.support.ConnectionPoolSupport
-
- createSoftReferenceObjectPool(Supplier<T>, boolean) - Static method in class io.lettuce.core.support.ConnectionPoolSupport
-
- createSslContextBuilder() - Method in class io.lettuce.core.SslOptions
-
- createSSLParameters() - Method in class io.lettuce.core.SslOptions
-
- createTimeoutException(Duration) - Static method in class io.lettuce.core.ExceptionFactory
-
- createTimeoutException(String, Duration) - Static method in class io.lettuce.core.ExceptionFactory
-
- DateOutput<K,V> - Class in io.lettuce.core.output
-
Date output with no milliseconds.
- DateOutput(RedisCodec<K, V>) - Constructor for class io.lettuce.core.output.DateOutput
-
- dbsize() - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- dbsize() - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- dbsize() - Method in interface io.lettuce.core.api.async.RedisServerAsyncCommands
-
Return the number of keys in the selected database.
- dbsize() - Method in interface io.lettuce.core.api.reactive.RedisServerReactiveCommands
-
Return the number of keys in the selected database.
- dbsize() - Method in interface io.lettuce.core.api.sync.RedisServerCommands
-
Return the number of keys in the selected database.
- dbsize() - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionServerAsyncCommands
-
Return the number of keys in the selected database.
- dbsize() - Method in interface io.lettuce.core.cluster.api.async.RedisAdvancedClusterAsyncCommands
-
Return the number of keys in the selected database on all cluster masters.
- dbsize() - Method in interface io.lettuce.core.cluster.api.reactive.RedisAdvancedClusterReactiveCommands
-
Return the number of keys in the selected database on all cluster masters.
- dbsize() - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionServerCommands
-
Return the number of keys in the selected database.
- dbsize() - Method in interface io.lettuce.core.cluster.api.sync.RedisAdvancedClusterCommands
-
Return the number of keys in the selected database on all cluster masters.
- dbsize() - Method in class io.lettuce.core.cluster.RedisAdvancedClusterAsyncCommandsImpl
-
- dbsize() - Method in class io.lettuce.core.cluster.RedisAdvancedClusterReactiveCommandsImpl
-
- deactivated() - Method in interface io.lettuce.core.protocol.ConnectionFacade
-
Callback for a connection deactivated event.
- deactivated() - Method in class io.lettuce.core.RedisChannelHandler
-
Notification when the connection becomes inactive (disconnected).
- debugCrashAndRecover(Long) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- debugCrashAndRecover(Long) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- debugCrashAndRecover(Long) - Method in interface io.lettuce.core.api.async.RedisServerAsyncCommands
-
Crash and recover
- debugCrashAndRecover(Long) - Method in interface io.lettuce.core.api.reactive.RedisServerReactiveCommands
-
Crash and recover
- debugCrashAndRecover(Long) - Method in interface io.lettuce.core.api.sync.RedisServerCommands
-
Crash and recover
- debugCrashAndRecover(Long) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionServerAsyncCommands
-
Crash and recover
- debugCrashAndRecover(Long) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionServerCommands
-
Crash and recover
- debugHtstats(int) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- debugHtstats(int) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- debugHtstats(int) - Method in interface io.lettuce.core.api.async.RedisServerAsyncCommands
-
Get debugging information about the internal hash-table state.
- debugHtstats(int) - Method in interface io.lettuce.core.api.reactive.RedisServerReactiveCommands
-
Get debugging information about the internal hash-table state.
- debugHtstats(int) - Method in interface io.lettuce.core.api.sync.RedisServerCommands
-
Get debugging information about the internal hash-table state.
- debugHtstats(int) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionServerAsyncCommands
-
Get debugging information about the internal hash-table state.
- debugHtstats(int) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionServerCommands
-
Get debugging information about the internal hash-table state.
- debugObject(K) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- debugObject(K) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- debugObject(K) - Method in interface io.lettuce.core.api.async.RedisServerAsyncCommands
-
Get debugging information about a key.
- debugObject(K) - Method in interface io.lettuce.core.api.reactive.RedisServerReactiveCommands
-
Get debugging information about a key.
- debugObject(K) - Method in interface io.lettuce.core.api.sync.RedisServerCommands
-
Get debugging information about a key.
- debugObject(K) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionServerAsyncCommands
-
Get debugging information about a key.
- debugObject(K) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionServerCommands
-
Get debugging information about a key.
- debugOom() - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- debugOom() - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- debugOom() - Method in interface io.lettuce.core.api.async.RedisServerAsyncCommands
-
Make the server crash: Out of memory.
- debugOom() - Method in interface io.lettuce.core.api.reactive.RedisServerReactiveCommands
-
Make the server crash: Out of memory.
- debugOom() - Method in interface io.lettuce.core.api.sync.RedisServerCommands
-
Make the server crash: Out of memory.
- debugReload() - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- debugReload() - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- debugReload() - Method in interface io.lettuce.core.api.async.RedisServerAsyncCommands
-
Save RDB, clear the database and reload RDB.
- debugReload() - Method in interface io.lettuce.core.api.reactive.RedisServerReactiveCommands
-
Save RDB, clear the database and reload RDB.
- debugReload() - Method in interface io.lettuce.core.api.sync.RedisServerCommands
-
Save RDB, clear the database and reload RDB.
- debugReload() - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionServerAsyncCommands
-
Save RDB, clear the database and reload RDB.
- debugReload() - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionServerCommands
-
Save RDB, clear the database and reload RDB.
- debugRestart(Long) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- debugRestart(Long) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- debugRestart(Long) - Method in interface io.lettuce.core.api.async.RedisServerAsyncCommands
-
Restart the server gracefully.
- debugRestart(Long) - Method in interface io.lettuce.core.api.reactive.RedisServerReactiveCommands
-
Restart the server gracefully.
- debugRestart(Long) - Method in interface io.lettuce.core.api.sync.RedisServerCommands
-
Restart the server gracefully.
- debugRestart(Long) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionServerAsyncCommands
-
Restart the server gracefully.
- debugRestart(Long) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionServerCommands
-
Restart the server gracefully.
- debugSdslen(K) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- debugSdslen(K) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- debugSdslen(K) - Method in interface io.lettuce.core.api.async.RedisServerAsyncCommands
-
Get debugging information about the internal SDS length.
- debugSdslen(K) - Method in interface io.lettuce.core.api.reactive.RedisServerReactiveCommands
-
Get debugging information about the internal SDS length.
- debugSdslen(K) - Method in interface io.lettuce.core.api.sync.RedisServerCommands
-
Get debugging information about the internal SDS length.
- debugSdslen(K) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionServerAsyncCommands
-
Get debugging information about the internal SDS length.
- debugSdslen(K) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionServerCommands
-
Get debugging information about the internal SDS length.
- debugSegfault() - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- debugSegfault() - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- debugSegfault() - Method in interface io.lettuce.core.api.async.RedisServerAsyncCommands
-
Make the server crash: Invalid pointer access.
- debugSegfault() - Method in interface io.lettuce.core.api.reactive.RedisServerReactiveCommands
-
Make the server crash: Invalid pointer access.
- debugSegfault() - Method in interface io.lettuce.core.api.sync.RedisServerCommands
-
Make the server crash: Invalid pointer access.
- DeclaredCommandMethod - Class in io.lettuce.core.dynamic
-
Abstraction of a method that is designated to execute a Redis command method.
- decode(ChannelHandlerContext, ByteBuf) - Method in class io.lettuce.core.protocol.CommandHandler
-
- decode(ByteBuf, CommandOutput<?, ?, ?>) - Method in class io.lettuce.core.protocol.CommandHandler
-
- decode(ByteBuf, RedisCommand<?, ?, ?>, CommandOutput<?, ?, ?>) - Method in class io.lettuce.core.protocol.CommandHandler
-
- decode(ByteBuf, CommandOutput<?, ?, ?>) - Method in class io.lettuce.core.protocol.RedisStateMachine
-
Decode a command using the input buffer.
- decode(ByteBuf, RedisCommand<?, ?, ?>, CommandOutput<?, ?, ?>) - Method in class io.lettuce.core.protocol.RedisStateMachine
-
Attempt to decode a redis response and return a flag indicating whether a complete response was read.
- decode(ChannelHandlerContext, ByteBuf) - Method in class io.lettuce.core.pubsub.PubSubCommandHandler
-
- decodeAscii(ByteBuffer) - Method in class io.lettuce.core.output.CommandOutput
-
- decodeKey(ByteBuffer) - Method in class io.lettuce.core.codec.ByteArrayCodec
-
- decodeKey(ByteBuffer) - Method in interface io.lettuce.core.codec.RedisCodec
-
Decode the key output by redis.
- decodeKey(ByteBuffer) - Method in class io.lettuce.core.codec.StringCodec
-
- decodeValue(ByteBuffer) - Method in class io.lettuce.core.codec.ByteArrayCodec
-
- decodeValue(ByteBuffer) - Method in interface io.lettuce.core.codec.RedisCodec
-
Decode the value output by redis.
- decodeValue(ByteBuffer) - Method in class io.lettuce.core.codec.StringCodec
-
- DecoratedCommand<K,V,T> - Interface in io.lettuce.core.protocol
-
- decorrelatedJitter() - Static method in class io.lettuce.core.resource.Delay
-
Creates a
Supplier
that constructs new
DecorrelatedJitterDelay
instances with default boundaries.
- decorrelatedJitter(Duration, Duration, long, TimeUnit) - Static method in class io.lettuce.core.resource.Delay
-
Creates a
Supplier
that constructs new
DecorrelatedJitterDelay
instances.
- decorrelatedJitter(long, long, long, TimeUnit) - Static method in class io.lettuce.core.resource.Delay
-
Creates a
Supplier
that constructs new
DecorrelatedJitterDelay
instances.
- decr(K) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- decr(K) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- decr(K) - Method in interface io.lettuce.core.api.async.RedisStringAsyncCommands
-
Decrement the integer value of a key by one.
- decr(K) - Method in interface io.lettuce.core.api.reactive.RedisStringReactiveCommands
-
Decrement the integer value of a key by one.
- decr(K) - Method in interface io.lettuce.core.api.sync.RedisStringCommands
-
Decrement the integer value of a key by one.
- decr(K) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionStringAsyncCommands
-
Decrement the integer value of a key by one.
- decr(K) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionStringCommands
-
Decrement the integer value of a key by one.
- decrby(K, long) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- decrby(K, long) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- decrby(K, long) - Method in interface io.lettuce.core.api.async.RedisStringAsyncCommands
-
Decrement the integer value of a key by the given number.
- decrby(K, long) - Method in interface io.lettuce.core.api.reactive.RedisStringReactiveCommands
-
Decrement the integer value of a key by the given number.
- decrby(K, long) - Method in interface io.lettuce.core.api.sync.RedisStringCommands
-
Decrement the integer value of a key by the given number.
- decrby(K, long) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionStringAsyncCommands
-
Decrement the integer value of a key by the given number.
- decrby(K, long) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionStringCommands
-
Decrement the integer value of a key by the given number.
- decreaseNestingLevel() - Method in class io.lettuce.core.dynamic.support.MethodParameter
-
Decrease this parameter's nesting level.
- DEFAULT_ADAPTIVE_REFRESH_TIMEOUT - Static variable in class io.lettuce.core.cluster.ClusterTopologyRefreshOptions
-
- DEFAULT_ADAPTIVE_REFRESH_TIMEOUT_DURATION - Static variable in class io.lettuce.core.cluster.ClusterTopologyRefreshOptions
-
- DEFAULT_ADAPTIVE_REFRESH_TIMEOUT_UNIT - Static variable in class io.lettuce.core.cluster.ClusterTopologyRefreshOptions
-
- DEFAULT_ADAPTIVE_REFRESH_TRIGGERS - Static variable in class io.lettuce.core.cluster.ClusterTopologyRefreshOptions
-
- DEFAULT_AUTO_RECONNECT - Static variable in class io.lettuce.core.ClientOptions
-
- DEFAULT_BUFFER_USAGE_RATIO - Static variable in class io.lettuce.core.ClientOptions
-
- DEFAULT_CANCEL_CMD_RECONNECT_FAIL - Static variable in class io.lettuce.core.ClientOptions
-
- DEFAULT_CLOSE_STALE_CONNECTIONS - Static variable in class io.lettuce.core.cluster.ClusterClientOptions
-
- DEFAULT_CLOSE_STALE_CONNECTIONS - Static variable in class io.lettuce.core.cluster.ClusterTopologyRefreshOptions
-
- DEFAULT_COMPUTATION_THREADS - Static variable in class io.lettuce.core.resource.DefaultClientResources
-
- DEFAULT_CONNECT_TIMEOUT - Static variable in class io.lettuce.core.SocketOptions
-
- DEFAULT_CONNECT_TIMEOUT_DURATION - Static variable in class io.lettuce.core.SocketOptions
-
- DEFAULT_CONNECT_TIMEOUT_UNIT - Static variable in class io.lettuce.core.SocketOptions
-
- DEFAULT_DISCONNECTED_BEHAVIOR - Static variable in class io.lettuce.core.ClientOptions
-
- DEFAULT_DYNAMIC_REFRESH_SOURCES - Static variable in class io.lettuce.core.cluster.ClusterTopologyRefreshOptions
-
- DEFAULT_EMIT_INTERVAL - Static variable in class io.lettuce.core.event.DefaultEventPublisherOptions
-
- DEFAULT_EMIT_INTERVAL_DURATION - Static variable in class io.lettuce.core.event.DefaultEventPublisherOptions
-
- DEFAULT_EMIT_INTERVAL_UNIT - Static variable in class io.lettuce.core.event.DefaultEventPublisherOptions
-
- DEFAULT_ENABLED - Static variable in class io.lettuce.core.metrics.DefaultCommandLatencyCollectorOptions
-
- DEFAULT_IO_THREADS - Static variable in class io.lettuce.core.resource.DefaultClientResources
-
- DEFAULT_LOCAL_DISTINCTION - Static variable in class io.lettuce.core.metrics.DefaultCommandLatencyCollectorOptions
-
- DEFAULT_MAX_IDLE - Static variable in class io.lettuce.core.support.BoundedPoolConfig
-
The default value for the maxIdle
configuration attribute.
- DEFAULT_MAX_REDIRECTS - Static variable in class io.lettuce.core.cluster.ClusterClientOptions
-
- DEFAULT_MAX_TOTAL - Static variable in class io.lettuce.core.support.BoundedPoolConfig
-
The default value for the maxTotal
configuration attribute.
- DEFAULT_MIN_IDLE - Static variable in class io.lettuce.core.support.BoundedPoolConfig
-
The default value for the minIdle
configuration attribute.
- DEFAULT_NETTY_CUSTOMIZER - Static variable in class io.lettuce.core.resource.DefaultClientResources
-
- DEFAULT_PERIODIC_REFRESH_ENABLED - Static variable in class io.lettuce.core.cluster.ClusterTopologyRefreshOptions
-
- DEFAULT_PING_BEFORE_ACTIVATE_CONNECTION - Static variable in class io.lettuce.core.ClientOptions
-
- DEFAULT_PUBLISH_ON_SCHEDULER - Static variable in class io.lettuce.core.ClientOptions
-
- DEFAULT_RECONNECT_DELAY - Static variable in class io.lettuce.core.resource.DefaultClientResources
-
- DEFAULT_REDIS_PORT - Static variable in class io.lettuce.core.RedisURI
-
The default redis port.
- DEFAULT_REFRESH_CLUSTER_VIEW - Static variable in class io.lettuce.core.cluster.ClusterClientOptions
-
- DEFAULT_REFRESH_PERIOD - Static variable in class io.lettuce.core.cluster.ClusterClientOptions
-
- DEFAULT_REFRESH_PERIOD - Static variable in class io.lettuce.core.cluster.ClusterTopologyRefreshOptions
-
- DEFAULT_REFRESH_PERIOD_DURATION - Static variable in class io.lettuce.core.cluster.ClusterClientOptions
-
- DEFAULT_REFRESH_PERIOD_DURATION - Static variable in class io.lettuce.core.cluster.ClusterTopologyRefreshOptions
-
- DEFAULT_REFRESH_PERIOD_UNIT - Static variable in class io.lettuce.core.cluster.ClusterTopologyRefreshOptions
-
- DEFAULT_REFRESH_TRIGGERS_RECONNECT_ATTEMPTS - Static variable in class io.lettuce.core.cluster.ClusterTopologyRefreshOptions
-
- DEFAULT_REQUEST_QUEUE_SIZE - Static variable in class io.lettuce.core.ClientOptions
-
- DEFAULT_RESET_LATENCIES_AFTER_EVENT - Static variable in class io.lettuce.core.metrics.DefaultCommandLatencyCollectorOptions
-
- DEFAULT_SENTINEL_PORT - Static variable in class io.lettuce.core.RedisURI
-
The default sentinel port.
- DEFAULT_SO_KEEPALIVE - Static variable in class io.lettuce.core.SocketOptions
-
- DEFAULT_SO_NO_DELAY - Static variable in class io.lettuce.core.SocketOptions
-
- DEFAULT_SOCKET_OPTIONS - Static variable in class io.lettuce.core.ClientOptions
-
- DEFAULT_SSL_OPTIONS - Static variable in class io.lettuce.core.ClientOptions
-
- DEFAULT_SSL_PROVIDER - Static variable in class io.lettuce.core.SslOptions
-
- DEFAULT_SUSPEND_RECONNECT_PROTO_FAIL - Static variable in class io.lettuce.core.ClientOptions
-
- DEFAULT_TARGET_PERCENTILES - Static variable in class io.lettuce.core.metrics.DefaultCommandLatencyCollectorOptions
-
- DEFAULT_TARGET_UNIT - Static variable in class io.lettuce.core.metrics.DefaultCommandLatencyCollectorOptions
-
- DEFAULT_TEST_ON_ACQUIRE - Static variable in class io.lettuce.core.support.BasePoolConfig
-
The default value for the testOnAcquire
configuration attribute.
- DEFAULT_TEST_ON_CREATE - Static variable in class io.lettuce.core.support.BasePoolConfig
-
The default value for the testOnCreate
configuration attribute.
- DEFAULT_TEST_ON_RELEASE - Static variable in class io.lettuce.core.support.BasePoolConfig
-
The default value for the testOnRelease
configuration attribute.
- DEFAULT_TIMEOUT - Static variable in class io.lettuce.core.RedisURI
-
Default timeout: 60 sec
- DEFAULT_TIMEOUT_COMMANDS - Static variable in class io.lettuce.core.TimeoutOptions
-
- DEFAULT_TIMEOUT_DURATION - Static variable in class io.lettuce.core.RedisURI
-
- DEFAULT_TIMEOUT_OPTIONS - Static variable in class io.lettuce.core.ClientOptions
-
- DEFAULT_TIMEOUT_UNIT - Static variable in class io.lettuce.core.RedisURI
-
- DEFAULT_VALIDATE_CLUSTER_MEMBERSHIP - Static variable in class io.lettuce.core.cluster.ClusterClientOptions
-
- DefaultClientResources - Class in io.lettuce.core.resource
-
Default instance of the client resources.
- DefaultClientResources(DefaultClientResources.Builder) - Constructor for class io.lettuce.core.resource.DefaultClientResources
-
- DefaultClientResources.Builder - Class in io.lettuce.core.resource
-
- DefaultCommandLatencyCollector - Class in io.lettuce.core.metrics
-
- DefaultCommandLatencyCollector(CommandLatencyCollectorOptions) - Constructor for class io.lettuce.core.metrics.DefaultCommandLatencyCollector
-
- DefaultCommandLatencyCollectorOptions - Class in io.lettuce.core.metrics
-
- DefaultCommandLatencyCollectorOptions(DefaultCommandLatencyCollectorOptions.Builder) - Constructor for class io.lettuce.core.metrics.DefaultCommandLatencyCollectorOptions
-
- DefaultCommandLatencyCollectorOptions.Builder - Class in io.lettuce.core.metrics
-
- DefaultCommandLatencyEventPublisher - Class in io.lettuce.core.event.metrics
-
- DefaultCommandLatencyEventPublisher(EventExecutorGroup, EventPublisherOptions, EventBus, CommandLatencyCollector) - Constructor for class io.lettuce.core.event.metrics.DefaultCommandLatencyEventPublisher
-
- DefaultEndpoint - Class in io.lettuce.core.protocol
-
- DefaultEndpoint(ClientOptions, ClientResources) - Constructor for class io.lettuce.core.protocol.DefaultEndpoint
-
- DefaultEventBus - Class in io.lettuce.core.event
-
- DefaultEventBus(Scheduler) - Constructor for class io.lettuce.core.event.DefaultEventBus
-
- DefaultEventLoopGroupProvider - Class in io.lettuce.core.resource
-
Default implementation which manages one event loop group instance per type.
- DefaultEventLoopGroupProvider(int) - Constructor for class io.lettuce.core.resource.DefaultEventLoopGroupProvider
-
- DefaultEventLoopGroupProvider(int, DefaultEventLoopGroupProvider.ThreadFactoryProvider) - Constructor for class io.lettuce.core.resource.DefaultEventLoopGroupProvider
-
- DefaultEventLoopGroupProvider.ThreadFactoryProvider - Interface in io.lettuce.core.resource
-
- DefaultEventPublisherOptions - Class in io.lettuce.core.event
-
- DefaultEventPublisherOptions.Builder - Class in io.lettuce.core.event
-
- DefaultMethodInvokingInterceptor - Class in io.lettuce.core.dynamic.intercept
-
Invokes default interface methods.
- DefaultMethodInvokingInterceptor() - Constructor for class io.lettuce.core.dynamic.intercept.DefaultMethodInvokingInterceptor
-
- DefaultMethods - Class in io.lettuce.core.internal
-
- DefaultMethods() - Constructor for class io.lettuce.core.internal.DefaultMethods
-
- del(K...) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- del(Iterable<K>) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- del(K...) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- del(Iterable<K>) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- del(K...) - Method in interface io.lettuce.core.api.async.RedisKeyAsyncCommands
-
Delete one or more keys.
- del(K...) - Method in interface io.lettuce.core.api.reactive.RedisKeyReactiveCommands
-
Delete one or more keys.
- del(K...) - Method in interface io.lettuce.core.api.sync.RedisKeyCommands
-
Delete one or more keys.
- del(K...) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionKeyAsyncCommands
-
Delete one or more keys.
- del(K...) - Method in interface io.lettuce.core.cluster.api.async.RedisAdvancedClusterAsyncCommands
-
Delete one or more keys with pipelining.
- del(K...) - Method in interface io.lettuce.core.cluster.api.async.RedisClusterAsyncCommands
-
Delete a key with pipelining.
- del(K...) - Method in interface io.lettuce.core.cluster.api.reactive.RedisAdvancedClusterReactiveCommands
-
Delete one or more keys with pipelining.
- del(K...) - Method in interface io.lettuce.core.cluster.api.reactive.RedisClusterReactiveCommands
-
Delete a key with pipelining.
- del(K...) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionKeyCommands
-
Delete one or more keys.
- del(K...) - Method in interface io.lettuce.core.cluster.api.sync.RedisAdvancedClusterCommands
-
Delete one or more keys with pipelining.
- del(K...) - Method in class io.lettuce.core.cluster.RedisAdvancedClusterAsyncCommandsImpl
-
- del(Iterable<K>) - Method in class io.lettuce.core.cluster.RedisAdvancedClusterAsyncCommandsImpl
-
- del(K...) - Method in class io.lettuce.core.cluster.RedisAdvancedClusterReactiveCommandsImpl
-
- del(Iterable<K>) - Method in class io.lettuce.core.cluster.RedisAdvancedClusterReactiveCommandsImpl
-
- Delay - Class in io.lettuce.core.resource
-
Base class for delays and factory class to create particular instances.
- Delay() - Constructor for class io.lettuce.core.resource.Delay
-
- Delay.StatefulDelay - Interface in io.lettuce.core.resource
-
Interface to be implemented by stateful
Delay
s.
- DemandAware - Interface in io.lettuce.core.protocol
-
Interface for demand-aware components.
- DemandAware.Sink - Interface in io.lettuce.core.protocol
-
- DemandAware.Source - Interface in io.lettuce.core.protocol
-
- desc() - Method in class io.lettuce.core.GeoArgs
-
Sort results descending.
- desc() - Method in class io.lettuce.core.GeoRadiusStoreArgs
-
Sort results descending.
- desc() - Static method in class io.lettuce.core.SortArgs.Builder
-
- desc() - Method in class io.lettuce.core.SortArgs
-
Apply numeric sort in descending order.
- destroy(T) - Method in interface io.lettuce.core.support.AsyncObjectFactory
-
Destroys an instance no longer needed by the pool.
- destroyInstance(ClientResources) - Method in class io.lettuce.core.support.ClientResourcesFactoryBean
-
- destroyInstance(RedisClient) - Method in class io.lettuce.core.support.RedisClientFactoryBean
-
- destroyInstance(RedisClusterClient) - Method in class io.lettuce.core.support.RedisClusterClientFactoryBean
-
- determinePartitions(Partitions, Map<RedisURI, Partitions>) - Method in class io.lettuce.core.cluster.RedisClusterClient
-
Determines a
topology view
based on the current and the obtain topology views.
- digest(V) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- digest(V) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- digest(V) - Method in interface io.lettuce.core.api.async.RedisScriptingAsyncCommands
-
Create a SHA1 digest from a Lua script.
- digest(V) - Method in interface io.lettuce.core.api.reactive.RedisScriptingReactiveCommands
-
Create a SHA1 digest from a Lua script.
- digest(V) - Method in interface io.lettuce.core.api.sync.RedisScriptingCommands
-
Create a SHA1 digest from a Lua script.
- digest(byte[]) - Static method in class io.lettuce.core.LettuceStrings
-
Create SHA1 digest from Lua script.
- digest(ByteBuffer) - Static method in class io.lettuce.core.LettuceStrings
-
Create SHA1 digest from Lua script.
- DirContextDnsResolver - Class in io.lettuce.core.resource
-
DNS Resolver based on Java's com.sun.jndi.dns.DnsContextFactory
.
- DirContextDnsResolver() - Constructor for class io.lettuce.core.resource.DirContextDnsResolver
-
- DirContextDnsResolver(String) - Constructor for class io.lettuce.core.resource.DirContextDnsResolver
-
- DirContextDnsResolver(Iterable<String>) - Constructor for class io.lettuce.core.resource.DirContextDnsResolver
-
- DirContextDnsResolver(boolean, boolean, Properties) - Constructor for class io.lettuce.core.resource.DirContextDnsResolver
-
- disable() - Method in interface io.lettuce.core.metrics.CommandLatencyCollectorOptions.Builder
-
Disable the latency collector.
- disable() - Method in class io.lettuce.core.metrics.DefaultCommandLatencyCollectorOptions.Builder
-
Disable the latency collector.
- disabled() - Static method in class io.lettuce.core.event.DefaultEventPublisherOptions
-
- disabled() - Static method in interface io.lettuce.core.metrics.CommandLatencyCollector
-
- disabled() - Static method in interface io.lettuce.core.metrics.CommandLatencyCollectorOptions
-
- disabled() - Static method in class io.lettuce.core.metrics.DefaultCommandLatencyCollector
-
- disabled() - Static method in class io.lettuce.core.metrics.DefaultCommandLatencyCollectorOptions
-
- disabled() - Static method in interface io.lettuce.core.tracing.Tracing
-
- discard() - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- discard() - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- discard() - Method in interface io.lettuce.core.api.async.RedisTransactionalAsyncCommands
-
Discard all commands issued after MULTI.
- discard() - Method in interface io.lettuce.core.api.reactive.RedisTransactionalReactiveCommands
-
Discard all commands issued after MULTI.
- discard() - Method in interface io.lettuce.core.api.sync.RedisTransactionalCommands
-
Discard all commands issued after MULTI.
- disconnectedBehavior(ClientOptions.DisconnectedBehavior) - Method in class io.lettuce.core.ClientOptions.Builder
-
Sets the behavior for command invocation when connections are in a disconnected state.
- disconnectedBehavior(ClientOptions.DisconnectedBehavior) - Method in class io.lettuce.core.cluster.ClusterClientOptions.Builder
-
- DisconnectedEvent - Class in io.lettuce.core.event.connection
-
Event for a disconnect on TCP-level.
- DisconnectedEvent(SocketAddress, SocketAddress) - Constructor for class io.lettuce.core.event.connection.DisconnectedEvent
-
- dispatch(ProtocolKeyword, CommandOutput<K, V, T>) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- dispatch(ProtocolKeyword, CommandOutput<K, V, T>, CommandArgs<K, V>) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- dispatch(CommandType, CommandOutput<K, V, T>) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- dispatch(CommandType, CommandOutput<K, V, T>, CommandArgs<K, V>) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- dispatch(RedisCommand<K, V, T>) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- dispatch(ProtocolKeyword, CommandOutput<K, V, ?>) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- dispatch(ProtocolKeyword, CommandOutput<K, V, ?>, CommandArgs<K, V>) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- dispatch(ProtocolKeyword, CommandOutput<K, V, T>) - Method in interface io.lettuce.core.api.async.BaseRedisAsyncCommands
-
Dispatch a command to the Redis Server.
- dispatch(ProtocolKeyword, CommandOutput<K, V, T>, CommandArgs<K, V>) - Method in interface io.lettuce.core.api.async.BaseRedisAsyncCommands
-
Dispatch a command to the Redis Server.
- dispatch(ProtocolKeyword, CommandOutput<K, V, ?>) - Method in interface io.lettuce.core.api.reactive.BaseRedisReactiveCommands
-
Dispatch a command to the Redis Server.
- dispatch(ProtocolKeyword, CommandOutput<K, V, ?>, CommandArgs<K, V>) - Method in interface io.lettuce.core.api.reactive.BaseRedisReactiveCommands
-
Dispatch a command to the Redis Server.
- dispatch(RedisCommand<K, V, T>) - Method in interface io.lettuce.core.api.StatefulConnection
-
Dispatch a command.
- dispatch(Collection<? extends RedisCommand<K, V, ?>>) - Method in interface io.lettuce.core.api.StatefulConnection
-
Dispatch multiple command in a single write on the channel.
- dispatch(ProtocolKeyword, CommandOutput<K, V, T>) - Method in interface io.lettuce.core.api.sync.BaseRedisCommands
-
Dispatch a command to the Redis Server.
- dispatch(ProtocolKeyword, CommandOutput<K, V, T>, CommandArgs<K, V>) - Method in interface io.lettuce.core.api.sync.BaseRedisCommands
-
Dispatch a command to the Redis Server.
- dispatch(ProtocolKeyword, CommandOutput<K, V, T>) - Method in interface io.lettuce.core.cluster.api.async.BaseNodeSelectionAsyncCommands
-
Dispatch a command to the Redis Server.
- dispatch(ProtocolKeyword, CommandOutput<K, V, T>, CommandArgs<K, V>) - Method in interface io.lettuce.core.cluster.api.async.BaseNodeSelectionAsyncCommands
-
Dispatch a command to the Redis Server.
- dispatch(RedisCommand<K, V, T>) - Method in class io.lettuce.core.cluster.StatefulRedisClusterConnectionImpl
-
- dispatch(Collection<? extends RedisCommand<K, V, ?>>) - Method in class io.lettuce.core.cluster.StatefulRedisClusterConnectionImpl
-
- dispatch(RedisCommand<K, V, T>) - Method in class io.lettuce.core.RedisChannelHandler
-
- dispatch(Collection<? extends RedisCommand<K, V, ?>>) - Method in class io.lettuce.core.RedisChannelHandler
-
- dispatch(ProtocolKeyword, CommandOutput<K, V, T>) - Method in interface io.lettuce.core.sentinel.api.async.RedisSentinelAsyncCommands
-
Dispatch a command to the Redis Server.
- dispatch(ProtocolKeyword, CommandOutput<K, V, T>, CommandArgs<K, V>) - Method in interface io.lettuce.core.sentinel.api.async.RedisSentinelAsyncCommands
-
Dispatch a command to the Redis Server.
- dispatch(ProtocolKeyword, CommandOutput<K, V, ?>) - Method in interface io.lettuce.core.sentinel.api.reactive.RedisSentinelReactiveCommands
-
Dispatch a command to the Redis Server.
- dispatch(ProtocolKeyword, CommandOutput<K, V, ?>, CommandArgs<K, V>) - Method in interface io.lettuce.core.sentinel.api.reactive.RedisSentinelReactiveCommands
-
Dispatch a command to the Redis Server.
- dispatch(ProtocolKeyword, CommandOutput<K, V, T>) - Method in interface io.lettuce.core.sentinel.api.sync.RedisSentinelCommands
-
Dispatch a command to the Redis Server.
- dispatch(ProtocolKeyword, CommandOutput<K, V, T>, CommandArgs<K, V>) - Method in interface io.lettuce.core.sentinel.api.sync.RedisSentinelCommands
-
Dispatch a command to the Redis Server.
- dispatch(ProtocolKeyword, CommandOutput<K, V, T>) - Method in class io.lettuce.core.sentinel.RedisSentinelAsyncCommandsImpl
-
- dispatch(ProtocolKeyword, CommandOutput<K, V, T>, CommandArgs<K, V>) - Method in class io.lettuce.core.sentinel.RedisSentinelAsyncCommandsImpl
-
- dispatch(RedisCommand<K, V, T>) - Method in class io.lettuce.core.sentinel.RedisSentinelAsyncCommandsImpl
-
- dispatch(ProtocolKeyword, CommandOutput<K, V, ?>) - Method in class io.lettuce.core.sentinel.RedisSentinelReactiveCommandsImpl
-
- dispatch(ProtocolKeyword, CommandOutput<K, V, ?>, CommandArgs<K, V>) - Method in class io.lettuce.core.sentinel.RedisSentinelReactiveCommandsImpl
-
- dispatch(RedisCommand<K, V, T>) - Method in class io.lettuce.core.sentinel.StatefulRedisSentinelConnectionImpl
-
- dispatch(Collection<? extends RedisCommand<K, V, ?>>) - Method in class io.lettuce.core.sentinel.StatefulRedisSentinelConnectionImpl
-
- dispatch(RedisCommand<K, V, T>) - Method in class io.lettuce.core.StatefulRedisConnectionImpl
-
- dispatch(Collection<? extends RedisCommand<K, V, ?>>) - Method in class io.lettuce.core.StatefulRedisConnectionImpl
-
- distance() - Static method in class io.lettuce.core.GeoArgs.Builder
-
Creates new
GeoArgs
with WITHDIST enabled.
- dnsResolver(DnsResolver) - Method in interface io.lettuce.core.resource.ClientResources.Builder
-
- dnsResolver() - Method in interface io.lettuce.core.resource.ClientResources
-
- dnsResolver(DnsResolver) - Method in class io.lettuce.core.resource.DefaultClientResources.Builder
-
- dnsResolver() - Method in class io.lettuce.core.resource.DefaultClientResources
-
- DnsResolver - Interface in io.lettuce.core.resource
-
Users may implement this interface to override the normal DNS lookup offered by the OS.
- DnsResolvers - Enum in io.lettuce.core.resource
-
Predefined DNS resolvers.
- doExclusive(Supplier<T>) - Method in class io.lettuce.core.protocol.DefaultEndpoint
-
Execute a
Supplier
callback guarded by an exclusive lock.
- doGetParameterNames(Annotation[][]) - Method in class io.lettuce.core.dynamic.support.AnnotationParameterNameDiscoverer
-
- domainSocketChannelClass() - Method in interface io.lettuce.core.EpollProvider.EpollResources
-
- domainSocketChannelClass() - Method in interface io.lettuce.core.KqueueProvider.KqueueResources
-
- DoubleOutput<K,V> - Class in io.lettuce.core.output
-
Double output, may be null.
- DoubleOutput(RedisCodec<K, V>) - Constructor for class io.lettuce.core.output.DoubleOutput
-
- doWith(Field) - Method in interface io.lettuce.core.dynamic.support.ReflectionUtils.FieldCallback
-
Perform an operation using the given field.
- doWith(Method) - Method in interface io.lettuce.core.dynamic.support.ReflectionUtils.MethodCallback
-
Perform an operation using the given method.
- doWithFields(Class<?>, ReflectionUtils.FieldCallback) - Static method in class io.lettuce.core.dynamic.support.ReflectionUtils
-
Invoke the given callback on all fields in the target class, going up the class hierarchy to get all declared fields.
- doWithFields(Class<?>, ReflectionUtils.FieldCallback, ReflectionUtils.FieldFilter) - Static method in class io.lettuce.core.dynamic.support.ReflectionUtils
-
Invoke the given callback on all fields in the target class, going up the class hierarchy to get all declared fields.
- doWithMethods(Class<?>, ReflectionUtils.MethodCallback) - Static method in class io.lettuce.core.dynamic.support.ReflectionUtils
-
Perform the given callback operation on all matching methods of the given class and superclasses.
- doWithMethods(Class<?>, ReflectionUtils.MethodCallback, ReflectionUtils.MethodFilter) - Static method in class io.lettuce.core.dynamic.support.ReflectionUtils
-
Perform the given callback operation on all matching methods of the given class and superclasses (or given interface and
super-interfaces).
- drainCommands() - Method in class io.lettuce.core.protocol.DefaultEndpoint
-
- drainQueue() - Method in class io.lettuce.core.protocol.CommandHandler
-
- dump(K) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- dump(K) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- dump(K) - Method in interface io.lettuce.core.api.async.RedisKeyAsyncCommands
-
Return a serialized version of the value stored at the specified key.
- dump(K) - Method in interface io.lettuce.core.api.reactive.RedisKeyReactiveCommands
-
Return a serialized version of the value stored at the specified key.
- dump(K) - Method in interface io.lettuce.core.api.sync.RedisKeyCommands
-
Return a serialized version of the value stored at the specified key.
- dump(K) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionKeyAsyncCommands
-
Return a serialized version of the value stored at the specified key.
- dump(K) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionKeyCommands
-
Return a serialized version of the value stored at the specified key.
- dynamicRefreshSources(boolean) - Method in class io.lettuce.core.cluster.ClusterTopologyRefreshOptions.Builder
-
Discover cluster nodes from topology and use the discovered nodes as source for the cluster topology.
- echo(V) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- echo(V) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- echo(V) - Method in interface io.lettuce.core.api.async.BaseRedisAsyncCommands
-
Echo the given string.
- echo(V) - Method in interface io.lettuce.core.api.reactive.BaseRedisReactiveCommands
-
Echo the given string.
- echo(V) - Method in interface io.lettuce.core.api.sync.BaseRedisCommands
-
Echo the given string.
- echo(V) - Method in interface io.lettuce.core.cluster.api.async.BaseNodeSelectionAsyncCommands
-
Echo the given string.
- echo(V) - Method in interface io.lettuce.core.cluster.api.sync.BaseNodeSelectionCommands
-
Echo the given string.
- emitMetricsEvent() - Method in class io.lettuce.core.event.metrics.DefaultCommandLatencyEventPublisher
-
- emitMetricsEvent() - Method in interface io.lettuce.core.event.metrics.MetricEventPublisher
-
Emit immediately a metrics event.
- empty(K) - Static method in class io.lettuce.core.KeyValue
-
Returns an empty KeyValue
instance with the key
set.
- empty() - Static method in class io.lettuce.core.ScoredValue
-
Returns an empty ScoredValue
instance.
- EMPTY - Static variable in interface io.lettuce.core.tracing.TraceContext
-
- empty() - Static method in class io.lettuce.core.Value
-
Returns an empty Value
instance.
- enable() - Method in interface io.lettuce.core.metrics.CommandLatencyCollectorOptions.Builder
-
Enable the latency collector.
- enable() - Method in class io.lettuce.core.metrics.DefaultCommandLatencyCollectorOptions.Builder
-
Enable the latency collector.
- enableAdaptiveRefreshTrigger(ClusterTopologyRefreshOptions.RefreshTrigger...) - Method in class io.lettuce.core.cluster.ClusterTopologyRefreshOptions.Builder
-
Enables adaptive topology refreshing using one or more
triggers
.
- enableAllAdaptiveRefreshTriggers() - Method in class io.lettuce.core.cluster.ClusterTopologyRefreshOptions.Builder
-
Enables adaptive topology refreshing using all
triggers
.
- enableAuthPingBeforeConnect() - Method in class io.lettuce.core.ConnectionBuilder
-
- enabled() - Static method in class io.lettuce.core.cluster.ClusterTopologyRefreshOptions
-
- enabled() - Static method in class io.lettuce.core.TimeoutOptions
-
Create a new instance of
TimeoutOptions
with enabled timeout applying default connection timeouts.
- enabled(Duration) - Static method in class io.lettuce.core.TimeoutOptions
-
- enablePeriodicRefresh() - Method in class io.lettuce.core.cluster.ClusterTopologyRefreshOptions.Builder
-
Enables periodic cluster topology updates.
- enablePeriodicRefresh(boolean) - Method in class io.lettuce.core.cluster.ClusterTopologyRefreshOptions.Builder
-
Enable regular cluster topology updates.
- enablePeriodicRefresh(Duration) - Method in class io.lettuce.core.cluster.ClusterTopologyRefreshOptions.Builder
-
Enables periodic refresh and sets the refresh period.
- enablePeriodicRefresh(long, TimeUnit) - Method in class io.lettuce.core.cluster.ClusterTopologyRefreshOptions.Builder
-
- enablePingBeforeConnect() - Method in class io.lettuce.core.ConnectionBuilder
-
- encode(byte[], boolean) - Static method in class io.lettuce.core.codec.Base16
-
Encode bytes to base16 chars.
- encode(String, ByteBuf) - Method in class io.lettuce.core.codec.StringCodec
-
- encode(ByteBuf) - Method in class io.lettuce.core.protocol.AsyncCommand
-
- encode(ByteBuf) - Method in class io.lettuce.core.protocol.Command
-
- encode(ByteBuf) - Method in class io.lettuce.core.protocol.CommandArgs
-
- encode(ChannelHandlerContext, Object, ByteBuf) - Method in class io.lettuce.core.protocol.CommandEncoder
-
- encode(ByteBuf) - Method in class io.lettuce.core.protocol.CommandWrapper
-
- encode(ByteBuf) - Method in interface io.lettuce.core.protocol.RedisCommand
-
Encode the command.
- encode(ByteBuf) - Method in class io.lettuce.core.protocol.TracedCommand
-
- encodeFirstKey(CommandArgs<K, V>) - Static method in class io.lettuce.core.protocol.CommandArgsAccessor
-
Get the first encoded key for cluster command routing.
- encodeKey(byte[], ByteBuf) - Method in class io.lettuce.core.codec.ByteArrayCodec
-
- encodeKey(byte[]) - Method in class io.lettuce.core.codec.ByteArrayCodec
-
- encodeKey(K) - Method in interface io.lettuce.core.codec.RedisCodec
-
Encode the key for output to redis.
- encodeKey(String, ByteBuf) - Method in class io.lettuce.core.codec.StringCodec
-
- encodeKey(String) - Method in class io.lettuce.core.codec.StringCodec
-
- encodeKey(K, ByteBuf) - Method in interface io.lettuce.core.codec.ToByteBufEncoder
-
Encode the key for output to redis.
- encodeValue(byte[], ByteBuf) - Method in class io.lettuce.core.codec.ByteArrayCodec
-
- encodeValue(byte[]) - Method in class io.lettuce.core.codec.ByteArrayCodec
-
- encodeValue(V) - Method in interface io.lettuce.core.codec.RedisCodec
-
Encode the value for output to redis.
- encodeValue(String, ByteBuf) - Method in class io.lettuce.core.codec.StringCodec
-
- encodeValue(String) - Method in class io.lettuce.core.codec.StringCodec
-
- encodeValue(V, ByteBuf) - Method in interface io.lettuce.core.codec.ToByteBufEncoder
-
Encode the value for output to redis.
- encryptionKey() - Method in interface io.lettuce.core.codec.CipherCodec.CipherSupplier
-
- endpoint(Endpoint) - Method in class io.lettuce.core.ConnectionBuilder
-
- endpoint() - Method in class io.lettuce.core.ConnectionBuilder
-
- Endpoint - Interface in io.lettuce.core.protocol
-
Wraps a stateful
Endpoint
that abstracts the underlying channel.
- endpointCustomizer(Consumer<Endpoint.Builder>) - Method in class io.lettuce.core.tracing.BraveTracing.Builder
-
Sets an Endpoint
customizer to customize the Endpoint
through its
Endpoint.Builder
.
- EpollProvider - Class in io.lettuce.core
-
Wraps and provides Epoll classes.
- EpollProvider() - Constructor for class io.lettuce.core.EpollProvider
-
- EpollProvider.EpollResources - Interface in io.lettuce.core
-
- equalJitter() - Static method in class io.lettuce.core.resource.Delay
-
Creates a new EqualJitterDelay
with default boundaries.
- equalJitter(Duration, Duration, long, TimeUnit) - Static method in class io.lettuce.core.resource.Delay
-
Creates a new EqualJitterDelay
.
- equalJitter(long, long, long, TimeUnit) - Static method in class io.lettuce.core.resource.Delay
-
Creates a new EqualJitterDelay
.
- equals(Object) - Method in class io.lettuce.core.cluster.models.partitions.RedisClusterNode
-
- equals(Object) - Method in class io.lettuce.core.Consumer
-
- equals(Object) - Method in class io.lettuce.core.dynamic.DeclaredCommandMethod
-
- equals(Object) - Method in class io.lettuce.core.dynamic.support.MethodParameter
-
- equals(Object) - Method in class io.lettuce.core.dynamic.support.ResolvableType
-
- equals(Object) - Method in class io.lettuce.core.dynamic.support.TypeVariableTypeInformation
-
- equals(Object) - Method in class io.lettuce.core.GeoCoordinates
-
- equals(Object) - Method in class io.lettuce.core.GeoWithin
-
- equals(Object) - Method in class io.lettuce.core.internal.AbstractInvocationHandler
-
- equals(Object) - Method in class io.lettuce.core.internal.HostAndPort
-
- equals(Object) - Method in class io.lettuce.core.KeyValue
-
- equals(Object) - Method in class io.lettuce.core.metrics.CommandLatencyId
-
- equals(Object) - Method in class io.lettuce.core.protocol.AsyncCommand
-
- equals(Object) - Method in class io.lettuce.core.protocol.CommandWrapper
-
- equals(Object) - Method in class io.lettuce.core.Range.Boundary
-
- equals(Object) - Method in class io.lettuce.core.Range
-
- equals(Object) - Method in class io.lettuce.core.RedisURI
-
- equals(Object) - Method in class io.lettuce.core.ScoredValue
-
- equals(Object) - Method in class io.lettuce.core.StreamMessage
-
- equals(Object) - Method in class io.lettuce.core.Value
-
- error - Variable in class io.lettuce.core.output.CommandOutput
-
- error(Throwable) - Method in class io.lettuce.core.tracing.Tracer.Span
-
- estimateSize(Object) - Method in class io.lettuce.core.codec.ByteArrayCodec
-
- estimateSize(Object) - Method in class io.lettuce.core.codec.StringCodec
-
- estimateSize(Object) - Method in interface io.lettuce.core.codec.ToByteBufEncoder
-
Estimates the size of the resulting byte stream.
- eval(String, ScriptOutputType, K...) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- eval(String, ScriptOutputType, K[], V...) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- eval(String, ScriptOutputType, K...) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- eval(String, ScriptOutputType, K[], V...) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- eval(String, ScriptOutputType, K...) - Method in interface io.lettuce.core.api.async.RedisScriptingAsyncCommands
-
Execute a Lua script server side.
- eval(String, ScriptOutputType, K[], V...) - Method in interface io.lettuce.core.api.async.RedisScriptingAsyncCommands
-
Execute a Lua script server side.
- eval(String, ScriptOutputType, K...) - Method in interface io.lettuce.core.api.reactive.RedisScriptingReactiveCommands
-
Execute a Lua script server side.
- eval(String, ScriptOutputType, K[], V...) - Method in interface io.lettuce.core.api.reactive.RedisScriptingReactiveCommands
-
Execute a Lua script server side.
- eval(String, ScriptOutputType, K...) - Method in interface io.lettuce.core.api.sync.RedisScriptingCommands
-
Execute a Lua script server side.
- eval(String, ScriptOutputType, K[], V...) - Method in interface io.lettuce.core.api.sync.RedisScriptingCommands
-
Execute a Lua script server side.
- eval(String, ScriptOutputType, K...) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionScriptingAsyncCommands
-
Execute a Lua script server side.
- eval(String, ScriptOutputType, K[], V...) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionScriptingAsyncCommands
-
Execute a Lua script server side.
- eval(String, ScriptOutputType, K...) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionScriptingCommands
-
Execute a Lua script server side.
- eval(String, ScriptOutputType, K[], V...) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionScriptingCommands
-
Execute a Lua script server side.
- evalsha(String, ScriptOutputType, K...) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- evalsha(String, ScriptOutputType, K[], V...) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- evalsha(String, ScriptOutputType, K...) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- evalsha(String, ScriptOutputType, K[], V...) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- evalsha(String, ScriptOutputType, K...) - Method in interface io.lettuce.core.api.async.RedisScriptingAsyncCommands
-
Evaluates a script cached on the server side by its SHA1 digest
- evalsha(String, ScriptOutputType, K[], V...) - Method in interface io.lettuce.core.api.async.RedisScriptingAsyncCommands
-
Execute a Lua script server side.
- evalsha(String, ScriptOutputType, K...) - Method in interface io.lettuce.core.api.reactive.RedisScriptingReactiveCommands
-
Evaluates a script cached on the server side by its SHA1 digest
- evalsha(String, ScriptOutputType, K[], V...) - Method in interface io.lettuce.core.api.reactive.RedisScriptingReactiveCommands
-
Execute a Lua script server side.
- evalsha(String, ScriptOutputType, K...) - Method in interface io.lettuce.core.api.sync.RedisScriptingCommands
-
Evaluates a script cached on the server side by its SHA1 digest
- evalsha(String, ScriptOutputType, K[], V...) - Method in interface io.lettuce.core.api.sync.RedisScriptingCommands
-
Execute a Lua script server side.
- evalsha(String, ScriptOutputType, K...) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionScriptingAsyncCommands
-
Evaluates a script cached on the server side by its SHA1 digest
- evalsha(String, ScriptOutputType, K[], V...) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionScriptingAsyncCommands
-
Execute a Lua script server side.
- evalsha(String, ScriptOutputType, K...) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionScriptingCommands
-
Evaluates a script cached on the server side by its SHA1 digest
- evalsha(String, ScriptOutputType, K[], V...) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionScriptingCommands
-
Execute a Lua script server side.
- Event - Interface in io.lettuce.core.event
-
Marker-interface for events that are published over the event bus.
- EventBus - Interface in io.lettuce.core.event
-
Interface for an EventBus.
- eventBus(EventBus) - Method in interface io.lettuce.core.resource.ClientResources.Builder
-
Sets the
EventBus
that can that can be used across different instances of the RedisClient.
- eventBus() - Method in interface io.lettuce.core.resource.ClientResources
-
Returns the event bus used to publish events.
- eventBus(EventBus) - Method in class io.lettuce.core.resource.DefaultClientResources.Builder
-
Sets the
EventBus
that can that can be used across different instances of the RedisClient.
- eventBus() - Method in class io.lettuce.core.resource.DefaultClientResources
-
- eventEmitInterval(Duration) - Method in class io.lettuce.core.event.DefaultEventPublisherOptions.Builder
-
Sets the emit interval and the interval unit.
- eventEmitInterval(long, TimeUnit) - Method in class io.lettuce.core.event.DefaultEventPublisherOptions.Builder
-
- eventEmitInterval() - Method in class io.lettuce.core.event.DefaultEventPublisherOptions
-
- eventEmitInterval() - Method in interface io.lettuce.core.event.EventPublisherOptions
-
Returns the interval for emit metrics.
- eventExecutorGroup(EventExecutorGroup) - Method in interface io.lettuce.core.resource.ClientResources.Builder
-
- eventExecutorGroup() - Method in interface io.lettuce.core.resource.ClientResources
-
Returns the computation pool used for internal operations.
- eventExecutorGroup(EventExecutorGroup) - Method in class io.lettuce.core.resource.DefaultClientResources.Builder
-
- eventExecutorGroup() - Method in class io.lettuce.core.resource.DefaultClientResources
-
- eventLoopGroupClass() - Method in interface io.lettuce.core.EpollProvider.EpollResources
-
- eventLoopGroupClass() - Method in interface io.lettuce.core.KqueueProvider.KqueueResources
-
- eventLoopGroupProvider(EventLoopGroupProvider) - Method in interface io.lettuce.core.resource.ClientResources.Builder
-
- eventLoopGroupProvider() - Method in interface io.lettuce.core.resource.ClientResources
-
- eventLoopGroupProvider(EventLoopGroupProvider) - Method in class io.lettuce.core.resource.DefaultClientResources.Builder
-
- eventLoopGroupProvider() - Method in class io.lettuce.core.resource.DefaultClientResources
-
- EventLoopGroupProvider - Interface in io.lettuce.core.resource
-
- eventLoopGroups - Variable in class io.lettuce.core.AbstractRedisClient
-
- EventPublisherOptions - Interface in io.lettuce.core.event
-
Configuration interface for command latency collection.
- ex(long) - Static method in class io.lettuce.core.SetArgs.Builder
-
Creates new
SetArgs
and enabling EX.
- ex(long) - Method in class io.lettuce.core.SetArgs
-
Set the specified expire time, in seconds.
- exception - Variable in class io.lettuce.core.protocol.Command
-
- exceptionally(Function<Throwable, ? extends T>) - Method in interface io.lettuce.core.ConnectionFuture
-
- exceptionCaught(ChannelHandlerContext, Throwable) - Method in class io.lettuce.core.protocol.CommandHandler
-
- ExceptionFactory - Class in io.lettuce.core
-
Factory for Redis exceptions.
- excludeCommandArgsFromSpanTags() - Method in class io.lettuce.core.tracing.BraveTracing.Builder
-
Excludes command arguments from Span
tags.
- excluding(T) - Static method in class io.lettuce.core.Range.Boundary
-
Create a
Range.Boundary
based on the
value
that excludes the value when comparing ranges.
- exec() - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- exec() - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- exec() - Method in interface io.lettuce.core.api.async.RedisTransactionalAsyncCommands
-
Execute all commands issued after MULTI.
- exec() - Method in interface io.lettuce.core.api.reactive.RedisTransactionalReactiveCommands
-
Execute all commands issued after MULTI.
- exec() - Method in interface io.lettuce.core.api.sync.RedisTransactionalCommands
-
Execute all commands issued after MULTI.
- executeOnMasters(Function<RedisClusterAsyncCommands<K, V>, RedisFuture<T>>) - Method in class io.lettuce.core.cluster.RedisAdvancedClusterAsyncCommandsImpl
-
Run a command on all available masters,
- executeOnMasters(Function<RedisClusterReactiveCommands<K, V>, ? extends Publisher<T>>) - Method in class io.lettuce.core.cluster.RedisAdvancedClusterReactiveCommandsImpl
-
Run a command on all available masters,
- executeOnNodes(Function<RedisClusterAsyncCommands<K, V>, RedisFuture<T>>, Function<RedisClusterNode, Boolean>) - Method in class io.lettuce.core.cluster.RedisAdvancedClusterAsyncCommandsImpl
-
Run a command on all available nodes that match filter
.
- executeOnNodes(Function<RedisClusterReactiveCommands<K, V>, ? extends Publisher<T>>, Predicate<RedisClusterNode>) - Method in class io.lettuce.core.cluster.RedisAdvancedClusterReactiveCommandsImpl
-
Run a command on all available nodes that match filter
.
- ExecutionAwareParameter(Method, int) - Constructor for class io.lettuce.core.dynamic.parameter.ExecutionSpecificParameters.ExecutionAwareParameter
-
- Executions<T> - Interface in io.lettuce.core.cluster.api.sync
-
Result holder for a command that was executed synchronously on multiple nodes.
- ExecutionSpecificParameters - Class in io.lettuce.core.dynamic.parameter
-
- ExecutionSpecificParameters(Method) - Constructor for class io.lettuce.core.dynamic.parameter.ExecutionSpecificParameters
-
- ExecutionSpecificParameters.ExecutionAwareParameter - Class in io.lettuce.core.dynamic.parameter
-
- exists(K...) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- exists(Iterable<K>) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- exists(K) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- exists(K...) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- exists(Iterable<K>) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- exists(K...) - Method in interface io.lettuce.core.api.async.RedisKeyAsyncCommands
-
Determine how many keys exist.
- exists(K...) - Method in interface io.lettuce.core.api.reactive.RedisKeyReactiveCommands
-
Determine how many keys exist.
- exists(K...) - Method in interface io.lettuce.core.api.sync.RedisKeyCommands
-
Determine how many keys exist.
- exists(K...) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionKeyAsyncCommands
-
Determine how many keys exist.
- exists(K...) - Method in interface io.lettuce.core.cluster.api.async.RedisAdvancedClusterAsyncCommands
-
Determine how many keys exist with pipelining.
- exists(K...) - Method in interface io.lettuce.core.cluster.api.reactive.RedisAdvancedClusterReactiveCommands
-
Determine how many keys exist with pipelining.
- exists(K...) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionKeyCommands
-
Determine how many keys exist.
- exists(K...) - Method in interface io.lettuce.core.cluster.api.sync.RedisAdvancedClusterCommands
-
Determine how many keys exist with pipelining.
- exists(K...) - Method in class io.lettuce.core.cluster.RedisAdvancedClusterAsyncCommandsImpl
-
- exists(Iterable<K>) - Method in class io.lettuce.core.cluster.RedisAdvancedClusterAsyncCommandsImpl
-
- exists(K...) - Method in class io.lettuce.core.cluster.RedisAdvancedClusterReactiveCommandsImpl
-
- exists(Iterable<K>) - Method in class io.lettuce.core.cluster.RedisAdvancedClusterReactiveCommandsImpl
-
- expire(K, long) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- expire(K, long) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- expire(K, long) - Method in interface io.lettuce.core.api.async.RedisKeyAsyncCommands
-
Set a key's time to live in seconds.
- expire(K, long) - Method in interface io.lettuce.core.api.reactive.RedisKeyReactiveCommands
-
Set a key's time to live in seconds.
- expire(K, long) - Method in interface io.lettuce.core.api.sync.RedisKeyCommands
-
Set a key's time to live in seconds.
- expire(K, long) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionKeyAsyncCommands
-
Set a key's time to live in seconds.
- expire(K, long) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionKeyCommands
-
Set a key's time to live in seconds.
- expireat(K, Date) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- expireat(K, long) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- expireat(K, long) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- expireat(K, Date) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- expireat(K, Date) - Method in interface io.lettuce.core.api.async.RedisKeyAsyncCommands
-
Set the expiration for a key as a UNIX timestamp.
- expireat(K, long) - Method in interface io.lettuce.core.api.async.RedisKeyAsyncCommands
-
Set the expiration for a key as a UNIX timestamp.
- expireat(K, Date) - Method in interface io.lettuce.core.api.reactive.RedisKeyReactiveCommands
-
Set the expiration for a key as a UNIX timestamp.
- expireat(K, long) - Method in interface io.lettuce.core.api.reactive.RedisKeyReactiveCommands
-
Set the expiration for a key as a UNIX timestamp.
- expireat(K, Date) - Method in interface io.lettuce.core.api.sync.RedisKeyCommands
-
Set the expiration for a key as a UNIX timestamp.
- expireat(K, long) - Method in interface io.lettuce.core.api.sync.RedisKeyCommands
-
Set the expiration for a key as a UNIX timestamp.
- expireat(K, Date) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionKeyAsyncCommands
-
Set the expiration for a key as a UNIX timestamp.
- expireat(K, long) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionKeyAsyncCommands
-
Set the expiration for a key as a UNIX timestamp.
- expireat(K, Date) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionKeyCommands
-
Set the expiration for a key as a UNIX timestamp.
- expireat(K, long) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionKeyCommands
-
Set the expiration for a key as a UNIX timestamp.
- exponential() - Static method in class io.lettuce.core.resource.Delay
-
Creates a new ExponentialDelay
with default boundaries and factor (1, 2, 4, 8, 16, 32...).
- exponential(Duration, Duration, int, TimeUnit) - Static method in class io.lettuce.core.resource.Delay
-
Creates a new ExponentialDelay
on with custom boundaries and factor (eg. with upper 9000, lower 0, powerOf 10: 1,
10, 100, 1000, 9000, 9000, 9000, ...).
- exponential(long, long, TimeUnit, int) - Static method in class io.lettuce.core.resource.Delay
-
Creates a new ExponentialDelay
on with custom boundaries and factor (eg. with upper 9000, lower 0, powerOf 10: 1,
10, 100, 1000, 9000, 9000, 9000, ...).
- GenericTypeResolver - Class in io.lettuce.core.dynamic.support
-
Helper class for resolving generic types against type variables.
- GenericTypeResolver() - Constructor for class io.lettuce.core.dynamic.support.GenericTypeResolver
-
- genericWorkerPool - Variable in class io.lettuce.core.AbstractRedisClient
-
- geoadd(K, double, double, V) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- geoadd(K, Object...) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- geoadd(K, double, double, V) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- geoadd(K, Object...) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- geoadd(K, double, double, V) - Method in interface io.lettuce.core.api.async.RedisGeoAsyncCommands
-
Single geo add.
- geoadd(K, Object...) - Method in interface io.lettuce.core.api.async.RedisGeoAsyncCommands
-
Multi geo add.
- geoadd(K, double, double, V) - Method in interface io.lettuce.core.api.reactive.RedisGeoReactiveCommands
-
Single geo add.
- geoadd(K, Object...) - Method in interface io.lettuce.core.api.reactive.RedisGeoReactiveCommands
-
Multi geo add.
- geoadd(K, double, double, V) - Method in interface io.lettuce.core.api.sync.RedisGeoCommands
-
Single geo add.
- geoadd(K, Object...) - Method in interface io.lettuce.core.api.sync.RedisGeoCommands
-
Multi geo add.
- geoadd(K, double, double, V) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionGeoAsyncCommands
-
Single geo add.
- geoadd(K, Object...) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionGeoAsyncCommands
-
Multi geo add.
- geoadd(K, double, double, V) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionGeoCommands
-
Single geo add.
- geoadd(K, Object...) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionGeoCommands
-
Multi geo add.
- GeoArgs - Class in io.lettuce.core
-
- GeoArgs() - Constructor for class io.lettuce.core.GeoArgs
-
- GeoArgs.Builder - Class in io.lettuce.core
-
- GeoArgs.Sort - Enum in io.lettuce.core
-
Sort order.
- GeoArgs.Unit - Enum in io.lettuce.core
-
Supported geo unit.
- GeoCoordinates - Class in io.lettuce.core
-
A tuple consisting of numerical geo data points to describe geo coordinates.
- GeoCoordinates(Number, Number) - Constructor for class io.lettuce.core.GeoCoordinates
-
- GeoCoordinatesListOutput<K,V> - Class in io.lettuce.core.output
-
- GeoCoordinatesListOutput(RedisCodec<K, V>) - Constructor for class io.lettuce.core.output.GeoCoordinatesListOutput
-
- GeoCoordinatesValueListOutput<K,V> - Class in io.lettuce.core.output
-
- GeoCoordinatesValueListOutput(RedisCodec<K, V>) - Constructor for class io.lettuce.core.output.GeoCoordinatesValueListOutput
-
- geodist(K, V, V, GeoArgs.Unit) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- geodist(K, V, V, GeoArgs.Unit) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- geodist(K, V, V, GeoArgs.Unit) - Method in interface io.lettuce.core.api.async.RedisGeoAsyncCommands
-
Retrieve distance between points from
and to
.
- geodist(K, V, V, GeoArgs.Unit) - Method in interface io.lettuce.core.api.reactive.RedisGeoReactiveCommands
-
Retrieve distance between points from
and to
.
- geodist(K, V, V, GeoArgs.Unit) - Method in interface io.lettuce.core.api.sync.RedisGeoCommands
-
Retrieve distance between points from
and to
.
- geodist(K, V, V, GeoArgs.Unit) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionGeoAsyncCommands
-
Retrieve distance between points from
and to
.
- geodist(K, V, V, GeoArgs.Unit) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionGeoCommands
-
Retrieve distance between points from
and to
.
- geohash(K, V...) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- geohash(K, V...) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- geohash(K, V...) - Method in interface io.lettuce.core.api.async.RedisGeoAsyncCommands
-
Retrieve Geohash strings representing the position of one or more elements in a sorted set value representing a geospatial index.
- geohash(K, V...) - Method in interface io.lettuce.core.api.reactive.RedisGeoReactiveCommands
-
Retrieve Geohash strings representing the position of one or more elements in a sorted set value representing a geospatial index.
- geohash(K, V...) - Method in interface io.lettuce.core.api.sync.RedisGeoCommands
-
Retrieve Geohash strings representing the position of one or more elements in a sorted set value representing a geospatial index.
- geohash(K, V...) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionGeoAsyncCommands
-
Retrieve Geohash strings representing the position of one or more elements in a sorted set value representing a geospatial index.
- geohash(K, V...) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionGeoCommands
-
Retrieve Geohash strings representing the position of one or more elements in a sorted set value representing a geospatial index.
- geopos(K, V...) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- geopos(K, V...) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- geopos(K, V...) - Method in interface io.lettuce.core.api.async.RedisGeoAsyncCommands
-
Get geo coordinates for the members
.
- geopos(K, V...) - Method in interface io.lettuce.core.api.reactive.RedisGeoReactiveCommands
-
Get geo coordinates for the members
.
- geopos(K, V...) - Method in interface io.lettuce.core.api.sync.RedisGeoCommands
-
Get geo coordinates for the members
.
- geopos(K, V...) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionGeoAsyncCommands
-
Get geo coordinates for the members
.
- geopos(K, V...) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionGeoCommands
-
Get geo coordinates for the members
.
- georadius(K, double, double, double, GeoArgs.Unit) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- georadius(K, double, double, double, GeoArgs.Unit, GeoArgs) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- georadius(K, double, double, double, GeoArgs.Unit, GeoRadiusStoreArgs<K>) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- georadius(K, double, double, double, GeoArgs.Unit) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- georadius(K, double, double, double, GeoArgs.Unit, GeoArgs) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- georadius(K, double, double, double, GeoArgs.Unit, GeoRadiusStoreArgs<K>) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- georadius(K, double, double, double, GeoArgs.Unit) - Method in interface io.lettuce.core.api.async.RedisGeoAsyncCommands
-
Retrieve members selected by distance with the center of longitude
and latitude
.
- georadius(K, double, double, double, GeoArgs.Unit, GeoArgs) - Method in interface io.lettuce.core.api.async.RedisGeoAsyncCommands
-
Retrieve members selected by distance with the center of longitude
and latitude
.
- georadius(K, double, double, double, GeoArgs.Unit, GeoRadiusStoreArgs<K>) - Method in interface io.lettuce.core.api.async.RedisGeoAsyncCommands
-
- georadius(K, double, double, double, GeoArgs.Unit) - Method in interface io.lettuce.core.api.reactive.RedisGeoReactiveCommands
-
Retrieve members selected by distance with the center of longitude
and latitude
.
- georadius(K, double, double, double, GeoArgs.Unit, GeoArgs) - Method in interface io.lettuce.core.api.reactive.RedisGeoReactiveCommands
-
Retrieve members selected by distance with the center of longitude
and latitude
.
- georadius(K, double, double, double, GeoArgs.Unit, GeoRadiusStoreArgs<K>) - Method in interface io.lettuce.core.api.reactive.RedisGeoReactiveCommands
-
- georadius(K, double, double, double, GeoArgs.Unit) - Method in interface io.lettuce.core.api.sync.RedisGeoCommands
-
Retrieve members selected by distance with the center of longitude
and latitude
.
- georadius(K, double, double, double, GeoArgs.Unit, GeoArgs) - Method in interface io.lettuce.core.api.sync.RedisGeoCommands
-
Retrieve members selected by distance with the center of longitude
and latitude
.
- georadius(K, double, double, double, GeoArgs.Unit, GeoRadiusStoreArgs<K>) - Method in interface io.lettuce.core.api.sync.RedisGeoCommands
-
- georadius(K, double, double, double, GeoArgs.Unit) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionGeoAsyncCommands
-
Retrieve members selected by distance with the center of longitude
and latitude
.
- georadius(K, double, double, double, GeoArgs.Unit, GeoArgs) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionGeoAsyncCommands
-
Retrieve members selected by distance with the center of longitude
and latitude
.
- georadius(K, double, double, double, GeoArgs.Unit, GeoRadiusStoreArgs<K>) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionGeoAsyncCommands
-
- georadius(K, double, double, double, GeoArgs.Unit) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionGeoCommands
-
Retrieve members selected by distance with the center of longitude
and latitude
.
- georadius(K, double, double, double, GeoArgs.Unit, GeoArgs) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionGeoCommands
-
Retrieve members selected by distance with the center of longitude
and latitude
.
- georadius(K, double, double, double, GeoArgs.Unit, GeoRadiusStoreArgs<K>) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionGeoCommands
-
- georadius(K, double, double, double, GeoArgs.Unit) - Method in class io.lettuce.core.cluster.RedisAdvancedClusterAsyncCommandsImpl
-
- georadius(K, double, double, double, GeoArgs.Unit, GeoArgs) - Method in class io.lettuce.core.cluster.RedisAdvancedClusterAsyncCommandsImpl
-
- georadius(K, double, double, double, GeoArgs.Unit) - Method in class io.lettuce.core.cluster.RedisAdvancedClusterReactiveCommandsImpl
-
- georadius(K, double, double, double, GeoArgs.Unit, GeoArgs) - Method in class io.lettuce.core.cluster.RedisAdvancedClusterReactiveCommandsImpl
-
- georadius(K, double, double, double, GeoArgs.Unit) - Method in class io.lettuce.core.cluster.RedisClusterPubSubAsyncCommandsImpl
-
- georadius(K, double, double, double, GeoArgs.Unit, GeoArgs) - Method in class io.lettuce.core.cluster.RedisClusterPubSubAsyncCommandsImpl
-
- georadius(K, double, double, double, GeoArgs.Unit) - Method in class io.lettuce.core.cluster.RedisClusterPubSubReactiveCommandsImpl
-
- georadius(K, double, double, double, GeoArgs.Unit, GeoArgs) - Method in class io.lettuce.core.cluster.RedisClusterPubSubReactiveCommandsImpl
-
- georadius_ro(K, double, double, double, GeoArgs.Unit) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- georadius_ro(K, double, double, double, GeoArgs.Unit, GeoArgs) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- georadius_ro(K, double, double, double, GeoArgs.Unit) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- georadius_ro(K, double, double, double, GeoArgs.Unit, GeoArgs) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- georadiusbymember(K, V, double, GeoArgs.Unit) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- georadiusbymember(K, V, double, GeoArgs.Unit, GeoArgs) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- georadiusbymember(K, V, double, GeoArgs.Unit, GeoRadiusStoreArgs<K>) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- georadiusbymember(K, V, double, GeoArgs.Unit) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- georadiusbymember(K, V, double, GeoArgs.Unit, GeoArgs) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- georadiusbymember(K, V, double, GeoArgs.Unit, GeoRadiusStoreArgs<K>) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- georadiusbymember(K, V, double, GeoArgs.Unit) - Method in interface io.lettuce.core.api.async.RedisGeoAsyncCommands
-
Retrieve members selected by distance with the center of member
.
- georadiusbymember(K, V, double, GeoArgs.Unit, GeoArgs) - Method in interface io.lettuce.core.api.async.RedisGeoAsyncCommands
-
Retrieve members selected by distance with the center of member
.
- georadiusbymember(K, V, double, GeoArgs.Unit, GeoRadiusStoreArgs<K>) - Method in interface io.lettuce.core.api.async.RedisGeoAsyncCommands
-
- georadiusbymember(K, V, double, GeoArgs.Unit) - Method in interface io.lettuce.core.api.reactive.RedisGeoReactiveCommands
-
Retrieve members selected by distance with the center of member
.
- georadiusbymember(K, V, double, GeoArgs.Unit, GeoArgs) - Method in interface io.lettuce.core.api.reactive.RedisGeoReactiveCommands
-
Retrieve members selected by distance with the center of member
.
- georadiusbymember(K, V, double, GeoArgs.Unit, GeoRadiusStoreArgs<K>) - Method in interface io.lettuce.core.api.reactive.RedisGeoReactiveCommands
-
- georadiusbymember(K, V, double, GeoArgs.Unit) - Method in interface io.lettuce.core.api.sync.RedisGeoCommands
-
Retrieve members selected by distance with the center of member
.
- georadiusbymember(K, V, double, GeoArgs.Unit, GeoArgs) - Method in interface io.lettuce.core.api.sync.RedisGeoCommands
-
Retrieve members selected by distance with the center of member
.
- georadiusbymember(K, V, double, GeoArgs.Unit, GeoRadiusStoreArgs<K>) - Method in interface io.lettuce.core.api.sync.RedisGeoCommands
-
- georadiusbymember(K, V, double, GeoArgs.Unit) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionGeoAsyncCommands
-
Retrieve members selected by distance with the center of member
.
- georadiusbymember(K, V, double, GeoArgs.Unit, GeoArgs) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionGeoAsyncCommands
-
Retrieve members selected by distance with the center of member
.
- georadiusbymember(K, V, double, GeoArgs.Unit, GeoRadiusStoreArgs<K>) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionGeoAsyncCommands
-
- georadiusbymember(K, V, double, GeoArgs.Unit) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionGeoCommands
-
Retrieve members selected by distance with the center of member
.
- georadiusbymember(K, V, double, GeoArgs.Unit, GeoArgs) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionGeoCommands
-
Retrieve members selected by distance with the center of member
.
- georadiusbymember(K, V, double, GeoArgs.Unit, GeoRadiusStoreArgs<K>) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionGeoCommands
-
- georadiusbymember(K, V, double, GeoArgs.Unit) - Method in class io.lettuce.core.cluster.RedisAdvancedClusterAsyncCommandsImpl
-
- georadiusbymember(K, V, double, GeoArgs.Unit, GeoArgs) - Method in class io.lettuce.core.cluster.RedisAdvancedClusterAsyncCommandsImpl
-
- georadiusbymember(K, V, double, GeoArgs.Unit) - Method in class io.lettuce.core.cluster.RedisAdvancedClusterReactiveCommandsImpl
-
- georadiusbymember(K, V, double, GeoArgs.Unit, GeoArgs) - Method in class io.lettuce.core.cluster.RedisAdvancedClusterReactiveCommandsImpl
-
- georadiusbymember(K, V, double, GeoArgs.Unit) - Method in class io.lettuce.core.cluster.RedisClusterPubSubAsyncCommandsImpl
-
- georadiusbymember(K, V, double, GeoArgs.Unit, GeoArgs) - Method in class io.lettuce.core.cluster.RedisClusterPubSubAsyncCommandsImpl
-
- georadiusbymember(K, V, double, GeoArgs.Unit) - Method in class io.lettuce.core.cluster.RedisClusterPubSubReactiveCommandsImpl
-
- georadiusbymember(K, V, double, GeoArgs.Unit, GeoArgs) - Method in class io.lettuce.core.cluster.RedisClusterPubSubReactiveCommandsImpl
-
- georadiusbymember_ro(K, V, double, GeoArgs.Unit) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- georadiusbymember_ro(K, V, double, GeoArgs.Unit, GeoArgs) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- georadiusbymember_ro(K, V, double, GeoArgs.Unit) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- georadiusbymember_ro(K, V, double, GeoArgs.Unit, GeoArgs) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- GeoRadiusStoreArgs<K> - Class in io.lettuce.core
-
Argument list builder for the Redis
GEORADIUS command to store
GEORADIUS results or GEORADIUS distances in a sorted set.
- GeoRadiusStoreArgs() - Constructor for class io.lettuce.core.GeoRadiusStoreArgs
-
- GeoRadiusStoreArgs.Builder - Class in io.lettuce.core
-
- GeoWithin<V> - Class in io.lettuce.core
-
Geo element within a certain radius.
- GeoWithin(V, Double, Long, GeoCoordinates) - Constructor for class io.lettuce.core.GeoWithin
-
- GeoWithinListOutput<K,V> - Class in io.lettuce.core.output
-
A list output that creates a list with either double/long or
GeoCoordinates
's.
- GeoWithinListOutput(RedisCodec<K, V>, boolean, boolean, boolean) - Constructor for class io.lettuce.core.output.GeoWithinListOutput
-
- get(K) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- get(K) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- get(K) - Method in interface io.lettuce.core.api.async.RedisStringAsyncCommands
-
Get the value of a key.
- get(K) - Method in interface io.lettuce.core.api.reactive.RedisStringReactiveCommands
-
Get the value of a key.
- get(K) - Method in interface io.lettuce.core.api.sync.RedisStringCommands
-
Get the value of a key.
- get(BitFieldArgs.BitFieldType, int) - Static method in class io.lettuce.core.BitFieldArgs.Builder
-
Create a new GET
subcommand.
- get(BitFieldArgs.BitFieldType, BitFieldArgs.Offset) - Static method in class io.lettuce.core.BitFieldArgs.Builder
-
Create a new GET
subcommand.
- get() - Method in class io.lettuce.core.BitFieldArgs
-
Adds a new GET
subcommand using offset 0
and the field type of the previous command.
- get(BitFieldArgs.BitFieldType) - Method in class io.lettuce.core.BitFieldArgs
-
Adds a new GET
subcommand using offset 0
.
- get(BitFieldArgs.BitFieldType, int) - Method in class io.lettuce.core.BitFieldArgs
-
Adds a new GET
subcommand.
- get(BitFieldArgs.BitFieldType, BitFieldArgs.Offset) - Method in class io.lettuce.core.BitFieldArgs
-
Adds a new GET
subcommand.
- get(int) - Method in class io.lettuce.core.BitFieldArgs
-
Adds a new GET
subcommand using the field type of the previous command.
- get(RedisClusterNode) - Method in interface io.lettuce.core.cluster.api.async.AsyncExecutions
-
- get(K) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionStringAsyncCommands
-
Get the value of a key.
- get(RedisClusterNode) - Method in interface io.lettuce.core.cluster.api.sync.Executions
-
- get(K) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionStringCommands
-
Get the value of a key.
- get(CipherCodec.KeyDescriptor) - Method in interface io.lettuce.core.codec.CipherCodec.CipherSupplier
-
- get() - Method in interface io.lettuce.core.ConnectionFuture
-
Waits if necessary for the computation to complete, and then retrieves its result.
- get() - Method in class io.lettuce.core.event.DefaultEventBus
-
- get() - Method in interface io.lettuce.core.event.EventBus
-
Subscribe to the event bus and
Event
s.
- get(Method) - Method in class io.lettuce.core.internal.AbstractInvocationHandler.MethodTranslator
-
- get() - Method in class io.lettuce.core.output.CommandOutput
-
Get the command output.
- get() - Method in class io.lettuce.core.output.MultiOutput
-
- get() - Method in class io.lettuce.core.protocol.Command
-
- get(String) - Static method in class io.lettuce.core.SortArgs.Builder
-
- get(String) - Method in class io.lettuce.core.SortArgs
-
Retrieve external keys during sort.
- get() - Method in interface io.lettuce.core.SslOptions.Resource
-
- get(int) - Method in interface io.lettuce.core.TransactionResult
-
- getActualReturnType() - Method in interface io.lettuce.core.dynamic.CommandMethod
-
- getActualReturnType() - Method in class io.lettuce.core.dynamic.DeclaredCommandMethod
-
- getActualType() - Method in interface io.lettuce.core.dynamic.support.TypeInformation
-
- getAdaptiveRefreshTimeout() - Method in class io.lettuce.core.cluster.ClusterTopologyRefreshOptions
-
Timeout between adaptive cluster topology updates.
- getAdaptiveRefreshTriggers() - Method in class io.lettuce.core.cluster.ClusterTopologyRefreshOptions
-
- getAliases() - Method in class io.lettuce.core.cluster.models.partitions.RedisClusterNode
-
- getAnnotatedElement() - Method in class io.lettuce.core.dynamic.support.MethodParameter
-
Returns the wrapped annotated element.
- getAnnotation(Class<A>) - Method in interface io.lettuce.core.dynamic.CommandMethod
-
Lookup a method annotation.
- getAnnotation(Class<A>) - Method in class io.lettuce.core.dynamic.DeclaredCommandMethod
-
Lookup a method annotation.
- getAnnotations() - Method in class io.lettuce.core.dynamic.parameter.Parameter
-
Return all parameter annotations.
- getArgs() - Method in class io.lettuce.core.protocol.AsyncCommand
-
- getArgs() - Method in class io.lettuce.core.protocol.Command
-
- getArgs() - Method in class io.lettuce.core.protocol.CommandWrapper
-
- getArgs() - Method in interface io.lettuce.core.protocol.RedisCommand
-
- getArguments() - Method in interface io.lettuce.core.dynamic.intercept.MethodInvocation
-
- getArity() - Method in class io.lettuce.core.models.command.CommandDetail
-
- getAttempt() - Method in class io.lettuce.core.ConnectionEvents.Reconnect
-
- getAttempt() - Method in class io.lettuce.core.event.connection.ReconnectFailedEvent
-
Returns the reconnect attempt counter for the connection.
- getBindableParameter(int) - Method in class io.lettuce.core.dynamic.parameter.Parameters
-
Get the bindable parameter according it's logical position in the command.
- getBindableParameters() - Method in class io.lettuce.core.dynamic.parameter.Parameters
-
Returns
Parameter
instances with effectively all special parameters removed.
- getBindableValue(int) - Method in interface io.lettuce.core.dynamic.parameter.MethodParametersAccessor
-
Returns the bindable value with the given index.
- getbit(K, long) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- getbit(K, long) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- getbit(K, long) - Method in interface io.lettuce.core.api.async.RedisStringAsyncCommands
-
Returns the bit value at offset in the string value stored at key.
- getbit(K, long) - Method in interface io.lettuce.core.api.reactive.RedisStringReactiveCommands
-
Returns the bit value at offset in the string value stored at key.
- getbit(K, long) - Method in interface io.lettuce.core.api.sync.RedisStringCommands
-
Returns the bit value at offset in the string value stored at key.
- getbit(K, long) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionStringAsyncCommands
-
Returns the bit value at offset in the string value stored at key.
- getbit(K, long) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionStringCommands
-
Returns the bit value at offset in the string value stored at key.
- getBits() - Method in class io.lettuce.core.BitFieldArgs.BitFieldType
-
- getBody() - Method in class io.lettuce.core.StreamMessage
-
- getBufferUsageRatio() - Method in class io.lettuce.core.ClientOptions
-
- getBytes() - Method in enum io.lettuce.core.BitFieldArgs.OverflowType
-
- getBytes() - Method in enum io.lettuce.core.protocol.CommandKeyword
-
- getBytes() - Method in enum io.lettuce.core.protocol.CommandType
-
- getBytes() - Method in interface io.lettuce.core.protocol.ProtocolKeyword
-
- getBytes() - Method in enum io.lettuce.core.UnblockType
-
- getCause() - Method in class io.lettuce.core.event.connection.ReconnectFailedEvent
-
Returns the
Throwable
that describes the reconnect cause.
- getChannel() - Method in class io.lettuce.core.pubsub.api.reactive.ChannelMessage
-
- getChannel() - Method in class io.lettuce.core.pubsub.api.reactive.PatternMessage
-
- getChannelCount() - Method in class io.lettuce.core.AbstractRedisClient
-
- getChannels() - Method in class io.lettuce.core.pubsub.PubSubEndpoint
-
- getChannelWriter() - Method in interface io.lettuce.core.cluster.api.StatefulRedisClusterConnection
-
- getChannelWriter() - Method in class io.lettuce.core.RedisChannelHandler
-
- getCipherSuites() - Method in class io.lettuce.core.SslOptions
-
- getClientName() - Method in class io.lettuce.core.RedisURI
-
Returns the client name.
- getClientResources() - Method in class io.lettuce.core.protocol.CommandExpiryWriter
-
- getClientResources() - Method in class io.lettuce.core.protocol.DefaultEndpoint
-
- getClientResources() - Method in interface io.lettuce.core.RedisChannelWriter
-
- getClientResources() - Method in class io.lettuce.core.support.LettuceFactoryBeanSupport
-
- getCommand() - Method in class io.lettuce.core.ConnectionEvents.PingBeforeActivate
-
- getCommandBatchingIndex() - Method in class io.lettuce.core.dynamic.parameter.ExecutionSpecificParameters
-
- getCommandMethod() - Method in exception io.lettuce.core.dynamic.CommandCreationException
-
- getCommandOutput(RedisCommand<?, ?, ?>) - Method in class io.lettuce.core.protocol.CommandHandler
-
- getCommandOutput(RedisCommand<?, ?, ?>) - Method in class io.lettuce.core.pubsub.PubSubCommandHandler
-
- getCommandOutputClass() - Method in class io.lettuce.core.dynamic.output.OutputType
-
- getCommands(Class<T>) - Method in class io.lettuce.core.dynamic.RedisCommandFactory
-
Returns a Redis Commands interface instance for the given interface.
- getCommandType() - Method in class io.lettuce.core.dynamic.segment.CommandSegments
-
- getCompletion() - Method in class io.lettuce.core.metrics.CommandMetrics
-
- getComponentType() - Method in class io.lettuce.core.dynamic.support.ResolvableType
-
Return the ResolvableType representing the component type of the array or
ResolvableType.NONE
if this type does not represent
an array.
- getComponentType() - Method in interface io.lettuce.core.dynamic.support.TypeInformation
-
Returns the component type for
Collection
s or the key type for
Map
s.
- getComputationThreadPoolSize() - Method in class io.lettuce.core.support.ClientResourcesFactoryBean
-
- getConfigEpoch() - Method in class io.lettuce.core.cluster.models.partitions.RedisClusterNode
-
- getConnection() - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- getConnection(ConnectionFuture<T>) - Method in class io.lettuce.core.AbstractRedisClient
-
- getConnection(CompletableFuture<T>) - Method in class io.lettuce.core.AbstractRedisClient
-
- getConnection() - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- getConnection(String) - Method in interface io.lettuce.core.cluster.api.async.RedisAdvancedClusterAsyncCommands
-
Retrieve a connection to the specified cluster node using the nodeId.
- getConnection(String, int) - Method in interface io.lettuce.core.cluster.api.async.RedisAdvancedClusterAsyncCommands
-
Retrieve a connection to the specified cluster node using host and port.
- getConnection(String) - Method in interface io.lettuce.core.cluster.api.reactive.RedisAdvancedClusterReactiveCommands
-
Retrieve a connection to the specified cluster node using the nodeId.
- getConnection(String, int) - Method in interface io.lettuce.core.cluster.api.reactive.RedisAdvancedClusterReactiveCommands
-
Retrieve a connection to the specified cluster node using host and port.
- getConnection(String) - Method in interface io.lettuce.core.cluster.api.StatefulRedisClusterConnection
-
Retrieve a connection to the specified cluster node using the nodeId.
- getConnection(String, int) - Method in interface io.lettuce.core.cluster.api.StatefulRedisClusterConnection
-
Retrieve a connection to the specified cluster node using host and port.
- getConnection(String) - Method in interface io.lettuce.core.cluster.api.sync.RedisAdvancedClusterCommands
-
Retrieve a connection to the specified cluster node using the nodeId.
- getConnection(String, int) - Method in interface io.lettuce.core.cluster.api.sync.RedisAdvancedClusterCommands
-
Retrieve a connection to the specified cluster node using host and port.
- getConnection(String) - Method in interface io.lettuce.core.cluster.pubsub.StatefulRedisClusterPubSubConnection
-
Retrieve a connection to the specified cluster node using the nodeId.
- getConnection(String, int) - Method in interface io.lettuce.core.cluster.pubsub.StatefulRedisClusterPubSubConnection
-
Retrieve a connection to the specified cluster node using host and port.
- getConnection(String) - Method in class io.lettuce.core.cluster.RedisAdvancedClusterAsyncCommandsImpl
-
- getConnection(String, int) - Method in class io.lettuce.core.cluster.RedisAdvancedClusterAsyncCommandsImpl
-
- getConnection(String) - Method in class io.lettuce.core.cluster.RedisAdvancedClusterReactiveCommandsImpl
-
- getConnection(String, int) - Method in class io.lettuce.core.cluster.RedisAdvancedClusterReactiveCommandsImpl
-
- getConnection(String) - Method in class io.lettuce.core.cluster.StatefulRedisClusterConnectionImpl
-
- getConnection(String, int) - Method in class io.lettuce.core.cluster.StatefulRedisClusterConnectionImpl
-
- getConnection(K) - Method in class io.lettuce.core.internal.AsyncConnectionProvider
-
Request a connection for the given the connection
key
and return a
CompletionStage
that is notified about
the connection outcome.
- getConnection(MasterSlaveConnectionProvider.Intent) - Method in class io.lettuce.core.masterslave.MasterSlaveConnectionProvider
-
Deprecated.
- getConnection(RedisNodeDescription) - Method in class io.lettuce.core.masterslave.MasterSlaveConnectionProvider
-
Deprecated.
- getConnectionAsync(String) - Method in interface io.lettuce.core.cluster.api.StatefulRedisClusterConnection
-
Retrieve asynchronously a connection to the specified cluster node using the nodeId.
- getConnectionAsync(String, int) - Method in interface io.lettuce.core.cluster.api.StatefulRedisClusterConnection
-
Retrieve asynchronously a connection to the specified cluster node using host and port.
- getConnectionAsync(String) - Method in interface io.lettuce.core.cluster.pubsub.StatefulRedisClusterPubSubConnection
-
Retrieve asynchronously a connection to the specified cluster node using the nodeId.
- getConnectionAsync(String, int) - Method in interface io.lettuce.core.cluster.pubsub.StatefulRedisClusterPubSubConnection
-
Retrieve a connection to the specified cluster node using host and port.
- getConnectionAsync(String) - Method in class io.lettuce.core.cluster.StatefulRedisClusterConnectionImpl
-
- getConnectionAsync(String, int) - Method in class io.lettuce.core.cluster.StatefulRedisClusterConnectionImpl
-
- getConnectionAsync(MasterSlaveConnectionProvider.Intent) - Method in class io.lettuce.core.masterslave.MasterSlaveConnectionProvider
-
Deprecated.
- getConnectionCount() - Method in class io.lettuce.core.internal.AsyncConnectionProvider
-
- getConnectionCount() - Method in class io.lettuce.core.masterslave.MasterSlaveConnectionProvider
-
Deprecated.
- getConnectTimeout() - Method in class io.lettuce.core.SocketOptions
-
Returns the connection timeout.
- getConstructor() - Method in class io.lettuce.core.dynamic.support.MethodParameter
-
Return the wrapped Constructor, if any.
- getConsumer() - Method in class io.lettuce.core.models.stream.PendingEntry
-
- getConsumer() - Method in class io.lettuce.core.models.stream.PendingMessage
-
- getConsumerMessageCount() - Method in class io.lettuce.core.models.stream.PendingMessages
-
- getContainingClass() - Method in class io.lettuce.core.dynamic.support.MethodParameter
-
- getContext() - Static method in interface io.lettuce.core.tracing.Tracing
-
- getCoordinates() - Method in class io.lettuce.core.GeoWithin
-
- getCount() - Method in class io.lettuce.core.Limit
-
- getCount() - Method in class io.lettuce.core.metrics.CommandMetrics
-
- getCount() - Method in class io.lettuce.core.models.stream.PendingMessages
-
- getCount() - Method in class io.lettuce.core.StreamScanCursor
-
- getCreationInProgress() - Method in class io.lettuce.core.support.BoundedAsyncPool
-
- getCursor() - Method in class io.lettuce.core.ScanCursor
-
- getDatabase() - Method in class io.lettuce.core.RedisURI
-
Returns the Redis database number.
- getDeclaringClass() - Method in class io.lettuce.core.dynamic.support.MethodParameter
-
Return the class that declares the underlying Method or Constructor.
- getDelegate() - Method in class io.lettuce.core.protocol.AsyncCommand
-
- getDelegate() - Method in class io.lettuce.core.protocol.CommandWrapper
-
- getDelegate() - Method in interface io.lettuce.core.protocol.DecoratedCommand
-
The underlying command.
- getDeliveryCount() - Method in class io.lettuce.core.models.stream.PendingEntry
-
- getDisconnectedBehavior() - Method in class io.lettuce.core.ClientOptions
-
Behavior for command invocation when connections are in a disconnected state.
- getDistance() - Method in class io.lettuce.core.GeoWithin
-
- getError() - Method in class io.lettuce.core.output.CommandOutput
-
Get the error that occurred.
- getError() - Method in class io.lettuce.core.protocol.AsyncCommand
-
- getError() - Method in class io.lettuce.core.protocol.Command
-
- getError() - Method in interface io.lettuce.core.RedisFuture
-
- getFailedCommands() - Method in exception io.lettuce.core.dynamic.batch.BatchException
-
- getField(Field, Object) - Static method in class io.lettuce.core.dynamic.support.ReflectionUtils
-
- getFirstCharArray(CommandArgs<K, V>) - Static method in class io.lettuce.core.protocol.CommandArgsAccessor
-
Get the first char
-array argument.
- getFirstEncodedKey() - Method in class io.lettuce.core.protocol.CommandArgs
-
Returns the first key argument in its byte-encoded representation.
- getFirstInteger() - Method in class io.lettuce.core.protocol.CommandArgs
-
Deprecated.
- getFirstInteger(CommandArgs<K, V>) - Static method in class io.lettuce.core.protocol.CommandArgsAccessor
-
- getFirstKeyPosition() - Method in class io.lettuce.core.models.command.CommandDetail
-
- getFirstResponse() - Method in class io.lettuce.core.metrics.CommandMetrics
-
- getFirstString() - Method in class io.lettuce.core.protocol.CommandArgs
-
Deprecated.
- getFirstString(CommandArgs<K, V>) - Static method in class io.lettuce.core.protocol.CommandArgsAccessor
-
Get the first
String
argument.
- getFirstUri() - Method in class io.lettuce.core.cluster.RedisClusterClient
-
- getFlags() - Method in class io.lettuce.core.cluster.models.partitions.RedisClusterNode
-
- getFlags() - Method in class io.lettuce.core.models.command.CommandDetail
-
- getFrom() - Method in class io.lettuce.core.cluster.models.slots.ClusterSlotRange
-
- getGeneric(int...) - Method in class io.lettuce.core.dynamic.support.ResolvableType
-
Return a
ResolvableType
representing the generic parameter for the given indexes.
- getGenericParameterType() - Method in class io.lettuce.core.dynamic.support.MethodParameter
-
Return the generic type of the method/constructor parameter.
- getGenerics() - Method in class io.lettuce.core.dynamic.support.ResolvableType
-
Return an array of
ResolvableType
s representing the generic parameters of this type.
- getGenericType() - Method in interface io.lettuce.core.dynamic.support.TypeInformation
-
- getGeohash() - Method in class io.lettuce.core.GeoWithin
-
- getGroup() - Method in class io.lettuce.core.Consumer
-
- getHost() - Method in interface io.lettuce.core.ConnectionPoint
-
Returns the host that should represent the hostname or IPv4/IPv6 literal.
- getHost() - Method in class io.lettuce.core.models.role.ReplicationPartner
-
- getHost() - Method in class io.lettuce.core.RedisURI
-
Returns the host.
- getHostText() - Method in class io.lettuce.core.internal.HostAndPort
-
- getId() - Method in class io.lettuce.core.models.stream.PendingMessage
-
- getId() - Method in class io.lettuce.core.StreamMessage
-
- getIdle() - Method in class io.lettuce.core.support.BoundedAsyncPool
-
- getInitialUris() - Method in class io.lettuce.core.cluster.RedisClusterClient
-
- getInterfaces() - Method in class io.lettuce.core.dynamic.support.ResolvableType
-
Return a
ResolvableType
array representing the direct interfaces implemented by this type.
- getInvocationTarget() - Method in interface io.lettuce.core.dynamic.intercept.InvocationTargetProvider
-
- getIoThreadPoolSize() - Method in class io.lettuce.core.support.ClientResourcesFactoryBean
-
- getKey() - Method in class io.lettuce.core.KeyValue
-
- getKeys() - Method in class io.lettuce.core.KeyScanCursor
-
- getKeyStepCount() - Method in class io.lettuce.core.models.command.CommandDetail
-
- getKeystore() - Method in class io.lettuce.core.SslOptions
-
- getKeystorePassword() - Method in class io.lettuce.core.SslOptions
-
- getKeyType(TypeInformation<?>) - Static method in class io.lettuce.core.dynamic.codec.AnnotationRedisCodecResolver.ParameterWrappers
-
- getLastKeyPosition() - Method in class io.lettuce.core.models.command.CommandDetail
-
- getLatencies() - Method in class io.lettuce.core.event.metrics.CommandLatencyEvent
-
- getListeners() - Method in class io.lettuce.core.pubsub.PubSubEndpoint
-
- getLower() - Method in class io.lettuce.core.Range
-
- getMap() - Method in class io.lettuce.core.MapScanCursor
-
- getMapValueType() - Method in interface io.lettuce.core.dynamic.support.TypeInformation
-
Will return the type of the value in case the underlying type is a
Map
.
- getMaster() - Method in class io.lettuce.core.masterslave.MasterSlaveConnectionProvider
-
Deprecated.
- getMaster() - Method in class io.lettuce.core.models.role.RedisSlaveInstance
-
- getMasterAddrByName(K) - Method in interface io.lettuce.core.sentinel.api.async.RedisSentinelAsyncCommands
-
Return the ip and port number of the master with that name.
- getMasterAddrByName(K) - Method in interface io.lettuce.core.sentinel.api.reactive.RedisSentinelReactiveCommands
-
Return the ip and port number of the master with that name.
- getMasterAddrByName(K) - Method in interface io.lettuce.core.sentinel.api.sync.RedisSentinelCommands
-
Return the ip and port number of the master with that name.
- getMasterAddrByName(K) - Method in class io.lettuce.core.sentinel.RedisSentinelAsyncCommandsImpl
-
- getMasterAddrByName(K) - Method in class io.lettuce.core.sentinel.RedisSentinelReactiveCommandsImpl
-
- getMasterNode() - Method in class io.lettuce.core.cluster.models.slots.ClusterSlotRange
-
- getMax() - Method in class io.lettuce.core.metrics.CommandMetrics.CommandLatency
-
- getMaxIdle() - Method in class io.lettuce.core.support.BoundedAsyncPool
-
Returns the cap on the number of "idle" instances in the pool.
- getMaxIdle() - Method in class io.lettuce.core.support.BoundedPoolConfig
-
Get the value for the maxIdle
configuration attribute for pools created with this configuration instance.
- getMaxRedirects() - Method in class io.lettuce.core.cluster.ClusterClientOptions
-
Number of maximal of cluster redirects (-MOVED and -ASK) to follow in case a key was moved from one
node to another node.
- getMaxTotal() - Method in class io.lettuce.core.support.BoundedAsyncPool
-
Returns the maximum number of objects that can be allocated by the pool (checked out to clients, or idle awaiting
checkout) at a given time.
- getMaxTotal() - Method in class io.lettuce.core.support.BoundedPoolConfig
-
Get the value for the maxTotal
configuration attribute for pools created with this configuration instance.
- getMember() - Method in class io.lettuce.core.dynamic.support.MethodParameter
-
Returns the wrapped member.
- getMember() - Method in class io.lettuce.core.GeoWithin
-
- getMessage() - Method in class io.lettuce.core.pubsub.api.reactive.ChannelMessage
-
- getMessage() - Method in class io.lettuce.core.pubsub.api.reactive.PatternMessage
-
- getMessageId() - Method in class io.lettuce.core.models.stream.PendingEntry
-
- getMessageIds() - Method in class io.lettuce.core.models.stream.PendingMessages
-
- getMethod() - Method in interface io.lettuce.core.dynamic.CommandMethod
-
- getMethod() - Method in class io.lettuce.core.dynamic.DeclaredCommandMethod
-
- getMethod() - Method in interface io.lettuce.core.dynamic.intercept.MethodInvocation
-
- getMethod() - Method in class io.lettuce.core.dynamic.support.MethodParameter
-
Return the wrapped Method, if any.
- getMethodAnnotation(Class<A>) - Method in class io.lettuce.core.dynamic.support.MethodParameter
-
Return the method/constructor annotation of the given type, if available.
- getMethodAnnotations() - Method in class io.lettuce.core.dynamic.support.MethodParameter
-
Return the annotations associated with the target method/constructor itself.
- getMillisSinceDelivery() - Method in class io.lettuce.core.models.stream.PendingEntry
-
- getMin() - Method in class io.lettuce.core.metrics.CommandMetrics.CommandLatency
-
- getMinIdle() - Method in class io.lettuce.core.support.BoundedAsyncPool
-
Returns the target for the minimum number of idle objects to maintain in the pool.
- getMinIdle() - Method in class io.lettuce.core.support.BoundedPoolConfig
-
Get the value for the minIdle
configuration attribute for pools created with this configuration instance.
- getMonitoredMasters() - Method in class io.lettuce.core.models.role.RedisSentinelInstance
-
- getMsSinceLastDelivery() - Method in class io.lettuce.core.models.stream.PendingMessage
-
- getName() - Method in class io.lettuce.core.codec.CipherCodec.KeyDescriptor
-
- getName(Charset) - Method in class io.lettuce.core.codec.CipherCodec.KeyDescriptor
-
Returns the key
name
by decoding name bytes using the given
Charset
.
- getName() - Method in class io.lettuce.core.Consumer
-
- getName() - Method in interface io.lettuce.core.dynamic.CommandMethod
-
- getName() - Method in class io.lettuce.core.dynamic.DeclaredCommandMethod
-
- getName() - Method in class io.lettuce.core.dynamic.parameter.Parameter
-
- getName() - Method in class io.lettuce.core.models.command.CommandDetail
-
- getName() - Method in class io.lettuce.core.XReadArgs.StreamOffset
-
- getNested(int) - Method in class io.lettuce.core.dynamic.support.ResolvableType
-
- getNested(int, Map<Integer, Integer>) - Method in class io.lettuce.core.dynamic.support.ResolvableType
-
- getNestedGenericParameterType() - Method in class io.lettuce.core.dynamic.support.MethodParameter
-
Return the nested generic type of the method/constructor parameter.
- getNestedParameterType() - Method in class io.lettuce.core.dynamic.support.MethodParameter
-
Return the nested type of the method/constructor parameter.
- getNestingLevel() - Method in class io.lettuce.core.dynamic.support.MethodParameter
-
Return the nesting level of the target type (typically 1; e.g. in case of a List of Lists, 1 would indicate the nested
List, whereas 2 would indicate the element of the nested List).
- getNodeId() - Method in class io.lettuce.core.cluster.models.partitions.RedisClusterNode
-
- getNodes() - Method in class io.lettuce.core.masterslave.MasterSlaveTopologyProvider
-
Deprecated.
- getNodes() - Method in class io.lettuce.core.masterslave.SentinelTopologyProvider
-
Deprecated.
- getNodes(StatefulRedisSentinelConnection<String, String>) - Method in class io.lettuce.core.masterslave.SentinelTopologyProvider
-
Deprecated.
- getNodes() - Method in class io.lettuce.core.masterslave.StaticMasterSlaveTopologyProvider
-
Deprecated.
- getNodes() - Method in interface io.lettuce.core.masterslave.TopologyProvider
-
Deprecated.
Lookup nodes within the topology.
- getNodes() - Method in interface io.lettuce.core.ReadFrom.Nodes
-
Returns the list of nodes that are applicable for the read operation.
- getNodesAsync() - Method in class io.lettuce.core.masterslave.MasterSlaveTopologyProvider
-
Deprecated.
- getNodesAsync() - Method in class io.lettuce.core.masterslave.SentinelTopologyProvider
-
Deprecated.
- getNodesAsync() - Method in class io.lettuce.core.masterslave.StaticMasterSlaveTopologyProvider
-
Deprecated.
- getNodesAsync() - Method in interface io.lettuce.core.masterslave.TopologyProvider
-
Deprecated.
Lookup nodes asynchronously within the topology.
- getNodesFromInfo(String) - Method in class io.lettuce.core.masterslave.MasterSlaveTopologyProvider
-
Deprecated.
- getObjectCount() - Method in class io.lettuce.core.support.BoundedAsyncPool
-
- getObjectType() - Method in class io.lettuce.core.support.ClientResourcesFactoryBean
-
- getObjectType() - Method in class io.lettuce.core.support.RedisClientFactoryBean
-
- getObjectType() - Method in class io.lettuce.core.support.RedisClusterClientFactoryBean
-
- getOffset() - Method in class io.lettuce.core.BitFieldArgs.Offset
-
- getOffset() - Method in class io.lettuce.core.Limit
-
- getOffset() - Method in class io.lettuce.core.XReadArgs.StreamOffset
-
- getOptions() - Method in class io.lettuce.core.AbstractRedisClient
-
- getOptions() - Method in interface io.lettuce.core.api.StatefulConnection
-
- getOptions() - Method in class io.lettuce.core.RedisChannelHandler
-
- getOutput() - Method in class io.lettuce.core.protocol.AsyncCommand
-
Get the object that holds this command's output.
- getOutput() - Method in class io.lettuce.core.protocol.Command
-
Get the object that holds this command's output.
- getOutput() - Method in class io.lettuce.core.protocol.CommandWrapper
-
- getOutput() - Method in interface io.lettuce.core.protocol.RedisCommand
-
The command output.
- getOutputType() - Method in class io.lettuce.core.dynamic.output.OutputSelector
-
- getParameterAnnotation(Class<T>) - Method in class io.lettuce.core.dynamic.support.MethodParameter
-
Return the parameter annotation of the given type, if available.
- getParameterAnnotations() - Method in class io.lettuce.core.dynamic.support.MethodParameter
-
Return the annotations associated with the specific method/constructor parameter.
- getParameterCount() - Method in interface io.lettuce.core.dynamic.parameter.MethodParametersAccessor
-
- getParameterIndex() - Method in class io.lettuce.core.dynamic.parameter.Parameter
-
- getParameterIndex() - Method in class io.lettuce.core.dynamic.segment.CommandSegment.ArgumentContribution
-
- getParameterIndex() - Method in class io.lettuce.core.dynamic.support.MethodParameter
-
Return the index of the method/constructor parameter.
- getParameterName() - Method in class io.lettuce.core.dynamic.support.MethodParameter
-
Return the name of the method/constructor parameter.
- getParameterNames(Method) - Method in class io.lettuce.core.dynamic.support.AnnotationParameterNameDiscoverer
-
- getParameterNames(Constructor<?>) - Method in class io.lettuce.core.dynamic.support.AnnotationParameterNameDiscoverer
-
- getParameterNames(Method) - Method in class io.lettuce.core.dynamic.support.CompositeParameterNameDiscoverer
-
- getParameterNames(Constructor<?>) - Method in class io.lettuce.core.dynamic.support.CompositeParameterNameDiscoverer
-
- getParameterNames(Method) - Method in interface io.lettuce.core.dynamic.support.ParameterNameDiscoverer
-
Return parameter names for this method, or null
if they cannot be determined.
- getParameterNames(Constructor<?>) - Method in interface io.lettuce.core.dynamic.support.ParameterNameDiscoverer
-
Return parameter names for this constructor, or null
if they cannot be determined.
- getParameterNames(Method) - Method in class io.lettuce.core.dynamic.support.StandardReflectionParameterNameDiscoverer
-
- getParameterNames(Constructor<?>) - Method in class io.lettuce.core.dynamic.support.StandardReflectionParameterNameDiscoverer
-
- getParameters() - Method in interface io.lettuce.core.dynamic.CommandMethod
-
- getParameters() - Method in class io.lettuce.core.dynamic.DeclaredCommandMethod
-
- getParameters() - Method in class io.lettuce.core.dynamic.parameter.Parameters
-
- getParameterType() - Method in class io.lettuce.core.dynamic.parameter.Parameter
-
- getParameterType() - Method in class io.lettuce.core.dynamic.support.MethodParameter
-
Return the type of the method/constructor parameter.
- getParameterTypes(Constructor<?>) - Method in interface io.lettuce.core.dynamic.support.TypeInformation
-
- getParameterTypes(Method) - Method in interface io.lettuce.core.dynamic.support.TypeInformation
-
- getPartition(String, int) - Method in class io.lettuce.core.cluster.models.partitions.Partitions
-
- getPartition(int) - Method in class io.lettuce.core.cluster.models.partitions.Partitions
-
- getPartitionByNodeId(String) - Method in class io.lettuce.core.cluster.models.partitions.Partitions
-
- getPartitionBySlot(int) - Method in class io.lettuce.core.cluster.models.partitions.Partitions
-
- getPartitions() - Method in interface io.lettuce.core.cluster.api.StatefulRedisClusterConnection
-
- getPartitions() - Method in class io.lettuce.core.cluster.models.partitions.Partitions
-
- getPartitions() - Method in exception io.lettuce.core.cluster.PartitionSelectorException
-
- getPartitions() - Method in interface io.lettuce.core.cluster.pubsub.StatefulRedisClusterPubSubConnection
-
- getPartitions() - Method in class io.lettuce.core.cluster.RedisClusterClient
-
Retrieve the cluster view.
- getPartitions() - Method in class io.lettuce.core.cluster.StatefulRedisClusterConnectionImpl
-
- getPartitions() - Method in class io.lettuce.core.event.cluster.AdaptiveRefreshTriggeredEvent
-
Retrieve the currently known partitions.
- getPassword() - Method in class io.lettuce.core.RedisURI
-
Returns the password.
- getPassword() - Method in class io.lettuce.core.support.LettuceFactoryBeanSupport
-
- getPattern() - Method in class io.lettuce.core.pubsub.api.reactive.PatternMessage
-
- getPatterns() - Method in class io.lettuce.core.pubsub.PubSubEndpoint
-
- getPercentiles() - Method in class io.lettuce.core.metrics.CommandMetrics.CommandLatency
-
- getPingSentTimestamp() - Method in class io.lettuce.core.cluster.models.partitions.RedisClusterNode
-
- getPongReceivedTimestamp() - Method in class io.lettuce.core.cluster.models.partitions.RedisClusterNode
-
- getPort() - Method in interface io.lettuce.core.ConnectionPoint
-
Get the current port number.
- getPort() - Method in class io.lettuce.core.internal.HostAndPort
-
- getPort() - Method in class io.lettuce.core.RedisURI
-
Returns the Redis port.
- getProtocols() - Method in class io.lettuce.core.SslOptions
-
- getrange(K, long, long) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- getrange(K, long, long) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- getrange(K, long, long) - Method in interface io.lettuce.core.api.async.RedisStringAsyncCommands
-
Get a substring of the string stored at a key.
- getrange(K, long, long) - Method in interface io.lettuce.core.api.reactive.RedisStringReactiveCommands
-
Get a substring of the string stored at a key.
- getrange(K, long, long) - Method in interface io.lettuce.core.api.sync.RedisStringCommands
-
Get a substring of the string stored at a key.
- getrange(K, long, long) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionStringAsyncCommands
-
Get a substring of the string stored at a key.
- getrange(K, long, long) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionStringCommands
-
Get a substring of the string stored at a key.
- getRawClass() - Method in class io.lettuce.core.dynamic.support.ResolvableType
-
Return the underlying Java
Class
being managed, if available; otherwise
null
.
- getRawTypeInformation() - Method in class io.lettuce.core.dynamic.support.ClassTypeInformation
-
- getRawTypeInformation() - Method in interface io.lettuce.core.dynamic.support.TypeInformation
-
- getReadFrom() - Method in interface io.lettuce.core.cluster.api.StatefulRedisClusterConnection
-
Gets the
ReadFrom
setting for this connection.
- getReadFrom() - Method in class io.lettuce.core.cluster.StatefulRedisClusterConnectionImpl
-
- getReadFrom() - Method in interface io.lettuce.core.masterreplica.StatefulRedisMasterReplicaConnection
-
Gets the
ReadFrom
setting for this connection.
- getReadFrom() - Method in class io.lettuce.core.masterslave.MasterSlaveConnectionProvider
-
Deprecated.
- getReadFrom() - Method in interface io.lettuce.core.masterslave.StatefulRedisMasterSlaveConnection
-
Deprecated.
Gets the
ReadFrom
setting for this connection.
- getRedeliveryCount() - Method in class io.lettuce.core.models.stream.PendingMessage
-
- getRedisCodec() - Method in class io.lettuce.core.dynamic.output.OutputSelector
-
- getRedisURI() - Method in class io.lettuce.core.support.LettuceFactoryBeanSupport
-
- getRedisURIs() - Method in class io.lettuce.core.support.RedisClusterClientFactoryBean
-
- getRefreshPeriod() - Method in class io.lettuce.core.cluster.ClusterClientOptions
-
Period between the regular cluster topology updates.
- getRefreshPeriod() - Method in class io.lettuce.core.cluster.ClusterTopologyRefreshOptions
-
Period between the regular cluster topology updates.
- getRefreshTriggersReconnectAttempts() - Method in class io.lettuce.core.cluster.ClusterTopologyRefreshOptions
-
- getRemoteAddress() - Method in interface io.lettuce.core.ConnectionFuture
-
- getReplicaNodes() - Method in class io.lettuce.core.cluster.models.slots.ClusterSlotRange
-
- getReplicas() - Method in class io.lettuce.core.models.role.RedisMasterInstance
-
- getReplicationOffset() - Method in class io.lettuce.core.models.role.RedisMasterInstance
-
- getReplicationOffset() - Method in class io.lettuce.core.models.role.ReplicationPartner
-
- getRequestQueueSize() - Method in class io.lettuce.core.ClientOptions
-
Request queue size for a connection.
- getResolvedAddress() - Method in class io.lettuce.core.RedisURI
-
- getResourceCount() - Method in class io.lettuce.core.AbstractRedisClient
-
- getResources() - Method in interface io.lettuce.core.api.StatefulConnection
-
- getResources() - Method in class io.lettuce.core.cluster.RedisClusterClient
-
- getResources() - Method in class io.lettuce.core.RedisChannelHandler
-
- getResources() - Method in class io.lettuce.core.RedisClient
-
- getReturnType() - Method in interface io.lettuce.core.dynamic.CommandMethod
-
- getReturnType() - Method in class io.lettuce.core.dynamic.DeclaredCommandMethod
-
- getReturnType(Method) - Method in interface io.lettuce.core.dynamic.support.TypeInformation
-
- getRole() - Method in class io.lettuce.core.cluster.models.partitions.RedisClusterNode
-
Returns the
Role
of the Redis Cluster node based on the
flags
.
- getRole() - Method in interface io.lettuce.core.models.role.RedisInstance
-
- getRole() - Method in class io.lettuce.core.models.role.RedisMasterInstance
-
- getRole() - Method in class io.lettuce.core.models.role.RedisSentinelInstance
-
- getRole() - Method in class io.lettuce.core.models.role.RedisSlaveInstance
-
- getScore() - Method in class io.lettuce.core.ScoredValue
-
- getSentinelMasterId() - Method in class io.lettuce.core.RedisURI
-
Returns the Sentinel Master Id.
- getSentinels() - Method in class io.lettuce.core.RedisURI
-
- getset(K, V) - Method in class io.lettuce.core.AbstractRedisAsyncCommands
-
- getset(K, V) - Method in class io.lettuce.core.AbstractRedisReactiveCommands
-
- getset(K, V) - Method in interface io.lettuce.core.api.async.RedisStringAsyncCommands
-
Set the string value of a key and return its old value.
- getset(K, V) - Method in interface io.lettuce.core.api.reactive.RedisStringReactiveCommands
-
Set the string value of a key and return its old value.
- getset(K, V) - Method in interface io.lettuce.core.api.sync.RedisStringCommands
-
Set the string value of a key and return its old value.
- getset(K, V) - Method in interface io.lettuce.core.cluster.api.async.NodeSelectionStringAsyncCommands
-
Set the string value of a key and return its old value.
- getset(K, V) - Method in interface io.lettuce.core.cluster.api.sync.NodeSelectionStringCommands
-
Set the string value of a key and return its old value.
- getSinceLastDelivery() - Method in class io.lettuce.core.models.stream.PendingMessage
-
- getSlaveNodes() - Method in class io.lettuce.core.cluster.models.slots.ClusterSlotRange
-
Deprecated.
- getSlaveOf() - Method in class io.lettuce.core.cluster.models.partitions.RedisClusterNode
-
- getSlaves() - Method in class io.lettuce.core.models.role.RedisMasterInstance
-
Deprecated.
- getSlot(String) - Static method in class io.lettuce.core.cluster.SlotHash
-
Calculate the slot from the given key.
- getSlot(byte[]) - Static method in class io.lettuce.core.cluster.SlotHash
-
Calculate the slot from the given key.
- getSlot(ByteBuffer) - Static method in class io.lettuce.core.cluster.SlotHash
-
Calculate the slot from the given key.
- getSlots() - Method in class io.lettuce.core.cluster.models.partitions.RedisClusterNode
-
Return the slots as
List
.
- getSocket() - Method in interface io.lettuce.core.ConnectionPoint
-
Get the socket path.
- getSocket() - Method in class io.lettuce.core.RedisURI
-
Returns the Unix Domain Socket path.
- getSocketAddress(RedisURI) - Method in class io.lettuce.core.RedisClient
-
- getSocketAddressSupplier(Function<Partitions, Collection<RedisClusterNode>>) - Method in class io.lettuce.core.cluster.RedisClusterClient
-
- getSocketOptions() - Method in class io.lettuce.core.ClientOptions
-
- getSource() - Method in class io.lettuce.core.dynamic.support.ResolvableType
-
Return the underlying source of the resolvable type.
- getSource() - Method in interface io.lettuce.core.dynamic.support.ResolvableType.VariableResolver
-
Return the source of the resolver (used for hashCode and equals).
- getSource() - Method in class io.lettuce.core.TimeoutOptions
-
- getSpan() - Method in class io.lettuce.core.protocol.TracedCommand
-
- getSslOptions() - Method in class io.lettuce.core.ClientOptions
-
- getSslProvider() - Method in class io.lettuce.core.SslOptions
-
Deprecated.
- getStack() - Method in class io.lettuce.core.protocol.CommandHandler
-
- getState() - Method in class io.lettuce.core.models.role.RedisSlaveInstance
-
- getState() - Method in class io.lettuce.core.protocol.CommandHandler
-
- getStatefulConnection() - Method in interface io.lettuce.core.api.async.RedisAsyncCommands
-
- getStatefulConnection() - Method in interface io.lettuce.core.api.reactive.RedisReactiveCommands
-
- getStatefulConnection() - Method in interface io.lettuce.core.api.sync.RedisCommands
-
- getStatefulConnection() - Method in interface io.lettuce.core.cluster.api.async.RedisAdvancedClusterAsyncCommands
-
- getStatefulConnection() - Method in interface io.lettuce.core.cluster.api.reactive.RedisAdvancedClusterReactiveCommands
-
- getStatefulConnection() - Method in interface io.lettuce.core.cluster.api.sync.RedisAdvancedClusterCommands
-
- getStatefulConnection() - Method in interface io.lettuce.core.cluster.pubsub.api.async.RedisClusterPubSubAsyncCommands
-
- getStatefulConnection() - Method in interface io.lettuce.core.cluster.pubsub.api.reactive.RedisClusterPubSubReactiveCommands
-
- getStatefulConnection() - Method in interface io.lettuce.core.cluster.pubsub.api.sync.RedisClusterPubSubCommands
-
- getStatefulConnection() - Method in class io.lettuce.core.cluster.RedisAdvancedClusterAsyncCommandsImpl
-
- getStatefulConnection() - Method in class io.lettuce.core.cluster.RedisAdvancedClusterReactiveCommandsImpl
-
- getStatefulConnection() - Method in class io.lettuce.core.cluster.RedisClusterPubSubAsyncCommandsImpl
-
- getStatefulConnection() - Method in class io.lettuce.core.cluster.RedisClusterPubSubReactiveCommandsImpl
-
- getStatefulConnection() - Method in interface io.lettuce.core.pubsub.api.async.RedisPubSubAsyncCommands
-
- getStatefulConnection() - Method in interface io.lettuce.core.pubsub.api.reactive.RedisPubSubReactiveCommands
-
- getStatefulConnection() - Method in interface io.lettuce.core.pubsub.api.sync.RedisPubSubCommands
-
- getStatefulConnection() - Method in class io.lettuce.core.pubsub.RedisPubSubAsyncCommandsImpl
-
- getStatefulConnection() - Method in class io.lettuce.core.pubsub.RedisPubSubReactiveCommandsImpl
-
- getStatefulConnection() - Method in class io.lettuce.core.RedisAsyncCommandsImpl
-
- getStatefulConnection() - Method in class io.lettuce.core.RedisReactiveCommandsImpl
-
- getStatefulConnection() - Method in interface io.lettuce.core.sentinel.api.async.RedisSentinelAsyncCommands
-
- getStatefulConnection() - Method in interface io.lettuce.core.sentinel.api.reactive.RedisSentinelReactiveCommands
-
- getStatefulConnection() - Method in interface io.lettuce.core.sentinel.api.sync.RedisSentinelCommands
-
- getStatefulConnection() - Method in class io.lettuce.core.sentinel.RedisSentinelAsyncCommandsImpl
-
- getStatefulConnection() - Method in class io.lettuce.core.sentinel.RedisSentinelReactiveCommandsImpl
-
- getStoreDistKey() - Method in class io.lettuce.core.GeoRadiusStoreArgs
-
- getStoreKey() - Method in class io.lettuce.core.GeoRadiusStoreArgs
-
- getStream() - Method in class io.lettuce.core.StreamMessage
-
- getSubscriber() - Method in class io.lettuce.core.output.BooleanListOutput
-
- getSubscriber() - Method in class io.lettuce.core.output.GeoCoordinatesListOutput
-
- getSubscriber() - Method in class io.lettuce.core.output.GeoCoordinatesValueListOutput
-
- getSubscriber() - Method in class io.lettuce.core.output.GeoWithinListOutput
-
- getSubscriber() - Method in class io.lettuce.core.output.KeyListOutput
-
- getSubscriber() - Method in class io.lettuce.core.output.KeyValueListOutput
-
- getSubscriber() - Method in class io.lettuce.core.output.ScoredValueListOutput
-
- getSubscriber() - Method in interface io.lettuce.core.output.StreamingOutput
-
- getSubscriber() - Method in class io.lettuce.core.output.StreamMessageListOutput
-
- getSubscriber() - Method in class io.lettuce.core.output.StreamReadOutput
-
- getSubscriber() - Method in class io.lettuce.core.output.StringListOutput
-
- getSubscriber() - Method in class io.lettuce.core.output.StringValueListOutput
-
- getSubscriber() - Method in class io.lettuce.core.output.ValueListOutput
-
- getSubscriber() - Method in class io.lettuce.core.output.ValueValueListOutput
-
- getSuperType() - Method in class io.lettuce.core.dynamic.support.ResolvableType
-
Return a
ResolvableType
representing the direct supertype of this type.
- getSuperTypeInformation(Class<?>) - Method in interface io.lettuce.core.dynamic.support.TypeInformation
-
- getThreadFactory(String) - Method in interface io.lettuce.core.resource.DefaultEventLoopGroupProvider.ThreadFactoryProvider
-
- getTimeout() - Method in interface io.lettuce.core.api.StatefulConnection
-
- getTimeout() - Method in class io.lettuce.core.ConnectionBuilder
-
- getTimeout() - Method in class io.lettuce.core.dynamic.domain.Timeout
-
- getTimeout() - Method in class io.lettuce.core.RedisChannelHandler
-
- getTimeout() - Method in class io.lettuce.core.RedisURI
-
Returns the command timeout for synchronous command execution.
- getTimeout(RedisCommand<?, ?, ?>) - Method in class io.lettuce.core.TimeoutOptions.TimeoutSource
-
- getTimeoutIndex() - Method in class io.lettuce.core.dynamic.parameter.ExecutionSpecificParameters
-
- getTimeoutNs(RedisCommand<?, ?, ?>) - Method in class io.lettuce.core.internal.TimeoutProvider
-
- getTimeoutOptions() - Method in class io.lettuce.core.ClientOptions
-
- getTimeUnit() - Method in class io.lettuce.core.metrics.CommandMetrics
-
- getTimeUnit() - Method in class io.lettuce.core.TimeoutOptions.TimeoutSource
-
- getTo() - Method in class io.lettuce.core.cluster.models.slots.ClusterSlotRange
-
- getTopologyRefreshOptions() - Method in class io.lettuce.core.cluster.ClusterClientOptions
-
- getTopologyRefreshSource() - Method in class io.lettuce.core.cluster.RedisClusterClient
-
Returns the seed
RedisURI
for the topology refreshing.
- getTraceContext() - Method in class io.lettuce.core.protocol.TracedCommand
-
- getTraceContext() - Method in interface io.lettuce.core.tracing.TraceContextProvider
-
- getTraceContextLater() - Method in interface io.lettuce.core.tracing.TraceContextProvider
-
- getTracer() - Method in interface io.lettuce.core.tracing.TracerProvider
-
- getTracerProvider() - Method in class io.lettuce.core.tracing.BraveTracing
-
- getTracerProvider() - Method in interface io.lettuce.core.tracing.Tracing
-
- getTruststore() - Method in class io.lettuce.core.SslOptions
-
- getTruststorePassword() - Method in class io.lettuce.core.SslOptions
-
- getType() - Method in class io.lettuce.core.dynamic.support.ClassTypeInformation
-
- getType() - Method in class io.lettuce.core.dynamic.support.ResolvableType
-
Return the underling Java
Type
being managed.
- getType() - Method in interface io.lettuce.core.dynamic.support.TypeInformation
-
Returns the type of the property.
- getType() - Method in class io.lettuce.core.dynamic.support.TypeVariableTypeInformation
-
- getType() - Method in class io.lettuce.core.protocol.AsyncCommand
-
- getType() - Method in class io.lettuce.core.protocol.Command
-
- getType() - Method in class io.lettuce.core.protocol.CommandWrapper
-
- getType() - Method in interface io.lettuce.core.protocol.RedisCommand
-
- getTypeArguments() - Method in interface io.lettuce.core.dynamic.support.TypeInformation
-
- getTypeArguments() - Method in class io.lettuce.core.dynamic.support.TypeVariableTypeInformation
-
- getTypeIndexForCurrentLevel() - Method in class io.lettuce.core.dynamic.support.MethodParameter
-
Return the type index for the current nesting level.
- getTypeIndexForLevel(int) - Method in class io.lettuce.core.dynamic.support.MethodParameter
-
Return the type index for the specified nesting level.
- getTypeInformation() - Method in class io.lettuce.core.dynamic.output.OutputType
-
- getTypeInformation() - Method in class io.lettuce.core.dynamic.parameter.Parameter
-
- getTypeVariableMap(Class<?>) - Static method in class io.lettuce.core.dynamic.support.GenericTypeResolver
-
- getTypeVariableMap() - Method in interface io.lettuce.core.dynamic.support.TypeInformation
-
- getUpper() - Method in class io.lettuce.core.Range
-
- getUpstreamListener() - Method in class io.lettuce.core.cluster.PubSubClusterEndpoint
-
- getUri() - Method in class io.lettuce.core.cluster.models.partitions.RedisClusterNode
-
- getUri() - Method in interface io.lettuce.core.models.role.RedisNodeDescription
-
- getUri() - Method in class io.lettuce.core.support.LettuceFactoryBeanSupport
-
- getValue() - Method in class io.lettuce.core.dynamic.segment.CommandSegment.ArgumentContribution
-
- getValue() - Method in class io.lettuce.core.Range.Boundary
-
- getValue() - Method in class io.lettuce.core.Value
-
If a value is present in this Value
, returns the value, otherwise throws NoSuchElementException
.
- getValueOrElse(V) - Method in class io.lettuce.core.Value
-
Return the value if present, otherwise return other
.
- getValueOrElseGet(Supplier<V>) - Method in class io.lettuce.core.Value
-
Return the value if present, otherwise invoke other
and return the result of that invocation.
- getValueOrElseThrow(Supplier<? extends X>) - Method in class io.lettuce.core.Value
-
Return the contained value, if present, otherwise throw an exception to be created by the provided supplier.
- getValues() - Method in class io.lettuce.core.ScoredValueScanCursor
-
- getValues() - Method in class io.lettuce.core.ValueScanCursor
-
- getValueType(TypeInformation<?>) - Static method in class io.lettuce.core.dynamic.codec.AnnotationRedisCodecResolver.ParameterWrappers
-
- getVariableName() - Method in class io.lettuce.core.dynamic.support.TypeVariableTypeInformation
-
- getVersion() - Method in class io.lettuce.core.codec.CipherCodec.KeyDescriptor
-
- getViewedBy(Map<RedisURI, Partitions>, Partitions) - Method in class io.lettuce.core.cluster.topology.ClusterTopologyRefresh
-
- getX() - Method in class io.lettuce.core.GeoCoordinates
-
- getY() - Method in class io.lettuce.core.GeoCoordinates
-
- gt(T) - Method in class io.lettuce.core.Range
-
Greater than lower
.
- gte(T) - Method in class io.lettuce.core.Range
-
Greater than or equals lower
.