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
 
AbstractView - Class in com.couchbase.client.protocol.views
The base class for Views and Spatial Views.
AbstractView(String, String, String) - Constructor for class com.couchbase.client.protocol.views.AbstractView
Instantiate a AbstractView object.
AdaptiveThrottler - Class in com.couchbase.client.internal
The AdaptiveThrottler allows dynamic backoff of memcached operations to make sure the server is not overloaded to more then a certain level.
AdaptiveThrottler(CouchbaseConnection, BinaryOperationFactory, InetSocketAddress) - Constructor for class com.couchbase.client.internal.AdaptiveThrottler
Initialize the Throttler with sensible default settings.
AdaptiveThrottler(CouchbaseConnection, BinaryOperationFactory, InetSocketAddress, int, int, int, int, int) - Constructor for class com.couchbase.client.internal.AdaptiveThrottler
Construct the AdaptiveThrottler with all possible options.
add(String, Object) - Method in class com.couchbase.client.CouchbaseClient
 
add(String, int, Object, PersistTo, ReplicateTo) - Method in class com.couchbase.client.CouchbaseClient
 
add(String, Object, PersistTo, ReplicateTo) - Method in class com.couchbase.client.CouchbaseClient
 
add(String, int, Object, PersistTo) - Method in class com.couchbase.client.CouchbaseClient
 
add(String, Object, PersistTo) - Method in class com.couchbase.client.CouchbaseClient
 
add(String, int, Object, ReplicateTo) - Method in class com.couchbase.client.CouchbaseClient
 
add(String, Object, ReplicateTo) - Method in class com.couchbase.client.CouchbaseClient
 
add(String, Object) - Method in interface com.couchbase.client.CouchbaseClientIF
Set a value with durability options and no TTL.
add(String, int, Object, PersistTo) - Method in interface com.couchbase.client.CouchbaseClientIF
Add a value with durability options.
add(String, Object, PersistTo) - Method in interface com.couchbase.client.CouchbaseClientIF
Add a value with durability options with No TTL This is a shorthand method so that you only need to provide a PersistTo value if you don't care if the value is already replicated.
add(String, int, Object, ReplicateTo) - Method in interface com.couchbase.client.CouchbaseClientIF
Add a value with durability options.
add(String, Object, ReplicateTo) - Method in interface com.couchbase.client.CouchbaseClientIF
Add a value with durability options with no TTL This method allows you to express durability at the replication level only and is the functional equivalent of PersistTo.ZERO.
add(String, int, Object, PersistTo, ReplicateTo) - Method in interface com.couchbase.client.CouchbaseClientIF
Add a value with durability options.
add(String, Object, PersistTo, ReplicateTo) - Method in interface com.couchbase.client.CouchbaseClientIF
Add a value with durability options with no TTL To make sure that a value is stored the way you want it to in the cluster, you can use the PersistTo and ReplicateTo arguments.
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
 
addAuthHeader(String) - Method in interface com.couchbase.client.protocol.views.HttpOperation
 
addAuthHeader(String) - Method in class com.couchbase.client.protocol.views.HttpOperationImpl
 
addCallbacks(GetOperation) - Method in class net.spy.memcached.protocol.ProxyCallback
 
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
 
addFutureToMonitor(Future<T>) - Method in class com.couchbase.client.internal.ReplicaGetFuture
Add a GetFuture to mointor.
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
 
addListener(HttpCompletionListener) - Method in class com.couchbase.client.internal.HttpFuture
 
addListener(ReplicaGetCompletionListener) - Method in class com.couchbase.client.internal.ReplicaGetFuture
 
addListener(HttpCompletionListener) - Method in class com.couchbase.client.internal.ViewFuture
 
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(HttpOperation) - Method in class com.couchbase.client.CouchbaseClient
Adds an operation to the queue where it waits to be sent to Couchbase.
addOp(HttpOperation) - Method in class com.couchbase.client.ViewConnection
Write an operation to the next HttpHost.
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 com.couchbase.client.CouchbaseConnection
Add an operation to the given connection.
addOperation(String, Operation) - Method in class com.couchbase.client.CouchbaseMemcachedConnection
 
addOperation(String, Operation) - Method in class net.spy.memcached.MemcachedConnection
Add an operation to the given connection.
addOperation(MemcachedNode, Operation) - Method in class net.spy.memcached.MemcachedConnection
 
addOperation(CASOperation) - Method in class net.spy.memcached.protocol.binary.OptimizedSetImpl
 
addOperations(Map<MemcachedNode, Operation>) - Method in class com.couchbase.client.CouchbaseConnection
 
addOperations(Map<MemcachedNode, Operation>) - Method in class net.spy.memcached.MemcachedConnection
 
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) - 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, Object, PersistTo, ReplicateTo) - Method in class com.couchbase.client.CouchbaseClient
 
asyncCas(String, long, Object, PersistTo) - Method in class com.couchbase.client.CouchbaseClient
 
asyncCas(String, long, Object, ReplicateTo) - Method in class com.couchbase.client.CouchbaseClient
 
asyncCas(String, long, int, Object, PersistTo) - Method in class com.couchbase.client.CouchbaseClient
 
asyncCas(String, long, int, Object, ReplicateTo) - Method in class com.couchbase.client.CouchbaseClient
 
asyncCas(String, long, int, Object, PersistTo, ReplicateTo) - Method in class com.couchbase.client.CouchbaseClient
 
asyncCas(String, long, Object, PersistTo, ReplicateTo) - Method in interface com.couchbase.client.CouchbaseClientIF
Set a value with a CAS and durability options.
asyncCas(String, long, Object, PersistTo) - Method in interface com.couchbase.client.CouchbaseClientIF
Set a value with a CAS and durability options.
asyncCas(String, long, Object, ReplicateTo) - Method in interface com.couchbase.client.CouchbaseClientIF
Set a value with a CAS and durability options.
asyncCas(String, long, int, Object, PersistTo) - Method in interface com.couchbase.client.CouchbaseClientIF
Set a value with a CAS and durability options.
asyncCas(String, long, int, Object, ReplicateTo) - Method in interface com.couchbase.client.CouchbaseClientIF
Set a value with a CAS and durability options.
asyncCas(String, long, int, Object, PersistTo, ReplicateTo) - Method in interface com.couchbase.client.CouchbaseClientIF
Set a value with a CAS and durability options.
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
 
asyncCreateDesignDoc(String, String) - Method in class com.couchbase.client.CouchbaseClient
 
asyncCreateDesignDoc(DesignDocument) - Method in class com.couchbase.client.CouchbaseClient
 
asyncCreateDesignDoc(DesignDocument) - Method in interface com.couchbase.client.CouchbaseClientIF
Store a design document in the cluster.
asyncCreateDesignDoc(String, String) - Method in interface com.couchbase.client.CouchbaseClientIF
Store a design document in the cluster.
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) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncDecr(String, int) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncDeleteDesignDoc(String) - Method in class com.couchbase.client.CouchbaseClient
 
asyncDeleteDesignDoc(String) - Method in interface com.couchbase.client.CouchbaseClientIF
Delete a design document in the cluster.
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
 
asyncGetAndLock(String, int, Transcoder<T>) - Method in class com.couchbase.client.CouchbaseClient
 
asyncGetAndLock(String, int) - Method in class com.couchbase.client.CouchbaseClient
 
asyncGetAndLock(String, int) - Method in interface com.couchbase.client.CouchbaseClientIF
Get and lock the given key asynchronously and decode with the default transcoder.
asyncGetAndLock(String, int, Transcoder<T>) - Method in interface com.couchbase.client.CouchbaseClientIF
Gets and locks the given key asynchronously.
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
 
asyncGetDesignDoc(String) - Method in class com.couchbase.client.CouchbaseClient
 
asyncGetDesignDoc(String) - Method in interface com.couchbase.client.CouchbaseClientIF
Gets a future with a design document from the cluster.
asyncGetDesignDocument(String) - Method in class com.couchbase.client.CouchbaseClient
Deprecated.
asyncGetDesignDocument(String) - Method in interface com.couchbase.client.CouchbaseClientIF
Deprecated.
asyncGetFromReplica(String) - Method in class com.couchbase.client.CouchbaseClient
 
asyncGetFromReplica(String, Transcoder<T>) - Method in class com.couchbase.client.CouchbaseClient
 
asyncGetFromReplica(String) - Method in interface com.couchbase.client.CouchbaseClientIF
Asynchronously get a document from the replica (or the active) nodes.
asyncGetFromReplica(String, Transcoder<T>) - Method in interface com.couchbase.client.CouchbaseClientIF
Asynchronously get a document from the replica (or the active) nodes with a custom transcoder.
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
 
asyncGetsFromReplica(String) - Method in class com.couchbase.client.CouchbaseClient
 
asyncGetsFromReplica(String, Transcoder<T>) - Method in class com.couchbase.client.CouchbaseClient
 
asyncGetsFromReplica(String) - Method in interface com.couchbase.client.CouchbaseClientIF
Asynchronously get a document and its CAS from the replica (or the active) nodes.
asyncGetsFromReplica(String, Transcoder<T>) - Method in interface com.couchbase.client.CouchbaseClientIF
Asynchronously get a document and its CAS from the replica (or the active) nodes with a custom transcoder.
asyncGetSpatialView(String, String) - Method in class com.couchbase.client.CouchbaseClient
 
asyncGetSpatialView(String, String) - Method in interface com.couchbase.client.CouchbaseClientIF
Gets access to a spatial view contained in a design document from the cluster.
asyncGetView(String, String) - Method in class com.couchbase.client.CouchbaseClient
 
asyncGetView(String, String) - Method in interface com.couchbase.client.CouchbaseClientIF
Gets access to a view contained in a design document from the cluster.
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) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncIncr(String, int) - Method in interface net.spy.memcached.MemcachedClientIF
 
asyncQuery(AbstractView, Query) - Method in class com.couchbase.client.CouchbaseClient
 
asyncQuery(AbstractView, Query) - Method in interface com.couchbase.client.CouchbaseClientIF
 
asyncUnlock(String, long, Transcoder<T>) - Method in class com.couchbase.client.CouchbaseClient
 
asyncUnlock(String, long) - Method in class com.couchbase.client.CouchbaseClient
 
asyncUnlock(String, long, Transcoder<T>) - Method in interface com.couchbase.client.CouchbaseClientIF
Unlock the given key asynchronously from the cache.
asyncUnlock(String, long) - Method in interface com.couchbase.client.CouchbaseClientIF
Unlock the given key asynchronously from the cache with the default transcoder.
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
 
AuthType - Enum in com.couchbase.client.clustermanager
An enum of the different Couchbase authentication types for creating a bucket.
authWaitTime - Variable in class com.couchbase.client.CouchbaseConnectionFactoryBuilder
 

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) - 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
 
bootstrap() - Method in class com.couchbase.client.vbucket.provider.BucketConfigurationProvider
 
bootstrap() - Method in interface com.couchbase.client.vbucket.provider.ConfigurationProvider
Initiate the config fetching process, eventually returning a valid configuration.
broadcastOp(BroadcastOpFactory) - Method in class net.spy.memcached.MemcachedClient
 
broadcastOp(BroadcastOpFactory, Collection<MemcachedNode>) - Method in class net.spy.memcached.MemcachedClient
 
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 specific collection of nodes.
BroadcastOpFactory - Interface in net.spy.memcached
Factory for creating Operations to be broadcast.
Bucket - Class in com.couchbase.client.vbucket.config
Bucket configuration bean.
Bucket(String, Config, URI, List<Node>, long) - Constructor for class com.couchbase.client.vbucket.config.Bucket
 
BucketConfigurationProvider - Class in com.couchbase.client.vbucket.provider
This ConfigurationProvider provides the current bucket configuration in a best-effort way, mixing both http and binary fetching techniques (depending on the supported mechanisms on the cluster side).
BucketConfigurationProvider(List<URI>, String, String, CouchbaseConnectionFactory) - Constructor for class com.couchbase.client.vbucket.provider.BucketConfigurationProvider
 
BucketMonitor - Class in com.couchbase.client.vbucket
The BucketMonitor will open an HTTP comet stream to monitor for changes to the list of nodes.
BucketMonitor(URI, String, String, ConfigurationParser, ConfigurationProviderHTTP) - Constructor for class com.couchbase.client.vbucket.BucketMonitor
 
BucketMonitorPipelineFactory - Class in com.couchbase.client.vbucket
A BucketMonitorPipelineFactory.
BucketMonitorPipelineFactory() - Constructor for class com.couchbase.client.vbucket.BucketMonitorPipelineFactory
 
BucketType - Enum in com.couchbase.client.clustermanager
An enum of the different Couchbase bucket types.
BucketUpdateResponseHandler - Class in com.couchbase.client.vbucket
A BucketUpdateResponseHandler.
BucketUpdateResponseHandler() - Constructor for class com.couchbase.client.vbucket.BucketUpdateResponseHandler
 
build(List<URI>, String, String) - Method in class com.couchbase.client.ClusterManagerBuilder
Builder a ClusterManager.
build() - Method in class net.spy.memcached.ConnectionFactoryBuilder
Get the ConnectionFactory set up with the provided parameters.
buildAuthHeader(String, String) - Static method in class com.couchbase.client.http.HttpUtil
Generate the payload of an authorization header given a username and password.
buildCouchbaseConnection(List<URI>, String, String) - Method in class com.couchbase.client.CouchbaseConnectionFactoryBuilder
Build the CouchbaseConnectionFactory set up with the provided settings.
buildCouchbaseConnection(List<URI>, String, String, String) - Method in class com.couchbase.client.CouchbaseConnectionFactoryBuilder
Deprecated.
buildCouchbaseConnection() - Method in class com.couchbase.client.CouchbaseConnectionFactoryBuilder
Build the CouchbaseConnectionFactory set up with the provided settings.
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 com.couchbase.client.protocol.views.HttpOperationImpl
 
callback - Variable in class net.spy.memcached.protocol.BaseOperationImpl
 
cancel(boolean) - Method in class com.couchbase.client.internal.HttpFuture
 
cancel() - Method in class com.couchbase.client.internal.ObserveFuture
 
cancel(boolean) - Method in class com.couchbase.client.internal.ObserveFuture
 
cancel(boolean) - Method in class com.couchbase.client.internal.ReplicaGetFuture
 
cancel() - Method in interface com.couchbase.client.protocol.views.HttpOperation
 
cancel() - Method in class com.couchbase.client.protocol.views.HttpOperationImpl
 
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() - Method in class com.couchbase.client.http.HttpResponseCallback
 
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, long, Object, PersistTo, ReplicateTo) - Method in class com.couchbase.client.CouchbaseClient
 
cas(String, long, int, Object, PersistTo, ReplicateTo) - Method in class com.couchbase.client.CouchbaseClient
 
cas(String, long, Object, PersistTo) - Method in class com.couchbase.client.CouchbaseClient
 
cas(String, long, int, Object, PersistTo) - Method in class com.couchbase.client.CouchbaseClient
 
cas(String, long, Object, ReplicateTo) - Method in class com.couchbase.client.CouchbaseClient
 
cas(String, long, int, Object, ReplicateTo) - Method in class com.couchbase.client.CouchbaseClient
 
cas(String, long, Object, PersistTo, ReplicateTo) - Method in interface com.couchbase.client.CouchbaseClientIF
Set a value with a CAS and durability options.
cas(String, long, int, Object, PersistTo, ReplicateTo) - Method in interface com.couchbase.client.CouchbaseClientIF
Set a value with a CAS and durability options.
cas(String, long, Object, PersistTo) - Method in interface com.couchbase.client.CouchbaseClientIF
Set a value with a CAS and durability options.
cas(String, long, Object, ReplicateTo) - Method in interface com.couchbase.client.CouchbaseClientIF
Set a value with a CAS and durability options.
cas(String, long, int, Object, PersistTo) - Method in interface com.couchbase.client.CouchbaseClientIF
Set a value with a CAS and durability options.
cas(String, long, int, Object, ReplicateTo) - Method in interface com.couchbase.client.CouchbaseClientIF
Set a value with a CAS and durability options.
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(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) - 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
 
