Spring Data Key-Value
A B C D E F G H I J K L M N O P Q R S T U V W Z

A

AbstractRedisCollection<E> - Class in org.springframework.data.keyvalue.redis.support.collections
Base implementation for RedisCollection.
AbstractRedisCollection(String, RedisOperations<String, E>) - Constructor for class org.springframework.data.keyvalue.redis.support.collections.AbstractRedisCollection
 
AbstractRiakMapReduceJob - Class in org.springframework.data.keyvalue.riak.mapreduce
An implementation of MapReduceJob for the Riak data store.
AbstractRiakMapReduceJob() - Constructor for class org.springframework.data.keyvalue.riak.mapreduce.AbstractRiakMapReduceJob
 
AbstractRiakTemplate - Class in org.springframework.data.keyvalue.riak.core
Base class for RiakTemplates that defines basic behaviour common to both kinds of templates (Key/Value and Bucket/Key/Value).
AbstractRiakTemplate() - Constructor for class org.springframework.data.keyvalue.riak.core.AbstractRiakTemplate
Take all the defaults.
AbstractRiakTemplate(ClientHttpRequestFactory) - Constructor for class org.springframework.data.keyvalue.riak.core.AbstractRiakTemplate
Use the specified ClientHttpRequestFactory.
AbstractSubscription - Class in org.springframework.data.keyvalue.redis.connection.util
Base implementation for a subscription handling the channel/pattern registration so subclasses only have to deal with the actual registration/unregistration.
AbstractSubscription(MessageListener) - Constructor for class org.springframework.data.keyvalue.redis.connection.util.AbstractSubscription
 
AbstractSubscription(MessageListener, byte[][], byte[][]) - Constructor for class org.springframework.data.keyvalue.redis.connection.util.AbstractSubscription
Constructs a new AbstractSubscription instance.
add(V) - Method in interface org.springframework.data.keyvalue.redis.core.BoundSetOperations
 
add(V, double) - Method in interface org.springframework.data.keyvalue.redis.core.BoundZSetOperations
 
add(K, V) - Method in interface org.springframework.data.keyvalue.redis.core.SetOperations
 
add(K, V, double) - Method in interface org.springframework.data.keyvalue.redis.core.ZSetOperations
 
add(E) - Method in class org.springframework.data.keyvalue.redis.support.collections.AbstractRedisCollection
 
add(E) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
 
add(int, E) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
 
add(E) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisSet
 
add(E) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisZSet
 
add(E, double) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisZSet
 
add(E, double) - Method in interface org.springframework.data.keyvalue.redis.support.collections.RedisZSet
Adds an element to the set with the given score, or updates the score if the element exists.
add(E) - Method in interface org.springframework.data.keyvalue.redis.support.collections.RedisZSet
Adds an element to the set with a default score.
addAll(Collection<? extends E>) - Method in class org.springframework.data.keyvalue.redis.support.collections.AbstractRedisCollection
 
addAll(int, Collection<? extends E>) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
 
addAndGet(int) - Method in class org.springframework.data.keyvalue.redis.support.atomic.RedisAtomicInteger
Atomically add the given value to current value.
addAndGet(long) - Method in class org.springframework.data.keyvalue.redis.support.atomic.RedisAtomicLong
Atomically adds the given value to the current value.
addFirst(E) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
 
