Skip navigation links
A B C D E F G H I J K L M N O P Q R S T U V W 

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(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, 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, T, Transcoder<T>) - Method in interface net.spy.memcached.MemcachedClientIF
 
add(String, int, Object) - Method in interface net.spy.memcached.MemcachedClientIF
 
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.
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(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(L) - Method in interface net.spy.memcached.internal.ListenableFuture
Add a listener to the future, which will be executed once the operation completes.
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
 
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.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
 
addOperations(Map<MemcachedNode, Operation>) - Method in class net.spy.memcached.MemcachedConnection
Enqueue the given list of operations on each handling node.
AddrUtil - Class in net.spy.memcached
Convenience utilities for simplifying common address parsing.
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.
append(long, String, Object) - Method in class net.spy.memcached.MemcachedClient
Append to an existing value in the cache.
append(String, Object) - Method in class net.spy.memcached.MemcachedClient
Append to an existing value in the cache.
append(long, 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 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(String, Object) - Method in interface net.spy.memcached.MemcachedClientIF
 
append(long, String, T, Transcoder<T>) - Method in interface net.spy.memcached.MemcachedClientIF
 
append(String, T, Transcoder<T>) - Method in interface net.spy.memcached.MemcachedClientIF
 
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.
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, T, Transcoder<T>) - Method in class net.spy.memcached.MemcachedClient
Asynchronous CAS operation.
asyncCAS(String, long, int, T, Transcoder<T>) - Method in class net.spy.memcached.MemcachedClient
Asynchronous CAS operation.
asyncCAS(String, long, Object) - Method in class net.spy.memcached.MemcachedClient
Asynchronous CAS operation using the default transcoder.
asyncCAS(String, long, int, Object) - Method in class net.spy.memcached.MemcachedClient
Asynchronous CAS operation using the default transcoder with expiration.
asyncCAS(String, long, T, Transcoder<T>) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncCAS(String, long, Object) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncCAS(String, long, int, Object) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncCAS(String, long, int, T, Transcoder<T>) - Method in interface net.spy.memcached.MemcachedClientIF
 
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, long) - Method in class net.spy.memcached.MemcachedClient
Asynchronous decrement.
asyncDecr(String, int) - Method in class net.spy.memcached.MemcachedClient
Asynchronous decrement.
asyncDecr(String, long, long, int) - Method in class net.spy.memcached.MemcachedClient
Asynchronous decrement.
asyncDecr(String, int, long, int) - Method in class net.spy.memcached.MemcachedClient
Asynchronous decrement.
asyncDecr(String, long, long) - Method in class net.spy.memcached.MemcachedClient
Asynchronous decrement.
asyncDecr(String, int, long) - Method in class net.spy.memcached.MemcachedClient
Asynchronous decrement.
asyncDecr(String, long) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncDecr(String, int) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncDecr(String, long, long, int) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncDecr(String, int, long, int) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncDecr(String, long, long) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncDecr(String, int, long) - 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) - Method in class net.spy.memcached.MemcachedClient
Get the given key asynchronously and decode with the default transcoder.
asyncGet(String, Transcoder<T>) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncGet(String) - 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, Transcoder<T>) - 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 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(Collection<String>, Iterator<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 class net.spy.memcached.MemcachedClient
Asynchronously get a bunch of objects from the cache.
asyncGetBulk(Collection<String>, Transcoder<T>) - Method in class net.spy.memcached.MemcachedClient
Asynchronously get a bunch of objects from the cache.
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(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(Transcoder<T>, String...) - Method in class net.spy.memcached.MemcachedClient
Varargs wrapper for asynchronous bulk gets.
asyncGetBulk(String...) - Method in class net.spy.memcached.MemcachedClient
Varargs wrapper for asynchronous bulk gets with the default transcoder.
asyncGetBulk(Iterator<String>, Iterator<Transcoder<T>>) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncGetBulk(Collection<String>, Iterator<Transcoder<T>>) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncGetBulk(Iterator<String>, Transcoder<T>) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncGetBulk(Collection<String>, Transcoder<T>) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncGetBulk(Iterator<String>) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncGetBulk(Collection<String>) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncGetBulk(Transcoder<T>, String...) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncGetBulk(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) - Method in class net.spy.memcached.MemcachedClient
Gets (with CAS support) the given key asynchronously and decode using the default transcoder.
asyncGets(String, Transcoder<T>) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncGets(String) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncIncr(String, long) - Method in class net.spy.memcached.MemcachedClient
Asychronous increment.
asyncIncr(String, int) - Method in class net.spy.memcached.MemcachedClient
Asychronous increment.
asyncIncr(String, long, long, int) - Method in class net.spy.memcached.MemcachedClient
Asychronous increment.
asyncIncr(String, int, long, int) - Method in class net.spy.memcached.MemcachedClient
Asychronous increment.
asyncIncr(String, long, long) - Method in class net.spy.memcached.MemcachedClient
Asychronous increment.
asyncIncr(String, int, long) - Method in class net.spy.memcached.MemcachedClient
Asychronous increment.
asyncIncr(String, long) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncIncr(String, int) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncIncr(String, long, long, int) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncIncr(String, int, long, int) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncIncr(String, long, long) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncIncr(String, int, long) - Method in interface net.spy.memcached.MemcachedClientIF
 
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.
authComplete() - Method in interface net.spy.memcached.MemcachedNode
Let the node know that auth is complete.
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 - 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.
authDescriptor - Variable in class net.spy.memcached.ConnectionFactoryBuilder
 
authDescriptor - Variable in class net.spy.memcached.MemcachedClient
 
authDescriptor - Variable in class net.spy.memcached.TapConnectionProvider
 
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
 

B

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.
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.
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
 
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
 
broadcastOp(BroadcastOpFactory) - Method in class net.spy.memcached.MemcachedClient
 
broadcastOp(BroadcastOpFactory, Collection<MemcachedNode>) - Method in class net.spy.memcached.MemcachedClient
 
broadcastOp(BroadcastOpFactory) - Method in interface net.spy.memcached.MemcachedClientIF
 
broadcastOp(BroadcastOpFactory, Collection<MemcachedNode>) - Method in interface net.spy.memcached.MemcachedClientIF
 
broadcastOp(BroadcastOpFactory) - 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.
build() - Method in class net.spy.memcached.ConnectionFactoryBuilder
Get the ConnectionFactory set up with the provided parameters.
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
 
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
 
bytes() - Method in class net.spy.memcached.protocol.binary.OptimizedSetImpl
 

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.
callback - Variable in class net.spy.memcached.protocol.BaseOperationImpl
 
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() - 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.
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
 
cas(String, T, int, CASMutation<T>) - Method in class net.spy.memcached.CASMutator
CAS a new value in for a key.
cas(String, long, T, Transcoder<T>) - Method in class net.spy.memcached.MemcachedClient
Perform a synchronous CAS operation.
cas(String, long, int, T, Transcoder<T>) - Method in class net.spy.memcached.MemcachedClient
Perform a synchronous CAS operation.
cas(String, long, Object) - Method in class net.spy.memcached.MemcachedClient
Perform a synchronous CAS operation with the default transcoder.
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, T, Transcoder<T>) - Method in interface net.spy.memcached.MemcachedClientIF
 
cas(String, long, Object) - Method in interface net.spy.memcached.MemcachedClientIF
 
cas(String, long, int, Object) - Method in interface net.spy.memcached.MemcachedClientIF
 
cas(String, long, T, Transcoder<T>) - Method in interface net.spy.memcached.MemcachedClientIF
 
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 - 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>, int) - Constructor for class net.spy.memcached.CASMutator
Construct a CASMutator that uses the given client.
CASMutator(MemcachedClientIF, Transcoder<T>) - 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.
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 - Enum in net.spy.memcached
Response codes for a CAS operation.
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
 