clearBuckets() - Method in class com.couchbase.client.vbucket.ConfigurationProviderHTTP
Clears all stored bucket references to get back to a pre-bootstrap state.
CLIENT_SPEC_VER - Static variable in class com.couchbase.client.vbucket.ConfigurationProviderHTTP
The specification version which this client meets.
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.
closeConnectionsForHost(HttpHost) - Method in class com.couchbase.client.http.ViewPool
Closes the underlying connections for the given HttpHost.
CloseUtil - Class in net.spy.memcached.compat
CloseUtil exists to provide a safe means to close anything closeable.
ClusterManager - Class in com.couchbase.client
A client to perform cluster-wide operations over the HTTP REST API.
ClusterManager(List<URI>, String, String) - Constructor for class com.couchbase.client.ClusterManager
Create a new ClusterManager instance.
ClusterManager(List<URI>, String, String, int, int, boolean, int, int) - Constructor for class com.couchbase.client.ClusterManager
Create a new ClusterManager instance.
ClusterManager.HttpResult - Class in com.couchbase.client
Value Object to aggregate a raw response message.
ClusterManager.HttpResult(String, int, String, String) - Constructor for class com.couchbase.client.ClusterManager.HttpResult
ClusterManagerBuilder - Class in com.couchbase.client
A builder to configure settings for the ClusterManager.
ClusterManagerBuilder() - Constructor for class com.couchbase.client.ClusterManagerBuilder
 
collector - Variable in class com.couchbase.client.CouchbaseConnectionFactoryBuilder
 
collector - Variable in class net.spy.memcached.ConnectionFactoryBuilder
 
com.couchbase.client - package com.couchbase.client
 
com.couchbase.client.clustermanager - package com.couchbase.client.clustermanager
 
com.couchbase.client.http - package com.couchbase.client.http
 
com.couchbase.client.internal - package com.couchbase.client.internal
 
com.couchbase.client.protocol.views - package com.couchbase.client.protocol.views
 
com.couchbase.client.vbucket - package com.couchbase.client.vbucket
 
com.couchbase.client.vbucket.config - package com.couchbase.client.vbucket.config
 
com.couchbase.client.vbucket.provider - package com.couchbase.client.vbucket.provider
 
compareTo(Config) - Method in interface com.couchbase.client.vbucket.config.Config
 
compareTo(Config) - Method in class com.couchbase.client.vbucket.config.CouchbaseConfig
Compares the given configuration with the current configuration and calculates the differences.
compareTo(Config) - Method in class com.couchbase.client.vbucket.config.MemcacheConfig
 
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
 
completed(HttpResponse) - Method in class com.couchbase.client.http.HttpResponseCallback
 
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.
ComplexKey - Class in com.couchbase.client.protocol.views
Allows simple definition of complex JSON keys for query inputs.
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.
Config - Interface in com.couchbase.client.vbucket.config
A Config.
ConfigDifference - Class in com.couchbase.client.vbucket.config
A ConfigDifference.
ConfigDifference() - Constructor for class com.couchbase.client.vbucket.config.ConfigDifference
 
ConfigFactory - Interface in com.couchbase.client.vbucket.config
A ConfigFactory.
ConfigParsingException - Exception in com.couchbase.client.vbucket.config
A ConfigParseException.
ConfigParsingException() - Constructor for exception com.couchbase.client.vbucket.config.ConfigParsingException
 
ConfigParsingException(String) - Constructor for exception com.couchbase.client.vbucket.config.ConfigParsingException
 
ConfigParsingException(String, Throwable) - Constructor for exception com.couchbase.client.vbucket.config.ConfigParsingException
 
ConfigParsingException(Throwable) - Constructor for exception com.couchbase.client.vbucket.config.ConfigParsingException
 
ConfigType - Enum in com.couchbase.client.vbucket.config
Config may have types.
ConfigurationException - Exception in com.couchbase.client.vbucket
An unchecked exception that signals that a configuration error has occurred while communicating with Couchbase.
ConfigurationException() - Constructor for exception com.couchbase.client.vbucket.ConfigurationException
 
ConfigurationException(String) - Constructor for exception com.couchbase.client.vbucket.ConfigurationException
 
ConfigurationException(String, Throwable) - Constructor for exception com.couchbase.client.vbucket.ConfigurationException
 
ConfigurationException(Throwable) - Constructor for exception com.couchbase.client.vbucket.ConfigurationException
 
ConfigurationParser - Interface in com.couchbase.client.vbucket.config
A ConfigParser.
ConfigurationParserJSON - Class in com.couchbase.client.vbucket.config
This ConfigurationParser takes JSON-based configuration information and transforms it into a Bucket.
ConfigurationParserJSON() - Constructor for class com.couchbase.client.vbucket.config.ConfigurationParserJSON
 
configurationProvider - Variable in class com.couchbase.client.CouchbaseConnectionFactory
 
ConfigurationProvider - Interface in com.couchbase.client.vbucket
A ConfigurationProvider.
ConfigurationProvider - Interface in com.couchbase.client.vbucket.provider
Defines common methods for a ConfigurationProvider.
ConfigurationProviderHTTP - Class in com.couchbase.client.vbucket
A configuration provider.
ConfigurationProviderHTTP(List<URI>) - Constructor for class com.couchbase.client.vbucket.ConfigurationProviderHTTP
Constructs a configuration provider with disabled authentication for the REST service.
ConfigurationProviderHTTP(List<URI>, String, String) - Constructor for class com.couchbase.client.vbucket.ConfigurationProviderHTTP
Constructs a configuration provider with a given credentials for the REST service.
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
 
ConnectionException - Exception in com.couchbase.client.vbucket
.
ConnectionException() - Constructor for exception com.couchbase.client.vbucket.ConnectionException
 
ConnectionException(String) - Constructor for exception com.couchbase.client.vbucket.ConnectionException
 
ConnectionException(String, Throwable) - Constructor for exception com.couchbase.client.vbucket.ConnectionException
 
ConnectionException(Throwable) - Constructor for exception com.couchbase.client.vbucket.ConnectionException
 
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 class com.couchbase.client.CouchbaseClient
 
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.
connectionShutDown() - Method in class com.couchbase.client.CouchbaseClient
 
connectionsStatus() - Method in class net.spy.memcached.MemcachedConnection
Get information about connections and their active status.
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.
copy() - Method in class com.couchbase.client.protocol.views.Query
Copy the current Query object into another one.
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
 
CouchbaseClient - Class in com.couchbase.client
A client for Couchbase Server.
CouchbaseClient(List<URI>, String, String) - Constructor for class com.couchbase.client.CouchbaseClient
Get a CouchbaseClient based on the initial server list provided.
CouchbaseClient(List<URI>, String, String, String) - Constructor for class com.couchbase.client.CouchbaseClient
Get a CouchbaseClient based on the initial server list provided.
CouchbaseClient(CouchbaseConnectionFactory) - Constructor for class com.couchbase.client.CouchbaseClient
Get a CouchbaseClient based on the settings from the given CouchbaseConnectionFactory.
CouchbaseClientIF - Interface in com.couchbase.client
This interface is provided as a helper for testing clients of the CouchbaseClient.
CouchbaseConfig - Class in com.couchbase.client.vbucket.config
A Config implementation that represents a "couchbase" bucket config.
CouchbaseConfig(HashAlgorithm, int, int, int, List<String>, List<VBucket>, List<URL>, List<String>, boolean) - Constructor for class com.couchbase.client.vbucket.config.CouchbaseConfig
 
CouchbaseConfigConnection - Class in com.couchbase.client.vbucket.provider
A custom CouchbaseConnection that is used for binary config fetching.
CouchbaseConfigConnection(int, CouchbaseConnectionFactory, List<InetSocketAddress>, Collection<ConnectionObserver>, FailureMode, OperationFactory) - Constructor for class com.couchbase.client.vbucket.provider.CouchbaseConfigConnection
 
CouchbaseConfigConnection.LoggerProxy - Class in com.couchbase.client.vbucket.provider
 
CouchbaseConfigConnection.LoggerProxy(Logger) - Constructor for class com.couchbase.client.vbucket.provider.CouchbaseConfigConnection.LoggerProxy
 
CouchbaseConnection - Class in com.couchbase.client
Maintains connections to each node in a cluster of Couchbase Nodes.
CouchbaseConnection(int, CouchbaseConnectionFactory, List<InetSocketAddress>, Collection<ConnectionObserver>, FailureMode, OperationFactory) - Constructor for class com.couchbase.client.CouchbaseConnection
 
CouchbaseConnectionFactory - Class in com.couchbase.client
Couchbase implementation of ConnectionFactory.
CouchbaseConnectionFactory() - Constructor for class com.couchbase.client.CouchbaseConnectionFactory
Create a new CouchbaseConnectionFactory and load the required connection information from system properties.
CouchbaseConnectionFactory(List<URI>, String, String) - Constructor for class com.couchbase.client.CouchbaseConnectionFactory
 
CouchbaseConnectionFactoryBuilder - Class in com.couchbase.client
The CouchbaseConnectionFactoryBuilder enables the customization of CouchbaseConnectionFactory settings.
CouchbaseConnectionFactoryBuilder() - Constructor for class com.couchbase.client.CouchbaseConnectionFactoryBuilder
 
CouchbaseMemcachedConnection - Class in com.couchbase.client
Couchbase implementation of CouchbaseConnection.
CouchbaseMemcachedConnection(int, CouchbaseConnectionFactory, List<InetSocketAddress>, Collection<ConnectionObserver>, FailureMode, OperationFactory) - Constructor for class com.couchbase.client.CouchbaseMemcachedConnection
 
CouchbaseNodeOrder - Enum in com.couchbase.client.vbucket
The CouchbaseNodeOrder helps with making sure that the streaming connection is not always bound to the same node.
CouchbaseProperties - Class in com.couchbase.client
The CouchbaseProperties class abstracts system properties and those set via a file exposed through a unified class.
create(File) - Method in interface com.couchbase.client.vbucket.config.ConfigFactory
 
create(String) - Method in interface com.couchbase.client.vbucket.config.ConfigFactory
 
create(JSONObject) - Method in interface com.couchbase.client.vbucket.config.ConfigFactory
 
create(JSONObject, Config) - Method in interface com.couchbase.client.vbucket.config.ConfigFactory
 
create(File) - Method in class com.couchbase.client.vbucket.config.DefaultConfigFactory
Create a Config from a File.
create(String) - Method in class com.couchbase.client.vbucket.config.DefaultConfigFactory
Create a Config from a raw JSON String.
create(JSONObject) - Method in class com.couchbase.client.vbucket.config.DefaultConfigFactory
Create a Config from a JSONObject.
create(JSONObject, Config) - Method in class com.couchbase.client.vbucket.config.DefaultConfigFactory
 
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.
createChannel() - Method in class com.couchbase.client.vbucket.BucketMonitor
 
createConnection(List<InetSocketAddress>) - Method in class com.couchbase.client.CouchbaseConnectionFactory
 
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
 
createDefaultBucket(BucketType, int, int, boolean) - Method in class com.couchbase.client.ClusterManager
Creates the default bucket.
createDesignDoc(DesignDocument) - Method in class com.couchbase.client.CouchbaseClient
 
createDesignDoc(DesignDocument) - Method in interface com.couchbase.client.CouchbaseClientIF
Store a design document in the cluster.
createLocator(List<MemcachedNode>) - Method in class com.couchbase.client.CouchbaseConnectionFactory
 
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
 
createNamedBucket(BucketType, String, int, int, String, boolean) - Method in class com.couchbase.client.ClusterManager
Creates a named bucket with a given password for SASL authentication.
createOperationQueue() - Method in interface net.spy.memcached.ConnectionFactory
Create a BlockingQueue for operations for a connection.
createOperationQueue() - Method in class net.spy.memcached.DefaultConnectionFactory
 
createPortBucket(BucketType, String, int, int, int, boolean) - Method in class com.couchbase.client.ClusterManager
Creates the a sasl bucket.
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
 
createViewConnection(List<InetSocketAddress>) - Method in class com.couchbase.client.CouchbaseConnectionFactory
 
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 com.couchbase.client.vbucket.provider.CouchbaseConfigConnection.LoggerProxy
 
debug(Object) - Method in class com.couchbase.client.vbucket.provider.CouchbaseConfigConnection.LoggerProxy
 
debug(String, Object...) - Method in class com.couchbase.client.vbucket.provider.CouchbaseConfigConnection.LoggerProxy
 
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 com.couchbase.client.vbucket.provider.GetConfigOperationImpl
 
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.ReplicaGetOperationImpl
 
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 com.couchbase.client.CouchbaseConnectionFactory
Default auth wait time.
DEFAULT_COMPRESSION_THRESHOLD - Static variable in class net.spy.memcached.transcoders.BaseSerializingTranscoder
Default compression threshold value.
DEFAULT_CONN_TIMEOUT - Static variable in class com.couchbase.client.ClusterManager
The default connection timeout in milliseconds.
DEFAULT_CONNS_PER_NODE - Static variable in class com.couchbase.client.ClusterManager
The default number fo max.
DEFAULT_FAILURE_MODE - Static variable in class com.couchbase.client.CouchbaseConnectionFactory
Default failure mode.
DEFAULT_FAILURE_MODE - Static variable in class net.spy.memcached.DefaultConnectionFactory
Default failure mode.
DEFAULT_HASH - Static variable in class com.couchbase.client.CouchbaseConnectionFactory
Default hash algorithm.
DEFAULT_HASH - Static variable in class net.spy.memcached.DefaultConnectionFactory
Default hash algorithm.
DEFAULT_IO_THREADS - Static variable in class com.couchbase.client.ClusterManager
The default number of IO (worker) threads to use.
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_MIN_RECONNECT_INTERVAL - Static variable in class com.couchbase.client.CouchbaseConnectionFactory
Specify a default minimum reconnect interval of 1.1s.
DEFAULT_OBS_POLL_INTERVAL - Static variable in class com.couchbase.client.CouchbaseConnectionFactory
Default Observe poll interval in ms.
DEFAULT_OBS_POLL_MAX - Static variable in class com.couchbase.client.CouchbaseConnectionFactory
Deprecated.
DEFAULT_OBS_TIMEOUT - Static variable in class com.couchbase.client.CouchbaseConnectionFactory
Default Timeout when persistence/replication constraints are used (in ms).
DEFAULT_OP_QUEUE_LEN - Static variable in class com.couchbase.client.CouchbaseConnectionFactory
Maximum length of the operation queue returned by this connection factory.
DEFAULT_OP_QUEUE_LEN - Static variable in class net.spy.memcached.DefaultConnectionFactory
Maximum length of the operation queue returned by this connection factory.
DEFAULT_OP_QUEUE_MAX_BLOCK_TIME - Static variable in class net.spy.memcached.DefaultConnectionFactory
The maximum time to block waiting for op queue operations to complete, in milliseconds.
DEFAULT_OPERATION_TIMEOUT - Static variable in class net.spy.memcached.DefaultConnectionFactory
Default operation timeout in milliseconds.
DEFAULT_READ_BUFFER_SIZE - Static variable in class net.spy.memcached.DefaultConnectionFactory
The read buffer size for each server connection from this factory.
DEFAULT_REPORTER_INTERVAL - Static variable in class net.spy.memcached.metrics.DefaultMetricCollector
Log every 30 seconds to the console by default.
DEFAULT_REPORTER_OUTDIR - Static variable in class net.spy.memcached.metrics.DefaultMetricCollector
Define an empty directory for the CSV exporter by default.
DEFAULT_REPORTER_TYPE - Static variable in class net.spy.memcached.metrics.DefaultMetricCollector
Use the "console" reporter by default.
DEFAULT_SOCKET_TIMEOUT - Static variable in class com.couchbase.client.ClusterManager
The default socket timeout in milliseconds.
DEFAULT_STREAMING_NODE_ORDER - Static variable in class com.couchbase.client.CouchbaseConnectionFactory
Default Node ordering to use for streaming connection.
DEFAULT_TCP_NODELAY - Static variable in class com.couchbase.client.ClusterManager
By default, enable tcp nodelay.
DEFAULT_VIEW_CONNS_PER_NODE - Static variable in class com.couchbase.client.CouchbaseConnectionFactory
Default amount of max connections per node.
DEFAULT_VIEW_TIMEOUT - Static variable in class com.couchbase.client.CouchbaseConnectionFactory
Default View request timeout in ms.
DEFAULT_VIEW_WORKER_SIZE - Static variable in class com.couchbase.client.CouchbaseConnectionFactory
Default size of view io worker threads.
DefaultConfigFactory - Class in com.couchbase.client.vbucket.config
A ConfigFactory for creating a Config out of raw JSON.
DefaultConfigFactory() - Constructor for class com.couchbase.client.vbucket.config.DefaultConfigFactory
 
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
Create a new DefaultMetricCollector.
delete(String, PersistTo, ReplicateTo) - Method in class com.couchbase.client.CouchbaseClient
 
