A B C D E F G H I J K L M N O P Q R S T U V W Z 
All Classes All Packages

A

AbstractListenableFuture<T,​L extends GenericCompletionListener> - Class in net.spy.memcached.internal
The AbstractListenableFuture implements common functionality shared by all futures that implement the ListenableFuture.
AbstractListenableFuture(ExecutorService) - Constructor for class net.spy.memcached.internal.AbstractListenableFuture
AbstractLogger - Class in net.spy.memcached.compat.log
Abstract implementation of Logger providing most of the common framework.
AbstractLogger(String) - Constructor for class net.spy.memcached.compat.log.AbstractLogger
Instantiate the abstract logger.
AbstractMetricCollector - Class in net.spy.memcached.metrics
This abstract class implements methods needed by all MetricCollectors.
AbstractMetricCollector() - Constructor for class net.spy.memcached.metrics.AbstractMetricCollector
 
add - net.spy.memcached.ops.StoreType
Store a value in the cache iff there is not already something stored for the given key.
add(String, int, Object) - Method in class net.spy.memcached.MemcachedClient
Add an object to the cache (using the default transcoder) iff it does not exist already.
add(String, int, Object) - Method in interface net.spy.memcached.MemcachedClientIF
 
add(String, int, T, Transcoder<T>) - Method in class net.spy.memcached.MemcachedClient
Add an object to the cache iff it does not exist already.
add(String, int, T, Transcoder<T>) - Method in interface net.spy.memcached.MemcachedClientIF
 
ADD - Static variable in class net.spy.memcached.protocol.binary.StoreOperationImpl
 
addCallbacks(GetOperation) - Method in class net.spy.memcached.protocol.ProxyCallback
 
addClone(Operation) - Method in interface net.spy.memcached.ops.Operation
Add the clone from this operation.
addClone(Operation) - Method in class net.spy.memcached.protocol.BaseOperationImpl
 
addCounter(String) - Method in class net.spy.memcached.metrics.DefaultMetricCollector
 
addCounter(String) - Method in interface net.spy.memcached.metrics.MetricCollector
Add a Counter to the collector.
addCounter(String) - Method in class net.spy.memcached.metrics.NoopMetricCollector
 
addedQueue - Variable in class net.spy.memcached.MemcachedConnection
AddedQueue is used to track the QueueAttachments for which operations have recently been queued.
addExtraHeaders(ByteBuffer, Object...) - Method in class net.spy.memcached.protocol.binary.OperationImpl
Add the extra headers to the write ByteBuffer.
addHistogram(String) - Method in class net.spy.memcached.metrics.DefaultMetricCollector
 
addHistogram(String) - Method in interface net.spy.memcached.metrics.MetricCollector
Add a Histogram to the Collector.
addHistogram(String) - Method in class net.spy.memcached.metrics.NoopMetricCollector
 
addKey(String) - Method in class net.spy.memcached.protocol.binary.MultiGetOperationImpl
Add a key (and return its new opaque value).
addListener(L) - Method in interface net.spy.memcached.internal.ListenableFuture
Add a listener to the future, which will be executed once the operation completes.
addListener(BulkGetCompletionListener) - Method in interface net.spy.memcached.internal.BulkFuture
Add a listener to the future, which will be executed once the operation completes.
addListener(BulkGetCompletionListener) - Method in class net.spy.memcached.internal.BulkGetFuture
 
addListener(GetCompletionListener) - Method in class net.spy.memcached.internal.GetFuture
 
addListener(OperationCompletionListener) - Method in class net.spy.memcached.internal.OperationFuture
 
addMeter(String) - Method in class net.spy.memcached.metrics.DefaultMetricCollector
 
addMeter(String) - Method in interface net.spy.memcached.metrics.MetricCollector
Add a Meter to the Collector.
addMeter(String) - Method in class net.spy.memcached.metrics.NoopMetricCollector
 
addNotMyVbucketNode(MemcachedNode) - Method in interface net.spy.memcached.ops.VBucketAware
 
addNotMyVbucketNode(MemcachedNode) - Method in class net.spy.memcached.protocol.binary.MultiKeyOperationImpl
 
addNotMyVbucketNode(MemcachedNode) - Method in class net.spy.memcached.protocol.binary.SingleKeyOperationImpl
 
addObserver(ConnectionObserver) - Method in class net.spy.memcached.MemcachedClient
Add a connection observer.
addObserver(ConnectionObserver) - Method in interface net.spy.memcached.MemcachedClientIF
 
addObserver(ConnectionObserver) - Method in class net.spy.memcached.MemcachedConnection
Add a connection observer.
addObserver(ConnectionObserver) - Method in class net.spy.memcached.TapConnectionProvider
Add a connection observer.
addOp(Operation) - Method in interface net.spy.memcached.MemcachedNode
Add an operation to the queue.
addOp(Operation) - Method in class net.spy.memcached.MemcachedNodeROImpl
 
addOp(Operation) - Method in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
addOp(TapOperation) - Method in class net.spy.memcached.tapmessage.TapStream
Add an operation to the stream of TAP messages which have been sent to the server.
addOperation(String, Operation) - Method in class net.spy.memcached.MemcachedConnection
Add an operation to a connection identified by the given key.
addOperation(MemcachedNode, Operation) - Method in class net.spy.memcached.MemcachedConnection
Enqueue an operation on the given node.
addOperation(CASOperation) - Method in class net.spy.memcached.protocol.binary.OptimizedSetImpl
 
addOperation(GetOperation) - Method in class net.spy.memcached.protocol.ascii.OptimizedGetImpl
Add a new GetOperation to get.
addOperation(GetOperation) - Method in class net.spy.memcached.protocol.binary.OptimizedGetImpl
Add a new GetOperation to get.
addOperations(Map<MemcachedNode, Operation>) - Method in class net.spy.memcached.MemcachedConnection
Enqueue the given list of operations on each handling node.
ADDQ - Static variable in class net.spy.memcached.protocol.binary.StoreOperationImpl
 
addrs - Variable in class net.spy.memcached.TapClient
 
AddrUtil - Class in net.spy.memcached
Convenience utilities for simplifying common address parsing.
AddrUtil() - Constructor for class net.spy.memcached.AddrUtil
 
addTapAckOp(MemcachedNode, Operation) - Method in class net.spy.memcached.TapConnectionProvider
 
addToListeners(GenericCompletionListener<? extends Future<T>>) - Method in class net.spy.memcached.internal.AbstractListenableFuture
Add the given listener to the total list of listeners to be notified.
afterKeyBytes(ByteBuffer) - Method in class net.spy.memcached.protocol.ascii.BaseGetOpImpl
 
afterKeyBytesSize() - Method in class net.spy.memcached.protocol.ascii.BaseGetOpImpl
 
allCallbacks - Variable in class net.spy.memcached.protocol.ProxyCallback
 
allNodes - Variable in class net.spy.memcached.KetamaNodeLocator
 
allowedAuthAttempts - Variable in class net.spy.memcached.auth.AuthDescriptor
 
amount - Variable in class net.spy.memcached.protocol.ascii.MutatorOperationImpl
 
append - net.spy.memcached.ops.ConcatenationType
Concatenate supplied data to the end of the existing data.
append(long, String, Object) - Method in class net.spy.memcached.MemcachedClient
Append to an existing value in the cache.
append(long, String, Object) - Method in interface net.spy.memcached.MemcachedClientIF
 
append(long, String, T, Transcoder<T>) - Method in class net.spy.memcached.MemcachedClient
Append to an existing value in the cache.
append(long, String, T, Transcoder<T>) - Method in interface net.spy.memcached.MemcachedClientIF
 
append(String, Object) - Method in class net.spy.memcached.MemcachedClient
Append to an existing value in the cache.
append(String, Object) - Method in interface net.spy.memcached.MemcachedClientIF
 
append(String, T, Transcoder<T>) - Method in class net.spy.memcached.MemcachedClient
Append to an existing value in the cache.
append(String, T, Transcoder<T>) - Method in interface net.spy.memcached.MemcachedClientIF
 
APPEND - Static variable in class net.spy.memcached.protocol.binary.ConcatenationOperationImpl
 
ARRAY_MOD - net.spy.memcached.ConnectionFactoryBuilder.Locator
Array modulus - the classic node location algorithm.
ArrayModNodeLocator - Class in net.spy.memcached
NodeLocator implementation for dealing with simple array lookups using a modulus of the hash code and node list length.
ArrayModNodeLocator(List<MemcachedNode>, HashAlgorithm) - Constructor for class net.spy.memcached.ArrayModNodeLocator
Construct an ArraymodNodeLocator over the given array of nodes and using the given hash algorithm.
ArrayModNodeLocator(MemcachedNode[], HashAlgorithm) - Constructor for class net.spy.memcached.ArrayModNodeLocator
 
ArrayModNodeLocator.NodeIterator - Class in net.spy.memcached
 
ArrayOperationQueueFactory - Class in net.spy.memcached.ops
OperationQueueFactory that uses an ArrayBlockingQueue.
ArrayOperationQueueFactory(int) - Constructor for class net.spy.memcached.ops.ArrayOperationQueueFactory
Create an ArrayOperationQueueFactory that creates blocking queues with the given capacity.
AsciiMemcachedNodeImpl - Class in net.spy.memcached.protocol.ascii
Memcached node for the ASCII protocol.
AsciiMemcachedNodeImpl(SocketAddress, SocketChannel, int, BlockingQueue<Operation>, BlockingQueue<Operation>, BlockingQueue<Operation>, Long, long, long, ConnectionFactory) - Constructor for class net.spy.memcached.protocol.ascii.AsciiMemcachedNodeImpl
 
AsciiOperationFactory - Class in net.spy.memcached.protocol.ascii
Operation factory for the ascii protocol.
AsciiOperationFactory() - Constructor for class net.spy.memcached.protocol.ascii.AsciiOperationFactory
 
asyncCAS(String, long, int, Object) - Method in class net.spy.memcached.MemcachedClient
Asynchronous CAS operation using the default transcoder with expiration.
asyncCAS(String, long, int, Object) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncCAS(String, long, int, T, Transcoder<T>) - Method in class net.spy.memcached.MemcachedClient
Asynchronous CAS operation.
asyncCAS(String, long, int, T, Transcoder<T>) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncCAS(String, long, Object) - Method in class net.spy.memcached.MemcachedClient
Asynchronous CAS operation using the default transcoder.
asyncCAS(String, long, Object) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncCAS(String, long, T, Transcoder<T>) - Method in class net.spy.memcached.MemcachedClient
Asynchronous CAS operation.
asyncCAS(String, long, T, Transcoder<T>) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncCat(ConcatenationType, long, String, T, Transcoder<T>) - Method in class net.spy.memcached.MemcachedClient
 
asyncDecode(CachedData) - Method in class net.spy.memcached.transcoders.BaseSerializingTranscoder
 
asyncDecode(CachedData) - Method in class net.spy.memcached.transcoders.IntegerTranscoder
 
asyncDecode(CachedData) - Method in class net.spy.memcached.transcoders.LongTranscoder
 
asyncDecode(CachedData) - Method in class net.spy.memcached.transcoders.SerializingTranscoder
 
asyncDecode(CachedData) - Method in interface net.spy.memcached.transcoders.Transcoder
Should the transcoder be run asyncronously.
asyncDecr(String, int) - Method in class net.spy.memcached.MemcachedClient
Asynchronous decrement.
asyncDecr(String, int) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncDecr(String, int, long) - Method in class net.spy.memcached.MemcachedClient
Asynchronous decrement.
asyncDecr(String, int, long) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncDecr(String, int, long, int) - Method in class net.spy.memcached.MemcachedClient
Asynchronous decrement.
asyncDecr(String, int, long, int) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncDecr(String, long) - Method in class net.spy.memcached.MemcachedClient
Asynchronous decrement.
asyncDecr(String, long) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncDecr(String, long, long) - Method in class net.spy.memcached.MemcachedClient
Asynchronous decrement.
asyncDecr(String, long, long) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncDecr(String, long, long, int) - Method in class net.spy.memcached.MemcachedClient
Asynchronous decrement.
asyncDecr(String, long, long, int) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncGet(String) - Method in class net.spy.memcached.MemcachedClient
Get the given key asynchronously and decode with the default transcoder.
asyncGet(String) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncGet(String, Transcoder<T>) - Method in class net.spy.memcached.MemcachedClient
Get the given key asynchronously.
asyncGet(String, Transcoder<T>) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncGetAndTouch(String, int) - Method in class net.spy.memcached.MemcachedClient
Get the given key to reset its expiration time.
asyncGetAndTouch(String, int) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncGetAndTouch(String, int, Transcoder<T>) - Method in class net.spy.memcached.MemcachedClient
Get the given key to reset its expiration time.
asyncGetAndTouch(String, int, Transcoder<T>) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncGetBulk(String...) - Method in class net.spy.memcached.MemcachedClient
Varargs wrapper for asynchronous bulk gets with the default transcoder.
asyncGetBulk(String...) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncGetBulk(Collection<String>) - Method in class net.spy.memcached.MemcachedClient
Asynchronously get a bunch of objects from the cache and decode them with the given transcoder.
asyncGetBulk(Collection<String>) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncGetBulk(Collection<String>, Iterator<Transcoder<T>>) - Method in class net.spy.memcached.MemcachedClient
Asynchronously get a bunch of objects from the cache.
asyncGetBulk(Collection<String>, Iterator<Transcoder<T>>) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncGetBulk(Collection<String>, Transcoder<T>) - Method in class net.spy.memcached.MemcachedClient
Asynchronously get a bunch of objects from the cache.
asyncGetBulk(Collection<String>, Transcoder<T>) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncGetBulk(Iterator<String>) - Method in class net.spy.memcached.MemcachedClient
Asynchronously get a bunch of objects from the cache and decode them with the given transcoder.
asyncGetBulk(Iterator<String>) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncGetBulk(Iterator<String>, Iterator<Transcoder<T>>) - Method in class net.spy.memcached.MemcachedClient
Asynchronously get a bunch of objects from the cache.
asyncGetBulk(Iterator<String>, Iterator<Transcoder<T>>) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncGetBulk(Iterator<String>, Transcoder<T>) - Method in class net.spy.memcached.MemcachedClient
Asynchronously get a bunch of objects from the cache.
asyncGetBulk(Iterator<String>, Transcoder<T>) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncGetBulk(Transcoder<T>, String...) - Method in class net.spy.memcached.MemcachedClient
Varargs wrapper for asynchronous bulk gets.
asyncGetBulk(Transcoder<T>, String...) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncGets(String) - Method in class net.spy.memcached.MemcachedClient
Gets (with CAS support) the given key asynchronously and decode using the default transcoder.
asyncGets(String) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncGets(String, Transcoder<T>) - Method in class net.spy.memcached.MemcachedClient
Gets (with CAS support) the given key asynchronously.
asyncGets(String, Transcoder<T>) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncIncr(String, int) - Method in class net.spy.memcached.MemcachedClient
Asychronous increment.
asyncIncr(String, int) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncIncr(String, int, long) - Method in class net.spy.memcached.MemcachedClient
Asychronous increment.
asyncIncr(String, int, long) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncIncr(String, int, long, int) - Method in class net.spy.memcached.MemcachedClient
Asychronous increment.
asyncIncr(String, int, long, int) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncIncr(String, long) - Method in class net.spy.memcached.MemcachedClient
Asychronous increment.
asyncIncr(String, long) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncIncr(String, long, long) - Method in class net.spy.memcached.MemcachedClient
Asychronous increment.
asyncIncr(String, long, long) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncIncr(String, long, long, int) - Method in class net.spy.memcached.MemcachedClient
Asychronous increment.
asyncIncr(String, long, long, int) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncMutate(Mutator, String, long, long, int) - Method in class net.spy.memcached.MemcachedClient
 
asyncStore(StoreType, String, int, Object) - Method in class net.spy.memcached.MemcachedClient
 
asyncStore(StoreType, String, int, T, Transcoder<T>) - Method in class net.spy.memcached.MemcachedClient
 
attemptReconnects() - Method in class net.spy.memcached.MemcachedConnection
Attempt to reconnect MemcachedNodes in the reconnect queue.
AUTH_ROUNDTRIP_THRESHOLD - Static variable in class net.spy.memcached.auth.AuthThread
If a SASL step takes longer than this period in milliseconds, a warning will be issued instead of a debug message.
AUTH_TOTAL_THRESHOLD - Static variable in class net.spy.memcached.auth.AuthThread
If the total AUTH steps take longer than this period in milliseconds, a warning will be issued instead of a debug message.
authAttempts - Variable in class net.spy.memcached.auth.AuthDescriptor
 
authComplete() - Method in interface net.spy.memcached.MemcachedNode
Let the node know that auth is complete.
authComplete() - Method in class net.spy.memcached.MemcachedNodeROImpl
 
authComplete() - Method in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
authConnection(MemcachedConnection, OperationFactory, AuthDescriptor, MemcachedNode) - Method in class net.spy.memcached.auth.AuthThreadMonitor
Authenticate a new connection.
authDescriptor - Variable in class net.spy.memcached.auth.AuthThread
 
authDescriptor - Variable in class net.spy.memcached.ConnectionFactoryBuilder
 
authDescriptor - Variable in class net.spy.memcached.MemcachedClient
 
authDescriptor - Variable in class net.spy.memcached.TapConnectionProvider
 
AuthDescriptor - Class in net.spy.memcached.auth
Information required to specify authentication mechanisms and callbacks.
AuthDescriptor(String[], CallbackHandler) - Constructor for class net.spy.memcached.auth.AuthDescriptor
Request authentication using the given list of mechanisms and callback handler.
authLatch - Variable in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
authMonitor - Variable in class net.spy.memcached.MemcachedClient
 
authMonitor - Variable in class net.spy.memcached.TapConnectionProvider
 
AuthThread - Class in net.spy.memcached.auth
A thread that does SASL authentication.
AuthThread(MemcachedConnection, OperationFactory, AuthDescriptor, MemcachedNode) - Constructor for class net.spy.memcached.auth.AuthThread
 
AuthThreadMonitor - Class in net.spy.memcached.auth
This will ensure no more than one AuthThread will exist for a given MemcachedNode.
AuthThreadMonitor() - Constructor for class net.spy.memcached.auth.AuthThreadMonitor
 
authThresholdReached() - Method in class net.spy.memcached.auth.AuthDescriptor
 
authWaitTime - Variable in class net.spy.memcached.ConnectionFactoryBuilder
 
authWaitTime - Variable in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 

B

BACKFILL - net.spy.memcached.tapmessage.TapRequestFlag
Tap backfill flag definition.
backfilldate - Variable in class net.spy.memcached.tapmessage.RequestMessage
 
barrier - Variable in class net.spy.memcached.compat.SyncThread
 
BaseCacheMap<V> - Class in net.spy.memcached
Base class for a Map interface to memcached.
BaseCacheMap(MemcachedClientIF, int, String, Transcoder<V>) - Constructor for class net.spy.memcached.BaseCacheMap
Build a BaseCacheMap.
BaseGetOpImpl - Class in net.spy.memcached.protocol.ascii
Base class for get and gets handlers.
BaseGetOpImpl(String, int, OperationCallback, String) - Constructor for class net.spy.memcached.protocol.ascii.BaseGetOpImpl
 
BaseGetOpImpl(String, OperationCallback, Collection<String>) - Constructor for class net.spy.memcached.protocol.ascii.BaseGetOpImpl
 
BaseMessage - Class in net.spy.memcached.tapmessage
The BaseMessage implements the header of a tap message.
BaseMessage() - Constructor for class net.spy.memcached.tapmessage.BaseMessage
 
BaseMessage(byte[]) - Constructor for class net.spy.memcached.tapmessage.BaseMessage
 
BaseOperationFactory - Class in net.spy.memcached.ops
Base class for operation factories.
BaseOperationFactory() - Constructor for class net.spy.memcached.ops.BaseOperationFactory
 
BaseOperationImpl - Class in net.spy.memcached.protocol
Base class for protocol-specific operation implementations.
BaseOperationImpl() - Constructor for class net.spy.memcached.protocol.BaseOperationImpl
 
BaseSerializingTranscoder - Class in net.spy.memcached.transcoders
Base class for any transcoders that may want to work with serialized or compressed data.
BaseSerializingTranscoder(int) - Constructor for class net.spy.memcached.transcoders.BaseSerializingTranscoder
Initialize a serializing transcoder with the given maximum data size.
BaseStoreOperationImpl - Class in net.spy.memcached.protocol.ascii
Base class for ascii store operations (add, set, replace, append, prepend).
BaseStoreOperationImpl(String, String, int, int, byte[], OperationCallback) - Constructor for class net.spy.memcached.protocol.ascii.BaseStoreOperationImpl
 
BasicThreadFactory - Class in net.spy.memcached.internal
Simple thread factory that can set daemon status on threads and give them names.
BasicThreadFactory(String, boolean) - Constructor for class net.spy.memcached.internal.BasicThreadFactory
 
belongsToCluster(MemcachedNode) - Method in class net.spy.memcached.MemcachedConnection
Makes sure that the given node belongs to the current cluster.
BINARY - net.spy.memcached.ConnectionFactoryBuilder.Protocol
Use the binary protocol.
BinaryConnectionFactory - Class in net.spy.memcached
Default connection factory for binary wire protocol connections.
BinaryConnectionFactory() - Constructor for class net.spy.memcached.BinaryConnectionFactory
Create a DefaultConnectionFactory with the default parameters.
BinaryConnectionFactory(int, int) - Constructor for class net.spy.memcached.BinaryConnectionFactory
Create a BinaryConnectionFactory with the given maximum operation queue length, and the given read buffer size.
BinaryConnectionFactory(int, int, HashAlgorithm) - Constructor for class net.spy.memcached.BinaryConnectionFactory
Construct a BinaryConnectionFactory with the given parameters.
BinaryMemcachedNodeImpl - Class in net.spy.memcached.protocol.binary
Implementation of MemcachedNode for speakers of the binary protocol.
BinaryMemcachedNodeImpl(SocketAddress, SocketChannel, int, BlockingQueue<Operation>, BlockingQueue<Operation>, BlockingQueue<Operation>, Long, boolean, long, long, ConnectionFactory) - Constructor for class net.spy.memcached.protocol.binary.BinaryMemcachedNodeImpl
 
BinaryOperationFactory - Class in net.spy.memcached.protocol.binary
Factory for binary operations.
BinaryOperationFactory() - Constructor for class net.spy.memcached.protocol.binary.BinaryOperationFactory
 
bkeys - Variable in class net.spy.memcached.protocol.binary.MultiGetOperationImpl
 
bodylen - Variable in class net.spy.memcached.protocol.binary.TapOperationImpl
 
broadcastOp(BroadcastOpFactory) - Method in class net.spy.memcached.MemcachedClient
 
broadcastOp(BroadcastOpFactory) - Method in interface net.spy.memcached.MemcachedClientIF
 
broadcastOp(BroadcastOpFactory) - Method in class net.spy.memcached.TapConnectionProvider
 
broadcastOp(BroadcastOpFactory, Collection<MemcachedNode>) - Method in class net.spy.memcached.MemcachedClient
 
broadcastOp(BroadcastOpFactory, Collection<MemcachedNode>) - Method in interface net.spy.memcached.MemcachedClientIF
 
broadcastOp(BroadcastOpFactory, Collection<MemcachedNode>, boolean) - Method in class net.spy.memcached.MemcachedClient
 
broadcastOp(BroadcastOpFactory, Collection<MemcachedNode>, boolean) - Method in class net.spy.memcached.TapConnectionProvider
 
broadcastOperation(BroadcastOpFactory) - Method in class net.spy.memcached.MemcachedConnection
Broadcast an operation to all nodes.
broadcastOperation(BroadcastOpFactory, Collection<MemcachedNode>) - Method in class net.spy.memcached.MemcachedConnection
Broadcast an operation to a collection of nodes.
BroadcastOpFactory - Interface in net.spy.memcached
Factory for creating Operations to be broadcast.
bufSize - Variable in class net.spy.memcached.MemcachedConnection
The buffer size that will be used when reading from the server.
build() - Method in class net.spy.memcached.ConnectionFactoryBuilder
Get the ConnectionFactory set up with the provided parameters.
buildOperation(OperationStatus, OperationCallback, String[]) - Method in class net.spy.memcached.auth.AuthThread
 
buildResponse(SaslClient) - Method in class net.spy.memcached.protocol.binary.SASLAuthOperationImpl
 
buildResponse(SaslClient) - Method in class net.spy.memcached.protocol.binary.SASLBaseOperationImpl
 
buildResponse(SaslClient) - Method in class net.spy.memcached.protocol.binary.SASLStepOperationImpl
 
buildTimeoutMessage(long, TimeUnit) - Method in class net.spy.memcached.MemcachedClient
 
BulkFuture<V> - Interface in net.spy.memcached.internal
Additional flexibility for asyncGetBulk
BulkGetCompletionListener - Interface in net.spy.memcached.internal
A listener that will be notified once the bulk get future completes.
BulkGetFuture<T> - Class in net.spy.memcached.internal
Future for handling results from bulk gets.
BulkGetFuture(Map<String, Future<T>>, Collection<Operation>, CountDownLatch, ExecutorService) - Constructor for class net.spy.memcached.internal.BulkGetFuture
 
by - Variable in class net.spy.memcached.protocol.binary.MutatorOperationImpl
 
byteBuffer - Variable in class net.spy.memcached.protocol.ascii.OperationImpl
 
byteCount - Variable in class net.spy.memcached.protocol.binary.OptimizedSetImpl
 
bytes() - Method in class net.spy.memcached.protocol.binary.OptimizedSetImpl
 
bytesProcessed - Variable in class net.spy.memcached.protocol.binary.TapOperationImpl
 

C

CachedData - Class in net.spy.memcached
Cached data with its attributes.
CachedData(int, byte[], int) - Constructor for class net.spy.memcached.CachedData
Get a CachedData instance for the given flags and byte array.
CacheLoader - Class in net.spy.memcached.util
CacheLoader provides efficient mechanisms for storing lots of data.
CacheLoader(MemcachedClientIF) - Constructor for class net.spy.memcached.util.CacheLoader
Simple CacheLoader constructor that doesn't provide any feedback and caches forever.
CacheLoader(MemcachedClientIF, ExecutorService, CacheLoader.StorageListener, int) - Constructor for class net.spy.memcached.util.CacheLoader
Get a CacheLoader with all the options.
CacheLoader.StorageListener - Interface in net.spy.memcached.util
If you are interested in the results of your data load, this interface will receive them.
CacheMap - Class in net.spy.memcached
A Map interface to memcached.
CacheMap(MemcachedClientIF, int, String) - Constructor for class net.spy.memcached.CacheMap
Construct a CacheMap over the given MemcachedClient.
CacheMap(MemcachedClientIF, String) - Constructor for class net.spy.memcached.CacheMap
Construct a CacheMap over the given MemcachedClient with no expiration.
calculateExtraLength(Object...) - Method in class net.spy.memcached.protocol.binary.OperationImpl
Calculate the length of all extra headers.
callable - Variable in class net.spy.memcached.compat.SyncThread
 
callback - Variable in class net.spy.memcached.protocol.BaseOperationImpl
 
callbacks - Variable in class net.spy.memcached.protocol.binary.OptimizedSetImpl
 
callbacks - Variable in class net.spy.memcached.protocol.ProxyCallback
 
cancel() - Method in class net.spy.memcached.internal.OperationFuture
Cancel this operation, if possible.
cancel() - Method in interface net.spy.memcached.ops.Operation
Cancel this operation.
cancel() - Method in class net.spy.memcached.protocol.BaseOperationImpl
 
cancel() - Method in class net.spy.memcached.tapmessage.TapStream
Cancels all operations still waiting on an existing TapStream.
cancel(boolean) - Method in class net.spy.memcached.internal.BulkGetFuture
 
cancel(boolean) - Method in class net.spy.memcached.internal.GetFuture
 
cancel(boolean) - Method in class net.spy.memcached.internal.ImmediateFuture
 
cancel(boolean) - Method in class net.spy.memcached.internal.OperationFuture
Deprecated. 
Cancel - net.spy.memcached.FailureMode
Automatically cancel all operations heading towards a downed node.
cancelled - Variable in class net.spy.memcached.internal.BulkGetFuture
 
cancelled - Variable in class net.spy.memcached.protocol.BaseOperationImpl
 
CANCELLED - net.spy.memcached.ops.StatusCode
 
CANCELLED - Static variable in class net.spy.memcached.protocol.BaseOperationImpl
Status object for canceled operations.
CancelledOperationStatus - Class in net.spy.memcached.ops
Operation status indicating an operation was cancelled.
CancelledOperationStatus() - Constructor for class net.spy.memcached.ops.CancelledOperationStatus
 
cancelOperations(Collection<Operation>) - Method in class net.spy.memcached.MemcachedConnection
Cancel the given collection of operations.
capacity - Variable in class net.spy.memcached.ops.ArrayOperationQueueFactory
 
cas - Variable in class net.spy.memcached.CASValue
 
cas - Variable in class net.spy.memcached.internal.OperationFuture
 
cas - Variable in class net.spy.memcached.protocol.ascii.UnlockOperationImpl
 
cas - Variable in class net.spy.memcached.protocol.binary.ConcatenationOperationImpl
 
cas - Variable in class net.spy.memcached.protocol.binary.DeleteOperationImpl
 
cas - Variable in class net.spy.memcached.protocol.binary.ObserveOperationImpl
 
cas - Variable in class net.spy.memcached.protocol.binary.StoreOperationImpl
 
cas - Variable in class net.spy.memcached.protocol.binary.UnlockOperationImpl
 
cas - Variable in class net.spy.memcached.tapmessage.BaseMessage
 
cas(String, long, int, Object) - Method in class net.spy.memcached.MemcachedClient
Perform a synchronous CAS operation with the default transcoder.
cas(String, long, int, Object) - Method in interface net.spy.memcached.MemcachedClientIF
 
cas(String, long, int, T, Transcoder<T>) - Method in class net.spy.memcached.MemcachedClient
Perform a synchronous CAS operation.
cas(String, long, int, T, Transcoder<T>) - Method in interface net.spy.memcached.MemcachedClientIF
 
cas(String, long, Object) - Method in class net.spy.memcached.MemcachedClient
Perform a synchronous CAS operation with the default transcoder.
cas(String, long, Object) - Method in interface net.spy.memcached.MemcachedClientIF
 
cas(String, long, T, Transcoder<T>) - Method in class net.spy.memcached.MemcachedClient
Perform a synchronous CAS operation.
cas(String, long, T, Transcoder<T>) - Method in interface net.spy.memcached.MemcachedClientIF
 
cas(String, T, int, CASMutation<T>) - Method in class net.spy.memcached.CASMutator
CAS a new value in for a key.
cas(StoreType, String, long, int, int, byte[], StoreOperation.Callback) - Method in interface net.spy.memcached.OperationFactory
Create a CAS operation.
cas(StoreType, String, long, int, int, byte[], StoreOperation.Callback) - Method in class net.spy.memcached.protocol.ascii.AsciiOperationFactory
 
cas(StoreType, String, long, int, int, byte[], StoreOperation.Callback) - Method in class net.spy.memcached.protocol.binary.BinaryOperationFactory
 
CAS_OFFSET - Static variable in class net.spy.memcached.tapmessage.BaseMessage
 
CASMutation<T> - Interface in net.spy.memcached
Defines a mutation mechanism for a high-level CAS client interface.
CASMutator<T> - Class in net.spy.memcached
Object that provides mutation via CAS over a given memcache client.
CASMutator(MemcachedClientIF, Transcoder<T>) - Constructor for class net.spy.memcached.CASMutator
Construct a CASMutator that uses the given client.
CASMutator(MemcachedClientIF, Transcoder<T>, int) - Constructor for class net.spy.memcached.CASMutator
Construct a CASMutator that uses the given client.
CASOperation - Interface in net.spy.memcached.ops
Operation that represents compare-and-swap.
CASOperationImpl - Class in net.spy.memcached.protocol.ascii
 
CASOperationImpl(String, long, int, int, byte[], OperationCallback) - Constructor for class net.spy.memcached.protocol.ascii.CASOperationImpl
 
CASOperationStatus - Class in net.spy.memcached.ops
OperationStatus subclass for indicating CAS status.
CASOperationStatus(boolean, String, CASResponse, StatusCode) - Constructor for class net.spy.memcached.ops.CASOperationStatus
 
casResponse - Variable in class net.spy.memcached.ops.CASOperationStatus
 