cbh - Variable in class net.spy.memcached.protocol.binary.SASLBaseOperationImpl
 
challenge - Variable in class net.spy.memcached.protocol.binary.SASLBaseOperationImpl
 
charset - Variable in class net.spy.memcached.transcoders.BaseSerializingTranscoder
 
CheckedOperationTimeoutException - Exception in net.spy.memcached.internal
Timeout exception that tracks the original operation.
CheckedOperationTimeoutException(String, Operation) - Constructor for exception net.spy.memcached.internal.CheckedOperationTimeoutException
Construct a CheckedOperationTimeoutException with the given message and operation.
CheckedOperationTimeoutException(String, Collection<Operation>) - Constructor for exception net.spy.memcached.internal.CheckedOperationTimeoutException
 
checkState() - Method in class net.spy.memcached.MemcachedConnection
Check to see if this connection is shutting down.
clear() - Method in class net.spy.memcached.BaseCacheMap
 
clone(KeyedOperation) - Method in interface net.spy.memcached.OperationFactory
Clone an operation.
clone(KeyedOperation) - Method in class net.spy.memcached.ops.BaseOperationFactory
 
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
 
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.
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.GetCallbackWrapper
 
complete() - Method in class net.spy.memcached.protocol.ProxyCallback
 
completedRead() - Method in interface net.spy.memcached.MemcachedNode
Notify node of successful read.
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.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.
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(ConcatenationType, String, byte[], OperationCallback) - Constructor for class net.spy.memcached.protocol.ascii.ConcatenationOperationImpl
 
ConcatenationType - Enum in net.spy.memcached.ops
Types of concatenation operations.
conn - Variable in class net.spy.memcached.TapConnectionProvider
 
connected() - Method in interface net.spy.memcached.MemcachedNode
Notify this node that it has reconnected.
connected() - Method 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 - 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
 
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.
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.protocol.TCPMemcachedNodeImpl
 
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
 
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
 

D

datatype - Variable in class net.spy.memcached.tapmessage.BaseMessage
 
debug(Object, Throwable) - Method in class net.spy.memcached.compat.log.AbstractLogger
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(Object) - 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(Object) - Method in interface net.spy.memcached.compat.log.Logger
Log a message at debug level.
debug(String, Object...) - Method in interface net.spy.memcached.compat.log.Logger
Log a formatted message at debug level.
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(Transcoder<T>, CachedData) - Method in class net.spy.memcached.transcoders.TranscodeService
Perform a decode.
decode(CachedData) - Method in class net.spy.memcached.transcoders.WhalinTranscoder
 
decode(CachedData) - Method in class net.spy.memcached.transcoders.WhalinV1Transcoder
 
decodeBoolean(byte[]) - Method in class net.spy.memcached.transcoders.TranscoderUtils
 
decodeBoolean(byte[]) - Method in class net.spy.memcached.transcoders.WhalinTranscoder
 
decodeByte(byte[]) - Method in class net.spy.memcached.transcoders.TranscoderUtils
 
decodeCharacter(byte[]) - Method in class net.spy.memcached.transcoders.WhalinTranscoder
 
decodeInt(byte[], int) - Method in class net.spy.memcached.tapmessage.BaseMessage
 
decodeInt(byte[]) - Method in class net.spy.memcached.transcoders.TranscoderUtils
 
decodeIntHostOrder(byte[], int) - Method in class net.spy.memcached.tapmessage.BaseMessage
 
decodeLong(byte[], int) - Method in class net.spy.memcached.tapmessage.BaseMessage
 
decodeLong(byte[]) - Method in class net.spy.memcached.transcoders.TranscoderUtils
 
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.GetsOperationImpl
 
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.TouchOperationImpl
 
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.
decompress(byte[]) - Method in class net.spy.memcached.transcoders.BaseSerializingTranscoder
Decompress the given array of bytes.
decr(String, long) - Method in class net.spy.memcached.MemcachedClient
Decrement the given key by the given value.
decr(String, int) - Method in class net.spy.memcached.MemcachedClient
Decrement the given key by the given value.
decr(String, long, long, int) - Method in class net.spy.memcached.MemcachedClient
Decrement the given counter, returning the new value.
decr(String, int, long, int) - Method in class net.spy.memcached.MemcachedClient
Decrement the given counter, returning the new value.
decr(String, long, long) - Method in class net.spy.memcached.MemcachedClient
Decrement the given counter, returning the new value.
decr(String, int, long) - Method in class net.spy.memcached.MemcachedClient
Decrement the given counter, returning the new value.
decr(String, long) - Method in interface net.spy.memcached.MemcachedClientIF
 