delete(String, PersistTo) - Method in class com.couchbase.client.CouchbaseClient
 
delete(String, ReplicateTo) - Method in class com.couchbase.client.CouchbaseClient
 
delete(String, PersistTo) - Method in interface com.couchbase.client.CouchbaseClientIF
Delete a value with durability options for persistence.
delete(String, PersistTo, ReplicateTo) - Method in interface com.couchbase.client.CouchbaseClientIF
Delete a value with durability options.
delete(String, ReplicateTo) - Method in interface com.couchbase.client.CouchbaseClientIF
Delete a value with durability options for replication.
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
 
deleteBucket(String) - Method in class com.couchbase.client.ClusterManager
Deletes a bucket.
deleteDesignDoc(String) - Method in class com.couchbase.client.CouchbaseClient
 
deleteDesignDoc(String) - Method in interface com.couchbase.client.CouchbaseClientIF
Delete a design document in the cluster.
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.
DesignDocFetcherOperation - Interface in com.couchbase.client.protocol.views
A ViewsOperation.
DesignDocFetcherOperation.DesignDocFetcherCallback - Interface in com.couchbase.client.protocol.views
A ViewsCallback.
DesignDocFetcherOperationImpl - Class in com.couchbase.client.protocol.views
Implements the design doc fetching HTTP operation.
DesignDocFetcherOperationImpl(HttpRequest, String, DesignDocFetcherOperation.DesignDocFetcherCallback) - Constructor for class com.couchbase.client.protocol.views.DesignDocFetcherOperationImpl
 
DesignDocOperation - Interface in com.couchbase.client.protocol.views
Base class for all Design Document Operations.
DesignDocOperation.DesignDocCallback - Interface in com.couchbase.client.protocol.views
Callback for the result of the DesignDocOperation.
DesignDocOperationImpl - Class in com.couchbase.client.protocol.views
Implements design document storing and deleting.
DesignDocOperationImpl(HttpRequest, OperationCallback) - Constructor for class com.couchbase.client.protocol.views.DesignDocOperationImpl
 
DesignDocument - Class in com.couchbase.client.protocol.views
The DesignDocument represents a design document stored and retrieved from a Couchbase cluster.
DesignDocument(String) - Constructor for class com.couchbase.client.protocol.views.DesignDocument
Create a new DesignDocument with a name.
DesignDocument(String, List<ViewDesign>, List<SpatialViewDesign>) - Constructor for class com.couchbase.client.protocol.views.DesignDocument
Create a new DesignDocument with a name and (spatial) views.
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
 
DocsOperationImpl - Class in com.couchbase.client.protocol.views
Implementation of a view that calls the map function and includes the documents in the result.
DocsOperationImpl(HttpRequest, AbstractView, ViewOperation.ViewCallback) - Constructor for class com.couchbase.client.protocol.views.DocsOperationImpl
 
doDump() - Method in class net.spy.memcached.tapmessage.MessageBuilder
 

E

emptyArray() - Static method in class com.couchbase.client.protocol.views.ComplexKey
Returns an empty array of objects.
emptyObject() - Static method in class com.couchbase.client.protocol.views.ComplexKey
Returns a single empty object.
enableMetrics() - Method in interface net.spy.memcached.ConnectionFactory
If true, metric collections are enabled.
enableMetrics() - Method in class net.spy.memcached.DefaultConnectionFactory
 
encode(String) - Method in class com.couchbase.client.protocol.views.Query
Helper method to properly encode a string.
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
 
entrySet() - Method in class net.spy.memcached.BaseCacheMap
 
equals(Object) - Method in class com.couchbase.client.vbucket.config.Bucket
 
equals(Object) - Method in class com.couchbase.client.vbucket.config.Node
 
equals(Object) - Method in class com.couchbase.client.vbucket.ReconfigurableObserver
 
error(Object, Throwable) - Method in class com.couchbase.client.vbucket.provider.CouchbaseConfigConnection.LoggerProxy
 
error(Object) - Method in class com.couchbase.client.vbucket.provider.CouchbaseConfigConnection.LoggerProxy
 
error(String, Object...) - Method in class com.couchbase.client.vbucket.provider.CouchbaseConfigConnection.LoggerProxy
 
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.
errors - Variable in class com.couchbase.client.protocol.views.ViewResponse
 
errorStoring(String, Exception) - Method in interface net.spy.memcached.util.CacheLoader.StorageListener
 
exception - Variable in class com.couchbase.client.protocol.views.HttpOperationImpl
 
exceptionCaught(ChannelHandlerContext, ExceptionEvent) - Method in class com.couchbase.client.vbucket.BucketUpdateResponseHandler
 
executor() - Method in class net.spy.memcached.internal.AbstractListenableFuture
Returns the current executor.
executorService - Variable in class com.couchbase.client.CouchbaseClient
 
executorService - Variable in class com.couchbase.client.CouchbaseConnectionFactoryBuilder
 
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

failed(Exception) - Method in class com.couchbase.client.http.HttpResponseCallback
 
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
 
fatal(Object, Throwable) - Method in class com.couchbase.client.vbucket.provider.CouchbaseConfigConnection.LoggerProxy
 
fatal(Object) - Method in class com.couchbase.client.vbucket.provider.CouchbaseConfigConnection.LoggerProxy
 
fatal(String, Object...) - Method in class com.couchbase.client.vbucket.provider.CouchbaseConfigConnection.LoggerProxy
 
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.OptimizedSetImpl
 
finishedPayload(byte[]) - Method in class net.spy.memcached.protocol.binary.SASLBaseOperationImpl
 
finishedPayload(byte[]) - Method in class net.spy.memcached.protocol.binary.StatsOperationImpl
 
finishResubscribe() - Method in interface com.couchbase.client.vbucket.ConfigurationProvider
 
finishResubscribe() - Method in class com.couchbase.client.vbucket.ConfigurationProviderHTTP
 
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() - Method in class com.couchbase.client.CouchbaseClient
Flush all data from the bucket immediately.
flush(int) - Method in class com.couchbase.client.CouchbaseClient
Flush all caches from all servers with a delay of application.
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
 
flushBucket(String) - Method in class com.couchbase.client.ClusterManager
Deletes all data in a bucket.
FlushOperation - Interface in net.spy.memcached.ops
Flush operation marker.
FlushResponse - Enum in com.couchbase.client.clustermanager
Contains the possible responses that can come up when flushing a bucket.
forceArray(boolean) - Method in class com.couchbase.client.protocol.views.ComplexKey
Force the cast to a JSON array even when there is only one element.
forceKeyType(Class<?>) - Method in class com.couchbase.client.protocol.views.Paginator
Allows one to override the type of the row key.
foundIncorrectMaster(int, int) - Method in interface com.couchbase.client.vbucket.config.Config
 
foundIncorrectMaster(int, int) - Method in class com.couchbase.client.vbucket.config.CouchbaseConfig
 
foundIncorrectMaster(int, int) - Method in class com.couchbase.client.vbucket.config.MemcacheConfig
 

G

GenericCompletionListener<F extends java.util.concurrent.Future<?>> - Interface in net.spy.memcached.internal
A generic listener that will be notified once the future completes.
get() - Method in class com.couchbase.client.internal.HttpFuture
 
get(long, TimeUnit) - Method in class com.couchbase.client.internal.HttpFuture
 
get() - Method in class com.couchbase.client.internal.ReplicaGetFuture
 
get(long, TimeUnit) - Method in class com.couchbase.client.internal.ReplicaGetFuture
 
get(long, TimeUnit) - Method in class com.couchbase.client.internal.ViewFuture
 
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 com.couchbase.client.vbucket.VBucketNodeLocator
Get all memcached nodes.
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.
getAlternative(String, Collection<MemcachedNode>) - Method in class com.couchbase.client.vbucket.VBucketNodeLocator
Method returns the node that is not contained in the specified collection of the failed nodes.
getAndLock(String, int, Transcoder<T>) - Method in class com.couchbase.client.CouchbaseClient
 
getAndLock(String, int) - Method in class com.couchbase.client.CouchbaseClient
 
getAndLock(String, int, Transcoder<T>) - Method in interface com.couchbase.client.CouchbaseClientIF
Getl with a single key.
getAndLock(String, int) - Method in interface com.couchbase.client.CouchbaseClientIF
Get and lock with a single key and decode using the default transcoder.
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
 
getAnonymousAuthBucket() - Method in interface com.couchbase.client.vbucket.ConfigurationProvider
Retrieves a default bucket name i.e.
getAnonymousAuthBucket() - Method in class com.couchbase.client.vbucket.ConfigurationProviderHTTP
 
getAnonymousAuthBucket() - Method in class com.couchbase.client.vbucket.provider.BucketConfigurationProvider
 
getAnonymousAuthBucket() - Method in interface com.couchbase.client.vbucket.provider.ConfigurationProvider
Retrieves a default bucket name i.e.
getArgs() - Method in class com.couchbase.client.protocol.views.Query
Helper method which collects all currently set arguments.
getAuthDescriptor() - Method in class com.couchbase.client.CouchbaseConnectionFactory
 
getAuthDescriptor() - Method in interface net.spy.memcached.ConnectionFactory
Authenticate connections using the given auth descriptor.
getAuthDescriptor() - Method in class net.spy.memcached.DefaultConnectionFactory
 
getAuthType() - Method in enum com.couchbase.client.clustermanager.AuthType
 
getAuthWaitTime() - Method in class com.couchbase.client.CouchbaseConnectionFactory
 
getAuthWaitTime() - Method in class com.couchbase.client.CouchbaseConnectionFactoryBuilder
Returns the currently configured authentication wait time.
getAvailableServers() - Method in class net.spy.memcached.MemcachedClient
Get the addresses of available servers.
getAvailableServers() - Method in interface net.spy.memcached.MemcachedClientIF
 
getBbox() - Method in class com.couchbase.client.protocol.views.SpatialViewRowNoDocs
 
getBbox() - Method in class com.couchbase.client.protocol.views.SpatialViewRowWithDocs
 
getBbox() - Method in interface com.couchbase.client.protocol.views.ViewRow
 
getBbox() - Method in class com.couchbase.client.protocol.views.ViewRowNoDocs
 
getBbox() - Method in class com.couchbase.client.protocol.views.ViewRowReduced
 
getBbox() - Method in class com.couchbase.client.protocol.views.ViewRowWithDocs
 
getBody() - Method in class com.couchbase.client.ClusterManager.HttpResult
 
getBucket() - Method in interface com.couchbase.client.vbucket.ConfigurationProvider
Returns the current bucket name.
getBucket() - Method in class com.couchbase.client.vbucket.ConfigurationProviderHTTP
Returns the current bucket name.
getBucketConfiguration(String) - Method in interface com.couchbase.client.vbucket.ConfigurationProvider
Connects to the REST service and retrieves the bucket configuration from the first pool available.
getBucketConfiguration(String) - Method in class com.couchbase.client.vbucket.ConfigurationProviderHTTP
Connects to the REST service and retrieves the bucket configuration from the first pool available.
getBucketName() - Method in class com.couchbase.client.CouchbaseConnectionFactory
 
getBucketsUri() - Method in class com.couchbase.client.vbucket.config.Pool
 
getBucketType() - Method in enum com.couchbase.client.clustermanager.BucketType
 
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 interface com.couchbase.client.protocol.views.HttpOperation
 
getCallback() - Method in class com.couchbase.client.protocol.views.HttpOperationImpl
 
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 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.
getClusterManager() - Method in class com.couchbase.client.CouchbaseConnectionFactory
Returns a ClusterManager and initializes one if it does not exist.
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.
getConfig() - Method in class com.couchbase.client.vbucket.config.Bucket
 
getConfig() - Method in class com.couchbase.client.vbucket.provider.BucketConfigurationProvider
 
getConfig() - Method in interface com.couchbase.client.vbucket.provider.ConfigurationProvider
Returns the current Bucket configuration.
GetConfigOperationImpl - Class in com.couchbase.client.vbucket.provider
 
GetConfigOperationImpl(OperationCallback) - Constructor for class com.couchbase.client.vbucket.provider.GetConfigOperationImpl
 
getConfigType() - Method in interface com.couchbase.client.vbucket.config.Config
 
getConfigType() - Method in class com.couchbase.client.vbucket.config.CouchbaseConfig
 
getConfigType() - Method in class com.couchbase.client.vbucket.config.MemcacheConfig
 
getConfigurationProvider() - Method in class com.couchbase.client.CouchbaseConnectionFactory
 
getConn() - Method in class net.spy.memcached.tapmessage.TapAck
 
getConnectionsPerNode() - Method in class com.couchbase.client.ClusterManagerBuilder
Returns the max connections per node.
getConnectionTimeout() - Method in class com.couchbase.client.ClusterManagerBuilder
Returns the connection timeout.
getContinuousTimeout() - Method in interface net.spy.memcached.MemcachedNode
 
getContinuousTimeout() - Method in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
getCouchServers() - Method in interface com.couchbase.client.vbucket.config.Config
 
getCouchServers() - Method in class com.couchbase.client.vbucket.config.CouchbaseConfig
 
getCouchServers() - Method in class com.couchbase.client.vbucket.config.MemcacheConfig
 
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.
getDatabaseName() - Method in class com.couchbase.client.protocol.views.AbstractView
Returns the database (bucket) name.
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
 
getDesignDoc(String) - Method in class com.couchbase.client.CouchbaseClient
 
getDesignDoc(String) - Method in interface com.couchbase.client.CouchbaseClientIF
Returns a representation of a design document stored in the cluster.
getDesignDocument(String) - Method in class com.couchbase.client.CouchbaseClient
Deprecated.
getDesignDocument(String) - Method in interface com.couchbase.client.CouchbaseClientIF
Deprecated.
getDesignDocumentName() - Method in class com.couchbase.client.protocol.views.AbstractView
Returns the design document name.
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.
getDocument() - Method in class com.couchbase.client.protocol.views.SpatialViewRowNoDocs
 