addGetPattern(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultSortParameters
 
addHandler(String, Closure, Closure) - Method in class org.springframework.data.keyvalue.riak.groovy.RiakOperation
 
addInputs(List) - Method in class org.springframework.data.keyvalue.riak.mapreduce.AbstractRiakMapReduceJob
 
addInputs(List<V>) - Method in interface org.springframework.data.keyvalue.riak.mapreduce.MapReduceJob
Set the list of inputs for this job.
addLast(E) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
 
addMessageListener(MessageListener, Collection<? extends Topic>) - Method in class org.springframework.data.keyvalue.redis.listener.RedisMessageListenerContainer
Adds a message listener to the (potentially running) container.
addMessageListener(MessageListener, Topic) - Method in class org.springframework.data.keyvalue.redis.listener.RedisMessageListenerContainer
Adds a message listener to the (potentially running) container.
addPhase(MapReducePhase) - Method in class org.springframework.data.keyvalue.riak.mapreduce.AbstractRiakMapReduceJob
 
addPhase(MapReducePhase) - Method in interface org.springframework.data.keyvalue.riak.mapreduce.MapReduceJob
Add a phase to this operation.
afterPropertiesSet() - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnectionFactory
 
afterPropertiesSet() - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnectionFactory
 
afterPropertiesSet() - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnectionFactory
 
afterPropertiesSet() - Method in class org.springframework.data.keyvalue.redis.core.RedisAccessor
 
afterPropertiesSet() - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
 
afterPropertiesSet() - Method in class org.springframework.data.keyvalue.redis.listener.RedisMessageListenerContainer
 
afterPropertiesSet() - Method in class org.springframework.data.keyvalue.redis.serializer.OxmSerializer
 
afterPropertiesSet() - Method in class org.springframework.data.keyvalue.redis.support.collections.RedisCollectionFactoryBean
 
afterPropertiesSet() - Method in class org.springframework.data.keyvalue.riak.core.AbstractRiakTemplate
 
afterPropertiesSet() - Method in class org.springframework.data.keyvalue.riak.core.RiakKeyValueTemplate
 
alpha() - Method in class org.springframework.data.keyvalue.redis.connection.DefaultSortParameters
 
alphabetical(boolean) - Method in interface org.springframework.data.keyvalue.redis.core.query.SortCriterion
 
append(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
append(String, String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
append(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
append(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
append(byte[], byte[]) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisStringCommands
 
append(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
append(String, String) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
append(String) - Method in interface org.springframework.data.keyvalue.redis.core.BoundValueOperations
 
append(K, String) - Method in interface org.springframework.data.keyvalue.redis.core.ValueOperations
 
arg - Variable in class org.springframework.data.keyvalue.riak.mapreduce.RiakMapReducePhase
 
asc() - Method in class org.springframework.data.keyvalue.redis.connection.DefaultSortParameters
 
AsyncBucketKeyValueStoreOperations - Interface in org.springframework.data.keyvalue.riak.core
An asynchronous version of BucketKeyValueStoreOperations.
AsyncKeyValueStoreOperation<V,T> - Interface in org.springframework.data.keyvalue.riak.core
 
AsyncMapReduceOperations - Interface in org.springframework.data.keyvalue.riak.mapreduce
Generic interface to Map/Reduce in data stores that support it.
AsyncRiakMapReduceJob - Class in org.springframework.data.keyvalue.riak.mapreduce
An implementation of MapReduceJob for the Riak data store.
AsyncRiakMapReduceJob(AsyncRiakTemplate) - Constructor for class org.springframework.data.keyvalue.riak.mapreduce.AsyncRiakMapReduceJob
 
AsyncRiakTemplate - Class in org.springframework.data.keyvalue.riak.core
An implementation of AsyncBucketKeyValueStoreOperations and AsyncMapReduceOperations for the Riak datastore.
AsyncRiakTemplate() - Constructor for class org.springframework.data.keyvalue.riak.core.AsyncRiakTemplate
 
AsyncRiakTemplate(ClientHttpRequestFactory) - Constructor for class org.springframework.data.keyvalue.riak.core.AsyncRiakTemplate
 
AsyncRiakTemplate.AsyncDelete<V,R> - Class in org.springframework.data.keyvalue.riak.core
 
AsyncRiakTemplate.AsyncDelete(String, String, AsyncKeyValueStoreOperation<Boolean, R>) - Constructor for class org.springframework.data.keyvalue.riak.core.AsyncRiakTemplate.AsyncDelete
 
AsyncRiakTemplate.AsyncGet<T,R> - Class in org.springframework.data.keyvalue.riak.core
 
AsyncRiakTemplate.AsyncGet(String, String, Class<T>, AsyncKeyValueStoreOperation<T, R>) - Constructor for class org.springframework.data.keyvalue.riak.core.AsyncRiakTemplate.AsyncGet
 
AsyncRiakTemplate.AsyncHead<V,R> - Class in org.springframework.data.keyvalue.riak.core
 
AsyncRiakTemplate.AsyncHead(String, String, AsyncKeyValueStoreOperation<HttpHeaders, R>) - Constructor for class org.springframework.data.keyvalue.riak.core.AsyncRiakTemplate.AsyncHead
 
AsyncRiakTemplate.AsyncMapReduce<R> - Class in org.springframework.data.keyvalue.riak.core
 
AsyncRiakTemplate.AsyncMapReduce(HttpEntity<String>, AsyncKeyValueStoreOperation<List<?>, R>) - Constructor for class org.springframework.data.keyvalue.riak.core.AsyncRiakTemplate.AsyncMapReduce
 
AsyncRiakTemplate.AsyncPost<V,R> - Class in org.springframework.data.keyvalue.riak.core
 
AsyncRiakTemplate.AsyncPost(String, String, HttpEntity<V>, AsyncKeyValueStoreOperation<V, R>) - Constructor for class org.springframework.data.keyvalue.riak.core.AsyncRiakTemplate.AsyncPost
 
AsyncRiakTemplate.AsyncPut<V,R> - Class in org.springframework.data.keyvalue.riak.core
 
AsyncRiakTemplate.AsyncPut(String, HttpEntity<V>, AsyncKeyValueStoreOperation<V, R>) - Constructor for class org.springframework.data.keyvalue.riak.core.AsyncRiakTemplate.AsyncPut
 
AsyncRiakTemplate.LoggingErrorHandler - Class in org.springframework.data.keyvalue.riak.core
 
AsyncRiakTemplate.LoggingErrorHandler() - Constructor for class org.springframework.data.keyvalue.riak.core.AsyncRiakTemplate.LoggingErrorHandler
 
available() - Method in class org.springframework.data.keyvalue.riak.core.io.RiakInputStream
 

B

BeanUtilsHashMapper<T> - Class in org.springframework.data.keyvalue.redis.hash
HashMapper based on Apache Commons BeanUtils project.
BeanUtilsHashMapper(Class<T>) - Constructor for class org.springframework.data.keyvalue.redis.hash.BeanUtilsHashMapper
 
bgSave() - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
bgSave() - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
bgSave() - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
bgSave() - Method in interface org.springframework.data.keyvalue.redis.connection.RedisServerCommands
 
bgSave() - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
bgWriteAof() - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
bgWriteAof() - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
bgWriteAof() - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
bgWriteAof() - Method in interface org.springframework.data.keyvalue.redis.connection.RedisServerCommands
 
bgWriteAof() - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
bindConnection(RedisConnectionFactory) - Static method in class org.springframework.data.keyvalue.redis.core.RedisConnectionUtils
Binds a new Redis connection (from the given factory) to the current thread, if none is already bound.
bLPop(int, byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
bLPop(int, String...) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
bLPop(int, byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
bLPop(int, byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
bLPop(int, byte[]...) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisListCommands
 
bLPop(int, byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
bLPop(int, String...) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
BoundHashOperations<H,HK,HV> - Interface in org.springframework.data.keyvalue.redis.core
Hash operations bound to a certain key.
boundHashOps(K) - Method in interface org.springframework.data.keyvalue.redis.core.RedisOperations
Returns the operations performed on hash values bound to the given key.
boundHashOps(K) - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
 
BoundKeyOperations<K> - Interface in org.springframework.data.keyvalue.redis.core
Operations over a Redis key.
BoundListOperations<K,V> - Interface in org.springframework.data.keyvalue.redis.core
List operations bound to a certain key.
boundListOps(K) - Method in interface org.springframework.data.keyvalue.redis.core.RedisOperations
Returns the operations performed on list values bound to the given key.
boundListOps(K) - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
 
BoundSetOperations<K,V> - Interface in org.springframework.data.keyvalue.redis.core
Set operations bound to a certain key.
boundSetOps(K) - Method in interface org.springframework.data.keyvalue.redis.core.RedisOperations
Returns the operations performed on set values bound to the given key.
boundSetOps(K) - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
 
BoundValueOperations<K,V> - Interface in org.springframework.data.keyvalue.redis.core
Value (or String in Redis terminology) operations bound to a certain key.
boundValueOps(K) - Method in interface org.springframework.data.keyvalue.redis.core.RedisOperations
Returns the operations performed on simple values (or Strings in Redis terminology) bound to the given key.
boundValueOps(K) - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
 
BoundZSetOperations<K,V> - Interface in org.springframework.data.keyvalue.redis.core
ZSet (or SortedSet) operations bound to a certain key.
boundZSetOps(K) - Method in interface org.springframework.data.keyvalue.redis.core.RedisOperations
Returns the operations performed on zset values (also known as sorted sets) bound to the given key.
boundZSetOps(K) - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
 
bRPop(int, byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
bRPop(int, String...) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
bRPop(int, byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
bRPop(int, byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
bRPop(int, byte[]...) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisListCommands
 
bRPop(int, byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
bRPop(int, String...) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
bRPopLPush(int, byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
bRPopLPush(int, String, String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
bRPopLPush(int, byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
bRPopLPush(int, byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
bRPopLPush(int, byte[], byte[]) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisListCommands
 
bRPopLPush(int, byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
bRPopLPush(int, String, String) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
bucket - Variable in class org.springframework.data.keyvalue.riak.groovy.RiakOperation
 
bucketColonKey - Variable in class org.springframework.data.keyvalue.riak.core.SimpleBucketKeyResolver
 
BucketKeyPair<B,K> - Interface in org.springframework.data.keyvalue.riak.core
A generic interface for representing composite keys in data stores that use a bucket and key pair.
bucketKeyPair - Variable in class org.springframework.data.keyvalue.riak.mapreduce.JavascriptMapReduceOperation
 
BucketKeyResolver - Interface in org.springframework.data.keyvalue.riak.core
A generic interface to a resolver to turn a single object into a BucketKeyPair.
bucketKeyResolvers - Variable in class org.springframework.data.keyvalue.riak.core.AbstractRiakTemplate
A list of resolvers to turn a single object into a BucketKeyPair.
BucketKeyValueStoreOperations - Interface in org.springframework.data.keyvalue.riak.core
 
buckets - Variable in class org.springframework.data.keyvalue.riak.util.RiakClassLoader
 
build() - Method in interface org.springframework.data.keyvalue.redis.core.query.SortCriterion
 
buildListenerArguments(Object) - Method in class org.springframework.data.keyvalue.redis.listener.adapter.MessageListenerAdapter
Build an array of arguments to be passed into the target listener method.
BulkMapper<T,V> - Interface in org.springframework.data.keyvalue.redis.core
Mapper translating Redis bulk value responses (typically returned by a sort query) to actual objects.
by(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultSortParameters
 
by(String) - Method in class org.springframework.data.keyvalue.redis.core.query.SortQueryBuilder
 
ByteArrayWrapper - Class in org.springframework.data.keyvalue.redis.connection.util
Simple wrapper class used for wrapping arrays so they can be used as keys inside maps.
ByteArrayWrapper(byte[]) - Constructor for class org.springframework.data.keyvalue.redis.connection.util.ByteArrayWrapper
 

C

cache - Variable in class org.springframework.data.keyvalue.riak.core.AbstractRiakTemplate
For caching objects based on ETags.
call() - Method in class org.springframework.data.keyvalue.riak.core.AsyncRiakTemplate.AsyncDelete
 
call() - Method in class org.springframework.data.keyvalue.riak.core.AsyncRiakTemplate.AsyncGet
 
call() - Method in class org.springframework.data.keyvalue.riak.core.AsyncRiakTemplate.AsyncHead
 
call() - Method in class org.springframework.data.keyvalue.riak.core.AsyncRiakTemplate.AsyncMapReduce
 
call() - Method in class org.springframework.data.keyvalue.riak.core.AsyncRiakTemplate.AsyncPost
 
call() - Method in class org.springframework.data.keyvalue.riak.core.AsyncRiakTemplate.AsyncPut
 
call() - Method in class org.springframework.data.keyvalue.riak.groovy.RiakMapReduceOperation
 
call() - Method in class org.springframework.data.keyvalue.riak.groovy.RiakOperation
 
call() - Method in class org.springframework.data.keyvalue.riak.mapreduce.AsyncRiakMapReduceJob
 
call() - Method in class org.springframework.data.keyvalue.riak.mapreduce.RiakMapReduceJob
 
callbackInvoker - Variable in class org.springframework.data.keyvalue.riak.groovy.RiakOperation
 
callbacks - Variable in class org.springframework.data.keyvalue.riak.groovy.RiakOperation
 
canExecute() - Method in class org.springframework.data.keyvalue.riak.core.io.RiakFile
 
canRead() - Method in class org.springframework.data.keyvalue.riak.core.io.RiakFile
 
canResolve(V) - Method in interface org.springframework.data.keyvalue.riak.core.BucketKeyResolver
Can this resolver deal with the given object?
canResolve(V) - Method in class org.springframework.data.keyvalue.riak.core.SimpleBucketKeyResolver
 
canWrite() - Method in class org.springframework.data.keyvalue.riak.core.io.RiakFile
 
ChannelTopic - Class in org.springframework.data.keyvalue.redis.listener
Channel topic implementation (maps to a Redis channel).
ChannelTopic(String) - Constructor for class org.springframework.data.keyvalue.redis.listener.ChannelTopic
Constructs a new ChannelTopic instance.
checkCache(K, Class<T>) - Method in class org.springframework.data.keyvalue.riak.core.AbstractRiakTemplate
 
classLoader - Variable in class org.springframework.data.keyvalue.riak.core.AbstractRiakTemplate
ClassLoader to use for saving/loading objects using the automatic converters.
clear() - Method in class org.springframework.data.keyvalue.redis.support.collections.AbstractRedisCollection
 
clear() - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
 
clear() - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisMap
 
clear() - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisSet
 
clear() - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisZSet
 
clear() - Method in class org.springframework.data.keyvalue.redis.support.collections.RedisProperties
 
clone() - Method in class org.springframework.data.keyvalue.redis.support.collections.RedisProperties
 
close() - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
close() - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
close() - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
close() - Method in interface org.springframework.data.keyvalue.redis.connection.RedisConnection
Closes (or quits) the connection.
close() - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
close() - Method in class org.springframework.data.keyvalue.riak.core.io.RiakInputStream
 
closePipeline() - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
closePipeline() - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
closePipeline() - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
closePipeline() - Method in interface org.springframework.data.keyvalue.redis.connection.RedisConnection
Executes the commands in the pipeline and returns their result.
closePipeline() - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
code() - Method in enum org.springframework.data.keyvalue.redis.connection.DataType
Returns the code associated with the current enum.
compareAndSet(int, int) - Method in class org.springframework.data.keyvalue.redis.support.atomic.RedisAtomicInteger
Atomically set the value to the given updated value if the current value == the expected value.
compareAndSet(long, long) - Method in class org.springframework.data.keyvalue.redis.support.atomic.RedisAtomicLong
Atomically sets the value to the given updated value if the current value == the expected value.
compareTo(File) - Method in class org.springframework.data.keyvalue.riak.core.io.RiakFile
 
compareTo(Object) - Method in class org.springframework.data.keyvalue.riak.core.SimpleBucketKeyPair
 
completed(KeyValueStoreMetaData, V) - Method in interface org.springframework.data.keyvalue.riak.core.AsyncKeyValueStoreOperation
 
completed(KeyValueStoreMetaData, Throwable) - Method in class org.springframework.data.keyvalue.riak.core.AsyncRiakTemplate.LoggingErrorHandler
 
completed - Variable in class org.springframework.data.keyvalue.riak.groovy.RiakMapReduceOperation
 
contains(Object) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisSet
 
contains(Object) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisZSet
 
contains(Object) - Method in class org.springframework.data.keyvalue.redis.support.collections.RedisProperties
 
containsAll(Collection<?>) - Method in class org.springframework.data.keyvalue.redis.support.collections.AbstractRedisCollection
 
containsKey(Object) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisMap
 
containsKey(Object) - Method in class org.springframework.data.keyvalue.redis.support.collections.RedisProperties
 
containsKey(B, K, AsyncKeyValueStoreOperation<Boolean, R>) - Method in interface org.springframework.data.keyvalue.riak.core.AsyncBucketKeyValueStoreOperations
 
containsKey(B, K, AsyncKeyValueStoreOperation<Boolean, R>) - Method in class org.springframework.data.keyvalue.riak.core.AsyncRiakTemplate
 
containsKey(B, K) - Method in interface org.springframework.data.keyvalue.riak.core.BucketKeyValueStoreOperations
Variant of KeyValueStoreOperations.containsKey(Object) that takes a discreet bucket and key pair.
containsKey(K) - Method in interface org.springframework.data.keyvalue.riak.core.KeyValueStoreOperations
Does the store contain this key?
containsKey(K) - Method in class org.springframework.data.keyvalue.riak.core.RiakKeyValueTemplate
 
containsKey(B, K) - Method in class org.springframework.data.keyvalue.riak.core.RiakTemplate
 
containsValue(Object) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisMap
 
containsValue(Object) - Method in class org.springframework.data.keyvalue.redis.support.collections.RedisProperties
 
conversionService - Variable in class org.springframework.data.keyvalue.riak.core.AbstractRiakTemplate
For converting objects to/from other kinds of objects.
convertAndSend(String, Object) - Method in interface org.springframework.data.keyvalue.redis.core.RedisOperations
 
convertAndSend(String, Object) - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
 
convertJedisAccessException(Exception) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
convertJedisAccessException(JedisException) - Static method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisUtils
Converts the given, native Jedis exception to Spring's DAO hierarchy.
convertJedisAccessException(RuntimeException) - Static method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisUtils
Converts the given, native, runtime Jedis exception to Spring's DAO hierarchy.
convertJredisAccessException(Exception) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
convertJredisAccessException(RedisException) - Static method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisUtils
Converts the given, native JRedis exception to Spring's DAO hierarchy.
convertJredisAccessException(ClientRuntimeException) - Static method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisUtils
Converts the given, native JRedis exception to Spring's DAO hierarchy.
convertQuery(SortQuery<K>, RedisSerializer<String>) - Static method in class org.springframework.data.keyvalue.redis.core.query.QueryUtils
 
convertRjcAccessException(Exception) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
convertRjcAccessException(RuntimeException) - Static method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcUtils
 
convertRjcAccessException(RedisException) - Static method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcUtils
 
convertToList(Collection<String>) - Static method in class org.springframework.data.keyvalue.redis.connection.util.DecodeUtils
 
convertToSet(Collection<String>) - Static method in class org.springframework.data.keyvalue.redis.connection.util.DecodeUtils
 
count(double, double) - Method in interface org.springframework.data.keyvalue.redis.core.BoundZSetOperations
 
count(K, double, double) - Method in interface org.springframework.data.keyvalue.redis.core.ZSetOperations
 
createDefaultTaskExecutor() - Method in class org.springframework.data.keyvalue.redis.listener.RedisMessageListenerContainer
Creates a default TaskExecutor.
createMapReduceJob() - Method in class org.springframework.data.keyvalue.riak.core.RiakKeyValueTemplate
 
createMapReduceJob() - Method in class org.springframework.data.keyvalue.riak.groovy.RiakBuilder
 
createNewFile() - Method in class org.springframework.data.keyvalue.riak.core.io.RiakFile
 
createNode(Object) - Method in class org.springframework.data.keyvalue.riak.groovy.RiakBuilder
 
createNode(Object, Object) - Method in class org.springframework.data.keyvalue.riak.groovy.RiakBuilder
 
createNode(Object, Map) - Method in class org.springframework.data.keyvalue.riak.groovy.RiakBuilder
 
createNode(Object, Map, Object) - Method in class org.springframework.data.keyvalue.riak.groovy.RiakBuilder
 
createRedisConnectionProxy(RedisConnection) - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
 
createRelative(String) - Method in class org.springframework.data.keyvalue.riak.core.io.RiakResource
 

D

DataStoreConnectionFailureException - Exception in org.springframework.data.keyvalue.riak
 
DataStoreConnectionFailureException(String) - Constructor for exception org.springframework.data.keyvalue.riak.DataStoreConnectionFailureException
 
DataStoreConnectionFailureException(String, Throwable) - Constructor for exception org.springframework.data.keyvalue.riak.DataStoreConnectionFailureException
 
DataStoreOperationException - Exception in org.springframework.data.keyvalue.riak
 
DataStoreOperationException(String) - Constructor for exception org.springframework.data.keyvalue.riak.DataStoreOperationException
 
DataStoreOperationException(String, Throwable) - Constructor for exception org.springframework.data.keyvalue.riak.DataStoreOperationException
 
DataType - Enum in org.springframework.data.keyvalue.redis.connection
Enumeration of the Redis data types.
dbSize() - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
dbSize() - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
dbSize() - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
dbSize() - Method in interface org.springframework.data.keyvalue.redis.connection.RedisServerCommands
 
dbSize() - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
decode(byte[]) - Static method in class org.springframework.data.keyvalue.redis.connection.util.DecodeUtils
 
decodeMap(Map<byte[], byte[]>) - Static method in class org.springframework.data.keyvalue.redis.connection.util.DecodeUtils
 
decodeMultiple(byte[]...) - Static method in class org.springframework.data.keyvalue.redis.connection.util.DecodeUtils
 
DecodeUtils - Class in org.springframework.data.keyvalue.redis.connection.util
Simple class containing various decoding utilities.
DecodeUtils() - Constructor for class org.springframework.data.keyvalue.redis.connection.util.DecodeUtils
 
DecoratingStringHashMapper<T> - Class in org.springframework.data.keyvalue.redis.hash
Delegating hash mapper used for flattening objects into Strings.
DecoratingStringHashMapper(HashMapper<T, K, V>) - Constructor for class org.springframework.data.keyvalue.redis.hash.DecoratingStringHashMapper
 
decr(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
decr(String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
decr(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
decr(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
decr(byte[]) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisStringCommands
 
decr(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
decr(String) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
decrBy(byte[], long) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
decrBy(String, long) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
decrBy(byte[], long) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
decrBy(byte[], long) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
decrBy(byte[], long) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisStringCommands
 
decrBy(byte[], long) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
decrBy(String, long) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
decrementAndGet() - Method in class org.springframework.data.keyvalue.redis.support.atomic.RedisAtomicInteger
Atomically decrement by one the current value.
decrementAndGet() - Method in class org.springframework.data.keyvalue.redis.support.atomic.RedisAtomicLong
Atomically decrements by one the current value.
DEFAULT_CHARSET - Static variable in class org.springframework.data.keyvalue.redis.serializer.JacksonJsonRedisSerializer
 
DEFAULT_THREAD_NAME_PREFIX - Static variable in class org.springframework.data.keyvalue.redis.listener.RedisMessageListenerContainer
Default thread name prefix: "RedisListeningContainer-".
defaultBucket - Variable in class org.springframework.data.keyvalue.riak.util.RiakClassLoader
 
defaultBucketName - Variable in class org.springframework.data.keyvalue.riak.groovy.RiakBuilder
 
defaultErrorHandler - Variable in class org.springframework.data.keyvalue.riak.core.AsyncRiakTemplate
 
defaultHeaders(Map<String, ?>) - Method in class org.springframework.data.keyvalue.riak.core.AbstractRiakTemplate
 
DefaultMessage - Class in org.springframework.data.keyvalue.redis.connection
Default message implementation.
DefaultMessage(byte[], byte[]) - Constructor for class org.springframework.data.keyvalue.redis.connection.DefaultMessage
 
defaultQosParameters - Variable in class org.springframework.data.keyvalue.riak.core.AbstractRiakTemplate
The default QosParameters to use for all operations through this template.
DefaultRedisList<E> - Class in org.springframework.data.keyvalue.redis.support.collections
Default implementation for RedisList.
DefaultRedisList(String, RedisOperations<String, E>) - Constructor for class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
Constructs a new, uncapped DefaultRedisList instance.
DefaultRedisList(BoundListOperations<String, E>) - Constructor for class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
Constructs a new, uncapped DefaultRedisList instance.
DefaultRedisList(BoundListOperations<String, E>, int) - Constructor for class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
Constructs a new DefaultRedisList instance.
DefaultRedisMap<K,V> - Class in org.springframework.data.keyvalue.redis.support.collections
Default implementation for RedisMap.
DefaultRedisMap(String, RedisOperations<String, ?>) - Constructor for class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisMap
Constructs a new DefaultRedisMap instance.
DefaultRedisMap(BoundHashOperations<String, K, V>) - Constructor for class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisMap
Constructs a new DefaultRedisMap instance.
DefaultRedisSet<E> - Class in org.springframework.data.keyvalue.redis.support.collections
Default implementation for RedisSet.
DefaultRedisSet(String, RedisOperations<String, E>) - Constructor for class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisSet
Constructs a new DefaultRedisSet instance.
DefaultRedisSet(BoundSetOperations<String, E>) - Constructor for class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisSet
Constructs a new DefaultRedisSet instance.
DefaultRedisZSet<E> - Class in org.springframework.data.keyvalue.redis.support.collections
Default implementation for RedisZSet.
DefaultRedisZSet(String, RedisOperations<String, E>) - Constructor for class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisZSet
Constructs a new DefaultRedisZSet instance with a default score of '1'.
DefaultRedisZSet(String, RedisOperations<String, E>, double) - Constructor for class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisZSet
Constructs a new DefaultRedisSortedSet instance.
DefaultRedisZSet(BoundZSetOperations<String, E>) - Constructor for class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisZSet
Constructs a new DefaultRedisZSet instance with a default score of '1'.
DefaultRedisZSet(BoundZSetOperations<String, E>, double) - Constructor for class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisZSet
Constructs a new DefaultRedisZSet instance.
DefaultSortParameters - Class in org.springframework.data.keyvalue.redis.connection
Default implementation for SortParameters.
DefaultSortParameters() - Constructor for class org.springframework.data.keyvalue.redis.connection.DefaultSortParameters
Constructs a new DefaultSortParameters instance.
DefaultSortParameters(SortParameters.Range, SortParameters.Order, Boolean) - Constructor for class org.springframework.data.keyvalue.redis.connection.DefaultSortParameters
Constructs a new DefaultSortParameters instance.
DefaultSortParameters(byte[], SortParameters.Range, byte[][], SortParameters.Order, Boolean) - Constructor for class org.springframework.data.keyvalue.redis.connection.DefaultSortParameters
Constructs a new DefaultSortParameters instance.
DefaultStringRedisConnection - Class in org.springframework.data.keyvalue.redis.connection
Default implementation of StringRedisConnection.
DefaultStringRedisConnection(RedisConnection) - Constructor for class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
Constructs a new DefaultStringRedisConnection instance.
DefaultStringRedisConnection(RedisConnection, RedisSerializer<String>) - Constructor for class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
Constructs a new DefaultStringRedisConnection instance.
DefaultStringTuple - Class in org.springframework.data.keyvalue.redis.connection
Default implementation for StringRedisConnection.StringTuple interface.
DefaultStringTuple(byte[], String, Double) - Constructor for class org.springframework.data.keyvalue.redis.connection.DefaultStringTuple
Constructs a new DefaultStringTuple instance.
DefaultStringTuple(RedisZSetCommands.Tuple, String) - Constructor for class org.springframework.data.keyvalue.redis.connection.DefaultStringTuple
Constructs a new DefaultStringTuple instance.
DefaultTuple - Class in org.springframework.data.keyvalue.redis.connection
Default implementation for RedisZSetCommands.Tuple interface.
DefaultTuple(byte[], Double) - Constructor for class org.springframework.data.keyvalue.redis.connection.DefaultTuple
Constructs a new DefaultTuple instance.
defaultType - Variable in class org.springframework.data.keyvalue.riak.core.AbstractRiakTemplate
Default type to use when trying to deserialize objects and we can't otherwise tell what to do.
defaultUri - Variable in class org.springframework.data.keyvalue.riak.core.AbstractRiakTemplate
The URI to use inside the RestTemplate.
del(byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
del(String...) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
del(byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
del(byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
del(byte[]...) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisKeyCommands
 
del(byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
del(String...) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
delete(Object) - Method in interface org.springframework.data.keyvalue.redis.core.BoundHashOperations
 
delete(H, Object) - Method in interface org.springframework.data.keyvalue.redis.core.HashOperations
 
delete(K) - Method in interface org.springframework.data.keyvalue.redis.core.RedisOperations
 
delete(Collection<K>) - Method in interface org.springframework.data.keyvalue.redis.core.RedisOperations
 
delete(K) - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
 
delete(Collection<K>) - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
 
delete(B, K, AsyncKeyValueStoreOperation<Boolean, R>) - Method in interface org.springframework.data.keyvalue.riak.core.AsyncBucketKeyValueStoreOperations
Delete a specific entry from this data store.
delete(B, K, AsyncKeyValueStoreOperation<Boolean, R>) - Method in class org.springframework.data.keyvalue.riak.core.AsyncRiakTemplate
 
delete(B, K) - Method in interface org.springframework.data.keyvalue.riak.core.BucketKeyValueStoreOperations
Delete a specific entry from this data store.
delete() - Method in class org.springframework.data.keyvalue.riak.core.io.RiakFile
 
delete(B, K) - Method in class org.springframework.data.keyvalue.riak.core.RiakTemplate
 
deleteKeys(K...) - Method in interface org.springframework.data.keyvalue.riak.core.KeyValueStoreOperations
Delete one or more keys from the store.
deleteKeys(K...) - Method in class org.springframework.data.keyvalue.riak.core.RiakKeyValueTemplate
 
deleteKeys(K...) - Method in class org.springframework.data.keyvalue.riak.core.RiakTemplate
 
deleteOnExit() - Method in class org.springframework.data.keyvalue.riak.core.io.RiakFile
 
desc() - Method in class org.springframework.data.keyvalue.redis.connection.DefaultSortParameters
 
descendingIterator() - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
 
deserialize(byte[]) - Method in class org.springframework.data.keyvalue.redis.serializer.GenericToStringSerializer
 
deserialize(byte[]) - Method in class org.springframework.data.keyvalue.redis.serializer.JacksonJsonRedisSerializer
 
deserialize(byte[]) - Method in class org.springframework.data.keyvalue.redis.serializer.JdkSerializationRedisSerializer
 
deserialize(byte[]) - Method in class org.springframework.data.keyvalue.redis.serializer.OxmSerializer
 
deserialize(byte[]) - Method in interface org.springframework.data.keyvalue.redis.serializer.RedisSerializer
Deserialize an object from the given binary data.
deserialize(Set<byte[]>, RedisSerializer<T>) - Static method in class org.springframework.data.keyvalue.redis.serializer.SerializationUtils
 
deserialize(List<byte[]>, RedisSerializer<T>) - Static method in class org.springframework.data.keyvalue.redis.serializer.SerializationUtils
 
deserialize(Collection<byte[]>, RedisSerializer<T>) - Static method in class org.springframework.data.keyvalue.redis.serializer.SerializationUtils
 
deserialize(byte[]) - Method in class org.springframework.data.keyvalue.redis.serializer.StringRedisSerializer
 
destroy() - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnectionFactory
 
destroy() - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnectionFactory
 
destroy() - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnectionFactory
 
destroy() - Method in class org.springframework.data.keyvalue.redis.listener.RedisMessageListenerContainer
 
diff(K) - Method in interface org.springframework.data.keyvalue.redis.core.BoundSetOperations
 
diff(Collection<K>) - Method in interface org.springframework.data.keyvalue.redis.core.BoundSetOperations
 
diff(RedisSet<?>) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisSet
 
diff(Collection<? extends RedisSet<?>>) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisSet
 
diff(RedisSet<?>) - Method in interface org.springframework.data.keyvalue.redis.support.collections.RedisSet
 
diff(Collection<? extends RedisSet<?>>) - Method in interface org.springframework.data.keyvalue.redis.support.collections.RedisSet
 
diffAndStore(K, K) - Method in interface org.springframework.data.keyvalue.redis.core.BoundSetOperations
 
diffAndStore(Collection<K>, K) - Method in interface org.springframework.data.keyvalue.redis.core.BoundSetOperations
 
diffAndStore(RedisSet<?>, String) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisSet
 
diffAndStore(Collection<? extends RedisSet<?>>, String) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisSet
 
diffAndStore(RedisSet<?>, String) - Method in interface org.springframework.data.keyvalue.redis.support.collections.RedisSet
 
diffAndStore(Collection<? extends RedisSet<?>>, String) - Method in interface org.springframework.data.keyvalue.redis.support.collections.RedisSet
 
difference(K, K) - Method in interface org.springframework.data.keyvalue.redis.core.SetOperations
 
difference(K, Collection<K>) - Method in interface org.springframework.data.keyvalue.redis.core.SetOperations
 
differenceAndStore(K, K, K) - Method in interface org.springframework.data.keyvalue.redis.core.SetOperations
 
differenceAndStore(K, Collection<K>, K) - Method in interface org.springframework.data.keyvalue.redis.core.SetOperations
 
discard() - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
discard() - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
discard() - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
discard() - Method in interface org.springframework.data.keyvalue.redis.connection.RedisTxCommands
 
discard() - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
discard() - Method in interface org.springframework.data.keyvalue.redis.core.RedisOperations
 
discard() - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
 
doClose() - Method in class org.springframework.data.keyvalue.redis.connection.util.AbstractSubscription
Shutdown the subscription and free any resources held.
doGetConnection(RedisConnectionFactory, boolean, boolean) - Static method in class org.springframework.data.keyvalue.redis.core.RedisConnectionUtils
Gets a Redis connection.
doInRedis(RedisConnection) - Method in interface org.springframework.data.keyvalue.redis.core.RedisCallback
Gets called by RedisTemplate with an active Redis connection.
doPsubscribe(byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.util.AbstractSubscription
Subscribe to the given patterns
doPUnsubscribe(boolean, byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.util.AbstractSubscription
Pattern unsubscribe.
doSubscribe(byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.util.AbstractSubscription
Subscribe to the given channels.
doubleValue() - Method in class org.springframework.data.keyvalue.redis.support.atomic.RedisAtomicInteger
 
doubleValue() - Method in class org.springframework.data.keyvalue.redis.support.atomic.RedisAtomicLong
 
doUnsubscribe(boolean, byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.util.AbstractSubscription
Channel unsubscribe.
drainTo(Collection<? super E>, int) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
 
drainTo(Collection<? super E>) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
 
durableWriteThreshold - Variable in class org.springframework.data.keyvalue.riak.core.RiakQosParameters
 

E

echo(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
echo(String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
echo(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
echo(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
echo(byte[]) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisConnectionCommands
 
echo(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
echo(String) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
element() - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
 
elements() - Method in class org.springframework.data.keyvalue.redis.support.collections.RedisProperties
 
encode(String) - Static method in class org.springframework.data.keyvalue.redis.connection.util.DecodeUtils
 
encodeMap(Map<String, byte[]>) - Static method in class org.springframework.data.keyvalue.redis.connection.util.DecodeUtils
 
ENCODING - Static variable in class org.springframework.data.keyvalue.redis.support.collections.AbstractRedisCollection
 
entries() - Method in interface org.springframework.data.keyvalue.redis.core.BoundHashOperations
 
entries(H) - Method in interface org.springframework.data.keyvalue.redis.core.HashOperations
 
entrySet() - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisMap
 
entrySet() - Method in class org.springframework.data.keyvalue.redis.support.collections.RedisProperties
 
equals(Object) - Method in class org.springframework.data.keyvalue.redis.connection.util.ByteArrayWrapper
 
equals(Object) - Method in class org.springframework.data.keyvalue.redis.support.collections.AbstractRedisCollection
 
equals(Object) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisMap
 
equals(Object) - Method in class org.springframework.data.keyvalue.redis.support.collections.RedisProperties
 
equals(Object) - Method in class org.springframework.data.keyvalue.riak.core.io.RiakFile
 
ErlangMapReduceOperation - Class in org.springframework.data.keyvalue.riak.mapreduce
An implementation of MapReduceOperation to represent an Erlang M/R function, which must be already defined inside the Riak server.
ErlangMapReduceOperation() - Constructor for class org.springframework.data.keyvalue.riak.mapreduce.ErlangMapReduceOperation
 
ErlangMapReduceOperation(String, String) - Constructor for class org.springframework.data.keyvalue.riak.mapreduce.ErlangMapReduceOperation
 
exec() - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
exec() - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
exec() - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
exec() - Method in interface org.springframework.data.keyvalue.redis.connection.RedisTxCommands
 
exec() - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
exec() - Method in interface org.springframework.data.keyvalue.redis.core.RedisOperations
 
exec() - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
 
execute(RedisCallback<T>) - Method in interface org.springframework.data.keyvalue.redis.core.RedisOperations
Executes the given action within a Redis connection.
execute(SessionCallback<T>) - Method in interface org.springframework.data.keyvalue.redis.core.RedisOperations
Executes a Redis session.
execute(RedisCallback<T>) - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
 
execute(RedisCallback<T>, boolean) - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
Executes the given action object within a connection, which can be exposed or not.
execute(RedisCallback<T>, boolean, boolean) - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
Executes the given action object within a connection that can be exposed or not.
execute(SessionCallback<T>) - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
 
execute(RedisOperations<K, V>) - Method in interface org.springframework.data.keyvalue.redis.core.SessionCallback
Executes all the given operations inside the same session.
execute(MapReduceJob, AsyncKeyValueStoreOperation<List<?>, R>) - Method in class org.springframework.data.keyvalue.riak.core.AsyncRiakTemplate
 
execute(MapReduceJob) - Method in class org.springframework.data.keyvalue.riak.core.RiakKeyValueTemplate
 
execute(MapReduceJob, Class<T>) - Method in class org.springframework.data.keyvalue.riak.core.RiakKeyValueTemplate
 
execute(MapReduceJob) - Method in class org.springframework.data.keyvalue.riak.core.RiakTemplate
 
execute(MapReduceJob, Class<T>) - Method in class org.springframework.data.keyvalue.riak.core.RiakTemplate
 
execute(MapReduceJob, AsyncKeyValueStoreOperation<List<?>, R>) - Method in interface org.springframework.data.keyvalue.riak.mapreduce.AsyncMapReduceOperations
Execute a MapReduceJob synchronously.
execute(MapReduceJob) - Method in interface org.springframework.data.keyvalue.riak.mapreduce.MapReduceOperations
Execute a MapReduceJob synchronously.
execute(MapReduceJob, Class<T>) - Method in interface org.springframework.data.keyvalue.riak.mapreduce.MapReduceOperations
Execute a MapReduceJob synchronously, converting the result into the given type.
executeListener(MessageListener, Message, byte[]) - Method in class org.springframework.data.keyvalue.redis.listener.RedisMessageListenerContainer
Execute the specified listener.
exists(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
exists(String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
exists(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
exists(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
exists(byte[]) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisKeyCommands
 
exists(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
exists(String) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
exists() - Method in class org.springframework.data.keyvalue.riak.core.io.RiakFile
 
expire(byte[], long) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
expire(String, long) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
expire(byte[], long) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
expire(byte[], long) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
expire(byte[], long) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisKeyCommands
 
expire(byte[], long) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
expire(String, long) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
expire(long, TimeUnit) - Method in interface org.springframework.data.keyvalue.redis.core.BoundKeyOperations
Sets the key time-to-live/expiration.
expire(K, long, TimeUnit) - Method in interface org.springframework.data.keyvalue.redis.core.RedisOperations
 
expire(K, long, TimeUnit) - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
 
expire(long, TimeUnit) - Method in class org.springframework.data.keyvalue.redis.support.atomic.RedisAtomicInteger
 
expire(long, TimeUnit) - Method in class org.springframework.data.keyvalue.redis.support.atomic.RedisAtomicLong
 
expire(long, TimeUnit) - Method in class org.springframework.data.keyvalue.redis.support.collections.AbstractRedisCollection
 
expire(long, TimeUnit) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisMap
 
expire(long, TimeUnit) - Method in class org.springframework.data.keyvalue.redis.support.collections.RedisProperties
 
expireAt(byte[], long) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
expireAt(String, long) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
expireAt(byte[], long) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
expireAt(byte[], long) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
expireAt(byte[], long) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisKeyCommands
 
expireAt(byte[], long) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
expireAt(String, long) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
expireAt(Date) - Method in interface org.springframework.data.keyvalue.redis.core.BoundKeyOperations
Sets the key time-to-live/expiration.
expireAt(K, Date) - Method in interface org.springframework.data.keyvalue.redis.core.RedisOperations
 
expireAt(K, Date) - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
 
expireAt(Date) - Method in class org.springframework.data.keyvalue.redis.support.atomic.RedisAtomicInteger
 
expireAt(Date) - Method in class org.springframework.data.keyvalue.redis.support.atomic.RedisAtomicLong
 
expireAt(Date) - Method in class org.springframework.data.keyvalue.redis.support.collections.AbstractRedisCollection
 
expireAt(Date) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisMap
 
expireAt(Date) - Method in class org.springframework.data.keyvalue.redis.support.collections.RedisProperties
 
extractMediaType(Object) - Method in class org.springframework.data.keyvalue.riak.core.AbstractRiakTemplate
 
extractMessage(Message) - Method in class org.springframework.data.keyvalue.redis.listener.adapter.MessageListenerAdapter
Extract the message body from the given Redis message.
extractMetaData(HttpHeaders) - Method in class org.springframework.data.keyvalue.riak.core.AbstractRiakTemplate
 
extractQosParameters(QosParameters) - Method in class org.springframework.data.keyvalue.riak.core.AbstractRiakTemplate
Get a string that represents the QOS parameters, taken either from the specified object or from the template defaults.
extractValue(ResponseEntity<?>, Class<?>, Class<T>) - Method in class org.springframework.data.keyvalue.riak.core.AbstractRiakTemplate
 

F

failed(Throwable) - Method in interface org.springframework.data.keyvalue.riak.core.AsyncKeyValueStoreOperation
 
failed(Throwable) - Method in class org.springframework.data.keyvalue.riak.core.AsyncRiakTemplate.LoggingErrorHandler
 
failed - Variable in class org.springframework.data.keyvalue.riak.groovy.RiakMapReduceOperation
 
fetchJedisConnector() - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnectionFactory
Returns a Jedis instance to be used as a Redis connection.
findClass(String) - Method in class org.springframework.data.keyvalue.riak.util.RiakClassLoader
 
first() - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisZSet
 
first() - Method in interface org.springframework.data.keyvalue.redis.support.collections.RedisZSet
Returns the first (lowest) element currently in this sorted set.
floatValue() - Method in class org.springframework.data.keyvalue.redis.support.atomic.RedisAtomicInteger
 
floatValue() - Method in class org.springframework.data.keyvalue.redis.support.atomic.RedisAtomicLong
 
flush() - Method in class org.springframework.data.keyvalue.riak.core.io.RiakOutputStream
 
flushAll() - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
flushAll() - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
flushAll() - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
flushAll() - Method in interface org.springframework.data.keyvalue.redis.connection.RedisServerCommands
 
flushAll() - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
flushDb() - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
flushDb() - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
flushDb() - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
flushDb() - Method in interface org.springframework.data.keyvalue.redis.connection.RedisServerCommands
 
flushDb() - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
fromCode(String) - Static method in enum org.springframework.data.keyvalue.redis.connection.DataType
Utility method for converting an enum code to an actual enum.
fromHash(Map<String, String>) - Method in class org.springframework.data.keyvalue.redis.hash.BeanUtilsHashMapper
 
fromHash(Map<String, String>) - Method in class org.springframework.data.keyvalue.redis.hash.DecoratingStringHashMapper
 
fromHash(Map<K, V>) - Method in interface org.springframework.data.keyvalue.redis.hash.HashMapper
 
fromHash(Map<String, Object>) - Method in class org.springframework.data.keyvalue.redis.hash.JacksonHashMapper
 

G

GenericToStringSerializer<T> - Class in org.springframework.data.keyvalue.redis.serializer
Generic String to byte[] (and back) serializer.
GenericToStringSerializer(Class<T>) - Constructor for class org.springframework.data.keyvalue.redis.serializer.GenericToStringSerializer
 
GenericToStringSerializer(Class<T>, Charset) - Constructor for class org.springframework.data.keyvalue.redis.serializer.GenericToStringSerializer
 
get(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultSortParameters
 
get(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
get(String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
get(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
get(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
get(byte[]) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisStringCommands
 
get(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
get(String) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
get(Object) - Method in interface org.springframework.data.keyvalue.redis.core.BoundHashOperations
 
get() - Method in interface org.springframework.data.keyvalue.redis.core.BoundValueOperations
 
get(long, long) - Method in interface org.springframework.data.keyvalue.redis.core.BoundValueOperations
 
get(H, Object) - Method in interface org.springframework.data.keyvalue.redis.core.HashOperations
 
get(String) - Method in interface org.springframework.data.keyvalue.redis.core.query.SortCriterion
 
get(Object) - Method in interface org.springframework.data.keyvalue.redis.core.ValueOperations
 
get(K, long, long) - Method in interface org.springframework.data.keyvalue.redis.core.ValueOperations
 
get() - Method in class org.springframework.data.keyvalue.redis.support.atomic.RedisAtomicInteger
Get the current value.
get() - Method in class org.springframework.data.keyvalue.redis.support.atomic.RedisAtomicLong
Gets the current value.
get(int) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
 
get(Object) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisMap
 
get(Object) - Method in class org.springframework.data.keyvalue.redis.support.collections.RedisProperties
 
get(B, K, AsyncKeyValueStoreOperation<V, R>) - Method in interface org.springframework.data.keyvalue.riak.core.AsyncBucketKeyValueStoreOperations
 
get(B, K, AsyncKeyValueStoreOperation<V, R>) - Method in class org.springframework.data.keyvalue.riak.core.AsyncRiakTemplate
 
get(B, K) - Method in interface org.springframework.data.keyvalue.riak.core.BucketKeyValueStoreOperations
Variant of KeyValueStoreOperations.get(Object) that takes a discreet bucket and key pair.
get(K) - Method in interface org.springframework.data.keyvalue.riak.core.KeyValueStoreOperations
Get a value at the specified key, trying to infer the type from either the bucket in which the value was stored, or (by default) as a java.util.Map.
get() - Method in interface org.springframework.data.keyvalue.riak.core.KeyValueStoreValue
Get the converted value itself.
get(K) - Method in class org.springframework.data.keyvalue.riak.core.RiakKeyValueTemplate
 
get(B, K) - Method in class org.springframework.data.keyvalue.riak.core.RiakTemplate
 
get() - Method in class org.springframework.data.keyvalue.riak.core.RiakValue
 
getAbsoluteFile() - Method in class org.springframework.data.keyvalue.riak.core.io.RiakFile
 
getAbsolutePath() - Method in class org.springframework.data.keyvalue.riak.core.io.RiakFile
 
getAndAdd(int) - Method in class org.springframework.data.keyvalue.redis.support.atomic.RedisAtomicInteger
Atomically add the given value to current value.
getAndAdd(long) - Method in class org.springframework.data.keyvalue.redis.support.atomic.RedisAtomicLong
Atomically adds the given value to the current value.
getAndDecrement() - Method in class org.springframework.data.keyvalue.redis.support.atomic.RedisAtomicInteger
Atomically decrement by one the current value.
getAndDecrement() - Method in class org.springframework.data.keyvalue.redis.support.atomic.RedisAtomicLong
Atomically decrements by one the current value.
getAndIncrement() - Method in class org.springframework.data.keyvalue.redis.support.atomic.RedisAtomicInteger
Atomically increment by one the current value.
getAndIncrement() - Method in class org.springframework.data.keyvalue.redis.support.atomic.RedisAtomicLong
Atomically increments by one the current value.
getAndSet(V) - Method in interface org.springframework.data.keyvalue.redis.core.BoundValueOperations
 
getAndSet(K, V) - Method in interface org.springframework.data.keyvalue.redis.core.ValueOperations
 
getAndSet(int) - Method in class org.springframework.data.keyvalue.redis.support.atomic.RedisAtomicInteger
Set to the give value and return the old value.
getAndSet(long) - Method in class org.springframework.data.keyvalue.redis.support.atomic.RedisAtomicLong
Atomically sets to the given value and returns the old value.
getAndSet(B, K, V, AsyncKeyValueStoreOperation<V, R>) - Method in interface org.springframework.data.keyvalue.riak.core.AsyncBucketKeyValueStoreOperations
 
getAndSet(B, K, V, AsyncKeyValueStoreOperation<V, R>) - Method in class org.springframework.data.keyvalue.riak.core.AsyncRiakTemplate
 
getAndSet(B, K, V) - Method in interface org.springframework.data.keyvalue.riak.core.BucketKeyValueStoreOperations
Variant of KeyValueStoreOperations.getAndSet(Object, Object) that takes a discreet bucket and key pair.
getAndSet(K, V) - Method in interface org.springframework.data.keyvalue.riak.core.KeyValueStoreOperations
Get the old value at the specified key and replace it with the given value.
getAndSet(K, V) - Method in class org.springframework.data.keyvalue.riak.core.RiakKeyValueTemplate
 
getAndSet(B, K, V) - Method in class org.springframework.data.keyvalue.riak.core.RiakTemplate
 
getAndSetAsBytes(B, K, byte[], AsyncKeyValueStoreOperation<byte[], R>) - Method in interface org.springframework.data.keyvalue.riak.core.AsyncBucketKeyValueStoreOperations
 
getAndSetAsBytes(B, K, byte[], AsyncKeyValueStoreOperation<byte[], R>) - Method in class org.springframework.data.keyvalue.riak.core.AsyncRiakTemplate
 
getAndSetAsBytes(B, K, byte[]) - Method in interface org.springframework.data.keyvalue.riak.core.BucketKeyValueStoreOperations
Variant of KeyValueStoreOperations.getAndSetAsBytes(Object, byte[]) that takes a discreet bucket and key pair.
getAndSetAsBytes(K, byte[]) - Method in interface org.springframework.data.keyvalue.riak.core.KeyValueStoreOperations
Get the old value at the specified key as a byte array and replace it with the given bytes.
getAndSetAsBytes(K, byte[]) - Method in class org.springframework.data.keyvalue.riak.core.RiakKeyValueTemplate
 
getAndSetAsBytes(B, K, byte[]) - Method in class org.springframework.data.keyvalue.riak.core.RiakTemplate
 
getAndSetAsType(B, K, V, Class<T>, AsyncKeyValueStoreOperation<T, R>) - Method in interface org.springframework.data.keyvalue.riak.core.AsyncBucketKeyValueStoreOperations
 
getAndSetAsType(B, K, V, Class<T>, AsyncKeyValueStoreOperation<T, R>) - Method in class org.springframework.data.keyvalue.riak.core.AsyncRiakTemplate
 
getAndSetAsType(B, K, V, Class<T>) - Method in interface org.springframework.data.keyvalue.riak.core.BucketKeyValueStoreOperations
Variant of KeyValueStoreOperations.getAndSetAsType(Object, Object, Class) that takes a discreet bucket and key pair.
getAndSetAsType(K, V, Class<T>) - Method in interface org.springframework.data.keyvalue.riak.core.KeyValueStoreOperations
Get the old value at the specified key and replace it with the given value, converting it to an instance of the given type.
getAndSetAsType(K, V, Class<T>) - Method in class org.springframework.data.keyvalue.riak.core.RiakKeyValueTemplate
 
getAndSetAsType(B, K, V, Class<T>) - Method in class org.springframework.data.keyvalue.riak.core.RiakTemplate
 
getArg() - Method in interface org.springframework.data.keyvalue.riak.mapreduce.MapReducePhase
Get the static argument for this phase.
getArg() - Method in class org.springframework.data.keyvalue.riak.mapreduce.RiakMapReducePhase
 
getArray() - Method in class org.springframework.data.keyvalue.redis.connection.util.ByteArrayWrapper
Returns the array.
getAsBytes(B, K, AsyncKeyValueStoreOperation<byte[], R>) - Method in interface org.springframework.data.keyvalue.riak.core.AsyncBucketKeyValueStoreOperations
 
getAsBytes(B, K, AsyncKeyValueStoreOperation<byte[], R>) - Method in class org.springframework.data.keyvalue.riak.core.AsyncRiakTemplate
 
getAsBytes(B, K) - Method in interface org.springframework.data.keyvalue.riak.core.BucketKeyValueStoreOperations
Variant of KeyValueStoreOperations.getAsBytes(Object) that takes a discreet bucket and key pair.
getAsBytes(K) - Method in interface org.springframework.data.keyvalue.riak.core.KeyValueStoreOperations
Get the value at the specified key as a byte array.
getAsBytes(K) - Method in class org.springframework.data.keyvalue.riak.core.RiakKeyValueTemplate
 
getAsBytes(B, K) - Method in class org.springframework.data.keyvalue.riak.core.RiakTemplate
 
getAsBytesWithMetaData(K) - Method in class org.springframework.data.keyvalue.riak.core.RiakKeyValueTemplate
 
getAsBytesWithMetaData(B, K) - Method in class org.springframework.data.keyvalue.riak.core.RiakTemplate
 
getAsType(B, K, Class<T>, AsyncKeyValueStoreOperation<T, R>) - Method in interface org.springframework.data.keyvalue.riak.core.AsyncBucketKeyValueStoreOperations
 
getAsType(B, K, Class<T>, AsyncKeyValueStoreOperation<T, R>) - Method in class org.springframework.data.keyvalue.riak.core.AsyncRiakTemplate
 
getAsType(B, K, Class<T>) - Method in interface org.springframework.data.keyvalue.riak.core.BucketKeyValueStoreOperations
Variant of KeyValueStoreOperations.getAsType(Object, Class) that takes a discreet bucket and key pair.
getAsType(K, Class<T>) - Method in interface org.springframework.data.keyvalue.riak.core.KeyValueStoreOperations
Get the value at the specified key and convert it into an instance of the specified type.
getAsType(K, Class<T>) - Method in class org.springframework.data.keyvalue.riak.core.RiakKeyValueTemplate
 
getAsType(B, K, Class<T>) - Method in class org.springframework.data.keyvalue.riak.core.RiakTemplate
 
getAsyncRiakTemplate() - Method in class org.springframework.data.keyvalue.riak.mapreduce.AsyncRiakMapReduceJob
 
getAsyncTemplate() - Method in class org.springframework.data.keyvalue.riak.groovy.RiakBuilder
 
getBit(byte[], long) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
getBit(String, long) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
getBit(byte[], long) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
getBit(byte[], long) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
getBit(byte[], long) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisStringCommands
 
getBit(byte[], long) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
getBit(String, long) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
getBody() - Method in class org.springframework.data.keyvalue.redis.connection.DefaultMessage
 
getBody() - Method in interface org.springframework.data.keyvalue.redis.connection.Message
Returns the body (or the payload) of the message.
getBucket() - Method in interface org.springframework.data.keyvalue.riak.core.BucketKeyPair
Get the bucket representation.
getBucket() - Method in class org.springframework.data.keyvalue.riak.core.io.RiakFile
 
getBucket() - Method in class org.springframework.data.keyvalue.riak.core.io.RiakResource
 
getBucket() - Method in interface org.springframework.data.keyvalue.riak.core.KeyValueStoreMetaData
 
getBucket() - Method in class org.springframework.data.keyvalue.riak.core.RiakMetaData
 
getBucket() - Method in class org.springframework.data.keyvalue.riak.core.SimpleBucketKeyPair
 
getBucket() - Method in class org.springframework.data.keyvalue.riak.groovy.RiakOperation
 
getBucketKeyPair() - Method in class org.springframework.data.keyvalue.riak.mapreduce.JavascriptMapReduceOperation
 
getBuckets() - Method in class org.springframework.data.keyvalue.riak.util.RiakClassLoader
 
getBucketSchema(B, QosParameters, AsyncKeyValueStoreOperation<Map<String, Object>, R>) - Method in class org.springframework.data.keyvalue.riak.core.AsyncRiakTemplate
 
getBucketSchema(B) - Method in interface org.springframework.data.keyvalue.riak.core.KeyValueStoreOperations
Get the properties of the specified bucket.
getBucketSchema(B, boolean) - Method in interface org.springframework.data.keyvalue.riak.core.KeyValueStoreOperations
Get the properties of the bucket and specify whether or not to list the keys in that bucket.
getBucketSchema(B) - Method in class org.springframework.data.keyvalue.riak.core.RiakKeyValueTemplate
 
getBucketSchema(B, boolean) - Method in class org.springframework.data.keyvalue.riak.core.RiakKeyValueTemplate
 
getBucketSchema(B) - Method in class org.springframework.data.keyvalue.riak.core.RiakTemplate
 
getBucketSchema(B, boolean) - Method in class org.springframework.data.keyvalue.riak.core.RiakTemplate
 
getBy() - Method in interface org.springframework.data.keyvalue.redis.core.query.SortQuery
Returns the pattern of the external key used for sorting.
getByPattern() - Method in class org.springframework.data.keyvalue.redis.connection.DefaultSortParameters
 
getByPattern() - Method in interface org.springframework.data.keyvalue.redis.connection.SortParameters
Returns the pattern (if set) for sorting by external keys (BY).
getCallbacks() - Method in class org.springframework.data.keyvalue.riak.groovy.RiakOperation
 
getCanonicalFile() - Method in class org.springframework.data.keyvalue.riak.core.io.RiakFile
 
getCanonicalPath() - Method in class org.springframework.data.keyvalue.riak.core.io.RiakFile
 
getChannel() - Method in class org.springframework.data.keyvalue.redis.connection.DefaultMessage
 
getChannel() - Method in interface org.springframework.data.keyvalue.redis.connection.Message
Returns the channel associated with the message.
getChannels() - Method in interface org.springframework.data.keyvalue.redis.connection.Subscription
Returns the (named) channels for this subscription.
getChannels() - Method in class org.springframework.data.keyvalue.redis.connection.util.AbstractSubscription
 
getCompleted() - Method in class org.springframework.data.keyvalue.riak.groovy.RiakMapReduceOperation
 
getConfig(String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
getConfig(String) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
getConfig(String) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
getConfig(String) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisServerCommands
 
getConfig(String) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
getConnection() - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnectionFactory
 
getConnection() - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnectionFactory
 
getConnection() - Method in interface org.springframework.data.keyvalue.redis.connection.RedisConnectionFactory
Provides a suitable connection for interacting with Redis.
getConnection() - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnectionFactory
 
getConnection(RedisConnectionFactory) - Static method in class org.springframework.data.keyvalue.redis.core.RedisConnectionUtils
Gets a Redis connection from the given factory.
getConnectionFactory() - Method in class org.springframework.data.keyvalue.redis.core.RedisAccessor
Returns the connectionFactory.
getConnectionFactory() - Method in class org.springframework.data.keyvalue.redis.listener.RedisMessageListenerContainer
Returns the connectionFactory.
getContentType() - Method in interface org.springframework.data.keyvalue.riak.core.KeyValueStoreMetaData
Get the Content-Type of this object.
getContentType() - Method in class org.springframework.data.keyvalue.riak.core.RiakMetaData
 
getConversionService() - Method in class org.springframework.data.keyvalue.riak.core.AbstractRiakTemplate
 
getCount() - Method in class org.springframework.data.keyvalue.redis.connection.SortParameters.Range
 
getDatabase() - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnectionFactory
Returns the index of the database.
getDatabase() - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnectionFactory
Returns the index of the database.
getDatabase() - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnectionFactory
Returns the index of the database.
getDefaultBucket() - Method in class org.springframework.data.keyvalue.riak.util.RiakClassLoader
 
getDefaultErrorHandler() - Method in class org.springframework.data.keyvalue.riak.core.AsyncRiakTemplate
 
getDefaultListenerMethod() - Method in class org.springframework.data.keyvalue.redis.listener.adapter.MessageListenerAdapter
Return the name of the default listener method to delegate to.
getDefaultQosParameters() - Method in class org.springframework.data.keyvalue.riak.core.AbstractRiakTemplate
 
getDefaultScore() - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisZSet
 
getDefaultScore() - Method in interface org.springframework.data.keyvalue.redis.support.collections.RedisZSet
Returns the default score used by this set.
getDefaultSerializer() - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
Returns the default serializer used by this template.
getDefaultType() - Method in class org.springframework.data.keyvalue.riak.core.AbstractRiakTemplate
Get the default type to use if none can be inferred.
getDefaultUri() - Method in class org.springframework.data.keyvalue.riak.core.AbstractRiakTemplate
 
getDelegate() - Method in class org.springframework.data.keyvalue.redis.listener.adapter.MessageListenerAdapter
Returns the target object to delegate message listening to.
getDescription() - Method in class org.springframework.data.keyvalue.riak.core.io.RiakResource
 
getDurableWriteThreshold() - Method in interface org.springframework.data.keyvalue.riak.core.QosParameters
Instruct the server on the durable write threshold.
getDurableWriteThreshold() - Method in class org.springframework.data.keyvalue.riak.core.RiakQosParameters
 
getExpire() - Method in interface org.springframework.data.keyvalue.redis.core.BoundKeyOperations
Returns the expiration of this key.
getExpire(K) - Method in interface org.springframework.data.keyvalue.redis.core.RedisOperations
 
getExpire(K) - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
 
getExpire() - Method in class org.springframework.data.keyvalue.redis.support.atomic.RedisAtomicInteger
 
getExpire() - Method in class org.springframework.data.keyvalue.redis.support.atomic.RedisAtomicLong
 
getExpire() - Method in class org.springframework.data.keyvalue.redis.support.collections.AbstractRedisCollection
 
getExpire() - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisMap
 
getExpire() - Method in class org.springframework.data.keyvalue.redis.support.collections.RedisProperties
 
getFailed() - Method in class org.springframework.data.keyvalue.riak.groovy.RiakMapReduceOperation
 
getFile() - Method in class org.springframework.data.keyvalue.riak.core.io.RiakResource
 
getFilename() - Method in class org.springframework.data.keyvalue.riak.core.io.RiakResource
 
getFirst() - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
 
getFreeSpace() - Method in class org.springframework.data.keyvalue.riak.core.io.RiakFile
 
getGetPattern() - Method in class org.springframework.data.keyvalue.redis.connection.DefaultSortParameters
 
getGetPattern() - Method in interface org.springframework.data.keyvalue.redis.connection.SortParameters
Returns the pattern (if set) for retrieving external keys (GET).
getGetPattern() - Method in interface org.springframework.data.keyvalue.redis.core.query.SortQuery
Returns the external key(s) whose values are returned by the sort.
getHashKeySerializer() - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
Returns the hashKeySerializer.
getHashValueSerializer() - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
Returns the hashValueSerializer.
getHost() - Method in class org.springframework.data.keyvalue.riak.core.AbstractRiakTemplate
 
getHostName() - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnectionFactory
Returns the Redis hostName.
getHostName() - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnectionFactory
Returns the Redis host name of this factory.
getHostName() - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnectionFactory
Returns the Redis hostName.
getIgnoreNotFound() - Method in class org.springframework.data.keyvalue.riak.core.AbstractRiakTemplate
 
getInputs() - Method in class org.springframework.data.keyvalue.riak.mapreduce.AbstractRiakMapReduceJob
 
getInputs() - Method in interface org.springframework.data.keyvalue.riak.mapreduce.MapReduceJob
Get the list of inputs for this job.
getInputStream() - Method in class org.springframework.data.keyvalue.riak.core.io.RiakResource
 
getJavaType(Class<?>) - Method in class org.springframework.data.keyvalue.redis.serializer.JacksonJsonRedisSerializer
Returns the Jackson JavaType for the specific class.
getJob() - Method in class org.springframework.data.keyvalue.riak.groovy.RiakMapReduceOperation
 
getKeepResults() - Method in interface org.springframework.data.keyvalue.riak.mapreduce.MapReducePhase
Whether or not to keep the result of this phase.
getKeepResults() - Method in class org.springframework.data.keyvalue.riak.mapreduce.RiakMapReducePhase
 
getKey() - Method in interface org.springframework.data.keyvalue.redis.core.BoundKeyOperations
Returns the key associated with this entity.
getKey() - Method in interface org.springframework.data.keyvalue.redis.core.query.SortQuery
Return the target key for sorting.
getKey() - Method in class org.springframework.data.keyvalue.redis.support.atomic.RedisAtomicInteger
 
getKey() - Method in class org.springframework.data.keyvalue.redis.support.atomic.RedisAtomicLong
 
getKey() - Method in class org.springframework.data.keyvalue.redis.support.collections.AbstractRedisCollection
 
getKey() - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisMap
 
getKey() - Method in class org.springframework.data.keyvalue.redis.support.collections.RedisProperties
 
getKey() - Method in interface org.springframework.data.keyvalue.riak.core.BucketKeyPair
Get the key representation.
getKey() - Method in class org.springframework.data.keyvalue.riak.core.io.RiakFile
 
getKey() - Method in class org.springframework.data.keyvalue.riak.core.io.RiakResource
 
getKey() - Method in interface org.springframework.data.keyvalue.riak.core.KeyValueStoreMetaData
 
getKey() - Method in class org.springframework.data.keyvalue.riak.core.RiakMetaData
 
getKey() - Method in class org.springframework.data.keyvalue.riak.core.SimpleBucketKeyPair
 
getKey() - Method in class org.springframework.data.keyvalue.riak.groovy.RiakOperation
 
getKeySerializer() - Method in interface org.springframework.data.keyvalue.redis.core.RedisOperations
 
getKeySerializer() - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
Returns the key serializer used by this template.
getLanguage() - Method in interface org.springframework.data.keyvalue.riak.mapreduce.MapReducePhase
The language this phase is described in.
getLanguage() - Method in class org.springframework.data.keyvalue.riak.mapreduce.RiakMapReducePhase
 
getLast() - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
 
getLastModified() - Method in interface org.springframework.data.keyvalue.riak.core.KeyValueStoreMetaData
 
getLastModified() - Method in class org.springframework.data.keyvalue.riak.core.RiakMetaData
 
getLimit() - Method in class org.springframework.data.keyvalue.redis.connection.DefaultSortParameters
 
getLimit() - Method in interface org.springframework.data.keyvalue.redis.connection.SortParameters
Returns the sorting limit (range or pagination).
getLimit() - Method in interface org.springframework.data.keyvalue.redis.core.query.SortQuery
Returns the sorting limit (range or pagination).
getListener() - Method in interface org.springframework.data.keyvalue.redis.connection.Subscription
Returns the listener used for this subscription.
getListener() - Method in class org.springframework.data.keyvalue.redis.connection.util.AbstractSubscription
 
getListenerMethodName(Message, Object) - Method in class org.springframework.data.keyvalue.redis.listener.adapter.MessageListenerAdapter
Determine the name of the listener method that is supposed to handle the given message.
getMapReduceUri() - Method in class org.springframework.data.keyvalue.riak.core.AbstractRiakTemplate
 
getMetaData(B, K) - Method in class org.springframework.data.keyvalue.riak.core.AsyncRiakTemplate
 
getMetaData() - Method in interface org.springframework.data.keyvalue.riak.core.KeyValueStoreValue
Get the metadata associated with this value.
getMetaData(K) - Method in class org.springframework.data.keyvalue.riak.core.RiakKeyValueTemplate
 
getMetaData(B, K) - Method in class org.springframework.data.keyvalue.riak.core.RiakTemplate
 
getMetaData() - Method in class org.springframework.data.keyvalue.riak.core.RiakValue
 
getName() - Method in class org.springframework.data.keyvalue.riak.core.io.RiakFile
 
getNativeConnection() - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
getNativeConnection() - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
getNativeConnection() - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
getNativeConnection() - Method in interface org.springframework.data.keyvalue.redis.connection.RedisConnection
Returns the native connection (the underlying library/driver object).
getNativeConnection() - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
getObject() - Method in class org.springframework.data.keyvalue.redis.support.collections.RedisCollectionFactoryBean
 
getObjectType() - Method in class org.springframework.data.keyvalue.redis.support.collections.RedisCollectionFactoryBean
 
getOperation() - Method in interface org.springframework.data.keyvalue.riak.mapreduce.MapReducePhase
Get the operation this phase will execute.
getOperation() - Method in class org.springframework.data.keyvalue.riak.mapreduce.RiakMapReducePhase
 
getOperations() - Method in interface org.springframework.data.keyvalue.redis.core.BoundHashOperations
 
getOperations() - Method in interface org.springframework.data.keyvalue.redis.core.BoundListOperations
 
getOperations() - Method in interface org.springframework.data.keyvalue.redis.core.BoundSetOperations
 
getOperations() - Method in interface org.springframework.data.keyvalue.redis.core.BoundValueOperations
 
getOperations() - Method in interface org.springframework.data.keyvalue.redis.core.BoundZSetOperations
 
getOperations() - Method in interface org.springframework.data.keyvalue.redis.core.HashOperations
 
getOperations() - Method in interface org.springframework.data.keyvalue.redis.core.ListOperations
 
getOperations() - Method in interface org.springframework.data.keyvalue.redis.core.SetOperations
 
getOperations() - Method in interface org.springframework.data.keyvalue.redis.core.ValueOperations
 
getOperations() - Method in interface org.springframework.data.keyvalue.redis.core.ZSetOperations
 
getOperations() - Method in class org.springframework.data.keyvalue.redis.support.collections.AbstractRedisCollection
 
getOperations() - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisMap
 
getOperations() - Method in class org.springframework.data.keyvalue.redis.support.collections.RedisProperties
 
getOperations() - Method in interface org.springframework.data.keyvalue.redis.support.collections.RedisStore
Returns the underlying Redis operations used by the backing implementation.
getOrder() - Method in class org.springframework.data.keyvalue.redis.connection.DefaultSortParameters
 
getOrder() - Method in interface org.springframework.data.keyvalue.redis.connection.SortParameters
Returns the sorting order.
getOrder() - Method in interface org.springframework.data.keyvalue.redis.core.query.SortQuery
Returns the sorting order.
getParent() - Method in class org.springframework.data.keyvalue.riak.core.io.RiakFile
 
getParentFile() - Method in class org.springframework.data.keyvalue.riak.core.io.RiakFile
 
getPassword() - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnectionFactory
Returns the password used for authenticating with the Redis server.
getPassword() - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnectionFactory
Returns the password used for authenticating with the Redis server.
getPassword() - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnectionFactory
Returns the password used for authenticating with the Redis server.
getPath() - Method in class org.springframework.data.keyvalue.riak.core.io.RiakFile
 
getPatterns() - Method in interface org.springframework.data.keyvalue.redis.connection.Subscription
Returns the channel patters for this subscription.
getPatterns() - Method in class org.springframework.data.keyvalue.redis.connection.util.AbstractSubscription
 
getPhase() - Method in class org.springframework.data.keyvalue.redis.listener.RedisMessageListenerContainer
 
getPhase() - Method in interface org.springframework.data.keyvalue.riak.mapreduce.MapReducePhase
 
getPhase() - Method in class org.springframework.data.keyvalue.riak.mapreduce.RiakMapReducePhase
 
getPhases() - Method in class org.springframework.data.keyvalue.riak.mapreduce.AbstractRiakMapReduceJob
 
getPhases() - Method in interface org.springframework.data.keyvalue.riak.mapreduce.MapReduceJob
Get the list of phases for this job.
getPoolConfig() - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnectionFactory
Returns the poolConfig.
getPoolSize() - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnectionFactory
Returns the pool size of this factory.
getPort() - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnectionFactory
Returns the port used to connect to the Redis instance.
getPort() - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnectionFactory
Returns the Redis port.
getPort() - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnectionFactory
Returns the port used to connect to the Redis instance.
getPort() - Method in class org.springframework.data.keyvalue.riak.core.AbstractRiakTemplate
 
getPrefix() - Method in class org.springframework.data.keyvalue.riak.core.AbstractRiakTemplate
Extract the prefix from the URI for use in creating links.
getProperties() - Method in interface org.springframework.data.keyvalue.riak.core.KeyValueStoreMetaData
Get the arbitrary properties for this object.
getProperties() - Method in class org.springframework.data.keyvalue.riak.core.RiakMetaData
 
getQosParameters() - Method in class org.springframework.data.keyvalue.riak.groovy.RiakOperation
 
getRange(byte[], long, long) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
getRange(String, long, long) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
getRange(byte[], long, long) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
getRange(byte[], long, long) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
getRange(byte[], long, long) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisStringCommands
 
getRange(byte[], long, long) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
getRange(String, long, long) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
getReadThreshold() - Method in interface org.springframework.data.keyvalue.riak.core.QosParameters
Instruct the server on the read threshold.
getReadThreshold() - Method in class org.springframework.data.keyvalue.riak.core.RiakQosParameters
 
getRepresentation() - Method in class org.springframework.data.keyvalue.riak.mapreduce.ErlangMapReduceOperation
 
getRepresentation() - Method in class org.springframework.data.keyvalue.riak.mapreduce.JavascriptMapReduceOperation
 
getRepresentation() - Method in interface org.springframework.data.keyvalue.riak.mapreduce.MapReduceOperation
Get the implementation-specific representation of a Map/Reduce operation.
getRequiredType() - Method in class org.springframework.data.keyvalue.riak.groovy.RiakOperation
 
getRiak() - Method in class org.springframework.data.keyvalue.riak.core.io.RiakFile
 
getRiakTemplate() - Method in class org.springframework.data.keyvalue.riak.core.io.RiakResource
 
getRiakTemplate() - Method in class org.springframework.data.keyvalue.riak.mapreduce.RiakMapReduceJob
 
getRiakTemplate() - Method in class org.springframework.data.keyvalue.riak.util.RiakClassLoader
 
getScore() - Method in class org.springframework.data.keyvalue.redis.connection.DefaultTuple
 
getScore() - Method in interface org.springframework.data.keyvalue.redis.connection.RedisZSetCommands.Tuple
 
getScore() - Method in interface org.springframework.data.keyvalue.redis.core.ZSetOperations.TypedTuple
 
getSet(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
getSet(String, String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
getSet(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
getSet(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
getSet(byte[], byte[]) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisStringCommands
 
getSet(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
getSet(String, String) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
getShardInfo() - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnectionFactory
Returns the shardInfo.
getSource() - Method in class org.springframework.data.keyvalue.riak.mapreduce.JavascriptMapReduceOperation
 
getStart() - Method in class org.springframework.data.keyvalue.redis.connection.SortParameters.Range
 
getStringSerializer() - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
Returns the stringSerializer.
getSubscription() - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
getSubscription() - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
getSubscription() - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
getSubscription() - Method in interface org.springframework.data.keyvalue.redis.connection.RedisPubSubCommands
Returns the current subscription for this connection or null if the connection is not subscribed.
getSubscription() - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
getTimeout() - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnectionFactory
Returns the timeout.
getTimeout() - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnectionFactory
Returns the timeout.
getTimeout() - Method in class org.springframework.data.keyvalue.riak.groovy.RiakMapReduceOperation
 
getTimeout() - Method in class org.springframework.data.keyvalue.riak.groovy.RiakOperation
 
getTopic() - Method in class org.springframework.data.keyvalue.redis.listener.ChannelTopic
Returns the topic name.
getTopic() - Method in class org.springframework.data.keyvalue.redis.listener.PatternTopic
 
getTopic() - Method in interface org.springframework.data.keyvalue.redis.listener.Topic
Returns the topic (as a String).
getTotalSpace() - Method in class org.springframework.data.keyvalue.riak.core.io.RiakFile
 
getType() - Method in interface org.springframework.data.keyvalue.redis.core.BoundKeyOperations
Returns the associated Redis type.
getType() - Method in class org.springframework.data.keyvalue.redis.support.atomic.RedisAtomicInteger
 
getType() - Method in class org.springframework.data.keyvalue.redis.support.atomic.RedisAtomicLong
 
getType() - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
 
getType() - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisMap
 
getType() - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisSet
 
getType() - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisZSet
 
getType() - Method in class org.springframework.data.keyvalue.redis.support.collections.RedisProperties
 
getType(B, K) - Method in class org.springframework.data.keyvalue.riak.core.AbstractRiakTemplate
 
getType(B, K, ClassLoader) - Method in class org.springframework.data.keyvalue.riak.core.AbstractRiakTemplate
 
getType() - Method in class org.springframework.data.keyvalue.riak.groovy.RiakOperation
 
getURI() - Method in class org.springframework.data.keyvalue.riak.core.io.RiakResource
 
getUriAsString(boolean) - Method in class org.springframework.data.keyvalue.riak.core.io.RiakFile
 
getURL() - Method in class org.springframework.data.keyvalue.riak.core.io.RiakResource
 
getUsableSpace() - Method in class org.springframework.data.keyvalue.riak.core.io.RiakFile
 
getUsePool() - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnectionFactory
Indicates the use of a connection pool.
getUsePool() - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnectionFactory
Indicates the use of a connection pool.
getUsePool() - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnectionFactory
Indicates the use of a connection pool.
getValue() - Method in class org.springframework.data.keyvalue.redis.connection.DefaultTuple
 
getValue() - Method in interface org.springframework.data.keyvalue.redis.connection.RedisZSetCommands.Tuple
 
getValue() - Method in interface org.springframework.data.keyvalue.redis.core.ZSetOperations.TypedTuple
 
getValue() - Method in class org.springframework.data.keyvalue.riak.groovy.RiakOperation
 
getValueAsString() - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringTuple
 
getValueAsString() - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection.StringTuple
 
getValues(List<K>) - Method in interface org.springframework.data.keyvalue.riak.core.KeyValueStoreOperations
Get all the values at the specified keys.
getValues(K...) - Method in interface org.springframework.data.keyvalue.riak.core.KeyValueStoreOperations
Variation on KeyValueStoreOperations.getValues(java.util.List) that uses varargs instead of a java.util.List.
getValues(List<K>) - Method in class org.springframework.data.keyvalue.riak.core.RiakKeyValueTemplate
 
getValues(K...) - Method in class org.springframework.data.keyvalue.riak.core.RiakKeyValueTemplate
 
getValues(List<K>) - Method in class org.springframework.data.keyvalue.riak.core.RiakTemplate
 
getValues(K...) - Method in class org.springframework.data.keyvalue.riak.core.RiakTemplate
 
getValuesAsType(List<K>, Class<T>) - Method in interface org.springframework.data.keyvalue.riak.core.KeyValueStoreOperations
Get all the values at the specified keys, converting the values into instances of the specified type.
getValuesAsType(Class<T>, K...) - Method in interface org.springframework.data.keyvalue.riak.core.KeyValueStoreOperations
A variation on KeyValueStoreOperations.getValuesAsType(java.util.List, Class) that takes uses varargs instead of a java.util.List.
getValuesAsType(List<K>, Class<T>) - Method in class org.springframework.data.keyvalue.riak.core.RiakKeyValueTemplate
 
getValuesAsType(Class<T>, K...) - Method in class org.springframework.data.keyvalue.riak.core.RiakKeyValueTemplate
 
getValuesAsType(List<K>, Class<T>) - Method in class org.springframework.data.keyvalue.riak.core.RiakTemplate
 
getValuesAsType(Class<T>, K...) - Method in class org.springframework.data.keyvalue.riak.core.RiakTemplate
 
getValueSerializer() - Method in interface org.springframework.data.keyvalue.redis.core.RedisOperations
 
getValueSerializer() - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
Returns the value serializer used by this template.
getWithMetaData(B, K, Class<T>, AsyncKeyValueStoreOperation<T, R>) - Method in class org.springframework.data.keyvalue.riak.core.AsyncRiakTemplate
 
getWithMetaData(K, Class<T>) - Method in class org.springframework.data.keyvalue.riak.core.RiakKeyValueTemplate
 
getWithMetaData(B, K, Class<T>) - Method in class org.springframework.data.keyvalue.riak.core.RiakTemplate
 
getWorkerPool() - Method in class org.springframework.data.keyvalue.riak.core.AbstractRiakTemplate
 
getWorkerPool() - Method in class org.springframework.data.keyvalue.riak.groovy.RiakBuilder
 
getWriteThreshold() - Method in interface org.springframework.data.keyvalue.riak.core.QosParameters
Instruct the server on the normal write threshold.
getWriteThreshold() - Method in class org.springframework.data.keyvalue.riak.core.RiakQosParameters
 
groovyPresent - Variable in class org.springframework.data.keyvalue.riak.core.AbstractRiakTemplate
Do we need to handle Groovy strings in the Jackson JSON processor?

H

handleError(ClientHttpResponse) - Method in class org.springframework.data.keyvalue.riak.util.Ignore404sErrorHandler
 
handleListenerException(Throwable) - Method in class org.springframework.data.keyvalue.redis.listener.adapter.MessageListenerAdapter
Handle the given exception that arose during listener execution.
handleListenerException(Throwable) - Method in class org.springframework.data.keyvalue.redis.listener.RedisMessageListenerContainer
Handle the given exception that arose during listener execution.
hasError(HttpStatus) - Method in class org.springframework.data.keyvalue.riak.util.Ignore404sErrorHandler
 
hashCode() - Method in class org.springframework.data.keyvalue.redis.connection.util.ByteArrayWrapper
 
hashCode() - Method in class org.springframework.data.keyvalue.redis.support.collections.AbstractRedisCollection
 
hashCode() - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisMap
 
hashCode() - Method in class org.springframework.data.keyvalue.redis.support.collections.RedisProperties
 
hashCode() - Method in class org.springframework.data.keyvalue.riak.core.io.RiakFile
 
HashMapper<T,K,V> - Interface in org.springframework.data.keyvalue.redis.hash
Core mapping contract between Java types and Redis hashes/maps.
HashOperations<H,HK,HV> - Interface in org.springframework.data.keyvalue.redis.core
Redis map specific operations working on a hash.
hasKey(Object) - Method in interface org.springframework.data.keyvalue.redis.core.BoundHashOperations
 
hasKey(H, Object) - Method in interface org.springframework.data.keyvalue.redis.core.HashOperations
 
hasKey(K) - Method in interface org.springframework.data.keyvalue.redis.core.RedisOperations
 
hasKey(K) - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
 
hDel(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
hDel(String, String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
hDel(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
hDel(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
hDel(byte[], byte[]) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisHashCommands
 
hDel(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
hDel(String, String) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
hExists(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
hExists(String, String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
hExists(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
hExists(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
hExists(byte[], byte[]) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisHashCommands
 
hExists(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
hExists(String, String) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
hGet(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
hGet(String, String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
hGet(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
hGet(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
hGet(byte[], byte[]) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisHashCommands
 
hGet(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
hGet(String, String) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
hGetAll(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
hGetAll(String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
hGetAll(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
hGetAll(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
hGetAll(byte[]) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisHashCommands
 
hGetAll(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
hGetAll(String) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
hIncrBy(byte[], byte[], long) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
hIncrBy(String, String, long) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
hIncrBy(byte[], byte[], long) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
hIncrBy(byte[], byte[], long) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
hIncrBy(byte[], byte[], long) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisHashCommands
 
hIncrBy(byte[], byte[], long) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
hIncrBy(String, String, long) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
hKeys(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
hKeys(String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
hKeys(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
hKeys(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
hKeys(byte[]) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisHashCommands
 
hKeys(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
hKeys(String) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
hLen(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
hLen(String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
hLen(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
hLen(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
hLen(byte[]) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisHashCommands
 
hLen(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
hLen(String) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
hMGet(byte[], byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
hMGet(String, String...) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
hMGet(byte[], byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
hMGet(byte[], byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
hMGet(byte[], byte[]...) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisHashCommands
 
hMGet(byte[], byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
hMGet(String, String...) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
hMSet(byte[], Map<byte[], byte[]>) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
hMSet(String, Map<String, String>) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
hMSet(byte[], Map<byte[], byte[]>) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
hMSet(byte[], Map<byte[], byte[]>) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
hMSet(byte[], Map<byte[], byte[]>) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisHashCommands
 
hMSet(byte[], Map<byte[], byte[]>) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
hMSet(String, Map<String, String>) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
hSet(byte[], byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
hSet(String, String, String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
hSet(byte[], byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
hSet(byte[], byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
hSet(byte[], byte[], byte[]) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisHashCommands
 
hSet(byte[], byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
hSet(String, String, String) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
hSetNX(byte[], byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
hSetNX(String, String, String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
hSetNX(byte[], byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
hSetNX(byte[], byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
hSetNX(byte[], byte[], byte[]) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisHashCommands
 
hSetNX(byte[], byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
hSetNX(String, String, String) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
httpDate - Static variable in class org.springframework.data.keyvalue.riak.core.AbstractRiakTemplate
For getting a java.util.Date from the Last-Modified header.
hVals(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
hVals(String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
hVals(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
hVals(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
hVals(byte[]) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisHashCommands
 
hVals(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
hVals(String) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 

I

Ignore404sErrorHandler - Class in org.springframework.data.keyvalue.riak.util
 
Ignore404sErrorHandler() - Constructor for class org.springframework.data.keyvalue.riak.util.Ignore404sErrorHandler
 
incr(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
incr(String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
incr(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
incr(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
incr(byte[]) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisStringCommands
 
incr(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
incr(String) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
incrBy(byte[], long) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
incrBy(String, long) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
incrBy(byte[], long) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
incrBy(byte[], long) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
incrBy(byte[], long) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisStringCommands
 
incrBy(byte[], long) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
incrBy(String, long) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
increment(HK, long) - Method in interface org.springframework.data.keyvalue.redis.core.BoundHashOperations
 
increment(long) - Method in interface org.springframework.data.keyvalue.redis.core.BoundValueOperations
 
increment(H, HK, long) - Method in interface org.springframework.data.keyvalue.redis.core.HashOperations
 
increment(K, long) - Method in interface org.springframework.data.keyvalue.redis.core.ValueOperations
 
increment(K, long) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisMap
 
increment(K, long) - Method in interface org.springframework.data.keyvalue.redis.support.collections.RedisMap
 
increment(Object, long) - Method in class org.springframework.data.keyvalue.redis.support.collections.RedisProperties
 
incrementAndGet() - Method in class org.springframework.data.keyvalue.redis.support.atomic.RedisAtomicInteger
Atomically increment by one the current value.
incrementAndGet() - Method in class org.springframework.data.keyvalue.redis.support.atomic.RedisAtomicLong
Atomically increments by one the current value.
incrementScore(V, double) - Method in interface org.springframework.data.keyvalue.redis.core.BoundZSetOperations
 
incrementScore(K, V, double) - Method in interface org.springframework.data.keyvalue.redis.core.ZSetOperations
 
index(long) - Method in interface org.springframework.data.keyvalue.redis.core.BoundListOperations
 
index(K, long) - Method in interface org.springframework.data.keyvalue.redis.core.ListOperations
 
indexOf(Object) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
 
info() - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
info() - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
info() - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
info() - Method in interface org.springframework.data.keyvalue.redis.connection.RedisServerCommands
 
info() - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
init(RiakTemplate) - Method in class org.springframework.data.keyvalue.riak.util.RiakClassLoader
 
initDefaultStrategies() - Method in class org.springframework.data.keyvalue.redis.listener.adapter.MessageListenerAdapter
Initialize the default implementations for the adapter's strategies.
inputs - Variable in class org.springframework.data.keyvalue.riak.mapreduce.AbstractRiakMapReduceJob
 
intersect(K) - Method in interface org.springframework.data.keyvalue.redis.core.BoundSetOperations
 
intersect(Collection<K>) - Method in interface org.springframework.data.keyvalue.redis.core.BoundSetOperations
 
intersect(K, K) - Method in interface org.springframework.data.keyvalue.redis.core.SetOperations
 
intersect(K, Collection<K>) - Method in interface org.springframework.data.keyvalue.redis.core.SetOperations
 
intersect(RedisSet<?>) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisSet
 
intersect(Collection<? extends RedisSet<?>>) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisSet
 
intersect(RedisSet<?>) - Method in interface org.springframework.data.keyvalue.redis.support.collections.RedisSet
 
intersect(Collection<? extends RedisSet<?>>) - Method in interface org.springframework.data.keyvalue.redis.support.collections.RedisSet
 
intersectAndStore(K, K) - Method in interface org.springframework.data.keyvalue.redis.core.BoundSetOperations
 
intersectAndStore(Collection<K>, K) - Method in interface org.springframework.data.keyvalue.redis.core.BoundSetOperations
 
intersectAndStore(K, K) - Method in interface org.springframework.data.keyvalue.redis.core.BoundZSetOperations
 
intersectAndStore(Collection<K>, K) - Method in interface org.springframework.data.keyvalue.redis.core.BoundZSetOperations
 
intersectAndStore(K, K, K) - Method in interface org.springframework.data.keyvalue.redis.core.SetOperations
 
intersectAndStore(K, Collection<K>, K) - Method in interface org.springframework.data.keyvalue.redis.core.SetOperations
 
intersectAndStore(K, K, K) - Method in interface org.springframework.data.keyvalue.redis.core.ZSetOperations
 
intersectAndStore(K, Collection<K>, K) - Method in interface org.springframework.data.keyvalue.redis.core.ZSetOperations
 
intersectAndStore(RedisSet<?>, String) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisSet
 
intersectAndStore(Collection<? extends RedisSet<?>>, String) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisSet
 
intersectAndStore(RedisZSet<?>, String) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisZSet
 
intersectAndStore(Collection<? extends RedisZSet<?>>, String) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisZSet
 
intersectAndStore(RedisSet<?>, String) - Method in interface org.springframework.data.keyvalue.redis.support.collections.RedisSet
 
intersectAndStore(Collection<? extends RedisSet<?>>, String) - Method in interface org.springframework.data.keyvalue.redis.support.collections.RedisSet
 
intersectAndStore(RedisZSet<?>, String) - Method in interface org.springframework.data.keyvalue.redis.support.collections.RedisZSet
 
intersectAndStore(Collection<? extends RedisZSet<?>>, String) - Method in interface org.springframework.data.keyvalue.redis.support.collections.RedisZSet
 
intValue() - Method in class org.springframework.data.keyvalue.redis.support.atomic.RedisAtomicInteger
 
intValue() - Method in class org.springframework.data.keyvalue.redis.support.atomic.RedisAtomicLong
 
invokeErrorHandler(Throwable) - Method in class org.springframework.data.keyvalue.redis.listener.RedisMessageListenerContainer
Invoke the registered ErrorHandler, if any.
invokeListenerMethod(String, Object[]) - Method in class org.springframework.data.keyvalue.redis.listener.adapter.MessageListenerAdapter
Invoke the specified listener method.
invokeMethod(String, Object) - Method in class org.springframework.data.keyvalue.riak.groovy.RiakBuilder
 
isAbsolute() - Method in class org.springframework.data.keyvalue.riak.core.io.RiakFile
 
isActive() - Method in class org.springframework.data.keyvalue.redis.listener.RedisMessageListenerContainer
Return whether this container is currently active, that is, whether it has been set up but not shut down yet.
isAlive() - Method in interface org.springframework.data.keyvalue.redis.connection.Subscription
Indicates whether this subscription is still 'alive' or not.
isAlive() - Method in class org.springframework.data.keyvalue.redis.connection.util.AbstractSubscription
 
isAlphabetic() - Method in class org.springframework.data.keyvalue.redis.connection.DefaultSortParameters
 
isAlphabetic() - Method in interface org.springframework.data.keyvalue.redis.connection.SortParameters
Indicates if the sorting is numeric (default) or alphabetical (lexicographical).
isAlphabetic() - Method in interface org.springframework.data.keyvalue.redis.core.query.SortQuery
Indicates if the sorting is numeric (default) or alphabetical (lexicographical).
isAutoStartup() - Method in class org.springframework.data.keyvalue.redis.listener.RedisMessageListenerContainer
 
isClosed() - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
isClosed() - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
isClosed() - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
isClosed() - Method in interface org.springframework.data.keyvalue.redis.connection.RedisConnection
Indicates whether the underlying connection is closed or not.
isClosed() - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
isConnectionTransactional(RedisConnection, RedisConnectionFactory) - Static method in class org.springframework.data.keyvalue.redis.core.RedisConnectionUtils
Return whether the given Redis connection is transactional, that is, bound to the current thread by Spring's transaction facilities.
isDirectory() - Method in class org.springframework.data.keyvalue.riak.core.io.RiakFile
 
isEmpty() - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisMap
 
isEmpty() - Method in class org.springframework.data.keyvalue.redis.support.collections.RedisProperties
 
isExposeConnection() - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
Returns whether to expose the native Redis connection to RedisCallback code, or rather a connection proxy (the default).
isFile() - Method in class org.springframework.data.keyvalue.riak.core.io.RiakFile
 
isHidden() - Method in class org.springframework.data.keyvalue.riak.core.io.RiakFile
 
isMember(Object) - Method in interface org.springframework.data.keyvalue.redis.core.BoundSetOperations
 
isMember(K, Object) - Method in interface org.springframework.data.keyvalue.redis.core.SetOperations
 
isPipelined() - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
isPipelined() - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
isPipelined() - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
isPipelined() - Method in interface org.springframework.data.keyvalue.redis.connection.RedisConnection
Indicates whether the connection is currently pipelined or not.
isPipelined() - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
isQueueing() - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
isQueueing() - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
isQueueing() - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
isQueueing() - Method in interface org.springframework.data.keyvalue.redis.connection.RedisConnection
Indicates whether the connection is in "queue"(or "MULTI") mode or not.
isQueueing() - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
isRunning() - Method in class org.springframework.data.keyvalue.redis.listener.RedisMessageListenerContainer
 
isSingleton() - Method in class org.springframework.data.keyvalue.redis.support.collections.RedisCollectionFactoryBean
 
isSubscribed() - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
isSubscribed() - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
isSubscribed() - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
isSubscribed() - Method in interface org.springframework.data.keyvalue.redis.connection.RedisPubSubCommands
Indicates whether the current connection is subscribed (to at least one channel) or not.
isSubscribed() - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
isUseCache() - Method in class org.springframework.data.keyvalue.riak.core.AbstractRiakTemplate
 
iterator() - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
 
iterator() - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisSet
 
iterator() - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisZSet
 

J

JacksonHashMapper<T> - Class in org.springframework.data.keyvalue.redis.hash
Mapper based on Jackson library.
JacksonHashMapper(Class<T>) - Constructor for class org.springframework.data.keyvalue.redis.hash.JacksonHashMapper
 
JacksonHashMapper(Class<T>, ObjectMapper) - Constructor for class org.springframework.data.keyvalue.redis.hash.JacksonHashMapper
 
JacksonJsonRedisSerializer<T> - Class in org.springframework.data.keyvalue.redis.serializer
RedisSerializer that can read and write JSON using Jackson's ObjectMapper.
JacksonJsonRedisSerializer(Class<T>) - Constructor for class org.springframework.data.keyvalue.redis.serializer.JacksonJsonRedisSerializer
 
JavascriptMapReduceOperation - Class in org.springframework.data.keyvalue.riak.mapreduce
An implementation of MapReduceOperation to describe a Javascript language M/R function.
JavascriptMapReduceOperation(String) - Constructor for class org.springframework.data.keyvalue.riak.mapreduce.JavascriptMapReduceOperation
 
JavascriptMapReduceOperation(BucketKeyPair) - Constructor for class org.springframework.data.keyvalue.riak.mapreduce.JavascriptMapReduceOperation
 
JdkSerializationRedisSerializer - Class in org.springframework.data.keyvalue.redis.serializer
Java Serialization Redis serializer.
JdkSerializationRedisSerializer() - Constructor for class org.springframework.data.keyvalue.redis.serializer.JdkSerializationRedisSerializer
 
JedisConnection - Class in org.springframework.data.keyvalue.redis.connection.jedis
RedisConnection implementation on top of Jedis library.
JedisConnection(Jedis) - Constructor for class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
Constructs a new JedisConnection instance.
JedisConnection(Jedis, Pool<Jedis>, int) - Constructor for class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
Constructs a new JedisConnection instance backed by a jedis pool.
JedisConnectionFactory - Class in org.springframework.data.keyvalue.redis.connection.jedis
Connection factory creating Jedis based connections.
JedisConnectionFactory() - Constructor for class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnectionFactory
Constructs a new JedisConnectionFactory instance with default settings (default connection pooling, no shard information).
JedisConnectionFactory(JedisShardInfo) - Constructor for class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnectionFactory
Constructs a new JedisConnectionFactory instance.
JedisConnectionFactory(JedisPoolConfig) - Constructor for class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnectionFactory
Constructs a new JedisConnectionFactory instance using the given pool configuration.
JedisUtils - Class in org.springframework.data.keyvalue.redis.connection.jedis
Helper class featuring methods for Jedis connection handling, providing support for exception translation.
JedisUtils() - Constructor for class org.springframework.data.keyvalue.redis.connection.jedis.JedisUtils
 
job - Variable in class org.springframework.data.keyvalue.riak.groovy.RiakMapReduceOperation
 
JredisConnection - Class in org.springframework.data.keyvalue.redis.connection.jredis
RedisConnection implementation on top of JRedis library.
JredisConnection(JRedis) - Constructor for class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
Constructs a new JredisConnection instance.
JredisConnectionFactory - Class in org.springframework.data.keyvalue.redis.connection.jredis
Connection factory using creating JRedis based connections.
JredisConnectionFactory() - Constructor for class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnectionFactory
Constructs a new JredisConnectionFactory instance.
JredisConnectionFactory(ConnectionSpec) - Constructor for class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnectionFactory
Constructs a new JredisConnectionFactory instance.
JredisUtils - Class in org.springframework.data.keyvalue.redis.connection.jredis
Helper class featuring methods for JRedis connection handling, providing support for exception translation.
JredisUtils() - Constructor for class org.springframework.data.keyvalue.redis.connection.jredis.JredisUtils
 

K

keepResults - Variable in class org.springframework.data.keyvalue.riak.mapreduce.RiakMapReducePhase
 
key - Variable in class org.springframework.data.keyvalue.riak.groovy.RiakOperation
 
keys(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
keys(String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
keys(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
keys(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
keys(byte[]) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisKeyCommands
 
keys(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
keys(String) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
keys() - Method in interface org.springframework.data.keyvalue.redis.core.BoundHashOperations
 
keys(H) - Method in interface org.springframework.data.keyvalue.redis.core.HashOperations
 
keys(K) - Method in interface org.springframework.data.keyvalue.redis.core.RedisOperations
 
keys(K) - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
 
keys() - Method in class org.springframework.data.keyvalue.redis.support.collections.RedisProperties
 
keySet() - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisMap
 
keySet() - Method in class org.springframework.data.keyvalue.redis.support.collections.RedisProperties
 
KeyValueStoreMetaData - Annotation Type in org.springframework.data.keyvalue.riak.convert
Specify the bucket in which to store the annotated object, overriding the default classname method of deriving bucket name.
KeyValueStoreMetaData - Interface in org.springframework.data.keyvalue.riak.core
A generic interface to MetaData provided by Key/Value data stores.
KeyValueStoreOperations - Interface in org.springframework.data.keyvalue.riak.core
Generic abstraction for Key/Value stores.
KeyValueStoreValue<T> - Interface in org.springframework.data.keyvalue.riak.core
A generic interface for dealing with values and their store metadata.

L

language - Variable in class org.springframework.data.keyvalue.riak.mapreduce.ErlangMapReduceOperation
 
language - Variable in class org.springframework.data.keyvalue.riak.mapreduce.RiakMapReducePhase
 
last() - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisZSet
 
last() - Method in interface org.springframework.data.keyvalue.redis.support.collections.RedisZSet
Returns the last (highest) element currently in this sorted set.
lastIndexOf(Object) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
 
lastModified() - Method in class org.springframework.data.keyvalue.riak.core.io.RiakFile
 
lastSave() - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
lastSave() - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
lastSave() - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
lastSave() - Method in interface org.springframework.data.keyvalue.redis.connection.RedisServerCommands
 
lastSave() - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
leftPop() - Method in interface org.springframework.data.keyvalue.redis.core.BoundListOperations
 
leftPop(long, TimeUnit) - Method in interface org.springframework.data.keyvalue.redis.core.BoundListOperations
 
leftPop(K) - Method in interface org.springframework.data.keyvalue.redis.core.ListOperations
 
leftPop(K, long, TimeUnit) - Method in interface org.springframework.data.keyvalue.redis.core.ListOperations
 
leftPush(V) - Method in interface org.springframework.data.keyvalue.redis.core.BoundListOperations
 
leftPush(V, V) - Method in interface org.springframework.data.keyvalue.redis.core.BoundListOperations
 
leftPush(K, V) - Method in interface org.springframework.data.keyvalue.redis.core.ListOperations
 
leftPush(K, V, V) - Method in interface org.springframework.data.keyvalue.redis.core.ListOperations
 
leftPushIfPresent(V) - Method in interface org.springframework.data.keyvalue.redis.core.BoundListOperations
 
leftPushIfPresent(K, V) - Method in interface org.springframework.data.keyvalue.redis.core.ListOperations
 
length() - Method in class org.springframework.data.keyvalue.riak.core.io.RiakFile
 
limit(long, long) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultSortParameters
 
limit(long, long) - Method in interface org.springframework.data.keyvalue.redis.core.query.SortCriterion
 
limit(SortParameters.Range) - Method in interface org.springframework.data.keyvalue.redis.core.query.SortCriterion
 
lIndex(byte[], long) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
lIndex(String, long) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
lIndex(byte[], long) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
lIndex(byte[], long) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
lIndex(byte[], long) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisListCommands
 
lIndex(byte[], long) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
lIndex(String, long) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
link(K1, K2, String) - Method in class org.springframework.data.keyvalue.riak.core.RiakKeyValueTemplate
Use Riak's native Link mechanism to link two entries together.
link(B1, K1, B2, K2, String) - Method in class org.springframework.data.keyvalue.riak.core.RiakTemplate
Use Riak's native Link mechanism to link two entries together.
linkWalk(K, String) - Method in class org.springframework.data.keyvalue.riak.core.RiakKeyValueTemplate
Use Riak's link walking mechanism to retrieve a multipart message that will be decoded like they were individual objects (e.g. using the built-in HttpMessageConverters of RestTemplate).
linkWalk(B, K, String) - Method in class org.springframework.data.keyvalue.riak.core.RiakTemplate
Use Riak's link walking mechanism to retrieve a multipart message that will be decoded like they were individual objects (e.g. using the built-in HttpMessageConverters of RestTemplate).
linkWalkAsType(B, K, String, Class<T>) - Method in class org.springframework.data.keyvalue.riak.core.RiakTemplate
Use Riak's link walking mechanism to retrieve a multipart message that will be decoded like they were individual objects (e.g. using the built-in HttpMessageConverters of RestTemplate) and return the result as a list of objects of one of: The type specified by requiredType If that's null, try using the bucket name in which the object was stored If all else fails, use a Map
lInsert(byte[], RedisListCommands.Position, byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
lInsert(String, RedisListCommands.Position, String, String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
lInsert(byte[], RedisListCommands.Position, byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
lInsert(byte[], RedisListCommands.Position, byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
lInsert(byte[], RedisListCommands.Position, byte[], byte[]) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisListCommands
 
lInsert(byte[], RedisListCommands.Position, byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
lInsert(String, RedisListCommands.Position, String, String) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
list() - Method in class org.springframework.data.keyvalue.riak.core.io.RiakFile
 
list(FilenameFilter) - Method in class org.springframework.data.keyvalue.riak.core.io.RiakFile
 
listFiles() - Method in class org.springframework.data.keyvalue.riak.core.io.RiakFile
 
listFiles(FilenameFilter) - Method in class org.springframework.data.keyvalue.riak.core.io.RiakFile
 
listFiles(FileFilter) - Method in class org.springframework.data.keyvalue.riak.core.io.RiakFile
 
listIterator() - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
 
listIterator(int) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
 
ListOperations<K,V> - Interface in org.springframework.data.keyvalue.redis.core
Redis list specific operations.
lLen(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
lLen(String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
lLen(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
lLen(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
lLen(byte[]) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisListCommands
 
lLen(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
lLen(String) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
loadBucketsFromClassPath() - Method in class org.springframework.data.keyvalue.riak.util.RiakClassLoader
 
log - Variable in class org.springframework.data.keyvalue.riak.core.AbstractRiakTemplate
 
log - Variable in class org.springframework.data.keyvalue.riak.core.io.RiakFile
 
log - Variable in class org.springframework.data.keyvalue.riak.core.io.RiakResource
 
log - Variable in class org.springframework.data.keyvalue.riak.groovy.RiakBuilder
 
log - Variable in class org.springframework.data.keyvalue.riak.groovy.RiakMapReduceOperation
 
log - Variable in class org.springframework.data.keyvalue.riak.groovy.RiakOperation
 
log - Variable in class org.springframework.data.keyvalue.riak.mapreduce.AbstractRiakMapReduceJob
 
log - Variable in class org.springframework.data.keyvalue.riak.util.RiakClassLoader
 
logger - Variable in class org.springframework.data.keyvalue.redis.core.RedisAccessor
Logger available to subclasses
logger - Variable in class org.springframework.data.keyvalue.redis.listener.adapter.MessageListenerAdapter
Logger available to subclasses
logger - Variable in class org.springframework.data.keyvalue.redis.listener.RedisMessageListenerContainer
Logger available to subclasses
longValue() - Method in class org.springframework.data.keyvalue.redis.support.atomic.RedisAtomicInteger
 
longValue() - Method in class org.springframework.data.keyvalue.redis.support.atomic.RedisAtomicLong
 
lPop(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
lPop(String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
lPop(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
lPop(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
lPop(byte[]) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisListCommands
 
lPop(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
lPop(String) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
lPush(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
lPush(String, String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
lPush(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
lPush(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
lPush(byte[], byte[]) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisListCommands
 
lPush(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
lPush(String, String) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
lPushX(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
lPushX(String, String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
lPushX(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
lPushX(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
lPushX(byte[], byte[]) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisListCommands
 
lPushX(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
lPushX(String, String) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
lRange(byte[], long, long) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
lRange(String, long, long) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
lRange(byte[], long, long) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
lRange(byte[], long, long) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
lRange(byte[], long, long) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisListCommands
 
lRange(byte[], long, long) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
lRange(String, long, long) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
lRem(byte[], long, byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
lRem(String, long, String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
lRem(byte[], long, byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
lRem(byte[], long, byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
lRem(byte[], long, byte[]) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisListCommands
 
lRem(byte[], long, byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
lRem(String, long, String) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
lSet(byte[], long, byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
lSet(String, long, String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
lSet(byte[], long, byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
lSet(byte[], long, byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
lSet(byte[], long, byte[]) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisListCommands
 
lSet(byte[], long, byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
lSet(String, long, String) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
lTrim(byte[], long, long) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
lTrim(String, long, long) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
lTrim(byte[], long, long) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
lTrim(byte[], long, long) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
lTrim(byte[], long, long) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisListCommands
 
lTrim(byte[], long, long) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
lTrim(String, long, long) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 

M

main(String[]) - Static method in class org.springframework.data.keyvalue.riak.util.RiakClassFileLoader
 
mapBulk(List<V>) - Method in interface org.springframework.data.keyvalue.redis.core.BulkMapper
 
MapReduceJob<T> - Interface in org.springframework.data.keyvalue.riak.mapreduce
A generic interface to representing a Map/Reduce job to a data store that supports that operation.
MapReduceOperation - Interface in org.springframework.data.keyvalue.riak.mapreduce
A generic interface to a Map/Reduce operation.
MapReduceOperations - Interface in org.springframework.data.keyvalue.riak.mapreduce
Generic interface to Map/Reduce in data stores that support it.
MapReducePhase - Interface in org.springframework.data.keyvalue.riak.mapreduce
A generic interface to the phases of Map/Reduce jobs.
MapReducePhase.Phase - Enum in org.springframework.data.keyvalue.riak.mapreduce
 
mapReduceUri - Variable in class org.springframework.data.keyvalue.riak.core.AbstractRiakTemplate
The URI for the Riak Map/Reduce API.
mark(int) - Method in class org.springframework.data.keyvalue.riak.core.io.RiakInputStream
 
markSupported() - Method in class org.springframework.data.keyvalue.riak.core.io.RiakInputStream
 
members() - Method in interface org.springframework.data.keyvalue.redis.core.BoundSetOperations
 
members(K) - Method in interface org.springframework.data.keyvalue.redis.core.SetOperations
 
Message - Interface in org.springframework.data.keyvalue.redis.connection
Class encapsulating a Redis message body and its properties.
MessageListener - Interface in org.springframework.data.keyvalue.redis.connection
Listener of messages published in Redis.
MessageListenerAdapter - Class in org.springframework.data.keyvalue.redis.listener.adapter
Message listener adapter that delegates the handling of messages to target listener methods via reflection, with flexible message type conversion.
MessageListenerAdapter() - Constructor for class org.springframework.data.keyvalue.redis.listener.adapter.MessageListenerAdapter
Create a new MessageListenerAdapter with default settings.
MessageListenerAdapter(Object) - Constructor for class org.springframework.data.keyvalue.redis.listener.adapter.MessageListenerAdapter
Create a new MessageListenerAdapter for the given delegate.
mGet(byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
mGet(String...) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
mGet(byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
mGet(byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
mGet(byte[]...) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisStringCommands
 
mGet(byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
mGet(String...) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
mkdir() - Method in class org.springframework.data.keyvalue.riak.core.io.RiakFile
 
mkdirs() - Method in class org.springframework.data.keyvalue.riak.core.io.RiakFile
 
moduleFunction - Variable in class org.springframework.data.keyvalue.riak.mapreduce.ErlangMapReduceOperation
 
move(byte[], int) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
move(String, int) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
move(byte[], int) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
move(byte[], int) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
move(byte[], int) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisKeyCommands
 
move(byte[], int) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
move(String, int) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
move(K, V) - Method in interface org.springframework.data.keyvalue.redis.core.BoundSetOperations
 
move(K, int) - Method in interface org.springframework.data.keyvalue.redis.core.RedisOperations
 
move(K, int) - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
 
move(K, V, K) - Method in interface org.springframework.data.keyvalue.redis.core.SetOperations
 
mSet(Map<byte[], byte[]>) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
mSet(Map<byte[], byte[]>) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
mSet(Map<byte[], byte[]>) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
mSet(Map<byte[], byte[]>) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisStringCommands
 
mSet(Map<byte[], byte[]>) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
mSetNX(Map<byte[], byte[]>) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
mSetNX(Map<byte[], byte[]>) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
mSetNX(Map<byte[], byte[]>) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
mSetNX(Map<byte[], byte[]>) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisStringCommands
 
mSetNX(Map<byte[], byte[]>) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
mSetNXString(Map<String, String>) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
mSetNXString(Map<String, String>) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
mSetString(Map<String, String>) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
mSetString(Map<String, String>) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
multi() - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
multi() - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
multi() - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
multi() - Method in interface org.springframework.data.keyvalue.redis.connection.RedisTxCommands
 
multi() - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
multi() - Method in interface org.springframework.data.keyvalue.redis.core.RedisOperations
'
multi() - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
 
multiGet(Collection<HK>) - Method in interface org.springframework.data.keyvalue.redis.core.BoundHashOperations
 
multiGet(H, Collection<HK>) - Method in interface org.springframework.data.keyvalue.redis.core.HashOperations
 
multiGet(Collection<K>) - Method in interface org.springframework.data.keyvalue.redis.core.ValueOperations
 
multiSet(Map<? extends K, ? extends V>) - Method in interface org.springframework.data.keyvalue.redis.core.ValueOperations
 
multiSetIfAbsent(Map<? extends K, ? extends V>) - Method in interface org.springframework.data.keyvalue.redis.core.ValueOperations
 

N

nodeCompleted(Object, Object) - Method in class org.springframework.data.keyvalue.riak.groovy.RiakBuilder
 
noSort() - Method in class org.springframework.data.keyvalue.redis.core.query.SortQueryBuilder
 
numeric() - Method in class org.springframework.data.keyvalue.redis.connection.DefaultSortParameters
 

O

offer(E) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
 
offer(E, long, TimeUnit) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
 
offerFirst(E) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
 
offerFirst(E, long, TimeUnit) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
 
offerLast(E) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
 
offerLast(E, long, TimeUnit) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
 
onMessage(Message, byte[]) - Method in interface org.springframework.data.keyvalue.redis.connection.MessageListener
Callback for processing received objects through Redis.
onMessage(Message, byte[]) - Method in class org.springframework.data.keyvalue.redis.listener.adapter.MessageListenerAdapter
Standard Redis MessageListener entry point.
openPipeline() - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
openPipeline() - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
openPipeline() - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
openPipeline() - Method in interface org.springframework.data.keyvalue.redis.connection.RedisConnection
Activates the pipeline mode for this connection.
openPipeline() - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
operation - Variable in class org.springframework.data.keyvalue.riak.mapreduce.RiakMapReducePhase
 
opsForHash() - Method in interface org.springframework.data.keyvalue.redis.core.RedisOperations
Returns the operations performed on hash values.
opsForHash() - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
 
opsForList() - Method in interface org.springframework.data.keyvalue.redis.core.RedisOperations
Returns the operations performed on list values.
opsForList() - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
 
opsForSet() - Method in interface org.springframework.data.keyvalue.redis.core.RedisOperations
Returns the operations performed on set values.
opsForSet() - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
 
opsForValue() - Method in interface org.springframework.data.keyvalue.redis.core.RedisOperations
Returns the operations performed on simple values (or Strings in Redis terminology).
opsForValue() - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
 
opsForZSet() - Method in interface org.springframework.data.keyvalue.redis.core.RedisOperations
Returns the operations performed on zset values (also known as sorted sets).
opsForZSet() - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
 
order(SortParameters.Order) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultSortParameters
 
order(SortParameters.Order) - Method in interface org.springframework.data.keyvalue.redis.core.query.SortCriterion
 
org.springframework.data.keyvalue - package org.springframework.data.keyvalue
 
org.springframework.data.keyvalue.redis - package org.springframework.data.keyvalue.redis
Root package for integrating Redis with Spring concepts.
org.springframework.data.keyvalue.redis.connection - package org.springframework.data.keyvalue.redis.connection
Connection package providing low-level abstractions for interacting with the various Redis 'drivers'/libraries.
org.springframework.data.keyvalue.redis.connection.jedis - package org.springframework.data.keyvalue.redis.connection.jedis
Connection package for Jedis library.
org.springframework.data.keyvalue.redis.connection.jredis - package org.springframework.data.keyvalue.redis.connection.jredis
Connection package for JRedis library.
org.springframework.data.keyvalue.redis.connection.rjc - package org.springframework.data.keyvalue.redis.connection.rjc
Connection package for RJC library.
org.springframework.data.keyvalue.redis.connection.util - package org.springframework.data.keyvalue.redis.connection.util
Internal utility package for encoding/decoding Strings to byte[] (using Base64) library.
org.springframework.data.keyvalue.redis.core - package org.springframework.data.keyvalue.redis.core
Core package for integrating Redis with Spring concepts.
org.springframework.data.keyvalue.redis.core.query - package org.springframework.data.keyvalue.redis.core.query
Query package for Redis template.
org.springframework.data.keyvalue.redis.hash - package org.springframework.data.keyvalue.redis.hash
Dedicated support package for Redis hashes.
org.springframework.data.keyvalue.redis.listener - package org.springframework.data.keyvalue.redis.listener
Base package for Redis message listener / pubsub container facility
org.springframework.data.keyvalue.redis.listener.adapter - package org.springframework.data.keyvalue.redis.listener.adapter
Message listener adapter package.
org.springframework.data.keyvalue.redis.serializer - package org.springframework.data.keyvalue.redis.serializer
Serialization/Deserialization package for converting Object to (and from) binary data.
org.springframework.data.keyvalue.redis.support - package org.springframework.data.keyvalue.redis.support
Classes supporting the Redis packages, such as collection or atomic counters.
org.springframework.data.keyvalue.redis.support.atomic - package org.springframework.data.keyvalue.redis.support.atomic
Small toolkit mirroring the java.util.atomic package in Redis.
org.springframework.data.keyvalue.redis.support.collections - package org.springframework.data.keyvalue.redis.support.collections
Package providing implementations for most of the java.util collections on top of Redis.
org.springframework.data.keyvalue.riak - package org.springframework.data.keyvalue.riak
 
org.springframework.data.keyvalue.riak.convert - package org.springframework.data.keyvalue.riak.convert
 
org.springframework.data.keyvalue.riak.core - package org.springframework.data.keyvalue.riak.core
 
org.springframework.data.keyvalue.riak.core.io - package org.springframework.data.keyvalue.riak.core.io
 
org.springframework.data.keyvalue.riak.groovy - package org.springframework.data.keyvalue.riak.groovy
 
org.springframework.data.keyvalue.riak.mapreduce - package org.springframework.data.keyvalue.riak.mapreduce
 
org.springframework.data.keyvalue.riak.util - package org.springframework.data.keyvalue.riak.util
 
ORIGINAL_DEFAULT_LISTENER_METHOD - Static variable in class org.springframework.data.keyvalue.redis.listener.adapter.MessageListenerAdapter
Out-of-the-box value for the default listener method: "handleMessage".
OxmSerializer - Class in org.springframework.data.keyvalue.redis.serializer
Serializer adapter on top of Spring's O/X Mapping.
OxmSerializer() - Constructor for class org.springframework.data.keyvalue.redis.serializer.OxmSerializer
 
OxmSerializer(Marshaller, Unmarshaller) - Constructor for class org.springframework.data.keyvalue.redis.serializer.OxmSerializer
 

P

PatternTopic - Class in org.springframework.data.keyvalue.redis.listener
Pattern topic (matching multiple channels).
PatternTopic(String) - Constructor for class org.springframework.data.keyvalue.redis.listener.PatternTopic
 
peek() - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
 
peekFirst() - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
 
peekLast() - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
 
persist(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
persist(String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
persist(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
persist(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
persist(byte[]) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisKeyCommands
 
persist(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
persist(String) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
persist() - Method in interface org.springframework.data.keyvalue.redis.core.BoundKeyOperations
Removes the expiration (if any) of the key.
persist(K) - Method in interface org.springframework.data.keyvalue.redis.core.RedisOperations
 
persist(K) - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
 
persist() - Method in class org.springframework.data.keyvalue.redis.support.atomic.RedisAtomicInteger
 
persist() - Method in class org.springframework.data.keyvalue.redis.support.atomic.RedisAtomicLong
 
persist() - Method in class org.springframework.data.keyvalue.redis.support.collections.AbstractRedisCollection
 
persist() - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisMap
 
persist() - Method in class org.springframework.data.keyvalue.redis.support.collections.RedisProperties
 
phase - Variable in class org.springframework.data.keyvalue.riak.mapreduce.RiakMapReducePhase
 
phases - Variable in class org.springframework.data.keyvalue.riak.mapreduce.AbstractRiakMapReduceJob
 
ping() - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
ping() - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
ping() - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
ping() - Method in interface org.springframework.data.keyvalue.redis.connection.RedisConnectionCommands
 
ping() - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
poll() - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
 
poll(long, TimeUnit) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
 
pollFirst() - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
 
pollFirst(long, TimeUnit) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
 
pollLast() - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
 
pollLast(long, TimeUnit) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
 
pop() - Method in interface org.springframework.data.keyvalue.redis.core.BoundSetOperations
 
pop(K) - Method in interface org.springframework.data.keyvalue.redis.core.SetOperations
 
pop() - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
 
postNodeCompletion(Object, Object) - Method in class org.springframework.data.keyvalue.riak.groovy.RiakBuilder
 
postProcessConnection(JedisConnection) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnectionFactory
Post process a newly retrieved connection.
postProcessConnection(JredisConnection) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnectionFactory
Post process a newly retrieved connection.
postProcessConnection(RjcConnection) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnectionFactory
Post process a newly retrieved connection.
postProcessResult(T, RedisConnection, boolean) - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
 
prefix - Static variable in class org.springframework.data.keyvalue.riak.core.AbstractRiakTemplate
Regex used to extract host, port, and prefix from the given URI.
preProcessConnection(RedisConnection, boolean) - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
Processes the connection (before any settings are executed on it).
preProcessConnection(RedisConnection, boolean) - Method in class org.springframework.data.keyvalue.redis.core.StringRedisTemplate
 
processMessage(MessageListener, Message, byte[]) - Method in class org.springframework.data.keyvalue.redis.listener.RedisMessageListenerContainer
Process a message received from the provider.
propertyNames() - Method in class org.springframework.data.keyvalue.redis.support.collections.RedisProperties
 
pSubscribe(MessageListener, byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
pSubscribe(MessageListener, String...) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
pSubscribe(MessageListener, byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
pSubscribe(MessageListener, byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
pSubscribe(MessageListener, byte[]...) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisPubSubCommands
Subscribes the connection to all channels matching the given patterns.
pSubscribe(MessageListener, byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
pSubscribe(MessageListener, String...) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
pSubscribe(byte[]...) - Method in interface org.springframework.data.keyvalue.redis.connection.Subscription
Adds the given channel patterns to the current subscription.
pSubscribe(byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.util.AbstractSubscription
 
publish(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
publish(String, String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
publish(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
publish(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
publish(byte[], byte[]) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisPubSubCommands
Publishes the given message to the given channel.
publish(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
publish(String, String) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
pUnsubscribe() - Method in interface org.springframework.data.keyvalue.redis.connection.Subscription
Cancels the subscription for all channels matched by patterns.
pUnsubscribe(byte[]...) - Method in interface org.springframework.data.keyvalue.redis.connection.Subscription
Cancels the subscription for all channels matching the given patterns.
pUnsubscribe() - Method in class org.springframework.data.keyvalue.redis.connection.util.AbstractSubscription
 
pUnsubscribe(byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.util.AbstractSubscription
 
push(E) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
 
put(HK, HV) - Method in interface org.springframework.data.keyvalue.redis.core.BoundHashOperations
 
put(H, HK, HV) - Method in interface org.springframework.data.keyvalue.redis.core.HashOperations
 
put(E) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
 
put(K, V) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisMap
 
put(Object, Object) - Method in class org.springframework.data.keyvalue.redis.support.collections.RedisProperties
 
put(B, V, AsyncKeyValueStoreOperation<V, R>) - Method in class org.springframework.data.keyvalue.riak.core.AsyncRiakTemplate
 
put(B, V, Map<String, String>, AsyncKeyValueStoreOperation<V, R>) - Method in class org.springframework.data.keyvalue.riak.core.AsyncRiakTemplate
 
put(B, V, Map<String, String>, QosParameters, AsyncKeyValueStoreOperation<V, R>) - Method in class org.springframework.data.keyvalue.riak.core.AsyncRiakTemplate
 
put(B, V) - Method in class org.springframework.data.keyvalue.riak.core.RiakTemplate
Save an object to Riak and let it generate an ID for it.
put(B, V, Map<String, String>) - Method in class org.springframework.data.keyvalue.riak.core.RiakTemplate
Save an object to Riak and let it generate an ID for it.
putAll(Map<? extends HK, ? extends HV>) - Method in interface org.springframework.data.keyvalue.redis.core.BoundHashOperations
 
putAll(H, Map<? extends HK, ? extends HV>) - Method in interface org.springframework.data.keyvalue.redis.core.HashOperations
 
putAll(Map<? extends K, ? extends V>) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisMap
 
putAll(Map<? extends Object, ? extends Object>) - Method in class org.springframework.data.keyvalue.redis.support.collections.RedisProperties
 
putFirst(E) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
 
putIfAbsent(HK, HV) - Method in interface org.springframework.data.keyvalue.redis.core.BoundHashOperations
 
putIfAbsent(H, HK, HV) - Method in interface org.springframework.data.keyvalue.redis.core.HashOperations
 
putIfAbsent(K, V) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisMap
 
putIfAbsent(Object, Object) - Method in class org.springframework.data.keyvalue.redis.support.collections.RedisProperties
 
putLast(E) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
 

Q

QosParameters - Interface in org.springframework.data.keyvalue.riak.core
Specify Quality Of Service parameters.
qosParameters - Variable in class org.springframework.data.keyvalue.riak.groovy.RiakOperation
 
QueryUtils - Class in org.springframework.data.keyvalue.redis.core.query
Utilities for SortQuery implementations.
QueryUtils() - Constructor for class org.springframework.data.keyvalue.redis.core.query.QueryUtils
 

R

randomKey() - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
randomKey() - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
randomKey() - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
randomKey() - Method in interface org.springframework.data.keyvalue.redis.connection.RedisKeyCommands
 
randomKey() - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
randomKey() - Method in interface org.springframework.data.keyvalue.redis.core.RedisOperations
 
randomKey() - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
 
randomMember() - Method in interface org.springframework.data.keyvalue.redis.core.BoundSetOperations
 
randomMember(K) - Method in interface org.springframework.data.keyvalue.redis.core.SetOperations
 
range(long, long) - Method in interface org.springframework.data.keyvalue.redis.core.BoundListOperations
 
range(long, long) - Method in interface org.springframework.data.keyvalue.redis.core.BoundZSetOperations
 
range(K, long, long) - Method in interface org.springframework.data.keyvalue.redis.core.ListOperations
 
range(K, long, long) - Method in interface org.springframework.data.keyvalue.redis.core.ZSetOperations
 
range(long, long) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
 
range(long, long) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisZSet
 
range(long, long) - Method in interface org.springframework.data.keyvalue.redis.support.collections.RedisList
 
range(long, long) - Method in interface org.springframework.data.keyvalue.redis.support.collections.RedisZSet
 
rangeByScore(double, double) - Method in interface org.springframework.data.keyvalue.redis.core.BoundZSetOperations
 
rangeByScore(K, double, double) - Method in interface org.springframework.data.keyvalue.redis.core.ZSetOperations
 
rangeByScore(double, double) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisZSet
 
rangeByScore(double, double) - Method in interface org.springframework.data.keyvalue.redis.support.collections.RedisZSet
 
rangeByScoreWithScores(double, double) - Method in interface org.springframework.data.keyvalue.redis.core.BoundZSetOperations
 
rangeByScoreWithScores(K, double, double) - Method in interface org.springframework.data.keyvalue.redis.core.ZSetOperations
 
rangeByScoreWithScores(double, double) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisZSet
 
rangeByScoreWithScores(double, double) - Method in interface org.springframework.data.keyvalue.redis.support.collections.RedisZSet
 
rangeWithScores(long, long) - Method in interface org.springframework.data.keyvalue.redis.core.BoundZSetOperations
 
rangeWithScores(K, long, long) - Method in interface org.springframework.data.keyvalue.redis.core.ZSetOperations
 
rangeWithScores(long, long) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisZSet
 
rangeWithScores(long, long) - Method in interface org.springframework.data.keyvalue.redis.support.collections.RedisZSet
 
rank(Object) - Method in interface org.springframework.data.keyvalue.redis.core.BoundZSetOperations
 
rank(K, Object) - Method in interface org.springframework.data.keyvalue.redis.core.ZSetOperations
 
rank(Object) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisZSet
 
rank(Object) - Method in interface org.springframework.data.keyvalue.redis.support.collections.RedisZSet
Returns the rank (position) of the given element in the set, in ascending order.
read(byte[]) - Method in class org.springframework.data.keyvalue.riak.core.io.RiakInputStream
 
read(byte[], int, int) - Method in class org.springframework.data.keyvalue.riak.core.io.RiakInputStream
 
read() - Method in class org.springframework.data.keyvalue.riak.core.io.RiakInputStream
 
readThreshold - Variable in class org.springframework.data.keyvalue.riak.core.RiakQosParameters
 
RedisAccessor - Class in org.springframework.data.keyvalue.redis.core
Base class for RedisTemplate defining common properties.
RedisAccessor() - Constructor for class org.springframework.data.keyvalue.redis.core.RedisAccessor
 
RedisAtomicInteger - Class in org.springframework.data.keyvalue.redis.support.atomic
Atomic integer backed by Redis.
RedisAtomicInteger(String, RedisConnectionFactory) - Constructor for class org.springframework.data.keyvalue.redis.support.atomic.RedisAtomicInteger
Constructs a new RedisAtomicInteger instance.
RedisAtomicInteger(String, RedisConnectionFactory, int) - Constructor for class org.springframework.data.keyvalue.redis.support.atomic.RedisAtomicInteger
Constructs a new RedisAtomicInteger instance.
RedisAtomicLong - Class in org.springframework.data.keyvalue.redis.support.atomic
Atomic long backed by Redis.
RedisAtomicLong(String, RedisConnectionFactory) - Constructor for class org.springframework.data.keyvalue.redis.support.atomic.RedisAtomicLong
Constructs a new RedisAtomicLong instance.
RedisAtomicLong(String, RedisConnectionFactory, long) - Constructor for class org.springframework.data.keyvalue.redis.support.atomic.RedisAtomicLong
Constructs a new RedisAtomicLong instance.
RedisCallback<T> - Interface in org.springframework.data.keyvalue.redis.core
Callback interface for Redis 'low level' code.
RedisCollection<E> - Interface in org.springframework.data.keyvalue.redis.support.collections
Redis extension for the Collection contract.
RedisCollectionFactoryBean - Class in org.springframework.data.keyvalue.redis.support.collections
Factory bean that facilitates creation of Redis-based collections.
RedisCollectionFactoryBean() - Constructor for class org.springframework.data.keyvalue.redis.support.collections.RedisCollectionFactoryBean
 
RedisCollectionFactoryBean.CollectionType - Enum in org.springframework.data.keyvalue.redis.support.collections
 
RedisCommands - Interface in org.springframework.data.keyvalue.redis.connection
Interface for the commands supported by Redis.
RedisConnection - Interface in org.springframework.data.keyvalue.redis.connection
A connection to a Redis server.
RedisConnectionCommands - Interface in org.springframework.data.keyvalue.redis.connection
Connection-specific commands supported by Redis.
RedisConnectionFactory - Interface in org.springframework.data.keyvalue.redis.connection
Thread-safe factory of Redis connections.
RedisConnectionFailureException - Exception in org.springframework.data.keyvalue.redis
Fatal exception thrown when the Redis connection fails completely.
RedisConnectionFailureException(String) - Constructor for exception org.springframework.data.keyvalue.redis.RedisConnectionFailureException
 
RedisConnectionFailureException(String, Throwable) - Constructor for exception org.springframework.data.keyvalue.redis.RedisConnectionFailureException
 
RedisConnectionUtils - Class in org.springframework.data.keyvalue.redis.core
Helper class featuring RedisConnection handling, allowing for reuse of instances within 'transactions'/scopes.
RedisConnectionUtils() - Constructor for class org.springframework.data.keyvalue.redis.core.RedisConnectionUtils
 
RedisHashCommands - Interface in org.springframework.data.keyvalue.redis.connection
Hash-specific commands supported by Redis.
RedisInvalidSubscriptionException - Exception in org.springframework.data.keyvalue.redis.connection
Exception thrown when subscribing to an expired/dead Subscription.
RedisInvalidSubscriptionException(String, Throwable) - Constructor for exception org.springframework.data.keyvalue.redis.connection.RedisInvalidSubscriptionException
Constructs a new RedisInvalidSubscriptionException instance.
RedisInvalidSubscriptionException(String) - Constructor for exception org.springframework.data.keyvalue.redis.connection.RedisInvalidSubscriptionException
Constructs a new RedisInvalidSubscriptionException instance.
RedisKeyCommands - Interface in org.springframework.data.keyvalue.redis.connection
Key-specific commands supported by Redis.
RedisList<E> - Interface in org.springframework.data.keyvalue.redis.support.collections
Redis extension for the List contract.
RedisListCommands - Interface in org.springframework.data.keyvalue.redis.connection
List-specific commands supported by Redis.
RedisListCommands.Position - Enum in org.springframework.data.keyvalue.redis.connection
List insertion position.
RedisListenerExecutionFailedException - Exception in org.springframework.data.keyvalue.redis.listener.adapter
Exception thrown when the execution of a listener method failed.
RedisListenerExecutionFailedException(String, Throwable) - Constructor for exception org.springframework.data.keyvalue.redis.listener.adapter.RedisListenerExecutionFailedException
Constructs a new RedisListenerExecutionFailedException instance.
RedisListenerExecutionFailedException(String) - Constructor for exception org.springframework.data.keyvalue.redis.listener.adapter.RedisListenerExecutionFailedException
Constructs a new RedisListenerExecutionFailedException instance.
RedisMap<K,V> - Interface in org.springframework.data.keyvalue.redis.support.collections
Map view of a Redis hash.
RedisMessageListenerContainer - Class in org.springframework.data.keyvalue.redis.listener
Container providing asynchronous behaviour for Redis message listeners.
RedisMessageListenerContainer() - Constructor for class org.springframework.data.keyvalue.redis.listener.RedisMessageListenerContainer
 
RedisOperations<K,V> - Interface in org.springframework.data.keyvalue.redis.core
Interface that specified a basic set of Redis operations, implemented by RedisTemplate.
RedisProperties - Class in org.springframework.data.keyvalue.redis.support.collections
Properties extension for a Redis back-store.
RedisProperties(BoundHashOperations<String, String, String>) - Constructor for class org.springframework.data.keyvalue.redis.support.collections.RedisProperties
Constructs a new RedisProperties instance.
RedisProperties(String, RedisOperations<String, ?>) - Constructor for class org.springframework.data.keyvalue.redis.support.collections.RedisProperties
Constructs a new RedisProperties instance.
RedisProperties(Properties, BoundHashOperations<String, String, String>) - Constructor for class org.springframework.data.keyvalue.redis.support.collections.RedisProperties
Constructs a new RedisProperties instance.
RedisProperties(Properties, String, RedisOperations<String, ?>) - Constructor for class org.springframework.data.keyvalue.redis.support.collections.RedisProperties
Constructs a new RedisProperties instance.
RedisPubSubCommands - Interface in org.springframework.data.keyvalue.redis.connection
PubSub-specific Redis commands.
RedisSerializer<T> - Interface in org.springframework.data.keyvalue.redis.serializer
Basic interface serialization and deserialization of Objects to byte arrays (binary data).
RedisServerCommands - Interface in org.springframework.data.keyvalue.redis.connection
Server-specific commands supported by Redis.
RedisSet<E> - Interface in org.springframework.data.keyvalue.redis.support.collections
Redis extension for the Set contract.
RedisSetCommands - Interface in org.springframework.data.keyvalue.redis.connection
Set-specific commands supported by Redis.
RedisStore - Interface in org.springframework.data.keyvalue.redis.support.collections
Basic interface for Redis-based collections.
RedisStringCommands - Interface in org.springframework.data.keyvalue.redis.connection
String/Value-specific commands supported by Redis.
RedisSubscribedConnectionException - Exception in org.springframework.data.keyvalue.redis.connection
Exception thrown when issuing commands on a connection that is subscribed and waiting for events.
RedisSubscribedConnectionException(String, Throwable) - Constructor for exception org.springframework.data.keyvalue.redis.connection.RedisSubscribedConnectionException
Constructs a new RedisSubscribedConnectionException instance.
RedisSubscribedConnectionException(String) - Constructor for exception org.springframework.data.keyvalue.redis.connection.RedisSubscribedConnectionException
Constructs a new RedisSubscribedConnectionException instance.
RedisSystemException - Exception in org.springframework.data.keyvalue.redis
Exception thrown when we can't classify a Redis exception into one of Spring generic data access exceptions.
RedisSystemException(String, Throwable) - Constructor for exception org.springframework.data.keyvalue.redis.RedisSystemException
 
RedisTemplate<K,V> - Class in org.springframework.data.keyvalue.redis.core
Helper class that simplifies Redis data access code.
RedisTemplate() - Constructor for class org.springframework.data.keyvalue.redis.core.RedisTemplate
Constructs a new RedisTemplate instance.
RedisTxCommands - Interface in org.springframework.data.keyvalue.redis.connection
Transaction/Batch specific commands supported by Redis.
RedisZSet<E> - Interface in org.springframework.data.keyvalue.redis.support.collections
Redis ZSet (or sorted set (by weight)).
RedisZSetCommands - Interface in org.springframework.data.keyvalue.redis.connection
ZSet(SortedSet)-specific commands supported by Redis.
RedisZSetCommands.Aggregate - Enum in org.springframework.data.keyvalue.redis.connection
Sort aggregation operations.
RedisZSetCommands.Tuple - Interface in org.springframework.data.keyvalue.redis.connection
ZSet tuple.
releaseConnection(RedisConnection, RedisConnectionFactory) - Static method in class org.springframework.data.keyvalue.redis.core.RedisConnectionUtils
Closes the given connection, created via the given factory if not managed externally (i.e. not bound to the thread).
remainingCapacity() - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
 
remove(long, Object) - Method in interface org.springframework.data.keyvalue.redis.core.BoundListOperations
 
remove(Object) - Method in interface org.springframework.data.keyvalue.redis.core.BoundSetOperations
 
remove(Object) - Method in interface org.springframework.data.keyvalue.redis.core.BoundZSetOperations
 
remove(K, long, Object) - Method in interface org.springframework.data.keyvalue.redis.core.ListOperations
 
remove(K, Object) - Method in interface org.springframework.data.keyvalue.redis.core.SetOperations
 
remove(K, Object) - Method in interface org.springframework.data.keyvalue.redis.core.ZSetOperations
 
remove(Object) - Method in class org.springframework.data.keyvalue.redis.support.collections.AbstractRedisCollection
 
remove(Object) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
 
remove(int) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
 
remove() - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
 
remove(Object) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisMap
 
remove(Object, Object) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisMap
 
remove(Object) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisSet
 
remove(long, long) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisZSet
 
remove(Object) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisZSet
 
remove(Object) - Method in class org.springframework.data.keyvalue.redis.support.collections.RedisProperties
 
remove(Object, Object) - Method in class org.springframework.data.keyvalue.redis.support.collections.RedisProperties
 
remove(long, long) - Method in interface org.springframework.data.keyvalue.redis.support.collections.RedisZSet
 
removeAll(Collection<?>) - Method in class org.springframework.data.keyvalue.redis.support.collections.AbstractRedisCollection
 
removeByScore(double, double) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisZSet
 
removeByScore(double, double) - Method in interface org.springframework.data.keyvalue.redis.support.collections.RedisZSet
 
removeFirst() - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
 
removeFirstOccurrence(Object) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
 
removeLast() - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
 
removeLastOccurrence(Object) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
 
removeRange(long, long) - Method in interface org.springframework.data.keyvalue.redis.core.BoundZSetOperations
 
removeRange(K, long, long) - Method in interface org.springframework.data.keyvalue.redis.core.ZSetOperations
 
removeRangeByScore(double, double) - Method in interface org.springframework.data.keyvalue.redis.core.BoundZSetOperations
 
removeRangeByScore(K, double, double) - Method in interface org.springframework.data.keyvalue.redis.core.ZSetOperations
 
rename(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
rename(String, String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
rename(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
rename(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
rename(byte[], byte[]) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisKeyCommands
 
rename(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
rename(String, String) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
rename(K) - Method in interface org.springframework.data.keyvalue.redis.core.BoundKeyOperations
Renames the key.
rename(K, K) - Method in interface org.springframework.data.keyvalue.redis.core.RedisOperations
 
rename(K, K) - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
 
rename(String) - Method in class org.springframework.data.keyvalue.redis.support.atomic.RedisAtomicInteger
 
rename(String) - Method in class org.springframework.data.keyvalue.redis.support.atomic.RedisAtomicLong
 
rename(String) - Method in class org.springframework.data.keyvalue.redis.support.collections.AbstractRedisCollection
 
rename(String) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisMap
 
rename(String) - Method in class org.springframework.data.keyvalue.redis.support.collections.RedisProperties
 
renameIfAbsent(K, K) - Method in interface org.springframework.data.keyvalue.redis.core.RedisOperations
 
renameIfAbsent(K, K) - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
 
renameNX(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
renameNX(String, String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
renameNX(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
renameNX(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
renameNX(byte[], byte[]) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisKeyCommands
 
renameNX(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
renameNX(String, String) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
renameTo(File) - Method in class org.springframework.data.keyvalue.riak.core.io.RiakFile
 
replace(K, V, V) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisMap
 
replace(K, V) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisMap
 
replace(Object, Object, Object) - Method in class org.springframework.data.keyvalue.redis.support.collections.RedisProperties
 
replace(Object, Object) - Method in class org.springframework.data.keyvalue.redis.support.collections.RedisProperties
 
requiredType - Variable in class org.springframework.data.keyvalue.riak.groovy.RiakOperation
 
reset() - Method in class org.springframework.data.keyvalue.riak.core.io.RiakInputStream
 
resetConfigStats() - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
resetConfigStats() - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
resetConfigStats() - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
resetConfigStats() - Method in interface org.springframework.data.keyvalue.redis.connection.RedisServerCommands
 
resetConfigStats() - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
resolve(V) - Method in interface org.springframework.data.keyvalue.riak.core.BucketKeyResolver
Turn the given object into a BucketKeyPair.
resolve(V) - Method in class org.springframework.data.keyvalue.riak.core.SimpleBucketKeyResolver
 
resolveBucketKeyPair(Object, Object) - Method in class org.springframework.data.keyvalue.riak.core.AbstractRiakTemplate
 
results - Variable in class org.springframework.data.keyvalue.riak.groovy.RiakBuilder
 
retainAll(Collection<?>) - Method in class org.springframework.data.keyvalue.redis.support.collections.AbstractRedisCollection
 
reverseRange(long, long) - Method in interface org.springframework.data.keyvalue.redis.core.BoundZSetOperations
 
reverseRange(K, long, long) - Method in interface org.springframework.data.keyvalue.redis.core.ZSetOperations
 
reverseRange(long, long) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisZSet
 
reverseRange(long, long) - Method in interface org.springframework.data.keyvalue.redis.support.collections.RedisZSet
 
reverseRangeByScore(double, double) - Method in interface org.springframework.data.keyvalue.redis.core.BoundZSetOperations
 
reverseRangeByScore(K, double, double) - Method in interface org.springframework.data.keyvalue.redis.core.ZSetOperations
 
reverseRangeByScore(double, double) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisZSet
 
reverseRangeByScore(double, double) - Method in interface org.springframework.data.keyvalue.redis.support.collections.RedisZSet
 
reverseRangeByScoreWithScores(double, double) - Method in interface org.springframework.data.keyvalue.redis.core.BoundZSetOperations
 
reverseRangeByScoreWithScores(K, double, double) - Method in interface org.springframework.data.keyvalue.redis.core.ZSetOperations
 
reverseRangeByScoreWithScores(double, double) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisZSet
 
reverseRangeByScoreWithScores(double, double) - Method in interface org.springframework.data.keyvalue.redis.support.collections.RedisZSet
 
reverseRangeWithScores(long, long) - Method in interface org.springframework.data.keyvalue.redis.core.BoundZSetOperations
 
reverseRangeWithScores(K, long, long) - Method in interface org.springframework.data.keyvalue.redis.core.ZSetOperations
 
reverseRangeWithScores(long, long) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisZSet
 
reverseRangeWithScores(long, long) - Method in interface org.springframework.data.keyvalue.redis.support.collections.RedisZSet
 
reverseRank(Object) - Method in interface org.springframework.data.keyvalue.redis.core.BoundZSetOperations
 
reverseRank(K, Object) - Method in interface org.springframework.data.keyvalue.redis.core.ZSetOperations
 
reverseRank(Object) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisZSet
 
reverseRank(Object) - Method in interface org.springframework.data.keyvalue.redis.support.collections.RedisZSet
Returns the rank (position) of the given element in the set, in descending order.
riak - Variable in class org.springframework.data.keyvalue.riak.core.RiakKeyValueTemplate
 
riak - Variable in class org.springframework.data.keyvalue.riak.groovy.RiakBuilder
 
riak - Variable in class org.springframework.data.keyvalue.riak.groovy.RiakMapReduceOperation
 
riak - Variable in class org.springframework.data.keyvalue.riak.groovy.RiakOperation
 
RIAK_CLIENT_ID - Variable in class org.springframework.data.keyvalue.riak.core.AbstractRiakTemplate
Client ID used by Riak to correlate updates.
RIAK_META_CLASSNAME - Static variable in class org.springframework.data.keyvalue.riak.core.AbstractRiakTemplate
 
RIAK_VCLOCK - Static variable in class org.springframework.data.keyvalue.riak.core.AbstractRiakTemplate
 
RiakBuilder - Class in org.springframework.data.keyvalue.riak.groovy
A Groovy Builder that implements a powerful and syntactically succinct DSL for Riak datastore access using SDKV for Riak's AsyncRiakTemplate.
RiakBuilder() - Constructor for class org.springframework.data.keyvalue.riak.groovy.RiakBuilder
 
RiakBuilder(AsyncRiakTemplate) - Constructor for class org.springframework.data.keyvalue.riak.groovy.RiakBuilder
 
RiakBuilder(AsyncRiakTemplate, ExecutorService) - Constructor for class org.springframework.data.keyvalue.riak.groovy.RiakBuilder
 
RiakBuilder(BuilderSupport, AsyncRiakTemplate) - Constructor for class org.springframework.data.keyvalue.riak.groovy.RiakBuilder
 
RiakBuilder(Closure, BuilderSupport, AsyncRiakTemplate) - Constructor for class org.springframework.data.keyvalue.riak.groovy.RiakBuilder
 
RiakClassFileLoader - Class in org.springframework.data.keyvalue.riak.util
 
RiakClassFileLoader() - Constructor for class org.springframework.data.keyvalue.riak.util.RiakClassFileLoader
 
RiakClassLoader - Class in org.springframework.data.keyvalue.riak.util
 
RiakClassLoader(ClassLoader, RiakTemplate) - Constructor for class org.springframework.data.keyvalue.riak.util.RiakClassLoader
 
RiakClassLoader(RiakTemplate) - Constructor for class org.springframework.data.keyvalue.riak.util.RiakClassLoader
 
RiakFile<B,K> - Class in org.springframework.data.keyvalue.riak.core.io
 
RiakFile(RiakTemplate, B, K) - Constructor for class org.springframework.data.keyvalue.riak.core.io.RiakFile
 
RiakInputStream<B,K> - Class in org.springframework.data.keyvalue.riak.core.io
An InputStream implementation that is backed by a resource residing in Riak.
RiakInputStream(RiakTemplate, B, K) - Constructor for class org.springframework.data.keyvalue.riak.core.io.RiakInputStream
 
RiakKeyValueTemplate - Class in org.springframework.data.keyvalue.riak.core
An implementation of KeyValueStoreOperations and MapReduceOperations for the Riak data store.
RiakKeyValueTemplate() - Constructor for class org.springframework.data.keyvalue.riak.core.RiakKeyValueTemplate
Take all the defaults.
RiakKeyValueTemplate(ClientHttpRequestFactory) - Constructor for class org.springframework.data.keyvalue.riak.core.RiakKeyValueTemplate
Use the specified ClientHttpRequestFactory.
RiakKeyValueTemplate(String, String) - Constructor for class org.springframework.data.keyvalue.riak.core.RiakKeyValueTemplate
Use the specified defaultUri and mapReduceUri.
RiakMapReduceJob - Class in org.springframework.data.keyvalue.riak.mapreduce
An implementation of MapReduceJob for the Riak data store.
RiakMapReduceJob(RiakTemplate) - Constructor for class org.springframework.data.keyvalue.riak.mapreduce.RiakMapReduceJob
 
RiakMapReduceOperation - Class in org.springframework.data.keyvalue.riak.groovy
 
RiakMapReduceOperation(AsyncRiakTemplate, AsyncRiakMapReduceJob) - Constructor for class org.springframework.data.keyvalue.riak.groovy.RiakMapReduceOperation
 
RiakMapReducePhase - Class in org.springframework.data.keyvalue.riak.mapreduce
An implementation of MapReducePhase for the Riak data store.
RiakMapReducePhase(String, String, MapReduceOperation) - Constructor for class org.springframework.data.keyvalue.riak.mapreduce.RiakMapReducePhase
 
RiakMapReducePhase(MapReducePhase.Phase, String, MapReduceOperation) - Constructor for class org.springframework.data.keyvalue.riak.mapreduce.RiakMapReducePhase
 
RiakMetaData - Class in org.springframework.data.keyvalue.riak.core
An implementation of KeyValueStoreMetaData for Riak.
RiakMetaData(Map<String, Object>) - Constructor for class org.springframework.data.keyvalue.riak.core.RiakMetaData
 
RiakMetaData(MediaType, Map<String, Object>) - Constructor for class org.springframework.data.keyvalue.riak.core.RiakMetaData
 
RiakMetaData(MediaType, Map<String, Object>, String, String) - Constructor for class org.springframework.data.keyvalue.riak.core.RiakMetaData
 
RiakOperation<T> - Class in org.springframework.data.keyvalue.riak.groovy
 
RiakOperation(AsyncRiakTemplate, RiakOperation.Type) - Constructor for class org.springframework.data.keyvalue.riak.groovy.RiakOperation
 
RiakOutputStream<B,K> - Class in org.springframework.data.keyvalue.riak.core.io
 
RiakOutputStream(RiakTemplate, B, K) - Constructor for class org.springframework.data.keyvalue.riak.core.io.RiakOutputStream
 
RiakQosParameters - Class in org.springframework.data.keyvalue.riak.core
A generic class for specifying Quality Of Service parameters on operations.
RiakQosParameters() - Constructor for class org.springframework.data.keyvalue.riak.core.RiakQosParameters
 
RiakResource<B,K> - Class in org.springframework.data.keyvalue.riak.core.io
An implementation of UrlResource that is backed by a resource in Riak.
RiakResource(RiakTemplate, B, K) - Constructor for class org.springframework.data.keyvalue.riak.core.io.RiakResource
 
RiakTemplate - Class in org.springframework.data.keyvalue.riak.core
An implementation of BucketKeyValueStoreOperations and MapReduceOperations for the Riak data store.
RiakTemplate() - Constructor for class org.springframework.data.keyvalue.riak.core.RiakTemplate
Take all the defaults.
RiakTemplate(ClientHttpRequestFactory) - Constructor for class org.springframework.data.keyvalue.riak.core.RiakTemplate
Use the specified ClientHttpRequestFactory.
RiakTemplate(String, String) - Constructor for class org.springframework.data.keyvalue.riak.core.RiakTemplate
Use the specified defaultUri and mapReduceUri.
riakTemplate - Variable in class org.springframework.data.keyvalue.riak.mapreduce.AsyncRiakMapReduceJob
 
riakTemplate - Variable in class org.springframework.data.keyvalue.riak.mapreduce.RiakMapReduceJob
 
riakTemplate - Variable in class org.springframework.data.keyvalue.riak.util.RiakClassLoader
 
RiakValue<T> - Class in org.springframework.data.keyvalue.riak.core
 
RiakValue(T, KeyValueStoreMetaData) - Constructor for class org.springframework.data.keyvalue.riak.core.RiakValue
 
rightPop() - Method in interface org.springframework.data.keyvalue.redis.core.BoundListOperations
 
rightPop(long, TimeUnit) - Method in interface org.springframework.data.keyvalue.redis.core.BoundListOperations
 
rightPop(K) - Method in interface org.springframework.data.keyvalue.redis.core.ListOperations
 
rightPop(K, long, TimeUnit) - Method in interface org.springframework.data.keyvalue.redis.core.ListOperations
 
rightPopAndLeftPush(K, K) - Method in interface org.springframework.data.keyvalue.redis.core.ListOperations
 
rightPopAndLeftPush(K, K, long, TimeUnit) - Method in interface org.springframework.data.keyvalue.redis.core.ListOperations
 
rightPush(V) - Method in interface org.springframework.data.keyvalue.redis.core.BoundListOperations
 
rightPush(V, V) - Method in interface org.springframework.data.keyvalue.redis.core.BoundListOperations
 
rightPush(K, V) - Method in interface org.springframework.data.keyvalue.redis.core.ListOperations
 
rightPush(K, V, V) - Method in interface org.springframework.data.keyvalue.redis.core.ListOperations
 
rightPushIfPresent(V) - Method in interface org.springframework.data.keyvalue.redis.core.BoundListOperations
 
rightPushIfPresent(K, V) - Method in interface org.springframework.data.keyvalue.redis.core.ListOperations
 
RjcConnection - Class in org.springframework.data.keyvalue.redis.connection.rjc
RedisConnection implementation on top of rjc library.
RjcConnection(RedisConnection, int) - Constructor for class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
RjcConnectionFactory - Class in org.springframework.data.keyvalue.redis.connection.rjc
Connection factory creating rjc based connections.
RjcConnectionFactory() - Constructor for class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnectionFactory
Constructs a new RjcConnectionFactory instance with default settings (default connection pooling, no shard information).
RjcUtils - Class in org.springframework.data.keyvalue.redis.connection.rjc
Helper class featuring methods for RJC connection handling, providing support for exception translation.
RjcUtils() - Constructor for class org.springframework.data.keyvalue.redis.connection.rjc.RjcUtils
 
rPop(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
rPop(String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
rPop(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
rPop(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
rPop(byte[]) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisListCommands
 
rPop(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
rPop(String) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
rPopLPush(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
rPopLPush(String, String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
rPopLPush(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
rPopLPush(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
rPopLPush(byte[], byte[]) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisListCommands
 
rPopLPush(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
rPopLPush(String, String) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
rPush(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
rPush(String, String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
rPush(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
rPush(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
rPush(byte[], byte[]) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisListCommands
 
rPush(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
rPush(String, String) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
rPushX(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
rPushX(String, String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
rPushX(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
rPushX(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
rPushX(byte[], byte[]) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisListCommands
 
rPushX(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
rPushX(String, String) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 

S

sAdd(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
sAdd(String, String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
sAdd(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
sAdd(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
sAdd(byte[], byte[]) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisSetCommands
 
sAdd(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
sAdd(String, String) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
save() - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
save() - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
save() - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
save() - Method in interface org.springframework.data.keyvalue.redis.connection.RedisServerCommands
 
save() - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
sCard(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
sCard(String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
sCard(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
sCard(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
sCard(byte[]) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisSetCommands
 
sCard(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
sCard(String) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
score(Object) - Method in interface org.springframework.data.keyvalue.redis.core.BoundZSetOperations
 
score(K, Object) - Method in interface org.springframework.data.keyvalue.redis.core.ZSetOperations
 
score(Object) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisZSet
 
score(Object) - Method in interface org.springframework.data.keyvalue.redis.support.collections.RedisZSet
Returns the score of the given element.
sDiff(byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
sDiff(String...) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
sDiff(byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
sDiff(byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
sDiff(byte[]...) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisSetCommands
 
sDiff(byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
sDiff(String...) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
sDiffStore(byte[], byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
sDiffStore(String, String...) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
sDiffStore(byte[], byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
sDiffStore(byte[], byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
sDiffStore(byte[], byte[]...) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisSetCommands
 
sDiffStore(byte[], byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
sDiffStore(String, String...) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
select(int) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
select(int) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
select(int) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
select(int) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisConnectionCommands
 
select(int) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
SerializationException - Exception in org.springframework.data.keyvalue.redis.serializer
Generic exception indicating a serialization/deserialization error.
SerializationException(String, Throwable) - Constructor for exception org.springframework.data.keyvalue.redis.serializer.SerializationException
Constructs a new SerializationException instance.
SerializationException(String) - Constructor for exception org.springframework.data.keyvalue.redis.serializer.SerializationException
Constructs a new SerializationException instance.
SerializationUtils - Class in org.springframework.data.keyvalue.redis.serializer
Utility class with various serialization-related methods.
SerializationUtils() - Constructor for class org.springframework.data.keyvalue.redis.serializer.SerializationUtils
 
serialize(T) - Method in class org.springframework.data.keyvalue.redis.serializer.GenericToStringSerializer
 
serialize(Object) - Method in class org.springframework.data.keyvalue.redis.serializer.JacksonJsonRedisSerializer
 
serialize(Object) - Method in class org.springframework.data.keyvalue.redis.serializer.JdkSerializationRedisSerializer
 
serialize(Object) - Method in class org.springframework.data.keyvalue.redis.serializer.OxmSerializer
 
serialize(T) - Method in interface org.springframework.data.keyvalue.redis.serializer.RedisSerializer
Serialize the given object to binary data.
serialize(String) - Method in class org.springframework.data.keyvalue.redis.serializer.StringRedisSerializer
 
serialVersionUID - Static variable in exception org.springframework.data.keyvalue.riak.DataStoreConnectionFailureException
 
serialVersionUID - Static variable in exception org.springframework.data.keyvalue.riak.DataStoreOperationException
 
SessionCallback<T> - Interface in org.springframework.data.keyvalue.redis.core
Callback executing all operations against a surrogate 'session' (basically against the same underlying Redis connection).
set(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
set(String, String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
set(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
set(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
set(byte[], byte[]) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisStringCommands
 
set(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
set(String, String) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
set(long, V) - Method in interface org.springframework.data.keyvalue.redis.core.BoundListOperations
 
set(V) - Method in interface org.springframework.data.keyvalue.redis.core.BoundValueOperations
 
set(V, long) - Method in interface org.springframework.data.keyvalue.redis.core.BoundValueOperations
 
set(V, long, TimeUnit) - Method in interface org.springframework.data.keyvalue.redis.core.BoundValueOperations
 
set(K, long, V) - Method in interface org.springframework.data.keyvalue.redis.core.ListOperations
 
set(K, V) - Method in interface org.springframework.data.keyvalue.redis.core.ValueOperations
 
set(K, V, long, TimeUnit) - Method in interface org.springframework.data.keyvalue.redis.core.ValueOperations
 
set(K, V, long) - Method in interface org.springframework.data.keyvalue.redis.core.ValueOperations
 
set(int) - Method in class org.springframework.data.keyvalue.redis.support.atomic.RedisAtomicInteger
Set to the given value.
set(long) - Method in class org.springframework.data.keyvalue.redis.support.atomic.RedisAtomicLong
Sets to the given value.
set(int, E) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
 
set(B, K, V, AsyncKeyValueStoreOperation<V, R>) - Method in interface org.springframework.data.keyvalue.riak.core.AsyncBucketKeyValueStoreOperations
Put an object in Riak at a specific bucket and key and invoke callback with the value pulled back out of Riak after the update, which contains full headers and metadata.
set(B, K, V, QosParameters, AsyncKeyValueStoreOperation<V, R>) - Method in interface org.springframework.data.keyvalue.riak.core.AsyncBucketKeyValueStoreOperations
 
set(B, K, V, AsyncKeyValueStoreOperation<V, R>) - Method in class org.springframework.data.keyvalue.riak.core.AsyncRiakTemplate
 
set(B, K, V, QosParameters, AsyncKeyValueStoreOperation<V, R>) - Method in class org.springframework.data.keyvalue.riak.core.AsyncRiakTemplate
 
set(B, K, V) - Method in interface org.springframework.data.keyvalue.riak.core.BucketKeyValueStoreOperations
Variant of KeyValueStoreOperations.set(Object, Object) that takes a discreet bucket and key pair.
set(B, K, V, QosParameters) - Method in interface org.springframework.data.keyvalue.riak.core.BucketKeyValueStoreOperations
Variant of KeyValueStoreOperations.set(Object, Object, QosParameters) that takes a discreet bucket and key pair.
set(K, V) - Method in interface org.springframework.data.keyvalue.riak.core.KeyValueStoreOperations
Set a value at a specified key.
set(K, V, QosParameters) - Method in interface org.springframework.data.keyvalue.riak.core.KeyValueStoreOperations
Variation on set() that allows the user to specify QosParameters.
set(K, V) - Method in class org.springframework.data.keyvalue.riak.core.RiakKeyValueTemplate
 
set(K, V, QosParameters) - Method in class org.springframework.data.keyvalue.riak.core.RiakKeyValueTemplate
 
set(B, K, V) - Method in class org.springframework.data.keyvalue.riak.core.RiakTemplate
 
set(B, K, V, QosParameters) - Method in class org.springframework.data.keyvalue.riak.core.RiakTemplate
 
setAlphabetic(Boolean) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultSortParameters
 
setArg(Object) - Method in interface org.springframework.data.keyvalue.riak.mapreduce.MapReducePhase
Set the static argument for this job.
setArg(Object) - Method in class org.springframework.data.keyvalue.riak.mapreduce.RiakMapReducePhase
 
setAsBytes(B, K, byte[], AsyncKeyValueStoreOperation<byte[], R>) - Method in interface org.springframework.data.keyvalue.riak.core.AsyncBucketKeyValueStoreOperations
 
setAsBytes(B, K, byte[], QosParameters, AsyncKeyValueStoreOperation<byte[], R>) - Method in interface org.springframework.data.keyvalue.riak.core.AsyncBucketKeyValueStoreOperations
 
setAsBytes(B, K, byte[], AsyncKeyValueStoreOperation<byte[], R>) - Method in class org.springframework.data.keyvalue.riak.core.AsyncRiakTemplate
 
setAsBytes(B, K, byte[], QosParameters, AsyncKeyValueStoreOperation<byte[], R>) - Method in class org.springframework.data.keyvalue.riak.core.AsyncRiakTemplate
 
setAsBytes(B, K, byte[]) - Method in interface org.springframework.data.keyvalue.riak.core.BucketKeyValueStoreOperations
Variant of KeyValueStoreOperations.setAsBytes(Object, byte[]) that takes a discreet bucket and key pair.
setAsBytes(B, K, byte[], QosParameters) - Method in interface org.springframework.data.keyvalue.riak.core.BucketKeyValueStoreOperations
Variant of KeyValueStoreOperations.setAsBytes(Object, byte[], QosParameters) that takes a discreet bucket and key pair.
setAsBytes(K, byte[]) - Method in interface org.springframework.data.keyvalue.riak.core.KeyValueStoreOperations
Set a value as a byte array at a specified key.
setAsBytes(K, byte[], QosParameters) - Method in interface org.springframework.data.keyvalue.riak.core.KeyValueStoreOperations
 
setAsBytes(K, byte[]) - Method in class org.springframework.data.keyvalue.riak.core.RiakKeyValueTemplate
 
setAsBytes(K, byte[], QosParameters) - Method in class org.springframework.data.keyvalue.riak.core.RiakKeyValueTemplate
 
setAsBytes(B, K, byte[]) - Method in class org.springframework.data.keyvalue.riak.core.RiakTemplate
 
setAsBytes(B, K, byte[], QosParameters) - Method in class org.springframework.data.keyvalue.riak.core.RiakTemplate
 
setAsyncRiakTemplate(AsyncRiakTemplate) - Method in class org.springframework.data.keyvalue.riak.mapreduce.AsyncRiakMapReduceJob
 
setAsyncTemplate(AsyncRiakTemplate) - Method in class org.springframework.data.keyvalue.riak.groovy.RiakBuilder
 
setBeanClassLoader(ClassLoader) - Method in class org.springframework.data.keyvalue.riak.core.AbstractRiakTemplate
 
setBeanFactory(BeanFactory) - Method in class org.springframework.data.keyvalue.redis.serializer.GenericToStringSerializer
 
setBeanName(String) - Method in class org.springframework.data.keyvalue.redis.listener.RedisMessageListenerContainer
 
setBeanName(String) - Method in class org.springframework.data.keyvalue.redis.support.collections.RedisCollectionFactoryBean
 
setBit(byte[], long, boolean) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
setBit(String, long, boolean) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
setBit(byte[], long, boolean) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
setBit(byte[], long, boolean) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
setBit(byte[], long, boolean) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisStringCommands
 
setBit(byte[], long, boolean) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
setBit(String, long, boolean) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
setBucket(B) - Method in class org.springframework.data.keyvalue.riak.core.io.RiakFile
 
setBucket(String) - Method in class org.springframework.data.keyvalue.riak.core.RiakMetaData
 
setBucket(String) - Method in class org.springframework.data.keyvalue.riak.groovy.RiakOperation
 
setBucketKeyPair(BucketKeyPair) - Method in class org.springframework.data.keyvalue.riak.mapreduce.JavascriptMapReduceOperation
Set the BucketKeyPair to point to for the Javascript to use in this M/R function.
setBuckets(Set<String>) - Method in class org.springframework.data.keyvalue.riak.util.RiakClassLoader
 
setByPattern(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultSortParameters
 
setCompleted(Closure) - Method in class org.springframework.data.keyvalue.riak.groovy.RiakMapReduceOperation
 
setConfig(String, String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
setConfig(String, String) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
setConfig(String, String) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
setConfig(String, String) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisServerCommands
 
setConfig(String, String) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
setConnectionFactory(RedisConnectionFactory) - Method in class org.springframework.data.keyvalue.redis.core.RedisAccessor
Sets the connection factory.
setConnectionFactory(RedisConnectionFactory) - Method in class org.springframework.data.keyvalue.redis.listener.RedisMessageListenerContainer
 
setConversionService(ConversionService) - Method in class org.springframework.data.keyvalue.redis.serializer.GenericToStringSerializer
 
setConversionService(ConversionService) - Method in class org.springframework.data.keyvalue.riak.core.AbstractRiakTemplate
Specify the conversion service to use.
setDatabase(int) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnectionFactory
Sets the index of the database used by this connection factory.
setDatabase(int) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnectionFactory
Sets the index of the database used by this connection factory.
setDatabase(int) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnectionFactory
Sets the index of the database used by this connection factory.
setDefaultBucket(String) - Method in class org.springframework.data.keyvalue.riak.util.RiakClassLoader
 
setDefaultErrorHandler(AsyncKeyValueStoreOperation<Throwable, Object>) - Method in class org.springframework.data.keyvalue.riak.core.AsyncRiakTemplate
 
setDefaultListenerMethod(String) - Method in class org.springframework.data.keyvalue.redis.listener.adapter.MessageListenerAdapter
Specify the name of the default listener method to delegate to, for the case where no specific listener method has been determined.
setDefaultQosParameters(QosParameters) - Method in class org.springframework.data.keyvalue.riak.core.AbstractRiakTemplate
 
setDefaultSerializer(RedisSerializer<?>) - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
Sets the default serializer to use for this template.
setDefaultType(Class<?>) - Method in class org.springframework.data.keyvalue.riak.core.AbstractRiakTemplate
Set the default type to use if none can be inferred.
setDefaultUri(String) - Method in class org.springframework.data.keyvalue.riak.core.AbstractRiakTemplate
 
setDelegate(Object) - Method in class org.springframework.data.keyvalue.redis.listener.adapter.MessageListenerAdapter
Set a target object to delegate message listening to.
setDescription(String) - Method in class org.springframework.data.keyvalue.riak.core.io.RiakResource
 
setDurableWriteThreshold(T) - Method in class org.springframework.data.keyvalue.riak.core.RiakQosParameters
 
setErrorHandler(ErrorHandler) - Method in class org.springframework.data.keyvalue.redis.listener.RedisMessageListenerContainer
Set an ErrorHandler to be invoked in case of any uncaught exceptions thrown while processing a Message.
setEx(byte[], long, byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
setEx(String, long, String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
setEx(byte[], long, byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
setEx(byte[], long, byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
setEx(byte[], long, byte[]) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisStringCommands
 
setEx(byte[], long, byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
setEx(String, long, String) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
setExecutable(boolean, boolean) - Method in class org.springframework.data.keyvalue.riak.core.io.RiakFile
 
setExecutable(boolean) - Method in class org.springframework.data.keyvalue.riak.core.io.RiakFile
 
setExposeConnection(boolean) - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
Sets whether to expose the Redis connection to RedisCallback code.
setFailed(Closure) - Method in class org.springframework.data.keyvalue.riak.groovy.RiakMapReduceOperation
 
setFunction(String) - Method in class org.springframework.data.keyvalue.riak.mapreduce.ErlangMapReduceOperation
Set the name of this Erlang function.
setGetPattern(byte[][]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultSortParameters
 
setHashKeySerializer(RedisSerializer<?>) - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
Sets the hash key (or field) serializer to be used by this template.
setHashValueSerializer(RedisSerializer<?>) - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
Sets the hash value serializer to be used by this template.
setHostName(String) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnectionFactory
Sets the Redis hostName.
setHostName(String) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnectionFactory
Sets the Redis host name for this factory.
setHostName(String) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnectionFactory
Sets the Redis hostName.
setIfAbsent(V) - Method in interface org.springframework.data.keyvalue.redis.core.BoundValueOperations
 
setIfAbsent(K, V) - Method in interface org.springframework.data.keyvalue.redis.core.ValueOperations
 
setIfKeyNonExistent(B, K, V, AsyncKeyValueStoreOperation<V, R>) - Method in interface org.springframework.data.keyvalue.riak.core.AsyncBucketKeyValueStoreOperations
 
setIfKeyNonExistent(B, K, V, AsyncKeyValueStoreOperation<V, R>) - Method in class org.springframework.data.keyvalue.riak.core.AsyncRiakTemplate
 
setIfKeyNonExistent(B, K, V) - Method in interface org.springframework.data.keyvalue.riak.core.BucketKeyValueStoreOperations
Variant of KeyValueStoreOperations.setIfKeyNonExistent(Object, Object) that takes a discreet bucket and key pair.
setIfKeyNonExistent(K, V) - Method in interface org.springframework.data.keyvalue.riak.core.KeyValueStoreOperations
Set the value at the given key only if that key doesn't already exist.
setIfKeyNonExistent(K, V) - Method in class org.springframework.data.keyvalue.riak.core.RiakKeyValueTemplate
 
setIfKeyNonExistent(B, K, V) - Method in class org.springframework.data.keyvalue.riak.core.RiakTemplate
 
setIfKeyNonExistentAsBytes(B, K, byte[], AsyncKeyValueStoreOperation<byte[], R>) - Method in interface org.springframework.data.keyvalue.riak.core.AsyncBucketKeyValueStoreOperations
 
setIfKeyNonExistentAsBytes(B, K, byte[], AsyncKeyValueStoreOperation<byte[], R>) - Method in class org.springframework.data.keyvalue.riak.core.AsyncRiakTemplate
 
setIfKeyNonExistentAsBytes(B, K, byte[]) - Method in interface org.springframework.data.keyvalue.riak.core.BucketKeyValueStoreOperations
Variant of KeyValueStoreOperations.setIfKeyNonExistentAsBytes(Object, byte[]) that takes a discreet bucket and key pair.
setIfKeyNonExistentAsBytes(K, byte[]) - Method in interface org.springframework.data.keyvalue.riak.core.KeyValueStoreOperations
Set the value at the given key as a byte array only if that key doesn't already exist.
setIfKeyNonExistentAsBytes(K, byte[]) - Method in class org.springframework.data.keyvalue.riak.core.RiakKeyValueTemplate
 
setIfKeyNonExistentAsBytes(B, K, byte[]) - Method in class org.springframework.data.keyvalue.riak.core.RiakTemplate
 
setIgnoreNotFound(boolean) - Method in class org.springframework.data.keyvalue.riak.core.AbstractRiakTemplate
 
setJob(AsyncRiakMapReduceJob) - Method in class org.springframework.data.keyvalue.riak.groovy.RiakMapReduceOperation
 
setKeepResults(boolean) - Method in class org.springframework.data.keyvalue.riak.mapreduce.RiakMapReducePhase
 
setKey(String) - Method in class org.springframework.data.keyvalue.redis.support.collections.RedisCollectionFactoryBean
Sets the key of the store.
setKey(K) - Method in class org.springframework.data.keyvalue.riak.core.io.RiakFile
 
setKey(String) - Method in class org.springframework.data.keyvalue.riak.core.RiakMetaData
 
setKey(String) - Method in class org.springframework.data.keyvalue.riak.groovy.RiakOperation
 
setKeySerializer(RedisSerializer<?>) - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
Sets the key serializer to be used by this template.
setLastModified(long) - Method in class org.springframework.data.keyvalue.riak.core.io.RiakFile
 
setLimit(SortParameters.Range) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultSortParameters
 
setMapReduceUri(String) - Method in class org.springframework.data.keyvalue.riak.core.AbstractRiakTemplate
 
setMarshaller(Marshaller) - Method in class org.springframework.data.keyvalue.redis.serializer.OxmSerializer
 
setMaxSize(int) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
Sets the maximum size of the (capped) list.
setMessageListeners(Map<? extends MessageListener, Collection<? extends Topic>>) - Method in class org.springframework.data.keyvalue.redis.listener.RedisMessageListenerContainer
Attaches the given listeners (and their topics) to the container.
setModule(String) - Method in class org.springframework.data.keyvalue.riak.mapreduce.ErlangMapReduceOperation
Set the Erlang module this function is defined in.
setMultiple(Map<K, V>) - Method in interface org.springframework.data.keyvalue.riak.core.KeyValueStoreOperations
Convenience method to set multiple values as Key/Value pairs.
setMultiple(Map<K, V>) - Method in class org.springframework.data.keyvalue.riak.core.RiakKeyValueTemplate
 
setMultipleAsBytes(Map<K, byte[]>) - Method in interface org.springframework.data.keyvalue.riak.core.KeyValueStoreOperations
Convenience method to set multiple values as Key/byte[] pairs.
setMultipleAsBytes(Map<K, byte[]>) - Method in class org.springframework.data.keyvalue.riak.core.RiakKeyValueTemplate
 
setMultipleAsBytesIfKeysNonExistent(Map<K, byte[]>) - Method in interface org.springframework.data.keyvalue.riak.core.KeyValueStoreOperations
Variation on setting multiple values as byte arrays only if the key doesn't already exist.
setMultipleAsBytesIfKeysNonExistent(Map<K, byte[]>) - Method in class org.springframework.data.keyvalue.riak.core.RiakKeyValueTemplate
 
setMultipleIfKeysNonExistent(Map<K, V>) - Method in interface org.springframework.data.keyvalue.riak.core.KeyValueStoreOperations
Variation on setting multiple values only if the key doesn't already exist.
setMultipleIfKeysNonExistent(Map<K, V>) - Method in class org.springframework.data.keyvalue.riak.core.RiakKeyValueTemplate
 
setNX(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
setNX(String, String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
setNX(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
setNX(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
setNX(byte[], byte[]) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisStringCommands
 
setNX(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
setNX(String, String) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
setObjectMapper(ObjectMapper) - Method in class org.springframework.data.keyvalue.redis.serializer.JacksonJsonRedisSerializer
Sets the ObjectMapper for this view.
setOperation(MapReduceOperation) - Method in class org.springframework.data.keyvalue.riak.mapreduce.RiakMapReducePhase
 
SetOperations<K,V> - Interface in org.springframework.data.keyvalue.redis.core
Redis set specific operations.
setOrder(SortParameters.Order) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultSortParameters
 
setParent(Object, Object) - Method in class org.springframework.data.keyvalue.riak.groovy.RiakBuilder
 
setPassword(String) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnectionFactory
Sets the password used for authenticating with the Redis server.
setPassword(String) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnectionFactory
Sets the password used for authenticating with the Redis server.
setPassword(String) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnectionFactory
Sets the password used for authenticating with the Redis server.
setPoolConfig(JedisPoolConfig) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnectionFactory
Sets the pool configuration for this factory.
setPoolSize(int) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnectionFactory
Sets the connection pool size of the underlying factory.
setPort(int) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnectionFactory
Sets the port used to connect to the Redis instance.
setPort(int) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnectionFactory
Sets the Redis port.
setPort(int) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnectionFactory
Sets the port used to connect to the Redis instance.
setQosParameters(QosParameters) - Method in class org.springframework.data.keyvalue.riak.groovy.RiakOperation
 
setRange(byte[], byte[], long) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
setRange(String, String, long) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
setRange(byte[], byte[], long) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
setRange(byte[], byte[], long) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
setRange(byte[], byte[], long) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisStringCommands
 
setRange(byte[], byte[], long) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
setRange(String, String, long) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
setReadable(boolean, boolean) - Method in class org.springframework.data.keyvalue.riak.core.io.RiakFile
 
setReadable(boolean) - Method in class org.springframework.data.keyvalue.riak.core.io.RiakFile
 
setReadOnly() - Method in class org.springframework.data.keyvalue.riak.core.io.RiakFile
 
setReadThreshold(T) - Method in class org.springframework.data.keyvalue.riak.core.RiakQosParameters
 
setRequiredType(Class<?>) - Method in class org.springframework.data.keyvalue.riak.groovy.RiakOperation
 
setRiak(RiakTemplate) - Method in class org.springframework.data.keyvalue.riak.core.io.RiakFile
 
setRiakTemplate(RiakTemplate) - Method in class org.springframework.data.keyvalue.riak.mapreduce.RiakMapReduceJob
 
setRiakTemplate(RiakTemplate) - Method in class org.springframework.data.keyvalue.riak.util.RiakClassLoader
 
setSerializer(RedisSerializer<?>) - Method in class org.springframework.data.keyvalue.redis.listener.adapter.MessageListenerAdapter
Set the serializer that will convert incoming raw Redis messages to listener method arguments.
setShardInfo(JedisShardInfo) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnectionFactory
Sets the shard info for this factory.
setSource(String) - Method in class org.springframework.data.keyvalue.riak.mapreduce.JavascriptMapReduceOperation
Set the anonymous source to use for the M/R function.
setStringSerializer(RedisSerializer<String>) - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
Sets the string value serializer to be used by this template (when the arguments or return types are always strings).
setSubscriptionExecutor(Executor) - Method in class org.springframework.data.keyvalue.redis.listener.RedisMessageListenerContainer
Sets the task execution used for subscribing to Redis channels.
setTaskExecutor(Executor) - Method in class org.springframework.data.keyvalue.redis.listener.RedisMessageListenerContainer
Sets the task executor used for running the message listeners when messages are received.
setTemplate(RedisTemplate<String, ?>) - Method in class org.springframework.data.keyvalue.redis.support.collections.RedisCollectionFactoryBean
Sets the template used by the resulting store.
setTimeout(int) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnectionFactory
 
setTimeout(int) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnectionFactory
 
setTimeout(Long) - Method in class org.springframework.data.keyvalue.riak.groovy.RiakMapReduceOperation
 
setTimeout(long) - Method in class org.springframework.data.keyvalue.riak.groovy.RiakOperation
 
setTopicSerializer(RedisSerializer<String>) - Method in class org.springframework.data.keyvalue.redis.listener.RedisMessageListenerContainer
Sets the serializer for converting the Topics into low-level channels and patterns.
setType(RedisCollectionFactoryBean.CollectionType) - Method in class org.springframework.data.keyvalue.redis.support.collections.RedisCollectionFactoryBean
Sets the store type.
setTypeConverter(TypeConverter) - Method in class org.springframework.data.keyvalue.redis.serializer.GenericToStringSerializer
 
setUnmarshaller(Unmarshaller) - Method in class org.springframework.data.keyvalue.redis.serializer.OxmSerializer
 
setUseCache(boolean) - Method in class org.springframework.data.keyvalue.riak.core.AbstractRiakTemplate
 
setUsePool(boolean) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnectionFactory
Turns on or off the use of connection pooling.
setUsePool(boolean) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnectionFactory
Turns on or off the use of connection pooling.
setUsePool(boolean) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnectionFactory
Turns on or off the use of connection pooling.
setValue(T) - Method in class org.springframework.data.keyvalue.riak.groovy.RiakOperation
 
setValueSerializer(RedisSerializer<?>) - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
Sets the value serializer to be used by this template.
setWithMetaData(B, K, V, Map<String, String>, AsyncKeyValueStoreOperation<V, R>) - Method in interface org.springframework.data.keyvalue.riak.core.AsyncBucketKeyValueStoreOperations
 
setWithMetaData(B, K, V, Map<String, String>, QosParameters, AsyncKeyValueStoreOperation<V, R>) - Method in interface org.springframework.data.keyvalue.riak.core.AsyncBucketKeyValueStoreOperations
 
setWithMetaData(B, K, V, Map<String, String>, QosParameters, AsyncKeyValueStoreOperation<V, R>) - Method in class org.springframework.data.keyvalue.riak.core.AsyncRiakTemplate
 
setWithMetaData(B, K, V, Map<String, String>, AsyncKeyValueStoreOperation<V, R>) - Method in class org.springframework.data.keyvalue.riak.core.AsyncRiakTemplate
 
setWithMetaData(B, K, V, Map<String, String>, QosParameters) - Method in interface org.springframework.data.keyvalue.riak.core.BucketKeyValueStoreOperations
Variant of KeyValueStoreOperations.setWithMetaData(Object, Object, java.util.Map, QosParameters) that takes a discreet bucket and key pair.
setWithMetaData(B, K, V, Map<String, String>) - Method in interface org.springframework.data.keyvalue.riak.core.BucketKeyValueStoreOperations
Variant of KeyValueStoreOperations.setWithMetaData(Object, Object, java.util.Map) that takes a discreet bucket and key pair.
setWithMetaData(K, V, Map<String, String>, QosParameters) - Method in interface org.springframework.data.keyvalue.riak.core.KeyValueStoreOperations
Variation on setWithMetaData() that allows the user to pass QosParameters.
setWithMetaData(K, V, Map<String, String>) - Method in interface org.springframework.data.keyvalue.riak.core.KeyValueStoreOperations
 
setWithMetaData(K, V, Map<String, String>, QosParameters) - Method in class org.springframework.data.keyvalue.riak.core.RiakKeyValueTemplate
 
setWithMetaData(K, V, Map<String, String>) - Method in class org.springframework.data.keyvalue.riak.core.RiakKeyValueTemplate
 
setWithMetaData(B, K, V, Map<String, String>, QosParameters) - Method in class org.springframework.data.keyvalue.riak.core.RiakTemplate
 
setWithMetaData(B, K, V, Map<String, String>) - Method in class org.springframework.data.keyvalue.riak.core.RiakTemplate
 
setWorkerPool(ExecutorService) - Method in class org.springframework.data.keyvalue.riak.core.AbstractRiakTemplate
 
setWorkerPool(ExecutorService) - Method in class org.springframework.data.keyvalue.riak.groovy.RiakBuilder
 
setWritable(boolean, boolean) - Method in class org.springframework.data.keyvalue.riak.core.io.RiakFile
 
setWritable(boolean) - Method in class org.springframework.data.keyvalue.riak.core.io.RiakFile
 
setWriteThreshold(T) - Method in class org.springframework.data.keyvalue.riak.core.RiakQosParameters
 
shutdown() - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
shutdown() - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
shutdown() - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
shutdown() - Method in interface org.springframework.data.keyvalue.redis.connection.RedisServerCommands
 
shutdown() - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
SimpleBucketKeyPair<B,K> - Class in org.springframework.data.keyvalue.riak.core
 
SimpleBucketKeyPair(B, K) - Constructor for class org.springframework.data.keyvalue.riak.core.SimpleBucketKeyPair
 
SimpleBucketKeyResolver - Class in org.springframework.data.keyvalue.riak.core
 
SimpleBucketKeyResolver() - Constructor for class org.springframework.data.keyvalue.riak.core.SimpleBucketKeyResolver
 
sInter(byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
sInter(String...) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
sInter(byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
sInter(byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
sInter(byte[]...) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisSetCommands
 
sInter(byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
sInter(String...) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
sInterStore(byte[], byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
sInterStore(String, String...) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
sInterStore(byte[], byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
sInterStore(byte[], byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
sInterStore(byte[], byte[]...) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisSetCommands
 
sInterStore(byte[], byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
sInterStore(String, String...) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
sIsMember(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
sIsMember(String, String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
sIsMember(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
sIsMember(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
sIsMember(byte[], byte[]) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisSetCommands
 
sIsMember(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
sIsMember(String, String) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
size() - Method in interface org.springframework.data.keyvalue.redis.core.BoundHashOperations
 
size() - Method in interface org.springframework.data.keyvalue.redis.core.BoundListOperations
 
size() - Method in interface org.springframework.data.keyvalue.redis.core.BoundSetOperations
 
size() - Method in interface org.springframework.data.keyvalue.redis.core.BoundValueOperations
 
size() - Method in interface org.springframework.data.keyvalue.redis.core.BoundZSetOperations
 
size(H) - Method in interface org.springframework.data.keyvalue.redis.core.HashOperations
 
size(K) - Method in interface org.springframework.data.keyvalue.redis.core.ListOperations
 
size(K) - Method in interface org.springframework.data.keyvalue.redis.core.SetOperations
 
size(K) - Method in interface org.springframework.data.keyvalue.redis.core.ValueOperations
 
size(K) - Method in interface org.springframework.data.keyvalue.redis.core.ZSetOperations
 
size() - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
 
size() - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisMap
 
size() - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisSet
 
size() - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisZSet
 
size() - Method in class org.springframework.data.keyvalue.redis.support.collections.RedisProperties
 
skip(long) - Method in class org.springframework.data.keyvalue.riak.core.io.RiakInputStream
 
sMembers(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
sMembers(String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
sMembers(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
sMembers(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
sMembers(byte[]) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisSetCommands
 
sMembers(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
sMembers(String) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
sMove(byte[], byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
sMove(String, String, String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
sMove(byte[], byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
sMove(byte[], byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
sMove(byte[], byte[], byte[]) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisSetCommands
 
sMove(byte[], byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
sMove(String, String, String) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
sort(byte[], SortParameters, byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
sort(byte[], SortParameters) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
sort(String, SortParameters, String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
sort(String, SortParameters) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
sort(byte[], SortParameters) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
sort(byte[], SortParameters, byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
sort(byte[], SortParameters) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
sort(byte[], SortParameters, byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
sort(byte[], SortParameters) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisKeyCommands
 
sort(byte[], SortParameters, byte[]) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisKeyCommands
 
sort(byte[], SortParameters) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
sort(byte[], SortParameters, byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
sort(String, SortParameters) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
sort(String, SortParameters, String) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
sort(K) - Static method in class org.springframework.data.keyvalue.redis.core.query.SortQueryBuilder
 
sort(SortQuery<K>) - Method in interface org.springframework.data.keyvalue.redis.core.RedisOperations
 
sort(SortQuery<K>, RedisSerializer<T>) - Method in interface org.springframework.data.keyvalue.redis.core.RedisOperations
 
sort(SortQuery<K>, BulkMapper<T, V>) - Method in interface org.springframework.data.keyvalue.redis.core.RedisOperations
 
sort(SortQuery<K>, BulkMapper<T, S>, RedisSerializer<S>) - Method in interface org.springframework.data.keyvalue.redis.core.RedisOperations
 
sort(SortQuery<K>, K) - Method in interface org.springframework.data.keyvalue.redis.core.RedisOperations
 
sort(SortQuery<K>) - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
 
sort(SortQuery<K>, RedisSerializer<T>) - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
 
sort(SortQuery<K>, BulkMapper<T, V>) - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
 
sort(SortQuery<K>, BulkMapper<T, S>, RedisSerializer<S>) - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
 
sort(SortQuery<K>, K) - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
 
SortCriterion<K> - Interface in org.springframework.data.keyvalue.redis.core.query
Internal interface part of the Sort DSL.
SortParameters - Interface in org.springframework.data.keyvalue.redis.connection
Entity containing the parameters for the SORT operation.
SortParameters.Order - Enum in org.springframework.data.keyvalue.redis.connection
Sorting order.
SortParameters.Range - Class in org.springframework.data.keyvalue.redis.connection
Utility class wrapping the 'LIMIT' setting.
SortParameters.Range(long, long) - Constructor for class org.springframework.data.keyvalue.redis.connection.SortParameters.Range
 
SortQuery<K> - Interface in org.springframework.data.keyvalue.redis.core.query
High-level abstraction over a Redis SORT (generified equivalent of SortParameters).
SortQueryBuilder<K> - Class in org.springframework.data.keyvalue.redis.core.query
Simple builder class for constructing SortQuery.
source - Variable in class org.springframework.data.keyvalue.riak.mapreduce.JavascriptMapReduceOperation
 
sPop(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
sPop(String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
sPop(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
sPop(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
sPop(byte[]) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisSetCommands
 
sPop(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
sPop(String) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
sRandMember(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
sRandMember(String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
sRandMember(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
sRandMember(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
sRandMember(byte[]) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisSetCommands
 
sRandMember(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
sRandMember(String) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
sRem(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
sRem(String, String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
sRem(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
sRem(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
sRem(byte[], byte[]) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisSetCommands
 
sRem(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
sRem(String, String) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
start() - Method in class org.springframework.data.keyvalue.redis.listener.RedisMessageListenerContainer
 
stop(Runnable) - Method in class org.springframework.data.keyvalue.redis.listener.RedisMessageListenerContainer
 
stop() - Method in class org.springframework.data.keyvalue.redis.listener.RedisMessageListenerContainer
 
storeToXML(OutputStream, String, String) - Method in class org.springframework.data.keyvalue.redis.support.collections.RedisProperties
 
storeToXML(OutputStream, String) - Method in class org.springframework.data.keyvalue.redis.support.collections.RedisProperties
 
StringRedisConnection - Interface in org.springframework.data.keyvalue.redis.connection
Convenience extension of RedisConnection that accepts and returns Strings instead of byte arrays.
StringRedisConnection.StringTuple - Interface in org.springframework.data.keyvalue.redis.connection
String-friendly ZSet tuple.
StringRedisSerializer - Class in org.springframework.data.keyvalue.redis.serializer
Simple String to byte[] (and back) serializer.
StringRedisSerializer() - Constructor for class org.springframework.data.keyvalue.redis.serializer.StringRedisSerializer
 
StringRedisSerializer(Charset) - Constructor for class org.springframework.data.keyvalue.redis.serializer.StringRedisSerializer
 
StringRedisTemplate - Class in org.springframework.data.keyvalue.redis.core
String-focused extension of RedisTemplate.
StringRedisTemplate() - Constructor for class org.springframework.data.keyvalue.redis.core.StringRedisTemplate
Constructs a new StringRedisTemplate instance.
StringRedisTemplate(RedisConnectionFactory) - Constructor for class org.springframework.data.keyvalue.redis.core.StringRedisTemplate
Constructs a new StringRedisTemplate instance ready to be used.
strLen(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
strLen(String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
strLen(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
strLen(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
strLen(byte[]) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisStringCommands
 
strLen(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
strLen(String) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
subList(int, int) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
 
submit(MapReduceJob) - Method in class org.springframework.data.keyvalue.riak.core.RiakKeyValueTemplate
 
submit(MapReduceJob) - Method in class org.springframework.data.keyvalue.riak.core.RiakTemplate
 
submit(MapReduceJob) - Method in interface org.springframework.data.keyvalue.riak.mapreduce.MapReduceOperations
Submit the job to run asynchronously.
subscribe(MessageListener, byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
subscribe(MessageListener, String...) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
subscribe(MessageListener, byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
subscribe(MessageListener, byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
subscribe(MessageListener, byte[]...) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisPubSubCommands
Subscribes the connection to the given channels.
subscribe(MessageListener, byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
subscribe(MessageListener, String...) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
subscribe(byte[]...) - Method in interface org.springframework.data.keyvalue.redis.connection.Subscription
Adds the given channels to the current subscription.
subscribe(byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.util.AbstractSubscription
 
Subscription - Interface in org.springframework.data.keyvalue.redis.connection
Subscription for Redis channels.
sUnion(byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
sUnion(String...) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
sUnion(byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
sUnion(byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
sUnion(byte[]...) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisSetCommands
 
sUnion(byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
sUnion(String...) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
sUnionStore(byte[], byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
sUnionStore(String, String...) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
sUnionStore(byte[], byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
sUnionStore(byte[], byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
sUnionStore(byte[], byte[]...) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisSetCommands
 
sUnionStore(byte[], byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
sUnionStore(String, String...) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 

T

take() - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
 
takeFirst() - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
 
takeLast() - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
 
timeout - Variable in class org.springframework.data.keyvalue.riak.groovy.RiakMapReduceOperation
 
timeout - Variable in class org.springframework.data.keyvalue.riak.groovy.RiakOperation
 
toHash(T) - Method in class org.springframework.data.keyvalue.redis.hash.BeanUtilsHashMapper
 
toHash(T) - Method in class org.springframework.data.keyvalue.redis.hash.DecoratingStringHashMapper
 
toHash(T) - Method in interface org.springframework.data.keyvalue.redis.hash.HashMapper
 
toHash(T) - Method in class org.springframework.data.keyvalue.redis.hash.JacksonHashMapper
 
toJson() - Method in class org.springframework.data.keyvalue.riak.mapreduce.AbstractRiakMapReduceJob
 
toJson() - Method in interface org.springframework.data.keyvalue.riak.mapreduce.MapReduceJob
Convert this job into the appropriate JSON to send to the server.
Topic - Interface in org.springframework.data.keyvalue.redis.listener
Topic for a Redis message.
toString() - Method in class org.springframework.data.keyvalue.redis.connection.DefaultMessage
 
toString() - Method in class org.springframework.data.keyvalue.redis.support.atomic.RedisAtomicInteger
Returns the String representation of the current value.
toString() - Method in class org.springframework.data.keyvalue.redis.support.atomic.RedisAtomicLong
Returns the String representation of the current value.
toString() - Method in class org.springframework.data.keyvalue.redis.support.collections.AbstractRedisCollection
 
toString() - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisMap
 
toString() - Method in class org.springframework.data.keyvalue.riak.core.io.RiakFile
 
toString() - Method in class org.springframework.data.keyvalue.riak.core.SimpleBucketKeyPair
 
toURI() - Method in class org.springframework.data.keyvalue.riak.core.io.RiakFile
 
toURL() - Method in class org.springframework.data.keyvalue.riak.core.io.RiakFile
 
translateExceptionIfPossible(RuntimeException) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnectionFactory
 
translateExceptionIfPossible(RuntimeException) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnectionFactory
 
translateExceptionIfPossible(RuntimeException) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnectionFactory
 
trim(long, long) - Method in interface org.springframework.data.keyvalue.redis.core.BoundListOperations
 
trim(K, long, long) - Method in interface org.springframework.data.keyvalue.redis.core.ListOperations
 
trim(int, int) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisList
 
trim(int, int) - Method in interface org.springframework.data.keyvalue.redis.support.collections.RedisList
 
ttl(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
ttl(String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
ttl(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
ttl(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
ttl(byte[]) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisKeyCommands
 
ttl(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
ttl(String) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
type(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
type(String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
type(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
type(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
type(byte[]) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisKeyCommands
 
type(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
type(String) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
type(K) - Method in interface org.springframework.data.keyvalue.redis.core.RedisOperations
 
type(K) - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
 
type - Variable in class org.springframework.data.keyvalue.riak.groovy.RiakOperation
 

U

unbindConnection(RedisConnectionFactory) - Static method in class org.springframework.data.keyvalue.redis.core.RedisConnectionUtils
Unbinds and closes the connection (if any) associated with the given factory.
UncategorizedKeyvalueStoreException - Exception in org.springframework.data.keyvalue
 
UncategorizedKeyvalueStoreException(String, Throwable) - Constructor for exception org.springframework.data.keyvalue.UncategorizedKeyvalueStoreException
 
union(K) - Method in interface org.springframework.data.keyvalue.redis.core.BoundSetOperations
 
union(Collection<K>) - Method in interface org.springframework.data.keyvalue.redis.core.BoundSetOperations
 
union(K, K) - Method in interface org.springframework.data.keyvalue.redis.core.SetOperations
 
union(K, Collection<K>) - Method in interface org.springframework.data.keyvalue.redis.core.SetOperations
 
union(RedisSet<?>) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisSet
 
union(Collection<? extends RedisSet<?>>) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisSet
 
union(RedisSet<?>) - Method in interface org.springframework.data.keyvalue.redis.support.collections.RedisSet
 
union(Collection<? extends RedisSet<?>>) - Method in interface org.springframework.data.keyvalue.redis.support.collections.RedisSet
 
unionAndStore(K, K) - Method in interface org.springframework.data.keyvalue.redis.core.BoundSetOperations
 
unionAndStore(Collection<K>, K) - Method in interface org.springframework.data.keyvalue.redis.core.BoundSetOperations
 
unionAndStore(K, K) - Method in interface org.springframework.data.keyvalue.redis.core.BoundZSetOperations
 
unionAndStore(Collection<K>, K) - Method in interface org.springframework.data.keyvalue.redis.core.BoundZSetOperations
 
unionAndStore(K, K, K) - Method in interface org.springframework.data.keyvalue.redis.core.SetOperations
 
unionAndStore(K, Collection<K>, K) - Method in interface org.springframework.data.keyvalue.redis.core.SetOperations
 
unionAndStore(K, K, K) - Method in interface org.springframework.data.keyvalue.redis.core.ZSetOperations
 
unionAndStore(K, Collection<K>, K) - Method in interface org.springframework.data.keyvalue.redis.core.ZSetOperations
 
unionAndStore(RedisSet<?>, String) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisSet
 
unionAndStore(Collection<? extends RedisSet<?>>, String) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisSet
 
unionAndStore(RedisZSet<?>, String) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisZSet
 
unionAndStore(Collection<? extends RedisZSet<?>>, String) - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisZSet
 
unionAndStore(RedisSet<?>, String) - Method in interface org.springframework.data.keyvalue.redis.support.collections.RedisSet
 
unionAndStore(Collection<? extends RedisSet<?>>, String) - Method in interface org.springframework.data.keyvalue.redis.support.collections.RedisSet
 
unionAndStore(RedisZSet<?>, String) - Method in interface org.springframework.data.keyvalue.redis.support.collections.RedisZSet
 
unionAndStore(Collection<? extends RedisZSet<?>>, String) - Method in interface org.springframework.data.keyvalue.redis.support.collections.RedisZSet
 
unsubscribe() - Method in interface org.springframework.data.keyvalue.redis.connection.Subscription
Cancels the current subscription for all channels given by name.
unsubscribe(byte[]...) - Method in interface org.springframework.data.keyvalue.redis.connection.Subscription
Cancels the current subscription for all given channels.
unsubscribe() - Method in class org.springframework.data.keyvalue.redis.connection.util.AbstractSubscription
 
unsubscribe(byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.util.AbstractSubscription
 
unwatch() - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
unwatch() - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
unwatch() - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
unwatch() - Method in interface org.springframework.data.keyvalue.redis.connection.RedisTxCommands
 
unwatch() - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
unwatch() - Method in interface org.springframework.data.keyvalue.redis.core.RedisOperations
 
unwatch() - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
 
updateBucketSchema(B, Map<String, Object>) - Method in interface org.springframework.data.keyvalue.riak.core.KeyValueStoreOperations
 
updateBucketSchema(B, Map<String, Object>) - Method in class org.springframework.data.keyvalue.riak.core.RiakKeyValueTemplate
 
updateBucketSchema(B, Map<String, Object>) - Method in class org.springframework.data.keyvalue.riak.core.RiakTemplate
 
useCache - Variable in class org.springframework.data.keyvalue.riak.core.AbstractRiakTemplate
Whether or not to use the ETag-based cache.

V

value - Variable in class org.springframework.data.keyvalue.riak.groovy.RiakOperation
 
valueOf(String) - Static method in enum org.springframework.data.keyvalue.redis.connection.DataType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.data.keyvalue.redis.connection.RedisListCommands.Position
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.data.keyvalue.redis.connection.RedisZSetCommands.Aggregate
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.data.keyvalue.redis.connection.SortParameters.Order
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.data.keyvalue.redis.support.collections.RedisCollectionFactoryBean.CollectionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.data.keyvalue.riak.mapreduce.MapReducePhase.Phase
Returns the enum constant of this type with the specified name.
ValueOperations<K,V> - Interface in org.springframework.data.keyvalue.redis.core
Redis operations for simple (or in Redis terminology 'string') values.
values() - Static method in enum org.springframework.data.keyvalue.redis.connection.DataType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.data.keyvalue.redis.connection.RedisListCommands.Position
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.data.keyvalue.redis.connection.RedisZSetCommands.Aggregate
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.data.keyvalue.redis.connection.SortParameters.Order
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in interface org.springframework.data.keyvalue.redis.core.BoundHashOperations
 
values(H) - Method in interface org.springframework.data.keyvalue.redis.core.HashOperations
 
values() - Method in class org.springframework.data.keyvalue.redis.support.collections.DefaultRedisMap
 
values() - Static method in enum org.springframework.data.keyvalue.redis.support.collections.RedisCollectionFactoryBean.CollectionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.springframework.data.keyvalue.redis.support.collections.RedisProperties
 
values() - Static method in enum org.springframework.data.keyvalue.riak.mapreduce.MapReducePhase.Phase
Returns an array containing the constants of this enum type, in the order they are declared.

W

watch(byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
watch(byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
watch(byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
watch(byte[]...) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisTxCommands
 
watch(byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
watch(K) - Method in interface org.springframework.data.keyvalue.redis.core.RedisOperations
 
watch(Collection<K>) - Method in interface org.springframework.data.keyvalue.redis.core.RedisOperations
 
watch(K) - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
 
watch(Collection<K>) - Method in class org.springframework.data.keyvalue.redis.core.RedisTemplate
 
workerPool - Variable in class org.springframework.data.keyvalue.riak.core.AbstractRiakTemplate
ExecutorService to use for running asynchronous jobs.
workerPool - Variable in class org.springframework.data.keyvalue.riak.groovy.RiakBuilder
 
writeThreshold - Variable in class org.springframework.data.keyvalue.riak.core.RiakQosParameters
 

Z

zAdd(byte[], double, byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
zAdd(String, double, String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
zAdd(byte[], double, byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
zAdd(byte[], double, byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
zAdd(byte[], double, byte[]) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisZSetCommands
 
zAdd(byte[], double, byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
zAdd(String, double, String) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
zCard(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
zCard(String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
zCard(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
zCard(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
zCard(byte[]) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisZSetCommands
 
zCard(byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
zCard(String) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
zCount(byte[], double, double) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
zCount(String, double, double) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
zCount(byte[], double, double) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
zCount(byte[], double, double) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
zCount(byte[], double, double) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisZSetCommands
 
zCount(byte[], double, double) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
zCount(String, double, double) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
zIncrBy(byte[], double, byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
zIncrBy(String, double, String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
zIncrBy(byte[], double, byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
zIncrBy(byte[], double, byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
zIncrBy(byte[], double, byte[]) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisZSetCommands
 
zIncrBy(byte[], double, byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
zIncrBy(String, double, String) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
zInterStore(byte[], RedisZSetCommands.Aggregate, int[], byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
zInterStore(byte[], byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
zInterStore(String, RedisZSetCommands.Aggregate, int[], String...) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
zInterStore(String, String...) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
zInterStore(byte[], RedisZSetCommands.Aggregate, int[], byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
zInterStore(byte[], byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
zInterStore(byte[], RedisZSetCommands.Aggregate, int[], byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
zInterStore(byte[], byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
zInterStore(byte[], byte[]...) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisZSetCommands
 
zInterStore(byte[], RedisZSetCommands.Aggregate, int[], byte[]...) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisZSetCommands
 
zInterStore(byte[], RedisZSetCommands.Aggregate, int[], byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
zInterStore(byte[], byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
zInterStore(String, String...) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
zInterStore(String, RedisZSetCommands.Aggregate, int[], String...) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
zRange(byte[], long, long) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
zRange(String, long, long) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
zRange(byte[], long, long) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
zRange(byte[], long, long) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
zRange(byte[], long, long) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisZSetCommands
 
zRange(byte[], long, long) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
zRange(String, long, long) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
zRangeByScore(byte[], double, double, long, long) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
zRangeByScore(byte[], double, double) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
zRangeByScore(String, double, double, long, long) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
zRangeByScore(String, double, double) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
zRangeByScore(byte[], double, double) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
zRangeByScore(byte[], double, double, long, long) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
zRangeByScore(byte[], double, double) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
zRangeByScore(byte[], double, double, long, long) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
zRangeByScore(byte[], double, double) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisZSetCommands
 
zRangeByScore(byte[], double, double, long, long) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisZSetCommands
 
zRangeByScore(byte[], double, double) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
zRangeByScore(byte[], double, double, long, long) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
zRangeByScore(String, double, double) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
zRangeByScore(String, double, double, long, long) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
zRangeByScoreWithScores(byte[], double, double, long, long) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
zRangeByScoreWithScores(byte[], double, double) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
zRangeByScoreWithScores(String, double, double, long, long) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
zRangeByScoreWithScores(String, double, double) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
zRangeByScoreWithScores(byte[], double, double) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
zRangeByScoreWithScores(byte[], double, double, long, long) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
zRangeByScoreWithScores(byte[], double, double) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
zRangeByScoreWithScores(byte[], double, double, long, long) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
zRangeByScoreWithScores(byte[], double, double) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisZSetCommands
 
zRangeByScoreWithScores(byte[], double, double, long, long) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisZSetCommands
 
zRangeByScoreWithScores(byte[], double, double) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
zRangeByScoreWithScores(byte[], double, double, long, long) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
zRangeByScoreWithScores(String, double, double) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
zRangeByScoreWithScores(String, double, double, long, long) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
zRangeWithScores(byte[], long, long) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
zRangeWithScores(String, long, long) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
zRangeWithScores(byte[], long, long) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
zRangeWithScores(byte[], long, long) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
zRangeWithScores(byte[], long, long) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisZSetCommands
 
zRangeWithScores(byte[], long, long) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
zRangeWithScores(String, long, long) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
zRank(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
zRank(String, String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
zRank(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
zRank(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
zRank(byte[], byte[]) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisZSetCommands
 
zRank(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
zRank(String, String) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
zRem(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
zRem(String, String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
zRem(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
zRem(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
zRem(byte[], byte[]) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisZSetCommands
 
zRem(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
zRem(String, String) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
zRemRange(byte[], long, long) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
zRemRange(String, long, long) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
zRemRange(byte[], long, long) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
zRemRange(byte[], long, long) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
zRemRange(byte[], long, long) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisZSetCommands
 
zRemRange(byte[], long, long) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
zRemRange(String, long, long) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
zRemRangeByScore(byte[], double, double) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
zRemRangeByScore(String, double, double) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
zRemRangeByScore(byte[], double, double) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
zRemRangeByScore(byte[], double, double) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
zRemRangeByScore(byte[], double, double) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisZSetCommands
 
zRemRangeByScore(byte[], double, double) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
zRemRangeByScore(String, double, double) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
zRevRange(byte[], long, long) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
zRevRange(String, long, long) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
zRevRange(byte[], long, long) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
zRevRange(byte[], long, long) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
zRevRange(byte[], long, long) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisZSetCommands
 
zRevRange(byte[], long, long) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
zRevRange(String, long, long) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
zRevRangeByScore(byte[], double, double, long, long) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
zRevRangeByScore(byte[], double, double) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
zRevRangeByScore(byte[], double, double, long, long) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
zRevRangeByScore(byte[], double, double) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
zRevRangeByScore(byte[], double, double, long, long) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
zRevRangeByScore(byte[], double, double) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
zRevRangeByScore(byte[], double, double) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisZSetCommands
 
zRevRangeByScore(byte[], double, double, long, long) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisZSetCommands
 
zRevRangeByScore(byte[], double, double, long, long) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
zRevRangeByScore(byte[], double, double) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
zRevRangeByScoreWithScores(byte[], double, double, long, long) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
zRevRangeByScoreWithScores(byte[], double, double) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
zRevRangeByScoreWithScores(byte[], double, double, long, long) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
zRevRangeByScoreWithScores(byte[], double, double) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
zRevRangeByScoreWithScores(byte[], double, double, long, long) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
zRevRangeByScoreWithScores(byte[], double, double) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
zRevRangeByScoreWithScores(byte[], double, double) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisZSetCommands
 
zRevRangeByScoreWithScores(byte[], double, double, long, long) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisZSetCommands
 
zRevRangeByScoreWithScores(byte[], double, double, long, long) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
zRevRangeByScoreWithScores(byte[], double, double) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
zRevRangeWithScores(byte[], long, long) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
zRevRangeWithScores(String, long, long) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
zRevRangeWithScores(byte[], long, long) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
zRevRangeWithScores(byte[], long, long) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
zRevRangeWithScores(byte[], long, long) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisZSetCommands
 
zRevRangeWithScores(byte[], long, long) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
zRevRangeWithScores(String, long, long) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
zRevRank(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
zRevRank(String, String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
zRevRank(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
zRevRank(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
zRevRank(byte[], byte[]) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisZSetCommands
 
zRevRank(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
zRevRank(String, String) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
zScore(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
zScore(String, String) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
zScore(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
zScore(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
zScore(byte[], byte[]) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisZSetCommands
 
zScore(byte[], byte[]) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
zScore(String, String) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
ZSetOperations<K,V> - Interface in org.springframework.data.keyvalue.redis.core
Redis ZSet/sorted set specific operations.
ZSetOperations.TypedTuple<V> - Interface in org.springframework.data.keyvalue.redis.core
Typed ZSet tuple.
zUnionStore(byte[], RedisZSetCommands.Aggregate, int[], byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
zUnionStore(byte[], byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
zUnionStore(String, RedisZSetCommands.Aggregate, int[], String...) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
zUnionStore(String, String...) - Method in class org.springframework.data.keyvalue.redis.connection.DefaultStringRedisConnection
 
zUnionStore(byte[], RedisZSetCommands.Aggregate, int[], byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
zUnionStore(byte[], byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.jedis.JedisConnection
 
zUnionStore(byte[], RedisZSetCommands.Aggregate, int[], byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
zUnionStore(byte[], byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.jredis.JredisConnection
 
zUnionStore(byte[], byte[]...) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisZSetCommands
 
zUnionStore(byte[], RedisZSetCommands.Aggregate, int[], byte[]...) - Method in interface org.springframework.data.keyvalue.redis.connection.RedisZSetCommands
 
zUnionStore(byte[], RedisZSetCommands.Aggregate, int[], byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
zUnionStore(byte[], byte[]...) - Method in class org.springframework.data.keyvalue.redis.connection.rjc.RjcConnection
 
zUnionStore(String, String...) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 
zUnionStore(String, RedisZSetCommands.Aggregate, int[], String...) - Method in interface org.springframework.data.keyvalue.redis.connection.StringRedisConnection
 

A B C D E F G H I J K L M N O P Q R S T U V W Z
Spring Data Key-Value

Copyright © 2010-2011 SpringSource. All Rights Reserved.