decr(String, int) - Method in interface net.spy.memcached.MemcachedClientIF
 
decr(String, long, long, int) - Method in interface net.spy.memcached.MemcachedClientIF
 
decr(String, int, long, int) - Method in interface net.spy.memcached.MemcachedClientIF
 
decr(String, long, long) - Method in interface net.spy.memcached.MemcachedClientIF
 
decr(String, int, long) - Method in interface net.spy.memcached.MemcachedClientIF
 
decrementCounter(String) - Method in class net.spy.memcached.metrics.AbstractMetricCollector
 
decrementCounter(String, int) - Method in class net.spy.memcached.metrics.DefaultMetricCollector
 
decrementCounter(String) - Method in interface net.spy.memcached.metrics.MetricCollector
Decrement a Counter by one.
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
 
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_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.
DefaultConnectionFactory - Class in net.spy.memcached
Default implementation of ConnectionFactory.
DefaultConnectionFactory(int, int, HashAlgorithm) - Constructor for class net.spy.memcached.DefaultConnectionFactory
Construct a DefaultConnectionFactory with the given 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() - Constructor for class net.spy.memcached.DefaultConnectionFactory
Create a DefaultConnectionFactory with the default parameters.
DefaultHashAlgorithm - Enum in net.spy.memcached
Known hashing algorithms for locating a server for a key.
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
 
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
delete(String, int) - Method in class net.spy.memcached.MemcachedClient
Deprecated.
Hold values are no longer honored.
delete(String) - Method in class net.spy.memcached.MemcachedClient
Delete the given key from the cache.
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) - Method in interface net.spy.memcached.MemcachedClientIF
 
delete(String, long) - Method in interface net.spy.memcached.MemcachedClientIF
 
delete(String, DeleteOperation.Callback) - Method in interface net.spy.memcached.OperationFactory
Create a deletion operation.
delete(String, long, DeleteOperation.Callback) - Method in interface net.spy.memcached.OperationFactory
Create a deletion operation with CAS.
delete(String, DeleteOperation.Callback) - Method in class net.spy.memcached.protocol.ascii.AsciiOperationFactory
 