getDocument() - Method in class com.couchbase.client.protocol.views.SpatialViewRowWithDocs
 
getDocument() - Method in interface com.couchbase.client.protocol.views.ViewRow
 
getDocument() - Method in class com.couchbase.client.protocol.views.ViewRowNoDocs
 
getDocument() - Method in class com.couchbase.client.protocol.views.ViewRowReduced
 
getDocument() - Method in class com.couchbase.client.protocol.views.ViewRowWithDocs
 
getEnginePrivate() - Method in class net.spy.memcached.tapmessage.ResponseMessage
Gets the value of the engine private field.
getEntityString(HttpResponse) - Method in class com.couchbase.client.protocol.views.HttpOperationImpl
 
getErrorCode() - Method in class com.couchbase.client.ClusterManager.HttpResult
 
getErrorPhrase() - Method in class com.couchbase.client.ClusterManager.HttpResult
 
getErrors() - Method in class com.couchbase.client.protocol.views.ViewResponse
 
getException() - Method in interface com.couchbase.client.protocol.views.HttpOperation
 
getException() - Method in class com.couchbase.client.protocol.views.HttpOperationImpl
 
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.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.
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
 
getFrom() - Method in class com.couchbase.client.protocol.views.RowError
 
getFromReplica(String) - Method in class com.couchbase.client.CouchbaseClient
 
getFromReplica(String, Transcoder<T>) - Method in class com.couchbase.client.CouchbaseClient
 
getFromReplica(String) - Method in interface com.couchbase.client.CouchbaseClientIF
Get a document from the replica (or the active) nodes.
getFromReplica(String, Transcoder<T>) - Method in interface com.couchbase.client.CouchbaseClientIF
Get a document from the replica (or the active) nodes and use a custom transcoder.
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
 
getGeometry() - Method in class com.couchbase.client.protocol.views.SpatialViewRowNoDocs
 
getGeometry() - Method in class com.couchbase.client.protocol.views.SpatialViewRowWithDocs
 
getGeometry() - Method in interface com.couchbase.client.protocol.views.ViewRow
 
getGeometry() - Method in class com.couchbase.client.protocol.views.ViewRowNoDocs
 
getGeometry() - Method in class com.couchbase.client.protocol.views.ViewRowReduced
 
getGeometry() - Method in class com.couchbase.client.protocol.views.ViewRowWithDocs
 
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
 
getHashAlgorithm() - Method in interface com.couchbase.client.vbucket.config.Config
 
getHashAlgorithm() - Method in class com.couchbase.client.vbucket.config.CouchbaseConfig
 
getHashAlgorithm() - Method in class com.couchbase.client.vbucket.config.MemcacheConfig
 
getHostname() - Method in class com.couchbase.client.vbucket.config.Node
 
getHttpPass() - Method in class com.couchbase.client.vbucket.BucketMonitor
 
getHttpUser() - Method in class com.couchbase.client.vbucket.BucketMonitor
 
getId() - Method in class com.couchbase.client.protocol.views.SpatialViewRowNoDocs
 
getId() - Method in class com.couchbase.client.protocol.views.SpatialViewRowWithDocs
 
getId() - Method in interface com.couchbase.client.protocol.views.ViewRow
 
getId() - Method in class com.couchbase.client.protocol.views.ViewRowNoDocs
 
getId() - Method in class com.couchbase.client.protocol.views.ViewRowReduced
 
getId() - Method in class com.couchbase.client.protocol.views.ViewRowWithDocs
 
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
 
getIoThreadCount() - Method in class com.couchbase.client.ClusterManagerBuilder
Returns the HTTP IO (worker) count.
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 com.couchbase.client.protocol.views.SpatialViewRowNoDocs
 
getKey() - Method in class com.couchbase.client.protocol.views.SpatialViewRowWithDocs
 
getKey() - Method in interface com.couchbase.client.protocol.views.ViewRow
 
getKey() - Method in class com.couchbase.client.protocol.views.ViewRowNoDocs
 
getKey() - Method in class com.couchbase.client.protocol.views.ViewRowReduced
 
getKey() - Method in class com.couchbase.client.protocol.views.ViewRowWithDocs
 
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.
getKeyStats(String) - Method in class com.couchbase.client.CouchbaseClient
 
getKeyStats(String) - Method in interface com.couchbase.client.CouchbaseClientIF
 
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
 
getLanguage() - Method in class com.couchbase.client.protocol.views.DesignDocument
Get the language of the views.
getLastResponse() - Method in class com.couchbase.client.vbucket.BucketUpdateResponseHandler
 
getLatestConfig(String) - Method in class com.couchbase.client.vbucket.ConfigurationProviderHTTP
 
getLimit() - Method in class com.couchbase.client.protocol.views.Query
Returns the currently set limit.
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
Get the node locator used by this connection.
getLogger() - Method in class com.couchbase.client.vbucket.provider.CouchbaseConfigConnection
 
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
 
getMap() - Method in class com.couchbase.client.protocol.views.SpatialViewDesign
Get the map function of the spatial view.
getMap() - Method in class com.couchbase.client.protocol.views.ViewDesign
Get the map function of the view.
getMap() - Method in class com.couchbase.client.protocol.views.ViewResponse
 
getMap() - Method in class com.couchbase.client.protocol.views.ViewResponseNoDocs
 
getMap() - Method in class com.couchbase.client.protocol.views.ViewResponseReduced
 
getMap() - Method in class com.couchbase.client.protocol.views.ViewResponseWithDocs
 
getMaster(int) - Method in interface com.couchbase.client.vbucket.config.Config
 
getMaster(int) - Method in class com.couchbase.client.vbucket.config.CouchbaseConfig
 
getMaster(int) - Method in class com.couchbase.client.vbucket.config.MemcacheConfig
 
getMaster() - Method in class com.couchbase.client.vbucket.config.VBucket
 
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 com.couchbase.client.TapClient
The number of messages read by all of the tap streams created with this client.
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
 
getMinReconnectInterval() - Method in class com.couchbase.client.CouchbaseConnectionFactory
The minimum reconnect interval in milliseconds.
getName() - Method in class com.couchbase.client.protocol.views.DesignDocument
Get the name of the design document.
getName() - Method in class com.couchbase.client.protocol.views.SpatialViewDesign
Get the name of the spatial view.
getName() - Method in class com.couchbase.client.protocol.views.ViewDesign
Get the name of the view.
getName() - Method in class com.couchbase.client.vbucket.config.Bucket
 
getName() - Method in class com.couchbase.client.vbucket.config.Pool
 
getName() - Method in class com.couchbase.client.vbucket.provider.CouchbaseConfigConnection.LoggerProxy
 
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
 
getNamespace() - Static method in class com.couchbase.client.CouchbaseProperties
Returns the namespace to be used for the properties.
getNewValue(T) - Method in interface net.spy.memcached.CASMutation
Get the new value to replace the current value.
getNextMessage() - Method in class com.couchbase.client.TapClient
Gets the next tap message from the queue of received tap messages.
getNextMessage(long, TimeUnit) - Method in class com.couchbase.client.TapClient
Gets the next tap message from the queue of received tap messages.
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
 
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
 
getNumVBuckets() - Method in class com.couchbase.client.CouchbaseClient
 
getNumVBuckets() - Method in interface com.couchbase.client.CouchbaseClientIF
Gets the number of vBuckets that are contained in the cluster.
getObject() - Method in class net.spy.memcached.spring.MemcachedClientFactoryBean
 
getObjectType() - Method in class net.spy.memcached.spring.MemcachedClientFactoryBean
 
getObsPollInterval() - Method in class com.couchbase.client.CouchbaseConnectionFactory
The observe poll interval in milliseconds.
getObsPollInterval() - Method in class com.couchbase.client.CouchbaseConnectionFactoryBuilder
Returns the currently set observe poll interval.
getObsPollMax() - Method in class com.couchbase.client.CouchbaseConnectionFactory
The number of observe polls to execute before giving up.
getObsPollMax() - Method in class com.couchbase.client.CouchbaseConnectionFactoryBuilder
Deprecated.
getObsTimeout() - Method in class com.couchbase.client.CouchbaseConnectionFactory
The observe timeout in milliseconds.
getObsTimeout() - Method in class com.couchbase.client.CouchbaseConnectionFactoryBuilder
Returns the currently set observe timeout.
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
 
getPipeline() - Method in class com.couchbase.client.vbucket.BucketMonitorPipelineFactory
 
getPorts() - Method in class com.couchbase.client.vbucket.config.Node
 
getPrimary(String) - Method in class com.couchbase.client.vbucket.VBucketNodeLocator
Get the primary location for the given key.
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.
getProperty(String, String, boolean) - Static method in class com.couchbase.client.CouchbaseProperties
Returns the property for the given name (or given default if not set).
getProperty(String, boolean) - Static method in class com.couchbase.client.CouchbaseProperties
Returns the property for the given name (or null if not set).
getProperty(String) - Static method in class com.couchbase.client.CouchbaseProperties
Returns the property for the given name (or null if not set).
getProperty(String, String) - Static method in class com.couchbase.client.CouchbaseProperties
Returns the property for the given name (or given default if not set).
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 com.couchbase.client.vbucket.VBucketNodeLocator
Create a read-only copy of this NodeLocator.
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.
getReason() - Method in class com.couchbase.client.ClusterManager.HttpResult
 
getReason() - Method in class com.couchbase.client.protocol.views.RowError
 
getReconfigurable() - Method in interface com.couchbase.client.vbucket.ConfigurationProvider
Returns the current Reconfigurable object.
getReconfigurable() - Method in class com.couchbase.client.vbucket.ConfigurationProviderHTTP
Returns the current Reconfigurable object.
getReconnectCount() - Method in interface net.spy.memcached.MemcachedNode
Get the current reconnect count.
getReconnectCount() - Method in class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
getReduce() - Method in class com.couchbase.client.protocol.views.ViewDesign
Get the reduce function of the view.
getReplica(int, int) - Method in interface com.couchbase.client.vbucket.config.Config
 
getReplica(int, int) - Method in class com.couchbase.client.vbucket.config.CouchbaseConfig
 
getReplica(int, int) - Method in class com.couchbase.client.vbucket.config.MemcacheConfig
 
getReplica(int) - Method in class com.couchbase.client.vbucket.config.VBucket
 
getReplica(String, int) - Method in class com.couchbase.client.vbucket.VBucketNodeLocator
Return a replica node for the given key and replica index.
getReplicaIndex() - Method in interface net.spy.memcached.ops.ReplicaGetOperation
 
getReplicaIndex() - Method in class net.spy.memcached.protocol.binary.ReplicaGetOperationImpl
 
getReplicaIndexes(String) - Method in class com.couchbase.client.vbucket.VBucketNodeLocator
Gets a list of vBucket indexes for the current replicas defined.
getReplicasCount() - Method in interface com.couchbase.client.vbucket.config.Config
 
getReplicasCount() - Method in class com.couchbase.client.vbucket.config.CouchbaseConfig
 
getReplicasCount() - Method in class com.couchbase.client.vbucket.config.MemcacheConfig
 
getRequest() - Method in interface com.couchbase.client.protocol.views.HttpOperation
 
getRequest() - Method in class com.couchbase.client.protocol.views.HttpOperationImpl
 
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
 
getRestEndpoints() - Method in interface com.couchbase.client.vbucket.config.Config
 
getRestEndpoints() - Method in class com.couchbase.client.vbucket.config.CouchbaseConfig
 
getRestEndpoints() - Method in class com.couchbase.client.vbucket.config.MemcacheConfig
 
getResult() - Method in class net.spy.memcached.compat.SyncThread
Get the result from the invocation.
getRevID() - Method in class net.spy.memcached.tapmessage.ResponseMessage
Gets the value of the revid field.
getRevision() - Method in class com.couchbase.client.vbucket.config.Bucket
 
getROBuckets() - Method in class com.couchbase.client.vbucket.config.Pool
 
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 com.couchbase.client.vbucket.VBucketNodeLocator
Get an iterator over the sequence of nodes that make up the backup locations for a given key.
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.
getServer(int) - Method in interface com.couchbase.client.vbucket.config.Config
 
getServer(int) - Method in class com.couchbase.client.vbucket.config.CouchbaseConfig
 
getServer(int) - Method in class com.couchbase.client.vbucket.config.MemcacheConfig
 
getServerByIndex(int) - Method in class com.couchbase.client.vbucket.VBucketNodeLocator
 
getServerList(String) - Method in class com.couchbase.client.vbucket.ConfigurationProviderHTTP
 
getServers() - Method in interface com.couchbase.client.vbucket.config.Config
 
getServers() - Method in class com.couchbase.client.vbucket.config.CouchbaseConfig
 
getServers() - Method in class com.couchbase.client.vbucket.config.MemcacheConfig
 
getServersAdded() - Method in class com.couchbase.client.vbucket.config.ConfigDifference
 
getServersCount() - Method in interface com.couchbase.client.vbucket.config.Config
 
getServersCount() - Method in class com.couchbase.client.vbucket.config.CouchbaseConfig
 
getServersCount() - Method in class com.couchbase.client.vbucket.config.MemcacheConfig
 
getServersRemoved() - Method in class com.couchbase.client.vbucket.config.ConfigDifference
 
getsFromReplica(String) - Method in class com.couchbase.client.CouchbaseClient
 
getsFromReplica(String, Transcoder<T>) - Method in class com.couchbase.client.CouchbaseClient
 
getsFromReplica(String) - Method in interface com.couchbase.client.CouchbaseClientIF
Get a document and its CAS from the replica (or the active) nodes.
getsFromReplica(String, Transcoder<T>) - Method in interface com.couchbase.client.CouchbaseClientIF
Get a document and its CAS from the replica (or the active) nodes and use a custom transcoder.
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.
getSocketTimeout() - Method in class com.couchbase.client.ClusterManagerBuilder
Returns the socket timeout for a connection.
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
 
getSpatialView(String, String) - Method in class com.couchbase.client.CouchbaseClient
 
getSpatialView(String, String) - Method in interface com.couchbase.client.CouchbaseClientIF
Gets access to a spatial view contained in a design document from the cluster.
getSpatialViews() - Method in class com.couchbase.client.protocol.views.DesignDocument
Return a list of all stored spatial views.
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 class com.couchbase.client.internal.HttpFuture
 
getStatus() - Method in class com.couchbase.client.vbucket.config.Node
 
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.
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
 
getStreamingNodeOrder() - Method in class com.couchbase.client.CouchbaseConnectionFactory
 
getStreamingNodeOrder() - Method in class com.couchbase.client.CouchbaseConnectionFactoryBuilder
Returns the currently configured streaming node order.
getStreamingURI() - Method in class com.couchbase.client.vbucket.config.Bucket
 
getStreamingUri() - Method in class com.couchbase.client.vbucket.config.Pool
 
getTcpNoDelay() - Method in class com.couchbase.client.ClusterManagerBuilder
Whether TCP NODELAY is used or not.
getThrottler(InetSocketAddress) - Method in class com.couchbase.client.internal.ThrottleManager
 
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.
getTotalRows() - Method in class com.couchbase.client.protocol.views.ViewResponse
 
getTotalRows() - Method in class com.couchbase.client.protocol.views.ViewResponseReduced
 
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
 
getURI() - Method in class com.couchbase.client.protocol.views.AbstractView
Returns the URI/String representation of the View.
getURI() - Method in class com.couchbase.client.protocol.views.SpatialView
Returns the URI/String representation of the Spatial View.
getURI() - Method in class com.couchbase.client.protocol.views.View
Returns the URI/String representation of the View.
getUri() - Method in class com.couchbase.client.vbucket.config.Pool
 