CASResponse - Enum in net.spy.memcached
Response codes for a CAS operation.
CASResponse() - Constructor for enum net.spy.memcached.CASResponse
 
casValue - Variable in class net.spy.memcached.protocol.ascii.BaseGetOpImpl
 
casValue - Variable in class net.spy.memcached.protocol.ascii.CASOperationImpl
 
CASValue<T> - Class in net.spy.memcached
A value with a CAS identifier.
CASValue(long, T) - Constructor for class net.spy.memcached.CASValue
Construct a new CASValue with the given identifer and value.
cat(ConcatenationType, long, String, byte[], OperationCallback) - Method in interface net.spy.memcached.OperationFactory
Get a concatenation operation.
cat(ConcatenationType, long, String, byte[], OperationCallback) - Method in class net.spy.memcached.protocol.ascii.AsciiOperationFactory
 
cat(ConcatenationType, long, String, byte[], OperationCallback) - Method in class net.spy.memcached.protocol.binary.BinaryOperationFactory
 
catType - Variable in class net.spy.memcached.protocol.binary.ConcatenationOperationImpl
 
cb - Variable in class net.spy.memcached.protocol.ascii.StatsOperationImpl
 
cb - Variable in class net.spy.memcached.protocol.GetCallbackWrapper
 
cb - Variable in class net.spy.memcached.tapmessage.TapAck
 
cbh - Variable in class net.spy.memcached.auth.AuthDescriptor
 
cbh - Variable in class net.spy.memcached.protocol.binary.SASLBaseOperationImpl
 
challenge - Variable in class net.spy.memcached.protocol.binary.SASLBaseOperationImpl
 
channel - Variable in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
charset - Variable in class net.spy.memcached.transcoders.BaseSerializingTranscoder
 
CHARSET - Static variable in class net.spy.memcached.protocol.ascii.OperationImpl
 
CheckedOperationTimeoutException - Exception in net.spy.memcached.internal
Timeout exception that tracks the original operation.
CheckedOperationTimeoutException(String, Collection<Operation>) - Constructor for exception net.spy.memcached.internal.CheckedOperationTimeoutException
 
CheckedOperationTimeoutException(String, Operation) - Constructor for exception net.spy.memcached.internal.CheckedOperationTimeoutException
Construct a CheckedOperationTimeoutException with the given message and operation.
checkpoint - Variable in class net.spy.memcached.tapmessage.ResponseMessage
 
CHECKPOINT - net.spy.memcached.tapmessage.TapRequestFlag
Tap use checkpoints.
checkPotentiallyTimedOutConnection() - Method in class net.spy.memcached.MemcachedConnection
Check if one or more nodes exceeded the timeout Threshold.
checkState() - Method in class net.spy.memcached.MemcachedConnection
Check to see if this connection is shutting down.
classifyError(String) - Method in class net.spy.memcached.protocol.ascii.OperationImpl
 
clear() - Method in class net.spy.memcached.BaseCacheMap
 
client - Variable in class net.spy.memcached.BaseCacheMap
 
client - Variable in class net.spy.memcached.CASMutator
 
client - Variable in class net.spy.memcached.util.CacheLoader
 
CLIENT - net.spy.memcached.ops.OperationErrorType
Error that occurred because the client did something stupid.
clone(KeyedOperation) - Method in interface net.spy.memcached.OperationFactory
Clone an operation.
clone(KeyedOperation) - Method in class net.spy.memcached.ops.BaseOperationFactory
 
cloneCount - Variable in class net.spy.memcached.protocol.BaseOperationImpl
Number of clones for this operation.
cloneGet(KeyedOperation) - Method in class net.spy.memcached.ops.BaseOperationFactory
 
cloneGet(KeyedOperation) - Method in class net.spy.memcached.protocol.ascii.AsciiOperationFactory
 
cloneGet(KeyedOperation) - Method in class net.spy.memcached.protocol.binary.BinaryOperationFactory
 
clones - Variable in class net.spy.memcached.protocol.BaseOperationImpl
If the operation gets cloned, the reference is used to cascade cancellations and timeouts.
close(Closeable) - Static method in class net.spy.memcached.compat.CloseUtil
Close a closeable.
CloseUtil - Class in net.spy.memcached.compat
CloseUtil exists to provide a safe means to close anything closeable.
CloseUtil() - Constructor for class net.spy.memcached.compat.CloseUtil
 
cmd - Variable in class net.spy.memcached.protocol.ascii.BaseGetOpImpl
 
cmd - Variable in class net.spy.memcached.protocol.BaseOperationImpl
 
cmd - Variable in class net.spy.memcached.protocol.binary.OperationImpl
 
CMD - Static variable in class net.spy.memcached.protocol.ascii.GetlOperationImpl
 
CMD - Static variable in class net.spy.memcached.protocol.ascii.GetOperationImpl
 
CMD - Static variable in class net.spy.memcached.protocol.ascii.GetsOperationImpl
 
CMD - Static variable in class net.spy.memcached.protocol.ascii.UnlockOperationImpl
 
CMD - Static variable in class net.spy.memcached.protocol.binary.DeleteOperationImpl
 
CMD - Static variable in class net.spy.memcached.protocol.binary.FlushOperationImpl
 
CMD - Static variable in class net.spy.memcached.protocol.binary.KeyStatsOperationImpl
 
CMD - Static variable in class net.spy.memcached.protocol.binary.NoopOperationImpl
 
CMD - Static variable in class net.spy.memcached.protocol.binary.ObserveOperationImpl
 
CMD - Static variable in class net.spy.memcached.protocol.binary.SASLAuthOperationImpl
 
CMD - Static variable in class net.spy.memcached.protocol.binary.SASLMechsOperationImpl
 
CMD - Static variable in class net.spy.memcached.protocol.binary.SASLStepOperationImpl
 
CMD - Static variable in class net.spy.memcached.protocol.binary.StatsOperationImpl
 
CMD - Static variable in class net.spy.memcached.protocol.binary.TapOperationImpl
 
CMD - Static variable in class net.spy.memcached.protocol.binary.TouchOperationImpl
 
CMD - Static variable in class net.spy.memcached.protocol.binary.UnlockOperationImpl
 
CMD - Static variable in class net.spy.memcached.protocol.binary.VersionOperationImpl
 
CMD_DECR - Static variable in class net.spy.memcached.protocol.binary.MutatorOperationImpl
 
CMD_GETQ - Static variable in class net.spy.memcached.protocol.binary.MultiGetOperationImpl
 
CMD_INCR - Static variable in class net.spy.memcached.protocol.binary.MutatorOperationImpl
 
cmdMap(ConcatenationType) - Static method in class net.spy.memcached.protocol.binary.ConcatenationOperationImpl
 
cmdMap(StoreType) - Static method in class net.spy.memcached.protocol.binary.OptimizedSetImpl
 
cmdMap(StoreType) - Static method in class net.spy.memcached.protocol.binary.StoreOperationImpl
 
collector - Variable in class net.spy.memcached.ConnectionFactoryBuilder
 
complete() - Method in class net.spy.memcached.ops.MultiOperationCallback
 
complete() - Method in interface net.spy.memcached.ops.OperationCallback
Called whenever an operation completes.
complete() - Method in class net.spy.memcached.protocol.binary.OptimizedSetImpl.NoopCallback
 
complete() - Method in class net.spy.memcached.protocol.GetCallbackWrapper
 
complete() - Method in class net.spy.memcached.protocol.ProxyCallback
 
COMPLETE - net.spy.memcached.ops.OperationState
State indicating this operation is complete.
completed - Variable in class net.spy.memcached.protocol.GetCallbackWrapper
 
completedRead() - Method in interface net.spy.memcached.MemcachedNode
Notify node of successful read.
completedRead() - Method in class net.spy.memcached.MemcachedNodeROImpl
 
completedRead() - Method in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
Mark this node as having just completed a read.
compress(byte[]) - Method in class net.spy.memcached.transcoders.BaseSerializingTranscoder
Compress the given array of bytes.
COMPRESSED - Static variable in class net.spy.memcached.transcoders.SerializingTranscoder
 
COMPRESSED - Static variable in class net.spy.memcached.transcoders.WhalinTranscoder
 
COMPRESSED - Static variable in class net.spy.memcached.transcoders.WhalinV1Transcoder
 
compressionThreshold - Variable in class net.spy.memcached.transcoders.BaseSerializingTranscoder
 
computeMd5(String) - Static method in enum net.spy.memcached.DefaultHashAlgorithm
Get the md5 of the given key.
computeNext() - Method in class net.spy.memcached.ArrayModNodeLocator.NodeIterator
 
ConcatenationOperation - Interface in net.spy.memcached.ops
ConcatenationOperation is used to append or prepend data to an existing object in the cache.
ConcatenationOperationImpl - Class in net.spy.memcached.protocol.ascii
Operation for ascii concatenations.
ConcatenationOperationImpl - Class in net.spy.memcached.protocol.binary
 
ConcatenationOperationImpl(ConcatenationType, String, byte[], long, OperationCallback) - Constructor for class net.spy.memcached.protocol.binary.ConcatenationOperationImpl
 
ConcatenationOperationImpl(ConcatenationType, String, byte[], OperationCallback) - Constructor for class net.spy.memcached.protocol.ascii.ConcatenationOperationImpl
 
ConcatenationType - Enum in net.spy.memcached.ops
Types of concatenation operations.
ConcatenationType() - Constructor for enum net.spy.memcached.ops.ConcatenationType
 
concatType - Variable in class net.spy.memcached.protocol.ascii.ConcatenationOperationImpl
 
config - Variable in class net.spy.memcached.KetamaNodeLocator
 
conn - Variable in class net.spy.memcached.auth.AuthThread
 
conn - Variable in class net.spy.memcached.TapConnectionProvider
 
conn - Variable in class net.spy.memcached.tapmessage.TapAck
 
connected() - Method in interface net.spy.memcached.MemcachedNode
Notify this node that it has reconnected.
connected() - Method in class net.spy.memcached.MemcachedNodeROImpl
 
connected() - Method in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
connected(MemcachedNode) - Method in class net.spy.memcached.MemcachedConnection
Indicate a successful connect to the given node.
connection - Variable in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
connectionEstablished(SocketAddress, int) - Method in interface net.spy.memcached.ConnectionObserver
A connection has just successfully been established on the given socket.
connectionEstablished(SocketAddress, int) - Method in class net.spy.memcached.MemcachedClient
 
connectionEstablished(SocketAddress, int) - Method in class net.spy.memcached.TapConnectionProvider
 
connectionFactory - Variable in class net.spy.memcached.MemcachedConnection
The connection factory to create MemcachedNodes from.
connectionFactory - Variable in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
ConnectionFactory - Interface in net.spy.memcached
Factory for creating instances of MemcachedConnection.
ConnectionFactoryBuilder - Class in net.spy.memcached
Builder for more easily configuring a ConnectionFactory.
ConnectionFactoryBuilder() - Constructor for class net.spy.memcached.ConnectionFactoryBuilder
Set the operation queue factory.
ConnectionFactoryBuilder(ConnectionFactory) - Constructor for class net.spy.memcached.ConnectionFactoryBuilder
 
ConnectionFactoryBuilder.Locator - Enum in net.spy.memcached
Type of node locator to use.
ConnectionFactoryBuilder.Protocol - Enum in net.spy.memcached
Type of protocol to use for connections.
connectionLost(SocketAddress) - Method in interface net.spy.memcached.ConnectionObserver
A connection was just lost on the given socket.
connectionLost(SocketAddress) - Method in class net.spy.memcached.MemcachedClient
 
connectionLost(SocketAddress) - Method in class net.spy.memcached.TapConnectionProvider
 
ConnectionObserver - Interface in net.spy.memcached
Users of this interface will be notified when changes to the state of connections take place.
connectionsStatus() - Method in class net.spy.memcached.MemcachedConnection
Construct a String containing information about all nodes and their state.
connFactory - Variable in class net.spy.memcached.MemcachedClient
 
connObservers - Variable in class net.spy.memcached.MemcachedConnection
Holds all connection observers that get notified on connection status changes.
CONSISTENT - net.spy.memcached.ConnectionFactoryBuilder.Locator
Consistent hash algorithm.
containsKey(Object) - Method in class net.spy.memcached.BaseCacheMap
 
containsValue(Object) - Method in class net.spy.memcached.BaseCacheMap
This method always returns false, as truth cannot be determined without iteration.
continuousTimeout - Variable in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
copyInputQueue() - Method in interface net.spy.memcached.MemcachedNode
Move all of the operations delivered via addOperation into the internal write queue.
copyInputQueue() - Method in class net.spy.memcached.MemcachedNodeROImpl
 
copyInputQueue() - Method in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
counters - Variable in class net.spy.memcached.metrics.DefaultMetricCollector
Contains all registered Counters.
CRC_HASH - net.spy.memcached.DefaultHashAlgorithm
CRC_HASH as used by the perl API.
create() - Method in class net.spy.memcached.ops.ArrayOperationQueueFactory
 
create() - Method in class net.spy.memcached.ops.LinkedOperationQueueFactory
 
create() - Method in interface net.spy.memcached.ops.OperationQueueFactory
Create an instance of a queue.
createConnection(List<InetSocketAddress>) - Method in interface net.spy.memcached.ConnectionFactory
Create a MemcachedConnection for the given SocketAddresses.
createConnection(List<InetSocketAddress>) - Method in class net.spy.memcached.DefaultConnectionFactory
 
createConnections(Collection<InetSocketAddress>) - Method in class net.spy.memcached.MemcachedConnection
Create connections for the given list of addresses.
createLocator(List<MemcachedNode>) - Method in interface net.spy.memcached.ConnectionFactory
Create a NodeLocator instance for the given list of nodes.
createLocator(List<MemcachedNode>) - Method in class net.spy.memcached.DefaultConnectionFactory
 
createLocator(List<MemcachedNode>) - Method in class net.spy.memcached.KetamaConnectionFactory
 
createMemcachedNode(SocketAddress, SocketChannel, int) - Method in class net.spy.memcached.BinaryConnectionFactory
 
createMemcachedNode(SocketAddress, SocketChannel, int) - Method in interface net.spy.memcached.ConnectionFactory
Create a new memcached node.
createMemcachedNode(SocketAddress, SocketChannel, int) - Method in class net.spy.memcached.DefaultConnectionFactory
 
createMessage(String, Collection<Operation>) - Static method in exception net.spy.memcached.internal.CheckedOperationTimeoutException
 
createOperationQueue() - Method in interface net.spy.memcached.ConnectionFactory
Create a BlockingQueue for operations for a connection.
createOperationQueue() - Method in class net.spy.memcached.DefaultConnectionFactory
 
createReadOperationQueue() - Method in interface net.spy.memcached.ConnectionFactory
Create a BlockingQueue for the operations currently expecting to read responses from memcached.
createReadOperationQueue() - Method in class net.spy.memcached.DefaultConnectionFactory
 
createWriteOperationQueue() - Method in interface net.spy.memcached.ConnectionFactory
Create a BlockingQueue for the operations currently expecting to write requests to memcached.
createWriteOperationQueue() - Method in class net.spy.memcached.DefaultConnectionFactory
 
creationTime - Variable in class net.spy.memcached.protocol.BaseOperationImpl
 
CRLF - Static variable in class net.spy.memcached.protocol.ascii.OperationImpl
 
currentFlags - Variable in class net.spy.memcached.protocol.ascii.BaseGetOpImpl
 
currentKey - Variable in class net.spy.memcached.protocol.ascii.BaseGetOpImpl
 

D

daemon - Variable in class net.spy.memcached.internal.BasicThreadFactory
 
data - Variable in class net.spy.memcached.CachedData
 
data - Variable in class net.spy.memcached.protocol.ascii.BaseGetOpImpl
 
data - Variable in class net.spy.memcached.protocol.ascii.BaseStoreOperationImpl
 
data - Variable in class net.spy.memcached.protocol.ascii.CASOperationImpl
 
data - Variable in class net.spy.memcached.protocol.binary.ConcatenationOperationImpl
 
data - Variable in class net.spy.memcached.protocol.binary.StoreOperationImpl
 
DATA - net.spy.memcached.protocol.ascii.OperationReadType
Read type indicating an operation currently wants to read raw data.
datatype - Variable in class net.spy.memcached.tapmessage.BaseMessage
 
DATATYPE_OFFSET - Static variable in class net.spy.memcached.tapmessage.BaseMessage
 
date - Variable in class net.spy.memcached.protocol.binary.TapBackfillOperationImpl
 
dbgBuffer(ByteBuffer, int) - Static method in class net.spy.memcached.MemcachedConnection
Convert the ByteBuffer into a string for easier debugging.
debug(Object) - Method in class net.spy.memcached.compat.log.AbstractLogger
Log a message at debug level.
debug(Object) - Method in interface net.spy.memcached.compat.log.Logger
Log a message at debug level.
debug(Object, Throwable) - Method in class net.spy.memcached.compat.log.AbstractLogger
Log a message at debug level.
debug(Object, Throwable) - Method in interface net.spy.memcached.compat.log.Logger
Log a message at debug level.
debug(String, Object...) - Method in class net.spy.memcached.compat.log.AbstractLogger
Log a formatted message at debug level.
debug(String, Object...) - Method in interface net.spy.memcached.compat.log.Logger
Log a formatted message at debug level.
DEBUG - net.spy.memcached.compat.log.Level
Debug level.
DEBUG - net.spy.memcached.metrics.MetricType
Metrics useful for debugging.
decimalPattern - Static variable in class net.spy.memcached.util.StringUtils
A pattern to match on a signed integer value.
decode(CachedData) - Method in class net.spy.memcached.transcoders.IntegerTranscoder
 
decode(CachedData) - Method in class net.spy.memcached.transcoders.LongTranscoder
 
decode(CachedData) - Method in class net.spy.memcached.transcoders.SerializingTranscoder
 
decode(CachedData) - Method in interface net.spy.memcached.transcoders.Transcoder
Decode the cached object into the object it represents.
decode(CachedData) - Method in class net.spy.memcached.transcoders.WhalinTranscoder
 
decode(CachedData) - Method in class net.spy.memcached.transcoders.WhalinV1Transcoder
 
decode(Transcoder<T>, CachedData) - Method in class net.spy.memcached.transcoders.TranscodeService
Perform a decode.
decodeBoolean(byte[]) - Method in class net.spy.memcached.transcoders.TranscoderUtils
 
decodeBoolean(byte[]) - Method in class net.spy.memcached.transcoders.WhalinTranscoder
 
decodeBoolean(byte[]) - Method in class net.spy.memcached.transcoders.WhalinV1Transcoder
 
decodeByte(byte[]) - Method in class net.spy.memcached.transcoders.TranscoderUtils
 
decodeByte(byte[]) - Method in class net.spy.memcached.transcoders.WhalinV1Transcoder
 
decodeByte(byte[], int) - Static method in class net.spy.memcached.protocol.binary.OperationImpl
 
decodeCharacter(byte[]) - Method in class net.spy.memcached.transcoders.WhalinTranscoder
 
decodeCharacter(byte[]) - Method in class net.spy.memcached.transcoders.WhalinV1Transcoder
 
decodeDouble(byte[]) - Method in class net.spy.memcached.transcoders.WhalinV1Transcoder
 
decodeFloat(byte[]) - Method in class net.spy.memcached.transcoders.WhalinV1Transcoder
 
decodeInt(byte[]) - Method in class net.spy.memcached.transcoders.TranscoderUtils
 
decodeInt(byte[], int) - Static method in class net.spy.memcached.protocol.binary.OperationImpl
 
decodeInt(byte[], int) - Method in class net.spy.memcached.tapmessage.BaseMessage
 
decodeInteger(byte[]) - Method in class net.spy.memcached.transcoders.WhalinV1Transcoder
 
decodeIntHostOrder(byte[], int) - Method in class net.spy.memcached.tapmessage.BaseMessage
 
decodeLong(byte[]) - Method in class net.spy.memcached.transcoders.TranscoderUtils
 
decodeLong(byte[]) - Method in class net.spy.memcached.transcoders.WhalinV1Transcoder
 
decodeLong(byte[], int) - Static method in class net.spy.memcached.protocol.binary.OperationImpl
 
decodeLong(byte[], int) - Method in class net.spy.memcached.tapmessage.BaseMessage
 
decodePayload(byte[]) - Method in class net.spy.memcached.protocol.binary.DeleteOperationImpl
 
decodePayload(byte[]) - Method in class net.spy.memcached.protocol.binary.GetAndTouchOperationImpl
 
decodePayload(byte[]) - Method in class net.spy.memcached.protocol.binary.GetlOperationImpl
 
decodePayload(byte[]) - Method in class net.spy.memcached.protocol.binary.GetOperationImpl
 
decodePayload(byte[]) - Method in class net.spy.memcached.protocol.binary.GetsOperationImpl
 
decodePayload(byte[]) - Method in class net.spy.memcached.protocol.binary.MutatorOperationImpl
 
decodePayload(byte[]) - Method in class net.spy.memcached.protocol.binary.ObserveOperationImpl
 
decodePayload(byte[]) - Method in class net.spy.memcached.protocol.binary.OperationImpl
Decode the given payload for this command.
decodePayload(byte[]) - Method in class net.spy.memcached.protocol.binary.ReplicaGetOperationImpl
 
decodePayload(byte[]) - Method in class net.spy.memcached.protocol.binary.ReplicaGetsOperationImpl
 
decodePayload(byte[]) - Method in class net.spy.memcached.protocol.binary.SASLBaseOperationImpl
 
decodePayload(byte[]) - Method in class net.spy.memcached.protocol.binary.SASLMechsOperationImpl
 
decodePayload(byte[]) - Method in class net.spy.memcached.protocol.binary.StoreOperationImpl
 
decodePayload(byte[]) - Method in class net.spy.memcached.protocol.binary.TouchOperationImpl
 
decodePayload(byte[]) - Method in class net.spy.memcached.protocol.binary.UnlockOperationImpl
 
decodePayload(byte[]) - Method in class net.spy.memcached.protocol.binary.VersionOperationImpl
 
decodeShort(byte[]) - Method in class net.spy.memcached.transcoders.WhalinV1Transcoder
 
decodeShort(byte[], int) - Static method in class net.spy.memcached.protocol.binary.OperationImpl
 
decodeShort(byte[], int) - Method in class net.spy.memcached.tapmessage.BaseMessage
 
decodeString(byte[]) - Method in class net.spy.memcached.transcoders.BaseSerializingTranscoder
Decode the string with the current character set.
decodeUnsignedInt(byte[], int) - Static method in class net.spy.memcached.protocol.binary.OperationImpl
 
decodeW1String(byte[]) - Method in class net.spy.memcached.transcoders.WhalinV1Transcoder
 
decompress(byte[]) - Method in class net.spy.memcached.transcoders.BaseSerializingTranscoder
Decompress the given array of bytes.
decr - net.spy.memcached.ops.Mutator
Decrement a value on the memcached server.
decr(String, int) - Method in class net.spy.memcached.MemcachedClient
Decrement the given key by the given value.
decr(String, int) - Method in interface net.spy.memcached.MemcachedClientIF
 
decr(String, int, long) - Method in class net.spy.memcached.MemcachedClient
Decrement the given counter, returning the new value.
decr(String, int, long) - Method in interface net.spy.memcached.MemcachedClientIF
 
decr(String, int, long, int) - Method in class net.spy.memcached.MemcachedClient
Decrement the given counter, returning the new value.
decr(String, int, long, int) - Method in interface net.spy.memcached.MemcachedClientIF
 
decr(String, long) - Method in class net.spy.memcached.MemcachedClient
Decrement the given key by the given value.
decr(String, long) - Method in interface net.spy.memcached.MemcachedClientIF
 
decr(String, long, long) - Method in class net.spy.memcached.MemcachedClient
Decrement the given counter, returning the new value.
decr(String, long, long) - Method in interface net.spy.memcached.MemcachedClientIF
 
decr(String, long, long, int) - Method in class net.spy.memcached.MemcachedClient
Decrement the given counter, returning the new value.
decr(String, long, long, int) - Method in interface net.spy.memcached.MemcachedClientIF
 
decrementCounter(String) - Method in class net.spy.memcached.metrics.AbstractMetricCollector
 
decrementCounter(String) - Method in interface net.spy.memcached.metrics.MetricCollector
Decrement a Counter by one.
decrementCounter(String, int) - Method in class net.spy.memcached.metrics.DefaultMetricCollector
 
decrementCounter(String, int) - Method in interface net.spy.memcached.metrics.MetricCollector
Decrement a Counter by the given amount.
decrementCounter(String, int) - Method in class net.spy.memcached.metrics.NoopMetricCollector
 
def - Variable in class net.spy.memcached.protocol.binary.MutatorOperationImpl
 
DEFAULT_AUTH_WAIT_TIME - Static variable in class net.spy.memcached.DefaultConnectionFactory
The time to wait for the authentication to complete when a operation is written in milliseconds.
DEFAULT_CHARSET - Static variable in class net.spy.memcached.transcoders.BaseSerializingTranscoder
 
DEFAULT_COMPRESSION_THRESHOLD - Static variable in class net.spy.memcached.transcoders.BaseSerializingTranscoder
Default compression threshold value.
DEFAULT_FAILURE_MODE - Static variable in class net.spy.memcached.DefaultConnectionFactory
Default failure mode.
DEFAULT_HASH - Static variable in class net.spy.memcached.DefaultConnectionFactory
Default hash algorithm.
DEFAULT_MAX_RECONNECT_DELAY - Static variable in class net.spy.memcached.DefaultConnectionFactory
Maximum amount of time (in seconds) to wait between reconnect attempts.
DEFAULT_MAX_TIMEOUTEXCEPTION_THRESHOLD - Static variable in class net.spy.memcached.DefaultConnectionFactory
Maximum number + 2 of timeout exception for shutdown connection.
DEFAULT_METRIC_TYPE - Static variable in class net.spy.memcached.DefaultConnectionFactory
Turn off metric collection by default.
DEFAULT_OP_QUEUE_LEN - Static variable in class net.spy.memcached.DefaultConnectionFactory
Maximum length of the operation queue returned by this connection factory.
DEFAULT_OP_QUEUE_MAX_BLOCK_TIME - Static variable in class net.spy.memcached.DefaultConnectionFactory
The maximum time to block waiting for op queue operations to complete, in milliseconds.
DEFAULT_OPERATION_TIMEOUT - Static variable in class net.spy.memcached.DefaultConnectionFactory
Default operation timeout in milliseconds.
DEFAULT_READ_BUFFER_SIZE - Static variable in class net.spy.memcached.DefaultConnectionFactory
The read buffer size for each server connection from this factory.
DEFAULT_REPORTER_INTERVAL - Static variable in class net.spy.memcached.metrics.DefaultMetricCollector
Log every 30 seconds to the console by default.
DEFAULT_REPORTER_OUTDIR - Static variable in class net.spy.memcached.metrics.DefaultMetricCollector
Define an empty directory for the CSV exporter by default.
DEFAULT_REPORTER_TYPE - Static variable in class net.spy.memcached.metrics.DefaultMetricCollector
Use the "console" reporter by default.
DEFAULT_RETRY_QUEUE_SIZE - Static variable in class net.spy.memcached.MemcachedConnection
By default, do not bound the retry queue.
DEFAULT_WAKEUP_DELAY - Static variable in class net.spy.memcached.MemcachedConnection
The default wakeup delay if not overridden by a system property.
DefaultConnectionFactory - Class in net.spy.memcached
Default implementation of ConnectionFactory.
DefaultConnectionFactory() - Constructor for class net.spy.memcached.DefaultConnectionFactory
Create a DefaultConnectionFactory with the default parameters.
DefaultConnectionFactory(int, int) - Constructor for class net.spy.memcached.DefaultConnectionFactory
Create a DefaultConnectionFactory with the given maximum operation queue length, and the given read buffer size.
DefaultConnectionFactory(int, int, HashAlgorithm) - Constructor for class net.spy.memcached.DefaultConnectionFactory
Construct a DefaultConnectionFactory with the given parameters.
DefaultHashAlgorithm - Enum in net.spy.memcached
Known hashing algorithms for locating a server for a key.
DefaultHashAlgorithm() - Constructor for enum net.spy.memcached.DefaultHashAlgorithm
 
DefaultKetamaNodeLocatorConfiguration - Class in net.spy.memcached.util
A Default implementation of the configuration required for the KetamaNodeLocator algorithm to run.
DefaultKetamaNodeLocatorConfiguration() - Constructor for class net.spy.memcached.util.DefaultKetamaNodeLocatorConfiguration
Create a KetamaNodeLocatorConfiguraiton with the default SPYMEMCACHED node key format
DefaultKetamaNodeLocatorConfiguration(KetamaNodeKeyFormatter) - Constructor for class net.spy.memcached.util.DefaultKetamaNodeLocatorConfiguration
Create a KetamaNodeLocatorConfiguraiton
DefaultLogger - Class in net.spy.memcached.compat.log
Default logger implementation.
DefaultLogger(String) - Constructor for class net.spy.memcached.compat.log.DefaultLogger
Get an instance of DefaultLogger.
DefaultMetricCollector - Class in net.spy.memcached.metrics
A MetricCollector that uses the Codahale Metrics library.
DefaultMetricCollector() - Constructor for class net.spy.memcached.metrics.DefaultMetricCollector
defaultOpTimeout - Variable in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
delay - Variable in class net.spy.memcached.protocol.ascii.FlushOperationImpl
 
delay - Variable in class net.spy.memcached.protocol.binary.FlushOperationImpl
 
delete(String) - Method in class net.spy.memcached.MemcachedClient
Delete the given key from the cache.
delete(String) - Method in interface net.spy.memcached.MemcachedClientIF
 
delete(String, int) - Method in class net.spy.memcached.MemcachedClient
Deprecated.
Hold values are no longer honored.
delete(String, long) - Method in class net.spy.memcached.MemcachedClient
Delete the given key from the cache of the given CAS value applies.
delete(String, long) - Method in interface net.spy.memcached.MemcachedClientIF
 
delete(String, long, DeleteOperation.Callback) - Method in interface net.spy.memcached.OperationFactory
Create a deletion operation with CAS.
delete(String, long, DeleteOperation.Callback) - Method in class net.spy.memcached.protocol.ascii.AsciiOperationFactory
 
delete(String, long, DeleteOperation.Callback) - Method in class net.spy.memcached.protocol.binary.BinaryOperationFactory
 
delete(String, DeleteOperation.Callback) - Method in interface net.spy.memcached.OperationFactory
Create a deletion operation.
delete(String, DeleteOperation.Callback) - Method in class net.spy.memcached.protocol.ascii.AsciiOperationFactory
 
delete(String, DeleteOperation.Callback) - Method in class net.spy.memcached.protocol.binary.BinaryOperationFactory
 
DELETE - net.spy.memcached.tapmessage.TapOpcode
Defines a delete message to specify a key has been deleted.
DELETED - Static variable in class net.spy.memcached.protocol.ascii.DeleteOperationImpl
 
DeleteOperation - Interface in net.spy.memcached.ops
Deletion operation.
DeleteOperation.Callback - Interface in net.spy.memcached.ops
Delete operation callback.
DeleteOperationImpl - Class in net.spy.memcached.protocol.ascii
Operation to delete an item from the cache.
DeleteOperationImpl - Class in net.spy.memcached.protocol.binary
 
DeleteOperationImpl(String, long, DeleteOperation.Callback) - Constructor for class net.spy.memcached.protocol.binary.DeleteOperationImpl
 
DeleteOperationImpl(String, DeleteOperation.Callback) - Constructor for class net.spy.memcached.protocol.binary.DeleteOperationImpl
 
DeleteOperationImpl(String, OperationCallback) - Constructor for class net.spy.memcached.protocol.ascii.DeleteOperationImpl
 
deserialize() - Method in class net.spy.memcached.tapmessage.ResponseMessage
Attempt to get the object represented by the given serialized bytes.
deserialize(byte[]) - Method in class net.spy.memcached.transcoders.BaseSerializingTranscoder
Get the object represented by the given serialized bytes.
destroyInputQueue() - Method in interface net.spy.memcached.MemcachedNode
Extract all queued items for this node destructively.
destroyInputQueue() - Method in class net.spy.memcached.MemcachedNodeROImpl
 
destroyInputQueue() - Method in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
df - Variable in class net.spy.memcached.compat.log.DefaultLogger
 
doBackfill(long) - Method in class net.spy.memcached.tapmessage.MessageBuilder
 
doDump() - Method in class net.spy.memcached.tapmessage.MessageBuilder
 