delete(String, long, 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(String, long, DeleteOperation.Callback) - Method in class net.spy.memcached.protocol.binary.BinaryOperationFactory
 
DeleteOperation - Interface in net.spy.memcached.ops
Deletion operation.
DeleteOperation.Callback - Interface in net.spy.memcached.ops
Delete operation callback.
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.protocol.TCPMemcachedNodeImpl
 
doBackfill(long) - Method in class net.spy.memcached.tapmessage.MessageBuilder
 
doDump() - Method in class net.spy.memcached.tapmessage.MessageBuilder
 
DUMMY_OPCODE - Static variable in class net.spy.memcached.protocol.binary.OperationImpl
 

E

EMPTY_BYTES - Static variable in class net.spy.memcached.protocol.binary.OperationImpl
 
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(T) - Method in interface net.spy.memcached.transcoders.Transcoder
Encode the given object for storage.
encode(Object) - Method in class net.spy.memcached.transcoders.WhalinTranscoder
 
encode(Object) - Method in class net.spy.memcached.transcoders.WhalinV1Transcoder
 
encodeBoolean(boolean) - Method in class net.spy.memcached.transcoders.TranscoderUtils
 
encodeBoolean(boolean) - Method in class net.spy.memcached.transcoders.WhalinTranscoder
 
encodeByte(byte) - Method in class net.spy.memcached.transcoders.TranscoderUtils
 
encodeInt(int) - Method in class net.spy.memcached.transcoders.TranscoderUtils
 
encodeLong(long) - Method in class net.spy.memcached.transcoders.TranscoderUtils
 
encodeNum(long, int) - Method in class net.spy.memcached.transcoders.TranscoderUtils
 
encodeString(String) - Method in class net.spy.memcached.transcoders.BaseSerializingTranscoder
Encode a string into the current character set.
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 - Static variable in class net.spy.memcached.protocol.binary.OperationImpl
 
ERR_BUSY - Static variable in class net.spy.memcached.protocol.binary.OperationImpl
 
ERR_DELTA_BADVAL - Static variable in class net.spy.memcached.protocol.binary.OperationImpl
 
ERR_EXISTS - Static variable in class net.spy.memcached.protocol.binary.OperationImpl
 
ERR_INTERNAL - Static variable in class net.spy.memcached.protocol.binary.OperationImpl
 
ERR_INVAL - Static variable in class net.spy.memcached.protocol.binary.OperationImpl
 
ERR_NO_MEM - Static variable in class net.spy.memcached.protocol.binary.OperationImpl
 
ERR_NOT_FOUND - Static variable in class net.spy.memcached.protocol.binary.OperationImpl
 
ERR_NOT_MY_VBUCKET - Static variable in class net.spy.memcached.protocol.binary.OperationImpl
 
ERR_NOT_STORED - Static variable in class net.spy.memcached.protocol.binary.OperationImpl
 
ERR_NOT_SUPPORTED - Static variable in class net.spy.memcached.protocol.binary.OperationImpl
 
ERR_TEMP_FAIL - Static variable in class net.spy.memcached.protocol.binary.OperationImpl
 
ERR_UNKNOWN_COMMAND - Static variable in class net.spy.memcached.protocol.binary.OperationImpl
 
error(Object, Throwable) - Method in class net.spy.memcached.compat.log.AbstractLogger
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(Object) - 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(Object) - Method in interface net.spy.memcached.compat.log.Logger
Log a message at error level.
error(String, Object...) - Method in interface net.spy.memcached.compat.log.Logger
Log a formatted message at debug level.
errorCode - Variable in class net.spy.memcached.protocol.binary.OperationImpl
 
errorStoring(String, Exception) - Method in interface net.spy.memcached.util.CacheLoader.StorageListener
 
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.MemcachedClient
 
extralength - Variable in class net.spy.memcached.tapmessage.BaseMessage
 

F

failureMode - Variable in class net.spy.memcached.ConnectionFactoryBuilder
 
FailureMode - Enum in net.spy.memcached
Failure modes for node failures.
failureMode - Variable in class net.spy.memcached.MemcachedConnection
The configured FailureMode.
fatal(Object, Throwable) - Method in class net.spy.memcached.compat.log.AbstractLogger
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(Object) - 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(Object) - Method in interface net.spy.memcached.compat.log.Logger
Log a message at fatal level.
fatal(String, Object...) - Method in interface net.spy.memcached.compat.log.Logger
Log a formatted message at debug 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.protocol.TCPMemcachedNodeImpl
 
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
 
fixupOps() - Method in interface net.spy.memcached.MemcachedNode
Fix up the selection ops on the selection key.
fixupOps() - Method in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
flush(int) - Method in class net.spy.memcached.MemcachedClient
Flush all caches from all servers with a delay of application.
flush() - Method in class net.spy.memcached.MemcachedClient
Flush all caches from all servers immediately.
flush(int) - Method in interface net.spy.memcached.MemcachedClientIF
 
flush() - 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
 
FlushOperation - Interface in net.spy.memcached.ops
Flush operation marker.
fromAsciiLine(String) - Static method in enum net.spy.memcached.ops.StatusCode
 
fromBinaryCode(int) - Static method in enum net.spy.memcached.ops.StatusCode
 

G

GenericCompletionListener<F extends Future<?>> - Interface in net.spy.memcached.internal
A generic listener that will be notified once the future completes.
get(Object) - Method in class net.spy.memcached.BaseCacheMap
 
get() - Method in class net.spy.memcached.internal.BulkGetFuture
 
get(long, TimeUnit) - Method in class net.spy.memcached.internal.BulkGetFuture
 
get() - Method in class net.spy.memcached.internal.GetFuture
 
get(long, TimeUnit) - Method in class net.spy.memcached.internal.GetFuture
 
get() - Method in class net.spy.memcached.internal.ImmediateFuture
 
get(long, TimeUnit) - 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(long, TimeUnit) - Method in class net.spy.memcached.internal.OperationFuture
Get the results of the given operation.
get(String, Transcoder<T>) - Method in class net.spy.memcached.MemcachedClient
Get with a single key.
get(String) - Method in class net.spy.memcached.MemcachedClient
Get with a single key and decode using the default transcoder.
get(String, Transcoder<T>) - Method in interface net.spy.memcached.MemcachedClientIF
 
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(Collection<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(Collection<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(Collection<String>, GetOperation.Callback) - Method in class net.spy.memcached.protocol.binary.BinaryOperationFactory
 
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, Transcoder<T>) - Method in class net.spy.memcached.MemcachedClient
Get with a single key and reset its expiration.
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, Transcoder<T>) - 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
 
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(String, int, GetAndTouchOperation.Callback, String) - Constructor for class net.spy.memcached.protocol.ascii.GetAndTouchOperationImpl
 
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
 
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(Iterator<String>, Transcoder<T>) - Method in class net.spy.memcached.MemcachedClient
Get the values for multiple keys from the cache.
getBulk(Iterator<String>) - Method in class net.spy.memcached.MemcachedClient
Get the values for multiple keys from the cache.
getBulk(Collection<String>, Transcoder<T>) - Method in class net.spy.memcached.MemcachedClient
Get the values for multiple keys from the cache.
getBulk(Collection<String>) - Method in class net.spy.memcached.MemcachedClient
Get the values for multiple keys from the cache.
getBulk(Transcoder<T>, String...) - Method in class net.spy.memcached.MemcachedClient
Get the values for multiple keys from the cache.
getBulk(String...) - 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(Collection<String>, Transcoder<T>) - Method in interface net.spy.memcached.MemcachedClientIF
 
getBulk(Iterator<String>) - Method in interface net.spy.memcached.MemcachedClientIF
 
getBulk(Collection<String>) - Method in interface net.spy.memcached.MemcachedClientIF
 
getBulk(Transcoder<T>, String...) - Method in interface net.spy.memcached.MemcachedClientIF
 
getBulk(String...) - Method in interface net.spy.memcached.MemcachedClientIF
 
getBy() - Method in interface net.spy.memcached.ops.MutatorOperation
Get the amount we're mutating by.
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.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.ConcatenationOperationImpl
 
getChannel() - Method in interface net.spy.memcached.MemcachedNode
Get the SocketChannel for this connection.
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 interface net.spy.memcached.MemcachedNode
 
getConnection() - Method in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
getContinuousTimeout() - Method in interface net.spy.memcached.MemcachedNode
 
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.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.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.
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).
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.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
 
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.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 class net.spy.memcached.protocol.ascii.GetAndTouchOperationImpl
 
getExpiration() - Method in class net.spy.memcached.protocol.binary.GetAndTouchOperationImpl
 
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.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(int) - Static method in enum net.spy.memcached.tapmessage.TapRequestFlag
 
getFlags() - Method in enum net.spy.memcached.tapmessage.TapRequestFlag
 
getFlags(short) - Static method in enum net.spy.memcached.tapmessage.TapResponseFlag
 
getFlags() - Method in enum net.spy.memcached.tapmessage.TapResponseFlag
 
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.
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.
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.
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.util.DefaultKetamaNodeLocatorConfiguration
Returns a uniquely identifying key, suitable for hashing by the KetamaNodeLocator algorithm.
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.
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
 
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(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.
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.
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.binary
Implementation of the get and lock operation.
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
 
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
 
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.
getNode() - Method in class net.spy.memcached.tapmessage.TapAck
 
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
 
getObject() - Method in class net.spy.memcached.spring.MemcachedClientFactoryBean
 
getObjectType() - Method in class net.spy.memcached.spring.MemcachedClientFactoryBean
 
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
 
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
 
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.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.
getReconnectCount() - Method in interface net.spy.memcached.MemcachedNode
Get the current reconnect count.
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, Transcoder<T>) - Method in class net.spy.memcached.MemcachedClient
Gets (with CAS support) with a single key.
gets(String) - Method in class net.spy.memcached.MemcachedClient
Gets (with CAS support) with a single key using the default transcoder.
gets(String, Transcoder<T>) - Method in interface net.spy.memcached.MemcachedClientIF
 
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
 
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.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.
getSk() - Method in interface net.spy.memcached.MemcachedNode
Get the selection key from this node.
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.protocol.TCPMemcachedNodeImpl
 