getValue() - Method in class com.couchbase.client.protocol.views.SpatialViewRowNoDocs
 
getValue() - Method in class com.couchbase.client.protocol.views.SpatialViewRowWithDocs
 
getValue() - Method in interface com.couchbase.client.protocol.views.ViewRow
 
getValue() - Method in class com.couchbase.client.protocol.views.ViewRowNoDocs
 
getValue() - Method in class com.couchbase.client.protocol.views.ViewRowReduced
 
getValue() - Method in class com.couchbase.client.protocol.views.ViewRowWithDocs
 
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.
getVbucketByKey(String) - Method in interface com.couchbase.client.vbucket.config.Config
 
getVbucketByKey(String) - Method in class com.couchbase.client.vbucket.config.CouchbaseConfig
 
getVbucketByKey(String) - Method in class com.couchbase.client.vbucket.config.MemcacheConfig
 
getVBucketConfig() - Method in class com.couchbase.client.CouchbaseConnectionFactory
 
getVBucketConfig() - Method in class com.couchbase.client.CouchbaseConnectionFactoryBuilder
Returns a potentially set configuration.
getVBucketIndex(String) - Method in class com.couchbase.client.vbucket.VBucketNodeLocator
Returns a vbucket index for the given key.
getVbuckets() - Method in interface com.couchbase.client.vbucket.config.Config
 
getVbuckets() - Method in class com.couchbase.client.vbucket.config.CouchbaseConfig
 
getVbuckets() - Method in class com.couchbase.client.vbucket.config.MemcacheConfig
 
getVbucketsChanges() - Method in class com.couchbase.client.vbucket.config.ConfigDifference
 
getVbucketsCount() - Method in interface com.couchbase.client.vbucket.config.Config
 
getVbucketsCount() - Method in class com.couchbase.client.vbucket.config.CouchbaseConfig
 
getVbucketsCount() - Method in class com.couchbase.client.vbucket.config.MemcacheConfig
 
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
 
getView(String, String) - Method in class com.couchbase.client.CouchbaseClient
 
getView(String, String) - Method in interface com.couchbase.client.CouchbaseClientIF
Gets access to a view contained in a design document from the cluster.
getView() - Method in class com.couchbase.client.protocol.views.ViewOperationImpl
 
getViewConnsPerNode() - Method in class com.couchbase.client.CouchbaseConnectionFactory
 
getViewConnsPerNode() - Method in class com.couchbase.client.CouchbaseConnectionFactoryBuilder
The currently configured number of maximum open view connections per node.
getViewName() - Method in class com.couchbase.client.protocol.views.AbstractView
Returns the view name.
getViews() - Method in class com.couchbase.client.protocol.views.DesignDocument
Get the list of the associated view designs.
getViewTimeout() - Method in class com.couchbase.client.CouchbaseConnectionFactory
 
getViewTimeout() - Method in class com.couchbase.client.CouchbaseConnectionFactoryBuilder
Returns the currently set view timeout.
getViewWorkerSize() - Method in class com.couchbase.client.CouchbaseConnectionFactory
 
getViewWorkerSize() - Method in class com.couchbase.client.CouchbaseConnectionFactoryBuilder
The currently configured number of view workers.
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(DesignDocument) - Method in interface com.couchbase.client.protocol.views.DesignDocFetcherOperation.DesignDocFetcherCallback
 
gotData(String) - Method in interface com.couchbase.client.protocol.views.DesignDocOperation.DesignDocCallback
 
gotData(ViewResponse) - Method in interface com.couchbase.client.protocol.views.NoDocsOperation.NoDocsCallback
 
gotData(ViewResponse) - Method in interface com.couchbase.client.protocol.views.ReducedOperation.ReducedCallback
 
gotData(SpatialView) - Method in interface com.couchbase.client.protocol.views.SpatialViewFetcherOperation.ViewFetcherCallback
 
gotData(View) - Method in interface com.couchbase.client.protocol.views.ViewFetcherOperation.ViewFetcherCallback
 
gotData(ViewResponse) - Method in interface com.couchbase.client.protocol.views.ViewOperation.ViewCallback
 
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, 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
MemcachedClient calls this method to handle IO over the connections.
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
 
handleResponse(HttpResponse) - Method in class com.couchbase.client.protocol.views.DesignDocFetcherOperationImpl
 
handleResponse(HttpResponse) - Method in class com.couchbase.client.protocol.views.DesignDocOperationImpl
 
handleResponse(HttpResponse) - Method in interface com.couchbase.client.protocol.views.HttpOperation
 
handleResponse(HttpResponse) - Method in class com.couchbase.client.protocol.views.HttpOperationImpl
 
handleResponse(HttpResponse) - Method in class com.couchbase.client.protocol.views.SpatialViewFetcherOperationImpl
 
handleResponse(HttpResponse) - Method in class com.couchbase.client.protocol.views.ViewFetcherOperationImpl
 
handleResponse(HttpResponse) - Method in class com.couchbase.client.protocol.views.ViewOperationImpl
 
handleRetryInformation(byte[]) - Method in class com.couchbase.client.CouchbaseConnection
 
handleUpstream(ChannelHandlerContext, ChannelEvent) - Method in class com.couchbase.client.vbucket.BucketUpdateResponseHandler
 
handleWokenUpSelector() - Method in class com.couchbase.client.CouchbaseConnection
Make sure that if the selector is woken up manually for an extended period of time that the sockets are still alive.
handleWokenUpSelector() - Method in class com.couchbase.client.CouchbaseMemcachedConnection
Make sure that if the selector is woken up manually for an extended period of time that the sockets are still alive.
hasActiveMaster(String) - Method in class com.couchbase.client.vbucket.VBucketNodeLocator
Checks if in the current vbucket the master is not "-1".
hasBucket(String) - Method in class com.couchbase.client.vbucket.config.Pool
 
hasErrored() - Method in interface com.couchbase.client.protocol.views.HttpOperation
 
hasErrored() - Method in class com.couchbase.client.protocol.views.HttpOperationImpl
 
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.
hashCode() - Method in class com.couchbase.client.vbucket.config.Bucket
 
hashCode() - Method in class com.couchbase.client.vbucket.config.Node
 
hashCode() - Method in class com.couchbase.client.vbucket.ReconfigurableObserver
 
hasMap() - Method in class com.couchbase.client.protocol.views.AbstractView
Checks if the view has a "map" method defined.
hasMap() - Method in class com.couchbase.client.protocol.views.SpatialView
Will always return true, because Spatial Views need to have a map function.
hasMap() - Method in class com.couchbase.client.protocol.views.View
Checks if the view has a "map" method defined.
hasMoreMessages() - Method in class com.couchbase.client.TapClient
Decides whether the client has received tap messages or will receive more messages in the future.
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 com.couchbase.client.protocol.views.Paginator
Check if another Page is available.
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
 
hasReduce() - Method in class com.couchbase.client.protocol.views.AbstractView
Checks if the view has a "reduce" method defined.
hasReduce() - Method in class com.couchbase.client.protocol.views.SpatialView
Will always return false, because Spatial Views can't have reduce functions.
hasReduce() - Method in class com.couchbase.client.protocol.views.View
Checks if the view has a "reduce" method defined.
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
 
HttpCompletionListener - Interface in com.couchbase.client.internal
A listener that will be notified once the http future completes.
HttpFuture<T> - Class in com.couchbase.client.internal
A future http response.
HttpFuture(CountDownLatch, long, ExecutorService) - Constructor for class com.couchbase.client.internal.HttpFuture
 
HttpOperation - Interface in com.couchbase.client.protocol.views
A Helper class for HttpOperation.
HttpOperationImpl - Class in com.couchbase.client.protocol.views
An HttpOperationImpl.
HttpOperationImpl(HttpRequest, OperationCallback) - Constructor for class com.couchbase.client.protocol.views.HttpOperationImpl
 
HttpResponseCallback - Class in com.couchbase.client.http
Describes a FutureCallback for asynchronous View responses.
HttpResponseCallback(HttpOperation, ViewConnection, HttpHost) - Constructor for class com.couchbase.client.http.HttpResponseCallback
Create a new callback.
HttpUtil - Class in com.couchbase.client.http
 

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 com.couchbase.client.vbucket.provider.CouchbaseConfigConnection.LoggerProxy
 
info(Object) - Method in class com.couchbase.client.vbucket.provider.CouchbaseConfigConnection.LoggerProxy
 
info(String, Object...) - Method in class com.couchbase.client.vbucket.provider.CouchbaseConfigConnection.LoggerProxy
 
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 class com.couchbase.client.vbucket.provider.GetConfigOperationImpl
 
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.OptimizedSetImpl
 
initialize() - Method in class net.spy.memcached.protocol.binary.ReplicaGetOperationImpl
 
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
 
IntegerTranscoder - Class in net.spy.memcached.transcoders
Transcoder that serializes and unserializes longs.
IntegerTranscoder() - Constructor for class net.spy.memcached.transcoders.IntegerTranscoder
 
InvalidViewException - Exception in com.couchbase.client.protocol.views
Is thrown when either the design doc or the view is not found in the cluster.
InvalidViewException() - Constructor for exception com.couchbase.client.protocol.views.InvalidViewException
 
InvalidViewException(String) - Constructor for exception com.couchbase.client.protocol.views.InvalidViewException
 
InvalidViewException(String, Throwable) - Constructor for exception com.couchbase.client.protocol.views.InvalidViewException
 
InvalidViewException(Throwable) - Constructor for exception com.couchbase.client.protocol.views.InvalidViewException
 
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 com.couchbase.client.internal.HttpFuture
 
isCancelled() - Method in class com.couchbase.client.internal.ObserveFuture
 
isCancelled() - Method in class com.couchbase.client.internal.ReplicaGetFuture
 
isCancelled() - Method in interface com.couchbase.client.protocol.views.HttpOperation
 
isCancelled() - Method in class com.couchbase.client.protocol.views.HttpOperationImpl
 
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 com.couchbase.client.vbucket.provider.CouchbaseConfigConnection.LoggerProxy
 
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 com.couchbase.client.internal.HttpFuture
 
isDone() - Method in class com.couchbase.client.internal.ObserveFuture
 
isDone() - Method in class com.couchbase.client.internal.ReplicaGetFuture
 
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 com.couchbase.client.vbucket.provider.CouchbaseConfigConnection.LoggerProxy
 
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
 
isNotUpdating() - Method in class com.couchbase.client.vbucket.config.Bucket
Indicates whether or not the bucket is being monitored for updates.
isPrimaryForKey(MemcachedNode, String) - Method in class com.couchbase.client.TapConnectionProvider
 
isSequenceChanged() - Method in class com.couchbase.client.vbucket.config.ConfigDifference
 
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?
isTainted() - Method in interface com.couchbase.client.vbucket.config.Config
If the current config is tainted and will most possibly be replaced soon with a clean one.
isTainted() - Method in class com.couchbase.client.vbucket.config.CouchbaseConfig
 
isTainted() - Method in class com.couchbase.client.vbucket.config.MemcacheConfig
 
isTimedOut() - Method in interface com.couchbase.client.protocol.views.HttpOperation
 
isTimedOut() - Method in class com.couchbase.client.protocol.views.HttpOperationImpl
 
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 com.couchbase.client.vbucket.provider.CouchbaseConfigConnection.LoggerProxy
 
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
 
iterator() - Method in class com.couchbase.client.protocol.views.ViewResponse
 

J

join(Collection<String>, String) - Static method in class net.spy.memcached.util.StringUtils
 

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.
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.
latch - Variable in class com.couchbase.client.internal.HttpFuture
 
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
 
listBuckets() - Method in class com.couchbase.client.ClusterManager
Lists all buckets in a Couchbase cluster.
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.
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
 
log(Level, Object, Throwable) - Method in class com.couchbase.client.vbucket.provider.CouchbaseConfigConnection.LoggerProxy
 
log(Level, Object) - Method in class com.couchbase.client.vbucket.provider.CouchbaseConfigConnection.LoggerProxy
 
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 - Static variable in class com.couchbase.client.protocol.views.ViewOperationImpl
 
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
 
markForResubscribe(String, Reconfigurable) - Method in interface com.couchbase.client.vbucket.ConfigurationProvider
 
markForResubscribe(String, Reconfigurable) - Method in class com.couchbase.client.vbucket.ConfigurationProviderHTTP
 
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_BUCKETS - Static variable in class com.couchbase.client.vbucket.config.VBucket
 
MAX_KEY_LENGTH - Static variable in interface net.spy.memcached.MemcachedClientIF
Maximum supported key length.
MAX_REPLICAS - Static variable in class com.couchbase.client.vbucket.config.VBucket
 
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
 
MemcacheConfig - Class in com.couchbase.client.vbucket.config
The MemcacheConfig class represents a configuration object for memcached-type buckets.
MemcacheConfig(int, List<String>) - Constructor for class com.couchbase.client.vbucket.config.MemcacheConfig
 
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
Connection to a cluster of memcached servers.
MemcachedConnection(int, ConnectionFactory, List<InetSocketAddress>, Collection<ConnectionObserver>, FailureMode, OperationFactory) - Constructor for class net.spy.memcached.MemcachedConnection
Construct a memcached connection.
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
 
messageReceived(ChannelHandlerContext, MessageEvent) - Method in class com.couchbase.client.vbucket.BucketUpdateResponseHandler
 
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
 
metricType - Variable in class com.couchbase.client.CouchbaseConnectionFactoryBuilder
 
metricType - Variable in class net.spy.memcached.ConnectionFactoryBuilder
 
metricType - Variable in class net.spy.memcached.MemcachedConnection
 
MetricType - Enum in net.spy.memcached.metrics
Defines the type of metric collection to use.
MODE_PREFIX - Static variable in class com.couchbase.client.CouchbaseClient
 
MultiGetOperationCallback - Class in net.spy.memcached.ops
MultiOperationCallback for get operations.
MultiGetOperationCallback(OperationCallback, int) - Constructor for class net.spy.memcached.ops.MultiGetOperationCallback
 
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 com.couchbase.client.protocol.views.Paginator
Returns the next ViewResponse.
next() - Method in class net.spy.memcached.internal.SingleElementInfiniteIterator
 
Node - Class in com.couchbase.client.vbucket.config
A Node.
Node(Status, String, Map<Port, String>) - Constructor for class com.couchbase.client.vbucket.config.Node
 
nodeHasActiveVBuckets(InetSocketAddress) - Method in class com.couchbase.client.vbucket.config.CouchbaseConfig
Check if the given node has active VBuckets.
NodeLocator - Interface in net.spy.memcached
Interface for locating a node by hash value.
nodesToShutdown - Variable in class net.spy.memcached.MemcachedConnection
 
NoDocsOperation - Interface in com.couchbase.client.protocol.views
An operation that represents a view that calls the map function and excludes the documents in the result.
NoDocsOperation.NoDocsCallback - Interface in com.couchbase.client.protocol.views
Callback for the result of the NoDocsOperation.
NoDocsOperationImpl - Class in com.couchbase.client.protocol.views
Implementation of a view that calls the map function and excludes the documents in the result.
NoDocsOperationImpl(HttpRequest, AbstractView, ViewOperation.ViewCallback) - Constructor for class com.couchbase.client.protocol.views.NoDocsOperationImpl
 
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.
notifyDisconnected() - Method in class com.couchbase.client.vbucket.BucketMonitor
Take any action required when the monitor appears to be disconnected.
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

objRef - Variable in class com.couchbase.client.internal.HttpFuture
 
observe(String, long) - Method in class com.couchbase.client.CouchbaseClient
 
observe(String, long) - Method in interface com.couchbase.client.CouchbaseClientIF
Observe a key with a associated CAS.
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
 
