Class Hierarchy
- java.lang.Object
- org.springframework.cache.support.AbstractCacheManager (implements org.springframework.cache.CacheManager, org.springframework.beans.factory.InitializingBean)
- java.util.AbstractCollection<E> (implements java.util.Collection<E>)
- org.springframework.data.redis.support.collections.AbstractRedisCollection<E> (implements org.springframework.data.redis.support.collections.RedisCollection<E>)
- org.springframework.data.redis.support.collections.DefaultRedisList<E> (implements org.springframework.data.redis.support.collections.RedisList<E>)
- org.springframework.data.redis.support.collections.DefaultRedisSet<E> (implements org.springframework.data.redis.support.collections.RedisSet<E>)
- org.springframework.data.redis.support.collections.DefaultRedisZSet<E> (implements org.springframework.data.redis.support.collections.RedisZSet<E>)
- org.springframework.data.keyvalue.core.AbstractKeyValueAdapter (implements org.springframework.data.keyvalue.core.KeyValueAdapter)
- org.springframework.data.mapping.context.AbstractMappingContext<E,P> (implements org.springframework.context.ApplicationContextAware, org.springframework.context.ApplicationEventPublisherAware, org.springframework.beans.factory.InitializingBean, org.springframework.data.mapping.context.MappingContext<E,P>)
- org.springframework.data.keyvalue.core.mapping.context.KeyValueMappingContext<E,P>
- org.springframework.data.mapping.model.AbstractPersistentProperty<P> (implements org.springframework.data.mapping.PersistentProperty<P>)
- org.springframework.data.repository.query.parser.AbstractQueryCreator<T,S>
- io.lettuce.core.AbstractRedisClient
- io.lettuce.core.RedisClient
- org.springframework.data.redis.connection.AbstractRedisConnection (implements org.springframework.data.redis.connection.DefaultedRedisConnection)
- org.springframework.data.redis.connection.util.AbstractSubscription (implements org.springframework.data.redis.connection.Subscription)
- org.springframework.cache.support.AbstractValueAdaptingCache (implements org.springframework.cache.Cache)
- org.apache.commons.pool2.BaseObject
- org.apache.commons.pool2.impl.BaseObjectPoolConfig<T> (implements java.lang.Cloneable)
- org.apache.commons.pool2.impl.GenericObjectPoolConfig<T>
- org.springframework.data.redis.connection.PoolConfig
- org.springframework.data.mapping.model.BasicPersistentEntity<T,P> (implements org.springframework.data.mapping.model.MutablePersistentEntity<T,P>)
- org.springframework.data.keyvalue.core.mapping.BasicKeyValuePersistentEntity<T,P> (implements org.springframework.data.keyvalue.core.mapping.KeyValuePersistentEntity<T,P>)
- org.springframework.data.redis.cache.BatchStrategies
- org.springframework.data.redis.hash.BeanUtilsHashMapper<T> (implements org.springframework.data.redis.hash.HashMapper<T,K,V>)
- org.springframework.data.redis.connection.BitFieldSubCommands (implements java.lang.Iterable<T>)
- org.springframework.data.redis.connection.BitFieldSubCommands.AbstractBitFieldSubCommand (implements org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldSubCommand)
- org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldGetBuilder
- org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldIncrByBuilder
- org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldSetBuilder
- org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldType
- org.springframework.data.redis.connection.BitFieldSubCommands.Offset
- org.springframework.data.redis.domain.geo.BoundingBox (implements org.springframework.data.geo.Shape)
- org.springframework.data.redis.domain.geo.BoxShape (implements org.springframework.data.redis.domain.geo.GeoShape)
- org.springframework.data.redis.core.convert.Bucket
- org.springframework.data.redis.core.convert.Bucket.BucketPropertyPath
- org.springframework.data.redis.connection.util.ByteArraySet (implements java.util.Set<E>)
- org.springframework.data.redis.connection.util.ByteArrayWrapper
- org.springframework.data.redis.util.ByteUtils
- org.springframework.data.redis.repository.cdi.CdiBean<T> (implements javax.enterprise.inject.spi.Bean<T>, javax.enterprise.inject.spi.PassivationCapable)
- org.springframework.data.repository.cdi.CdiRepositoryBean<T> (implements javax.enterprise.inject.spi.Bean<T>, javax.enterprise.inject.spi.PassivationCapable)
- org.springframework.data.repository.cdi.CdiRepositoryExtensionSupport (implements javax.enterprise.inject.spi.Extension)
- org.springframework.data.redis.listener.ChannelTopic (implements org.springframework.data.redis.listener.Topic)
- org.springframework.data.redis.connection.ClusterCommandExecutor (implements org.springframework.beans.factory.DisposableBean)
- org.springframework.data.redis.connection.ClusterCommandExecutor.MultiNodeResult<T>
- org.springframework.data.redis.connection.ClusterCommandExecutor.NodeResult<T>
- org.springframework.data.redis.connection.ClusterInfo
- org.springframework.data.redis.connection.ClusterSlotHashUtil
- org.springframework.data.redis.connection.ClusterTopology
- org.springframework.data.redis.core.convert.CompositeIndexResolver (implements org.springframework.data.redis.core.convert.IndexResolver)
- org.springframework.data.redis.connection.ConnectionUtils
- org.springframework.data.redis.connection.stream.Consumer
- org.springframework.data.redis.connection.convert.Converters
- org.springframework.data.redis.core.ConvertingCursor<S,T> (implements org.springframework.data.redis.core.Cursor<T>)
- org.springframework.data.convert.CustomConversions
- org.springframework.data.redis.connection.util.DecodeUtils
- org.springframework.data.redis.hash.DecoratingStringHashMapper<T> (implements org.springframework.data.redis.hash.HashMapper<T,K,V>)
- org.springframework.data.redis.connection.lettuce.DefaultLettucePool (implements org.springframework.beans.factory.InitializingBean, org.springframework.data.redis.connection.lettuce.LettucePool)
- org.springframework.data.redis.connection.DefaultMessage (implements org.springframework.data.redis.connection.Message)
- org.springframework.data.redis.core.script.DefaultReactiveScriptExecutor<K> (implements org.springframework.data.redis.core.script.ReactiveScriptExecutor<K>)
- org.springframework.data.redis.support.collections.DefaultRedisMap<K,V> (implements org.springframework.data.redis.support.collections.RedisMap<K,V>)
- org.springframework.data.redis.core.script.DefaultRedisScript<T> (implements org.springframework.beans.factory.InitializingBean, org.springframework.data.redis.core.script.RedisScript<T>)
- org.springframework.data.redis.core.script.DefaultScriptExecutor<K> (implements org.springframework.data.redis.core.script.ScriptExecutor<K>)
- org.springframework.data.redis.connection.DefaultSortParameters (implements org.springframework.data.redis.connection.SortParameters)
- org.springframework.data.redis.connection.DefaultStringRedisConnection (implements org.springframework.data.redis.connection.DecoratedRedisConnection, org.springframework.data.redis.connection.StringRedisConnection)
- org.springframework.data.redis.connection.DefaultTuple (implements org.springframework.data.redis.connection.RedisZSetCommands.Tuple)
- org.springframework.data.redis.core.DefaultTypedTuple<V> (implements org.springframework.data.redis.core.ZSetOperations.TypedTuple<V>)
- org.springframework.data.convert.DefaultTypeMapper<S> (implements org.springframework.data.convert.TypeMapper<S>)
- java.util.Dictionary<K,V>
- org.springframework.data.redis.core.script.DigestUtils
- java.util.EventObject (implements java.io.Serializable)
- org.springframework.data.redis.repository.query.ExampleQueryMapper
- org.springframework.data.redis.core.types.Expiration
- org.springframework.data.redis.connection.FutureResult<T>
- org.springframework.data.redis.serializer.GenericJackson2JsonRedisSerializer (implements org.springframework.data.redis.serializer.RedisSerializer<T>)
- org.springframework.data.redis.serializer.GenericToStringSerializer<T> (implements org.springframework.beans.factory.BeanFactoryAware, org.springframework.data.redis.serializer.RedisSerializer<T>)
- org.springframework.data.redis.core.convert.GeoIndexedPropertyValue (implements org.springframework.data.redis.core.convert.IndexedData)
- org.springframework.data.redis.domain.geo.GeoLocation<T>
- org.springframework.data.redis.domain.geo.GeoReference.GeoCoordinateReference<T> (implements org.springframework.data.redis.domain.geo.GeoReference<T>)
- org.springframework.data.redis.domain.geo.GeoReference.GeoMemberReference<T> (implements org.springframework.data.redis.domain.geo.GeoReference<T>)
- org.springframework.data.redis.core.index.IndexConfiguration (implements org.springframework.data.redis.core.index.ConfigurableIndexDefinitionProvider)
- org.springframework.data.redis.core.index.IndexDefinition.IndexingContext
- org.springframework.data.redis.hash.Jackson2HashMapper (implements org.springframework.data.redis.hash.HashMapper<T,K,V>)
- org.springframework.data.redis.serializer.Jackson2JsonRedisSerializer<T> (implements org.springframework.data.redis.serializer.RedisSerializer<T>)
- org.springframework.data.redis.serializer.JdkSerializationRedisSerializer (implements org.springframework.data.redis.serializer.RedisSerializer<T>)
- org.springframework.data.redis.connection.jedis.JedisClientConfiguration.DefaultJedisClientConfigurationBuilder (implements org.springframework.data.redis.connection.jedis.JedisClientConfiguration.JedisClientConfigurationBuilder, org.springframework.data.redis.connection.jedis.JedisClientConfiguration.JedisPoolingClientConfigurationBuilder, org.springframework.data.redis.connection.jedis.JedisClientConfiguration.JedisSslClientConfigurationBuilder)
- org.springframework.data.redis.connection.jedis.JedisClusterConnection (implements org.springframework.data.redis.connection.DefaultedRedisClusterConnection)
- org.springframework.data.redis.connection.jedis.JedisClusterConnection.JedisClusterTopologyProvider (implements org.springframework.data.redis.connection.ClusterTopologyProvider)
- org.springframework.data.redis.connection.jedis.JedisConnectionFactory (implements org.springframework.beans.factory.DisposableBean, org.springframework.beans.factory.InitializingBean, org.springframework.data.redis.connection.RedisConnectionFactory)
- org.springframework.data.redis.connection.jedis.JedisExceptionConverter (implements org.springframework.core.convert.converter.Converter<S,T>)
- org.springframework.data.redis.connection.jedis.JedisScriptReturnConverter (implements org.springframework.core.convert.converter.Converter<S,T>)
- org.springframework.data.redis.connection.jedis.JedisSentinelConnection (implements org.springframework.data.redis.connection.RedisSentinelConnection)
- org.springframework.data.redis.connection.jedis.JedisUtils
- org.springframework.data.redis.connection.jedis.JedisVersionUtil
- org.springframework.data.redis.core.convert.Jsr310Converters
- org.springframework.data.redis.core.convert.KeyspaceConfiguration
- org.springframework.data.redis.core.convert.KeyspaceConfiguration.KeyspaceSettings
- org.springframework.data.redis.listener.KeyspaceEventMessageListener (implements org.springframework.beans.factory.DisposableBean, org.springframework.beans.factory.InitializingBean, org.springframework.data.redis.connection.MessageListener)
- org.springframework.data.keyvalue.core.KeyValueTemplate (implements org.springframework.context.ApplicationEventPublisherAware, org.springframework.data.keyvalue.core.KeyValueOperations)
- org.springframework.data.redis.connection.lettuce.LettuceClientConfiguration.LettuceClientConfigurationBuilder
- org.springframework.data.redis.connection.lettuce.LettuceClientConfiguration.LettuceSslClientConfigurationBuilder
- org.springframework.data.redis.connection.lettuce.LettuceConnectionFactory (implements org.springframework.beans.factory.DisposableBean, org.springframework.beans.factory.InitializingBean, org.springframework.data.redis.connection.ReactiveRedisConnectionFactory, org.springframework.data.redis.connection.RedisConnectionFactory)
- org.springframework.data.redis.connection.lettuce.LettuceExceptionConverter (implements org.springframework.core.convert.converter.Converter<S,T>)
- org.springframework.data.redis.connection.lettuce.LettuceSentinelConnection (implements org.springframework.data.redis.connection.RedisSentinelConnection)
- org.springframework.data.redis.connection.convert.ListConverter<S,T> (implements org.springframework.core.convert.converter.Converter<S,T>)
- org.springframework.data.redis.core.ListOperations.MoveFrom<K>
- org.springframework.data.redis.core.ListOperations.MoveTo<K>
- org.springframework.data.redis.connection.convert.LongToBooleanConverter (implements org.springframework.core.convert.converter.Converter<S,T>)
- org.springframework.data.redis.connection.convert.MapConverter<S,T> (implements org.springframework.core.convert.converter.Converter<S,T>)
- org.springframework.data.redis.core.convert.MappingConfiguration
- org.springframework.data.redis.core.convert.MappingRedisConverter (implements org.springframework.beans.factory.InitializingBean, org.springframework.data.redis.core.convert.RedisConverter)
- org.springframework.data.redis.core.convert.MappingRedisConverter.BinaryKeyspaceIdentifier
- org.springframework.data.redis.core.convert.MappingRedisConverter.KeyspaceIdentifier
- org.springframework.data.redis.listener.adapter.MessageListenerAdapter (implements org.springframework.beans.factory.InitializingBean, org.springframework.data.redis.connection.MessageListener)
- java.lang.Number (implements java.io.Serializable)
- org.springframework.data.redis.hash.ObjectHashMapper (implements org.springframework.data.redis.hash.HashMapper<T,K,V>)
- org.springframework.data.redis.serializer.OxmSerializer (implements org.springframework.beans.factory.InitializingBean, org.springframework.data.redis.serializer.RedisSerializer<T>)
- org.springframework.data.redis.core.PartialUpdate<T>
- org.springframework.data.redis.core.PartialUpdate.PropertyUpdate
- org.springframework.data.redis.PassThroughExceptionTranslationStrategy (implements org.springframework.data.redis.ExceptionTranslationStrategy)
- org.springframework.data.redis.core.convert.PathIndexResolver (implements org.springframework.data.redis.core.convert.IndexResolver)
- org.springframework.data.redis.listener.PatternTopic (implements org.springframework.data.redis.listener.Topic)
- org.springframework.data.redis.connection.stream.PendingMessage
- org.springframework.data.redis.connection.stream.PendingMessages (implements org.springframework.data.util.Streamable<T>)
- org.springframework.data.redis.connection.stream.PendingMessagesSummary
- org.springframework.data.repository.core.support.PersistentEntityInformation<T,ID> (implements org.springframework.data.repository.core.EntityInformation<T,ID>)
- org.springframework.data.redis.repository.support.QueryByExampleRedisExecutor<T> (implements org.springframework.data.repository.query.QueryByExampleExecutor<T>)
- org.springframework.data.redis.core.query.QueryUtils
- org.springframework.data.redis.domain.geo.RadiusShape (implements org.springframework.data.redis.domain.geo.GeoShape)
- org.springframework.data.redis.connection.ReactiveHyperLogLogCommands.PfCountCommand (implements org.springframework.data.redis.connection.ReactiveRedisConnection.Command)
- org.springframework.data.redis.connection.ReactiveListCommands.BPopCommand (implements org.springframework.data.redis.connection.ReactiveRedisConnection.Command)
- org.springframework.data.redis.connection.ReactiveListCommands.PopResult
- org.springframework.data.redis.connection.ReactiveRedisConnection.CommandResponse<I,O>
- org.springframework.data.redis.connection.ReactiveRedisConnection.KeyCommand (implements org.springframework.data.redis.connection.ReactiveRedisConnection.Command)
- org.springframework.data.redis.listener.ReactiveRedisMessageListenerContainer (implements org.springframework.beans.factory.DisposableBean)
- org.springframework.data.redis.core.ReactiveRedisTemplate<K,V> (implements org.springframework.data.redis.core.ReactiveRedisOperations<K,V>)
- org.springframework.data.redis.connection.ReactiveSetCommands.SDiffCommand (implements org.springframework.data.redis.connection.ReactiveRedisConnection.Command)
- org.springframework.data.redis.connection.ReactiveSetCommands.SInterCommand (implements org.springframework.data.redis.connection.ReactiveRedisConnection.Command)
- org.springframework.data.redis.connection.ReactiveSetCommands.SUnionCommand (implements org.springframework.data.redis.connection.ReactiveRedisConnection.Command)
- org.springframework.data.redis.connection.ReactiveStreamCommands.ReadCommand
- org.springframework.data.redis.connection.ReactiveStringCommands.BitOpCommand
- org.springframework.data.redis.connection.ReactiveStringCommands.MSetCommand (implements org.springframework.data.redis.connection.ReactiveRedisConnection.Command)
- org.springframework.data.redis.connection.ReactiveSubscription.ChannelMessage<C,M> (implements org.springframework.data.redis.connection.ReactiveSubscription.Message<C,M>)
- org.springframework.data.redis.connection.ReactiveZSetCommands.ZAggregateCommand (implements org.springframework.data.redis.connection.ReactiveRedisConnection.Command)
- org.springframework.data.redis.connection.ReactiveZSetCommands.ZDiffCommand (implements org.springframework.data.redis.connection.ReactiveRedisConnection.Command)
- org.springframework.data.redis.connection.stream.ReadOffset
- org.springframework.data.redis.connection.stream.RecordId
- org.springframework.data.redis.core.RedisAccessor (implements org.springframework.beans.factory.InitializingBean)
- org.springframework.data.redis.cache.RedisCacheConfiguration
- org.springframework.data.redis.cache.RedisCacheManager.RedisCacheManagerBuilder
- org.springframework.data.redis.core.types.RedisClientInfo
- org.springframework.data.redis.core.types.RedisClientInfo.RedisClientInfoBuilder
- org.springframework.data.redis.connection.RedisClusterConfiguration (implements org.springframework.data.redis.connection.RedisConfiguration, org.springframework.data.redis.connection.RedisConfiguration.ClusterConfiguration)
- org.springframework.data.redis.connection.RedisClusterNode.SlotRange
- org.springframework.data.redis.support.collections.RedisCollectionFactoryBean (implements org.springframework.beans.factory.BeanNameAware, org.springframework.beans.factory.FactoryBean<T>, org.springframework.beans.factory.InitializingBean)
- org.springframework.data.redis.core.RedisConnectionUtils
- org.springframework.data.redis.core.convert.RedisData
- org.springframework.data.redis.connection.RedisGeoCommands.GeoSearchCommandArgs (implements java.lang.Cloneable, org.springframework.data.redis.connection.RedisGeoCommands.GeoCommandArgs)
- org.springframework.data.redis.connection.RedisGeoCommands.GeoSearchStoreCommandArgs (implements java.lang.Cloneable, org.springframework.data.redis.connection.RedisGeoCommands.GeoCommandArgs)
- org.springframework.data.redis.core.index.RedisIndexDefinition (implements org.springframework.data.redis.core.index.IndexDefinition)
- org.springframework.data.redis.core.index.RedisIndexDefinition.CompositeValueTransformer (implements org.springframework.data.redis.core.index.IndexValueTransformer)
- org.springframework.data.redis.core.index.RedisIndexDefinition.OrCondition<T> (implements org.springframework.data.redis.core.index.IndexDefinition.Condition<T>)
- org.springframework.data.redis.core.index.RedisIndexDefinition.PathCondition (implements org.springframework.data.redis.core.index.IndexDefinition.Condition<T>)
- org.springframework.data.redis.core.RedisKeyValueTemplate.RedisKeyValueCallback<T> (implements org.springframework.data.keyvalue.core.KeyValueCallback<T>)
- org.springframework.data.redis.listener.RedisMessageListenerContainer (implements org.springframework.beans.factory.BeanNameAware, org.springframework.beans.factory.DisposableBean, org.springframework.beans.factory.InitializingBean, org.springframework.context.SmartLifecycle)
- org.springframework.data.redis.connection.RedisNode (implements org.springframework.data.redis.connection.NamedNode)
- org.springframework.data.redis.connection.RedisNode.RedisNodeBuilder
- org.springframework.data.redis.repository.query.RedisOperationChain
- org.springframework.data.redis.repository.query.RedisOperationChain.PathAndValue
- org.springframework.data.redis.connection.RedisPassword
- org.springframework.data.redis.connection.RedisSentinelConfiguration (implements org.springframework.data.redis.connection.RedisConfiguration, org.springframework.data.redis.connection.RedisConfiguration.SentinelConfiguration)
- org.springframework.data.redis.connection.RedisSocketConfiguration (implements org.springframework.data.redis.connection.RedisConfiguration, org.springframework.data.redis.connection.RedisConfiguration.DomainSocketConfiguration)
- org.springframework.data.redis.connection.RedisStandaloneConfiguration (implements org.springframework.data.redis.connection.RedisConfiguration, org.springframework.data.redis.connection.RedisConfiguration.WithDatabaseIndex, org.springframework.data.redis.connection.RedisConfiguration.WithHostAndPort, org.springframework.data.redis.connection.RedisConfiguration.WithPassword)
- org.springframework.data.redis.connection.RedisStaticMasterReplicaConfiguration (implements org.springframework.data.redis.connection.RedisConfiguration, org.springframework.data.redis.connection.RedisConfiguration.StaticMasterReplicaConfiguration)
- org.springframework.data.redis.connection.RedisStreamCommands.XAddOptions
- org.springframework.data.redis.connection.RedisStreamCommands.XClaimOptions
- org.springframework.data.redis.connection.RedisStreamCommands.XClaimOptions.XClaimOptionsBuilder
- org.springframework.data.redis.connection.RedisStreamCommands.XPendingOptions
- org.springframework.data.redis.connection.RedisZSetCommands.Limit
- org.springframework.data.redis.connection.RedisZSetCommands.Range
- org.springframework.data.redis.connection.RedisZSetCommands.Range.Boundary
- org.springframework.data.redis.connection.RedisZSetCommands.Weights
- org.springframework.data.redis.connection.RedisZSetCommands.ZAddArgs
- org.springframework.data.redis.core.convert.ReferenceResolverImpl (implements org.springframework.data.redis.core.convert.ReferenceResolver)
- org.springframework.data.redis.core.convert.RemoveIndexedData (implements org.springframework.data.redis.core.convert.IndexedData)
- org.springframework.data.repository.config.RepositoryBeanDefinitionRegistrarSupport (implements org.springframework.context.EnvironmentAware, org.springframework.context.annotation.ImportBeanDefinitionRegistrar, org.springframework.context.ResourceLoaderAware)
- org.springframework.data.repository.config.RepositoryConfigurationExtensionSupport (implements org.springframework.data.repository.config.RepositoryConfigurationExtension)
- org.springframework.data.keyvalue.repository.config.KeyValueRepositoryConfigurationExtension
- org.springframework.data.repository.core.support.RepositoryFactoryBeanSupport<T,S,ID> (implements org.springframework.context.ApplicationEventPublisherAware, org.springframework.beans.factory.BeanClassLoaderAware, org.springframework.beans.factory.BeanFactoryAware, org.springframework.beans.factory.FactoryBean<T>, org.springframework.beans.factory.InitializingBean, org.springframework.data.repository.core.support.RepositoryFactoryInformation<T,ID>)
- org.springframework.data.keyvalue.repository.support.KeyValueRepositoryFactoryBean<T,S,ID>
- org.springframework.data.repository.core.support.RepositoryFactorySupport (implements org.springframework.beans.factory.BeanClassLoaderAware, org.springframework.beans.factory.BeanFactoryAware)
- org.springframework.data.keyvalue.repository.support.KeyValueRepositoryFactory
- org.springframework.data.redis.core.ScanCursor<T> (implements org.springframework.data.redis.core.Cursor<T>)
- org.springframework.data.redis.core.ScanIteration<T> (implements java.lang.Iterable<T>)
- org.springframework.data.redis.core.ScanOptions
- org.springframework.data.redis.core.ScanOptions.ScanOptionsBuilder
- org.springframework.data.redis.serializer.SerializationUtils
- org.springframework.data.redis.connection.convert.SetConverter<S,T> (implements org.springframework.core.convert.converter.Converter<S,T>)
- org.springframework.data.redis.core.convert.SimpleIndexedPropertyValue (implements org.springframework.data.redis.core.convert.IndexedData)
- org.springframework.data.redis.connection.SortParameters.Range
- org.springframework.data.redis.core.query.SortQueryBuilder<K>
- org.springframework.data.redis.core.convert.SpelIndexResolver (implements org.springframework.data.redis.core.convert.IndexResolver)
- org.springframework.data.redis.connection.stream.StreamInfo
- org.springframework.data.redis.connection.stream.StreamInfo.XInfoConsumers
- org.springframework.data.redis.connection.stream.StreamInfo.XInfoGroups
- org.springframework.data.redis.connection.stream.StreamInfo.XInfoObject
- org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamMessageListenerContainerOptions<K,V>
- org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamMessageListenerContainerOptionsBuilder<K,V>
- org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamReadRequest<K>
- org.springframework.data.redis.stream.StreamMessageListenerContainer.StreamReadRequestBuilder<K>
- org.springframework.data.redis.connection.stream.StreamOffset<K>
- org.springframework.data.redis.connection.stream.StreamReadOptions
- org.springframework.data.redis.stream.StreamReceiver.StreamReceiverOptions<K,V>
- org.springframework.data.redis.stream.StreamReceiver.StreamReceiverOptionsBuilder<K,V>
- org.springframework.data.redis.connection.stream.StreamRecords
- org.springframework.data.redis.connection.stream.StreamRecords.RecordBuilder<S>
- org.springframework.data.redis.serializer.StringRedisSerializer (implements org.springframework.data.redis.serializer.RedisSerializer<T>)
- org.springframework.data.redis.connection.convert.StringToDataTypeConverter (implements org.springframework.core.convert.converter.Converter<S,T>)
- org.springframework.data.redis.connection.convert.StringToPropertiesConverter (implements org.springframework.core.convert.converter.Converter<S,T>)
- org.springframework.data.redis.connection.convert.StringToRedisClientInfoConverter (implements org.springframework.core.convert.converter.Converter<S,T>)
- java.lang.Throwable (implements java.io.Serializable)
- org.springframework.data.redis.core.TimeoutUtils
- org.springframework.data.redis.connection.convert.TransactionResultConverter<T> (implements org.springframework.core.convert.converter.Converter<S,T>)
- org.springframework.data.redis.Version (implements java.lang.Comparable<T>)
- org.springframework.data.redis.VersionParser
Interface Hierarchy
- java.lang.AutoCloseable
- org.springframework.data.redis.cache.BatchStrategy
- org.springframework.data.redis.connection.BitFieldSubCommands.BitFieldSubCommand
- org.springframework.data.redis.core.BoundKeyOperations<K>
- org.springframework.data.redis.core.BoundGeoOperations<K,M>
- org.springframework.data.redis.core.BoundHashOperations<H,HK,HV>
- org.springframework.data.redis.core.BoundListOperations<K,V>
- org.springframework.data.redis.core.BoundSetOperations<K,V>
- org.springframework.data.redis.core.BoundValueOperations<K,V>
- org.springframework.data.redis.core.BoundZSetOperations<K,V>
- org.springframework.data.redis.support.collections.RedisCollection<E>
- org.springframework.data.redis.support.collections.RedisList<E> (also extends java.util.concurrent.BlockingDeque<E>, java.util.List<E>)
- org.springframework.data.redis.support.collections.RedisSet<E> (also extends java.util.Set<E>)
- org.springframework.data.redis.support.collections.RedisZSet<E> (also extends java.util.Set<E>)
- org.springframework.data.redis.support.collections.RedisList<E> (also extends java.util.concurrent.BlockingDeque<E>, java.util.List<E>, org.springframework.data.redis.support.collections.RedisCollection<E>)
- org.springframework.data.redis.support.collections.RedisMap<K,V> (also extends java.util.concurrent.ConcurrentMap<K,V>, org.springframework.data.redis.support.collections.RedisStore)
- org.springframework.data.redis.support.collections.RedisSet<E> (also extends org.springframework.data.redis.support.collections.RedisCollection<E>, java.util.Set<E>)
- org.springframework.data.redis.support.collections.RedisStore
- org.springframework.data.redis.support.collections.RedisCollection<E>
- org.springframework.data.redis.support.collections.RedisList<E> (also extends java.util.concurrent.BlockingDeque<E>, java.util.List<E>)
- org.springframework.data.redis.support.collections.RedisSet<E> (also extends java.util.Set<E>)
- org.springframework.data.redis.support.collections.RedisZSet<E> (also extends java.util.Set<E>)
- org.springframework.data.redis.support.collections.RedisList<E> (also extends java.util.concurrent.BlockingDeque<E>, java.util.List<E>, org.springframework.data.redis.support.collections.RedisCollection<E>)
- org.springframework.data.redis.support.collections.RedisMap<K,V> (also extends java.util.concurrent.ConcurrentMap<K,V>)
- org.springframework.data.redis.support.collections.RedisSet<E> (also extends org.springframework.data.redis.support.collections.RedisCollection<E>, java.util.Set<E>)
- org.springframework.data.redis.support.collections.RedisZSet<E> (also extends org.springframework.data.redis.support.collections.RedisCollection<E>, java.util.Set<E>)
- org.springframework.data.redis.support.collections.RedisZSet<E> (also extends org.springframework.data.redis.support.collections.RedisCollection<E>, java.util.Set<E>)
- org.springframework.data.redis.core.BoundStreamOperations<K,HK,HV>
- org.springframework.data.redis.core.BulkMapper<T,V>
- org.springframework.data.redis.cache.CacheKeyPrefix
- org.springframework.data.redis.cache.CacheStatistics
- org.springframework.data.redis.cache.CacheStatisticsProvider
- org.springframework.data.redis.stream.Cancelable
- org.springframework.data.redis.connection.ClusterCommandExecutor.ClusterCommandCallback<T,S>
- org.springframework.data.redis.connection.ClusterCommandExecutor.MultiKeyClusterCommandCallback<T,S>
- org.springframework.data.redis.connection.ClusterNodeResourceProvider
- org.springframework.data.redis.core.ClusterOperations<K,V>
- org.springframework.data.redis.connection.ClusterTopologyProvider
- java.lang.Comparable<T>
- org.springframework.core.convert.converter.Converter<S,T>
- org.springframework.data.redis.connection.DecoratedRedisConnection
- org.springframework.data.repository.core.EntityMetadata<T>
- org.springframework.data.convert.EntityReader<T,S>
- org.springframework.data.convert.EntityWriter<T,S>
- org.springframework.data.redis.ExceptionTranslationStrategy
- org.springframework.data.redis.core.GeoOperations<K,M>
- org.springframework.data.redis.domain.geo.GeoReference<T>
- org.springframework.data.redis.hash.HashMapper<T,K,V>
- org.springframework.data.redis.core.HashMapperProvider<HK,HV>
- org.springframework.data.redis.core.HashOperations<H,HK,HV>
- org.springframework.data.redis.core.HyperLogLogOperations<K,V>
- org.springframework.data.redis.core.index.IndexDefinition
- org.springframework.data.redis.core.index.IndexDefinition.Condition<T>
- org.springframework.data.redis.core.index.IndexDefinitionProvider
- org.springframework.data.redis.core.index.IndexDefinitionRegistry
- org.springframework.data.redis.core.convert.IndexedData
- org.springframework.data.redis.core.convert.IndexResolver
- java.lang.Iterable<T>
- java.util.concurrent.BlockingDeque<E> (also extends java.util.concurrent.BlockingQueue<E>, java.util.Deque<E>)
- org.springframework.data.redis.support.collections.RedisList<E> (also extends java.util.List<E>, org.springframework.data.redis.support.collections.RedisCollection<E>)
- java.util.concurrent.BlockingQueue<E>
- java.util.concurrent.BlockingDeque<E> (also extends java.util.Deque<E>)
- org.springframework.data.redis.support.collections.RedisList<E> (also extends java.util.List<E>, org.springframework.data.redis.support.collections.RedisCollection<E>)
- org.springframework.data.redis.support.collections.RedisList<E> (also extends java.util.concurrent.BlockingDeque<E>, java.util.List<E>, org.springframework.data.redis.support.collections.RedisCollection<E>)
- org.springframework.data.redis.connection.stream.ByteBufferRecord
- org.springframework.data.redis.connection.stream.ByteRecord
- java.util.Collection<E>
- java.util.concurrent.BlockingDeque<E> (also extends java.util.concurrent.BlockingQueue<E>, java.util.Deque<E>)
- org.springframework.data.redis.support.collections.RedisList<E> (also extends java.util.List<E>, org.springframework.data.redis.support.collections.RedisCollection<E>)
- java.util.concurrent.BlockingQueue<E>
- java.util.concurrent.BlockingDeque<E> (also extends java.util.Deque<E>)
- org.springframework.data.redis.support.collections.RedisList<E> (also extends java.util.List<E>, org.springframework.data.redis.support.collections.RedisCollection<E>)
- org.springframework.data.redis.support.collections.RedisList<E> (also extends java.util.concurrent.BlockingDeque<E>, java.util.List<E>, org.springframework.data.redis.support.collections.RedisCollection<E>)
- java.util.Deque<E>
- java.util.List<E>
- org.springframework.data.redis.support.collections.RedisList<E> (also extends java.util.concurrent.BlockingDeque<E>, org.springframework.data.redis.support.collections.RedisCollection<E>)
- java.util.Queue<E>
- org.springframework.data.redis.support.collections.RedisList<E> (also extends java.util.concurrent.BlockingDeque<E>, java.util.List<E>, org.springframework.data.redis.support.collections.RedisCollection<E>)
- org.springframework.data.redis.support.collections.RedisSet<E> (also extends org.springframework.data.redis.support.collections.RedisCollection<E>, java.util.Set<E>)
- org.springframework.data.redis.support.collections.RedisZSet<E> (also extends org.springframework.data.redis.support.collections.RedisCollection<E>, java.util.Set<E>)
- java.util.Set<E>
- org.springframework.data.redis.support.collections.RedisSet<E> (also extends org.springframework.data.redis.support.collections.RedisCollection<E>)
- org.springframework.data.redis.support.collections.RedisZSet<E> (also extends org.springframework.data.redis.support.collections.RedisCollection<E>)
- java.util.Deque<E>
- org.springframework.data.keyvalue.core.mapping.KeyValuePersistentEntity<T,P>
- java.util.List<E>
- org.springframework.data.redis.support.collections.RedisList<E> (also extends java.util.concurrent.BlockingDeque<E>, org.springframework.data.redis.support.collections.RedisCollection<E>)
- org.springframework.data.redis.connection.stream.MapRecord<S,K,V> (also extends org.springframework.data.redis.connection.stream.Record<S,V>)
- org.springframework.data.mapping.model.MutablePersistentEntity<T,P>
- org.springframework.data.keyvalue.core.mapping.KeyValuePersistentEntity<T,P>
- org.springframework.data.redis.core.mapping.RedisPersistentEntity<T>
- org.springframework.data.mapping.PersistentEntity<T,P>
- org.springframework.data.keyvalue.core.mapping.KeyValuePersistentEntity<T,P>
- org.springframework.data.mapping.model.MutablePersistentEntity<T,P>
- org.springframework.data.keyvalue.core.mapping.KeyValuePersistentEntity<T,P>
- org.springframework.data.redis.core.mapping.RedisPersistentEntity<T>
- org.springframework.data.redis.core.mapping.RedisPersistentEntity<T>
- java.util.Queue<E>
- org.springframework.data.redis.support.collections.RedisList<E> (also extends java.util.concurrent.BlockingDeque<E>, java.util.List<E>, org.springframework.data.redis.support.collections.RedisCollection<E>)
- org.springframework.data.redis.core.mapping.RedisPersistentEntity<T>
- org.springframework.data.redis.support.collections.RedisSet<E> (also extends org.springframework.data.redis.support.collections.RedisCollection<E>, java.util.Set<E>)
- org.springframework.data.redis.support.collections.RedisZSet<E> (also extends org.springframework.data.redis.support.collections.RedisCollection<E>, java.util.Set<E>)
- java.util.Set<E>
- org.springframework.data.redis.support.collections.RedisSet<E> (also extends org.springframework.data.redis.support.collections.RedisCollection<E>)
- org.springframework.data.redis.support.collections.RedisZSet<E> (also extends org.springframework.data.redis.support.collections.RedisCollection<E>)
- org.springframework.data.redis.connection.stream.StringRecord
- java.util.Iterator<E>
- org.springframework.data.redis.connection.jedis.JedisClientConfiguration
- org.springframework.data.redis.connection.jedis.JedisClientConfiguration.JedisClientConfigurationBuilder
- org.springframework.data.redis.connection.jedis.JedisClientConfiguration.JedisPoolingClientConfigurationBuilder
- org.springframework.data.redis.connection.jedis.JedisClientConfiguration.JedisSslClientConfigurationBuilder
- org.springframework.data.redis.connection.lettuce.LettuceClientConfiguration
- org.springframework.data.redis.connection.lettuce.LettuceConnection.PipeliningFlushPolicy
- org.springframework.data.redis.connection.lettuce.LettuceConnection.PipeliningFlushState
- org.springframework.data.redis.connection.lettuce.LettuceConnectionProvider
- org.springframework.data.redis.connection.lettuce.LettuceConnectionProvider.TargetAware
- org.springframework.context.Lifecycle
- org.springframework.data.redis.core.ListOperations<K,V>
- java.util.Map<K,V>
- java.util.concurrent.ConcurrentMap<K,V>
- org.springframework.data.redis.support.collections.RedisMap<K,V> (also extends org.springframework.data.redis.support.collections.RedisStore)
- org.springframework.data.redis.support.collections.RedisMap<K,V> (also extends java.util.concurrent.ConcurrentMap<K,V>, org.springframework.data.redis.support.collections.RedisStore)
- org.springframework.data.redis.connection.MessageListener
- org.springframework.data.redis.connection.NamedNode
- org.springframework.dao.support.PersistenceExceptionTranslator
- org.springframework.context.Phased
- org.springframework.data.redis.connection.Pool<T>
- org.springframework.data.redis.connection.lettuce.LettucePool
- org.springframework.aop.RawTargetAccess
- org.springframework.data.redis.connection.ReactiveClusterCommands
- org.springframework.data.redis.connection.ReactiveGeoCommands
- org.springframework.data.redis.core.ReactiveGeoOperations<K,M>
- org.springframework.data.redis.connection.ReactiveHashCommands
- org.springframework.data.redis.core.ReactiveHashOperations<H,HK,HV>
- org.springframework.data.redis.connection.ReactiveHyperLogLogCommands
- org.springframework.data.redis.core.ReactiveHyperLogLogOperations<K,V>
- org.springframework.data.redis.connection.ReactiveKeyCommands
- org.springframework.data.redis.connection.ReactiveListCommands
- org.springframework.data.redis.core.ReactiveListOperations<K,V>
- org.springframework.data.redis.connection.ReactiveNumberCommands
- org.springframework.data.redis.connection.ReactivePubSubCommands
- org.springframework.data.redis.core.ReactiveRedisCallback<T>
- org.springframework.data.redis.connection.ReactiveRedisConnection.Command
- org.springframework.data.redis.core.ReactiveRedisOperations<K,V>
- org.springframework.data.redis.core.script.ReactiveScriptExecutor<K>
- org.springframework.data.redis.connection.ReactiveScriptingCommands
- org.springframework.data.redis.connection.ReactiveServerCommands
- org.springframework.data.redis.connection.ReactiveSetCommands
- org.springframework.data.redis.core.ReactiveSetOperations<K,V>
- org.springframework.data.redis.connection.ReactiveStreamCommands
- org.springframework.data.redis.connection.ReactiveStringCommands
- org.springframework.data.redis.connection.ReactiveSubscription
- org.springframework.data.redis.connection.ReactiveSubscription.Message<C,M>
- org.springframework.data.redis.core.ReactiveValueOperations<K,V>
- org.springframework.data.redis.connection.ReactiveZSetCommands
- org.springframework.data.redis.core.ReactiveZSetOperations<K,V>
- org.springframework.data.redis.connection.stream.Record<S,V>
- org.springframework.data.redis.connection.stream.ByteBufferRecord
- org.springframework.data.redis.connection.stream.ByteRecord
- org.springframework.data.redis.connection.stream.MapRecord<S,K,V> (also extends java.lang.Iterable<T>)
- org.springframework.data.redis.connection.stream.ObjectRecord<S,V>
- org.springframework.data.redis.connection.stream.StringRecord
- org.springframework.data.redis.core.RedisCallback<T>
- org.springframework.data.redis.core.RedisClusterCallback<T>
- org.springframework.data.redis.connection.RedisClusterCommands
- org.springframework.data.redis.connection.RedisConfiguration
- org.springframework.data.redis.connection.RedisConfiguration.WithAuthentication
- org.springframework.data.redis.connection.RedisConfiguration.WithDatabaseIndex
- org.springframework.data.redis.connection.RedisConfiguration.WithDomainSocket
- org.springframework.data.redis.connection.RedisConfiguration.WithHostAndPort
- org.springframework.data.redis.connection.RedisConnectionCommands
- org.springframework.data.redis.connection.DefaultedRedisClusterConnection (also extends org.springframework.data.redis.connection.DefaultedRedisConnection, org.springframework.data.redis.connection.RedisClusterConnection)
- org.springframework.data.redis.connection.DefaultedRedisConnection
- org.springframework.data.redis.connection.RedisClusterConnection (also extends org.springframework.data.redis.connection.RedisClusterCommands, org.springframework.data.redis.connection.RedisClusterServerCommands, org.springframework.data.redis.connection.RedisConnection)
- org.springframework.data.redis.connection.RedisCommands (also extends org.springframework.data.redis.connection.RedisGeoCommands, org.springframework.data.redis.connection.RedisHashCommands, org.springframework.data.redis.connection.RedisHyperLogLogCommands, org.springframework.data.redis.connection.RedisKeyCommands, org.springframework.data.redis.connection.RedisListCommands, org.springframework.data.redis.connection.RedisPubSubCommands, org.springframework.data.redis.connection.RedisScriptingCommands, org.springframework.data.redis.connection.RedisServerCommands, org.springframework.data.redis.connection.RedisSetCommands, org.springframework.data.redis.connection.RedisStreamCommands, org.springframework.data.redis.connection.RedisStringCommands, org.springframework.data.redis.connection.RedisTxCommands, org.springframework.data.redis.connection.RedisZSetCommands)
- org.springframework.data.redis.connection.RedisConnection (also extends java.lang.AutoCloseable, org.springframework.data.redis.connection.RedisCommands)
- org.springframework.data.redis.core.RedisConnectionUtils.RedisConnectionProxy (also extends org.springframework.aop.RawTargetAccess, org.springframework.data.redis.connection.RedisConnection)
- org.springframework.data.redis.connection.StringRedisConnection
- org.springframework.data.redis.serializer.RedisElementReader<T>
- org.springframework.data.redis.serializer.RedisElementWriter<T>
- org.springframework.data.redis.connection.RedisGeoCommands
- org.springframework.data.redis.connection.DefaultedRedisClusterConnection (also extends org.springframework.data.redis.connection.DefaultedRedisConnection, org.springframework.data.redis.connection.RedisClusterConnection)
- org.springframework.data.redis.connection.DefaultedRedisConnection
- org.springframework.data.redis.connection.RedisClusterConnection (also extends org.springframework.data.redis.connection.RedisClusterCommands, org.springframework.data.redis.connection.RedisClusterServerCommands, org.springframework.data.redis.connection.RedisConnection)
- org.springframework.data.redis.connection.RedisCommands (also extends org.springframework.data.redis.connection.RedisConnectionCommands, org.springframework.data.redis.connection.RedisHashCommands, org.springframework.data.redis.connection.RedisHyperLogLogCommands, org.springframework.data.redis.connection.RedisKeyCommands, org.springframework.data.redis.connection.RedisListCommands, org.springframework.data.redis.connection.RedisPubSubCommands, org.springframework.data.redis.connection.RedisScriptingCommands, org.springframework.data.redis.connection.RedisServerCommands, org.springframework.data.redis.connection.RedisSetCommands, org.springframework.data.redis.connection.RedisStreamCommands, org.springframework.data.redis.connection.RedisStringCommands, org.springframework.data.redis.connection.RedisTxCommands, org.springframework.data.redis.connection.RedisZSetCommands)
- org.springframework.data.redis.connection.RedisConnection (also extends java.lang.AutoCloseable, org.springframework.data.redis.connection.RedisCommands)
- org.springframework.data.redis.core.RedisConnectionUtils.RedisConnectionProxy (also extends org.springframework.aop.RawTargetAccess, org.springframework.data.redis.connection.RedisConnection)
- org.springframework.data.redis.connection.StringRedisConnection
- org.springframework.data.redis.connection.RedisGeoCommands.GeoCommandArgs
- org.springframework.data.redis.connection.RedisGeoCommands.GeoCommandArgs.GeoCommandFlag
- org.springframework.data.redis.connection.RedisHashCommands
- org.springframework.data.redis.connection.DefaultedRedisClusterConnection (also extends org.springframework.data.redis.connection.DefaultedRedisConnection, org.springframework.data.redis.connection.RedisClusterConnection)
- org.springframework.data.redis.connection.DefaultedRedisConnection
- org.springframework.data.redis.connection.RedisClusterConnection (also extends org.springframework.data.redis.connection.RedisClusterCommands, org.springframework.data.redis.connection.RedisClusterServerCommands, org.springframework.data.redis.connection.RedisConnection)
- org.springframework.data.redis.connection.RedisCommands (also extends org.springframework.data.redis.connection.RedisConnectionCommands, org.springframework.data.redis.connection.RedisGeoCommands, org.springframework.data.redis.connection.RedisHyperLogLogCommands, org.springframework.data.redis.connection.RedisKeyCommands, org.springframework.data.redis.connection.RedisListCommands, org.springframework.data.redis.connection.RedisPubSubCommands, org.springframework.data.redis.connection.RedisScriptingCommands, org.springframework.data.redis.connection.RedisServerCommands, org.springframework.data.redis.connection.RedisSetCommands, org.springframework.data.redis.connection.RedisStreamCommands, org.springframework.data.redis.connection.RedisStringCommands, org.springframework.data.redis.connection.RedisTxCommands, org.springframework.data.redis.connection.RedisZSetCommands)
- org.springframework.data.redis.connection.RedisConnection (also extends java.lang.AutoCloseable, org.springframework.data.redis.connection.RedisCommands)
- org.springframework.data.redis.core.RedisConnectionUtils.RedisConnectionProxy (also extends org.springframework.aop.RawTargetAccess, org.springframework.data.redis.connection.RedisConnection)
- org.springframework.data.redis.connection.StringRedisConnection
- org.springframework.data.redis.connection.RedisHyperLogLogCommands
- org.springframework.data.redis.connection.DefaultedRedisClusterConnection (also extends org.springframework.data.redis.connection.DefaultedRedisConnection, org.springframework.data.redis.connection.RedisClusterConnection)
- org.springframework.data.redis.connection.DefaultedRedisConnection
- org.springframework.data.redis.connection.RedisClusterConnection (also extends org.springframework.data.redis.connection.RedisClusterCommands, org.springframework.data.redis.connection.RedisClusterServerCommands, org.springframework.data.redis.connection.RedisConnection)
- org.springframework.data.redis.connection.RedisCommands (also extends org.springframework.data.redis.connection.RedisConnectionCommands, org.springframework.data.redis.connection.RedisGeoCommands, org.springframework.data.redis.connection.RedisHashCommands, org.springframework.data.redis.connection.RedisKeyCommands, org.springframework.data.redis.connection.RedisListCommands, org.springframework.data.redis.connection.RedisPubSubCommands, org.springframework.data.redis.connection.RedisScriptingCommands, org.springframework.data.redis.connection.RedisServerCommands, org.springframework.data.redis.connection.RedisSetCommands, org.springframework.data.redis.connection.RedisStreamCommands, org.springframework.data.redis.connection.RedisStringCommands, org.springframework.data.redis.connection.RedisTxCommands, org.springframework.data.redis.connection.RedisZSetCommands)
- org.springframework.data.redis.connection.RedisConnection (also extends java.lang.AutoCloseable, org.springframework.data.redis.connection.RedisCommands)
- org.springframework.data.redis.core.RedisConnectionUtils.RedisConnectionProxy (also extends org.springframework.aop.RawTargetAccess, org.springframework.data.redis.connection.RedisConnection)
- org.springframework.data.redis.connection.StringRedisConnection
- org.springframework.data.redis.connection.RedisKeyCommands
- org.springframework.data.redis.connection.DefaultedRedisClusterConnection (also extends org.springframework.data.redis.connection.DefaultedRedisConnection, org.springframework.data.redis.connection.RedisClusterConnection)
- org.springframework.data.redis.connection.DefaultedRedisConnection
- org.springframework.data.redis.connection.RedisClusterConnection (also extends org.springframework.data.redis.connection.RedisClusterCommands, org.springframework.data.redis.connection.RedisClusterServerCommands, org.springframework.data.redis.connection.RedisConnection)
- org.springframework.data.redis.connection.RedisCommands (also extends org.springframework.data.redis.connection.RedisConnectionCommands, org.springframework.data.redis.connection.RedisGeoCommands, org.springframework.data.redis.connection.RedisHashCommands, org.springframework.data.redis.connection.RedisHyperLogLogCommands, org.springframework.data.redis.connection.RedisListCommands, org.springframework.data.redis.connection.RedisPubSubCommands, org.springframework.data.redis.connection.RedisScriptingCommands, org.springframework.data.redis.connection.RedisServerCommands, org.springframework.data.redis.connection.RedisSetCommands, org.springframework.data.redis.connection.RedisStreamCommands, org.springframework.data.redis.connection.RedisStringCommands, org.springframework.data.redis.connection.RedisTxCommands, org.springframework.data.redis.connection.RedisZSetCommands)
- org.springframework.data.redis.connection.RedisConnection (also extends java.lang.AutoCloseable, org.springframework.data.redis.connection.RedisCommands)
- org.springframework.data.redis.core.RedisConnectionUtils.RedisConnectionProxy (also extends org.springframework.aop.RawTargetAccess, org.springframework.data.redis.connection.RedisConnection)
- org.springframework.data.redis.connection.StringRedisConnection
- org.springframework.data.redis.connection.RedisListCommands
- org.springframework.data.redis.connection.DefaultedRedisClusterConnection (also extends org.springframework.data.redis.connection.DefaultedRedisConnection, org.springframework.data.redis.connection.RedisClusterConnection)
- org.springframework.data.redis.connection.DefaultedRedisConnection
- org.springframework.data.redis.connection.RedisClusterConnection (also extends org.springframework.data.redis.connection.RedisClusterCommands, org.springframework.data.redis.connection.RedisClusterServerCommands, org.springframework.data.redis.connection.RedisConnection)
- org.springframework.data.redis.connection.RedisCommands (also extends org.springframework.data.redis.connection.RedisConnectionCommands, org.springframework.data.redis.connection.RedisGeoCommands, org.springframework.data.redis.connection.RedisHashCommands, org.springframework.data.redis.connection.RedisHyperLogLogCommands, org.springframework.data.redis.connection.RedisKeyCommands, org.springframework.data.redis.connection.RedisPubSubCommands, org.springframework.data.redis.connection.RedisScriptingCommands, org.springframework.data.redis.connection.RedisServerCommands, org.springframework.data.redis.connection.RedisSetCommands, org.springframework.data.redis.connection.RedisStreamCommands, org.springframework.data.redis.connection.RedisStringCommands, org.springframework.data.redis.connection.RedisTxCommands, org.springframework.data.redis.connection.RedisZSetCommands)
- org.springframework.data.redis.connection.RedisConnection (also extends java.lang.AutoCloseable, org.springframework.data.redis.connection.RedisCommands)
- org.springframework.data.redis.core.RedisConnectionUtils.RedisConnectionProxy (also extends org.springframework.aop.RawTargetAccess, org.springframework.data.redis.connection.RedisConnection)
- org.springframework.data.redis.connection.StringRedisConnection
- org.springframework.data.redis.core.RedisOperations<K,V>
- org.springframework.data.redis.connection.RedisPubSubCommands
- org.springframework.data.redis.connection.DefaultedRedisClusterConnection (also extends org.springframework.data.redis.connection.DefaultedRedisConnection, org.springframework.data.redis.connection.RedisClusterConnection)
- org.springframework.data.redis.connection.DefaultedRedisConnection
- org.springframework.data.redis.connection.RedisClusterConnection (also extends org.springframework.data.redis.connection.RedisClusterCommands, org.springframework.data.redis.connection.RedisClusterServerCommands, org.springframework.data.redis.connection.RedisConnection)
- org.springframework.data.redis.connection.RedisCommands (also extends org.springframework.data.redis.connection.RedisConnectionCommands, org.springframework.data.redis.connection.RedisGeoCommands, org.springframework.data.redis.connection.RedisHashCommands, org.springframework.data.redis.connection.RedisHyperLogLogCommands, org.springframework.data.redis.connection.RedisKeyCommands, org.springframework.data.redis.connection.RedisListCommands, org.springframework.data.redis.connection.RedisScriptingCommands, org.springframework.data.redis.connection.RedisServerCommands, org.springframework.data.redis.connection.RedisSetCommands, org.springframework.data.redis.connection.RedisStreamCommands, org.springframework.data.redis.connection.RedisStringCommands, org.springframework.data.redis.connection.RedisTxCommands, org.springframework.data.redis.connection.RedisZSetCommands)
- org.springframework.data.redis.connection.RedisConnection (also extends java.lang.AutoCloseable, org.springframework.data.redis.connection.RedisCommands)
- org.springframework.data.redis.core.RedisConnectionUtils.RedisConnectionProxy (also extends org.springframework.aop.RawTargetAccess, org.springframework.data.redis.connection.RedisConnection)
- org.springframework.data.redis.connection.StringRedisConnection
- org.springframework.data.redis.core.script.RedisScript<T>
- org.springframework.data.redis.connection.RedisScriptingCommands
- org.springframework.data.redis.connection.DefaultedRedisClusterConnection (also extends org.springframework.data.redis.connection.DefaultedRedisConnection, org.springframework.data.redis.connection.RedisClusterConnection)
- org.springframework.data.redis.connection.DefaultedRedisConnection
- org.springframework.data.redis.connection.RedisClusterConnection (also extends org.springframework.data.redis.connection.RedisClusterCommands, org.springframework.data.redis.connection.RedisClusterServerCommands, org.springframework.data.redis.connection.RedisConnection)
- org.springframework.data.redis.connection.RedisCommands (also extends org.springframework.data.redis.connection.RedisConnectionCommands, org.springframework.data.redis.connection.RedisGeoCommands, org.springframework.data.redis.connection.RedisHashCommands, org.springframework.data.redis.connection.RedisHyperLogLogCommands, org.springframework.data.redis.connection.RedisKeyCommands, org.springframework.data.redis.connection.RedisListCommands, org.springframework.data.redis.connection.RedisPubSubCommands, org.springframework.data.redis.connection.RedisServerCommands, org.springframework.data.redis.connection.RedisSetCommands, org.springframework.data.redis.connection.RedisStreamCommands, org.springframework.data.redis.connection.RedisStringCommands, org.springframework.data.redis.connection.RedisTxCommands, org.springframework.data.redis.connection.RedisZSetCommands)
- org.springframework.data.redis.connection.RedisConnection (also extends java.lang.AutoCloseable, org.springframework.data.redis.connection.RedisCommands)
- org.springframework.data.redis.core.RedisConnectionUtils.RedisConnectionProxy (also extends org.springframework.aop.RawTargetAccess, org.springframework.data.redis.connection.RedisConnection)
- org.springframework.data.redis.connection.StringRedisConnection
- org.springframework.data.redis.connection.RedisSentinelCommands
- org.springframework.data.redis.serializer.RedisSerializationContext<K,V>
- org.springframework.data.redis.serializer.RedisSerializationContext.RedisSerializationContextBuilder<K,V>
- org.springframework.data.redis.serializer.RedisSerializationContext.SerializationPair<T>
- org.springframework.data.redis.serializer.RedisSerializer<T>
- org.springframework.data.redis.connection.RedisServerCommands
- org.springframework.data.redis.connection.DefaultedRedisClusterConnection (also extends org.springframework.data.redis.connection.DefaultedRedisConnection, org.springframework.data.redis.connection.RedisClusterConnection)
- org.springframework.data.redis.connection.DefaultedRedisConnection
- org.springframework.data.redis.connection.RedisClusterConnection (also extends org.springframework.data.redis.connection.RedisClusterCommands, org.springframework.data.redis.connection.RedisClusterServerCommands, org.springframework.data.redis.connection.RedisConnection)
- org.springframework.data.redis.connection.RedisClusterServerCommands
- org.springframework.data.redis.connection.RedisCommands (also extends org.springframework.data.redis.connection.RedisConnectionCommands, org.springframework.data.redis.connection.RedisGeoCommands, org.springframework.data.redis.connection.RedisHashCommands, org.springframework.data.redis.connection.RedisHyperLogLogCommands, org.springframework.data.redis.connection.RedisKeyCommands, org.springframework.data.redis.connection.RedisListCommands, org.springframework.data.redis.connection.RedisPubSubCommands, org.springframework.data.redis.connection.RedisScriptingCommands, org.springframework.data.redis.connection.RedisSetCommands, org.springframework.data.redis.connection.RedisStreamCommands, org.springframework.data.redis.connection.RedisStringCommands, org.springframework.data.redis.connection.RedisTxCommands, org.springframework.data.redis.connection.RedisZSetCommands)
- org.springframework.data.redis.connection.RedisConnection (also extends java.lang.AutoCloseable, org.springframework.data.redis.connection.RedisCommands)
- org.springframework.data.redis.core.RedisConnectionUtils.RedisConnectionProxy (also extends org.springframework.aop.RawTargetAccess, org.springframework.data.redis.connection.RedisConnection)
- org.springframework.data.redis.connection.StringRedisConnection
- org.springframework.data.redis.connection.RedisSetCommands
- org.springframework.data.redis.connection.DefaultedRedisClusterConnection (also extends org.springframework.data.redis.connection.DefaultedRedisConnection, org.springframework.data.redis.connection.RedisClusterConnection)
- org.springframework.data.redis.connection.DefaultedRedisConnection
- org.springframework.data.redis.connection.RedisClusterConnection (also extends org.springframework.data.redis.connection.RedisClusterCommands, org.springframework.data.redis.connection.RedisClusterServerCommands, org.springframework.data.redis.connection.RedisConnection)
- org.springframework.data.redis.connection.RedisCommands (also extends org.springframework.data.redis.connection.RedisConnectionCommands, org.springframework.data.redis.connection.RedisGeoCommands, org.springframework.data.redis.connection.RedisHashCommands, org.springframework.data.redis.connection.RedisHyperLogLogCommands, org.springframework.data.redis.connection.RedisKeyCommands, org.springframework.data.redis.connection.RedisListCommands, org.springframework.data.redis.connection.RedisPubSubCommands, org.springframework.data.redis.connection.RedisScriptingCommands, org.springframework.data.redis.connection.RedisServerCommands, org.springframework.data.redis.connection.RedisStreamCommands, org.springframework.data.redis.connection.RedisStringCommands, org.springframework.data.redis.connection.RedisTxCommands, org.springframework.data.redis.connection.RedisZSetCommands)
- org.springframework.data.redis.connection.RedisConnection (also extends java.lang.AutoCloseable, org.springframework.data.redis.connection.RedisCommands)
- org.springframework.data.redis.core.RedisConnectionUtils.RedisConnectionProxy (also extends org.springframework.aop.RawTargetAccess, org.springframework.data.redis.connection.RedisConnection)
- org.springframework.data.redis.connection.StringRedisConnection
- org.springframework.data.redis.connection.RedisStreamCommands
- org.springframework.data.redis.connection.DefaultedRedisClusterConnection (also extends org.springframework.data.redis.connection.DefaultedRedisConnection, org.springframework.data.redis.connection.RedisClusterConnection)
- org.springframework.data.redis.connection.DefaultedRedisConnection
- org.springframework.data.redis.connection.RedisClusterConnection (also extends org.springframework.data.redis.connection.RedisClusterCommands, org.springframework.data.redis.connection.RedisClusterServerCommands, org.springframework.data.redis.connection.RedisConnection)
- org.springframework.data.redis.connection.RedisCommands (also extends org.springframework.data.redis.connection.RedisConnectionCommands, org.springframework.data.redis.connection.RedisGeoCommands, org.springframework.data.redis.connection.RedisHashCommands, org.springframework.data.redis.connection.RedisHyperLogLogCommands, org.springframework.data.redis.connection.RedisKeyCommands, org.springframework.data.redis.connection.RedisListCommands, org.springframework.data.redis.connection.RedisPubSubCommands, org.springframework.data.redis.connection.RedisScriptingCommands, org.springframework.data.redis.connection.RedisServerCommands, org.springframework.data.redis.connection.RedisSetCommands, org.springframework.data.redis.connection.RedisStringCommands, org.springframework.data.redis.connection.RedisTxCommands, org.springframework.data.redis.connection.RedisZSetCommands)
- org.springframework.data.redis.connection.RedisConnection (also extends java.lang.AutoCloseable, org.springframework.data.redis.connection.RedisCommands)
- org.springframework.data.redis.core.RedisConnectionUtils.RedisConnectionProxy (also extends org.springframework.aop.RawTargetAccess, org.springframework.data.redis.connection.RedisConnection)
- org.springframework.data.redis.connection.StringRedisConnection
- org.springframework.data.redis.connection.RedisStringCommands
- org.springframework.data.redis.connection.DefaultedRedisClusterConnection (also extends org.springframework.data.redis.connection.DefaultedRedisConnection, org.springframework.data.redis.connection.RedisClusterConnection)
- org.springframework.data.redis.connection.DefaultedRedisConnection
- org.springframework.data.redis.connection.RedisClusterConnection (also extends org.springframework.data.redis.connection.RedisClusterCommands, org.springframework.data.redis.connection.RedisClusterServerCommands, org.springframework.data.redis.connection.RedisConnection)
- org.springframework.data.redis.connection.RedisCommands (also extends org.springframework.data.redis.connection.RedisConnectionCommands, org.springframework.data.redis.connection.RedisGeoCommands, org.springframework.data.redis.connection.RedisHashCommands, org.springframework.data.redis.connection.RedisHyperLogLogCommands, org.springframework.data.redis.connection.RedisKeyCommands, org.springframework.data.redis.connection.RedisListCommands, org.springframework.data.redis.connection.RedisPubSubCommands, org.springframework.data.redis.connection.RedisScriptingCommands, org.springframework.data.redis.connection.RedisServerCommands, org.springframework.data.redis.connection.RedisSetCommands, org.springframework.data.redis.connection.RedisStreamCommands, org.springframework.data.redis.connection.RedisTxCommands, org.springframework.data.redis.connection.RedisZSetCommands)
- org.springframework.data.redis.connection.RedisConnection (also extends java.lang.AutoCloseable, org.springframework.data.redis.connection.RedisCommands)
- org.springframework.data.redis.core.RedisConnectionUtils.RedisConnectionProxy (also extends org.springframework.aop.RawTargetAccess, org.springframework.data.redis.connection.RedisConnection)
- org.springframework.data.redis.connection.StringRedisConnection
- org.springframework.data.redis.connection.RedisTxCommands
- org.springframework.data.redis.connection.DefaultedRedisClusterConnection (also extends org.springframework.data.redis.connection.DefaultedRedisConnection, org.springframework.data.redis.connection.RedisClusterConnection)
- org.springframework.data.redis.connection.DefaultedRedisConnection
- org.springframework.data.redis.connection.RedisClusterConnection (also extends org.springframework.data.redis.connection.RedisClusterCommands, org.springframework.data.redis.connection.RedisClusterServerCommands, org.springframework.data.redis.connection.RedisConnection)
- org.springframework.data.redis.connection.RedisCommands (also extends org.springframework.data.redis.connection.RedisConnectionCommands, org.springframework.data.redis.connection.RedisGeoCommands, org.springframework.data.redis.connection.RedisHashCommands, org.springframework.data.redis.connection.RedisHyperLogLogCommands, org.springframework.data.redis.connection.RedisKeyCommands, org.springframework.data.redis.connection.RedisListCommands, org.springframework.data.redis.connection.RedisPubSubCommands, org.springframework.data.redis.connection.RedisScriptingCommands, org.springframework.data.redis.connection.RedisServerCommands, org.springframework.data.redis.connection.RedisSetCommands, org.springframework.data.redis.connection.RedisStreamCommands, org.springframework.data.redis.connection.RedisStringCommands, org.springframework.data.redis.connection.RedisZSetCommands)
- org.springframework.data.redis.connection.RedisConnection (also extends java.lang.AutoCloseable, org.springframework.data.redis.connection.RedisCommands)
- org.springframework.data.redis.core.RedisConnectionUtils.RedisConnectionProxy (also extends org.springframework.aop.RawTargetAccess, org.springframework.data.redis.connection.RedisConnection)
- org.springframework.data.redis.connection.StringRedisConnection
- org.springframework.data.redis.connection.RedisZSetCommands
- org.springframework.data.redis.connection.DefaultedRedisClusterConnection (also extends org.springframework.data.redis.connection.DefaultedRedisConnection, org.springframework.data.redis.connection.RedisClusterConnection)
- org.springframework.data.redis.connection.DefaultedRedisConnection
- org.springframework.data.redis.connection.RedisClusterConnection (also extends org.springframework.data.redis.connection.RedisClusterCommands, org.springframework.data.redis.connection.RedisClusterServerCommands, org.springframework.data.redis.connection.RedisConnection)
- org.springframework.data.redis.connection.RedisCommands (also extends org.springframework.data.redis.connection.RedisConnectionCommands, org.springframework.data.redis.connection.RedisGeoCommands, org.springframework.data.redis.connection.RedisHashCommands, org.springframework.data.redis.connection.RedisHyperLogLogCommands, org.springframework.data.redis.connection.RedisKeyCommands, org.springframework.data.redis.connection.RedisListCommands, org.springframework.data.redis.connection.RedisPubSubCommands, org.springframework.data.redis.connection.RedisScriptingCommands, org.springframework.data.redis.connection.RedisServerCommands, org.springframework.data.redis.connection.RedisSetCommands, org.springframework.data.redis.connection.RedisStreamCommands, org.springframework.data.redis.connection.RedisStringCommands, org.springframework.data.redis.connection.RedisTxCommands)
- org.springframework.data.redis.connection.RedisConnection (also extends java.lang.AutoCloseable, org.springframework.data.redis.connection.RedisCommands)
- org.springframework.data.redis.core.RedisConnectionUtils.RedisConnectionProxy (also extends org.springframework.aop.RawTargetAccess, org.springframework.data.redis.connection.RedisConnection)
- org.springframework.data.redis.connection.StringRedisConnection
- org.springframework.data.redis.core.convert.ReferenceResolver
- java.lang.Runnable
- org.springframework.data.redis.core.script.ScriptExecutor<K>
- java.io.Serializable
- org.springframework.data.redis.domain.geo.GeoShape
- org.springframework.data.redis.connection.Message
- org.springframework.data.geo.Shape
- org.springframework.data.redis.domain.geo.GeoShape
- org.springframework.data.redis.core.SessionCallback<T>
- org.springframework.data.redis.core.SetOperations<K,V>
- org.springframework.data.redis.core.query.SortCriterion<K>
- org.springframework.data.redis.connection.SortParameters
- org.springframework.data.redis.core.query.SortQuery<K>
- org.springframework.data.redis.stream.StreamListener<K,V>
- org.springframework.data.redis.stream.StreamReceiver<K,V>
- org.springframework.data.redis.connection.Subscription
- org.springframework.data.redis.connection.SubscriptionListener
- org.springframework.data.redis.core.TimeToLiveAccessor
- org.springframework.data.redis.listener.Topic
- org.springframework.data.convert.TypeMapper<S>
- org.springframework.data.redis.connection.ValueEncoding
- org.springframework.data.redis.core.ValueOperations<K,V>
- org.springframework.data.redis.core.ZSetOperations<K,V>
Annotation Type Hierarchy
Enum Hierarchy
Copyright © 2011–2021 Pivotal Software, Inc.. All rights reserved.