DOUBLE_CHECK_EMPTY - Static variable in class net.spy.memcached.MemcachedConnection
The number of empty selects we'll allow before assuming we may have missed one and should check the current selectors.
DUMMY_OPCODE - Static variable in class net.spy.memcached.protocol.binary.OperationImpl
 
DUMP - net.spy.memcached.tapmessage.TapRequestFlag
Tap dump flag definition.

E

element - Variable in class net.spy.memcached.internal.SingleElementInfiniteIterator
 
EMPTY_BYTES - Static variable in class net.spy.memcached.protocol.binary.OperationImpl
 
emptySelects - Variable in class net.spy.memcached.MemcachedConnection
Contains the current number of empty select() calls, which could indicate bugs.
enableMetrics() - Method in interface net.spy.memcached.ConnectionFactory
If true, metric collections are enabled.
enableMetrics() - Method in class net.spy.memcached.DefaultConnectionFactory
 
encode(Integer) - Method in class net.spy.memcached.transcoders.IntegerTranscoder
 
encode(Long) - Method in class net.spy.memcached.transcoders.LongTranscoder
 
encode(Object) - Method in class net.spy.memcached.transcoders.SerializingTranscoder
 
encode(Object) - Method in class net.spy.memcached.transcoders.WhalinTranscoder
 
encode(Object) - Method in class net.spy.memcached.transcoders.WhalinV1Transcoder
 
encode(T) - Method in interface net.spy.memcached.transcoders.Transcoder
Encode the given object for storage.
encodeBoolean(boolean) - Method in class net.spy.memcached.transcoders.TranscoderUtils
 
encodeBoolean(boolean) - Method in class net.spy.memcached.transcoders.WhalinTranscoder
 
encodeBoolean(Boolean) - Method in class net.spy.memcached.transcoders.WhalinV1Transcoder
 
encodeByte(byte) - Method in class net.spy.memcached.transcoders.TranscoderUtils
 
encodeByte(Byte) - Method in class net.spy.memcached.transcoders.WhalinV1Transcoder
 
encodeCharacter(Character) - Method in class net.spy.memcached.transcoders.WhalinV1Transcoder
 
encodeDouble(Double) - Method in class net.spy.memcached.transcoders.WhalinV1Transcoder
 
encodeFloat(Float) - Method in class net.spy.memcached.transcoders.WhalinV1Transcoder
 
encodeInt(int) - Method in class net.spy.memcached.transcoders.TranscoderUtils
 
encodeInteger(Integer) - Method in class net.spy.memcached.transcoders.WhalinV1Transcoder
 
encodeLong(long) - Method in class net.spy.memcached.transcoders.TranscoderUtils
 
encodeLong(Long) - Method in class net.spy.memcached.transcoders.WhalinV1Transcoder
 
encodeLong(Long, int) - Method in class net.spy.memcached.transcoders.WhalinV1Transcoder
 
encodeNum(long, int) - Method in class net.spy.memcached.transcoders.TranscoderUtils
 
encodeNum(long, int) - Method in class net.spy.memcached.transcoders.WhalinV1Transcoder
 
encodeShort(Short) - Method in class net.spy.memcached.transcoders.WhalinV1Transcoder
 
encodeString(String) - Method in class net.spy.memcached.transcoders.BaseSerializingTranscoder
Encode a string into the current character set.
encodeStringBuffer(StringBuffer) - Method in class net.spy.memcached.transcoders.WhalinV1Transcoder
 
encodeStringbuilder(StringBuilder) - Method in class net.spy.memcached.transcoders.WhalinV1Transcoder
 
encodeW1String(String) - Method in class net.spy.memcached.transcoders.WhalinV1Transcoder
 
END - Static variable in class net.spy.memcached.protocol.ascii.BaseGetOpImpl
 
END - Static variable in class net.spy.memcached.protocol.ascii.StatsOperationImpl
 
END - Static variable in class net.spy.memcached.protocol.GetCallbackWrapper
 
END_CHECKPOINT - net.spy.memcached.tapmessage.TapOpcode
Defines the end of a checkpoint.
ENGINE_PRIVATE_OFFSET - Static variable in class net.spy.memcached.tapmessage.ResponseMessage
 
engineprivate - Variable in class net.spy.memcached.tapmessage.ResponseMessage
 
enqueueOperation(String, Operation) - Method in class net.spy.memcached.MemcachedConnection
Enqueue the given Operation with the used key.
entrySet() - Method in class net.spy.memcached.BaseCacheMap
 
ERR_2BIG - net.spy.memcached.ops.StatusCode
 
ERR_2BIG - Static variable in class net.spy.memcached.protocol.binary.OperationImpl
 
ERR_BUSY - net.spy.memcached.ops.StatusCode
 
ERR_BUSY - Static variable in class net.spy.memcached.protocol.binary.OperationImpl
 
ERR_CLIENT - net.spy.memcached.ops.StatusCode
 
ERR_DELTA_BADVAL - net.spy.memcached.ops.StatusCode
 
ERR_DELTA_BADVAL - Static variable in class net.spy.memcached.protocol.binary.OperationImpl
 
ERR_EXISTS - net.spy.memcached.ops.StatusCode
 
ERR_EXISTS - Static variable in class net.spy.memcached.protocol.binary.OperationImpl
 
ERR_INTERNAL - net.spy.memcached.ops.StatusCode
 
ERR_INTERNAL - Static variable in class net.spy.memcached.protocol.binary.OperationImpl
 
ERR_INVAL - net.spy.memcached.ops.StatusCode
 
ERR_INVAL - Static variable in class net.spy.memcached.protocol.binary.OperationImpl
 
ERR_NO_MEM - net.spy.memcached.ops.StatusCode
 
ERR_NO_MEM - Static variable in class net.spy.memcached.protocol.binary.OperationImpl
 
ERR_NOT_FOUND - net.spy.memcached.ops.StatusCode
 
ERR_NOT_FOUND - Static variable in class net.spy.memcached.protocol.binary.OperationImpl
 
ERR_NOT_MY_VBUCKET - net.spy.memcached.ops.StatusCode
 
ERR_NOT_MY_VBUCKET - Static variable in class net.spy.memcached.protocol.binary.OperationImpl
 
ERR_NOT_STORED - net.spy.memcached.ops.StatusCode
 
ERR_NOT_STORED - Static variable in class net.spy.memcached.protocol.binary.OperationImpl
 
ERR_NOT_SUPPORTED - net.spy.memcached.ops.StatusCode
 
ERR_NOT_SUPPORTED - Static variable in class net.spy.memcached.protocol.binary.OperationImpl
 
ERR_TEMP_FAIL - net.spy.memcached.ops.StatusCode
 
ERR_TEMP_FAIL - Static variable in class net.spy.memcached.protocol.binary.OperationImpl
 
ERR_UNKNOWN_COMMAND - net.spy.memcached.ops.StatusCode
 
ERR_UNKNOWN_COMMAND - Static variable in class net.spy.memcached.protocol.binary.OperationImpl
 
error(Object) - Method in class net.spy.memcached.compat.log.AbstractLogger
Log a message at error level.
error(Object) - Method in interface net.spy.memcached.compat.log.Logger
Log a message at error level.
error(Object, Throwable) - Method in class net.spy.memcached.compat.log.AbstractLogger
Log a message at error level.
error(Object, Throwable) - Method in interface net.spy.memcached.compat.log.Logger
Log a message at error level.
error(String, Object...) - Method in class net.spy.memcached.compat.log.AbstractLogger
Log a formatted message at debug level.
error(String, Object...) - Method in interface net.spy.memcached.compat.log.Logger
Log a formatted message at debug level.
ERROR - net.spy.memcached.compat.log.Level
Error level.
errorCode - Variable in class net.spy.memcached.protocol.binary.OperationImpl
 
errorMsg - Variable in class net.spy.memcached.protocol.ascii.OperationImpl
 
errorMsg - Variable in class net.spy.memcached.protocol.binary.OperationImpl
 
errorStoring(String, Exception) - Method in interface net.spy.memcached.util.CacheLoader.StorageListener
 
exception - Variable in class net.spy.memcached.internal.ImmediateFuture
 
exception - Variable in class net.spy.memcached.protocol.BaseOperationImpl
 
EXCESSIVE_EMPTY - Static variable in class net.spy.memcached.MemcachedConnection
The number of empty selects we'll allow before blowing up.
executor() - Method in class net.spy.memcached.internal.AbstractListenableFuture
Returns the current executor.
executorService - Variable in class net.spy.memcached.ConnectionFactoryBuilder
 
executorService - Variable in class net.spy.memcached.DefaultConnectionFactory
The ExecutorService in which the listener callbacks will be executed.
executorService - Variable in class net.spy.memcached.MemcachedClient
 
executorService - Variable in class net.spy.memcached.util.CacheLoader
 
EXISTS - net.spy.memcached.CASResponse
Status indicating the value was found in the cache, but exists with a different CAS value than expected.
EXISTS - Static variable in class net.spy.memcached.protocol.ascii.CASOperationImpl
 
exp - Variable in class net.spy.memcached.BaseCacheMap
 
exp - Variable in class net.spy.memcached.protocol.ascii.BaseGetOpImpl
 
exp - Variable in class net.spy.memcached.protocol.ascii.BaseStoreOperationImpl
 
exp - Variable in class net.spy.memcached.protocol.ascii.CASOperationImpl
 
exp - Variable in class net.spy.memcached.protocol.ascii.GetlOperationImpl
 
exp - Variable in class net.spy.memcached.protocol.ascii.TouchOperationImpl
 
exp - Variable in class net.spy.memcached.protocol.binary.GetAndTouchOperationImpl
 
exp - Variable in class net.spy.memcached.protocol.binary.GetlOperationImpl
 
exp - Variable in class net.spy.memcached.protocol.binary.MutatorOperationImpl
 
exp - Variable in class net.spy.memcached.protocol.binary.StoreOperationImpl
 
exp - Variable in class net.spy.memcached.protocol.binary.TouchOperationImpl
 
expBytes - Variable in class net.spy.memcached.protocol.ascii.BaseGetOpImpl
 
expiration - Variable in class net.spy.memcached.util.CacheLoader
 
EXTRA_HDR_LEN - Static variable in class net.spy.memcached.protocol.binary.GetAndTouchOperationImpl
Length of the extra header stuff for a GET response.
EXTRA_HDR_LEN - Static variable in class net.spy.memcached.protocol.binary.GetlOperationImpl
Length of the extra header stuff for a GET response.
EXTRA_HDR_LEN - Static variable in class net.spy.memcached.protocol.binary.GetOperationImpl
Length of the extra header stuff for a GET response.
EXTRA_HDR_LEN - Static variable in class net.spy.memcached.protocol.binary.GetsOperationImpl
Length of the extra header stuff for a GET response.
EXTRA_HDR_LEN - Static variable in class net.spy.memcached.protocol.binary.ReplicaGetOperationImpl
Length of the extra header stuff for a GET response.
EXTRA_HDR_LEN - Static variable in class net.spy.memcached.protocol.binary.ReplicaGetsOperationImpl
Length of the extra header stuff for a GET response.
EXTRA_LEN - Static variable in class net.spy.memcached.protocol.binary.StoreOperationImpl
 
extralength - Variable in class net.spy.memcached.tapmessage.BaseMessage
 
EXTRALENGTH_OFFSET - Static variable in class net.spy.memcached.tapmessage.BaseMessage
 

F

failureMode - Variable in class net.spy.memcached.ConnectionFactoryBuilder
 
failureMode - Variable in class net.spy.memcached.MemcachedConnection
The configured FailureMode.
FailureMode - Enum in net.spy.memcached
Failure modes for node failures.
FailureMode() - Constructor for enum net.spy.memcached.FailureMode
 
fatal(Object) - Method in class net.spy.memcached.compat.log.AbstractLogger
Log a message at fatal level.
fatal(Object) - Method in interface net.spy.memcached.compat.log.Logger
Log a message at fatal level.
fatal(Object, Throwable) - Method in class net.spy.memcached.compat.log.AbstractLogger
Log a message at fatal level.
fatal(Object, Throwable) - Method in interface net.spy.memcached.compat.log.Logger
Log a message at fatal level.
fatal(String, Object...) - Method in class net.spy.memcached.compat.log.AbstractLogger
Log a formatted message at debug level.
fatal(String, Object...) - Method in interface net.spy.memcached.compat.log.Logger
Log a formatted message at debug level.
FATAL - net.spy.memcached.compat.log.Level
Fatal level.
fieldToValue(byte[], int, int) - Static method in class net.spy.memcached.tapmessage.Util
Converts a field in a byte array into a value.
fillWriteBuffer(boolean) - Method in interface net.spy.memcached.MemcachedNode
Fill the write buffer with data from the next operations in the queue.
fillWriteBuffer(boolean) - Method in class net.spy.memcached.MemcachedNodeROImpl
 
fillWriteBuffer(boolean) - Method in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
findNode(SocketAddress) - Method in class net.spy.memcached.MemcachedClient
 
findNode(SocketAddress) - Method in class net.spy.memcached.TapConnectionProvider
 
finishConnect(SelectionKey, MemcachedNode) - Method in class net.spy.memcached.MemcachedConnection
Finish the connect phase and potentially verify its liveness.
finishedPayload(byte[]) - Method in class net.spy.memcached.protocol.binary.KeyStatsOperationImpl
 
finishedPayload(byte[]) - Method in class net.spy.memcached.protocol.binary.MultiGetOperationImpl
 
finishedPayload(byte[]) - Method in class net.spy.memcached.protocol.binary.OperationImpl
 
finishedPayload(byte[]) - Method in class net.spy.memcached.protocol.binary.OptimizedSetImpl
 
finishedPayload(byte[]) - Method in class net.spy.memcached.protocol.binary.SASLBaseOperationImpl
 
finishedPayload(byte[]) - Method in class net.spy.memcached.protocol.binary.StatsOperationImpl
 
first(Collection<String>) - Method in class net.spy.memcached.ops.BaseOperationFactory
 
FIX_BYTEORDER - net.spy.memcached.tapmessage.TapRequestFlag
Tap request fixed byteorder.
fixupOps() - Method in interface net.spy.memcached.MemcachedNode
Fix up the selection ops on the selection key.
fixupOps() - Method in class net.spy.memcached.MemcachedNodeROImpl
 
fixupOps() - Method in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
flag - Variable in enum net.spy.memcached.tapmessage.TapRequestFlag
The flag value.
flag - Variable in enum net.spy.memcached.tapmessage.TapResponseFlag
The flag value.
flagList - Variable in class net.spy.memcached.tapmessage.RequestMessage
 
flags - Variable in class net.spy.memcached.CachedData
 
flags - Variable in class net.spy.memcached.protocol.ascii.BaseStoreOperationImpl
 
flags - Variable in class net.spy.memcached.protocol.ascii.CASOperationImpl
 
flags - Variable in class net.spy.memcached.protocol.binary.StoreOperationImpl
 
flags - Variable in class net.spy.memcached.tapmessage.ResponseMessage
 
FLAGS - Static variable in class net.spy.memcached.transcoders.IntegerTranscoder
 
FLAGS - Static variable in class net.spy.memcached.transcoders.LongTranscoder
 
FLAGS_OFFSET - Static variable in class net.spy.memcached.tapmessage.ResponseMessage
 
flush() - Method in class net.spy.memcached.MemcachedClient
Flush all caches from all servers immediately.
flush() - Method in interface net.spy.memcached.MemcachedClientIF
 
flush(int) - Method in class net.spy.memcached.MemcachedClient
Flush all caches from all servers with a delay of application.
flush(int) - Method in interface net.spy.memcached.MemcachedClientIF
 
flush(int, OperationCallback) - Method in interface net.spy.memcached.OperationFactory
Create a flush operation.
flush(int, OperationCallback) - Method in class net.spy.memcached.protocol.ascii.AsciiOperationFactory
 
flush(int, OperationCallback) - Method in class net.spy.memcached.protocol.binary.BinaryOperationFactory
 
FLUSH - net.spy.memcached.tapmessage.TapOpcode
Defines a tap flush message.
FLUSH - Static variable in class net.spy.memcached.protocol.ascii.FlushOperationImpl
 
FlushOperation - Interface in net.spy.memcached.ops
Flush operation marker.
FlushOperationImpl - Class in net.spy.memcached.protocol.ascii
Memcached flush_all operation.
FlushOperationImpl - Class in net.spy.memcached.protocol.binary
 
FlushOperationImpl(int, OperationCallback) - Constructor for class net.spy.memcached.protocol.ascii.FlushOperationImpl
 
FlushOperationImpl(int, OperationCallback) - Constructor for class net.spy.memcached.protocol.binary.FlushOperationImpl
 
FlushOperationImpl(OperationCallback) - Constructor for class net.spy.memcached.protocol.binary.FlushOperationImpl
 
FNV_32_INIT - Static variable in enum net.spy.memcached.DefaultHashAlgorithm
 
FNV_32_PRIME - Static variable in enum net.spy.memcached.DefaultHashAlgorithm
 
FNV_64_INIT - Static variable in enum net.spy.memcached.DefaultHashAlgorithm
 
FNV_64_PRIME - Static variable in enum net.spy.memcached.DefaultHashAlgorithm
 
FNV1_32_HASH - net.spy.memcached.DefaultHashAlgorithm
32-bit FNV1.
FNV1_64_HASH - net.spy.memcached.DefaultHashAlgorithm
FNV hashes are designed to be fast while maintaining a low collision rate.
FNV1A_32_HASH - net.spy.memcached.DefaultHashAlgorithm
32-bit FNV1a.
FNV1A_64_HASH - net.spy.memcached.DefaultHashAlgorithm
Variation of FNV.
format - Variable in class net.spy.memcached.KetamaNodeKeyFormatter
 
Format() - Constructor for enum net.spy.memcached.KetamaNodeKeyFormatter.Format
 
FOUND_NOT_PERSISTED - net.spy.memcached.ObserveResponse
Response indicating the key was found but not persisted.
FOUND_PERSISTED - net.spy.memcached.ObserveResponse
Response indicating the key was persisted.
foundCr - Variable in class net.spy.memcached.protocol.ascii.OperationImpl
 
FOUR - net.spy.memcached.PersistTo
Persist to at least four nodes including Master.
fromAsciiLine(String) - Static method in enum net.spy.memcached.ops.StatusCode
 
fromBinaryCode(int) - Static method in enum net.spy.memcached.ops.StatusCode
 

G

GAT_CMD - Static variable in class net.spy.memcached.protocol.binary.GetAndTouchOperationImpl
 
GENERAL - net.spy.memcached.ops.OperationErrorType
General error.
generateOpaque() - Static method in class net.spy.memcached.protocol.binary.OperationImpl
Generate an opaque ID.
GenericCompletionListener<F extends java.util.concurrent.Future<?>> - Interface in net.spy.memcached.internal
A generic listener that will be notified once the future completes.
get() - Method in class net.spy.memcached.internal.BulkGetFuture
 
get() - Method in class net.spy.memcached.internal.GetFuture
 
get() - Method in class net.spy.memcached.internal.ImmediateFuture
 
get() - Method in class net.spy.memcached.internal.OperationFuture
Get the results of the given operation.
get() - Method in class net.spy.memcached.transcoders.TranscodeService.Task
 
get(long, TimeUnit) - Method in class net.spy.memcached.internal.BulkGetFuture
 
get(long, TimeUnit) - Method in class net.spy.memcached.internal.GetFuture
 
get(long, TimeUnit) - Method in class net.spy.memcached.internal.ImmediateFuture
 
get(long, TimeUnit) - Method in class net.spy.memcached.internal.OperationFuture
Get the results of the given operation.
get(long, TimeUnit) - Method in class net.spy.memcached.transcoders.TranscodeService.Task
 
get(Object) - Method in class net.spy.memcached.BaseCacheMap
 
get(String) - Method in class net.spy.memcached.MemcachedClient
Get with a single key and decode using the default transcoder.
get(String) - Method in interface net.spy.memcached.MemcachedClientIF
 
get(String, GetOperation.Callback) - Method in interface net.spy.memcached.OperationFactory
Create a get operation.
get(String, GetOperation.Callback) - Method in class net.spy.memcached.protocol.ascii.AsciiOperationFactory
 
get(String, GetOperation.Callback) - Method in class net.spy.memcached.protocol.binary.BinaryOperationFactory
 
get(String, Transcoder<T>) - Method in class net.spy.memcached.MemcachedClient
Get with a single key.
get(String, Transcoder<T>) - Method in interface net.spy.memcached.MemcachedClientIF
 
get(Collection<String>, GetOperation.Callback) - Method in interface net.spy.memcached.OperationFactory
Create a get operation.
get(Collection<String>, GetOperation.Callback) - Method in class net.spy.memcached.protocol.ascii.AsciiOperationFactory
 
get(Collection<String>, GetOperation.Callback) - Method in class net.spy.memcached.protocol.binary.BinaryOperationFactory
 
GET_CMD - Static variable in class net.spy.memcached.protocol.binary.GetOperationImpl
 
GET_CMD - Static variable in class net.spy.memcached.protocol.binary.GetsOperationImpl
 
getAddresses(String) - Static method in class net.spy.memcached.AddrUtil
Split a string containing whitespace or comma separated host or IP addresses and port numbers of the form "host:port host2:port" or "host:port, host2:port" into a List of InetSocketAddress instances suitable for instantiating a MemcachedClient.
getAddresses(List<String>) - Static method in class net.spy.memcached.AddrUtil
 
getAddressesFromURL(List<URL>) - Static method in class net.spy.memcached.AddrUtil
 
getAll() - Method in class net.spy.memcached.ArrayModNodeLocator
 
getAll() - Method in class net.spy.memcached.KetamaNodeLocator
 
getAll() - Method in interface net.spy.memcached.NodeLocator
Get all memcached nodes.
getAndTouch(String, int) - Method in class net.spy.memcached.MemcachedClient
Get a single key and reset its expiration using the default transcoder.
getAndTouch(String, int) - Method in interface net.spy.memcached.MemcachedClientIF
 
getAndTouch(String, int, GetAndTouchOperation.Callback) - Method in interface net.spy.memcached.OperationFactory
Gets the value of a key and resets its timeout.
getAndTouch(String, int, GetAndTouchOperation.Callback) - Method in class net.spy.memcached.protocol.ascii.AsciiOperationFactory
 
getAndTouch(String, int, GetAndTouchOperation.Callback) - Method in class net.spy.memcached.protocol.binary.BinaryOperationFactory
 
getAndTouch(String, int, Transcoder<T>) - Method in class net.spy.memcached.MemcachedClient
Get with a single key and reset its expiration.
getAndTouch(String, int, Transcoder<T>) - Method in interface net.spy.memcached.MemcachedClientIF
 
GetAndTouchOperation - Interface in net.spy.memcached.ops
Gat operation.
GetAndTouchOperation.Callback - Interface in net.spy.memcached.ops
Operation callback for the gat request.
GetAndTouchOperationImpl - Class in net.spy.memcached.protocol.ascii
Implementation of the get and touch operation.
GetAndTouchOperationImpl - Class in net.spy.memcached.protocol.binary
Implementation of the get and touch operation.
GetAndTouchOperationImpl(String, int, GetAndTouchOperation.Callback) - Constructor for class net.spy.memcached.protocol.binary.GetAndTouchOperationImpl
 
GetAndTouchOperationImpl(String, int, GetAndTouchOperation.Callback, String) - Constructor for class net.spy.memcached.protocol.ascii.GetAndTouchOperationImpl
 
getAuthDescriptor() - Method in interface net.spy.memcached.ConnectionFactory
Authenticate connections using the given auth descriptor.
getAuthDescriptor() - Method in class net.spy.memcached.DefaultConnectionFactory
 
getAuthWaitTime() - Method in interface net.spy.memcached.ConnectionFactory
The time to wait until authentication completes when an operation is inserted.
getAuthWaitTime() - Method in class net.spy.memcached.DefaultConnectionFactory
 
getAvailableServers() - Method in class net.spy.memcached.MemcachedClient
Get the addresses of available servers.
getAvailableServers() - Method in interface net.spy.memcached.MemcachedClientIF
 
getBuffer() - Method in interface net.spy.memcached.ops.Operation
Get the write buffer for this operation.
getBuffer() - Method in class net.spy.memcached.protocol.BaseOperationImpl
 
getBulk(String...) - Method in class net.spy.memcached.MemcachedClient
Get the values for multiple keys from the cache.
getBulk(String...) - Method in interface net.spy.memcached.MemcachedClientIF
 
getBulk(Collection<String>) - Method in class net.spy.memcached.MemcachedClient
Get the values for multiple keys from the cache.
getBulk(Collection<String>) - Method in interface net.spy.memcached.MemcachedClientIF
 
getBulk(Collection<String>, Transcoder<T>) - Method in class net.spy.memcached.MemcachedClient
Get the values for multiple keys from the cache.
getBulk(Collection<String>, Transcoder<T>) - Method in interface net.spy.memcached.MemcachedClientIF
 
getBulk(Iterator<String>) - Method in class net.spy.memcached.MemcachedClient
Get the values for multiple keys from the cache.
getBulk(Iterator<String>) - Method in interface net.spy.memcached.MemcachedClientIF
 
getBulk(Iterator<String>, Transcoder<T>) - Method in class net.spy.memcached.MemcachedClient
Get the values for multiple keys from the cache.
getBulk(Iterator<String>, Transcoder<T>) - Method in interface net.spy.memcached.MemcachedClientIF
 
getBulk(Transcoder<T>, String...) - Method in class net.spy.memcached.MemcachedClient
Get the values for multiple keys from the cache.
getBulk(Transcoder<T>, String...) - Method in interface net.spy.memcached.MemcachedClientIF
 
getBy() - Method in interface net.spy.memcached.ops.MutatorOperation
Get the amount we're mutating by.
getBy() - Method in class net.spy.memcached.protocol.ascii.MutatorOperationImpl
 
getBy() - Method in class net.spy.memcached.protocol.binary.MutatorOperationImpl
 
getBytes() - Method in class net.spy.memcached.tapmessage.BaseMessage
Creates a ByteBuffer representation of the message.
getBytes() - Method in class net.spy.memcached.tapmessage.RequestMessage
Encodes the message into binary.
getBytes() - Method in class net.spy.memcached.tapmessage.ResponseMessage
 
getBytesRemainingToWrite() - Method in interface net.spy.memcached.MemcachedNode
Get the number of bytes remaining to write.
getBytesRemainingToWrite() - Method in class net.spy.memcached.MemcachedNodeROImpl
 
getBytesRemainingToWrite() - Method in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
getCallback() - Method in class net.spy.memcached.auth.AuthDescriptor
 
getCallback() - Method in interface net.spy.memcached.ops.Operation
Get the callback for this get operation.
getCallback() - Method in class net.spy.memcached.protocol.BaseOperationImpl
Get the operation callback associated with this operation.
getCallback() - Method in class net.spy.memcached.tapmessage.TapAck
 
GetCallbackWrapper - Class in net.spy.memcached.protocol
Wrapper callback for use in optimized gets.
GetCallbackWrapper(int, GetOperation.Callback) - Constructor for class net.spy.memcached.protocol.GetCallbackWrapper
 
getCas() - Method in class net.spy.memcached.CASValue
Get the CAS identifier.
getCas() - Method in class net.spy.memcached.internal.OperationFuture
Get the CAS for this operation.
getCas() - Method in class net.spy.memcached.tapmessage.BaseMessage
Gets the value of the tap messages cas field.
getCASResponse() - Method in class net.spy.memcached.ops.CASOperationStatus
Get the CAS response indicated here.
getCasValue() - Method in interface net.spy.memcached.ops.CASOperation
Get the CAS value advised for this operation.
getCasValue() - Method in interface net.spy.memcached.ops.ConcatenationOperation
Get the CAS value sent with this operation.
getCasValue() - Method in interface net.spy.memcached.ops.ObserveOperation
Get the CAS value advised for this operation.
getCasValue() - Method in class net.spy.memcached.protocol.ascii.CASOperationImpl
 
getCasValue() - Method in class net.spy.memcached.protocol.ascii.ConcatenationOperationImpl
 
getCasValue() - Method in class net.spy.memcached.protocol.binary.ConcatenationOperationImpl
 
getCasValue() - Method in class net.spy.memcached.protocol.binary.ObserveOperationImpl
 
getCasValue() - Method in class net.spy.memcached.protocol.binary.StoreOperationImpl
 
getChannel() - Method in interface net.spy.memcached.MemcachedNode
Get the SocketChannel for this connection.
getChannel() - Method in class net.spy.memcached.MemcachedNodeROImpl
 
getChannel() - Method in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
getCheckpoint() - Method in class net.spy.memcached.tapmessage.ResponseMessage
Gets the checkpoint of the vbucket.
getCloneCount() - Method in interface net.spy.memcached.ops.Operation
Returns the number of times this operation has been cloned.
getCloneCount() - Method in class net.spy.memcached.protocol.BaseOperationImpl
 
getCompletedThreads(int, Callable<T>) - Static method in class net.spy.memcached.compat.SyncThread
Get a collection of SyncThreads that all began as close to the same time as possible and have all completed.
GetCompletionListener - Interface in net.spy.memcached.internal
A listener that will be notified once the get future completes.
getConn() - Method in class net.spy.memcached.tapmessage.TapAck
 
getConnection() - Method in class net.spy.memcached.MemcachedClient
 
getConnection() - Method in interface net.spy.memcached.MemcachedNode
 
getConnection() - Method in class net.spy.memcached.MemcachedNodeROImpl
 
getConnection() - Method in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
getConstructor() - Method in class net.spy.memcached.compat.log.LoggerFactory
 
getContinuousTimeout() - Method in interface net.spy.memcached.MemcachedNode
 
getContinuousTimeout() - Method in class net.spy.memcached.MemcachedNodeROImpl
 
getContinuousTimeout() - Method in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
getCurrentReadOp() - Method in interface net.spy.memcached.MemcachedNode
Get the operation at the top of the queue that is requiring input.
getCurrentReadOp() - Method in class net.spy.memcached.MemcachedNodeROImpl
 
getCurrentReadOp() - Method in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
getCurrentWriteOp() - Method in interface net.spy.memcached.MemcachedNode
Get the operation at the top of the queue that has information available to write.
getCurrentWriteOp() - Method in class net.spy.memcached.MemcachedNodeROImpl
 
getCurrentWriteOp() - Method in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
getData() - Method in class net.spy.memcached.CachedData
Get the stored data.
getData() - Method in interface net.spy.memcached.ops.CASOperation
Get the bytes to be set during this operation.
getData() - Method in interface net.spy.memcached.ops.ConcatenationOperation
Get the bytes to be set during this operation.
getData() - Method in interface net.spy.memcached.ops.StoreOperation
Get the bytes to be set during this operation.
getData() - Method in class net.spy.memcached.protocol.ascii.BaseStoreOperationImpl
 
getData() - Method in class net.spy.memcached.protocol.ascii.CASOperationImpl
 
getData() - Method in class net.spy.memcached.protocol.binary.ConcatenationOperationImpl
 
getData() - Method in class net.spy.memcached.protocol.binary.StoreOperationImpl
 