ObservedException - Exception in com.couchbase.client
An exception in Observe.
ObservedException() - Constructor for exception com.couchbase.client.ObservedException
 
ObservedException(String) - Constructor for exception com.couchbase.client.ObservedException
 
ObservedException(String, Throwable) - Constructor for exception com.couchbase.client.ObservedException
 
ObservedException(Throwable) - Constructor for exception com.couchbase.client.ObservedException
 
ObservedModifiedException - Exception in com.couchbase.client
An exception in Observe indicating the Key/CAS combination was modified.
ObservedModifiedException() - Constructor for exception com.couchbase.client.ObservedModifiedException
 
ObservedModifiedException(String) - Constructor for exception com.couchbase.client.ObservedModifiedException
 
ObservedModifiedException(String, Throwable) - Constructor for exception com.couchbase.client.ObservedModifiedException
 
ObservedModifiedException(Throwable) - Constructor for exception com.couchbase.client.ObservedModifiedException
 
ObservedTimeoutException - Exception in com.couchbase.client
An exception in Observe indicating a Timeout.
ObservedTimeoutException() - Constructor for exception com.couchbase.client.ObservedTimeoutException
 
ObservedTimeoutException(String) - Constructor for exception com.couchbase.client.ObservedTimeoutException
 
ObservedTimeoutException(String, Throwable) - Constructor for exception com.couchbase.client.ObservedTimeoutException
 
ObservedTimeoutException(Throwable) - Constructor for exception com.couchbase.client.ObservedTimeoutException
 
ObserveFuture<T> - Class in com.couchbase.client.internal
A future that allows to chain operations with observe calls.
ObserveFuture(String, CountDownLatch, long, ExecutorService) - Constructor for class com.couchbase.client.internal.ObserveFuture
 
ObserveOperation - Interface in net.spy.memcached.ops
Observe operation.
ObserveOperation.Callback - Interface in net.spy.memcached.ops
Operation callback for the Observe request.
observePoll(String, long, PersistTo, ReplicateTo, boolean) - Method in class com.couchbase.client.CouchbaseClient
 
observePoll(String, long, PersistTo, ReplicateTo, boolean) - Method in interface com.couchbase.client.CouchbaseClientIF
Poll and observe a key with the given CAS and persist settings.
ObserveResponse - Enum in net.spy.memcached
Response codes for a Observe operation.
of(Object...) - Static method in class com.couchbase.client.protocol.views.ComplexKey
Generate a ComplexKey based on the input Object arguments (varargs).
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.
OnError - Enum in com.couchbase.client.protocol.views
Possible on_error arguments to view queries.
op - Variable in class com.couchbase.client.internal.HttpFuture
 
opaque - Variable in class net.spy.memcached.tapmessage.BaseMessage
 
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.
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
 
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
helper method: reset timeout counter.
opTimedOut(Operation) - Static method in class net.spy.memcached.MemcachedConnection
helper method: increase timeout count on node attached to this op.
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

paginatedQuery(View, Query, int) - Method in class com.couchbase.client.CouchbaseClient
 
paginatedQuery(View, Query, int) - Method in interface com.couchbase.client.CouchbaseClientIF
A paginated query allows the user to get the results of a large query in small chunks allowing for better performance.
Paginator - Class in com.couchbase.client.protocol.views
The Paginator makes it possible to iterate over a ViewResponse in pages.
Paginator(CouchbaseClient, View, Query, int) - Constructor for class com.couchbase.client.protocol.views.Paginator
Create a new Paginator by passing in the needed params.
parseBucket(String) - Method in interface com.couchbase.client.vbucket.config.ConfigurationParser
 
parseBucket(String) - Method in class com.couchbase.client.vbucket.config.ConfigurationParserJSON
Parse a raw bucket config string into a Bucket configuration.
parseBuckets(String) - Method in interface com.couchbase.client.vbucket.config.ConfigurationParser
 
parseBuckets(String) - Method in class com.couchbase.client.vbucket.config.ConfigurationParserJSON
Parses the /pools/{pool}/buckets URI for a list of contained buckets.
parseError(String, int) - Method in class com.couchbase.client.protocol.views.DocsOperationImpl
 
parseError(String, int) - Method in class com.couchbase.client.protocol.views.NoDocsOperationImpl
 
parseError(String, int) - Method in class com.couchbase.client.protocol.views.ReducedOperationImpl
 
parseError(String, int) - Method in class com.couchbase.client.protocol.views.ViewOperationImpl
 
parsePool(Pool, String) - Method in interface com.couchbase.client.vbucket.config.ConfigurationParser
 
parsePool(Pool, String) - Method in class com.couchbase.client.vbucket.config.ConfigurationParserJSON
Parses a given /pools/{pool} JSON for the buckets URI.
parsePools(String) - Method in interface com.couchbase.client.vbucket.config.ConfigurationParser
 
parsePools(String) - Method in class com.couchbase.client.vbucket.config.ConfigurationParserJSON
Parses the /pools URI and returns a map of found pools.
parseResult(String) - Method in class com.couchbase.client.protocol.views.DocsOperationImpl
 
parseResult(String) - Method in class com.couchbase.client.protocol.views.NoDocsOperationImpl
 
parseResult(String) - Method in class com.couchbase.client.protocol.views.ReducedOperationImpl
 
parseResult(String) - Method in class com.couchbase.client.protocol.views.ViewOperationImpl
 
parseViewForStatus(String, int) - Method in class com.couchbase.client.protocol.views.HttpOperationImpl
 
pastReconnThreshold() - Method in class com.couchbase.client.CouchbaseConnectionFactory
Checks if there have been more requests than allowed through maxConfigCheck in a 10 second period.
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.
Pool - Class in com.couchbase.client.vbucket.config
Pool represents a collection of buckets.
Pool(String, URI, URI) - Constructor for class com.couchbase.client.vbucket.config.Pool
 
Port - Enum in com.couchbase.client.vbucket.config
A Port.
prepareRequest(URI, String) - Method in class com.couchbase.client.vbucket.BucketMonitor
 
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
 
printMessage(BaseMessage, PrintWriter) - Static method in class com.couchbase.client.TapMessagePrinter
Prints the message in byte form in a pretty way.
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

query(AbstractView, Query) - Method in class com.couchbase.client.CouchbaseClient
 
query(AbstractView, Query) - Method in interface com.couchbase.client.CouchbaseClientIF
Queries a Couchbase view and returns the result.
Query - Class in com.couchbase.client.protocol.views
The Query class allows custom view-queries to the Couchbase cluster.
Query() - Constructor for class com.couchbase.client.protocol.views.Query
Create a new Query.
queueReconnect(MemcachedNode) - Method in class com.couchbase.client.CouchbaseConnection
Only queue for reconnect if the given node is still part of the cluster.
queueReconnect(MemcachedNode) - Method in class com.couchbase.client.CouchbaseMemcachedConnection
Only queue for reconnect if the given node is still part of the cluster.
queueReconnect(MemcachedNode) - Method in class net.spy.memcached.MemcachedConnection
 
quote(String) - Method in class com.couchbase.client.protocol.views.Query
Helper method to properly quote the string if its a JSON string.

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.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
 
Reconfigurable - Interface in com.couchbase.client.vbucket
Interface provides a method for receiving configuration updates.
ReconfigurableObserver - Class in com.couchbase.client.vbucket
An implementation of the observer for calling reconfigure.
ReconfigurableObserver(Reconfigurable) - Constructor for class com.couchbase.client.vbucket.ReconfigurableObserver
 
reconfigure(Bucket) - Method in class com.couchbase.client.CouchbaseClient
 
reconfigure(Bucket) - Method in class com.couchbase.client.CouchbaseConnection
 
reconfigure(Bucket) - Method in class com.couchbase.client.CouchbaseMemcachedConnection
 
reconfigure(Bucket) - Method in class com.couchbase.client.TapConnectionProvider
 
reconfigure(Bucket) - Method in class com.couchbase.client.vbucket.provider.BucketConfigurationProvider
 
reconfigure(Bucket) - Method in interface com.couchbase.client.vbucket.Reconfigurable
Call on a configuration update.
reconfigure(Bucket) - Method in class com.couchbase.client.ViewConnection
Updates the list of active HttpHosts based on the incoming Bucket configuration.
reconfiguring - Variable in class com.couchbase.client.CouchbaseClient
 
reconfiguring - Variable in class com.couchbase.client.CouchbaseConnection
 
reconfiguring - Variable in class com.couchbase.client.CouchbaseMemcachedConnection
 
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
 
ReducedOperation - Interface in com.couchbase.client.protocol.views
An operation that represents a view that calls the map function and the reduce function and gets the result.
ReducedOperation.ReducedCallback - Interface in com.couchbase.client.protocol.views
A ReducedCallback.
ReducedOperationImpl - Class in com.couchbase.client.protocol.views
Implementation of a view that calls the map function and the reduce function and gets the result.
ReducedOperationImpl(HttpRequest, AbstractView, ViewOperation.ViewCallback) - Constructor for class com.couchbase.client.protocol.views.ReducedOperationImpl
 
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.
reloadConfig() - Method in class com.couchbase.client.vbucket.provider.BucketConfigurationProvider
 
reloadConfig() - Method in interface com.couchbase.client.vbucket.provider.ConfigurationProvider
Method used to signal a new configuration should be loaded.
remove() - Method in class com.couchbase.client.protocol.views.Paginator
The Paginator.remove() method is not supported in this context.
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
 
removeLastElement() - Method in class com.couchbase.client.protocol.views.ViewResponse
 
removeListener(HttpCompletionListener) - Method in class com.couchbase.client.internal.HttpFuture
 
removeListener(ReplicaGetCompletionListener) - Method in class com.couchbase.client.internal.ReplicaGetFuture
 
removeListener(HttpCompletionListener) - Method in class com.couchbase.client.internal.ViewFuture
 
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 com.couchbase.client.TapConnectionProvider
Remove a connection observer.
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.
removeThrottler(InetSocketAddress) - Method in class com.couchbase.client.internal.ThrottleManager
 
replace(String, Object) - Method in class com.couchbase.client.CouchbaseClient
 
replace(String, int, Object, PersistTo, ReplicateTo) - Method in class com.couchbase.client.CouchbaseClient
 
replace(String, Object, PersistTo, ReplicateTo) - Method in class com.couchbase.client.CouchbaseClient
 
replace(String, int, Object, PersistTo) - Method in class com.couchbase.client.CouchbaseClient
 
replace(String, Object, PersistTo) - Method in class com.couchbase.client.CouchbaseClient
 
replace(String, int, Object, ReplicateTo) - Method in class com.couchbase.client.CouchbaseClient
 
replace(String, Object, ReplicateTo) - Method in class com.couchbase.client.CouchbaseClient
 
replace(String, Object) - Method in interface com.couchbase.client.CouchbaseClientIF
Add a value with durability options.
replace(String, int, Object, PersistTo) - Method in interface com.couchbase.client.CouchbaseClientIF
Replace a value with durability options.
replace(String, Object, PersistTo) - Method in interface com.couchbase.client.CouchbaseClientIF
Replace a value with durability options with no TTL This is a shorthand method so that you only need to provide a PersistTo value if you don't care if the value is already replicated.
replace(String, int, Object, ReplicateTo) - Method in interface com.couchbase.client.CouchbaseClientIF
Replace a value with durability options.
replace(String, Object, ReplicateTo) - Method in interface com.couchbase.client.CouchbaseClientIF
Replace a value with durability options with no TTL This method allows you to express durability at the replication level only and is the functional equivalent of PersistTo.ZERO.
replace(String, int, Object, PersistTo, ReplicateTo) - Method in interface com.couchbase.client.CouchbaseClientIF
Replace a value with durability options.
replace(String, Object, PersistTo, ReplicateTo) - Method in interface com.couchbase.client.CouchbaseClientIF
Replace a value with durability options with no TTL.
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
 
replaceBuckets(Map<String, Bucket>) - Method in class com.couchbase.client.vbucket.config.Pool
 
replaceConfig() - Method in class com.couchbase.client.vbucket.BucketMonitor
Replace the previously received configuration with the current one.
replaceConfigWildcards(String) - Method in class com.couchbase.client.CouchbaseConnection
Helper method to parse config wildcards into their actual representations.
REPLICA_NOT_USED - Static variable in class com.couchbase.client.vbucket.config.VBucket
 
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
 
ReplicaGetCompletionListener - Interface in com.couchbase.client.internal
A listener that will be notified once the replica get future completes.
ReplicaGetFuture<T> - Class in com.couchbase.client.internal
Represents the future result of a ReplicaGet operation.
ReplicaGetFuture(long, ExecutorService) - Constructor for class com.couchbase.client.internal.ReplicaGetFuture
 
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
 
ReplicateTo - Enum in net.spy.memcached
ReplicateTo codes for a Observe operation.
requestConfigReconnect(String, Reconfigurable) - Method in class com.couchbase.client.CouchbaseConnectionFactory
 
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.
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.
RowError - Class in com.couchbase.client.protocol.views
Holds the information for row in a view result that describes an error.
RowError(String, String) - Constructor for class com.couchbase.client.protocol.views.RowError
 
rows - Variable in class com.couchbase.client.protocol.views.ViewResponse
 
rqueue - Variable in class net.spy.memcached.TapClient
 
run() - Method in class com.couchbase.client.CouchbaseConnection
Infinitely loop processing IO.
run() - Method in class com.couchbase.client.CouchbaseMemcachedConnection
Infinitely loop processing IO.
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
Infinitely loop processing IO.
running - Variable in class net.spy.memcached.MemcachedConnection
 

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
 
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(String, Object) - Method in class com.couchbase.client.CouchbaseClient
 
set(String, int, Object, PersistTo, ReplicateTo) - Method in class com.couchbase.client.CouchbaseClient
 
set(String, Object, PersistTo, ReplicateTo) - Method in class com.couchbase.client.CouchbaseClient
 
set(String, int, Object, PersistTo) - Method in class com.couchbase.client.CouchbaseClient
 
set(String, Object, PersistTo) - Method in class com.couchbase.client.CouchbaseClient
 
set(String, int, Object, ReplicateTo) - Method in class com.couchbase.client.CouchbaseClient
 
set(String, Object, ReplicateTo) - Method in class com.couchbase.client.CouchbaseClient
 
set(String, Object) - Method in interface com.couchbase.client.CouchbaseClientIF
Set a value without any durability options with no TTL.
set(String, int, Object, PersistTo) - Method in interface com.couchbase.client.CouchbaseClientIF
Set a value with durability options.
set(String, Object, PersistTo) - Method in interface com.couchbase.client.CouchbaseClientIF
Set a value with durability options with no TTL This is a shorthand method so that you only need to provide a PersistTo value if you don't care if the value is already replicated.
set(String, int, Object, ReplicateTo) - Method in interface com.couchbase.client.CouchbaseClientIF
Set a value with durability options.
set(String, Object, ReplicateTo) - Method in interface com.couchbase.client.CouchbaseClientIF
Set a value with durability option and no TTL This method allows you to express durability at the replication level only and is the functional equivalent of PersistTo.ZERO.
set(String, int, Object, PersistTo, ReplicateTo) - Method in interface com.couchbase.client.CouchbaseClientIF
Set a value with durability options.
set(String, Object, PersistTo, ReplicateTo) - Method in interface com.couchbase.client.CouchbaseClientIF
Set a value with durability options and not TTL.
set(T, OperationStatus) - Method in class com.couchbase.client.internal.HttpFuture
 