getSocketAddressForNode(MemcachedNode) - Method in class net.spy.memcached.util.DefaultKetamaNodeLocatorConfiguration
Returns the socket address of a given MemcachedNode.
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.binary
Implementation of the gets operation.
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(String) - Method in class net.spy.memcached.MemcachedClient
Get a set of stats from all connections.
getStats() - Method in interface net.spy.memcached.MemcachedClientIF
 
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.ConcatenationOperationImpl
 
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
 
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.
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(String) - Method in interface net.spy.memcached.ops.VBucketAware
 
getVbucket() - Method in class net.spy.memcached.tapmessage.BaseMessage
Gets the value of the tap messages vbucket field.
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.protocol.TCPMemcachedNodeImpl
 
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, 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, byte[]) - Method in interface net.spy.memcached.ops.GetOperation.Callback
Callback for each result from a get.
gotData(String, int, long, byte[]) - Method in interface net.spy.memcached.ops.GetsOperation.Callback
Callback for each result from a gets.
gotData(String, int, byte[]) - Method in class net.spy.memcached.ops.MultiGetOperationCallback
 
gotData(String, int, long, byte[]) - Method in class net.spy.memcached.ops.MultiGetsOperationCallback
 
gotData(String, int, byte[]) - Method in class net.spy.memcached.ops.MultiReplicaGetOperationCallback
 
gotData(String, long, MemcachedNode, ObserveResponse) - Method in interface net.spy.memcached.ops.ObserveOperation.Callback
Callback for each result from a observe.
gotData(String, int, byte[]) - Method in interface net.spy.memcached.ops.ReplicaGetOperation.Callback
Callback for each result from a replica get.
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(ResponseMessage) - Method in interface net.spy.memcached.ops.TapOperation.Callback
Callback for each result from a 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
 
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
 
handleError(OperationErrorType, String) - Method in class net.spy.memcached.protocol.BaseOperationImpl
 
handleIO() - Method in class net.spy.memcached.MemcachedConnection
Handle all IO that flows through the connection.
handleRead(ByteBuffer) - Method in interface net.spy.memcached.ops.Operation
Handle a raw data read.
handleRead(ByteBuffer) - Method in class net.spy.memcached.protocol.BaseOperationImpl
 
handleRetryInformation(byte[]) - Method in class net.spy.memcached.MemcachedConnection
Optionally handle retry (NOT_MY_VBUKET) responses.
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.
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.
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.ConnectionFactoryBuilder
 
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.
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.internal.SingleElementInfiniteIterator
 
hasReadOp() - Method in interface net.spy.memcached.MemcachedNode
True if an operation is available to read.
hasReadOp() - Method in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
hasWriteOp() - Method in interface net.spy.memcached.MemcachedNode
True if an operation is available to write.
hasWriteOp() - Method in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
HEADER_LENGTH - Static variable in class net.spy.memcached.tapmessage.BaseMessage
 

I

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(String, long) - Method in class net.spy.memcached.MemcachedClient
Increment the given key by the given amount.
incr(String, int) - Method in class net.spy.memcached.MemcachedClient
Increment the given key by the given amount.
incr(String, long, long, int) - Method in class net.spy.memcached.MemcachedClient
Increment the given counter, returning the new value.
incr(String, int, long, int) - Method in class net.spy.memcached.MemcachedClient
Increment the given counter, returning the new value.
incr(String, long, long) - Method in class net.spy.memcached.MemcachedClient
Increment the given counter, returning the new value.
incr(String, int, long) - Method in class net.spy.memcached.MemcachedClient
Increment the given counter, returning the new value.
incr(String, long) - Method in interface net.spy.memcached.MemcachedClientIF
 
incr(String, int) - Method in interface net.spy.memcached.MemcachedClientIF
 
incr(String, long, long, int) - Method in interface net.spy.memcached.MemcachedClientIF
 
incr(String, int, long, int) - Method in interface net.spy.memcached.MemcachedClientIF
 
incr(String, long, long) - Method in interface net.spy.memcached.MemcachedClientIF
 
incr(String, int, long) - Method in interface net.spy.memcached.MemcachedClientIF
 
incrementCounter(String) - Method in class net.spy.memcached.metrics.AbstractMetricCollector
 
incrementCounter(String, int) - Method in class net.spy.memcached.metrics.DefaultMetricCollector
 
incrementCounter(String) - Method in interface net.spy.memcached.metrics.MetricCollector
Increment a Counter by one.
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
 
info(Object, Throwable) - Method in class net.spy.memcached.compat.log.AbstractLogger
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(Object) - 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(Object) - Method in interface net.spy.memcached.compat.log.Logger
Log a message at info level.
info(String, Object...) - Method in interface net.spy.memcached.compat.log.Logger
Log a formatted message at info level.
initialize() - Method in interface net.spy.memcached.ops.Operation
Initialize this operation.
initialize() - Method in class net.spy.memcached.protocol.BaseOperationImpl
 
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.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.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.StatsOperationImpl
 
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
 
initialObservers - Variable in class net.spy.memcached.ConnectionFactoryBuilder
 
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.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.
IntegerTranscoder - Class in net.spy.memcached.transcoders
Transcoder that serializes and unserializes longs.
IntegerTranscoder() - Constructor for class net.spy.memcached.transcoders.IntegerTranscoder
 
interruptAllPendingAuth() - Method in class net.spy.memcached.auth.AuthThreadMonitor
Interrupt all pending AuthThreads.
isActive() - Method in interface net.spy.memcached.MemcachedNode
True if this node is active. i.e.
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.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() - Method in interface net.spy.memcached.ConnectionFactory
If true, the IO thread should be a daemon thread.
isDaemon - Variable in class net.spy.memcached.ConnectionFactoryBuilder
 
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.
isShutDown() - Method in class net.spy.memcached.MemcachedConnection
Returns whether the connection is shut down or not.
isShutdown() - Method in class net.spy.memcached.transcoders.TranscodeService
Ask whether this service has been shut down.
isSingleton() - Method in class net.spy.memcached.spring.MemcachedClientFactoryBean
 
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(long) - 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 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
 

J

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

K

