spring-data-redis 文档 下载链接(含jar包、源码、pom)
组件名称 | 中文-文档-下载链接 | 中英对照-文档-下载链接 |
---|---|---|
spring-data-redis-1.7.5.RELEASE.jar | spring-data-redis-1.7.5.RELEASE-API文档-中文版.zip | spring-data-redis-1.7.5.RELEASE-API文档-中英对照版.zip |
spring-data-redis-2.0.6.RELEASE.jar | spring-data-redis-2.0.6.RELEASE-API文档-中文版.zip | spring-data-redis-2.0.6.RELEASE-API文档-中英对照版.zip |
spring-data-redis-2.0.9.RELEASE.jar | spring-data-redis-2.0.9.RELEASE-API文档-中文版.zip | spring-data-redis-2.0.9.RELEASE-API文档-中英对照版.zip |
spring-data-redis-2.3.9.RELEASE.jar | spring-data-redis-2.3.9.RELEASE-API文档-中文版.zip | spring-data-redis-2.3.9.RELEASE-API文档-中英对照版.zip |
spring-data-redis-2.5.5.jar | spring-data-redis-2.5.5-API文档-中文版.zip | spring-data-redis-2.5.5-API文档-中英对照版.zip |
spring-data-redis-2.6.1.jar | spring-data-redis-2.6.1-API文档-中文版.zip | spring-data-redis-2.6.1-API文档-中英对照版.zip |
spring-data-redis 简介
Redis的Spring Data模块
spring-data-redis 中文文档、中英对照文档 说明
摘要:spring-data-redis、org.springframework.data、中文文档、中英对照文档、下载、包含jar包、原API文档、源代码、Maven依赖信息文件、翻译后的API文档、spring、data、springframework、redis、jar包、java、中英对照文档;
使用方法:解压翻译后的API文档,用浏览器打开“index.html”文件,即可纵览文档内容。
人性化翻译,文档中的代码和结构保持不变,注释和说明精准翻译,请放心使用。
双语对照,边学技术、边学英语。
涉及的包(package)
Spring Data Redis 2.6.1 API
Package | Description |
---|---|
org.springframework.data.redis | |
org.springframework.data.redis.cache | |
org.springframework.data.redis.config |
Namespace and configuration.
命名空间和配置。 |
org.springframework.data.redis.connection |
Connection package providing low-level abstractions for interacting with the various Redis 'drivers'/libraries.
连接包提供与各种redis'drivers'/库交互的低级抽象。 |
org.springframework.data.redis.connection.convert |
Redis specific converters used for sending data and parsing responses.
Redis特定转换器用于发送数据和解析响应。 |
org.springframework.data.redis.connection.jedis | |
org.springframework.data.redis.connection.lettuce | |
org.springframework.data.redis.connection.stream |
Data structures and interfaces to interact with Redis Streams.
数据结构和接口与REDIS流交互。 |
org.springframework.data.redis.connection.util |
Internal utility package for encoding/decoding Strings to byte[] (using Base64) library.
内部实用程序包,用于将字符串编码/解码到字节[](使用Base64)库。 |
org.springframework.data.redis.core | |
org.springframework.data.redis.core.convert |
Converters for Redis repository support utilizing mapping metadata.
用于redis存储库支持的转换器利用映射元数据。 |
org.springframework.data.redis.core.index |
Abstractions for Redis secondary indexes.
redis次要索引的抽象。 |
org.springframework.data.redis.core.mapping |
Redis specific repository support mapping meta information.
redis特定存储库支持映射元信息。 |
org.springframework.data.redis.core.query |
Query package for Redis template.
redis模板的查询包。 |
org.springframework.data.redis.core.script |
Lua script execution abstraction.
lua脚本执行抽象。 |
org.springframework.data.redis.core.types |
Redis domain specific types.
redis域特定类型。 |
org.springframework.data.redis.domain.geo | |
org.springframework.data.redis.hash |
Dedicated support package for Redis hashes.
redis哈希的专用支持包。 |
org.springframework.data.redis.listener |
Base package for Redis message listener / pubsub container facility
Redis消息侦听器/ Pubsub容器设施的基本包 |
org.springframework.data.redis.listener.adapter |
Message listener adapter package.
消息侦听器适配器包。 |
org.springframework.data.redis.repository.cdi |
CDI support for Redis specific repository implementation.
CDI支持Redis特定存储库实施。 |
org.springframework.data.redis.repository.configuration |
Redis repository specific configuration and bean registration.
redis存储库特定配置和bean注册。 |
org.springframework.data.redis.repository.core |
Core domain entities for repository support.
存储库支持的核心域实体。 |
org.springframework.data.redis.repository.query |
Redis specific query execution engine.
redis特定查询执行引擎。 |
org.springframework.data.redis.repository.support |
Spring context specific factory support.
Spring Context特定的工厂支持。 |
org.springframework.data.redis.serializer |
Serialization/Deserialization package for converting Object to (and from) binary data.
序列化/反序列化包将对象转换为(和来自)二进制数据。 |
org.springframework.data.redis.stream | |
org.springframework.data.redis.support.atomic |
Small toolkit mirroring the
java.util.atomic package in Redis.
在Redis中镜像java.util.atomic包的小型工具包。 |
org.springframework.data.redis.support.collections |
Package providing implementations for most of the
java.util collections on top of Redis.
包为Redis顶部提供大多数Java.util集合的实现。 |
org.springframework.data.redis.util |
Commonly used stuff for data manipulation throughout different driver specific implementations.
常用的东西用于在不同的驱动程序中进行数据操作。 |
org.springframework.data.redis
org.springframework.data.redis.cache
org.springframework.data.redis.config
org.springframework.data.redis.connection
org.springframework.data.redis.connection.convert
org.springframework.data.redis.connection.jedis
org.springframework.data.redis.connection.lettuce
org.springframework.data.redis.connection.stream
org.springframework.data.redis.connection.util
org.springframework.data.redis.core
org.springframework.data.redis.core.convert
org.springframework.data.redis.core.index
org.springframework.data.redis.core.mapping
org.springframework.data.redis.core.query
org.springframework.data.redis.core.script
org.springframework.data.redis.core.types
org.springframework.data.redis.domain.geo
org.springframework.data.redis.hash
org.springframework.data.redis.listener
org.springframework.data.redis.listener.adapter
org.springframework.data.redis.repository.cdi
org.springframework.data.redis.repository.configuration
org.springframework.data.redis.repository.core
org.springframework.data.redis.repository.query
org.springframework.data.redis.repository.support
org.springframework.data.redis.serializer
org.springframework.data.redis.stream
org.springframework.data.redis.support.atomic
org.springframework.data.redis.support.collections
org.springframework.data.redis.util
涉及的类(class)
AbstractRedisCollection
AbstractRedisConnection
AbstractSubscription
AuthenticatingRedisClient
BasicRedisPersistentEntity
BatchStrategies
BatchStrategy
BeanUtilsHashMapper
BitFieldSubCommands
BitFieldSubCommands.AbstractBitFieldSubCommand
BitFieldSubCommands.BitFieldGet
BitFieldSubCommands.BitFieldGetBuilder
BitFieldSubCommands.BitFieldIncrBy
BitFieldSubCommands.BitFieldIncrBy.Overflow
BitFieldSubCommands.BitFieldSet
BitFieldSubCommands.BitFieldSetBuilder
BitFieldSubCommands.BitFieldSubCommand
BitFieldSubCommands.BitFieldType
BitFieldSubCommands.Offset
BoundGeoOperations
BoundHashOperations
BoundingBox
BoundKeyOperations
BoundListOperations
BoundSetOperations
BoundStreamOperations
BoundValueOperations
BoundZSetOperations
BoxShape
Bucket
Bucket.BucketPropertyPath
BulkMapper
ByteArraySet
ByteArrayWrapper
ByteBufferRecord
ByteRecord
ByteUtils
CacheKeyPrefix
CacheStatistics
CacheStatisticsCollector
CacheStatisticsProvider
Cancelable
CdiBean
ChannelTopic
ClusterCommandExecutionFailureException
ClusterCommandExecutor
ClusterCommandExecutor.ClusterCommandCallback
ClusterCommandExecutor.MultiKeyClusterCommandCallback
ClusterCommandExecutor.MultiNodeResult
ClusterCommandExecutor.NodeResult
ClusterInfo
ClusterInfo.Info
ClusterNodeResourceProvider
ClusterOperations
ClusterRedirectException
ClusterSlotHashUtil
ClusterStateFailureException
ClusterTopology
ClusterTopologyProvider
CompositeIndexResolver
ConfigurableIndexDefinitionProvider
ConnectionUtils
Consumer
Converters
ConvertingCursor
Cursor
CustomConversions
DataType
DecodeUtils
DecoratedRedisConnection
DecoratingStringHashMapper
DefaultedRedisClusterConnection
DefaultedRedisConnection
DefaultLettucePool
DefaultMessage
DefaultReactiveScriptExecutor
DefaultRedisList
DefaultRedisMap
DefaultRedisScript
DefaultRedisSet
DefaultRedisTypeMapper
DefaultRedisZSet
DefaultScriptExecutor
DefaultSortParameters
DefaultStringRedisConnection
DefaultStringTuple
DefaultTuple
DefaultTypedTuple
DigestUtils
EnableRedisRepositories
ExampleQueryMapper
ExceptionTranslationStrategy
Expiration
FallbackExceptionTranslationStrategy
FutureResult
GenericJackson2JsonRedisSerializer
GenericToStringSerializer
GeoIndexDefinition
GeoIndexed
GeoIndexedPropertyValue
GeoLocation
GeoOperations
GeoReference
GeoReference.GeoCoordinateReference
GeoReference.GeoMemberReference
GeoShape
HashMapper
HashMapperProvider
HashOperations
HyperLogLogOperations
IndexConfiguration
IndexDefinition
IndexDefinition.Condition
IndexDefinition.IndexingContext
IndexDefinitionProvider
IndexDefinitionRegistry
Indexed
IndexedData
IndexResolver
IndexValueTransformer
Jackson2HashMapper
Jackson2JsonRedisSerializer
JdkSerializationRedisSerializer
JedisClientConfiguration
JedisClientConfiguration.DefaultJedisClientConfigurationBuilder
JedisClientConfiguration.JedisClientConfigurationBuilder
JedisClientConfiguration.JedisPoolingClientConfigurationBuilder
JedisClientConfiguration.JedisSslClientConfigurationBuilder
JedisClusterConnection
JedisClusterConnection.JedisClusterCommandCallback
JedisClusterConnection.JedisClusterTopologyProvider
JedisClusterConnection.JedisMultiKeyClusterCommandCallback
JedisConnection
JedisConnectionFactory
JedisConverters
JedisExceptionConverter
JedisScriptReturnConverter
JedisSentinelConnection
JedisUtils
JedisVersionUtil
Jsr310Converters
KeyBoundCursor
KeyExpirationEventMessageListener
KeyScanOptions
KeyspaceConfiguration
KeyspaceConfiguration.KeyspaceSettings
KeyspaceEventMessageListener
LettuceClientConfiguration
LettuceClientConfiguration.LettuceClientConfigurationBuilder
LettuceClientConfiguration.LettuceSslClientConfigurationBuilder
LettuceClusterConnection
LettuceClusterConnection.LettuceClusterCommandCallback
LettuceClusterConnection.LettuceMultiKeyClusterCommandCallback
LettuceConnection
LettuceConnection.PipeliningFlushPolicy
LettuceConnection.PipeliningFlushState
LettuceConnectionFactory
LettuceConnectionProvider
LettuceConnectionProvider.TargetAware
LettuceConverters
LettuceExceptionConverter
LettucePool
LettucePoolingClientConfiguration
LettucePoolingClientConfiguration.LettucePoolingClientConfigurationBuilder
LettucePoolingClientConfiguration.LettucePoolingSslClientConfigurationBuilder
LettuceSentinelConnection
LettuceSubscription
ListConverter
ListOperations
ListOperations.MoveFrom
ListOperations.MoveTo
LongToBooleanConverter
MapConverter
MappingConfiguration
MappingRedisConverter
MappingRedisConverter.BinaryKeyspaceIdentifier
MappingRedisConverter.KeyspaceIdentifier
MappingRedisEntityInformation
MapRecord
MapToPropertiesConverter
Message
MessageListener
MessageListenerAdapter
Metrics
NamedNode
ObjectHashMapper
ObjectRecord
OxmSerializer
PartialUpdate
PartialUpdate.PropertyUpdate
PartialUpdate.UpdateCommand
PassThroughExceptionTranslationStrategy
PathBasedRedisIndexDefinition
PathIndexResolver
PatternTopic
PendingMessage
PendingMessages
PendingMessagesSummary
Pool
PoolConfig
PoolException
QueryByExampleRedisExecutor
QueryUtils
RadiusShape
ReactiveClusterCommands
ReactiveClusterCommands.AddSlots
ReactiveClusterGeoCommands
ReactiveClusterHashCommands
ReactiveClusterHyperLogLogCommands
ReactiveClusterKeyCommands
ReactiveClusterListCommands
ReactiveClusterNumberCommands
ReactiveClusterScriptingCommands
ReactiveClusterServerCommands
ReactiveClusterSetCommands
ReactiveClusterStreamCommands
ReactiveClusterStringCommands
ReactiveClusterZSetCommands
ReactiveGeoCommands
ReactiveGeoCommands.GeoAddCommand
ReactiveGeoCommands.GeoDistCommand
ReactiveGeoCommands.GeoHashCommand
ReactiveGeoCommands.GeoPosCommand
ReactiveGeoCommands.GeoRadiusByMemberCommand
ReactiveGeoCommands.GeoRadiusCommand
ReactiveGeoCommands.GeoSearchCommand
ReactiveGeoCommands.GeoSearchStoreCommand
ReactiveGeoOperations
ReactiveHashCommands
ReactiveHashCommands.HDelCommand
ReactiveHashCommands.HExistsCommand
ReactiveHashCommands.HGetCommand
ReactiveHashCommands.HRandFieldCommand
ReactiveHashCommands.HSetCommand
ReactiveHashCommands.HStrLenCommand
ReactiveHashOperations
ReactiveHyperLogLogCommands
ReactiveHyperLogLogCommands.PfAddCommand
ReactiveHyperLogLogCommands.PfCountCommand
ReactiveHyperLogLogCommands.PfMergeCommand
ReactiveHyperLogLogOperations
ReactiveKeyCommands
ReactiveKeyCommands.CopyCommand
ReactiveKeyCommands.ExpireAtCommand
ReactiveKeyCommands.ExpireCommand
ReactiveKeyCommands.MoveCommand
ReactiveKeyCommands.RenameCommand
ReactiveListCommands
ReactiveListCommands.BLMoveCommand
ReactiveListCommands.BPopCommand
ReactiveListCommands.BRPopLPushCommand
ReactiveListCommands.Direction
ReactiveListCommands.LIndexCommand
ReactiveListCommands.LInsertCommand
ReactiveListCommands.LMoveCommand
ReactiveListCommands.LPosCommand
ReactiveListCommands.LRemCommand
ReactiveListCommands.LSetCommand
ReactiveListCommands.PopCommand
ReactiveListCommands.PopResponse
ReactiveListCommands.PopResult
ReactiveListCommands.PushCommand
ReactiveListCommands.RPopLPushCommand
ReactiveListOperations
ReactiveNumberCommands
ReactiveNumberCommands.DecrByCommand
ReactiveNumberCommands.HIncrByCommand
ReactiveNumberCommands.IncrByCommand
ReactivePubSubCommands
ReactiveRedisCallback
ReactiveRedisClusterConnection
ReactiveRedisConnection
ReactiveRedisConnection.AbsentByteBufferResponse
ReactiveRedisConnection.BooleanResponse
ReactiveRedisConnection.ByteBufferResponse
ReactiveRedisConnection.Command
ReactiveRedisConnection.CommandResponse
ReactiveRedisConnection.KeyCommand
ReactiveRedisConnection.KeyScanCommand
ReactiveRedisConnection.MultiValueResponse
ReactiveRedisConnection.NumericResponse
ReactiveRedisConnection.RangeCommand
ReactiveRedisConnectionFactory
ReactiveRedisMessageListenerContainer
ReactiveRedisOperations
ReactiveRedisSessionCallback
ReactiveRedisTemplate
ReactiveScriptExecutor
ReactiveScriptingCommands
ReactiveServerCommands
ReactiveSetCommands
ReactiveSetCommands.SAddCommand
ReactiveSetCommands.SDiffCommand
ReactiveSetCommands.SDiffStoreCommand
ReactiveSetCommands.SInterCommand
ReactiveSetCommands.SInterStoreCommand
ReactiveSetCommands.SIsMemberCommand
ReactiveSetCommands.SMIsMemberCommand
ReactiveSetCommands.SMoveCommand
ReactiveSetCommands.SPopCommand
ReactiveSetCommands.SRandMembersCommand
ReactiveSetCommands.SRemCommand
ReactiveSetCommands.SUnionCommand
ReactiveSetCommands.SUnionStoreCommand
ReactiveSetOperations
ReactiveStreamCommands
ReactiveStreamCommands.AcknowledgeCommand
ReactiveStreamCommands.AddStreamRecord
ReactiveStreamCommands.DeleteCommand
ReactiveStreamCommands.GroupCommand
ReactiveStreamCommands.GroupCommand.GroupCommandAction
ReactiveStreamCommands.PendingRecordsCommand
ReactiveStreamCommands.RangeCommand
ReactiveStreamCommands.ReadCommand
ReactiveStreamCommands.TrimCommand
ReactiveStreamCommands.XClaimCommand
ReactiveStreamCommands.XInfoCommand
ReactiveStreamOperations
ReactiveStringCommands
ReactiveStringCommands.AppendCommand
ReactiveStringCommands.BitCountCommand
ReactiveStringCommands.BitFieldCommand
ReactiveStringCommands.BitOpCommand
ReactiveStringCommands.BitPosCommand
ReactiveStringCommands.GetBitCommand
ReactiveStringCommands.GetExCommand
ReactiveStringCommands.MSetCommand
ReactiveStringCommands.SetBitCommand
ReactiveStringCommands.SetCommand
ReactiveStringCommands.SetRangeCommand
ReactiveStringRedisTemplate
ReactiveSubscription
ReactiveSubscription.ChannelMessage
ReactiveSubscription.Message
ReactiveSubscription.PatternMessage
ReactiveValueOperations
ReactiveZSetCommands
ReactiveZSetCommands.BZPopCommand
ReactiveZSetCommands.PopDirection
ReactiveZSetCommands.ZAddCommand
ReactiveZSetCommands.ZAggregateCommand
ReactiveZSetCommands.ZAggregateStoreCommand
ReactiveZSetCommands.ZCountCommand
ReactiveZSetCommands.ZDiffCommand
ReactiveZSetCommands.ZDiffStoreCommand
ReactiveZSetCommands.ZIncrByCommand
ReactiveZSetCommands.ZInterStoreCommand
ReactiveZSetCommands.ZLexCountCommand
ReactiveZSetCommands.ZMScoreCommand
ReactiveZSetCommands.ZPopCommand
ReactiveZSetCommands.ZRandMemberCommand
ReactiveZSetCommands.ZRangeByLexCommand
ReactiveZSetCommands.ZRangeByScoreCommand
ReactiveZSetCommands.ZRangeCommand
ReactiveZSetCommands.ZRankCommand
ReactiveZSetCommands.ZRemCommand
ReactiveZSetCommands.ZRemRangeByLexCommand
ReactiveZSetCommands.ZRemRangeByRankCommand
ReactiveZSetCommands.ZRemRangeByScoreCommand
ReactiveZSetCommands.ZScoreCommand
ReactiveZSetCommands.ZUnionStoreCommand
ReactiveZSetOperations
ReadOffset
Record
RecordId
RedisAccessor
RedisAtomicDouble
RedisAtomicInteger
RedisAtomicLong
RedisCache
RedisCacheConfiguration
RedisCacheManager
RedisCacheManager.RedisCacheManagerBuilder
RedisCacheWriter
RedisCallback
RedisClientInfo
RedisClientInfo.INFO
RedisClientInfo.RedisClientInfoBuilder
RedisClusterCallback
RedisClusterCommands
RedisClusterCommands.AddSlots
RedisClusterConfiguration
RedisClusterConnection
RedisClusterNode
RedisClusterNode.Flag
RedisClusterNode.LinkState
RedisClusterNode.RedisClusterNodeBuilder
RedisClusterNode.SlotRange
RedisClusterServerCommands
RedisCollection
RedisCollectionFactoryBean
RedisCollectionFactoryBean.CollectionType
RedisCommand
RedisCommands
RedisConfiguration
RedisConfiguration.ClusterConfiguration
RedisConfiguration.DomainSocketConfiguration
RedisConfiguration.SentinelConfiguration
RedisConfiguration.StaticMasterReplicaConfiguration
RedisConfiguration.WithAuthentication
RedisConfiguration.WithDatabaseIndex
RedisConfiguration.WithDomainSocket
RedisConfiguration.WithHostAndPort
RedisConfiguration.WithPassword
RedisConnection
RedisConnectionCommands
RedisConnectionFactory
RedisConnectionFailureException
RedisConnectionUtils
RedisConnectionUtils.RedisConnectionProxy
RedisConverter
RedisCustomConversions
RedisData
RedisElementReader
RedisElementWriter
RedisEntityInformation
RedisGeoCommands
RedisGeoCommands.DistanceUnit
RedisGeoCommands.GeoCommandArgs
RedisGeoCommands.GeoCommandArgs.GeoCommandFlag
RedisGeoCommands.GeoLocation
RedisGeoCommands.GeoRadiusCommandArgs
RedisGeoCommands.GeoRadiusCommandArgs.Flag
RedisGeoCommands.GeoSearchCommandArgs
RedisGeoCommands.GeoSearchStoreCommandArgs
RedisHash
RedisHashCommands
RedisHyperLogLogCommands
RedisIndexDefinition
RedisIndexDefinition.CompositeValueTransformer
RedisIndexDefinition.LowercaseIndexValueTransformer
RedisIndexDefinition.NoOpValueTransformer
RedisIndexDefinition.OrCondition
RedisIndexDefinition.PathCondition
RedisInvalidSubscriptionException
RedisKeyCommands
RedisKeyExpiredEvent
RedisKeyspaceEvent
RedisKeyValueAdapter
RedisKeyValueAdapter.EnableKeyspaceEvents
RedisKeyValueAdapter.ShadowCopy
RedisKeyValueAdapterBean
RedisKeyValueTemplate
RedisKeyValueTemplate.RedisKeyValueCallback
RedisKeyValueTemplateBean
RedisList
RedisListCommands
RedisListCommands.Direction
RedisListCommands.Position
RedisListenerExecutionFailedException
RedisMap
RedisMappingContext
RedisMessageListenerContainer
RedisNode
RedisNode.NodeType
RedisNode.RedisNodeBuilder
RedisOperationChain
RedisOperationChain.NearPath
RedisOperationChain.PathAndValue
RedisOperations
RedisPassword
RedisPersistentEntity
RedisPersistentProperty
RedisPipelineException
RedisProperties
RedisPubSubCommands
RedisQueryCreator
RedisRepositoriesRegistrar
RedisRepositoryBean
RedisRepositoryConfigurationExtension
RedisRepositoryExtension
RedisRepositoryFactory
RedisRepositoryFactoryBean
RedisScript
RedisScriptingCommands
RedisSentinelCommands
RedisSentinelConfiguration
RedisSentinelConnection
RedisSerializationContext
RedisSerializationContext.RedisSerializationContextBuilder
RedisSerializationContext.SerializationPair
RedisSerializer
RedisServer
RedisServer.INFO
RedisServerCommands
RedisServerCommands.MigrateOption
RedisServerCommands.ShutdownOption
RedisSet
RedisSetCommands
RedisSocketConfiguration
RedisStandaloneConfiguration
RedisStaticMasterReplicaConfiguration
RedisStore
RedisStreamCommands
RedisStreamCommands.XAddOptions
RedisStreamCommands.XClaimOptions
RedisStreamCommands.XClaimOptions.XClaimOptionsBuilder
RedisStreamCommands.XPendingOptions
RedisStringCommands
RedisStringCommands.BitOperation
RedisStringCommands.SetOption
RedisSubscribedConnectionException
RedisSystemException
RedisTemplate
RedisTxCommands
RedisTypeMapper
RedisZSet
RedisZSetCommands
RedisZSetCommands.Aggregate
RedisZSetCommands.Limit
RedisZSetCommands.Range
RedisZSetCommands.Range.Boundary
RedisZSetCommands.Tuple
RedisZSetCommands.Weights
RedisZSetCommands.ZAddArgs
RedisZSetCommands.ZAddArgs.Flag
ReferenceResolver
ReferenceResolverImpl
RemoveIndexedData
ReturnType
ScanCursor
ScanIteration
ScanOptions
ScanOptions.ScanOptionsBuilder
ScriptExecutor
ScriptingException
SerializationException
SerializationUtils
SessionCallback
SetConverter
SetOperations
SimpleIndexDefinition
SimpleIndexedPropertyValue
SortCriterion
SortParameters
SortParameters.Order
SortParameters.Range
SortQuery
SortQueryBuilder
SpelIndexDefinition
SpelIndexResolver
StreamInfo
StreamInfo.XInfoConsumer
StreamInfo.XInfoConsumers
StreamInfo.XInfoGroup
StreamInfo.XInfoGroups
StreamInfo.XInfoObject
StreamInfo.XInfoStream
StreamListener
StreamMessageListenerContainer
StreamMessageListenerContainer.ConsumerStreamReadRequest
StreamMessageListenerContainer.ConsumerStreamReadRequestBuilder
StreamMessageListenerContainer.StreamMessageListenerContainerOptions
StreamMessageListenerContainer.StreamMessageListenerContainerOptionsBuilder
StreamMessageListenerContainer.StreamReadRequest
StreamMessageListenerContainer.StreamReadRequestBuilder
StreamOffset
StreamOperations
StreamReadOptions
StreamReceiver
StreamReceiver.StreamReceiverOptions
StreamReceiver.StreamReceiverOptionsBuilder
StreamRecords
StreamRecords.RecordBuilder
StringRecord
StringRedisConnection
StringRedisConnection.StringTuple
StringRedisSerializer
StringRedisTemplate
StringToDataTypeConverter
StringToPropertiesConverter
StringToRedisClientInfoConverter
Subscription
Subscription
SubscriptionListener
Task
Task.State
TimeoutUtils
TimeToLive
TimeToLiveAccessor
TooManyClusterRedirectionsException
Topic
TransactionResultConverter
ValueEncoding
ValueEncoding.RedisValueEncoding
ValueOperations
Version
VersionParser
ZSetOperations
ZSetOperations.TypedTuple