set(ViewResponse, BulkFuture<Map<String, Object>>, OperationStatus) - Method in class com.couchbase.client.internal.ViewFuture
 
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 com.couchbase.client.CouchbaseConnectionFactoryBuilder
Sets a custom waiting time until authentication completes.
setBackfill(long) - Method in class net.spy.memcached.tapmessage.RequestMessage
Stream all keys inserted into the server after a given date.
setBbox(double, double, double, double) - Method in class com.couchbase.client.protocol.views.Query
Sets the params for a spatial bounding box view query.
setBucketMonitor(BucketMonitor) - Method in class com.couchbase.client.vbucket.BucketUpdateResponseHandler
 
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).
setCompletedFuture(Future<T>) - Method in class com.couchbase.client.internal.ReplicaGetFuture
Mark a monitored future as complete.
setCompressionThreshold(int) - Method in class net.spy.memcached.transcoders.BaseSerializingTranscoder
Set the compression threshold to the given number of bytes.
setConfig(Bucket) - Method in class com.couchbase.client.vbucket.provider.BucketConfigurationProvider
 
setConfig(String) - Method in class com.couchbase.client.vbucket.provider.BucketConfigurationProvider
 
setConfig(Bucket) - Method in interface com.couchbase.client.vbucket.provider.ConfigurationProvider
Explictly set the current Bucket configuration.
setConfig(String) - Method in interface com.couchbase.client.vbucket.provider.ConfigurationProvider
Replace the current config with a raw JSON string configuration.
setConfigParser(ConfigurationParser) - Method in class com.couchbase.client.vbucket.BucketMonitor
 
setConnectionsPerNode(int) - Method in class com.couchbase.client.ClusterManagerBuilder
The maximum number of parallel connections per node to open (5 per default).
setConnectionTimeout(int) - Method in class com.couchbase.client.ClusterManagerBuilder
Set the HTTP connection timeout (2 minutes by default).
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.
setDebug(boolean) - Method in class com.couchbase.client.protocol.views.Query
Enabled debugging on view queries.
setDescending(boolean) - Method in class com.couchbase.client.protocol.views.Query
Return the documents in descending by key order.
setEnableMetrics(MetricType) - Method in class com.couchbase.client.CouchbaseConnectionFactoryBuilder
Enable the collection of runtime metrics.
setEnableMetrics(MetricType) - Method in class net.spy.memcached.ConnectionFactoryBuilder
Enable or disable metric collection.
setEndkeyDocID(String) - Method in class com.couchbase.client.protocol.views.Query
Stop returning records when the specified document ID is reached.
setException(OperationException) - Method in class com.couchbase.client.protocol.views.HttpOperationImpl
 
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.
setGroup(boolean) - Method in class com.couchbase.client.protocol.views.Query
Group the results using the reduce function to a group or single row.
setGroupLevel(int) - Method in class com.couchbase.client.protocol.views.Query
Specify the group level to be used.
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
 
setIncludeDocs(boolean) - Method in class com.couchbase.client.protocol.views.Query
If the full documents should be included in the result.
setInclusiveEnd(boolean) - Method in class com.couchbase.client.protocol.views.Query
Specifies whether the specified end key should be included in the result.
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
 
setIoThreadCount(int) - Method in class com.couchbase.client.ClusterManagerBuilder
The number of IO worker threads to use (1 by default).
setIsNotUpdating() - Method in class com.couchbase.client.vbucket.config.Bucket
Mark this bucket as not receiving updates.
setKetamaNodes(List<MemcachedNode>) - Method in class net.spy.memcached.KetamaNodeLocator
Setup the KetamaNodeLocator with the list of nodes it should use.
setKey(ComplexKey) - Method in class com.couchbase.client.protocol.views.Query
Return only documents that match the specified key.
setKey(String) - Method in class com.couchbase.client.protocol.views.Query
Return only documents that match the specified key.
setKeys(ComplexKey) - Method in class com.couchbase.client.protocol.views.Query
Return only documents that match each of keys specified within the given array.
setKeys(String) - Method in class com.couchbase.client.protocol.views.Query
Return only documents that match each of keys specified within the given array.
setLimit(int) - Method in class com.couchbase.client.protocol.views.Query
Limit the number of the returned documents to the specified number.
setListenerExecutorService(ExecutorService) - Method in class com.couchbase.client.CouchbaseConnectionFactoryBuilder
Set a custom ExecutorService to execute the listener callbacks and other callback-type operations.
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.
setMaster(short) - Method in class com.couchbase.client.vbucket.config.VBucket
 
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 com.couchbase.client.CouchbaseConnectionFactoryBuilder
Allows to provide a custom MetricCollector.
setMetricCollector(MetricCollector) - Method in class net.spy.memcached.ConnectionFactoryBuilder
Set a custom MetricCollector.
setName(String) - Method in class com.couchbase.client.protocol.views.DesignDocument
Set the name of the design document.
setName(String) - Method in class net.spy.memcached.tapmessage.RequestMessage
Sets a name for this tap stream.
setNamespace(String) - Static method in class com.couchbase.client.CouchbaseProperties
Replaces the default (or old) namespace with this new one.
setNotMyVbucketNodes(Collection<MemcachedNode>) - Method in interface net.spy.memcached.ops.VBucketAware
 
setObsPollInterval(long) - Method in class com.couchbase.client.CouchbaseConnectionFactoryBuilder
Sets a custom interval between observe poll cycles.
setObsPollMax(int) - Method in class com.couchbase.client.CouchbaseConnectionFactoryBuilder
Deprecated.
setObsTimeout(long) - Method in class com.couchbase.client.CouchbaseConnectionFactoryBuilder
Sets the absolute per-operation timeout for observe calls.
setOnError(OnError) - Method in class com.couchbase.client.protocol.views.Query
Sets the response in the event of an error.
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(HttpOperation) - Method in class com.couchbase.client.internal.HttpFuture
 
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
 
setPropertyFile(String) - Static method in class com.couchbase.client.CouchbaseProperties
Set the filename of the properties file and load it (if possible).
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
 
setRange(String, String) - Method in class com.couchbase.client.protocol.views.Query
Returns records in the given key range.
setRange(ComplexKey, ComplexKey) - Method in class com.couchbase.client.protocol.views.Query
Returns records in the given key range.
setRangeEnd(String) - Method in class com.couchbase.client.protocol.views.Query
Stop returning records when the specified key is reached.
setRangeEnd(ComplexKey) - Method in class com.couchbase.client.protocol.views.Query
Stop returning records when the specified key is reached.
setRangeStart(String) - Method in class com.couchbase.client.protocol.views.Query
Return records with a value equal to or greater than the specified key.
setRangeStart(ComplexKey) - Method in class com.couchbase.client.protocol.views.Query
Return records with a value equal to or greater than the specified key.
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
 
setReconnectThresholdTime(long, TimeUnit) - Method in class com.couchbase.client.CouchbaseConnectionFactoryBuilder
Sets a custom reconnect threshold.
setReduce(boolean) - Method in class com.couchbase.client.protocol.views.Query
Explicitly enable/disable the reduce function on the query.
setSequenceChanged(boolean) - Method in class com.couchbase.client.vbucket.config.ConfigDifference
 
setServers(List<String>) - Method in class com.couchbase.client.vbucket.config.MemcacheConfig
 
setServers(String) - Method in class net.spy.memcached.spring.MemcachedClientFactoryBean
 
setServersAdded(List<String>) - Method in class com.couchbase.client.vbucket.config.ConfigDifference
 
setServersRemoved(List<String>) - Method in class com.couchbase.client.vbucket.config.ConfigDifference
 
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
 
setSkip(int) - Method in class com.couchbase.client.protocol.views.Query
Skip this number of records before starting to return the results.
setSocketTimeout(int) - Method in class com.couchbase.client.ClusterManagerBuilder
The HTTP connection socket timeout (2 minutes by default).
setSpatialView(SpatialViewDesign) - Method in class com.couchbase.client.protocol.views.DesignDocument
Add a single spatial view to the list of stored DpatialViewDesign objects.
setSpatialViews(List<SpatialViewDesign>) - Method in class com.couchbase.client.protocol.views.DesignDocument
Set a list of SpatialViewDesigns.
setStale(Stale) - Method in class com.couchbase.client.protocol.views.Query
Allow the results from a stale view to be used.
setStartkeyDocID(String) - Method in class com.couchbase.client.protocol.views.Query
Return records starting with the specified document ID.
setStatus(OperationStatus) - Method in class net.spy.memcached.internal.BulkGetFuture
 
setStreamingNodeOrder(CouchbaseNodeOrder) - Method in class com.couchbase.client.CouchbaseConnectionFactoryBuilder
Changes the node ordering for streaming connections.
setTcpNoDelay(boolean) - Method in class com.couchbase.client.ClusterManagerBuilder
The TCP NODELAY setting (true by default).
setThrottler(InetSocketAddress) - Method in class com.couchbase.client.internal.ThrottleManager
 
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.
setVBucketConfig(Config) - Method in class com.couchbase.client.CouchbaseConnectionFactoryBuilder
Sets a custom Config to use.
setVbucketlist(short[]) - Method in class net.spy.memcached.tapmessage.RequestMessage
Sets a list of vbuckets to stream keys from.
setVbuckets(List<VBucket>) - Method in class com.couchbase.client.vbucket.config.MemcacheConfig
 
setVbucketsChanges(int) - Method in class com.couchbase.client.vbucket.config.ConfigDifference
 
setView(ViewDesign) - Method in class com.couchbase.client.protocol.views.DesignDocument
Add a single view to the list of stored ViewDesign objects.
setViewConnsPerNode(int) - Method in class com.couchbase.client.CouchbaseConnectionFactoryBuilder
Changes the maximum parallel open connections per node for view operations.
setViews(List<ViewDesign>) - Method in class com.couchbase.client.protocol.views.DesignDocument
Set a list of ViewDesigns.
setViewTimeout(int) - Method in class com.couchbase.client.CouchbaseConnectionFactoryBuilder
Sets a custom timeout for view operations.
setViewWorkerSize(int) - Method in class com.couchbase.client.CouchbaseConnectionFactoryBuilder
Sets a custom worker count for view operations.
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 class com.couchbase.client.CouchbaseConnectionFactory
 
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 com.couchbase.client.ClusterManager
Shutdown the ClusterManager.
shutdown(long, TimeUnit) - Method in class com.couchbase.client.CouchbaseClient
 
shutdown() - Method in class com.couchbase.client.TapClient
Shuts down all tap streams that are currently running.
shutdown() - Method in class com.couchbase.client.TapConnectionProvider
 
shutdown() - Method in class com.couchbase.client.vbucket.BucketMonitor
Shut down the monitor in a graceful way (and release all resources).
shutdown(long, TimeUnit) - Method in class com.couchbase.client.vbucket.BucketMonitor
Shut down this monitor in a graceful way.
shutdown() - Method in interface com.couchbase.client.vbucket.ConfigurationProvider
Shutdowns a monitor connections to the REST service.
shutdown() - Method in class com.couchbase.client.vbucket.ConfigurationProviderHTTP
Shutdowns a monitor connections to the REST service.
shutdown() - Method in class com.couchbase.client.vbucket.provider.BucketConfigurationProvider
 
shutdown() - Method in interface com.couchbase.client.vbucket.provider.ConfigurationProvider
Shut down the ConfigurationProvider.
shutdown() - Method in class com.couchbase.client.ViewConnection
Shuts down the active ViewConnection.
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
 
shutdown() - Method in class net.spy.memcached.MemcachedConnection
Shut down all of the connections.
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 com.couchbase.client.internal.HttpFuture
Signals that this future is complete.
signalComplete() - Method in class com.couchbase.client.internal.ReplicaGetFuture
Signals that this future is complete.
signalOutdated() - Method in class com.couchbase.client.vbucket.provider.BucketConfigurationProvider
 
signalOutdated() - Method in interface com.couchbase.client.vbucket.provider.ConfigurationProvider
Can be used as a hint for the ConfigurationProvider to signal that his current configuration may be outdated.
signalOutdatedConfig() - Method in class com.couchbase.client.ViewConnection
Helper method to signal an outdated config and potentially force a refresh of the connection provider.
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 com.couchbase.client.protocol.views.ViewResponse
 
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
 
SpatialView - Class in com.couchbase.client.protocol.views
Holds information about a spatial view that can be queried in Couchbase Server.
SpatialView(String, String, String) - Constructor for class com.couchbase.client.protocol.views.SpatialView
Create a new Spatial View object.
SpatialViewDesign - Class in com.couchbase.client.protocol.views
The SpatialViewDesign object represents a spatial view to be stored and retrieved from the Couchbase cluster.
SpatialViewDesign(String, String) - Constructor for class com.couchbase.client.protocol.views.SpatialViewDesign
Create a SpatialViewDesign with a name and a map function.
SpatialViewFetcherOperation - Interface in com.couchbase.client.protocol.views
A ViewOperation.
SpatialViewFetcherOperation.ViewFetcherCallback - Interface in com.couchbase.client.protocol.views
A ViewCallback.
SpatialViewFetcherOperationImpl - Class in com.couchbase.client.protocol.views
A SpatialViewOperationImpl.
SpatialViewFetcherOperationImpl(HttpRequest, String, String, String, SpatialViewFetcherOperation.ViewFetcherCallback) - Constructor for class com.couchbase.client.protocol.views.SpatialViewFetcherOperationImpl
 
SpatialViewRowNoDocs - Class in com.couchbase.client.protocol.views
Holds a row in a spatial view result that contains the fields id, bbox, and geometry.
SpatialViewRowNoDocs(String, String, String, String) - Constructor for class com.couchbase.client.protocol.views.SpatialViewRowNoDocs
 
SpatialViewRowWithDocs - Class in com.couchbase.client.protocol.views
Holds a row in a spatial view result that contains the fields id, bbox, geometry, and doc.
SpatialViewRowWithDocs(String, String, String, String, Object) - Constructor for class com.couchbase.client.protocol.views.SpatialViewRowWithDocs
 
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.
Stale - Enum in com.couchbase.client.protocol.views
An enum containing the two possible values for the stale parameter.
startMonitor() - Method in class com.couchbase.client.vbucket.BucketMonitor
 
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 com.couchbase.client.internal.HttpFuture
 
Status - Enum in com.couchbase.client.vbucket.config
A Status.
status - Variable in class net.spy.memcached.internal.OperationFuture
 
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 com.couchbase.client
Operation Types.
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
Some String utilities.
subscribe(String, Reconfigurable) - Method in interface com.couchbase.client.vbucket.ConfigurationProvider
Subscribes for configuration updates.
subscribe(String, Reconfigurable) - Method in class com.couchbase.client.vbucket.ConfigurationProviderHTTP
Subscribes for configuration updates.
subscribe(Reconfigurable) - Method in class com.couchbase.client.vbucket.provider.BucketConfigurationProvider
 