KetamaConnectionFactory - Class in net.spy.memcached
ConnectionFactory instance that sets up a ketama compatible connection.
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() - Constructor for class net.spy.memcached.KetamaConnectionFactory
Create a KetamaConnectionFactory with the default parameters.
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, KetamaNodeLocatorConfiguration) - Constructor for class net.spy.memcached.KetamaNodeLocator
Create a new KetamaNodeLocator using specified nodes and the specifed hash algorithm and configuration.
KetamaNodeLocatorConfiguration - Interface in net.spy.memcached.util
Defines the set of all configuration dependencies required for the KetamaNodeLocator algorithm to run.
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
 
keySet() - Method in class net.spy.memcached.BaseCacheMap
 
keysOnly() - Method in class net.spy.memcached.tapmessage.MessageBuilder
 
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.

L

lastReadDelta() - Method in interface net.spy.memcached.MemcachedNode
Milliseconds since last successful read.
lastReadDelta() - Method in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
Number of milliseconds since the last read of this node completed.
Level - Enum in net.spy.memcached.compat.log
Levels for logging.
LinkedOperationQueueFactory - Class in net.spy.memcached.ops
OperationQueueFactory that creates LinkedBlockingQueue (unbounded) operation queues.
LinkedOperationQueueFactory() - Constructor for class net.spy.memcached.ops.LinkedOperationQueueFactory
 
ListenableFuture<T,L extends GenericCompletionListener> - Interface in net.spy.memcached.internal
A Future that accepts one or more listeners that will be executed asynchronously.
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.
log(Level, Object) - Method in class net.spy.memcached.compat.log.AbstractLogger
Log a message at the given 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) - 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 - 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.
LongTranscoder - Class in net.spy.memcached.transcoders
Transcoder that serializes and unserializes longs.
LongTranscoder() - Constructor for class net.spy.memcached.transcoders.LongTranscoder
 
lookupHashAlgorithm(String) - Static method in class net.spy.memcached.HashAlgorithmRegistry
Tries to find selected hash algorithm using name provided.

M

magic - 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
 
MAX_KEY_LENGTH - Static variable in interface net.spy.memcached.MemcachedClientIF
Maximum supported key length.
MAX_SIZE - Static variable in class net.spy.memcached.CachedData
The maximum size that should be considered storing in a server.
maxReconnectDelay - Variable in class net.spy.memcached.ConnectionFactoryBuilder
 
mconn - Variable in class net.spy.memcached.MemcachedClient
 
mech - Variable in class net.spy.memcached.protocol.binary.SASLBaseOperationImpl
 
MECH_SEPARATOR - Static variable in class net.spy.memcached.auth.AuthThread
 
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.
MemcachedClientFactoryBean - Class in net.spy.memcached.spring
A Spring FactoryBean creating MemcachedClient instances.
MemcachedClientFactoryBean() - Constructor for class net.spy.memcached.spring.MemcachedClientFactoryBean
 
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.
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
 
MetricCollector - Interface in net.spy.memcached.metrics
Defines a common API for all MetricCollectors.
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.
MIN_RECV_PACKET - Static variable in class net.spy.memcached.protocol.binary.OperationImpl
 
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
 
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, 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
 
Mutator - Enum in net.spy.memcached.ops
Type of mutation to perform.
MutatorOperation - Interface in net.spy.memcached.ops
incr and decr operations.

N

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.spring - package net.spy.memcached.spring
 
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() - Method in class net.spy.memcached.internal.SingleElementInfiniteIterator
 
NodeLocator - Interface in net.spy.memcached
Interface for locating a node by hash value.
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
 
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.
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
 

O

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
 
ObserveOperation - Interface in net.spy.memcached.ops
Observe operation.
ObserveOperation.Callback - Interface in net.spy.memcached.ops
Operation callback for the Observe request.
ObserveResponse - Enum in net.spy.memcached
Response codes for a Observe operation.
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.
opaque - Variable in class net.spy.memcached.protocol.binary.OperationImpl
 
opaque - 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.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.
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.binary
Base class for binary operations.
OperationImpl(byte, int, OperationCallback) - Constructor for class net.spy.memcached.protocol.binary.OperationImpl
Construct with opaque.
OperationQueueFactory - Interface in net.spy.memcached.ops
Factory used for creating operation queues.
OperationState - Enum in net.spy.memcached.ops
State of this operation.
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.ConnectionFactoryBuilder
 
opFact - Variable in class net.spy.memcached.MemcachedClient
 
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
 
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
 
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.
originalCallback - Variable in class net.spy.memcached.ops.MultiOperationCallback
 

P