getDatatype() - Method in class net.spy.memcached.tapmessage.BaseMessage
Gets the value of the tap messages data type field.
getDefault() - Method in interface net.spy.memcached.ops.MutatorOperation
Get the default value (for when there's no value to mutate).
getDefault() - Method in class net.spy.memcached.protocol.ascii.MutatorOperationImpl
 
getDefault() - Method in class net.spy.memcached.protocol.binary.MutatorOperationImpl
 
getDefaultTranscoder() - Method in interface net.spy.memcached.ConnectionFactory
Get the default transcoder to be used in connections created by this factory.
getDefaultTranscoder() - Method in class net.spy.memcached.DefaultConnectionFactory
 
getDistinctResultCount(int, Callable<T>) - Static method in class net.spy.memcached.compat.SyncThread
Get the distinct result count for the given callable at the given concurrency.
getEnginePrivate() - Method in class net.spy.memcached.tapmessage.ResponseMessage
Gets the value of the engine private field.
getErrorMsg() - Method in interface net.spy.memcached.ops.Operation
Returns the raw bytes of the error message content.
getErrorMsg() - Method in class net.spy.memcached.protocol.ascii.OperationImpl
 
getErrorMsg() - Method in class net.spy.memcached.protocol.binary.OperationImpl
 
getException() - Method in interface net.spy.memcached.ops.Operation
Get the exception that occurred (or null if no exception occurred).
getException() - Method in class net.spy.memcached.protocol.BaseOperationImpl
 
getExecutorService() - Method in class net.spy.memcached.MemcachedClient
 
getExpiration() - Method in interface net.spy.memcached.ops.CASOperation
Get the expiration to be set for this operation.
getExpiration() - Method in interface net.spy.memcached.ops.GetAndTouchOperation
Get the expiration to set in case of a new entry.
getExpiration() - Method in interface net.spy.memcached.ops.GetlOperation
 
getExpiration() - Method in interface net.spy.memcached.ops.MutatorOperation
Get the expiration to set in case of a new entry.
getExpiration() - Method in interface net.spy.memcached.ops.StoreOperation
Get the expiration value to be set.
getExpiration() - Method in interface net.spy.memcached.ops.TouchOperation
Get the expiration to set in case of a new entry.
getExpiration() - Method in class net.spy.memcached.protocol.ascii.BaseStoreOperationImpl
 
getExpiration() - Method in class net.spy.memcached.protocol.ascii.CASOperationImpl
 
getExpiration() - Method in class net.spy.memcached.protocol.ascii.GetAndTouchOperationImpl
 
getExpiration() - Method in class net.spy.memcached.protocol.ascii.GetlOperationImpl
 
getExpiration() - Method in class net.spy.memcached.protocol.ascii.MutatorOperationImpl
 
getExpiration() - Method in class net.spy.memcached.protocol.ascii.TouchOperationImpl
 
getExpiration() - Method in class net.spy.memcached.protocol.binary.GetAndTouchOperationImpl
 
getExpiration() - Method in class net.spy.memcached.protocol.binary.GetlOperationImpl
 
getExpiration() - Method in class net.spy.memcached.protocol.binary.MutatorOperationImpl
 
getExpiration() - Method in class net.spy.memcached.protocol.binary.StoreOperationImpl
 
getExpiration() - Method in class net.spy.memcached.protocol.binary.TouchOperationImpl
 
getExtralength() - Method in class net.spy.memcached.tapmessage.BaseMessage
Gets the value of the tap messages extra length field.
getFailureMode() - Method in interface net.spy.memcached.ConnectionFactory
Get the default failure mode for the underlying connection.
getFailureMode() - Method in class net.spy.memcached.DefaultConnectionFactory
 
getFlags() - Method in class net.spy.memcached.CachedData
Get the flags stored along with this value.
getFlags() - Method in interface net.spy.memcached.ops.CASOperation
Get the flags to be set for this operation.
getFlags() - Method in interface net.spy.memcached.ops.StoreOperation
Get the flags to be set.
getFlags() - Method in class net.spy.memcached.protocol.ascii.BaseStoreOperationImpl
 
getFlags() - Method in class net.spy.memcached.protocol.ascii.CASOperationImpl
 
getFlags() - Method in class net.spy.memcached.protocol.binary.StoreOperationImpl
 
getFlags() - Method in class net.spy.memcached.tapmessage.RequestMessage
Returns the flags for this message.
getFlags() - Method in class net.spy.memcached.tapmessage.ResponseMessage
Gets the value of the flags field.
getFlags() - Method in enum net.spy.memcached.tapmessage.TapRequestFlag
 
getFlags() - Method in enum net.spy.memcached.tapmessage.TapResponseFlag
 
getFlags(int) - Static method in enum net.spy.memcached.tapmessage.TapRequestFlag
 
getFlags(short) - Static method in enum net.spy.memcached.tapmessage.TapResponseFlag
 
getFormat() - Method in class net.spy.memcached.KetamaNodeKeyFormatter
 
GetFuture<T> - Class in net.spy.memcached.internal
Future returned for GET operations.
GetFuture(CountDownLatch, long, String, ExecutorService) - Constructor for class net.spy.memcached.internal.GetFuture
 
getHandlingNode() - Method in interface net.spy.memcached.ops.Operation
Get the node that should've been handling this operation.
getHandlingNode() - Method in class net.spy.memcached.protocol.BaseOperationImpl
 
getHashAlg() - Method in interface net.spy.memcached.ConnectionFactory
Get the hash algorithm to be used.
getHashAlg() - Method in class net.spy.memcached.DefaultConnectionFactory
 
getIndex() - Method in interface net.spy.memcached.ops.ObserveOperation
Get the index advised for this operation.
getIndex() - Method in class net.spy.memcached.protocol.binary.ObserveOperationImpl
 
getInitialObservers() - Method in interface net.spy.memcached.ConnectionFactory
Observers that should be established at the time of connection instantiation.
getInitialObservers() - Method in class net.spy.memcached.DefaultConnectionFactory
 
getItemExpiry() - Method in class net.spy.memcached.tapmessage.ResponseMessage
Gets the value of the item expiry field.
getItemFlags() - Method in class net.spy.memcached.tapmessage.ResponseMessage
Gets the value of the items flag field.
getKetamaNodeKeyFormat() - Method in class net.spy.memcached.KetamaConnectionFactory
 
getKetamaNodes() - Method in class net.spy.memcached.KetamaNodeLocator
 
getKey() - Method in class net.spy.memcached.internal.OperationFuture
Get the key for this operation.
getKey() - Method in class net.spy.memcached.tapmessage.ResponseMessage
Gets the value of the key field.
getKey(String) - Method in class net.spy.memcached.BaseCacheMap
 
getKeyBytes(String) - Static method in class net.spy.memcached.KeyUtil
Get the bytes for a key.
getKeyBytes(Collection<String>) - Static method in class net.spy.memcached.KeyUtil
Get the keys in byte form for all of the string keys.
getKeyForNode(MemcachedNode, int) - Method in class net.spy.memcached.KetamaNodeKeyFormatter
Returns a uniquely identifying key, suitable for hashing by the KetamaNodeLocator algorithm.
getKeyForNode(MemcachedNode, int) - Method in class net.spy.memcached.util.DefaultKetamaNodeLocatorConfiguration
Delegates to the KetamaNodeKeyFormatter
getKeyForNode(MemcachedNode, int) - Method in interface net.spy.memcached.util.KetamaNodeLocatorConfiguration
Returns a uniquely identifying key, suitable for hashing by the KetamaNodeLocator algorithm.
getKeylength() - Method in class net.spy.memcached.tapmessage.BaseMessage
Gets the value of the tap messages key length field.
getKeys() - Method in interface net.spy.memcached.ops.KeyedOperation
Get the keys requested in this GetOperation.
getKeys() - Method in class net.spy.memcached.protocol.ascii.BaseGetOpImpl
Get the keys this GetOperation is looking for.
getKeys() - Method in class net.spy.memcached.protocol.ascii.BaseStoreOperationImpl
 
getKeys() - Method in class net.spy.memcached.protocol.ascii.CASOperationImpl
 
getKeys() - Method in class net.spy.memcached.protocol.ascii.DeleteOperationImpl
 
getKeys() - Method in class net.spy.memcached.protocol.ascii.MutatorOperationImpl
 
getKeys() - Method in class net.spy.memcached.protocol.ascii.TouchOperationImpl
 
getKeys() - Method in class net.spy.memcached.protocol.ascii.UnlockOperationImpl
 
getKeys() - Method in class net.spy.memcached.protocol.binary.MultiKeyOperationImpl
 
getKeys() - Method in class net.spy.memcached.protocol.binary.SingleKeyOperationImpl
 
getl(String, int, GetlOperation.Callback) - Method in interface net.spy.memcached.OperationFactory
Create a getl operation.
getl(String, int, GetlOperation.Callback) - Method in class net.spy.memcached.protocol.ascii.AsciiOperationFactory
 
getl(String, int, GetlOperation.Callback) - Method in class net.spy.memcached.protocol.binary.BinaryOperationFactory
 
GETL_CMD - Static variable in class net.spy.memcached.protocol.binary.GetlOperationImpl
 
getListenerExecutorService() - Method in interface net.spy.memcached.ConnectionFactory
Get the ExecutorService which is used to asynchronously execute listeners on futures.
getListenerExecutorService() - Method in class net.spy.memcached.DefaultConnectionFactory
Returns the stored ExecutorService for listeners.
getLocator() - Method in class net.spy.memcached.MemcachedConnection
Returns the NodeLocator in use for this connection.
getLogger() - Method in class net.spy.memcached.compat.SpyObject
Get a Logger instance for this class.
getLogger() - Method in class net.spy.memcached.compat.SpyThread
Get a Logger instance for this class.
getLogger(Class<?>) - Static method in class net.spy.memcached.compat.log.LoggerFactory
Get a logger by class.
getLogger(String) - Static method in class net.spy.memcached.compat.log.LoggerFactory
Get a logger by name.
GetlOperation - Interface in net.spy.memcached.ops
Getl operation.
GetlOperation.Callback - Interface in net.spy.memcached.ops
Operation callback for the getl request.
GetlOperationImpl - Class in net.spy.memcached.protocol.ascii
Implementation of the getl operation.
GetlOperationImpl - Class in net.spy.memcached.protocol.binary
Implementation of the get and lock operation.
GetlOperationImpl(String, int, GetlOperation.Callback) - Constructor for class net.spy.memcached.protocol.ascii.GetlOperationImpl
 
GetlOperationImpl(String, int, GetlOperation.Callback) - Constructor for class net.spy.memcached.protocol.binary.GetlOperationImpl
 
getMagic() - Method in class net.spy.memcached.tapmessage.BaseMessage
Gets the value of the tap messages magic field.
getMagic() - Method in enum net.spy.memcached.tapmessage.TapMagic
 
getMagicByByte(byte) - Static method in enum net.spy.memcached.tapmessage.TapMagic
 
getMaxKey() - Method in class net.spy.memcached.KetamaNodeLocator
 
getMaxReconnectDelay() - Method in interface net.spy.memcached.ConnectionFactory
Maximum number of milliseconds to wait between reconnect attempts.
getMaxReconnectDelay() - Method in class net.spy.memcached.DefaultConnectionFactory
 
getMaxSize() - Method in class net.spy.memcached.transcoders.BaseSerializingTranscoder
 
getMaxSize() - Method in class net.spy.memcached.transcoders.IntegerTranscoder
 
getMaxSize() - Method in class net.spy.memcached.transcoders.LongTranscoder
 
getMaxSize() - Method in interface net.spy.memcached.transcoders.Transcoder
Get the maximum size of objects handled by this transcoder.
getMechs() - Method in class net.spy.memcached.auth.AuthDescriptor
 
getMessage() - Method in class net.spy.memcached.ops.OperationStatus
Get the message included as part of this status.
getMessage() - Method in class net.spy.memcached.tapmessage.MessageBuilder
 
getMessageLength() - Method in class net.spy.memcached.tapmessage.BaseMessage
Gets the length of the entire message.
getMessagesRead() - Method in class net.spy.memcached.TapClient
The number of messages read by all of the tap streams created with this client.
getMetricCollector() - Method in interface net.spy.memcached.ConnectionFactory
The currently active MetricCollector.
getMetricCollector() - Method in class net.spy.memcached.DefaultConnectionFactory
 
getName() - Method in class net.spy.memcached.BinaryConnectionFactory
 
getName() - Method in class net.spy.memcached.compat.log.AbstractLogger
Get the name of this logger.
getName() - Method in interface net.spy.memcached.compat.log.Logger
Get the name of this logger.
getName() - Method in class net.spy.memcached.DefaultConnectionFactory
 
getNewInstance(String) - Method in class net.spy.memcached.compat.log.LoggerFactory
 
getNewValue(T) - Method in interface net.spy.memcached.CASMutation
Get the new value to replace the current value.
getNextMessage() - Method in class net.spy.memcached.TapClient
Gets the next tap message from the queue of received tap messages.
getNextMessage(long, TimeUnit) - Method in class net.spy.memcached.TapClient
Gets the next tap message from the queue of received tap messages.
getNextWritableOp() - Method in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
getNode() - Method in class net.spy.memcached.tapmessage.TapAck
 
getNodeForKey(long) - Method in class net.spy.memcached.KetamaIterator
 
getNodeForKey(long) - Method in class net.spy.memcached.KetamaNodeLocator
 
getNodeLocator() - Method in class net.spy.memcached.MemcachedClient
Get a read-only wrapper around the node locator wrapping this instance.
getNodeLocator() - Method in interface net.spy.memcached.MemcachedClientIF
 
getNodeMap() - Method in class net.spy.memcached.auth.AuthThreadMonitor
Returns Map of AuthThread for testing authentication mechanisms for different server versions.
getNodeRepetitions() - Method in class net.spy.memcached.util.DefaultKetamaNodeLocatorConfiguration
Returns the number of discrete hashes that should be defined for each node in the continuum.
getNodeRepetitions() - Method in interface net.spy.memcached.util.KetamaNodeLocatorConfiguration
Returns the number of discrete hashes that should be defined for each node in the continuum.
getNotMyVbucketNodes() - Method in interface net.spy.memcached.ops.VBucketAware
 
getNotMyVbucketNodes() - Method in class net.spy.memcached.protocol.binary.MultiKeyOperationImpl
 
getNotMyVbucketNodes() - Method in class net.spy.memcached.protocol.binary.SingleKeyOperationImpl
 
getOpaque() - Method in class net.spy.memcached.tapmessage.BaseMessage
Gets the value of the tap messages opaque field.
getOpaque() - Method in class net.spy.memcached.tapmessage.TapAck
 
getOpcode() - Method in class net.spy.memcached.tapmessage.BaseMessage
Gets the value of the tap messages opaque field.
getOpcode() - Method in class net.spy.memcached.tapmessage.TapAck
 
getOpcode() - Method in enum net.spy.memcached.tapmessage.TapOpcode
 
getOpcodeByByte(byte) - Static method in enum net.spy.memcached.tapmessage.TapOpcode
 
GetOperation - Interface in net.spy.memcached.ops
Get operation.
GetOperation.Callback - Interface in net.spy.memcached.ops
Operation callback for the get request.
getOperationFactory() - Method in class net.spy.memcached.BinaryConnectionFactory
 
getOperationFactory() - Method in interface net.spy.memcached.ConnectionFactory
Get the operation factory for connections built by this connection factory.
getOperationFactory() - Method in class net.spy.memcached.DefaultConnectionFactory
 
GetOperationImpl - Class in net.spy.memcached.protocol.ascii
Operation for retrieving data.
GetOperationImpl - Class in net.spy.memcached.protocol.binary
Implementation of the get operation.
GetOperationImpl(String, GetOperation.Callback) - Constructor for class net.spy.memcached.protocol.ascii.GetOperationImpl
 
GetOperationImpl(String, GetOperation.Callback) - Constructor for class net.spy.memcached.protocol.binary.GetOperationImpl
 
GetOperationImpl(Collection<String>, GetOperation.Callback) - Constructor for class net.spy.memcached.protocol.ascii.GetOperationImpl
 
getOperations() - Method in exception net.spy.memcached.internal.CheckedOperationTimeoutException
Get the operation that timed out.
getOperationTimeout() - Method in interface net.spy.memcached.ConnectionFactory
Get the operation timeout used by this connection.
getOperationTimeout() - Method in class net.spy.memcached.DefaultConnectionFactory
 
getOperationTimeout() - Method in class net.spy.memcached.MemcachedClient
 
getOpFactory() - Method in class net.spy.memcached.TapConnectionProvider
 
getOpQueueLen() - Method in class net.spy.memcached.DefaultConnectionFactory
Get the op queue length set at construct time.
getOpQueueMaxBlockTime() - Method in interface net.spy.memcached.ConnectionFactory
Get the maximum amount of time (in milliseconds) a client is willing to wait to add a new item to a queue.
getOpQueueMaxBlockTime() - Method in class net.spy.memcached.DefaultConnectionFactory
 
getPrimary(String) - Method in class net.spy.memcached.ArrayModNodeLocator
 
getPrimary(String) - Method in class net.spy.memcached.KetamaNodeLocator
 
getPrimary(String) - Method in interface net.spy.memcached.NodeLocator
Get the primary location for the given key.
getRbuf() - Method in interface net.spy.memcached.MemcachedNode
Get the buffer used for reading data from this node.
getRbuf() - Method in class net.spy.memcached.MemcachedNodeROImpl
 
getRbuf() - Method in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
getReadBufSize() - Method in interface net.spy.memcached.ConnectionFactory
 
getReadBufSize() - Method in class net.spy.memcached.DefaultConnectionFactory
 
getReadonlyCopy() - Method in class net.spy.memcached.ArrayModNodeLocator
 
getReadonlyCopy() - Method in class net.spy.memcached.KetamaNodeLocator
 
getReadonlyCopy() - Method in interface net.spy.memcached.NodeLocator
Create a read-only copy of this NodeLocator.
getReadType() - Method in class net.spy.memcached.protocol.ascii.OperationImpl
 
getReconnectCount() - Method in interface net.spy.memcached.MemcachedNode
Get the current reconnect count.
getReconnectCount() - Method in class net.spy.memcached.MemcachedNodeROImpl
 
getReconnectCount() - Method in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
getReplicaIndex() - Method in interface net.spy.memcached.ops.ReplicaGetOperation
 
getReplicaIndex() - Method in interface net.spy.memcached.ops.ReplicaGetsOperation
 
getReplicaIndex() - Method in class net.spy.memcached.protocol.binary.ReplicaGetOperationImpl
 
getReplicaIndex() - Method in class net.spy.memcached.protocol.binary.ReplicaGetsOperationImpl
 
getReserved1() - Method in class net.spy.memcached.tapmessage.ResponseMessage
Gets the value of the reserved1 field.
getReserved2() - Method in class net.spy.memcached.tapmessage.ResponseMessage
Gets the value of the reserved2 field.
getReserved3() - Method in class net.spy.memcached.tapmessage.ResponseMessage
Gets the value of the reserved3 field.
getResponse() - Method in enum net.spy.memcached.ObserveResponse
 
getResult() - Method in class net.spy.memcached.compat.SyncThread
Get the result from the invocation.
getRetryKeys() - Method in class net.spy.memcached.protocol.binary.MultiGetOperationImpl
Returns the keys to redistribute.
getRevID() - Method in class net.spy.memcached.tapmessage.ResponseMessage
Gets the value of the revid field.
gets(String) - Method in class net.spy.memcached.MemcachedClient
Gets (with CAS support) with a single key using the default transcoder.
gets(String) - Method in interface net.spy.memcached.MemcachedClientIF
 
gets(String, GetsOperation.Callback) - Method in interface net.spy.memcached.OperationFactory
Create a gets operation.
gets(String, GetsOperation.Callback) - Method in class net.spy.memcached.protocol.ascii.AsciiOperationFactory
 
gets(String, GetsOperation.Callback) - Method in class net.spy.memcached.protocol.binary.BinaryOperationFactory
 
gets(String, Transcoder<T>) - Method in class net.spy.memcached.MemcachedClient
Gets (with CAS support) with a single key.
gets(String, Transcoder<T>) - Method in interface net.spy.memcached.MemcachedClientIF
 
getSelectionOps() - Method in interface net.spy.memcached.MemcachedNode
Compute the appropriate selection operations for the channel this MemcachedNode holds to the server.
getSelectionOps() - Method in class net.spy.memcached.MemcachedNodeROImpl
 
getSelectionOps() - Method in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
getSequence(String) - Method in class net.spy.memcached.ArrayModNodeLocator
 
getSequence(String) - Method in class net.spy.memcached.KetamaNodeLocator
 
getSequence(String) - Method in interface net.spy.memcached.NodeLocator
Get an iterator over the sequence of nodes that make up the backup locations for a given key.
getServerForKey(String) - Method in class net.spy.memcached.ArrayModNodeLocator
 
getSk() - Method in interface net.spy.memcached.MemcachedNode
Get the selection key from this node.
getSk() - Method in class net.spy.memcached.MemcachedNodeROImpl
 
getSk() - Method in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
getSocketAddress() - Method in interface net.spy.memcached.MemcachedNode
Get the SocketAddress of the server to which this node is connected.
getSocketAddress() - Method in class net.spy.memcached.MemcachedNodeROImpl
 
getSocketAddress() - Method in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
getSome(long, TimeUnit) - Method in interface net.spy.memcached.internal.BulkFuture
Wait for the operation to complete and return results If operation could not complete within specified timeout, partial result is returned.
getSome(long, TimeUnit) - Method in class net.spy.memcached.internal.BulkGetFuture
 
GetsOperation - Interface in net.spy.memcached.ops
Gets operation (get with CAS identifier support).
GetsOperation.Callback - Interface in net.spy.memcached.ops
Operation callback for the Gets request.
GetsOperationImpl - Class in net.spy.memcached.protocol.ascii
Implementation of the gets operation.
GetsOperationImpl - Class in net.spy.memcached.protocol.binary
Implementation of the gets operation.
GetsOperationImpl(String, GetsOperation.Callback) - Constructor for class net.spy.memcached.protocol.ascii.GetsOperationImpl
 
GetsOperationImpl(String, GetsOperation.Callback) - Constructor for class net.spy.memcached.protocol.binary.GetsOperationImpl
 
getState() - Method in interface net.spy.memcached.ops.Operation
Get the current state of this operation.
getState() - Method in class net.spy.memcached.protocol.BaseOperationImpl
 
getStats() - Method in class net.spy.memcached.MemcachedClient
Get all of the stats from all of the connections.
getStats() - Method in interface net.spy.memcached.MemcachedClientIF
 
getStats(String) - Method in class net.spy.memcached.MemcachedClient
Get a set of stats from all connections.
getStats(String) - Method in interface net.spy.memcached.MemcachedClientIF
 
getStatus() - Method in interface net.spy.memcached.internal.BulkFuture
Gets the status of the operation upon completion.
getStatus() - Method in class net.spy.memcached.internal.BulkGetFuture
 
getStatus() - Method in class net.spy.memcached.internal.GetFuture
 
getStatus() - Method in class net.spy.memcached.internal.OperationFuture
Get the current status of this operation.
getStatusCode() - Method in class net.spy.memcached.ops.OperationStatus
Get the status code associated with the operation status.
getStatusForErrorCode(int, byte[]) - Method in class net.spy.memcached.protocol.binary.OperationImpl
Get the OperationStatus object for the given error code.
getStoreType() - Method in interface net.spy.memcached.ops.CASOperation
Get the type of storage used by this CASOperation.
getStoreType() - Method in interface net.spy.memcached.ops.ConcatenationOperation
Get the concatenation type for this operation.
getStoreType() - Method in interface net.spy.memcached.ops.StoreOperation
Get the store type used by this operation.
getStoreType() - Method in class net.spy.memcached.protocol.ascii.CASOperationImpl
 
getStoreType() - Method in class net.spy.memcached.protocol.ascii.ConcatenationOperationImpl
 
getStoreType() - Method in class net.spy.memcached.protocol.ascii.StoreOperationImpl
 
getStoreType() - Method in class net.spy.memcached.protocol.binary.ConcatenationOperationImpl
 
getStoreType() - Method in class net.spy.memcached.protocol.binary.StoreOperationImpl
 
getThrowable(Object[]) - Method in class net.spy.memcached.compat.log.AbstractLogger
Get the throwable from the last element of this array if it is Throwable, else null.
getTimeoutExceptionThreshold() - Method in interface net.spy.memcached.ConnectionFactory
Maximum number of timeout exception for shutdown connection.
getTimeoutExceptionThreshold() - Method in class net.spy.memcached.DefaultConnectionFactory
 
getTotalbody() - Method in class net.spy.memcached.tapmessage.BaseMessage
Gets the value of the tap messages total body field.
getTranscoder() - Method in class net.spy.memcached.MemcachedClient
Get the default transcoder that's in use.
getTranscoder() - Method in interface net.spy.memcached.MemcachedClientIF
 
getTranscoderService() - Method in class net.spy.memcached.MemcachedClient
 
getTTL() - Method in class net.spy.memcached.tapmessage.ResponseMessage
Gets the value of the time to live field.
getType() - Method in interface net.spy.memcached.ops.MutatorOperation
Get the mutator type used for this operation.
getType() - Method in exception net.spy.memcached.ops.OperationException
Get the type of error.
getType() - Method in class net.spy.memcached.protocol.ascii.MutatorOperationImpl
 
getType() - Method in class net.spy.memcached.protocol.binary.MutatorOperationImpl
 
getUnavailableServers() - Method in class net.spy.memcached.MemcachedClient
Get the addresses of unavailable servers.
getUnavailableServers() - Method in interface net.spy.memcached.MemcachedClientIF
 
getValue() - Method in class net.spy.memcached.CASValue
Get the object value.
getValue() - Method in enum net.spy.memcached.PersistTo
 
getValue() - Method in enum net.spy.memcached.ReplicateTo
 
getValue() - Method in class net.spy.memcached.tapmessage.ResponseMessage
Gets the value of the value field.
getVbucket() - Method in class net.spy.memcached.tapmessage.BaseMessage
Gets the value of the tap messages vbucket field.
getVBucket(String) - Method in interface net.spy.memcached.ops.VBucketAware
 
getVBucket(String) - Method in class net.spy.memcached.protocol.binary.MultiKeyOperationImpl
 
getVBucket(String) - Method in class net.spy.memcached.protocol.binary.SingleKeyOperationImpl
 
getVBucketState() - Method in class net.spy.memcached.tapmessage.ResponseMessage
Gets the state of the vbucket.
getVersions() - Method in class net.spy.memcached.MemcachedClient
Get the versions of all of the connected memcacheds.
getVersions() - Method in interface net.spy.memcached.MemcachedClientIF
 
getWbuf() - Method in interface net.spy.memcached.MemcachedNode
Get the buffer used for writing data to this node.
getWbuf() - Method in class net.spy.memcached.MemcachedNodeROImpl
 
getWbuf() - Method in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
getWeights() - Method in class net.spy.memcached.KetamaConnectionFactory
 
getWriteCompleteTimestamp() - Method in interface net.spy.memcached.ops.Operation
Returns the timestamp from the point where the WRITE was completed.
getWriteCompleteTimestamp() - Method in class net.spy.memcached.protocol.BaseOperationImpl
 
gotAck(MemcachedNode, TapOpcode, int) - Method in interface net.spy.memcached.ops.TapOperation.Callback
 
gotData(long) - Method in interface net.spy.memcached.ops.DeleteOperation.Callback
Callback for each result from a Store.
gotData(String, int, byte[]) - Method in interface net.spy.memcached.ops.GetOperation.Callback
Callback for each result from a get.
gotData(String, int, byte[]) - Method in class net.spy.memcached.ops.MultiGetOperationCallback
 
gotData(String, int, byte[]) - Method in class net.spy.memcached.ops.MultiReplicaGetOperationCallback
 
gotData(String, int, byte[]) - Method in interface net.spy.memcached.ops.ReplicaGetOperation.Callback
Callback for each result from a replica get.
gotData(String, int, byte[]) - Method in class net.spy.memcached.protocol.GetCallbackWrapper
 
gotData(String, int, byte[]) - Method in class net.spy.memcached.protocol.ProxyCallback
 
gotData(String, int, long, byte[]) - Method in interface net.spy.memcached.ops.GetAndTouchOperation.Callback
Callback for each result from a gat.
gotData(String, int, long, byte[]) - Method in interface net.spy.memcached.ops.GetlOperation.Callback
Callback for each result from a getl.
gotData(String, int, long, byte[]) - Method in interface net.spy.memcached.ops.GetsOperation.Callback
Callback for each result from a gets.
gotData(String, int, long, byte[]) - Method in class net.spy.memcached.ops.MultiGetsOperationCallback
 
gotData(String, int, long, byte[]) - Method in interface net.spy.memcached.ops.ReplicaGetsOperation.Callback
Callback for each result from a replica get.
gotData(String, long) - Method in interface net.spy.memcached.ops.StoreOperation.Callback
Callback for each result from a Store.
gotData(String, long, MemcachedNode, ObserveResponse) - Method in interface net.spy.memcached.ops.ObserveOperation.Callback
Callback for each result from a observe.
gotData(ResponseMessage) - Method in interface net.spy.memcached.ops.TapOperation.Callback
Callback for each result from a get.
gotStat(String, String) - Method in interface net.spy.memcached.ops.StatsOperation.Callback
Invoked once for every stat returned from the server.

H

handle(Callback[]) - Method in class net.spy.memcached.auth.PlainCallbackHandler
 
handleEmptySelects() - Method in class net.spy.memcached.MemcachedConnection
Helper method for MemcachedConnection.handleIO() to handle empty select calls.
handleError(OperationErrorType, String) - Method in class net.spy.memcached.protocol.BaseOperationImpl
 
handleInputQueue() - Method in class net.spy.memcached.MemcachedConnection
Handle any requests that have been made against the client.
handleIO() - Method in class net.spy.memcached.MemcachedConnection
Handle all IO that flows through the connection.
handleIO(SelectionKey) - Method in class net.spy.memcached.MemcachedConnection
Handle IO for a specific selector.
handleLine(String) - Method in class net.spy.memcached.protocol.ascii.BaseGetOpImpl
 
handleLine(String) - Method in class net.spy.memcached.protocol.ascii.BaseStoreOperationImpl
 
handleLine(String) - Method in class net.spy.memcached.protocol.ascii.CASOperationImpl
 
handleLine(String) - Method in class net.spy.memcached.protocol.ascii.DeleteOperationImpl
 
handleLine(String) - Method in class net.spy.memcached.protocol.ascii.FlushOperationImpl
 
handleLine(String) - Method in class net.spy.memcached.protocol.ascii.MutatorOperationImpl
 
handleLine(String) - Method in class net.spy.memcached.protocol.ascii.OperationImpl
 
handleLine(String) - Method in class net.spy.memcached.protocol.ascii.StatsOperationImpl
 
handleLine(String) - Method in class net.spy.memcached.protocol.ascii.TouchOperationImpl
 
handleLine(String) - Method in class net.spy.memcached.protocol.ascii.UnlockOperationImpl
 
handleLine(String) - Method in class net.spy.memcached.protocol.ascii.VersionOperationImpl
 
handleOperationalTasks() - Method in class net.spy.memcached.MemcachedConnection
Helper method for MemcachedConnection.handleIO() to encapsulate everything that needs to be checked on a regular basis that has nothing to do directly with reading and writing data.
handleRead(ByteBuffer) - Method in interface net.spy.memcached.ops.Operation
Handle a raw data read.
handleRead(ByteBuffer) - Method in class net.spy.memcached.protocol.ascii.BaseGetOpImpl
 
handleRead(ByteBuffer) - Method in class net.spy.memcached.protocol.BaseOperationImpl
 
handleReads(MemcachedNode) - Method in class net.spy.memcached.MemcachedConnection
Handle pending reads for the given node.
handleReadsAndWrites(SelectionKey, MemcachedNode) - Method in class net.spy.memcached.MemcachedConnection
A helper method for MemcachedConnection.handleIO(java.nio.channels.SelectionKey) to handle reads and writes if appropriate.
handleReadsWhenChannelEndOfStream(Operation, MemcachedNode, ByteBuffer) - Method in class net.spy.memcached.MemcachedConnection
Deal with an operation where the channel reached the end of a stream.
handleRetryInformation(byte[]) - Method in class net.spy.memcached.MemcachedConnection
Optionally handle retry (NOT_MY_VBUKET) responses.
handleShutdownQueue() - Method in class net.spy.memcached.MemcachedConnection
Check if nodes need to be shut down and do so if needed.
handleWokenUpSelector() - Method in class net.spy.memcached.MemcachedConnection
Helper method which gets called if the selector is woken up because of the timeout setting, if has been interrupted or if happens during regular write operation phases.
handleWrites(MemcachedNode) - Method in class net.spy.memcached.MemcachedConnection
Handle pending writes for the given node.
handlingNode - Variable in class net.spy.memcached.protocol.BaseOperationImpl
 
hasBackfill - Variable in class net.spy.memcached.tapmessage.RequestMessage
 
hasErrored() - Method in interface net.spy.memcached.ops.Operation
True if an error occurred while processing this operation.
hasErrored() - Method in class net.spy.memcached.protocol.BaseOperationImpl
 
hasErrored() - Method in class net.spy.memcached.tapmessage.TapStream
Determine if messages sent to this server and recorded on this TapStream have been determined to be in error.
hasFlags - Variable in class net.spy.memcached.tapmessage.RequestMessage
 
hash(String) - Method in enum net.spy.memcached.DefaultHashAlgorithm
Compute the hash for the given key.
hash(String) - Method in interface net.spy.memcached.HashAlgorithm
Compute the hash for the given key.
hashAlg - Variable in class net.spy.memcached.ArrayModNodeLocator
 
hashAlg - Variable in class net.spy.memcached.ConnectionFactoryBuilder
 
hashAlg - Variable in class net.spy.memcached.DefaultConnectionFactory
 
hashAlg - Variable in class net.spy.memcached.KetamaIterator
 
hashAlg - Variable in class net.spy.memcached.KetamaNodeLocator
 
HashAlgorithm - Interface in net.spy.memcached
Intents to provide hash for locating a server for a key.
HashAlgorithmRegistry - Class in net.spy.memcached
Registry of known hashing algorithms for locating a server for a key.
HashAlgorithmRegistry() - Constructor for class net.spy.memcached.HashAlgorithmRegistry
 
hashVal - Variable in class net.spy.memcached.KetamaIterator
 
hasMoreMessages() - Method in class net.spy.memcached.TapClient
Decides whether the client has received tap messages or will receive more messages in the future.
hasNext() - Method in class net.spy.memcached.ArrayModNodeLocator.NodeIterator
 
hasNext() - Method in class net.spy.memcached.internal.SingleElementInfiniteIterator
 
hasNext() - Method in class net.spy.memcached.KetamaIterator
 
hasReadOp() - Method in interface net.spy.memcached.MemcachedNode
True if an operation is available to read.
hasReadOp() - Method in class net.spy.memcached.MemcachedNodeROImpl
 
hasReadOp() - Method in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
hasValue - Variable in class net.spy.memcached.protocol.ascii.BaseGetOpImpl
 
hasVBucketCheckpoints - Variable in class net.spy.memcached.tapmessage.RequestMessage
 
hasVBucketList - Variable in class net.spy.memcached.tapmessage.RequestMessage
 
hasWriteOp() - Method in interface net.spy.memcached.MemcachedNode
True if an operation is available to write.
hasWriteOp() - Method in class net.spy.memcached.MemcachedNodeROImpl
 
hasWriteOp() - Method in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
header - Variable in class net.spy.memcached.protocol.binary.OperationImpl
 
header - Variable in class net.spy.memcached.protocol.binary.TapOperationImpl
 
HEADER_LENGTH - Static variable in class net.spy.memcached.tapmessage.BaseMessage
 
headerOffset - Variable in class net.spy.memcached.protocol.binary.OperationImpl
 
histograms - Variable in class net.spy.memcached.metrics.DefaultMetricCollector
Contains all registered Histograms.

I

id - Variable in class net.spy.memcached.protocol.binary.TapBackfillOperationImpl
 
id - Variable in class net.spy.memcached.protocol.binary.TapCustomOperationImpl
 
id - Variable in class net.spy.memcached.protocol.binary.TapDumpOperationImpl
 
ImmediateFuture - Class in net.spy.memcached.internal
A future that fires immediately.
ImmediateFuture(Boolean) - Constructor for class net.spy.memcached.internal.ImmediateFuture
 
ImmediateFuture(Exception) - Constructor for class net.spy.memcached.internal.ImmediateFuture
 
incr - net.spy.memcached.ops.Mutator
Increment a value on the memcached server.
incr(String, int) - Method in class net.spy.memcached.MemcachedClient
Increment the given key by the given amount.
incr(String, int) - Method in interface net.spy.memcached.MemcachedClientIF
 
incr(String, int, long) - Method in class net.spy.memcached.MemcachedClient
Increment the given counter, returning the new value.
incr(String, int, long) - Method in interface net.spy.memcached.MemcachedClientIF
 
incr(String, int, long, int) - Method in class net.spy.memcached.MemcachedClient
Increment the given counter, returning the new value.
incr(String, int, long, int) - Method in interface net.spy.memcached.MemcachedClientIF
 
incr(String, long) - Method in class net.spy.memcached.MemcachedClient
Increment the given key by the given amount.
incr(String, long) - Method in interface net.spy.memcached.MemcachedClientIF
 
incr(String, long, long) - Method in class net.spy.memcached.MemcachedClient
Increment the given counter, returning the new value.
incr(String, long, long) - Method in interface net.spy.memcached.MemcachedClientIF
 
incr(String, long, long, int) - Method in class net.spy.memcached.MemcachedClient
Increment the given counter, returning the new value.
incr(String, long, long, int) - Method in interface net.spy.memcached.MemcachedClientIF
 
incrementCounter(String) - Method in class net.spy.memcached.metrics.AbstractMetricCollector
 
incrementCounter(String) - Method in interface net.spy.memcached.metrics.MetricCollector
Increment a Counter by one.
incrementCounter(String, int) - Method in class net.spy.memcached.metrics.DefaultMetricCollector
 
incrementCounter(String, int) - Method in interface net.spy.memcached.metrics.MetricCollector
Increment a Counter by the given amount.
incrementCounter(String, int) - Method in class net.spy.memcached.metrics.NoopMetricCollector
 
index - Variable in class net.spy.memcached.protocol.binary.ObserveOperationImpl
 
info(Object) - Method in class net.spy.memcached.compat.log.AbstractLogger
Log a message at info level.
info(Object) - Method in interface net.spy.memcached.compat.log.Logger
Log a message at info level.
info(Object, Throwable) - Method in class net.spy.memcached.compat.log.AbstractLogger
Log a message at info level.
info(Object, Throwable) - Method in interface net.spy.memcached.compat.log.Logger
Log a message at info level.
info(String, Object...) - Method in class net.spy.memcached.compat.log.AbstractLogger
Log a formatted message at info level.
info(String, Object...) - Method in interface net.spy.memcached.compat.log.Logger
Log a formatted message at info level.
INFO - net.spy.memcached.compat.log.Level
Info level.
init() - Static method in class net.spy.memcached.compat.log.LoggerFactory
 
initialize() - Method in interface net.spy.memcached.ops.Operation
Initialize this operation.
initialize() - Method in class net.spy.memcached.protocol.ascii.BaseGetOpImpl
 
initialize() - Method in class net.spy.memcached.protocol.ascii.BaseStoreOperationImpl
 
initialize() - Method in class net.spy.memcached.protocol.ascii.CASOperationImpl
 
initialize() - Method in class net.spy.memcached.protocol.ascii.DeleteOperationImpl
 
initialize() - Method in class net.spy.memcached.protocol.ascii.FlushOperationImpl
 
initialize() - Method in class net.spy.memcached.protocol.ascii.MutatorOperationImpl
 
initialize() - Method in class net.spy.memcached.protocol.ascii.StatsOperationImpl
 
initialize() - Method in class net.spy.memcached.protocol.ascii.TouchOperationImpl
 
initialize() - Method in class net.spy.memcached.protocol.ascii.UnlockOperationImpl
 
initialize() - Method in class net.spy.memcached.protocol.ascii.VersionOperationImpl
 
initialize() - Method in class net.spy.memcached.protocol.BaseOperationImpl
 
initialize() - Method in class net.spy.memcached.protocol.binary.ConcatenationOperationImpl
 
initialize() - Method in class net.spy.memcached.protocol.binary.DeleteOperationImpl
 
initialize() - Method in class net.spy.memcached.protocol.binary.FlushOperationImpl
 
initialize() - Method in class net.spy.memcached.protocol.binary.GetAndTouchOperationImpl
 
initialize() - Method in class net.spy.memcached.protocol.binary.GetlOperationImpl
 
initialize() - Method in class net.spy.memcached.protocol.binary.GetOperationImpl
 
initialize() - Method in class net.spy.memcached.protocol.binary.GetsOperationImpl
 
initialize() - Method in class net.spy.memcached.protocol.binary.KeyStatsOperationImpl
 
initialize() - Method in class net.spy.memcached.protocol.binary.MultiGetOperationImpl
 
initialize() - Method in class net.spy.memcached.protocol.binary.MutatorOperationImpl
 
initialize() - Method in class net.spy.memcached.protocol.binary.NoopOperationImpl
 
initialize() - Method in class net.spy.memcached.protocol.binary.ObserveOperationImpl
 
initialize() - Method in class net.spy.memcached.protocol.binary.OptimizedSetImpl
 
initialize() - Method in class net.spy.memcached.protocol.binary.ReplicaGetOperationImpl
 
initialize() - Method in class net.spy.memcached.protocol.binary.ReplicaGetsOperationImpl
 
initialize() - Method in class net.spy.memcached.protocol.binary.SASLBaseOperationImpl
 
initialize() - Method in class net.spy.memcached.protocol.binary.SASLMechsOperationImpl
 
initialize() - Method in class net.spy.memcached.protocol.binary.StatsOperationImpl
 
initialize() - Method in class net.spy.memcached.protocol.binary.StoreOperationImpl
 
initialize() - Method in class net.spy.memcached.protocol.binary.TapAckOperationImpl
 
initialize() - Method in class net.spy.memcached.protocol.binary.TapBackfillOperationImpl
 
initialize() - Method in class net.spy.memcached.protocol.binary.TapCustomOperationImpl
 
initialize() - Method in class net.spy.memcached.protocol.binary.TapDumpOperationImpl
 
initialize() - Method in class net.spy.memcached.protocol.binary.TapOperationImpl
 
initialize() - Method in class net.spy.memcached.protocol.binary.TouchOperationImpl
 
initialize() - Method in class net.spy.memcached.protocol.binary.UnlockOperationImpl
 
initialize() - Method in class net.spy.memcached.protocol.binary.VersionOperationImpl
 
initialObservers - Variable in class net.spy.memcached.ConnectionFactoryBuilder
 
initReporter() - Method in class net.spy.memcached.metrics.DefaultMetricCollector
Initialize the proper metrics Reporter.
inputQueue - Variable in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
insertOp(Operation) - Method in interface net.spy.memcached.MemcachedNode
Insert an operation to the beginning of the queue.
insertOp(Operation) - Method in class net.spy.memcached.MemcachedNodeROImpl
 
insertOp(Operation) - Method in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
insertOperation(MemcachedNode, Operation) - Method in class net.spy.memcached.MemcachedConnection
Insert an operation on the given node to the beginning of the queue.
instance - Static variable in class net.spy.memcached.compat.log.LoggerFactory
 
instanceConstructor - Variable in class net.spy.memcached.compat.log.LoggerFactory
 
instances - Variable in class net.spy.memcached.compat.log.LoggerFactory
 
IntegerTranscoder - Class in net.spy.memcached.transcoders
Transcoder that serializes and unserializes longs.
IntegerTranscoder() - Constructor for class net.spy.memcached.transcoders.IntegerTranscoder
 
internalGet(long, TimeUnit, Collection<Operation>) - Method in class net.spy.memcached.internal.BulkGetFuture
refactored code common to both get(long, TimeUnit) and getSome(long, TimeUnit).
internalGetLogger(String) - Method in class net.spy.memcached.compat.log.LoggerFactory
 
interruptAllPendingAuth() - Method in class net.spy.memcached.auth.AuthThreadMonitor
Interrupt all pending AuthThreads.
INTERRUPTED - net.spy.memcached.ops.StatusCode
 
interruptOldAuth(MemcachedNode) - Method in class net.spy.memcached.auth.AuthThreadMonitor
 
isActive() - Method in interface net.spy.memcached.MemcachedNode
True if this node is active. i.e.
isActive() - Method in class net.spy.memcached.MemcachedNodeROImpl
 
isActive() - Method in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
isAuthenticated() - Method in interface net.spy.memcached.MemcachedNode
True if this node is authenticated.
isAuthenticated() - Method in class net.spy.memcached.MemcachedNodeROImpl
 
isAuthenticated() - Method in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
isCancelled() - Method in class net.spy.memcached.internal.BulkGetFuture
 
isCancelled() - Method in class net.spy.memcached.internal.GetFuture
 
isCancelled() - Method in class net.spy.memcached.internal.ImmediateFuture
 
isCancelled() - Method in class net.spy.memcached.internal.OperationFuture
Whether or not the Operation associated with this OperationFuture has been canceled.
isCancelled() - Method in interface net.spy.memcached.ops.Operation
Has this operation been cancelled?
isCancelled() - Method in class net.spy.memcached.protocol.BaseOperationImpl
 
isCancelled() - Method in class net.spy.memcached.tapmessage.TapStream
Determine if messages sent to this server and recorded on this TapStream have been canceled.
isCompleted() - Method in class net.spy.memcached.tapmessage.TapStream
Check if all operations in the TapStream are completed.
isDaemon - Variable in class net.spy.memcached.ConnectionFactoryBuilder
 
isDaemon() - Method in interface net.spy.memcached.ConnectionFactory
If true, the IO thread should be a daemon thread.
isDaemon() - Method in class net.spy.memcached.DefaultConnectionFactory
 
isDebugEnabled() - Method in class net.spy.memcached.compat.log.AbstractLogger
True if debug is enabled for this logger.
isDebugEnabled() - Method in class net.spy.memcached.compat.log.DefaultLogger
Always returns false, debug is not enabled on the DefaultLogger.
isDebugEnabled() - Method in class net.spy.memcached.compat.log.Log4JLogger
 
isDebugEnabled() - Method in interface net.spy.memcached.compat.log.Logger
Checks whether DEBUG logging is enabled.
isDebugEnabled() - Method in class net.spy.memcached.compat.log.SLF4JLogger
 
isDebugEnabled() - Method in class net.spy.memcached.compat.log.SunLogger
 
isDefaultExecutorService() - Method in interface net.spy.memcached.ConnectionFactory
Returns true if the default provided ExecutorService has not been overriden through the builder.
isDefaultExecutorService() - Method in class net.spy.memcached.DefaultConnectionFactory
 
isDone() - Method in class net.spy.memcached.internal.BulkGetFuture
 
isDone() - Method in class net.spy.memcached.internal.GetFuture
 
isDone() - Method in class net.spy.memcached.internal.ImmediateFuture
 
isDone() - Method in class net.spy.memcached.internal.OperationFuture
Whether or not the Operation is done and result can be retrieved with get().
isEmpty() - Method in class net.spy.memcached.BaseCacheMap
 
isInfoEnabled() - Method in class net.spy.memcached.compat.log.AbstractLogger
True if debug is enabled for this logger.
isInfoEnabled() - Method in class net.spy.memcached.compat.log.DefaultLogger
Always returns true, info is always enabled on the DefaultLogger.
isInfoEnabled() - Method in class net.spy.memcached.compat.log.Log4JLogger
 
isInfoEnabled() - Method in interface net.spy.memcached.compat.log.Logger
Checks whether INFO logging is enabled.
isInfoEnabled() - Method in class net.spy.memcached.compat.log.SLF4JLogger
 
isInfoEnabled() - Method in class net.spy.memcached.compat.log.SunLogger
 
isJsonObject(String) - Static method in class net.spy.memcached.util.StringUtils
Check if a given string is a JSON object.
isRunning - Variable in class net.spy.memcached.transcoders.TranscodeService.Task
 
isShutdown() - Method in class net.spy.memcached.transcoders.TranscodeService
Ask whether this service has been shut down.
isShutDown() - Method in class net.spy.memcached.MemcachedConnection
Returns whether the connection is shut down or not.
isSuccess - Variable in class net.spy.memcached.ops.OperationStatus
 
isSuccess() - Method in class net.spy.memcached.ops.OperationStatus
Does this status indicate success?
isTimedOut() - Method in interface net.spy.memcached.ops.Operation
True if the operation has timed out.
isTimedOut() - Method in class net.spy.memcached.protocol.BaseOperationImpl
 
isTimedOut(long) - Method in interface net.spy.memcached.ops.Operation
True if the operation has timed out.
isTimedOut(long) - Method in class net.spy.memcached.protocol.BaseOperationImpl
 
isTimedOutUnsent() - Method in interface net.spy.memcached.ops.Operation
True if the operation has timed out and has not been sent.
isTimedOutUnsent() - Method in class net.spy.memcached.protocol.BaseOperationImpl
 
isTimeout() - Method in interface net.spy.memcached.internal.BulkFuture
 
isTimeout() - Method in class net.spy.memcached.internal.BulkGetFuture
 
isTraceEnabled() - Method in class net.spy.memcached.compat.log.DefaultLogger
Always returns false, trace is not enabled on the DefaultLogger.
isTraceEnabled() - Method in class net.spy.memcached.compat.log.Log4JLogger
 
isTraceEnabled() - Method in interface net.spy.memcached.compat.log.Logger
Checks whether TRACE logging is enabled.
isTraceEnabled() - Method in class net.spy.memcached.compat.log.SLF4JLogger
 
isTraceEnabled() - Method in class net.spy.memcached.compat.log.SunLogger
 
isWeightedKetama - Variable in class net.spy.memcached.KetamaNodeLocator
 
ITEM_EXPIRY_OFFSET - Static variable in class net.spy.memcached.tapmessage.ResponseMessage
 
ITEM_FLAGS_OFFSET - Static variable in class net.spy.memcached.tapmessage.ResponseMessage
 
itemexpiry - Variable in class net.spy.memcached.tapmessage.ResponseMessage
 
itemflags - Variable in class net.spy.memcached.tapmessage.ResponseMessage
 

J

join(Collection<String>, String) - Static method in class net.spy.memcached.util.StringUtils
Join a collection of strings together into one.

K

KETAMA_HASH - net.spy.memcached.DefaultHashAlgorithm
MD5-based hash algorithm used by ketama.
KetamaConnectionFactory - Class in net.spy.memcached
ConnectionFactory instance that sets up a ketama compatible connection.
KetamaConnectionFactory() - Constructor for class net.spy.memcached.KetamaConnectionFactory
Create a KetamaConnectionFactory with the default parameters.
KetamaConnectionFactory(int, int, long) - Constructor for class net.spy.memcached.KetamaConnectionFactory
Create a KetamaConnectionFactory with the given maximum operation queue length, and the given read buffer size.
KetamaConnectionFactory(int, int, long, HashAlgorithm, KetamaNodeKeyFormatter.Format, Map<InetSocketAddress, Integer>) - Constructor for class net.spy.memcached.KetamaConnectionFactory
Create a KetamaConnectionFactory with the maximum operation queue length, the given read buffer size, the maximum time to block waiting operations, a specific hash algorithm, a set ring key format, and a given set of weights.
KetamaIterator - Class in net.spy.memcached
Implements an Iterator which the KetamaNodeLoctaor may return to a client for iterating through alternate nodes for a given key.
KetamaIterator(String, int, TreeMap<Long, MemcachedNode>, HashAlgorithm) - Constructor for class net.spy.memcached.KetamaIterator
Create a new KetamaIterator to be used by a client for an operation.
ketamaNodeKeyFormat - Variable in class net.spy.memcached.KetamaConnectionFactory
 
ketamaNodeKeyFormatter - Variable in class net.spy.memcached.util.DefaultKetamaNodeLocatorConfiguration
 
KetamaNodeKeyFormatter - Class in net.spy.memcached
Known key formats used in Ketama for assigning nodes around the ring
KetamaNodeKeyFormatter() - Constructor for class net.spy.memcached.KetamaNodeKeyFormatter
 
KetamaNodeKeyFormatter(KetamaNodeKeyFormatter.Format) - Constructor for class net.spy.memcached.KetamaNodeKeyFormatter
 
KetamaNodeKeyFormatter.Format - Enum in net.spy.memcached
 
KetamaNodeLocator - Class in net.spy.memcached
This is an implementation of the Ketama consistent hash strategy from last.fm.
KetamaNodeLocator(List<MemcachedNode>, HashAlgorithm) - Constructor for class net.spy.memcached.KetamaNodeLocator
Create a new KetamaNodeLocator using specified nodes and the specifed hash algorithm.
KetamaNodeLocator(List<MemcachedNode>, HashAlgorithm, Map<InetSocketAddress, Integer>, KetamaNodeLocatorConfiguration) - Constructor for class net.spy.memcached.KetamaNodeLocator
Create a new KetamaNodeLocator with specific nodes, hash, node key format, and weight
KetamaNodeLocator(List<MemcachedNode>, HashAlgorithm, KetamaNodeKeyFormatter.Format, Map<InetSocketAddress, Integer>) - Constructor for class net.spy.memcached.KetamaNodeLocator
Create a new KetamaNodeLocator with specific nodes, hash, node key format, and weight
KetamaNodeLocator(List<MemcachedNode>, HashAlgorithm, KetamaNodeLocatorConfiguration) - Constructor for class net.spy.memcached.KetamaNodeLocator
Create a new KetamaNodeLocator using specified nodes and the specifed hash algorithm and configuration.
KetamaNodeLocator(TreeMap<Long, MemcachedNode>, Collection<MemcachedNode>, HashAlgorithm, Map<InetSocketAddress, Integer>, KetamaNodeLocatorConfiguration) - Constructor for class net.spy.memcached.KetamaNodeLocator
 
KetamaNodeLocatorConfiguration - Interface in net.spy.memcached.util
Defines the set of all configuration dependencies required for the KetamaNodeLocator algorithm to run.
ketamaNodePositionsAtIteration(MemcachedNode, int) - Method in class net.spy.memcached.KetamaNodeLocator
 
ketamaNodes - Variable in class net.spy.memcached.KetamaIterator
 
ketamaNodes - Variable in class net.spy.memcached.KetamaNodeLocator
 
key - Variable in class net.spy.memcached.internal.OperationFuture
 
key - Variable in class net.spy.memcached.KetamaIterator
 
key - Variable in class net.spy.memcached.protocol.ascii.BaseStoreOperationImpl
 
key - Variable in class net.spy.memcached.protocol.ascii.CASOperationImpl
 
key - Variable in class net.spy.memcached.protocol.ascii.DeleteOperationImpl
 
key - Variable in class net.spy.memcached.protocol.ascii.MutatorOperationImpl
 
key - Variable in class net.spy.memcached.protocol.ascii.TouchOperationImpl
 
key - Variable in class net.spy.memcached.protocol.ascii.UnlockOperationImpl
 
key - Variable in class net.spy.memcached.protocol.binary.SingleKeyOperationImpl
 
key - Variable in class net.spy.memcached.protocol.binary.StatsOperationImpl
 
key - Variable in class net.spy.memcached.tapmessage.ResponseMessage
 
KEY_EMPTY_EXCEPTION - Static variable in class net.spy.memcached.util.StringUtils
Exception thrown if the input key is empty.
KEY_OFFSET - Static variable in class net.spy.memcached.tapmessage.ResponseMessage
 
KEY_TOO_LONG_EXCEPTION - Static variable in class net.spy.memcached.util.StringUtils
Exception thrown if the input key is too long.
KeyedOperation - Interface in net.spy.memcached.ops
Operations that contain keys.
keyLen - Variable in class net.spy.memcached.protocol.binary.OperationImpl
 
keylength - Variable in class net.spy.memcached.tapmessage.BaseMessage
 
KEYLENGTH_OFFSET - Static variable in class net.spy.memcached.tapmessage.BaseMessage
 
keyPrefix - Variable in class net.spy.memcached.BaseCacheMap
 
keys - Variable in class net.spy.memcached.protocol.ascii.BaseGetOpImpl
 
keys - Variable in class net.spy.memcached.protocol.binary.MultiGetOperationImpl
 
KEYS_ONLY - net.spy.memcached.tapmessage.TapRequestFlag
Tap send keys only flag definition.
keySet() - Method in class net.spy.memcached.BaseCacheMap
 
keysOnly() - Method in class net.spy.memcached.tapmessage.MessageBuilder
 
keystate - Variable in class net.spy.memcached.protocol.binary.ObserveOperationImpl
 
keyStats(String, StatsOperation.Callback) - Method in interface net.spy.memcached.OperationFactory
Get a new KeyStatsOperation.
keyStats(String, StatsOperation.Callback) - Method in class net.spy.memcached.protocol.ascii.AsciiOperationFactory
 
keyStats(String, StatsOperation.Callback) - Method in class net.spy.memcached.protocol.binary.BinaryOperationFactory
 
KeyStatsOperationImpl - Class in net.spy.memcached.protocol.binary
A StatsOperationImpl.
KeyStatsOperationImpl(String, StatsOperation.Callback) - Constructor for class net.spy.memcached.protocol.binary.KeyStatsOperationImpl
 
KeyUtil - Class in net.spy.memcached
Utilities for processing key values.
KeyUtil() - Constructor for class net.spy.memcached.KeyUtil
 

L

l4jLogger - Variable in class net.spy.memcached.compat.log.Log4JLogger
 
lastReadDelta() - Method in interface net.spy.memcached.MemcachedNode
Milliseconds since last successful read.
lastReadDelta() - Method in class net.spy.memcached.MemcachedNodeROImpl
 
lastReadDelta() - Method in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
Number of milliseconds since the last read of this node completed.
lastReadTimestamp - Variable in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
latch - Variable in class net.spy.memcached.compat.SyncThread
 
latch - Variable in class net.spy.memcached.internal.BulkGetFuture
 
latch - Variable in class net.spy.memcached.internal.OperationFuture
 
Level - Enum in net.spy.memcached.compat.log
Levels for logging.
Level() - Constructor for enum net.spy.memcached.compat.log.Level
 
LIBMEMCACHED - net.spy.memcached.KetamaNodeKeyFormatter.Format
LIBMEMCACHED uses the format traditionally used by libmemcached to map nodes to names.
LINE - net.spy.memcached.protocol.ascii.OperationReadType
Read type indicating an operation currently wants to read lines.
LinkedOperationQueueFactory - Class in net.spy.memcached.ops
OperationQueueFactory that creates LinkedBlockingQueue (unbounded) operation queues.
LinkedOperationQueueFactory() - Constructor for class net.spy.memcached.ops.LinkedOperationQueueFactory
 
LIST_VBUCKETS - net.spy.memcached.tapmessage.TapRequestFlag
Tap list vBuckets flag definition.
ListenableFuture<T,​L extends GenericCompletionListener> - Interface in net.spy.memcached.internal
A Future that accepts one or more listeners that will be executed asynchronously.
listenerExecutorService - Variable in class net.spy.memcached.MemcachedConnection
The ExecutorService to use for callbacks.
listeners - Variable in class net.spy.memcached.internal.AbstractListenableFuture
Holds the list of listeners which will be notified upon completion.
listSaslMechanisms() - Method in class net.spy.memcached.MemcachedClient
 
listSaslMechanisms() - Method in interface net.spy.memcached.MemcachedClientIF
Get the set of SASL mechanisms supported by the servers.
listSupportedSASLMechanisms(AtomicBoolean) - Method in class net.spy.memcached.auth.AuthThread
 
loadData(Iterator<Map.Entry<String, T>>) - Method in class net.spy.memcached.util.CacheLoader
Load data from the given iterator.
loadData(Map<String, T>) - Method in class net.spy.memcached.util.CacheLoader
Load data from the given map.
locator - Variable in class net.spy.memcached.ConnectionFactoryBuilder
 
locator - Variable in class net.spy.memcached.MemcachedConnection
The NodeLocator to use for this connection.
Locator() - Constructor for enum net.spy.memcached.ConnectionFactoryBuilder.Locator
 
LOCK_ERROR - Static variable in class net.spy.memcached.protocol.ascii.BaseGetOpImpl
 
log(Level, Object) - Method in class net.spy.memcached.compat.log.AbstractLogger
Log a message at the given level.
log(Level, Object) - Method in interface net.spy.memcached.compat.log.Logger
Log a message at the specified level.
log(Level, Object, Throwable) - Method in class net.spy.memcached.compat.log.AbstractLogger
Subclasses should implement this method to determine what to do when a client wants to log at a particular level.
log(Level, Object, Throwable) - Method in class net.spy.memcached.compat.log.DefaultLogger
 
log(Level, Object, Throwable) - Method in class net.spy.memcached.compat.log.Log4JLogger
Wrapper around log4j.
log(Level, Object, Throwable) - Method in interface net.spy.memcached.compat.log.Logger
Log a message at the specified level.
log(Level, Object, Throwable) - Method in class net.spy.memcached.compat.log.SLF4JLogger
Wrapper around SLF4J logger facade.
log(Level, Object, Throwable) - Method in class net.spy.memcached.compat.log.SunLogger
Wrapper around sun logger.
Log4JLogger - Class in net.spy.memcached.compat.log
Logging implementation using log4j.
Log4JLogger(String) - Constructor for class net.spy.memcached.compat.log.Log4JLogger
Get an instance of Log4JLogger.
logger - Static variable in class net.spy.memcached.compat.CloseUtil
 
logger - Variable in class net.spy.memcached.compat.log.SLF4JLogger
 
logger - Variable in class net.spy.memcached.compat.SpyObject
 
logger - Variable in class net.spy.memcached.compat.SpyThread
 
Logger - Interface in net.spy.memcached.compat.log
Abstract mechanism for dealing with logs from various objects.
LoggerFactory - Class in net.spy.memcached.compat.log
Factory to get logger instances.
LoggerFactory() - Constructor for class net.spy.memcached.compat.log.LoggerFactory
Get an instance of LoggerFactory.
logRunException(Exception) - Method in class net.spy.memcached.MemcachedConnection
Log a exception to different levels depending on the state.
LongTranscoder - Class in net.spy.memcached.transcoders
Transcoder that serializes and unserializes longs.
LongTranscoder() - Constructor for class net.spy.memcached.transcoders.LongTranscoder
 
lookingFor - Variable in class net.spy.memcached.protocol.ascii.BaseGetOpImpl
 
lookupHashAlgorithm(String) - Static method in class net.spy.memcached.HashAlgorithmRegistry
Tries to find selected hash algorithm using name provided.
lostConnection(MemcachedNode) - Method in class net.spy.memcached.MemcachedConnection
Indicate a lost connection to the given node.

M

magic - Variable in class net.spy.memcached.tapmessage.BaseMessage
 
magic - Variable in enum net.spy.memcached.tapmessage.TapMagic
The magic value.
MAGIC_OFFSET - Static variable in class net.spy.memcached.tapmessage.BaseMessage
 
markMeter(String) - Method in class net.spy.memcached.metrics.DefaultMetricCollector
 
markMeter(String) - Method in interface net.spy.memcached.metrics.MetricCollector
Mark a checkpoint in the Meter.
markMeter(String) - Method in class net.spy.memcached.metrics.NoopMetricCollector
 
MASTER - net.spy.memcached.PersistTo
Persist to the Master.
matchStatus(String, OperationStatus...) - Method in class net.spy.memcached.protocol.ascii.OperationImpl
Match the status line provided against one of the given OperationStatus objects.
max - Variable in class net.spy.memcached.CASMutator
 
MAX_CLONE_COUNT - Static variable in class net.spy.memcached.MemcachedConnection
If an operation gets cloned more than this ceiling, cancel it for safety reasons.
MAX_GET_OPTIMIZATION_COUNT - Static variable in class net.spy.memcached.protocol.binary.BinaryMemcachedNodeImpl
 
MAX_KEY_LENGTH - Static variable in interface net.spy.memcached.MemcachedClientIF
Maximum supported key length.
MAX_KEY_LENGTH - Static variable in class net.spy.memcached.util.StringUtils
Maximum supported key length.
MAX_SET_OPTIMIZATION_BYTES - Static variable in class net.spy.memcached.protocol.binary.BinaryMemcachedNodeImpl
 
MAX_SET_OPTIMIZATION_COUNT - Static variable in class net.spy.memcached.protocol.binary.BinaryMemcachedNodeImpl
 
MAX_SIZE - Static variable in class net.spy.memcached.CachedData
The maximum size that should be considered storing in a server.
MAX_TRIES - Static variable in class net.spy.memcached.CASMutator
 
maxDelay - Variable in class net.spy.memcached.MemcachedConnection
Maximum amount of time to wait between reconnect attempts.
maxReconnectDelay - Variable in class net.spy.memcached.ConnectionFactoryBuilder
 
maxSize - Variable in class net.spy.memcached.transcoders.BaseSerializingTranscoder
 
mconn - Variable in class net.spy.memcached.MemcachedClient
 
md5Digest - Static variable in enum net.spy.memcached.DefaultHashAlgorithm
 
mech - Variable in class net.spy.memcached.protocol.binary.SASLBaseOperationImpl
 
MECH_SEPARATOR - Static variable in class net.spy.memcached.auth.AuthThread
 
mechs - Variable in class net.spy.memcached.auth.AuthDescriptor
 
MemcachedClient - Class in net.spy.memcached
Client to a memcached server.
MemcachedClient(InetSocketAddress...) - Constructor for class net.spy.memcached.MemcachedClient
Get a memcache client operating on the specified memcached locations.
MemcachedClient(List<InetSocketAddress>) - Constructor for class net.spy.memcached.MemcachedClient
Get a memcache client over the specified memcached locations.
MemcachedClient(ConnectionFactory, List<InetSocketAddress>) - Constructor for class net.spy.memcached.MemcachedClient
Get a memcache client over the specified memcached locations.
MemcachedClientIF - Interface in net.spy.memcached
This interface is provided as a helper for testing clients of the MemcachedClient.
MemcachedConnection - Class in net.spy.memcached
Main class for handling connections to a memcached cluster.
MemcachedConnection(int, ConnectionFactory, List<InetSocketAddress>, Collection<ConnectionObserver>, FailureMode, OperationFactory) - Constructor for class net.spy.memcached.MemcachedConnection
Construct a MemcachedConnection.
MemcachedNode - Interface in net.spy.memcached
Interface defining a connection to a memcached server.
MemcachedNodeROImpl - Class in net.spy.memcached
 
MemcachedNodeROImpl(MemcachedNode) - Constructor for class net.spy.memcached.MemcachedNodeROImpl
 
message - Variable in class net.spy.memcached.ops.OperationStatus
 
message - Variable in class net.spy.memcached.protocol.binary.TapCustomOperationImpl
 
message - Variable in class net.spy.memcached.protocol.binary.TapOperationImpl
 
message - Variable in class net.spy.memcached.tapmessage.MessageBuilder
 
MessageBuilder - Class in net.spy.memcached.tapmessage
Builds a tap message.
MessageBuilder() - Constructor for class net.spy.memcached.tapmessage.MessageBuilder
 
messagesRead - Variable in class net.spy.memcached.TapClient
 
meters - Variable in class net.spy.memcached.metrics.DefaultMetricCollector
Contains all registered Meters.
MetricCollector - Interface in net.spy.memcached.metrics
Defines a common API for all MetricCollectors.
metrics - Variable in class net.spy.memcached.DefaultConnectionFactory
 
metrics - Variable in class net.spy.memcached.MemcachedConnection
The MetricCollector to accumulate metrics (or dummy).
metricType - Variable in class net.spy.memcached.ConnectionFactoryBuilder
 
metricType - Variable in class net.spy.memcached.MemcachedConnection
The current type of metrics to collect.
MetricType - Enum in net.spy.memcached.metrics
Defines the type of metric collection to use.
MetricType() - Constructor for enum net.spy.memcached.metrics.MetricType
 
MIN_RECV_PACKET - Static variable in class net.spy.memcached.protocol.binary.OperationImpl
 
MODIFIED - net.spy.memcached.ObserveResponse
Response indicating the key was modified.
mostRecentStatus - Variable in class net.spy.memcached.ops.MultiOperationCallback
 
msg - Variable in class net.spy.memcached.protocol.ascii.StatsOperationImpl
 
MSG - Static variable in class net.spy.memcached.protocol.ascii.StatsOperationImpl
 
MultiGetOperationCallback - Class in net.spy.memcached.ops
MultiOperationCallback for get operations.
MultiGetOperationCallback(OperationCallback, int) - Constructor for class net.spy.memcached.ops.MultiGetOperationCallback
 
MultiGetOperationImpl - Class in net.spy.memcached.protocol.binary
 
MultiGetOperationImpl(Collection<String>, OperationCallback) - Constructor for class net.spy.memcached.protocol.binary.MultiGetOperationImpl
 
MultiGetsOperationCallback - Class in net.spy.memcached.ops
MultiOperationCallback for get operations.
MultiGetsOperationCallback(OperationCallback, int) - Constructor for class net.spy.memcached.ops.MultiGetsOperationCallback
 
MultiKeyOperationImpl - Class in net.spy.memcached.protocol.binary
Binary operations that contain multiple keys and are VBucket aware operations should extend this class.
MultiKeyOperationImpl(byte, int, OperationCallback) - Constructor for class net.spy.memcached.protocol.binary.MultiKeyOperationImpl
 
MultiOperationCallback - Class in net.spy.memcached.ops
An operation callback that will capture receivedStatus and complete invocations and dispatch to a single callback.
MultiOperationCallback(OperationCallback, int) - Constructor for class net.spy.memcached.ops.MultiOperationCallback
Get a MultiOperationCallback over the given callback for the specified number of replicates.
MultiReplicaGetOperationCallback - Class in net.spy.memcached.ops
MultiOperationCallback for replica get operations.
MultiReplicaGetOperationCallback(OperationCallback, int) - Constructor for class net.spy.memcached.ops.MultiReplicaGetOperationCallback
 
mutate(Mutator, String, long, long, int) - Method in class net.spy.memcached.MemcachedClient
 
mutate(Mutator, String, long, long, int, OperationCallback) - Method in interface net.spy.memcached.OperationFactory
Create a mutator operation.
mutate(Mutator, String, long, long, int, OperationCallback) - Method in class net.spy.memcached.protocol.ascii.AsciiOperationFactory
 
mutate(Mutator, String, long, long, int, OperationCallback) - Method in class net.spy.memcached.protocol.binary.BinaryOperationFactory
 
mutateWithDefault(Mutator, String, long, long, int) - Method in class net.spy.memcached.MemcachedClient
 
MUTATION - net.spy.memcached.tapmessage.TapOpcode
Defines a key-value mutation message to specify a key-value has changed.
mutator - Variable in class net.spy.memcached.protocol.ascii.MutatorOperationImpl
 
mutator - Variable in class net.spy.memcached.protocol.binary.MutatorOperationImpl
 
Mutator - Enum in net.spy.memcached.ops
Type of mutation to perform.
Mutator() - Constructor for enum net.spy.memcached.ops.Mutator
 
MutatorOperation - Interface in net.spy.memcached.ops
incr and decr operations.
MutatorOperationImpl - Class in net.spy.memcached.protocol.ascii
Operation for mutating integers inside of memcached.
MutatorOperationImpl - Class in net.spy.memcached.protocol.binary
 
MutatorOperationImpl(Mutator, String, long, long, int, OperationCallback) - Constructor for class net.spy.memcached.protocol.binary.MutatorOperationImpl
 
MutatorOperationImpl(Mutator, String, long, OperationCallback) - Constructor for class net.spy.memcached.protocol.ascii.MutatorOperationImpl
 

N

name - Variable in class net.spy.memcached.compat.log.AbstractLogger
 
name - Variable in class net.spy.memcached.tapmessage.RequestMessage
 
namePrefix - Variable in class net.spy.memcached.internal.BasicThreadFactory
 
NATIVE_HASH - net.spy.memcached.DefaultHashAlgorithm
Native hash (String.hashCode()).
net.spy.memcached - package net.spy.memcached
Memcached client and transformation utils
net.spy.memcached.auth - package net.spy.memcached.auth
Auth Utilities.
net.spy.memcached.compat - package net.spy.memcached.compat
spy.jar compatibility classes
net.spy.memcached.compat.log - package net.spy.memcached.compat.log
Logging Abstractions
net.spy.memcached.internal - package net.spy.memcached.internal
Internal utilities.
net.spy.memcached.metrics - package net.spy.memcached.metrics
 
net.spy.memcached.ops - package net.spy.memcached.ops
Fundamental protocol operation interfaces
net.spy.memcached.protocol - package net.spy.memcached.protocol
Base classes for protocol abstractions.
net.spy.memcached.protocol.ascii - package net.spy.memcached.protocol.ascii
Low-level operations for the memcached ascii protocol
net.spy.memcached.protocol.binary - package net.spy.memcached.protocol.binary
Low-level operations for the memcached binary protocol
net.spy.memcached.tapmessage - package net.spy.memcached.tapmessage
 
net.spy.memcached.transcoders - package net.spy.memcached.transcoders
Classes that deal with data encoding
net.spy.memcached.util - package net.spy.memcached.util
Cache Utilities.
newOp(MemcachedNode, CountDownLatch) - Method in interface net.spy.memcached.BroadcastOpFactory
Construct a new operation for delivery to the given node.
newThread(Runnable) - Method in class net.spy.memcached.internal.BasicThreadFactory
 
next - Variable in class net.spy.memcached.ArrayModNodeLocator.NodeIterator
 
next() - Method in class net.spy.memcached.ArrayModNodeLocator.NodeIterator
 
next() - Method in class net.spy.memcached.internal.SingleElementInfiniteIterator
 
next() - Method in class net.spy.memcached.KetamaIterator
 
nextHash() - Method in class net.spy.memcached.KetamaIterator
 
node - Variable in class net.spy.memcached.auth.AuthThread
 
node - Variable in class net.spy.memcached.tapmessage.TapAck
 
NodeIterator(int) - Constructor for class net.spy.memcached.ArrayModNodeLocator.NodeIterator
 
nodeKeys - Variable in class net.spy.memcached.KetamaNodeKeyFormatter
 
NodeLocator - Interface in net.spy.memcached
Interface for locating a node by hash value.
nodeMap - Variable in class net.spy.memcached.auth.AuthThreadMonitor
 
nodes - Variable in class net.spy.memcached.ArrayModNodeLocator
 
nodesToShutdown - Variable in class net.spy.memcached.MemcachedConnection
Holds all nodes that are scheduled for shutdown.
noop(OperationCallback) - Method in interface net.spy.memcached.OperationFactory
Create a NOOP operation.
noop(OperationCallback) - Method in class net.spy.memcached.protocol.ascii.AsciiOperationFactory
 
noop(OperationCallback) - Method in class net.spy.memcached.protocol.binary.BinaryOperationFactory
 
NOOP - net.spy.memcached.tapmessage.TapOpcode
Defines a tap no-op message.
NOOP_CALLBACK - Static variable in class net.spy.memcached.protocol.binary.OptimizedSetImpl
 
NoopCallback() - Constructor for class net.spy.memcached.protocol.binary.OptimizedSetImpl.NoopCallback
 
NoopMetricCollector - Class in net.spy.memcached.metrics
A MetricCollector that does nothing.
NoopMetricCollector() - Constructor for class net.spy.memcached.metrics.NoopMetricCollector
 
NoopOperation - Interface in net.spy.memcached.ops
The NOOP Operation.
NoopOperationImpl - Class in net.spy.memcached.protocol.binary
Implementation of a noop operation.
NoopOperationImpl(OperationCallback) - Constructor for class net.spy.memcached.protocol.binary.NoopOperationImpl
 
NOT_FOUND - net.spy.memcached.CASResponse
Status indicating the value was not found in the cache (an add operation may be issued to store the value).
NOT_FOUND - Static variable in class net.spy.memcached.protocol.ascii.BaseGetOpImpl
 
NOT_FOUND - Static variable in class net.spy.memcached.protocol.ascii.CASOperationImpl
 
NOT_FOUND - Static variable in class net.spy.memcached.protocol.ascii.DeleteOperationImpl
 
NOT_FOUND - Static variable in class net.spy.memcached.protocol.ascii.MutatorOperationImpl
 
NOT_FOUND - Static variable in class net.spy.memcached.protocol.ascii.UnlockOperationImpl
 
NOT_FOUND_NOT_PERSISTED - net.spy.memcached.ObserveResponse
Response indicating the key was not found and not persisted, as in the case of deletes - a logical delete.
NOT_FOUND_PERSISTED - net.spy.memcached.ObserveResponse
Response indicating the key was not found and persisted, as in the case of deletes - a real delete.
notifyListener(ExecutorService, Future<?>, GenericCompletionListener) - Method in class net.spy.memcached.internal.AbstractListenableFuture
Notify a specific listener of completion.
notifyListeners() - Method in class net.spy.memcached.internal.AbstractListenableFuture
Notify all registered listeners of future completion.
notifyListeners(Future<?>) - Method in class net.spy.memcached.internal.AbstractListenableFuture
Notify all registered listeners with a special future on completion.
notMyVbucketNodes - Variable in class net.spy.memcached.protocol.BaseOperationImpl
 
numCallbacks() - Method in class net.spy.memcached.protocol.ProxyCallback
 
numKeys() - Method in class net.spy.memcached.protocol.ProxyCallback
 
numReps - Variable in class net.spy.memcached.util.DefaultKetamaNodeLocatorConfiguration
 
numTries - Variable in class net.spy.memcached.KetamaIterator
 

O

objRef - Variable in class net.spy.memcached.internal.OperationFuture
 
observe(String, long, int, ObserveOperation.Callback) - Method in interface net.spy.memcached.OperationFactory
Create an Observe operation.
observe(String, long, int, ObserveOperation.Callback) - Method in class net.spy.memcached.protocol.ascii.AsciiOperationFactory
 
observe(String, long, int, ObserveOperation.Callback) - Method in class net.spy.memcached.protocol.binary.BinaryOperationFactory
 
OBSERVE_ERROR_IN_ARGS - net.spy.memcached.CASResponse
Status indicating there was an error in specifying the arguments for the Observe.
OBSERVE_MODIFIED - net.spy.memcached.CASResponse
Status indicating the CAS operation succeeded but the value was subsequently modified during Observe.
OBSERVE_TIMEOUT - net.spy.memcached.CASResponse
Status indicating there was a Timeout in the Observe operation.
ObserveOperation - Interface in net.spy.memcached.ops
Observe operation.
ObserveOperation.Callback - Interface in net.spy.memcached.ops
Operation callback for the Observe request.
ObserveOperationImpl - Class in net.spy.memcached.protocol.binary
 
ObserveOperationImpl(String, long, int, OperationCallback) - Constructor for class net.spy.memcached.protocol.binary.ObserveOperationImpl
 
ObserveResponse - Enum in net.spy.memcached
Response codes for a Observe operation.
ObserveResponse(byte) - Constructor for enum net.spy.memcached.ObserveResponse
 
OFF - net.spy.memcached.metrics.MetricType
No metrics collection.
OK - net.spy.memcached.CASResponse
Status indicating that the CAS was successful and the new value is stored in the cache.
OK - Static variable in class net.spy.memcached.protocol.ascii.FlushOperationImpl
 
OK - Static variable in class net.spy.memcached.protocol.ascii.TouchOperationImpl
 
omap - Variable in class net.spy.memcached.TapClient
 
onComplete(F) - Method in interface net.spy.memcached.internal.GenericCompletionListener
This method will be executed once the future completes.
ONE - net.spy.memcached.PersistTo
ONE implies MASTER.
ONE - net.spy.memcached.ReplicateTo
Replicate to at least one node.
op - Variable in class net.spy.memcached.internal.OperationFuture
 
opaque - Variable in class net.spy.memcached.protocol.binary.OperationImpl
 
opaque - Variable in class net.spy.memcached.protocol.binary.TapAckOperationImpl
 
opaque - Variable in class net.spy.memcached.tapmessage.BaseMessage
 
opaque - Variable in class net.spy.memcached.tapmessage.TapAck
 
OPAQUE - net.spy.memcached.tapmessage.TapOpcode
Defines a opaque message to send control data to the consumer.
OPAQUE_OFFSET - Static variable in class net.spy.memcached.tapmessage.BaseMessage
 
opaqueIsValid() - Method in class net.spy.memcached.protocol.binary.MultiGetOperationImpl
 
opaqueIsValid() - Method in class net.spy.memcached.protocol.binary.OperationImpl
Validate an opaque value from the header.
opaqueIsValid() - Method in class net.spy.memcached.protocol.binary.OptimizedSetImpl
 
opcode - Variable in class net.spy.memcached.protocol.binary.TapAckOperationImpl
 
opcode - Variable in class net.spy.memcached.tapmessage.BaseMessage
 
opcode - Variable in class net.spy.memcached.tapmessage.TapAck
 
opcode - Variable in enum net.spy.memcached.tapmessage.TapOpcode
The opcode value.
OPCODE_OFFSET - Static variable in class net.spy.memcached.tapmessage.BaseMessage
 
Operation - Interface in net.spy.memcached.ops
Base interface for all operations.
OperationCallback - Interface in net.spy.memcached.ops
Callback that's invoked with the response of an operation.
OperationCompletionListener - Interface in net.spy.memcached.internal
A listener that will be notified once the operation future completes.
OperationErrorType - Enum in net.spy.memcached.ops
Error classification.
OperationErrorType() - Constructor for enum net.spy.memcached.ops.OperationErrorType
 
OperationException - Exception in net.spy.memcached.ops
Exceptions thrown when protocol errors occur.
OperationException() - Constructor for exception net.spy.memcached.ops.OperationException
General exception (no message).
OperationException(OperationErrorType, String) - Constructor for exception net.spy.memcached.ops.OperationException
Exception with a message.
OperationFactory - Interface in net.spy.memcached
Factory that builds operations for protocol handlers.
OperationFuture<T> - Class in net.spy.memcached.internal
Managed future for operations.
OperationFuture(String, CountDownLatch, long, ExecutorService) - Constructor for class net.spy.memcached.internal.OperationFuture
Create an OperationFuture for a given async operation.
OperationFuture(String, CountDownLatch, AtomicReference<T>, long, ExecutorService) - Constructor for class net.spy.memcached.internal.OperationFuture
Create an OperationFuture for a given async operation.
OperationImpl - Class in net.spy.memcached.protocol.ascii
Operations on a memcached connection.
OperationImpl - Class in net.spy.memcached.protocol.binary
Base class for binary operations.
OperationImpl() - Constructor for class net.spy.memcached.protocol.ascii.OperationImpl
 
OperationImpl(byte, int, OperationCallback) - Constructor for class net.spy.memcached.protocol.binary.OperationImpl
Construct with opaque.
OperationImpl(OperationCallback) - Constructor for class net.spy.memcached.protocol.ascii.OperationImpl
 
OperationQueueFactory - Interface in net.spy.memcached.ops
Factory used for creating operation queues.
OperationReadType - Enum in net.spy.memcached.protocol.ascii
Data read types.
OperationReadType() - Constructor for enum net.spy.memcached.protocol.ascii.OperationReadType
 
operations - Variable in exception net.spy.memcached.internal.CheckedOperationTimeoutException
 
OperationState - Enum in net.spy.memcached.ops
State of this operation.
OperationState() - Constructor for enum net.spy.memcached.ops.OperationState
 
OperationStatus - Class in net.spy.memcached.ops
Status indicator.
OperationStatus(boolean, String) - Constructor for class net.spy.memcached.ops.OperationStatus
 
OperationStatus(boolean, String, StatusCode) - Constructor for class net.spy.memcached.ops.OperationStatus
 
operationTimeout - Variable in class net.spy.memcached.MemcachedClient
 
OperationTimeoutException - Exception in net.spy.memcached
Thrown by MemcachedClient when any internal operations timeout.
OperationTimeoutException(String) - Constructor for exception net.spy.memcached.OperationTimeoutException
 
OperationTimeoutException(String, Throwable) - Constructor for exception net.spy.memcached.OperationTimeoutException
 
opFact - Variable in class net.spy.memcached.auth.AuthThread
 
opFact - Variable in class net.spy.memcached.ConnectionFactoryBuilder
 
opFact - Variable in class net.spy.memcached.MemcachedClient
 
opFact - Variable in class net.spy.memcached.MemcachedConnection
The OperationFactory to clone or create operations.
opFact - Variable in class net.spy.memcached.TapConnectionProvider
 
opQueueFactory - Variable in class net.spy.memcached.ConnectionFactoryBuilder
 
opQueueLen - Variable in class net.spy.memcached.DefaultConnectionFactory
 
opQueueMaxBlockTime - Variable in class net.spy.memcached.ConnectionFactoryBuilder
 
opQueueMaxBlockTime - Variable in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
ops - Variable in class net.spy.memcached.internal.BulkGetFuture
 
ops - Variable in class net.spy.memcached.protocol.binary.OptimizedSetImpl
 
ops - Variable in class net.spy.memcached.tapmessage.TapStream
 
opSucceeded(Operation) - Static method in class net.spy.memcached.MemcachedConnection
Reset the timeout counter for the given handling node.
opTimedOut(Operation) - Static method in class net.spy.memcached.MemcachedConnection
Increase the timeout counter for the given handling node.
opTimeout - Variable in class net.spy.memcached.ConnectionFactoryBuilder
 
optimize() - Method in class net.spy.memcached.protocol.ascii.AsciiMemcachedNodeImpl
 
optimize() - Method in class net.spy.memcached.protocol.binary.BinaryMemcachedNodeImpl
 
optimize() - Method in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
OptimizedGetImpl - Class in net.spy.memcached.protocol.ascii
Optimized Get operation for folding a bunch of gets together.
OptimizedGetImpl - Class in net.spy.memcached.protocol.binary
Optimized Get operation for folding a bunch of gets together.
OptimizedGetImpl(GetOperation) - Constructor for class net.spy.memcached.protocol.ascii.OptimizedGetImpl
Construct an optimized get starting with the given get operation.
OptimizedGetImpl(GetOperation) - Constructor for class net.spy.memcached.protocol.binary.OptimizedGetImpl
Construct an optimized get starting with the given get operation.
optimizedOp - Variable in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
OptimizedSetImpl - Class in net.spy.memcached.protocol.binary
Optimized Set operation for folding a bunch of sets together.
OptimizedSetImpl(CASOperation) - Constructor for class net.spy.memcached.protocol.binary.OptimizedSetImpl
Construct an optimized get starting with the given get operation.
OptimizedSetImpl.NoopCallback - Class in net.spy.memcached.protocol.binary
 
optimizeGets() - Method in class net.spy.memcached.protocol.binary.BinaryMemcachedNodeImpl
 
optimizeSets() - Method in class net.spy.memcached.protocol.binary.BinaryMemcachedNodeImpl
 
originalCallback - Variable in class net.spy.memcached.ops.MultiOperationCallback
 
OVERALL_AVG_BYTES_READ_METRIC - Static variable in class net.spy.memcached.MemcachedConnection
 
OVERALL_AVG_BYTES_WRITE_METRIC - Static variable in class net.spy.memcached.MemcachedConnection
 
OVERALL_AVG_TIME_ON_WIRE_METRIC - Static variable in class net.spy.memcached.MemcachedConnection
 
OVERALL_REQUEST_METRIC - Static variable in class net.spy.memcached.MemcachedConnection
 
OVERALL_RESPONSE_FAIL_METRIC - Static variable in class net.spy.memcached.MemcachedConnection
 
OVERALL_RESPONSE_METRIC - Static variable in class net.spy.memcached.MemcachedConnection
 
OVERALL_RESPONSE_RETRY_METRIC - Static variable in class net.spy.memcached.MemcachedConnection
 
OVERALL_RESPONSE_SUCC_METRIC - Static variable in class net.spy.memcached.MemcachedConnection
 
OVERHEAD - Static variable in class net.spy.memcached.protocol.ascii.BaseStoreOperationImpl
 
OVERHEAD - Static variable in class net.spy.memcached.protocol.ascii.CASOperationImpl
 
OVERHEAD - Static variable in class net.spy.memcached.protocol.ascii.DeleteOperationImpl
 
OVERHEAD - Static variable in class net.spy.memcached.protocol.ascii.MutatorOperationImpl
 
OVERHEAD - Static variable in class net.spy.memcached.protocol.ascii.TouchOperationImpl
 
OVERHEAD - Static variable in class net.spy.memcached.protocol.ascii.UnlockOperationImpl
 

P

packZeros - Variable in class net.spy.memcached.transcoders.TranscoderUtils
 
parseHeaderFromBuffer() - Method in class net.spy.memcached.protocol.binary.OperationImpl
Parse the header info out of the buffer.
password - Variable in class net.spy.memcached.auth.PlainCallbackHandler
 
payload - Variable in class net.spy.memcached.protocol.binary.OperationImpl
 
payloadOffset - Variable in class net.spy.memcached.protocol.binary.OperationImpl
 
pcb - Variable in class net.spy.memcached.protocol.ascii.OptimizedGetImpl
 
pcb - Variable in class net.spy.memcached.protocol.binary.OptimizedGetImpl
 
PERFORMANCE - net.spy.memcached.metrics.MetricType
Metrics useful for performance-related tracing.
PersistTo - Enum in net.spy.memcached
PersistTo codes for a Observe operation.
PersistTo(int) - Constructor for enum net.spy.memcached.PersistTo
 
PlainCallbackHandler - Class in net.spy.memcached.auth
Callback handler for doing plain auth.
PlainCallbackHandler(String, String) - Constructor for class net.spy.memcached.auth.PlainCallbackHandler
Construct a plain callback handler with the given username and password.
pool - Variable in class net.spy.memcached.transcoders.TranscodeService
 
POOL_NUMBER - Static variable in class net.spy.memcached.internal.BasicThreadFactory
 
potentiallyCloseLeakingChannel(SocketChannel, MemcachedNode) - Method in class net.spy.memcached.MemcachedConnection
Make sure channel connections are not leaked and properly close under faulty reconnect cirumstances.
prepareBuffer(String, long, byte[], Object...) - Method in class net.spy.memcached.protocol.binary.OperationImpl
Prepare the buffer for sending.
preparePending() - Method in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
prepend - net.spy.memcached.ops.ConcatenationType
Concatenate existing data onto the end of the supplied data.
prepend(long, String, Object) - Method in class net.spy.memcached.MemcachedClient
Prepend to an existing value in the cache.
prepend(long, String, Object) - Method in interface net.spy.memcached.MemcachedClientIF
 
prepend(long, String, T, Transcoder<T>) - Method in class net.spy.memcached.MemcachedClient
Prepend to an existing value in the cache.
prepend(long, String, T, Transcoder<T>) - Method in interface net.spy.memcached.MemcachedClientIF
 
prepend(String, Object) - Method in class net.spy.memcached.MemcachedClient
Prepend to an existing value in the cache.
prepend(String, Object) - Method in interface net.spy.memcached.MemcachedClientIF
 
prepend(String, T, Transcoder<T>) - Method in class net.spy.memcached.MemcachedClient
Prepend to an existing value in the cache.
prepend(String, T, Transcoder<T>) - Method in interface net.spy.memcached.MemcachedClientIF
 
PREPEND - Static variable in class net.spy.memcached.protocol.binary.ConcatenationOperationImpl
 
props - Variable in class net.spy.memcached.protocol.binary.SASLBaseOperationImpl
 
Protocol() - Constructor for enum net.spy.memcached.ConnectionFactoryBuilder.Protocol
 
PROTOCOL_BINARY_REQ - net.spy.memcached.tapmessage.TapMagic
Defines a tap binary request packet.
PROTOCOL_BINARY_RES - net.spy.memcached.tapmessage.TapMagic
Defines a tap binary response packet.
ProxyCallback - Class in net.spy.memcached.protocol
Proxy callback used for dispatching callbacks over optimized gets.
ProxyCallback() - Constructor for class net.spy.memcached.protocol.ProxyCallback
 
push(String, T) - Method in class net.spy.memcached.util.CacheLoader
Push a value into the cache.
put(String, V) - Method in class net.spy.memcached.BaseCacheMap
 
putAll(Map<? extends String, ? extends V>) - Method in class net.spy.memcached.BaseCacheMap
 

Q

queueReconnect(MemcachedNode) - Method in class net.spy.memcached.MemcachedConnection
Enqueue the given MemcachedNode for reconnect.

R

rbuf - Variable in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
readBufferAndLogMetrics(Operation, ByteBuffer, MemcachedNode) - Method in class net.spy.memcached.MemcachedConnection
Read from the buffer and add metrics information.
readBufSize - Variable in class net.spy.memcached.ConnectionFactoryBuilder
 
readBufSize - Variable in class net.spy.memcached.DefaultConnectionFactory
 
readFromBuffer(ByteBuffer) - Method in interface net.spy.memcached.ops.Operation
Read data from the given byte buffer and dispatch to the appropriate read mechanism.
readFromBuffer(ByteBuffer) - Method in class net.spy.memcached.protocol.ascii.OperationImpl
 
readFromBuffer(ByteBuffer) - Method in class net.spy.memcached.protocol.BaseOperationImpl
 
readFromBuffer(ByteBuffer) - Method in class net.spy.memcached.protocol.binary.OperationImpl
Read from the incoming ByteBuffer.
readFromBuffer(ByteBuffer) - Method in class net.spy.memcached.protocol.binary.TapAckOperationImpl
 
readFromBuffer(ByteBuffer) - Method in class net.spy.memcached.protocol.binary.TapOperationImpl
 
readHeaderFromBuffer(ByteBuffer) - Method in class net.spy.memcached.protocol.binary.OperationImpl
Read the header bytes from the incoming ByteBuffer.
READING - net.spy.memcached.ops.OperationState
State indicating this operation is reading data from the server.
readOffset - Variable in class net.spy.memcached.protocol.ascii.BaseGetOpImpl
 
readPayloadFromBuffer(ByteBuffer) - Method in class net.spy.memcached.protocol.binary.OperationImpl
Read the payload from the buffer.
readQ - Variable in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
readQueueFactory - Variable in class net.spy.memcached.ConnectionFactoryBuilder
 
readType - Variable in class net.spy.memcached.protocol.ascii.OperationImpl
 
receivedStatus(OperationStatus) - Method in class net.spy.memcached.ops.MultiOperationCallback
 
receivedStatus(OperationStatus) - Method in interface net.spy.memcached.ops.OperationCallback
Method invoked with the status when the operation is complete.
receivedStatus(OperationStatus) - Method in class net.spy.memcached.protocol.binary.OptimizedSetImpl.NoopCallback
 
receivedStatus(OperationStatus) - Method in class net.spy.memcached.protocol.GetCallbackWrapper
 
receivedStatus(OperationStatus) - Method in class net.spy.memcached.protocol.ProxyCallback
 
RECON_QUEUE_METRIC - Static variable in class net.spy.memcached.MemcachedConnection
 
reconnectAttempt - Variable in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
reconnectBlocked - Variable in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
reconnecting() - Method in interface net.spy.memcached.MemcachedNode
Notify this node that it will be reconnecting.
reconnecting() - Method in class net.spy.memcached.MemcachedNodeROImpl
 
reconnecting() - Method in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
reconnectQueue - Variable in class net.spy.memcached.MemcachedConnection
reconnectQueue contains the attachments that need to be reconnected.
Redistribute - net.spy.memcached.FailureMode
Move on to functional nodes when nodes fail.
redistributeOperation(Operation) - Method in class net.spy.memcached.MemcachedConnection
Redistribute the given operation to (potentially) other nodes.
redistributeOperations(Collection<Operation>) - Method in class net.spy.memcached.MemcachedConnection
Redistribute the given list of operations to (potentially) other nodes.
registerChannel(SocketChannel, SelectionKey) - Method in interface net.spy.memcached.MemcachedNode
Register a channel with this node.
registerChannel(SocketChannel, SelectionKey) - Method in class net.spy.memcached.MemcachedNodeROImpl
 
registerChannel(SocketChannel, SelectionKey) - Method in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
registerHashAlgorithm(String, HashAlgorithm) - Static method in class net.spy.memcached.HashAlgorithmRegistry
Registers provided HashAlgorithm instance with the given name.
registerMetrics() - Method in class net.spy.memcached.MemcachedConnection
Register Metrics for collection.
registry - Variable in class net.spy.memcached.metrics.DefaultMetricCollector
Holds the registry where all metrics are stored.
REGISTRY - Static variable in class net.spy.memcached.HashAlgorithmRegistry
Internal registry storage.
remaining - Variable in class net.spy.memcached.ops.MultiOperationCallback
 
remainingKeys - Variable in class net.spy.memcached.protocol.GetCallbackWrapper
 
remainingTries - Variable in class net.spy.memcached.KetamaIterator
 
remove() - Method in class net.spy.memcached.ArrayModNodeLocator.NodeIterator
 
remove() - Method in class net.spy.memcached.internal.SingleElementInfiniteIterator
 
remove() - Method in class net.spy.memcached.KetamaIterator
 
remove(Object) - Method in class net.spy.memcached.BaseCacheMap
 
removeCounter(String) - Method in class net.spy.memcached.metrics.DefaultMetricCollector
 
removeCounter(String) - Method in interface net.spy.memcached.metrics.MetricCollector
Remove a Counter from the collector.
removeCounter(String) - Method in class net.spy.memcached.metrics.NoopMetricCollector
 
removeCurrentReadOp() - Method in interface net.spy.memcached.MemcachedNode
Remove the operation at the top of the queue that is requiring input.
removeCurrentReadOp() - Method in class net.spy.memcached.MemcachedNodeROImpl
 
removeCurrentReadOp() - Method in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
removeCurrentWriteOp() - Method in interface net.spy.memcached.MemcachedNode
Remove the operation at the top of the queue that has information available to write.
removeCurrentWriteOp() - Method in class net.spy.memcached.MemcachedNodeROImpl
 
removeCurrentWriteOp() - Method in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
removeFromListeners(GenericCompletionListener<? extends Future<T>>) - Method in class net.spy.memcached.internal.AbstractListenableFuture
Remove a listener from the list of registered listeners.
removeHistogram(String) - Method in class net.spy.memcached.metrics.DefaultMetricCollector
 
removeHistogram(String) - Method in interface net.spy.memcached.metrics.MetricCollector
Remove a Histogram from the Collector.
removeHistogram(String) - Method in class net.spy.memcached.metrics.NoopMetricCollector
 
removeListener(L) - Method in interface net.spy.memcached.internal.ListenableFuture
Remove a previously added listener from the future.
removeListener(BulkGetCompletionListener) - Method in interface net.spy.memcached.internal.BulkFuture
Remove a previously added listener from the future.
removeListener(BulkGetCompletionListener) - Method in class net.spy.memcached.internal.BulkGetFuture
 
removeListener(GetCompletionListener) - Method in class net.spy.memcached.internal.GetFuture
 
removeListener(OperationCompletionListener) - Method in class net.spy.memcached.internal.OperationFuture
 
removeMeter(String) - Method in class net.spy.memcached.metrics.DefaultMetricCollector
 
removeMeter(String) - Method in interface net.spy.memcached.metrics.MetricCollector
Remove a Meter from the Collector.
removeMeter(String) - Method in class net.spy.memcached.metrics.NoopMetricCollector
 
removeObserver(ConnectionObserver) - Method in class net.spy.memcached.MemcachedClient
Remove a connection observer.
removeObserver(ConnectionObserver) - Method in interface net.spy.memcached.MemcachedClientIF
 
removeObserver(ConnectionObserver) - Method in class net.spy.memcached.MemcachedConnection
Remove a connection observer.
removeObserver(ConnectionObserver) - Method in class net.spy.memcached.TapConnectionProvider
Remove a connection observer.
replace - net.spy.memcached.ops.StoreType
Store a value in the cache iff there is already something stored for the given key.
replace(String, int, Object) - Method in class net.spy.memcached.MemcachedClient
Replace an object with the given value (transcoded with the default transcoder) iff there is already a value for the given key.
replace(String, int, Object) - Method in interface net.spy.memcached.MemcachedClientIF
 
replace(String, int, T, Transcoder<T>) - Method in class net.spy.memcached.MemcachedClient
Replace an object with the given value iff there is already a value for the given key.
replace(String, int, T, Transcoder<T>) - Method in interface net.spy.memcached.MemcachedClientIF
 
REPLACE - Static variable in class net.spy.memcached.protocol.binary.StoreOperationImpl
 
REPLACEQ - Static variable in class net.spy.memcached.protocol.binary.StoreOperationImpl
 
REPLICA_GET_CMD - Static variable in class net.spy.memcached.protocol.binary.ReplicaGetOperationImpl
 
REPLICA_GET_CMD - Static variable in class net.spy.memcached.protocol.binary.ReplicaGetsOperationImpl
 
replicaGet(String, int, ReplicaGetOperation.Callback) - Method in interface net.spy.memcached.OperationFactory
Create a replica get operation.
replicaGet(String, int, ReplicaGetOperation.Callback) - Method in class net.spy.memcached.protocol.ascii.AsciiOperationFactory
 
replicaGet(String, int, ReplicaGetOperation.Callback) - Method in class net.spy.memcached.protocol.binary.BinaryOperationFactory
 
ReplicaGetOperation - Interface in net.spy.memcached.ops
Replica get operation.
ReplicaGetOperation.Callback - Interface in net.spy.memcached.ops
Operation callback for the replica get request.
ReplicaGetOperationImpl - Class in net.spy.memcached.protocol.binary
Implementation of the replica get operation.
ReplicaGetOperationImpl(String, int, ReplicaGetOperation.Callback) - Constructor for class net.spy.memcached.protocol.binary.ReplicaGetOperationImpl
 
replicaGets(String, int, ReplicaGetsOperation.Callback) - Method in interface net.spy.memcached.OperationFactory
Create a replica gets operation.
replicaGets(String, int, ReplicaGetsOperation.Callback) - Method in class net.spy.memcached.protocol.ascii.AsciiOperationFactory
 
replicaGets(String, int, ReplicaGetsOperation.Callback) - Method in class net.spy.memcached.protocol.binary.BinaryOperationFactory
 
ReplicaGetsOperation - Interface in net.spy.memcached.ops
Replica get operation.
ReplicaGetsOperation.Callback - Interface in net.spy.memcached.ops
Operation callback for the replica get request.
ReplicaGetsOperationImpl - Class in net.spy.memcached.protocol.binary
Implementation of the replica gets operation.
ReplicaGetsOperationImpl(String, int, ReplicaGetsOperation.Callback) - Constructor for class net.spy.memcached.protocol.binary.ReplicaGetsOperationImpl
 
replicaIndex - Variable in class net.spy.memcached.protocol.binary.ReplicaGetOperationImpl
 
replicaIndex - Variable in class net.spy.memcached.protocol.binary.ReplicaGetsOperationImpl
 
ReplicateTo - Enum in net.spy.memcached
ReplicateTo codes for a Observe operation.
ReplicateTo(int) - Constructor for enum net.spy.memcached.ReplicateTo
 
REQ_MAGIC - Static variable in class net.spy.memcached.protocol.binary.OperationImpl
 
REQUEST - net.spy.memcached.tapmessage.TapOpcode
Defines a request message to open a tap connection.
REQUEST - Static variable in class net.spy.memcached.protocol.ascii.VersionOperationImpl
 
RequestMessage - Class in net.spy.memcached.tapmessage
A tap request message that is used to start tap streams, perform sasl authentication, and maintain the health of tap streams.
RequestMessage() - Constructor for class net.spy.memcached.tapmessage.RequestMessage
Create a tap request message.
RES_MAGIC - Static variable in class net.spy.memcached.protocol.binary.OperationImpl
 
reserved1 - Variable in class net.spy.memcached.tapmessage.ResponseMessage
 
RESERVED1_OFFSET - Static variable in class net.spy.memcached.tapmessage.ResponseMessage
 
reserved2 - Variable in class net.spy.memcached.tapmessage.ResponseMessage
 
RESERVED2_OFFSET - Static variable in class net.spy.memcached.tapmessage.ResponseMessage
 
reserved3 - Variable in class net.spy.memcached.tapmessage.ResponseMessage
 
RESERVED3_OFFSET - Static variable in class net.spy.memcached.tapmessage.ResponseMessage
 
resetInput() - Method in class net.spy.memcached.protocol.binary.OperationImpl
 
responseCas - Variable in class net.spy.memcached.protocol.binary.OperationImpl
 
responseCmd - Variable in class net.spy.memcached.protocol.binary.OperationImpl
 
ResponseMessage - Class in net.spy.memcached.tapmessage
A representation of a tap stream message sent from a tap stream server.
ResponseMessage(byte[]) - Constructor for class net.spy.memcached.tapmessage.ResponseMessage
Creates a ResponseMessage from binary data.
responseOpaque - Variable in class net.spy.memcached.protocol.binary.OperationImpl
 
retCas - Variable in class net.spy.memcached.protocol.binary.ObserveOperationImpl
 
Retry - net.spy.memcached.FailureMode
Continue to retry a failing node until it comes back up.
RETRY - net.spy.memcached.ops.OperationState
State indicating this operation needs to be resent.
retryKeys - Variable in class net.spy.memcached.protocol.binary.MultiGetOperationImpl
 
retryOperation(Operation) - Method in class net.spy.memcached.MemcachedConnection
Add a operation to the retry queue.
retryOps - Variable in class net.spy.memcached.MemcachedConnection
Holds operations that need to be retried.
retryQueueSize - Variable in class net.spy.memcached.MemcachedConnection
Optionally bound the retry queue if set via system property.
revid - Variable in class net.spy.memcached.tapmessage.ResponseMessage
 
rkeys - Variable in class net.spy.memcached.protocol.binary.MultiGetOperationImpl
 
RN_BYTES - Static variable in class net.spy.memcached.protocol.ascii.BaseGetOpImpl
 
root - Variable in class net.spy.memcached.MemcachedNodeROImpl
 
rqueue - Variable in class net.spy.memcached.TapClient
 
run() - Method in class net.spy.memcached.auth.AuthThread
 
run() - Method in class net.spy.memcached.compat.SyncThread
Wait for the barrier, invoke the callable and capture the result or an exception.
run() - Method in class net.spy.memcached.MemcachedConnection
Handle IO as long as the application is running.
run() - Method in class net.spy.memcached.transcoders.TranscodeService.Task
 
running - Variable in class net.spy.memcached.MemcachedConnection
True if not shutting down or shut down.
rv - Variable in class net.spy.memcached.compat.SyncThread
 
rv - Variable in class net.spy.memcached.internal.GetFuture
 
rvMap - Variable in class net.spy.memcached.internal.BulkGetFuture
 

S

SASL_CONTINUE - Static variable in class net.spy.memcached.protocol.binary.SASLBaseOperationImpl
 
saslAuth(String[], String, Map<String, ?>, CallbackHandler, OperationCallback) - Method in interface net.spy.memcached.OperationFactory
Create a new sasl auth operation.
saslAuth(String[], String, Map<String, ?>, CallbackHandler, OperationCallback) - Method in class net.spy.memcached.protocol.ascii.AsciiOperationFactory
 
saslAuth(String[], String, Map<String, ?>, CallbackHandler, OperationCallback) - Method in class net.spy.memcached.protocol.binary.BinaryOperationFactory
 
SASLAUTH - net.spy.memcached.tapmessage.TapOpcode
Defines a SASL authorization message.
SASLAuthOperation - Interface in net.spy.memcached.ops
Operation for beginning a SASL auth cycle.
SASLAuthOperationImpl - Class in net.spy.memcached.protocol.binary
SASL authenticator.
SASLAuthOperationImpl(String[], String, Map<String, ?>, CallbackHandler, OperationCallback) - Constructor for class net.spy.memcached.protocol.binary.SASLAuthOperationImpl
 
SASLBaseOperationImpl - Class in net.spy.memcached.protocol.binary
SASL authenticator.
SASLBaseOperationImpl(byte, String[], byte[], String, Map<String, ?>, CallbackHandler, OperationCallback) - Constructor for class net.spy.memcached.protocol.binary.SASLBaseOperationImpl
 
SASLLIST - net.spy.memcached.tapmessage.TapOpcode
Defines a SASL list mechanism message.
saslMechs(OperationCallback) - Method in interface net.spy.memcached.OperationFactory
Create a new SASL mechs operation.
saslMechs(OperationCallback) - Method in class net.spy.memcached.protocol.ascii.AsciiOperationFactory
 
saslMechs(OperationCallback) - Method in class net.spy.memcached.protocol.binary.BinaryOperationFactory
 
SASLMechsOperation - Interface in net.spy.memcached.ops
Operation for listing supported SASL mechanisms.
SASLMechsOperationImpl - Class in net.spy.memcached.protocol.binary
 
SASLMechsOperationImpl(OperationCallback) - Constructor for class net.spy.memcached.protocol.binary.SASLMechsOperationImpl
 
saslStep(String[], byte[], String, Map<String, ?>, CallbackHandler, OperationCallback) - Method in interface net.spy.memcached.OperationFactory
Create a new sasl step operation.
saslStep(String[], byte[], String, Map<String, ?>, CallbackHandler, OperationCallback) - Method in class net.spy.memcached.protocol.ascii.AsciiOperationFactory
 
saslStep(String[], byte[], String, Map<String, ?>, CallbackHandler, OperationCallback) - Method in class net.spy.memcached.protocol.binary.BinaryOperationFactory
 
SASLStepOperation - Interface in net.spy.memcached.ops
Operation for proceeding in a SASL auth negotiation.
SASLStepOperationImpl - Class in net.spy.memcached.protocol.binary
A SASLStepOperationImpl.
SASLStepOperationImpl(String[], byte[], String, Map<String, ?>, CallbackHandler, OperationCallback) - Constructor for class net.spy.memcached.protocol.binary.SASLStepOperationImpl
 
selector - Variable in class net.spy.memcached.MemcachedConnection
Holds the current Selector to use.
selectorsMakeSense() - Method in class net.spy.memcached.MemcachedConnection
Make sure that the current selectors make sense.
SEQ_NUMBER - Static variable in class net.spy.memcached.protocol.binary.OperationImpl
 
serialize(Object) - Method in class net.spy.memcached.transcoders.BaseSerializingTranscoder
Get the bytes representing the given serialized object.
SERIALIZED - Static variable in class net.spy.memcached.transcoders.SerializingTranscoder
 
SERIALIZED - Static variable in class net.spy.memcached.transcoders.WhalinTranscoder
 
SERIALIZED - Static variable in class net.spy.memcached.transcoders.WhalinV1Transcoder
 
SerializingTranscoder - Class in net.spy.memcached.transcoders
Transcoder that serializes and compresses objects.
SerializingTranscoder() - Constructor for class net.spy.memcached.transcoders.SerializingTranscoder
Get a serializing transcoder with the default max data size.
SerializingTranscoder(int) - Constructor for class net.spy.memcached.transcoders.SerializingTranscoder
Get a serializing transcoder that specifies the max data size.
serialVersionUID - Static variable in exception net.spy.memcached.internal.CheckedOperationTimeoutException
 
serialVersionUID - Static variable in exception net.spy.memcached.OperationTimeoutException
 
serialVersionUID - Static variable in exception net.spy.memcached.ops.OperationException
 
SERVER - net.spy.memcached.ops.OperationErrorType
Error that occurred because the server did something stupid.
serverName - Variable in class net.spy.memcached.protocol.binary.SASLBaseOperationImpl
 
service - Variable in class net.spy.memcached.internal.AbstractListenableFuture
The ExecutorService in which the notifications will be handled.
set - net.spy.memcached.ops.StoreType
Unconditionally store a value in the cache.
set(String, int, Object) - Method in class net.spy.memcached.MemcachedClient
Set an object in the cache (using the default transcoder) regardless of any existing value.
set(String, int, Object) - Method in interface net.spy.memcached.MemcachedClientIF
 
set(String, int, T, Transcoder<T>) - Method in class net.spy.memcached.MemcachedClient
Set an object in the cache regardless of any existing value.
set(String, int, T, Transcoder<T>) - Method in interface net.spy.memcached.MemcachedClientIF
 
set(Future<T>, OperationStatus) - Method in class net.spy.memcached.internal.GetFuture
 
set(T, OperationStatus) - Method in class net.spy.memcached.internal.OperationFuture
Set the Operation associated with this OperationFuture.
SET - Static variable in class net.spy.memcached.protocol.binary.StoreOperationImpl
 
setArguments(ByteBuffer, Object...) - Method in class net.spy.memcached.protocol.ascii.OperationImpl
Set some arguments for an operation into the given byte buffer.
setAuthDescriptor(AuthDescriptor) - Method in class net.spy.memcached.ConnectionFactoryBuilder
Set the auth descriptor to enable authentication on new connections.
setAuthWaitTime(long) - Method in class net.spy.memcached.ConnectionFactoryBuilder
Set a custom wait time for the authentication on connect/reconnect.
setBackfill(long) - Method in class net.spy.memcached.tapmessage.RequestMessage
Stream all keys inserted into the server after a given date.
setBuffer(ByteBuffer) - Method in class net.spy.memcached.protocol.BaseOperationImpl
Set the write buffer for this operation.
setCallback(OperationCallback) - Method in class net.spy.memcached.protocol.BaseOperationImpl
Set the callback for this instance.
setCas(long) - Method in class net.spy.memcached.internal.OperationFuture
Set the key for this operation.
setCas(long) - Method in class net.spy.memcached.tapmessage.BaseMessage
Sets the value of the tap messages cas field.
setChannel(SocketChannel) - Method in interface net.spy.memcached.MemcachedNode
Set the SocketChannel this node uses.
setChannel(SocketChannel) - Method in class net.spy.memcached.MemcachedNodeROImpl
 
setChannel(SocketChannel) - Method in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
setCharset(String) - Method in class net.spy.memcached.transcoders.BaseSerializingTranscoder
Set the character set for string value transcoding (defaults to UTF-8).
setCloneCount(int) - Method in interface net.spy.memcached.ops.Operation
Sets the clone count for this operation.
setCloneCount(int) - Method in class net.spy.memcached.protocol.BaseOperationImpl
 
setCompressionThreshold(int) - Method in class net.spy.memcached.transcoders.BaseSerializingTranscoder
Set the compression threshold to the given number of bytes.
setConnection(MemcachedConnection) - Method in interface net.spy.memcached.MemcachedNode
 
setConnection(MemcachedConnection) - Method in class net.spy.memcached.MemcachedNodeROImpl
 
setConnection(MemcachedConnection) - Method in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
setContinuousTimeout(boolean) - Method in interface net.spy.memcached.MemcachedNode
Count 'time out' exceptions to drop connections that fail perpetually.
setContinuousTimeout(boolean) - Method in class net.spy.memcached.MemcachedNodeROImpl
 
setContinuousTimeout(boolean) - Method in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
setDaemon(boolean) - Method in class net.spy.memcached.ConnectionFactoryBuilder
Set the daemon state of the IO thread (defaults to true).
setDatatype(byte) - Method in class net.spy.memcached.tapmessage.BaseMessage
Sets the value of the tap messages data type field.
setEnableMetrics(MetricType) - Method in class net.spy.memcached.ConnectionFactoryBuilder
Enable or disable metric collection.
setExtralength(byte) - Method in class net.spy.memcached.tapmessage.BaseMessage
Sets the value of the tap messages extra length field.
setFailureMode(FailureMode) - Method in class net.spy.memcached.ConnectionFactoryBuilder
Set the failure mode.
setFlags(TapRequestFlag) - Method in class net.spy.memcached.tapmessage.RequestMessage
Sets the flags for the tap stream.
setHandlingNode(MemcachedNode) - Method in interface net.spy.memcached.ops.Operation
Set a reference to the node that will be/is handling this operation.
setHandlingNode(MemcachedNode) - Method in class net.spy.memcached.protocol.BaseOperationImpl
 
setHashAlg(HashAlgorithm) - Method in class net.spy.memcached.ConnectionFactoryBuilder
Set the hash algorithm.
setInitialObservers(Collection<ConnectionObserver>) - Method in class net.spy.memcached.ConnectionFactoryBuilder
Set the initial connection observers (will observe initial connection).
setKetamaNodes(List<MemcachedNode>) - Method in class net.spy.memcached.KetamaNodeLocator
Setup the KetamaNodeLocator with the list of nodes it should use.
setListenerExecutorService(ExecutorService) - Method in class net.spy.memcached.ConnectionFactoryBuilder
Set a custom ExecutorService to execute the listener callbacks.
setLocatorType(ConnectionFactoryBuilder.Locator) - Method in class net.spy.memcached.ConnectionFactoryBuilder
Set the locator type.
setMagic(TapMagic) - Method in class net.spy.memcached.tapmessage.BaseMessage
Sets the value of the tap messages magic field.
setMaxReconnectDelay(long) - Method in class net.spy.memcached.ConnectionFactoryBuilder
Set the maximum reconnect delay.
setMetricCollector(MetricCollector) - Method in class net.spy.memcached.ConnectionFactoryBuilder
Set a custom MetricCollector.
setName(String) - Method in class net.spy.memcached.tapmessage.RequestMessage
Sets a name for this tap stream.
setNotMyVbucketNodes(Collection<MemcachedNode>) - Method in interface net.spy.memcached.ops.VBucketAware
 
setNotMyVbucketNodes(Collection<MemcachedNode>) - Method in class net.spy.memcached.protocol.binary.MultiKeyOperationImpl
 
setNotMyVbucketNodes(Collection<MemcachedNode>) - Method in class net.spy.memcached.protocol.binary.SingleKeyOperationImpl
 
setOpaque(int) - Method in class net.spy.memcached.tapmessage.BaseMessage
Sets the value of the tap messages opaque field.
setOpcode(TapOpcode) - Method in class net.spy.memcached.tapmessage.BaseMessage
Sets the value of the tap messages opcode field.
setOperation(Operation) - Method in class net.spy.memcached.internal.GetFuture
 
setOperation(Operation) - Method in class net.spy.memcached.internal.OperationFuture
Set the Operation associated with this OperationFuture.
setOpFact(OperationFactory) - Method in class net.spy.memcached.ConnectionFactoryBuilder
Set the operation factory.
setOpQueueFactory(OperationQueueFactory) - Method in class net.spy.memcached.ConnectionFactoryBuilder
 
setOpQueueMaxBlockTime(long) - Method in class net.spy.memcached.ConnectionFactoryBuilder
Set the maximum amount of time (in milliseconds) a client is willing to wait for space to become available in an output queue.
setOpTimeout(long) - Method in class net.spy.memcached.ConnectionFactoryBuilder
Set the default operation timeout in milliseconds.
setProtocol(ConnectionFactoryBuilder.Protocol) - Method in class net.spy.memcached.ConnectionFactoryBuilder
Convenience method to specify the protocol to use.
SETQ - Static variable in class net.spy.memcached.protocol.binary.StoreOperationImpl
 
setReadBufferSize(int) - Method in class net.spy.memcached.ConnectionFactoryBuilder
Set the read buffer size.
setReadOpQueueFactory(OperationQueueFactory) - Method in class net.spy.memcached.ConnectionFactoryBuilder
Set the read queue factory.
setReadType(OperationReadType) - Method in class net.spy.memcached.protocol.ascii.OperationImpl
Set the read type of this operation.
setShouldOptimize(boolean) - Method in class net.spy.memcached.ConnectionFactoryBuilder
Set to false if the default operation optimization is not desirable.
setSk(SelectionKey) - Method in interface net.spy.memcached.MemcachedNode
Set the selection key for this node.
setSk(SelectionKey) - Method in class net.spy.memcached.MemcachedNodeROImpl
 
setSk(SelectionKey) - Method in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
setStatus(OperationStatus) - Method in class net.spy.memcached.internal.BulkGetFuture
 
setTimeout(Operation, boolean) - Static method in class net.spy.memcached.MemcachedConnection
Set the continuous timeout on an operation.
setTimeoutExceptionThreshold(int) - Method in class net.spy.memcached.ConnectionFactoryBuilder
Set the maximum timeout exception threshold.
setTotalbody(int) - Method in class net.spy.memcached.tapmessage.BaseMessage
Sets the value of the tap messages total body field.
setTranscoder(Transcoder<Object>) - Method in class net.spy.memcached.ConnectionFactoryBuilder
Set the default transcoder.
setupForAuth() - Method in interface net.spy.memcached.MemcachedNode
Tell a node to set up for authentication.
setupForAuth() - Method in class net.spy.memcached.MemcachedNodeROImpl
 
setupForAuth() - Method in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
setupResend() - Method in interface net.spy.memcached.MemcachedNode
Clear the queue of currently processing operations by either cancelling them or setting them up to be reapplied after a reconnect.
setupResend() - Method in class net.spy.memcached.MemcachedNodeROImpl
 
setupResend() - Method in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
setUseNagleAlgorithm(boolean) - Method in class net.spy.memcached.ConnectionFactoryBuilder
Set to true if you'd like to enable the Nagle algorithm.
setVbucket(short) - Method in class net.spy.memcached.tapmessage.BaseMessage
Sets the value of the tap messages vbucket field.
setVBucket(String, short) - Method in interface net.spy.memcached.ops.VBucketAware
 
setVBucket(String, short) - Method in class net.spy.memcached.protocol.binary.MultiKeyOperationImpl
 
setVBucket(String, short) - Method in class net.spy.memcached.protocol.binary.SingleKeyOperationImpl
 
setvBucketCheckpoints(Map<Short, Long>) - Method in class net.spy.memcached.tapmessage.RequestMessage
Sets a map of vbucket checkpoints.
setVbucketlist(short[]) - Method in class net.spy.memcached.tapmessage.RequestMessage
Sets a list of vbuckets to stream keys from.
setWriteOpQueueFactory(OperationQueueFactory) - Method in class net.spy.memcached.ConnectionFactoryBuilder
Set the write queue factory.
shouldAuth - Variable in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
shouldOptimize - Variable in class net.spy.memcached.ConnectionFactoryBuilder
 
shouldOptimize - Variable in class net.spy.memcached.MemcachedConnection
If true, optimization will collapse multiple sequential get ops.
shouldOptimize() - Method in interface net.spy.memcached.ConnectionFactory
If true, low-level optimization is in effect.
shouldOptimize() - Method in class net.spy.memcached.DefaultConnectionFactory
 
SHUTD_QUEUE_METRIC - Static variable in class net.spy.memcached.MemcachedConnection
 
shutdown() - Method in class net.spy.memcached.MemcachedClient
Shut down immediately.
shutdown() - Method in interface net.spy.memcached.MemcachedClientIF
 
shutdown() - Method in class net.spy.memcached.MemcachedConnection
Shut down all connections and do not accept further incoming ops.
shutdown() - Method in class net.spy.memcached.TapClient
Shuts down all tap streams that are currently running.
shutdown() - Method in class net.spy.memcached.TapConnectionProvider
Shut down immediately.
shutdown() - Method in class net.spy.memcached.transcoders.TranscodeService
Shut down the pool.
shutdown(long, TimeUnit) - Method in class net.spy.memcached.MemcachedClient
Shut down this client gracefully.
shutdown(long, TimeUnit) - Method in interface net.spy.memcached.MemcachedClientIF
 
shutdown(long, TimeUnit) - Method in class net.spy.memcached.TapConnectionProvider
Shut down this client gracefully.
shutDown - Variable in class net.spy.memcached.MemcachedConnection
If the connection is alread shut down or shutting down.
shuttingDown - Variable in class net.spy.memcached.MemcachedClient
 
shuttingDown - Variable in class net.spy.memcached.TapConnectionProvider
 
signalComplete() - Method in class net.spy.memcached.internal.BulkGetFuture
Signals that this future is complete.
signalComplete() - Method in class net.spy.memcached.internal.GetFuture
Signals that this future is complete.
signalComplete() - Method in class net.spy.memcached.internal.OperationFuture
Signals that this future is complete.
SingleElementInfiniteIterator<T> - Class in net.spy.memcached.internal
An iterator that returns a single element for as many elements as are needed from the iterator; in other words, #hasNext() never returns false.
SingleElementInfiniteIterator(T) - Constructor for class net.spy.memcached.internal.SingleElementInfiniteIterator
Construct a iterator tat returns the input element an infinite number of times.
SingleKeyOperationImpl - Class in net.spy.memcached.protocol.binary
Binary operations that contain a single key and are VBucket aware operations should extend this class.
SingleKeyOperationImpl(byte, int, String, OperationCallback) - Constructor for class net.spy.memcached.protocol.binary.SingleKeyOperationImpl
 
size() - Method in class net.spy.memcached.BaseCacheMap
 
size() - Method in class net.spy.memcached.protocol.binary.OptimizedGetImpl
 
size() - Method in class net.spy.memcached.protocol.binary.OptimizedSetImpl
 
sk - Variable in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
SLF4JLogger - Class in net.spy.memcached.compat.log
Logging Implementation using the SLF4J logging facade.
SLF4JLogger(String) - Constructor for class net.spy.memcached.compat.log.SLF4JLogger
Get an instance of the SLF4JLogger.
socketAddress - Variable in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
SPECIAL_BOOLEAN - Static variable in class net.spy.memcached.transcoders.SerializingTranscoder
 
SPECIAL_BOOLEAN - Static variable in class net.spy.memcached.transcoders.WhalinTranscoder
 
SPECIAL_BOOLEAN - Static variable in class net.spy.memcached.transcoders.WhalinV1Transcoder
 
SPECIAL_BYTE - Static variable in class net.spy.memcached.transcoders.SerializingTranscoder
 
SPECIAL_BYTE - Static variable in class net.spy.memcached.transcoders.WhalinTranscoder
 
SPECIAL_BYTE - Static variable in class net.spy.memcached.transcoders.WhalinV1Transcoder
 
SPECIAL_BYTEARRAY - Static variable in class net.spy.memcached.transcoders.SerializingTranscoder
 
SPECIAL_BYTEARRAY - Static variable in class net.spy.memcached.transcoders.WhalinTranscoder
 
SPECIAL_CHARACTER - Static variable in class net.spy.memcached.transcoders.WhalinTranscoder
 
SPECIAL_CHARACTER - Static variable in class net.spy.memcached.transcoders.WhalinV1Transcoder
 
SPECIAL_DATE - Static variable in class net.spy.memcached.transcoders.SerializingTranscoder
 
SPECIAL_DATE - Static variable in class net.spy.memcached.transcoders.WhalinTranscoder
 
SPECIAL_DATE - Static variable in class net.spy.memcached.transcoders.WhalinV1Transcoder
 
SPECIAL_DOUBLE - Static variable in class net.spy.memcached.transcoders.SerializingTranscoder
 
SPECIAL_DOUBLE - Static variable in class net.spy.memcached.transcoders.WhalinTranscoder
 
SPECIAL_DOUBLE - Static variable in class net.spy.memcached.transcoders.WhalinV1Transcoder
 
SPECIAL_FLOAT - Static variable in class net.spy.memcached.transcoders.SerializingTranscoder
 
SPECIAL_FLOAT - Static variable in class net.spy.memcached.transcoders.WhalinTranscoder
 
SPECIAL_FLOAT - Static variable in class net.spy.memcached.transcoders.WhalinV1Transcoder
 
SPECIAL_INT - Static variable in class net.spy.memcached.transcoders.SerializingTranscoder
 
SPECIAL_INT - Static variable in class net.spy.memcached.transcoders.WhalinTranscoder
 
SPECIAL_INTEGER - Static variable in class net.spy.memcached.transcoders.WhalinV1Transcoder
 
SPECIAL_LONG - Static variable in class net.spy.memcached.transcoders.SerializingTranscoder
 
SPECIAL_LONG - Static variable in class net.spy.memcached.transcoders.WhalinTranscoder
 
SPECIAL_LONG - Static variable in class net.spy.memcached.transcoders.WhalinV1Transcoder
 
SPECIAL_MASK - Static variable in class net.spy.memcached.transcoders.SerializingTranscoder
 
SPECIAL_SHORT - Static variable in class net.spy.memcached.transcoders.WhalinTranscoder
 
SPECIAL_SHORT - Static variable in class net.spy.memcached.transcoders.WhalinV1Transcoder
 
SPECIAL_STRING - Static variable in class net.spy.memcached.transcoders.WhalinTranscoder
 
SPECIAL_STRING - Static variable in class net.spy.memcached.transcoders.WhalinV1Transcoder
 
SPECIAL_STRINGBUFFER - Static variable in class net.spy.memcached.transcoders.WhalinTranscoder
 
SPECIAL_STRINGBUFFER - Static variable in class net.spy.memcached.transcoders.WhalinV1Transcoder
 
SPECIAL_STRINGBUILDER - Static variable in class net.spy.memcached.transcoders.WhalinTranscoder
 
SPECIAL_STRINGBUILDER - Static variable in class net.spy.memcached.transcoders.WhalinV1Transcoder
 
specifyVbuckets(short[]) - Method in class net.spy.memcached.tapmessage.MessageBuilder
 
SPYMEMCACHED - net.spy.memcached.KetamaNodeKeyFormatter.Format
SPYMEMCACHED uses the format traditionally used by spymemcached to map nodes to names.
SpyObject - Class in net.spy.memcached.compat
Superclass for all Spy Objects.
SpyObject() - Constructor for class net.spy.memcached.compat.SpyObject
Get an instance of SpyObject.
SpyThread - Class in net.spy.memcached.compat
Superclass for all Spy Threads.
SpyThread() - Constructor for class net.spy.memcached.compat.SpyThread
Get an instance of SpyThread.
SpyThread(String) - Constructor for class net.spy.memcached.compat.SpyThread
Get an instance of SpyThread with a name.
start - Variable in class net.spy.memcached.ArrayModNodeLocator.NodeIterator
 
START_CHECKPOINT - net.spy.memcached.tapmessage.TapOpcode
Defines the start of a checkpoint.
state - Variable in class net.spy.memcached.protocol.BaseOperationImpl
 
stats(String, StatsOperation.Callback) - Method in interface net.spy.memcached.OperationFactory
Get a new StatsOperation.
stats(String, StatsOperation.Callback) - Method in class net.spy.memcached.protocol.ascii.AsciiOperationFactory
 
stats(String, StatsOperation.Callback) - Method in class net.spy.memcached.protocol.binary.BinaryOperationFactory
 
StatsOperation - Interface in net.spy.memcached.ops
Stats fetching operation.
StatsOperation.Callback - Interface in net.spy.memcached.ops
Callback for stats operation.
StatsOperationImpl - Class in net.spy.memcached.protocol.ascii
Operation to retrieve statistics from a memcached server.
StatsOperationImpl - Class in net.spy.memcached.protocol.binary
A StatsOperationImpl.
StatsOperationImpl(String, StatsOperation.Callback) - Constructor for class net.spy.memcached.protocol.ascii.StatsOperationImpl
 
StatsOperationImpl(String, StatsOperation.Callback) - Constructor for class net.spy.memcached.protocol.binary.StatsOperationImpl
 
status - Variable in class net.spy.memcached.internal.BulkGetFuture
 
status - Variable in class net.spy.memcached.internal.OperationFuture
 
STATUS_OK - Static variable in class net.spy.memcached.protocol.binary.OperationImpl
 
statusCode - Variable in class net.spy.memcached.ops.OperationStatus
 
StatusCode - Enum in net.spy.memcached.ops
Represents status and error codes from the binary protocol.
StatusCode() - Constructor for enum net.spy.memcached.ops.StatusCode
 
storageListener - Variable in class net.spy.memcached.util.CacheLoader
 
store(StoreType, String, int, int, byte[], StoreOperation.Callback) - Method in interface net.spy.memcached.OperationFactory
Create a store operation.
store(StoreType, String, int, int, byte[], StoreOperation.Callback) - Method in class net.spy.memcached.protocol.ascii.AsciiOperationFactory
 
store(StoreType, String, int, int, byte[], StoreOperation.Callback) - Method in class net.spy.memcached.protocol.binary.BinaryOperationFactory
 
STORED - Static variable in class net.spy.memcached.protocol.ascii.BaseStoreOperationImpl
 
STORED - Static variable in class net.spy.memcached.protocol.ascii.CASOperationImpl
 
StoreOperation - Interface in net.spy.memcached.ops
Operation that represents object storage.
StoreOperation.Callback - Interface in net.spy.memcached.ops
Operation callback to get the CAS value.
StoreOperationImpl - Class in net.spy.memcached.protocol.ascii
Operation to store data in a memcached server.
StoreOperationImpl - Class in net.spy.memcached.protocol.binary
 
StoreOperationImpl(StoreType, String, int, int, byte[], long, StoreOperation.Callback) - Constructor for class net.spy.memcached.protocol.binary.StoreOperationImpl
 
StoreOperationImpl(StoreType, String, int, int, byte[], OperationCallback) - Constructor for class net.spy.memcached.protocol.ascii.StoreOperationImpl
 
storeResult(String, boolean) - Method in interface net.spy.memcached.util.CacheLoader.StorageListener
Normal path response for a set.
storeType - Variable in class net.spy.memcached.protocol.ascii.StoreOperationImpl
 
storeType - Variable in class net.spy.memcached.protocol.binary.StoreOperationImpl
 
StoreType - Enum in net.spy.memcached.ops
The type of storage operation to perform.
StoreType() - Constructor for enum net.spy.memcached.ops.StoreType
 
streamClosed(OperationState) - Method in interface net.spy.memcached.ops.TapOperation
 
streamClosed(OperationState) - Method in class net.spy.memcached.protocol.binary.TapAckOperationImpl
 
streamClosed(OperationState) - Method in class net.spy.memcached.protocol.binary.TapBackfillOperationImpl
 
streamClosed(OperationState) - Method in class net.spy.memcached.protocol.binary.TapCustomOperationImpl
 
streamClosed(OperationState) - Method in class net.spy.memcached.protocol.binary.TapDumpOperationImpl
 
StringUtils - Class in net.spy.memcached.util
Utility methods on string objects.
StringUtils() - Constructor for class net.spy.memcached.util.StringUtils
Private constructor, since this is a purely static class.
SUCCESS - net.spy.memcached.ops.StatusCode
 
SUCCESS - Static variable in class net.spy.memcached.protocol.binary.OperationImpl
Error code for operations.
sunLogger - Variable in class net.spy.memcached.compat.log.SunLogger
 
SunLogger - Class in net.spy.memcached.compat.log
Logging implementation using the sun logger.
SunLogger(String) - Constructor for class net.spy.memcached.compat.log.SunLogger
Get an instance of SunLogger.
SUPPORT_ACK - net.spy.memcached.tapmessage.TapRequestFlag
Tap support acknowledgment flag definition.
supportAck() - Method in class net.spy.memcached.tapmessage.MessageBuilder
 
SyncThread<T> - Class in net.spy.memcached.compat
Thread that invokes a callable multiple times concurrently.
SyncThread(CyclicBarrier, Callable<T>) - Constructor for class net.spy.memcached.compat.SyncThread
Get a SyncThread that will call the given callable when the given barrier allows it past.

T

TAKEOVER_VBUCKETS - net.spy.memcached.tapmessage.TapRequestFlag
Tap take over vBuckets flag definition.
takeoverVbuckets(short[]) - Method in class net.spy.memcached.tapmessage.MessageBuilder
 
TAP_ACK - net.spy.memcached.tapmessage.TapResponseFlag
This message requires acknowledgment.
TAP_FLAG_NETWORK_BYTE_ORDER - net.spy.memcached.tapmessage.TapResponseFlag
This message is sent correctly in network byte order.
TAP_NO_VALUE - net.spy.memcached.tapmessage.TapResponseFlag
This message doesn't contain a value.
tapAck(TapConnectionProvider, MemcachedNode, TapOpcode, int, OperationCallback) - Method in class net.spy.memcached.TapClient
 
tapAck(TapOpcode, int, OperationCallback) - Method in interface net.spy.memcached.OperationFactory
Sends a tap ack message to the server.
tapAck(TapOpcode, int, OperationCallback) - Method in class net.spy.memcached.protocol.ascii.AsciiOperationFactory
 
tapAck(TapOpcode, int, OperationCallback) - Method in class net.spy.memcached.protocol.binary.BinaryOperationFactory
 
TapAck - Class in net.spy.memcached.tapmessage
An acknowledgment message used to tell the server we have received a series of messages.
TapAck(TapConnectionProvider, MemcachedNode, TapOpcode, int, OperationCallback) - Constructor for class net.spy.memcached.tapmessage.TapAck
 
TapAckOperationImpl - Class in net.spy.memcached.protocol.binary
Implementation of a tap ACK operation.
TapAckOperationImpl(TapOpcode, int, OperationCallback) - Constructor for class net.spy.memcached.protocol.binary.TapAckOperationImpl
 
tapBackfill(String, long, OperationCallback) - Method in interface net.spy.memcached.OperationFactory
Creates a tap backfill stream.
tapBackfill(String, long, OperationCallback) - Method in class net.spy.memcached.protocol.ascii.AsciiOperationFactory
 
tapBackfill(String, long, OperationCallback) - Method in class net.spy.memcached.protocol.binary.BinaryOperationFactory
 
TapBackfillOperationImpl - Class in net.spy.memcached.protocol.binary
Implementation of a tap backfill operation.
TapBackfillOperationImpl(String, long, OperationCallback) - Constructor for class net.spy.memcached.protocol.binary.TapBackfillOperationImpl
 
TapClient - Class in net.spy.memcached
A tap client for memcached.
TapClient(InetSocketAddress...) - Constructor for class net.spy.memcached.TapClient
Creates a tap client against the specified servers.
TapClient(List<InetSocketAddress>) - Constructor for class net.spy.memcached.TapClient
Creates a tap client against the specified servers.
TapConnectionProvider - Class in net.spy.memcached
A TapConnectionProvider.
TapConnectionProvider(InetSocketAddress...) - Constructor for class net.spy.memcached.TapConnectionProvider
Get a tap client operating on the specified memcached locations.
TapConnectionProvider(List<InetSocketAddress>) - Constructor for class net.spy.memcached.TapConnectionProvider
Get a tap client operating on the specified memcached locations.
TapConnectionProvider(ConnectionFactory, List<InetSocketAddress>) - Constructor for class net.spy.memcached.TapConnectionProvider
Get a tap client operating on the specified memcached locations.
tapCustom(String, RequestMessage) - Method in class net.spy.memcached.TapClient
Allows the user to specify a custom tap message.
tapCustom(String, RequestMessage, OperationCallback) - Method in interface net.spy.memcached.OperationFactory
Creates a custom tap stream.
tapCustom(String, RequestMessage, OperationCallback) - Method in class net.spy.memcached.protocol.ascii.AsciiOperationFactory
 
tapCustom(String, RequestMessage, OperationCallback) - Method in class net.spy.memcached.protocol.binary.BinaryOperationFactory
 
TapCustomOperationImpl - Class in net.spy.memcached.protocol.binary
Implementation of a custom tap operation.
TapCustomOperationImpl(String, RequestMessage, OperationCallback) - Constructor for class net.spy.memcached.protocol.binary.TapCustomOperationImpl
 
tapDump(String) - Method in class net.spy.memcached.TapClient
Specifies a tap stream that will take a snapshot of items in memcached and send them through a tap stream.
tapDump(String, OperationCallback) - Method in interface net.spy.memcached.OperationFactory
Sends a tap dump message to the server.
tapDump(String, OperationCallback) - Method in class net.spy.memcached.protocol.ascii.AsciiOperationFactory
 
tapDump(String, OperationCallback) - Method in class net.spy.memcached.protocol.binary.BinaryOperationFactory
 
TapDumpOperationImpl - Class in net.spy.memcached.protocol.binary
Implementation of a tap dump operation.
TapDumpOperationImpl(String, OperationCallback) - Constructor for class net.spy.memcached.protocol.binary.TapDumpOperationImpl
 
TapMagic - Enum in net.spy.memcached.tapmessage
The Magic enum contains a list all of the different magic that can be passed in a tap message in the flag field.
TapMagic(byte) - Constructor for enum net.spy.memcached.tapmessage.TapMagic
Defines the magic value.
TapOpcode - Enum in net.spy.memcached.tapmessage
The Opcode enum contains a list all of the different opcodes that can be passed in a tap message in the flag field.
TapOpcode(byte) - Constructor for enum net.spy.memcached.tapmessage.TapOpcode
Defines the magic value.
TapOperation - Interface in net.spy.memcached.ops
Tap operation.
TapOperation.Callback - Interface in net.spy.memcached.ops
Operation callback for the tap dump request.
TapOperationImpl - Class in net.spy.memcached.protocol.binary
Abstract implementation of a tap operation.
TapOperationImpl(OperationCallback) - Constructor for class net.spy.memcached.protocol.binary.TapOperationImpl
 
TapRequestFlag - Enum in net.spy.memcached.tapmessage
The Flag enum contains a list all of the different flags that can be passed in a tap message in the flag field.
TapRequestFlag(int) - Constructor for enum net.spy.memcached.tapmessage.TapRequestFlag
Defines the flag value.
TapResponseFlag - Enum in net.spy.memcached.tapmessage
The Flag enum contains a list all of the different flags that can be passed in a tap message in the flag field.
TapResponseFlag(short) - Constructor for enum net.spy.memcached.tapmessage.TapResponseFlag
Defines the flag value.
TapStream - Class in net.spy.memcached.tapmessage
Holds multiple operations put together for a tap stream.
TapStream() - Constructor for class net.spy.memcached.tapmessage.TapStream
Creates a new TapStream which will be used by a TapClient to handle incoming TAP operations.
Task(Callable<T>) - Constructor for class net.spy.memcached.transcoders.TranscodeService.Task
 
TCPMemcachedNodeImpl - Class in net.spy.memcached.protocol
Represents a node with the memcached cluster, along with buffering and operation queues.
TCPMemcachedNodeImpl(SocketAddress, SocketChannel, int, BlockingQueue<Operation>, BlockingQueue<Operation>, BlockingQueue<Operation>, long, boolean, long, long, ConnectionFactory) - Constructor for class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
tcService - Variable in class net.spy.memcached.MemcachedClient
 
tcService - Variable in class net.spy.memcached.TapConnectionProvider
 
terminalOpaque - Variable in class net.spy.memcached.protocol.binary.MultiGetOperationImpl
 
terminalOpaque - Variable in class net.spy.memcached.protocol.binary.OptimizedSetImpl
 
TEXT - net.spy.memcached.ConnectionFactoryBuilder.Protocol
Use the text (ascii) protocol.
threadNumber - Variable in class net.spy.memcached.internal.BasicThreadFactory
 
THREE - net.spy.memcached.PersistTo
Persist to at least three nodes including Master.
THREE - net.spy.memcached.ReplicateTo
Replicate to at least three nodes.
throwable - Variable in class net.spy.memcached.compat.SyncThread
 
TIMED_OUT - Static variable in class net.spy.memcached.protocol.BaseOperationImpl
 
timedout - Variable in class net.spy.memcached.protocol.BaseOperationImpl
 
TIMEDOUT - net.spy.memcached.ops.StatusCode
 
TimedOutOperationStatus - Class in net.spy.memcached.ops
Operation status indicating an operation was timed out.
TimedOutOperationStatus() - Constructor for class net.spy.memcached.ops.TimedOutOperationStatus
 
timedOutUnsent - Variable in class net.spy.memcached.protocol.BaseOperationImpl
 
timeout - Variable in class net.spy.memcached.internal.BulkGetFuture
 
timeout - Variable in class net.spy.memcached.internal.OperationFuture
 
timeOut() - Method in interface net.spy.memcached.ops.Operation
Mark this operation as one which has exceeded its timeout value.
timeOut() - Method in class net.spy.memcached.protocol.BaseOperationImpl
 
timeoutExceptionThreshold - Variable in class net.spy.memcached.ConnectionFactoryBuilder
 
timeoutExceptionThreshold - Variable in class net.spy.memcached.MemcachedConnection
The threshold for timeout exceptions.
toString() - Method in class net.spy.memcached.CachedData
 
toString() - Method in class net.spy.memcached.CASValue
 
toString() - Method in enum net.spy.memcached.compat.log.Level
Get a string representation of this level.
toString() - Method in class net.spy.memcached.DefaultConnectionFactory
 
toString() - Method in class net.spy.memcached.MemcachedClient
 
toString() - Method in class net.spy.memcached.MemcachedConnection
 
toString() - Method in class net.spy.memcached.MemcachedNodeROImpl
 
toString() - Method in exception net.spy.memcached.ops.OperationException
 
toString() - Method in class net.spy.memcached.ops.OperationStatus
 
toString() - Method in class net.spy.memcached.protocol.ascii.BaseGetOpImpl
 
toString() - Method in class net.spy.memcached.protocol.ascii.BaseStoreOperationImpl
 
toString() - Method in class net.spy.memcached.protocol.ascii.CASOperationImpl
 
toString() - Method in class net.spy.memcached.protocol.ascii.DeleteOperationImpl
 
toString() - Method in class net.spy.memcached.protocol.ascii.FlushOperationImpl
 
toString() - Method in class net.spy.memcached.protocol.ascii.MutatorOperationImpl
 
toString() - Method in class net.spy.memcached.protocol.ascii.StatsOperationImpl
 
toString() - Method in class net.spy.memcached.protocol.ascii.TouchOperationImpl
 
toString() - Method in class net.spy.memcached.protocol.ascii.UnlockOperationImpl
 
toString() - Method in class net.spy.memcached.protocol.ascii.VersionOperationImpl
 
toString() - Method in class net.spy.memcached.protocol.binary.ConcatenationOperationImpl
 
toString() - Method in class net.spy.memcached.protocol.binary.DeleteOperationImpl
 
toString() - Method in class net.spy.memcached.protocol.binary.FlushOperationImpl
 
toString() - Method in class net.spy.memcached.protocol.binary.GetAndTouchOperationImpl
 
toString() - Method in class net.spy.memcached.protocol.binary.GetlOperationImpl
 
toString() - Method in class net.spy.memcached.protocol.binary.MultiKeyOperationImpl
 
toString() - Method in class net.spy.memcached.protocol.binary.MutatorOperationImpl
 
toString() - Method in class net.spy.memcached.protocol.binary.ObserveOperationImpl
 
toString() - Method in class net.spy.memcached.protocol.binary.OperationImpl
 
toString() - Method in class net.spy.memcached.protocol.binary.SASLAuthOperationImpl
 
toString() - Method in class net.spy.memcached.protocol.binary.SASLBaseOperationImpl
 
toString() - Method in class net.spy.memcached.protocol.binary.SASLMechsOperationImpl
 
toString() - Method in class net.spy.memcached.protocol.binary.SASLStepOperationImpl
 
toString() - Method in class net.spy.memcached.protocol.binary.SingleKeyOperationImpl
 
toString() - Method in class net.spy.memcached.protocol.binary.StoreOperationImpl
 
toString() - Method in class net.spy.memcached.protocol.binary.TapAckOperationImpl
 
toString() - Method in class net.spy.memcached.protocol.binary.TapBackfillOperationImpl
 
toString() - Method in class net.spy.memcached.protocol.binary.TapCustomOperationImpl
 
toString() - Method in class net.spy.memcached.protocol.binary.TapDumpOperationImpl
 
toString() - Method in class net.spy.memcached.protocol.binary.TouchOperationImpl
 
toString() - Method in class net.spy.memcached.protocol.binary.UnlockOperationImpl
 
toString() - Method in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
toString() - Method in class net.spy.memcached.tapmessage.ResponseMessage
 
totalbody - Variable in class net.spy.memcached.tapmessage.BaseMessage
 
TOTALBODY_OFFSET - Static variable in class net.spy.memcached.tapmessage.BaseMessage
 
touch(String, int) - Method in class net.spy.memcached.MemcachedClient
Touch the given key to reset its expiration time with the default transcoder.
touch(String, int) - Method in interface net.spy.memcached.MemcachedClientIF
 
touch(String, int, OperationCallback) - Method in interface net.spy.memcached.OperationFactory
Resets a keys expiration time.
touch(String, int, OperationCallback) - Method in class net.spy.memcached.protocol.ascii.AsciiOperationFactory
 
touch(String, int, OperationCallback) - Method in class net.spy.memcached.protocol.binary.BinaryOperationFactory
 
touch(String, int, Transcoder<T>) - Method in class net.spy.memcached.MemcachedClient
Touch the given key to reset its expiration time.
touch(String, int, Transcoder<T>) - Method in interface net.spy.memcached.MemcachedClientIF
 
TouchOperation - Interface in net.spy.memcached.ops
Touch operation marker.
TouchOperationImpl - Class in net.spy.memcached.protocol.ascii
Memcached touch operation.
TouchOperationImpl - Class in net.spy.memcached.protocol.binary
Operation to reset a timeout in Membase server.
TouchOperationImpl(String, int, OperationCallback) - Constructor for class net.spy.memcached.protocol.ascii.TouchOperationImpl
 
TouchOperationImpl(String, int, OperationCallback) - Constructor for class net.spy.memcached.protocol.binary.TouchOperationImpl
 
toWrite - Variable in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
trace(Object) - Method in class net.spy.memcached.compat.log.AbstractLogger
Log a message at trace level.
trace(Object) - Method in interface net.spy.memcached.compat.log.Logger
Log a message at trace level.
trace(Object, Throwable) - Method in class net.spy.memcached.compat.log.AbstractLogger
Log a message at trace level.
trace(Object, Throwable) - Method in interface net.spy.memcached.compat.log.Logger
Log a message at trace level.
trace(String, Object...) - Method in class net.spy.memcached.compat.log.AbstractLogger
Log a formatted message at trace level.
trace(String, Object...) - Method in interface net.spy.memcached.compat.log.Logger
Log a formatted message at trace level.
TRACE - net.spy.memcached.compat.log.Level
Trace level.
transcoder - Variable in class net.spy.memcached.BaseCacheMap
 
transcoder - Variable in class net.spy.memcached.CASMutator
 
transcoder - Variable in class net.spy.memcached.ConnectionFactoryBuilder
 
transcoder - Variable in class net.spy.memcached.MemcachedClient
 
Transcoder<T> - Interface in net.spy.memcached.transcoders
Transcoder is an interface for classes that convert between byte arrays and objects for storage in the cache.
TranscoderUtils - Class in net.spy.memcached.transcoders
Utility class for transcoding Java types.
TranscoderUtils(boolean) - Constructor for class net.spy.memcached.transcoders.TranscoderUtils
Get an instance of TranscoderUtils.
TranscodeService - Class in net.spy.memcached.transcoders
Asynchronous transcoder.
TranscodeService(boolean) - Constructor for class net.spy.memcached.transcoders.TranscodeService
 
TranscodeService.Task<T> - Class in net.spy.memcached.transcoders
 
transitionState(OperationState) - Method in class net.spy.memcached.protocol.BaseOperationImpl
Transition the state of this operation to the given state.
transitionWriteItem() - Method in interface net.spy.memcached.MemcachedNode
Transition the current write item into a read state.
transitionWriteItem() - Method in class net.spy.memcached.MemcachedNodeROImpl
 
transitionWriteItem() - Method in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
ttl - Variable in class net.spy.memcached.tapmessage.ResponseMessage
 
TTL_OFFSET - Static variable in class net.spy.memcached.tapmessage.ResponseMessage
 
tu - Variable in class net.spy.memcached.transcoders.IntegerTranscoder
 
tu - Variable in class net.spy.memcached.transcoders.LongTranscoder
 
tu - Variable in class net.spy.memcached.transcoders.SerializingTranscoder
 
tu - Variable in class net.spy.memcached.transcoders.WhalinTranscoder
 
TWO - net.spy.memcached.PersistTo
Persist to at least two nodes including Master.
TWO - net.spy.memcached.ReplicateTo
Replicate to at least two nodes.
type - Variable in exception net.spy.memcached.ops.OperationException
 
type - Variable in class net.spy.memcached.protocol.ascii.BaseStoreOperationImpl
 
typical(String, String) - Static method in class net.spy.memcached.auth.AuthDescriptor
Get a typical auth descriptor for CRAM-MD5 or PLAIN auth with the given username and password.

U

UNINITIALIZED - net.spy.memcached.ObserveResponse
Response indicating the key was uninitialized.
unlock(String, long, OperationCallback) - Method in interface net.spy.memcached.OperationFactory
Create a Unlock operation.
unlock(String, long, OperationCallback) - Method in class net.spy.memcached.protocol.ascii.AsciiOperationFactory
 
unlock(String, long, OperationCallback) - Method in class net.spy.memcached.protocol.binary.BinaryOperationFactory
 
UNLOCKED - Static variable in class net.spy.memcached.protocol.ascii.UnlockOperationImpl
 
UnlockOperation - Interface in net.spy.memcached.ops
Unlock operation.
UnlockOperationImpl - Class in net.spy.memcached.protocol.ascii
Operation to delete an item from the cache.
UnlockOperationImpl - Class in net.spy.memcached.protocol.binary
 
UnlockOperationImpl(String, long, OperationCallback) - Constructor for class net.spy.memcached.protocol.ascii.UnlockOperationImpl
 
UnlockOperationImpl(String, long, OperationCallback) - Constructor for class net.spy.memcached.protocol.binary.UnlockOperationImpl
 
updateHistogram(String, int) - Method in class net.spy.memcached.metrics.DefaultMetricCollector
 
updateHistogram(String, int) - Method in interface net.spy.memcached.metrics.MetricCollector
Update the Histogram with the given amount.
updateHistogram(String, int) - Method in class net.spy.memcached.metrics.NoopMetricCollector
 
updateLocator(List<MemcachedNode>) - Method in class net.spy.memcached.ArrayModNodeLocator
 
updateLocator(List<MemcachedNode>) - Method in class net.spy.memcached.KetamaNodeLocator
 
updateLocator(List<MemcachedNode>) - Method in interface net.spy.memcached.NodeLocator
Update locator status.
useNagle - Variable in class net.spy.memcached.ConnectionFactoryBuilder
 
useNagleAlgorithm() - Method in interface net.spy.memcached.ConnectionFactory
If true, the nagle algorithm will be used on connected sockets.
useNagleAlgorithm() - Method in class net.spy.memcached.DefaultConnectionFactory
 
username - Variable in class net.spy.memcached.auth.PlainCallbackHandler
 
Util - Class in net.spy.memcached.tapmessage
The Util class provides utility functions for converting portions of byte arrays to values and putting values into byte arrays.
Util() - Constructor for class net.spy.memcached.tapmessage.Util
 

V

validateAlgorithm(HashAlgorithm) - Static method in class net.spy.memcached.HashAlgorithmRegistry
Validates algorithm instance.
validateKey(String, boolean) - Static method in class net.spy.memcached.util.StringUtils
Check if a given key is valid to transmit.
validateName(String) - Static method in class net.spy.memcached.HashAlgorithmRegistry
Validates name of the algorithm.
value - Variable in class net.spy.memcached.CASValue
 
value - Variable in class net.spy.memcached.internal.ImmediateFuture
 
value - Variable in enum net.spy.memcached.ObserveResponse
 
value - Variable in enum net.spy.memcached.PersistTo
 
value - Variable in enum net.spy.memcached.ReplicateTo
 
value - Variable in class net.spy.memcached.tapmessage.ResponseMessage
 
valueOf(byte) - Static method in enum net.spy.memcached.ObserveResponse
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.spy.memcached.CASResponse
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.spy.memcached.compat.log.Level
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.spy.memcached.ConnectionFactoryBuilder.Locator
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.spy.memcached.ConnectionFactoryBuilder.Protocol
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.spy.memcached.DefaultHashAlgorithm
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.spy.memcached.FailureMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.spy.memcached.KetamaNodeKeyFormatter.Format
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.spy.memcached.metrics.MetricType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.spy.memcached.ObserveResponse
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.spy.memcached.ops.ConcatenationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.spy.memcached.ops.Mutator
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.spy.memcached.ops.OperationErrorType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.spy.memcached.ops.OperationState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.spy.memcached.ops.StatusCode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.spy.memcached.ops.StoreType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.spy.memcached.PersistTo
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.spy.memcached.protocol.ascii.OperationReadType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.spy.memcached.ReplicateTo
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.spy.memcached.tapmessage.TapMagic
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.spy.memcached.tapmessage.TapOpcode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.spy.memcached.tapmessage.TapRequestFlag
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.spy.memcached.tapmessage.TapResponseFlag
Returns the enum constant of this type with the specified name.
values() - Method in class net.spy.memcached.BaseCacheMap
 
values() - Static method in enum net.spy.memcached.CASResponse
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.spy.memcached.compat.log.Level
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.spy.memcached.ConnectionFactoryBuilder.Locator
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.spy.memcached.ConnectionFactoryBuilder.Protocol
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.spy.memcached.DefaultHashAlgorithm
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.spy.memcached.FailureMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.spy.memcached.KetamaNodeKeyFormatter.Format
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.spy.memcached.metrics.MetricType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.spy.memcached.ObserveResponse
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.spy.memcached.ops.ConcatenationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.spy.memcached.ops.Mutator
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.spy.memcached.ops.OperationErrorType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.spy.memcached.ops.OperationState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.spy.memcached.ops.StatusCode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.spy.memcached.ops.StoreType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.spy.memcached.PersistTo
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.spy.memcached.protocol.ascii.OperationReadType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.spy.memcached.ReplicateTo
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.spy.memcached.tapmessage.TapMagic
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.spy.memcached.tapmessage.TapOpcode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.spy.memcached.tapmessage.TapRequestFlag
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum net.spy.memcached.tapmessage.TapResponseFlag
Returns an array containing the constants of this enum type, in the order they are declared.
valueToFieldOffest(byte[], int, int, long) - Static method in class net.spy.memcached.tapmessage.Util
Puts a value into a specific location in a byte buffer.
vblist - Variable in class net.spy.memcached.tapmessage.RequestMessage
 
vbmap - Variable in class net.spy.memcached.protocol.binary.MultiKeyOperationImpl
 
vbucket - Variable in class net.spy.memcached.protocol.binary.OperationImpl
 
vbucket - Variable in class net.spy.memcached.tapmessage.BaseMessage
 
VBUCKET - net.spy.memcached.ConnectionFactoryBuilder.Locator
VBucket support.
VBUCKET_OFFSET - Static variable in class net.spy.memcached.tapmessage.BaseMessage
 
VBucketAware - Interface in net.spy.memcached.ops
Operations that depend on a VBucket number being sent to the server are required to implement this interface.
vBucketCheckpoints - Variable in class net.spy.memcached.tapmessage.RequestMessage
 
VBUCKETSET - net.spy.memcached.tapmessage.TapOpcode
Defines a vBucket set message to set the state of a vBucket in the consumer.
vbucketstate - Variable in class net.spy.memcached.tapmessage.ResponseMessage
 
verifyAliveOnConnect - Variable in class net.spy.memcached.MemcachedConnection
If set to true, a proper check after finish connecting is done to see if the node is not responding but really alive.
version(OperationCallback) - Method in interface net.spy.memcached.OperationFactory
Create a new version operation.
version(OperationCallback) - Method in class net.spy.memcached.protocol.ascii.AsciiOperationFactory
 
version(OperationCallback) - Method in class net.spy.memcached.protocol.binary.BinaryOperationFactory
 
VersionOperation - Interface in net.spy.memcached.ops
Version operation.
VersionOperationImpl - Class in net.spy.memcached.protocol.ascii
Operation to request the version of a memcached server.
VersionOperationImpl - Class in net.spy.memcached.protocol.binary
 
VersionOperationImpl(OperationCallback) - Constructor for class net.spy.memcached.protocol.ascii.VersionOperationImpl
 
VersionOperationImpl(OperationCallback) - Constructor for class net.spy.memcached.protocol.binary.VersionOperationImpl
 

W

waitForQueues(long, TimeUnit) - Method in class net.spy.memcached.MemcachedClient
Wait for the queues to die down.
waitForQueues(long, TimeUnit) - Method in interface net.spy.memcached.MemcachedClientIF
 
waitForQueues(long, TimeUnit) - Method in class net.spy.memcached.TapConnectionProvider
Wait for the queues to die down.
wakeupDelay - Variable in class net.spy.memcached.MemcachedConnection
The selector wakeup delay, defaults to 1000ms.
warn(Object) - Method in class net.spy.memcached.compat.log.AbstractLogger
Log a message at warning level.
warn(Object) - Method in interface net.spy.memcached.compat.log.Logger
Log a message at warning level.
warn(Object, Throwable) - Method in class net.spy.memcached.compat.log.AbstractLogger
Log a message at warning level.
warn(Object, Throwable) - Method in interface net.spy.memcached.compat.log.Logger
Log a message at warning level.
warn(String, Object...) - Method in class net.spy.memcached.compat.log.AbstractLogger
Log a formatted message at debug level.
warn(String, Object...) - Method in interface net.spy.memcached.compat.log.Logger
Log a formatted message at debug level.
WARN - net.spy.memcached.compat.log.Level
Warning level.
wasCancelled() - Method in class net.spy.memcached.protocol.ascii.BaseGetOpImpl
 
wasCancelled() - Method in class net.spy.memcached.protocol.ascii.BaseStoreOperationImpl
 
wasCancelled() - Method in class net.spy.memcached.protocol.ascii.MutatorOperationImpl
 
wasCancelled() - Method in class net.spy.memcached.protocol.ascii.StatsOperationImpl
 
wasCancelled() - Method in class net.spy.memcached.protocol.BaseOperationImpl
This is called on each subclass whenever an operation was cancelled.
watch(String, Future<Boolean>) - Method in class net.spy.memcached.util.CacheLoader
 
wbuf - Variable in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
weights - Variable in class net.spy.memcached.KetamaConnectionFactory
 
weights - Variable in class net.spy.memcached.KetamaNodeLocator
 
WhalinTranscoder - Class in net.spy.memcached.transcoders
Transcoder that provides compatibility with Greg Whalin's memcached client.
WhalinTranscoder() - Constructor for class net.spy.memcached.transcoders.WhalinTranscoder
 
WhalinV1Transcoder - Class in net.spy.memcached.transcoders
Handles old whalin (tested with v1.6) encoding: data type is in the first byte of the value.
WhalinV1Transcoder() - Constructor for class net.spy.memcached.transcoders.WhalinV1Transcoder
 
WRITE_QUEUED - net.spy.memcached.ops.OperationState
State indicating this operation is waiting to be written to the server.
writeComplete() - Method in interface net.spy.memcached.ops.Operation
Invoked after having written all of the bytes from the supplied output buffer.
writeComplete() - Method in class net.spy.memcached.protocol.BaseOperationImpl
 
writeCompleteTimestamp - Variable in class net.spy.memcached.protocol.BaseOperationImpl
 
writeQ - Variable in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
writeQueueFactory - Variable in class net.spy.memcached.ConnectionFactoryBuilder
 
writeSome() - Method in interface net.spy.memcached.MemcachedNode
Write some bytes and return the number of bytes written.
writeSome() - Method in class net.spy.memcached.MemcachedNodeROImpl
 
writeSome() - Method in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
writing() - Method in interface net.spy.memcached.ops.Operation
Invoked when we start writing all of the bytes from this operation to the sockets write buffer.
writing() - Method in class net.spy.memcached.protocol.BaseOperationImpl
 
WRITING - net.spy.memcached.ops.OperationState
State indicating this operation is writing data to the server.

Z

ZERO - net.spy.memcached.PersistTo
Don't wait for persistence on any nodes.
ZERO - net.spy.memcached.ReplicateTo
Replicate to at least zero nodes.
A B C D E F G H I J K L M N O P Q R S T U V W Z 
All Classes All Packages