subscribe(Reconfigurable) - Method in interface com.couchbase.client.vbucket.provider.ConfigurationProvider
Subscribes for configuration updates.
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, int, TimeUnit) - Method in class com.couchbase.client.TapClient
Specifies a tap stream that will send all key-value mutations that take place in the future.
tapBackfill(String, long, int, TimeUnit) - Method in class com.couchbase.client.TapClient
Specifies a tap stream that will send all key-value mutations that took place after a specific date.
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 com.couchbase.client
A tap client for Couchbase server.
TapClient(List<URI>, String, String) - Constructor for class com.couchbase.client.TapClient
Creates a cluster aware tap client for Couchbase Server.
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 com.couchbase.client
A TapConnectionProvider for Couchbase Server.
TapConnectionProvider(List<URI>, String, String) - Constructor for class com.couchbase.client.TapConnectionProvider
Get a tap connection based on the REST response from a Couchbase server.
TapConnectionProvider(CouchbaseConnectionFactory) - Constructor for class com.couchbase.client.TapConnectionProvider
Get a tap connection based on the REST response from a Couchbase server.
TapConnectionProvider - Class in net.spy.memcached
A TapConnectionProvider.
TapConnectionProvider(InetSocketAddress...) - Constructor for class net.spy.memcached.TapConnectionProvider
Get a tap client operating on the specified memcached locations.
TapConnectionProvider(List<InetSocketAddress>) - Constructor for class net.spy.memcached.TapConnectionProvider
Get a tap client operating on the specified memcached locations.
TapConnectionProvider(ConnectionFactory, List<InetSocketAddress>) - Constructor for class net.spy.memcached.TapConnectionProvider
Get a tap client operating on the specified memcached locations.
tapCustom(String, RequestMessage) - Method in class com.couchbase.client.TapClient
Allows the user to specify a custom tap message.
tapCustom(String, RequestMessage, OperationCallback) - Method in interface net.spy.memcached.OperationFactory
Creates a custom tap stream.
tapCustom(String, RequestMessage, OperationCallback) - Method in class net.spy.memcached.protocol.ascii.AsciiOperationFactory
 
tapCustom(String, RequestMessage, OperationCallback) - Method in class net.spy.memcached.protocol.binary.BinaryOperationFactory
 
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) - Method in class com.couchbase.client.TapClient
Specifies a tap stream that will take a snapshot of items in Couchbase and send them through a tap stream.
tapDump(String, OperationCallback) - Method in interface net.spy.memcached.OperationFactory
Sends a tap dump message to the server.
tapDump(String, OperationCallback) - Method in class net.spy.memcached.protocol.ascii.AsciiOperationFactory
 
tapDump(String, OperationCallback) - Method in class net.spy.memcached.protocol.binary.BinaryOperationFactory
 
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.
TapMessagePrinter - Class in com.couchbase.client
A utility class for printing the bytes of a tap message.
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) - Constructor for class net.spy.memcached.protocol.TCPMemcachedNodeImpl
 
tcService - Variable in class net.spy.memcached.MemcachedClient
 
tcService - Variable in class net.spy.memcached.TapConnectionProvider
 
throttle() - Method in class com.couchbase.client.internal.AdaptiveThrottler
Throttle if needed based on the given throttle constraints.
throttle() - Method in interface com.couchbase.client.internal.Throttler
Throttle the current message if needed.
ThrottleManager<T extends Throttler> - Class in com.couchbase.client.internal
The ThrottleManager handles Throttle instances which are bound to their corresponding MemcachedNodes.
ThrottleManager(List<InetSocketAddress>, Class<T>, CouchbaseConnection, OperationFactory) - Constructor for class com.couchbase.client.internal.ThrottleManager
 
Throttler - Interface in com.couchbase.client.internal
Interface for Message Throttling.
ThrottlerState - Enum in com.couchbase.client.internal
Defines all possible throttler states.
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 - Variable in class com.couchbase.client.internal.HttpFuture
 
timeOut() - Method in interface com.couchbase.client.protocol.views.HttpOperation
 
timeOut() - Method in class com.couchbase.client.protocol.views.HttpOperationImpl
 
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
 
toJson() - Method in class com.couchbase.client.protocol.views.ComplexKey
Generate a JSON string of the ComplexKey.
toJson() - Method in class com.couchbase.client.protocol.views.DesignDocument
Create a JSON representation of the design document.
toString() - Method in class com.couchbase.client.CouchbaseConnectionFactory
 
toString() - Method in class com.couchbase.client.protocol.views.HttpOperationImpl
 
toString() - Method in class com.couchbase.client.protocol.views.Query
Returns the Query as a HTTP-compatible query string.
toString() - Method in class com.couchbase.client.protocol.views.ViewResponseNoDocs
 
toString() - Method in class com.couchbase.client.protocol.views.ViewResponseReduced
 
toString() - Method in class com.couchbase.client.protocol.views.ViewResponseWithDocs
 
toString() - Method in class com.couchbase.client.vbucket.config.Bucket
 
toString() - Method in class com.couchbase.client.vbucket.config.CouchbaseConfig
 
toString() - Method in class com.couchbase.client.vbucket.config.MemcacheConfig
 
toString() - Method in class com.couchbase.client.vbucket.config.Node
 
toString() - Method in class com.couchbase.client.vbucket.config.VBucket
 
toString() - Method in class com.couchbase.client.vbucket.ConfigurationProviderHTTP
 
toString() - Method in class com.couchbase.client.vbucket.provider.CouchbaseConfigConnection
 
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.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
 
totalRows - Variable in class com.couchbase.client.protocol.views.ViewResponse
 
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 com.couchbase.client.vbucket.provider.CouchbaseConfigConnection.LoggerProxy
 
trace(Object) - Method in class com.couchbase.client.vbucket.provider.CouchbaseConfigConnection.LoggerProxy
 
trace(String, Object...) - Method in class com.couchbase.client.vbucket.provider.CouchbaseConfigConnection.LoggerProxy
 
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, Transcoder<T>) - Method in class com.couchbase.client.CouchbaseClient
 
unlock(String, long) - Method in class com.couchbase.client.CouchbaseClient
 
unlock(String, long, Transcoder<T>) - Method in interface com.couchbase.client.CouchbaseClientIF
Unlock the given key synchronously from the cache.
unlock(String, long) - Method in interface com.couchbase.client.CouchbaseClientIF
Unlock the given key synchronously from the cache with the default transcoder.
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.
unsubscribe(String, Reconfigurable) - Method in interface com.couchbase.client.vbucket.ConfigurationProvider
Unsubscribe from updates on a given bucket and given reconfigurable.
unsubscribe(String, Reconfigurable) - Method in class com.couchbase.client.vbucket.ConfigurationProviderHTTP
Unsubscribe from updates on a given bucket and given reconfigurable.
unsubscribe(Reconfigurable) - Method in class com.couchbase.client.vbucket.provider.BucketConfigurationProvider
 
unsubscribe(Reconfigurable) - Method in interface com.couchbase.client.vbucket.provider.ConfigurationProvider
Unsubscribe from updates on the connected bucket.
update(Observable, Object) - Method in class com.couchbase.client.vbucket.ReconfigurableObserver
Delegates update to the reconfigurable passed in the constructor.
updateBaseListFromConfig(List<URI>) - Method in interface com.couchbase.client.vbucket.ConfigurationProvider
Update the configured baseList on bootstrap with a new one.
updateBaseListFromConfig(List<URI>) - Method in class com.couchbase.client.vbucket.ConfigurationProviderHTTP
Override the old baseList with new values.
updateBucket(String, int, AuthType, int, int, String, boolean) - Method in class com.couchbase.client.ClusterManager
Update a bucket with the new settings.
updateBucket(String, Bucket) - Method in interface com.couchbase.client.vbucket.config.ConfigurationParser
 
updateBucket(String, Bucket) - Method in class com.couchbase.client.vbucket.config.ConfigurationParserJSON
Parse a raw bucket config and update an old bucket with the new infos.
updateBucket(String, Bucket) - Method in interface com.couchbase.client.vbucket.ConfigurationProvider
Update the bucket including configuration.
updateBucket(String) - Method in interface com.couchbase.client.vbucket.ConfigurationProvider
Updates the current bucket with a new JSON config string
updateBucket(String, Bucket) - Method in class com.couchbase.client.vbucket.ConfigurationProviderHTTP
Update the configuration provider with a new bucket.
updateBucket(String) - Method in class com.couchbase.client.vbucket.ConfigurationProviderHTTP
 
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 com.couchbase.client.vbucket.VBucketNodeLocator
 
updateLocator(Collection<MemcachedNode>, Config) - Method in class com.couchbase.client.vbucket.VBucketNodeLocator
 
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
 
valueOf(String) - Static method in enum com.couchbase.client.clustermanager.AuthType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.couchbase.client.clustermanager.BucketType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.couchbase.client.clustermanager.FlushResponse
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.couchbase.client.internal.ThrottlerState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.couchbase.client.protocol.views.OnError
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.couchbase.client.protocol.views.Stale
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.couchbase.client.StoreType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.couchbase.client.vbucket.config.ConfigType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.couchbase.client.vbucket.config.Port
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.couchbase.client.vbucket.config.Status
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.couchbase.client.vbucket.CouchbaseNodeOrder
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.spy.memcached.CASResponse
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.spy.memcached.compat.log.Level
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.spy.memcached.ConnectionFactoryBuilder.Locator
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.spy.memcached.ConnectionFactoryBuilder.Protocol
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.spy.memcached.DefaultHashAlgorithm
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.spy.memcached.FailureMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum net.spy.memcached.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.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() - Static method in enum com.couchbase.client.clustermanager.AuthType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.couchbase.client.clustermanager.BucketType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.couchbase.client.clustermanager.FlushResponse
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.couchbase.client.internal.ThrottlerState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.couchbase.client.protocol.views.OnError
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.couchbase.client.protocol.views.Stale
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.couchbase.client.StoreType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.couchbase.client.vbucket.config.ConfigType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.couchbase.client.vbucket.config.Port
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.couchbase.client.vbucket.config.Status
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.couchbase.client.vbucket.CouchbaseNodeOrder
Returns an array containing the constants of this enum type, in the order they are declared.
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.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 - Class in com.couchbase.client.vbucket.config
A VBucket.
VBucket(short) - Constructor for class com.couchbase.client.vbucket.config.VBucket
 
VBucket(short, short) - Constructor for class com.couchbase.client.vbucket.config.VBucket
 
VBucket(short, short, short) - Constructor for class com.couchbase.client.vbucket.config.VBucket
 
VBucket(short, short, short, short) - Constructor for class com.couchbase.client.vbucket.config.VBucket
 
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.
VBucketNodeLocator - Class in com.couchbase.client.vbucket
Implementation of the NodeLocator interface that contains vbucket hashing methods.
VBucketNodeLocator(List<MemcachedNode>, Config) - Constructor for class com.couchbase.client.vbucket.VBucketNodeLocator
Construct a VBucketNodeLocator over the given JSON configuration string.
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.
View - Class in com.couchbase.client.protocol.views
Represents a View definition inside the Couchbase cluster.
View(String, String, String, boolean, boolean) - Constructor for class com.couchbase.client.protocol.views.View
Create a new View object.
ViewConnection - Class in com.couchbase.client
The ViewConnection is responsible for managing and multiplexing HTTP connections to Couchbase View endpoints.
ViewConnection(CouchbaseConnectionFactory, List<InetSocketAddress>, String, String) - Constructor for class com.couchbase.client.ViewConnection
Boostrap the ViewConnections.
ViewDesign - Class in com.couchbase.client.protocol.views
The ViewDesign object represents a view to be stored and retrieved from the Couchbase cluster.
ViewDesign(String, String) - Constructor for class com.couchbase.client.protocol.views.ViewDesign
Create a ViewDesign with a name and a map function.
ViewDesign(String, String, String) - Constructor for class com.couchbase.client.protocol.views.ViewDesign
Create a ViewDesign with a name, map and reduce function.
ViewException - Exception in com.couchbase.client.protocol.views
An exception thrown for non-200 server error codes.
ViewException() - Constructor for exception com.couchbase.client.protocol.views.ViewException
 
ViewException(String, String) - Constructor for exception com.couchbase.client.protocol.views.ViewException
 
ViewFetcherOperation - Interface in com.couchbase.client.protocol.views
A ViewOperation.
ViewFetcherOperation.ViewFetcherCallback - Interface in com.couchbase.client.protocol.views
A ViewCallback.
ViewFetcherOperationImpl - Class in com.couchbase.client.protocol.views
A ViewOperationImpl.
ViewFetcherOperationImpl(HttpRequest, String, String, String, ViewFetcherOperation.ViewFetcherCallback) - Constructor for class com.couchbase.client.protocol.views.ViewFetcherOperationImpl
 
ViewFuture - Class in com.couchbase.client.internal
A ViewFuture.
ViewFuture(CountDownLatch, long, AbstractView, ExecutorService) - Constructor for class com.couchbase.client.internal.ViewFuture
 
ViewOperation - Interface in com.couchbase.client.protocol.views
A ViewOperation.
ViewOperation.ViewCallback - Interface in com.couchbase.client.protocol.views
A ViewCallback.
ViewOperationImpl - Class in com.couchbase.client.protocol.views
A ViewOperationImpl.
ViewOperationImpl(HttpRequest, AbstractView, OperationCallback) - Constructor for class com.couchbase.client.protocol.views.ViewOperationImpl
 
ViewPool - Class in com.couchbase.client.http
Extended Pool that allows for explicit removal of HttpHosts.
ViewPool(ConnectingIOReactor, ConnectionConfig) - Constructor for class com.couchbase.client.http.ViewPool
Create a new ViewPool.
ViewResponse - Class in com.couchbase.client.protocol.views
Holds the response of a queried view.
ViewResponse(Collection<ViewRow>, Collection<RowError>, long) - Constructor for class com.couchbase.client.protocol.views.ViewResponse
 
ViewResponseNoDocs - Class in com.couchbase.client.protocol.views
Holds the response of a view query where the map function was called and the documents are excluded.
ViewResponseNoDocs(Collection<ViewRow>, Collection<RowError>, long) - Constructor for class com.couchbase.client.protocol.views.ViewResponseNoDocs
 
ViewResponseReduced - Class in com.couchbase.client.protocol.views
Holds the response of a view query where the map and reduce function were called.
ViewResponseReduced(Collection<ViewRow>, Collection<RowError>) - Constructor for class com.couchbase.client.protocol.views.ViewResponseReduced
 
ViewResponseReduced(Collection<ViewRow>, Collection<RowError>, long) - Constructor for class com.couchbase.client.protocol.views.ViewResponseReduced
 
ViewResponseWithDocs - Class in com.couchbase.client.protocol.views
Holds the response of a view query where the map function was called and the documents are included.
ViewResponseWithDocs(Collection<ViewRow>, Collection<RowError>, long) - Constructor for class com.couchbase.client.protocol.views.ViewResponseWithDocs
 
ViewRow - Interface in com.couchbase.client.protocol.views
A ViewRow.
ViewRowNoDocs - Class in com.couchbase.client.protocol.views
Holds a row in a view result that contains the fields id, key, and value.
ViewRowNoDocs(String, String, String) - Constructor for class com.couchbase.client.protocol.views.ViewRowNoDocs
 
ViewRowReduced - Class in com.couchbase.client.protocol.views
Holds a row in a view result that contains the fields key and value.
ViewRowReduced(String, String) - Constructor for class com.couchbase.client.protocol.views.ViewRowReduced
 
ViewRowWithDocs - Class in com.couchbase.client.protocol.views
Holds a row in a view result that contains the fields id, key, value, and doc.
ViewRowWithDocs(String, String, String, Object) - Constructor for class com.couchbase.client.protocol.views.ViewRowWithDocs
 

W

waitForAndCheckOperation(long, TimeUnit) - Method in class com.couchbase.client.internal.HttpFuture
 
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 com.couchbase.client.vbucket.provider.CouchbaseConfigConnection.LoggerProxy
 
warn(Object) - Method in class com.couchbase.client.vbucket.provider.CouchbaseConfigConnection.LoggerProxy
 
warn(String, Object...) - Method in class com.couchbase.client.vbucket.provider.CouchbaseConfigConnection.LoggerProxy
 
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
 
willIncludeDocs() - Method in class com.couchbase.client.protocol.views.Query
Read if full documents will be included on the query.
willReduce() - Method in class com.couchbase.client.protocol.views.Query
Read if reduce is enabled or not.
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 

Copyright © 2006-2009 Dustin Sallings, 2009-2014 Couchbase, Inc.