PersistTo - Enum in net.spy.memcached
PersistTo codes for a Observe operation.
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.
prepareBuffer(String, long, byte[], Object...) - Method in class net.spy.memcached.protocol.binary.OperationImpl
Prepare the buffer for sending.
prepend(long, String, Object) - Method in class net.spy.memcached.MemcachedClient
Prepend to an existing value in the cache.
prepend(String, Object) - Method in class net.spy.memcached.MemcachedClient
Prepend to an existing value in the cache.
prepend(long, 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 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(String, Object) - Method in interface net.spy.memcached.MemcachedClientIF
 
prepend(long, String, T, Transcoder<T>) - Method in interface net.spy.memcached.MemcachedClientIF
 
prepend(String, T, Transcoder<T>) - Method in interface net.spy.memcached.MemcachedClientIF
 
props - Variable in class net.spy.memcached.protocol.binary.SASLBaseOperationImpl
 
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

readBufSize - Variable in class net.spy.memcached.ConnectionFactoryBuilder
 
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.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
 
readQueueFactory - Variable in class net.spy.memcached.ConnectionFactoryBuilder
 
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.GetCallbackWrapper
 
receivedStatus(OperationStatus) - Method in class net.spy.memcached.protocol.ProxyCallback
 
reconnecting() - Method in interface net.spy.memcached.MemcachedNode
Notify this node that it will be reconnecting.
reconnecting() - Method in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
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.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.
remove(Object) - Method in class net.spy.memcached.BaseCacheMap
 
remove() - Method in class net.spy.memcached.internal.SingleElementInfiniteIterator
 
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.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.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(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(L) - Method in interface net.spy.memcached.internal.ListenableFuture
Remove a previously added listener from the future.
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(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, 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, T, Transcoder<T>) - Method in interface net.spy.memcached.MemcachedClientIF
 
replace(String, int, Object) - Method in interface net.spy.memcached.MemcachedClientIF
 
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
 
ReplicateTo - Enum in net.spy.memcached
ReplicateTo codes for a Observe operation.
REQ_MAGIC - Static variable in class net.spy.memcached.protocol.binary.OperationImpl
 
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
 
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
 
retryOperation(Operation) - Method in class net.spy.memcached.MemcachedConnection
Add a operation to the retry queue.
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.
running - Variable in class net.spy.memcached.MemcachedConnection
True if not shutting down or shut down.

S

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
 
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
 
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.
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.
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.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.
serverName - Variable in class net.spy.memcached.protocol.binary.SASLBaseOperationImpl
 
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(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, 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, T, Transcoder<T>) - Method in interface net.spy.memcached.MemcachedClientIF
 
set(String, int, Object) - Method in interface net.spy.memcached.MemcachedClientIF
 
setAuthDescriptor(AuthDescriptor) - Method in class net.spy.memcached.ConnectionFactoryBuilder
Set the auth descriptor to enable authentication on new connections.
setAuthDescriptor(AuthDescriptor) - Method in class net.spy.memcached.spring.MemcachedClientFactoryBean
 
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.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.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.protocol.TCPMemcachedNodeImpl
 
setDaemon(boolean) - Method in class net.spy.memcached.ConnectionFactoryBuilder
Set the daemon state of the IO thread (defaults to true).
setDaemon(boolean) - Method in class net.spy.memcached.spring.MemcachedClientFactoryBean
 
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.
setFailureMode(FailureMode) - Method in class net.spy.memcached.spring.MemcachedClientFactoryBean
 
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.
setHashAlg(HashAlgorithm) - Method in class net.spy.memcached.spring.MemcachedClientFactoryBean
 
setInitialObservers(Collection<ConnectionObserver>) - Method in class net.spy.memcached.ConnectionFactoryBuilder
Set the initial connection observers (will observe initial connection).
setInitialObservers(Collection<ConnectionObserver>) - Method in class net.spy.memcached.spring.MemcachedClientFactoryBean
 
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.
setLocatorType(ConnectionFactoryBuilder.Locator) - Method in class net.spy.memcached.spring.MemcachedClientFactoryBean
 
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.
setMaxReconnectDelay(long) - Method in class net.spy.memcached.spring.MemcachedClientFactoryBean
 
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
 
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.
setOpFact(OperationFactory) - Method in class net.spy.memcached.spring.MemcachedClientFactoryBean
 
setOpQueueFactory(OperationQueueFactory) - Method in class net.spy.memcached.ConnectionFactoryBuilder
 
setOpQueueFactory(OperationQueueFactory) - Method in class net.spy.memcached.spring.MemcachedClientFactoryBean
 
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.
setOpQueueMaxBlockTime(long) - Method in class net.spy.memcached.spring.MemcachedClientFactoryBean
 
setOpTimeout(long) - Method in class net.spy.memcached.ConnectionFactoryBuilder
Set the default operation timeout in milliseconds.
setOpTimeout(long) - Method in class net.spy.memcached.spring.MemcachedClientFactoryBean
 
setProtocol(ConnectionFactoryBuilder.Protocol) - Method in class net.spy.memcached.ConnectionFactoryBuilder
Convenience method to specify the protocol to use.
setProtocol(ConnectionFactoryBuilder.Protocol) - Method in class net.spy.memcached.spring.MemcachedClientFactoryBean
 
setReadBufferSize(int) - Method in class net.spy.memcached.ConnectionFactoryBuilder
Set the read buffer size.
setReadBufferSize(int) - Method in class net.spy.memcached.spring.MemcachedClientFactoryBean
 
setReadOpQueueFactory(OperationQueueFactory) - Method in class net.spy.memcached.ConnectionFactoryBuilder
Set the read queue factory.
setReadOpQueueFactory(OperationQueueFactory) - Method in class net.spy.memcached.spring.MemcachedClientFactoryBean
 
setServers(String) - Method in class net.spy.memcached.spring.MemcachedClientFactoryBean
 
setShouldOptimize(boolean) - Method in class net.spy.memcached.ConnectionFactoryBuilder
Set to false if the default operation optimization is not desirable.
setShouldOptimize(boolean) - Method in class net.spy.memcached.spring.MemcachedClientFactoryBean
 
setSk(SelectionKey) - Method in interface net.spy.memcached.MemcachedNode
Set the selection key for this node.
setSk(SelectionKey) - Method in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
setStatus(OperationStatus) - Method in class net.spy.memcached.internal.BulkGetFuture
 
setTimeoutExceptionThreshold(int) - Method in class net.spy.memcached.ConnectionFactoryBuilder
Set the maximum timeout exception threshold.
setTimeoutExceptionThreshold(int) - Method in class net.spy.memcached.spring.MemcachedClientFactoryBean
 
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.
setTranscoder(Transcoder<Object>) - Method in class net.spy.memcached.spring.MemcachedClientFactoryBean
 
setupForAuth() - Method in interface net.spy.memcached.MemcachedNode
Tell a node to set up for authentication.
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.protocol.TCPMemcachedNodeImpl
 
setUseNagleAlgorithm(boolean) - Method in class net.spy.memcached.ConnectionFactoryBuilder
Set to true if you'd like to enable the Nagle algorithm.
setUseNagleAlgorithm(boolean) - Method in class net.spy.memcached.spring.MemcachedClientFactoryBean
 
setVBucket(String, short) - Method in interface net.spy.memcached.ops.VBucketAware
 
setVbucket(short) - Method in class net.spy.memcached.tapmessage.BaseMessage
Sets the value of the tap messages vbucket field.
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.
setWriteOpQueueFactory(OperationQueueFactory) - Method in class net.spy.memcached.spring.MemcachedClientFactoryBean
 
shouldOptimize() - Method in interface net.spy.memcached.ConnectionFactory
If true, low-level optimization is in effect.
shouldOptimize - Variable in class net.spy.memcached.ConnectionFactoryBuilder
 
shouldOptimize() - Method in class net.spy.memcached.DefaultConnectionFactory
 
shutdown() - Method in class net.spy.memcached.MemcachedClient
Shut down immediately.
shutdown(long, TimeUnit) - Method in class net.spy.memcached.MemcachedClient
Shut down this client gracefully.
shutdown() - Method in interface net.spy.memcached.MemcachedClientIF
 
shutdown(long, TimeUnit) - Method in interface net.spy.memcached.MemcachedClientIF
 
shutDown - Variable in class net.spy.memcached.MemcachedConnection
If the connection is alread shut down or shutting down.
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(long, TimeUnit) - Method in class net.spy.memcached.TapConnectionProvider
Shut down this client gracefully.
shutdown() - Method in class net.spy.memcached.transcoders.TranscodeService
Shut down the pool.
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.
size() - Method in class net.spy.memcached.BaseCacheMap
 
size() - Method in class net.spy.memcached.protocol.binary.OptimizedSetImpl
 
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.
socketAddresses - Variable in class net.spy.memcached.util.DefaultKetamaNodeLocatorConfiguration
 
SPECIAL_BOOLEAN - Static variable in class net.spy.memcached.transcoders.WhalinV1Transcoder
 
SPECIAL_BYTE - Static variable in class net.spy.memcached.transcoders.WhalinV1Transcoder
 
SPECIAL_CHARACTER - Static variable in class net.spy.memcached.transcoders.WhalinV1Transcoder
 
SPECIAL_DATE - Static variable in class net.spy.memcached.transcoders.WhalinV1Transcoder
 
SPECIAL_DOUBLE - Static variable in class net.spy.memcached.transcoders.WhalinV1Transcoder
 
SPECIAL_FLOAT - Static variable in class net.spy.memcached.transcoders.WhalinV1Transcoder
 
SPECIAL_INTEGER - Static variable in class net.spy.memcached.transcoders.WhalinV1Transcoder
 
SPECIAL_LONG - Static variable in class net.spy.memcached.transcoders.WhalinV1Transcoder
 
SPECIAL_SHORT - Static variable in class net.spy.memcached.transcoders.WhalinV1Transcoder
 
SPECIAL_STRING - Static variable in class net.spy.memcached.transcoders.WhalinV1Transcoder
 
SPECIAL_STRINGBUFFER - Static variable in class net.spy.memcached.transcoders.WhalinV1Transcoder
 
SPECIAL_STRINGBUILDER - Static variable in class net.spy.memcached.transcoders.WhalinV1Transcoder
 
specifyVbuckets(short[]) - Method in class net.spy.memcached.tapmessage.MessageBuilder
 
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.
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.binary
A StatsOperationImpl.
StatsOperationImpl(String, StatsOperation.Callback) - Constructor for class net.spy.memcached.protocol.binary.StatsOperationImpl
 
status - Variable in class net.spy.memcached.internal.OperationFuture
 
STATUS_OK - Static variable in class net.spy.memcached.protocol.binary.OperationImpl
 
StatusCode - Enum in net.spy.memcached.ops
Represents status and error codes from the binary protocol.
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
 
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.
storeResult(String, boolean) - Method in interface net.spy.memcached.util.CacheLoader.StorageListener
Normal path response for a set.
StoreType - Enum in net.spy.memcached.ops
The type of storage operation to perform.
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.
SUCCESS - Static variable in class net.spy.memcached.protocol.binary.OperationImpl
Error code for operations.
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.
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

takeoverVbuckets(short[]) - Method in class net.spy.memcached.tapmessage.MessageBuilder
 
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.
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.
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, 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
 
tapCustom(String, RequestMessage) - Method in class net.spy.memcached.TapClient
Allows the user to specify a custom tap message.
TapCustomOperationImpl - Class in net.spy.memcached.protocol.binary
Implementation of a custom tap operation.
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
 
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.
TapDumpOperationImpl - Class in net.spy.memcached.protocol.binary
Implementation of a tap dump operation.
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.
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.
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.
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.
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.
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
 
TIMED_OUT - Static variable in class net.spy.memcached.protocol.BaseOperationImpl
 
TimedOutOperationStatus - Class in net.spy.memcached.ops
Operation status indicating an operation was timed out.
TimedOutOperationStatus() - Constructor for class net.spy.memcached.ops.TimedOutOperationStatus
 
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
 
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 exception net.spy.memcached.ops.OperationException
 
toString() - Method in class net.spy.memcached.ops.OperationStatus
 
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.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.SASLStepOperationImpl
 
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.TCPMemcachedNodeImpl
 
toString() - Method in class net.spy.memcached.tapmessage.ResponseMessage
 
totalbody - 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, 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
 
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
 
TouchOperation - Interface in net.spy.memcached.ops
Touch operation marker.
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.binary.TouchOperationImpl
 
trace(Object, Throwable) - Method in class net.spy.memcached.compat.log.AbstractLogger
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(Object) - 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(Object) - Method in interface net.spy.memcached.compat.log.Logger
Log a message at trace level.
trace(String, Object...) - Method in interface net.spy.memcached.compat.log.Logger
Log a formatted message at trace level.
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
 
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.protocol.TCPMemcachedNodeImpl
 
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

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
 
UnlockOperation - Interface in net.spy.memcached.ops
Unlock operation.
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
 
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.

V

validateKey(String, boolean) - Static method in class net.spy.memcached.util.StringUtils
Check if a given key is valid to transmit.
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.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(byte) - Static method in enum net.spy.memcached.ObserveResponse
 
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.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.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.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.
vbucket - Variable in class net.spy.memcached.protocol.binary.OperationImpl
 
vbucket - 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.
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.

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.
warn(Object, Throwable) - Method in class net.spy.memcached.compat.log.AbstractLogger
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(Object) - 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(Object) - Method in interface net.spy.memcached.compat.log.Logger
Log a message at warning level.
warn(String, Object...) - Method in interface net.spy.memcached.compat.log.Logger
Log a formatted message at debug level.
wasCancelled() - Method in class net.spy.memcached.protocol.BaseOperationImpl
This is called on each subclass whenever an operation was cancelled.
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
 
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
 
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.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
 
A B C D E F G H I J K L M N O P Q R S T U V W 
Skip navigation links

Copyright © 2021. All rights reserved.