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

A

AbstractBinaryMemcacheDecoder<M extends BinaryMemcacheMessage> - Class in com.couchbase.client.deps.io.netty.handler.codec.memcache.binary
AbstractBinaryMemcacheDecoder() - Constructor for class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheDecoder
Create a new AbstractBinaryMemcacheDecoder with default settings.
AbstractBinaryMemcacheDecoder(int) - Constructor for class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheDecoder
Create a new AbstractBinaryMemcacheDecoder with custom settings.
AbstractBinaryMemcacheEncoder<M extends BinaryMemcacheMessage> - Class in com.couchbase.client.deps.io.netty.handler.codec.memcache.binary
A MessageToByteEncoder that encodes binary memache messages into bytes.
AbstractBinaryMemcacheEncoder() - Constructor for class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheEncoder
 
AbstractBinaryMemcacheMessage - Class in com.couchbase.client.deps.io.netty.handler.codec.memcache.binary
Default implementation of a BinaryMemcacheMessage.
AbstractBinaryMemcacheMessage(byte[], ByteBuf) - Constructor for class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
Create a new instance with all properties set.
AbstractBucketConfig - Class in com.couchbase.client.core.config
 
AbstractBucketConfig(String, String, BucketNodeLocator, String, String, List<NodeInfo>, List<PortInfo>, List<BucketCapabilities>, NetworkAddress) - Constructor for class com.couchbase.client.core.config.AbstractBucketConfig
 
AbstractCouchbaseLogger - Class in com.couchbase.client.core.logging
A skeletal implementation of CouchbaseLogger.
AbstractCouchbaseLogger(String) - Constructor for class com.couchbase.client.core.logging.AbstractCouchbaseLogger
Creates a new instance.
AbstractCouchbaseRequest - Class in com.couchbase.client.core.message
Default implementation for a CouchbaseRequest, should be extended by child messages.
AbstractCouchbaseRequest(String, String) - Constructor for class com.couchbase.client.core.message.AbstractCouchbaseRequest
AbstractCouchbaseRequest(String, String, String) - Constructor for class com.couchbase.client.core.message.AbstractCouchbaseRequest
AbstractCouchbaseRequest(String, String, String, Subject<CouchbaseResponse, CouchbaseResponse>) - Constructor for class com.couchbase.client.core.message.AbstractCouchbaseRequest
AbstractCouchbaseResponse - Class in com.couchbase.client.core.message
The default representation of a CouchbaseResponse.
AbstractCouchbaseResponse(ResponseStatus, CouchbaseRequest) - Constructor for class com.couchbase.client.core.message.AbstractCouchbaseResponse
Sets the required properties for the response.
AbstractDynamicService - Class in com.couchbase.client.core.service
Parent implementation of a dynamic Service.
AbstractDynamicService(String, String, String, String, int, CoreContext, int, Service.EndpointFactory) - Constructor for class com.couchbase.client.core.service.AbstractDynamicService
 
AbstractEndpoint - Class in com.couchbase.client.core.endpoint
The common parent implementation for all Endpoints.
AbstractEndpoint(String, String, String, BootstrapAdapter, boolean, CoreContext, boolean) - Constructor for class com.couchbase.client.core.endpoint.AbstractEndpoint
Constructor to which allows to pass in an artificial bootstrap adapter.
AbstractEndpoint(String, String, String, String, int, CoreContext, boolean, EventLoopGroup, boolean) - Constructor for class com.couchbase.client.core.endpoint.AbstractEndpoint
Create a new AbstractEndpoint.
AbstractGenericHandler<RESPONSE,ENCODED,REQUEST extends CouchbaseRequest> - Class in com.couchbase.client.core.endpoint
Generic handler which acts as the common base type for all implementing handlers.
AbstractGenericHandler(AbstractEndpoint, EventSink<ResponseEvent>, boolean, boolean) - Constructor for class com.couchbase.client.core.endpoint.AbstractGenericHandler
Creates a new AbstractGenericHandler with the default queue.
AbstractGenericHandler(AbstractEndpoint, EventSink<ResponseEvent>, Queue<REQUEST>, boolean, boolean) - Constructor for class com.couchbase.client.core.endpoint.AbstractGenericHandler
Creates a new AbstractGenericHandler with a custom queue.
AbstractKeyValueRequest - Class in com.couchbase.client.core.message.kv
Default implementation of a BinaryRequest.
AbstractKeyValueRequest(String, String) - Constructor for class com.couchbase.client.core.message.kv.AbstractKeyValueRequest
AbstractKeyValueRequest(String, String, String) - Constructor for class com.couchbase.client.core.message.kv.AbstractKeyValueRequest
AbstractKeyValueRequest(String, String, String, String) - Constructor for class com.couchbase.client.core.message.kv.AbstractKeyValueRequest
AbstractKeyValueRequest(String, String, String, String, Subject<CouchbaseResponse, CouchbaseResponse>) - Constructor for class com.couchbase.client.core.message.kv.AbstractKeyValueRequest
AbstractKeyValueResponse - Class in com.couchbase.client.core.message.kv
 
AbstractKeyValueResponse(ResponseStatus, short, String, ByteBuf, CouchbaseRequest) - Constructor for class com.couchbase.client.core.message.kv.AbstractKeyValueResponse
 
AbstractLatencyMetricsCollector<I extends LatencyMetricsIdentifier,E extends LatencyMetricsEvent> - Class in com.couchbase.client.core.metrics
The default abstract implementation for a latency metrics collector.
AbstractLatencyMetricsCollector(EventBus, Scheduler, LatencyMetricsCollectorConfig) - Constructor for class com.couchbase.client.core.metrics.AbstractLatencyMetricsCollector
 
AbstractLazyService - Class in com.couchbase.client.core.service
This service lazily creates an Endpoint if needed and reuses it.
AbstractLazyService(String, String, String, String, int, CoreContext, Service.EndpointFactory) - Constructor for class com.couchbase.client.core.service.AbstractLazyService
 
AbstractLoader - Class in com.couchbase.client.core.config.loader
An AbstractLoader which provides common basic processing for all implementing loaders.
AbstractLoader(LoaderType, ServiceType, ClusterFacade, CoreEnvironment) - Constructor for class com.couchbase.client.core.config.loader.AbstractLoader
Create a new AbstractLoader.
AbstractMemcacheObject - Class in com.couchbase.client.deps.io.netty.handler.codec.memcache
The default MemcacheObject implementation.
AbstractMemcacheObject() - Constructor for class com.couchbase.client.deps.io.netty.handler.codec.memcache.AbstractMemcacheObject
 
AbstractMemcacheObjectAggregator - Class in com.couchbase.client.deps.io.netty.handler.codec.memcache
A ChannelHandler that aggregates an MemcacheMessage and its following MemcacheContents into a single MemcacheMessage with no following MemcacheContents.
AbstractMemcacheObjectAggregator(int) - Constructor for class com.couchbase.client.deps.io.netty.handler.codec.memcache.AbstractMemcacheObjectAggregator
 
AbstractMemcacheObjectDecoder - Class in com.couchbase.client.deps.io.netty.handler.codec.memcache
Abstract super class for both ascii and binary decoders.
AbstractMemcacheObjectDecoder() - Constructor for class com.couchbase.client.deps.io.netty.handler.codec.memcache.AbstractMemcacheObjectDecoder
 
AbstractMemcacheObjectEncoder<M extends MemcacheMessage> - Class in com.couchbase.client.deps.io.netty.handler.codec.memcache
A general purpose AbstractMemcacheObjectEncoder that encodes MemcacheMessages.
AbstractMemcacheObjectEncoder() - Constructor for class com.couchbase.client.deps.io.netty.handler.codec.memcache.AbstractMemcacheObjectEncoder
 
AbstractMetricsCollector - Class in com.couchbase.client.core.metrics
A common base class for all metrics collectors which emit events.
AbstractMetricsCollector(EventBus, Scheduler, MetricsCollectorConfig) - Constructor for class com.couchbase.client.core.metrics.AbstractMetricsCollector
 
AbstractOnDemandService - Class in com.couchbase.client.core.service
Abstract implementation of a service which enables and disables endpoints on demand.
AbstractOnDemandService(String, String, String, String, int, CoreContext, Service.EndpointFactory) - Constructor for class com.couchbase.client.core.service.AbstractOnDemandService
 
AbstractPoolingService - Class in com.couchbase.client.core.service
Abstract implementation of a (fixed size) pooling Service.
AbstractPoolingService(String, String, String, String, int, CoreContext, int, int, SelectionStrategy, Service.EndpointFactory) - Constructor for class com.couchbase.client.core.service.AbstractPoolingService
 
AbstractRefresher - Class in com.couchbase.client.core.config.refresher
Common implementation for all refreshers.
AbstractRefresher(CoreEnvironment, ClusterFacade) - Constructor for class com.couchbase.client.core.config.refresher.AbstractRefresher
Creates a new AbstractRefresher.
AbstractServiceConfig - Class in com.couchbase.client.core.env
Defines a general config for a Service.
AbstractServiceConfig(int, int, boolean, int) - Constructor for class com.couchbase.client.core.env.AbstractServiceConfig
 
AbstractStateMachine<S extends Enum> - Class in com.couchbase.client.core.state
Abstract Stateful implementation which acts like a simple state machine.
AbstractStateMachine(S) - Constructor for class com.couchbase.client.core.state.AbstractStateMachine
Creates a new state machine.
AbstractStateZipper<T,S extends Enum> - Class in com.couchbase.client.core.state
The default implementation of a StateZipper.
AbstractStateZipper(S) - Constructor for class com.couchbase.client.core.state.AbstractStateZipper
 
AbstractStringAwareBufProcessor - Class in com.couchbase.client.core.endpoint.util
Base class for ByteBufProcessor that need to take JSON string escaping into account, through the AbstractStringAwareBufProcessor.isEscaped(byte) method.
AbstractStringAwareBufProcessor() - Constructor for class com.couchbase.client.core.endpoint.util.AbstractStringAwareBufProcessor
 
AbstractSubdocMutationRequest - Class in com.couchbase.client.core.message.kv.subdoc.simple
Base class for all BinarySubdocMutationRequest.
AbstractSubdocMutationRequest(String, String, ByteBuf, String, int, long) - Constructor for class com.couchbase.client.core.message.kv.subdoc.simple.AbstractSubdocMutationRequest
AbstractSubdocMutationRequest(String, String, ByteBuf, String, int, long, Subject<CouchbaseResponse, CouchbaseResponse>) - Constructor for class com.couchbase.client.core.message.kv.subdoc.simple.AbstractSubdocMutationRequest
AbstractSubdocRequest - Class in com.couchbase.client.core.message.kv.subdoc.simple
Base class for all BinarySubdocRequest.
AbstractSubdocRequest(String, String, String, ByteBuf...) - Constructor for class com.couchbase.client.core.message.kv.subdoc.simple.AbstractSubdocRequest
Creates a new AbstractSubdocRequest.
AbstractSubdocRequest(String, String, String, Subject<CouchbaseResponse, CouchbaseResponse>, ByteBuf...) - Constructor for class com.couchbase.client.core.message.kv.subdoc.simple.AbstractSubdocRequest
Creates a new AbstractSubdocRequest.
acceptOutboundMessage(Object) - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.AbstractMemcacheObjectEncoder
 
accessDeleted(boolean) - Method in class com.couchbase.client.core.message.kv.subdoc.multi.SubMultiLookupDocOptionsBuilder
 
accessDeleted() - Method in class com.couchbase.client.core.message.kv.subdoc.multi.SubMultiLookupDocOptionsBuilder
 
accessDeleted() - Method in class com.couchbase.client.core.message.kv.subdoc.simple.SubExistRequest
 
accessDeleted(boolean) - Method in class com.couchbase.client.core.message.kv.subdoc.simple.SubExistRequest
 
accessDeleted() - Method in class com.couchbase.client.core.message.kv.subdoc.simple.SubGetCountRequest
 
accessDeleted(boolean) - Method in class com.couchbase.client.core.message.kv.subdoc.simple.SubGetCountRequest
 
accessDeleted() - Method in class com.couchbase.client.core.message.kv.subdoc.simple.SubGetRequest
 
accessDeleted(boolean) - Method in class com.couchbase.client.core.message.kv.subdoc.simple.SubGetRequest
 
activate(Span, boolean) - Method in class com.couchbase.client.core.tracing.ThresholdLogScopeManager
 
active() - Method in class com.couchbase.client.core.tracing.ThresholdLogScopeManager
 
activeSpan() - Method in class com.couchbase.client.core.tracing.ThresholdLogTracer
 
add(StatResponse) - Method in class com.couchbase.client.core.message.kv.StatRequest
 
ADD - Static variable in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
addHttpBasicAuth(ChannelHandlerContext, HttpRequest, String, String) - Static method in class com.couchbase.client.core.endpoint.AbstractGenericHandler
Add basic authentication headers to a HttpRequest.
addNode(NetworkAddress) - Method in class com.couchbase.client.core.RequestHandler
Add a Node identified by its hostname.
AddNodeRequest - Class in com.couchbase.client.core.message.internal
 
AddNodeRequest(NetworkAddress) - Constructor for class com.couchbase.client.core.message.internal.AddNodeRequest
 
AddNodeResponse - Class in com.couchbase.client.core.message.internal
 
AddNodeResponse(ResponseStatus, NetworkAddress) - Constructor for class com.couchbase.client.core.message.internal.AddNodeResponse
 
ADDQ - Static variable in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
addReference(String, SpanContext) - Method in class com.couchbase.client.core.tracing.ThresholdLogSpanBuilder
 
addRequest(CouchbaseRequest) - Method in class com.couchbase.client.core.tracing.RingBufferMonitor
 
address() - Method in class com.couchbase.client.core.utils.NetworkAddress
Returns the string IP representation for this network address.
addService(AddServiceRequest) - Method in class com.couchbase.client.core.node.CouchbaseNode
 
addService(Service, String) - Method in class com.couchbase.client.core.node.DefaultServiceRegistry
 
addService(AddServiceRequest) - Method in interface com.couchbase.client.core.node.Node
 
addService(Service, String) - Method in interface com.couchbase.client.core.node.ServiceRegistry
 
addService(AddServiceRequest) - Method in class com.couchbase.client.core.RequestHandler
Add the service to the node.
AddServiceRequest - Class in com.couchbase.client.core.message.internal
 
AddServiceRequest(ServiceType, String, String, int, NetworkAddress) - Constructor for class com.couchbase.client.core.message.internal.AddServiceRequest
 
AddServiceRequest(ServiceType, String, String, String, int, NetworkAddress) - Constructor for class com.couchbase.client.core.message.internal.AddServiceRequest
 
AddServiceResponse - Class in com.couchbase.client.core.message.internal
 
AddServiceResponse(ResponseStatus, NetworkAddress) - Constructor for class com.couchbase.client.core.message.internal.AddServiceResponse
 
after() - Method in class com.couchbase.client.core.endpoint.kv.ErrorMap.RetrySpecification
 
afterSpanSet(Span) - Method in class com.couchbase.client.core.message.AbstractCouchbaseRequest
Use this method to add custom span values on insert.
afterSpanSet(Span) - Method in class com.couchbase.client.core.message.analytics.GenericAnalyticsRequest
 
afterSpanSet(Span) - Method in class com.couchbase.client.core.message.analytics.PingRequest
 
afterSpanSet(Span) - Method in class com.couchbase.client.core.message.kv.AbstractKeyValueRequest
 
afterSpanSet(Span) - Method in class com.couchbase.client.core.message.query.GenericQueryRequest
 
afterSpanSet(Span) - Method in class com.couchbase.client.core.message.query.PingRequest
 
afterSpanSet(Span) - Method in class com.couchbase.client.core.message.search.GetSearchIndexRequest
 
afterSpanSet(Span) - Method in class com.couchbase.client.core.message.search.PingRequest
 
afterSpanSet(Span) - Method in class com.couchbase.client.core.message.search.RemoveSearchIndexRequest
 
afterSpanSet(Span) - Method in class com.couchbase.client.core.message.search.SearchQueryRequest
 
afterSpanSet(Span) - Method in class com.couchbase.client.core.message.search.UpsertSearchIndexRequest
 
afterSpanSet(Span) - Method in class com.couchbase.client.core.message.view.GetDesignDocumentRequest
 
afterSpanSet(Span) - Method in class com.couchbase.client.core.message.view.PingRequest
 
afterSpanSet(Span) - Method in class com.couchbase.client.core.message.view.RemoveDesignDocumentRequest
 
afterSpanSet(Span) - Method in class com.couchbase.client.core.message.view.UpsertDesignDocumentRequest
 
afterSpanSet(Span) - Method in class com.couchbase.client.core.message.view.ViewQueryRequest
 
all() - Method in class com.couchbase.client.core.event.metrics.RuntimeMetricsEvent
 
allHosts() - Method in class com.couchbase.client.core.utils.ConnectionString
Get the list of all hosts set on the connection string.
allNodeAddresses() - Method in interface com.couchbase.client.core.config.ClusterConfig
Returns the addresses of all nodes in the cluster, accumulated from all open buckets.
allNodeAddresses() - Method in class com.couchbase.client.core.config.DefaultClusterConfig
 
ALLOW_REVERSE_DNS - Static variable in class com.couchbase.client.core.utils.NetworkAddress
Flag which controls the usage of reverse dns
AlternateAddress - Interface in com.couchbase.client.core.config
 
alternateAddresses() - Method in class com.couchbase.client.core.config.DefaultNodeInfo
 
alternateAddresses() - Method in class com.couchbase.client.core.config.DefaultPortInfo
 
alternateAddresses() - Method in interface com.couchbase.client.core.config.NodeInfo
Contains alternate addresses, if set.
alternateAddresses() - Method in interface com.couchbase.client.core.config.PortInfo
 
ANALYTICS_ENDPOINTS - Static variable in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
AnalyticsEndpoint - Class in com.couchbase.client.core.endpoint.analytics
This endpoint defines the pipeline for analytics requests and responses.
AnalyticsEndpoint(String, String, String, int, CoreContext) - Constructor for class com.couchbase.client.core.endpoint.analytics.AnalyticsEndpoint
 
AnalyticsEndpoint(String, String, String, String, int, CoreContext) - Constructor for class com.couchbase.client.core.endpoint.analytics.AnalyticsEndpoint
 
AnalyticsHandler - Class in com.couchbase.client.core.endpoint.analytics
The AnalyticsHandler is responsible for encoding AnalyticsRequests into lower level HttpRequests as well as decoding HttpObjects into CouchbaseResponses.
AnalyticsHandler(AbstractEndpoint, RingBuffer<ResponseEvent>, boolean, boolean) - Constructor for class com.couchbase.client.core.endpoint.analytics.AnalyticsHandler
Creates a new AnalyticsHandler with the default queue for requests.
AnalyticsHandler.KeepAliveRequest - Class in com.couchbase.client.core.endpoint.analytics
 
AnalyticsHandler.KeepAliveResponse - Class in com.couchbase.client.core.endpoint.analytics
 
analyticsIoPool() - Method in interface com.couchbase.client.core.env.CoreEnvironment
If set returns the IO Pool for the analytics service, if not returns null.
analyticsIoPool() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
analyticsIoPool(EventLoopGroup, ShutdownHook) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Sets the Analytics I/O Pool implementation for the underlying IO framework, along with the action to execute when this environment is shut down.
AnalyticsLocator - Class in com.couchbase.client.core.node.locate
Round robin node locator for Analytics.
AnalyticsLocator() - Constructor for class com.couchbase.client.core.node.locate.AnalyticsLocator
 
AnalyticsRequest - Interface in com.couchbase.client.core.message.analytics
Marker interface for all requests against the Analytics Service
AnalyticsService - Class in com.couchbase.client.core.service
The AnalyticsService is composed of and manages AnalyticsEndpoints.
AnalyticsService(String, String, String, int, CoreContext) - Constructor for class com.couchbase.client.core.service.AnalyticsService
Deprecated.
AnalyticsService(String, String, String, String, int, CoreContext) - Constructor for class com.couchbase.client.core.service.AnalyticsService
Creates a new AnalyticsService.
AnalyticsServiceConfig - Class in com.couchbase.client.core.env
 
analyticsServiceConfig() - Method in interface com.couchbase.client.core.env.CoreEnvironment
Returns the current AnalyticsService configuration.
analyticsServiceConfig() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
analyticsServiceConfig(AnalyticsServiceConfig) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Allows to set a custom configuration for the Analytics service.
analyticsThreshold(long, TimeUnit) - Method in class com.couchbase.client.core.tracing.ThresholdLogReporter.Builder
Allows to customize the analyticsThreshold.
APPEND - Static variable in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
APPENDQ - Static variable in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
AppendRequest - Class in com.couchbase.client.core.message.kv
 
AppendRequest(String, long, ByteBuf, String) - Constructor for class com.couchbase.client.core.message.kv.AppendRequest
 
AppendResponse - Class in com.couchbase.client.core.message.kv
 
AppendResponse(ResponseStatus, short, long, String, ByteBuf, MutationToken, CouchbaseRequest) - Constructor for class com.couchbase.client.core.message.kv.AppendResponse
 
arrayOperation() - Method in class com.couchbase.client.core.message.kv.subdoc.simple.SubArrayRequest
 
asChildOf(SpanContext) - Method in class com.couchbase.client.core.tracing.ThresholdLogSpanBuilder
 
asChildOf(Span) - Method in class com.couchbase.client.core.tracing.ThresholdLogSpanBuilder
 
asJson() - Method in enum com.couchbase.client.core.message.internal.PingServiceHealth.PingState
Returns the json representation for this enum.
attributes() - Method in class com.couchbase.client.core.endpoint.kv.ErrorMap.ErrorCode
 
AUTH_CONTINUE - Static variable in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheResponseStatus
 
AUTH_ERROR - Static variable in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheResponseStatus
 
AuthenticationException - Exception in com.couchbase.client.core.endpoint.kv
 
AuthenticationException() - Constructor for exception com.couchbase.client.core.endpoint.kv.AuthenticationException
 
AuthenticationException(String) - Constructor for exception com.couchbase.client.core.endpoint.kv.AuthenticationException
 
AuthenticationException(String, Throwable) - Constructor for exception com.couchbase.client.core.endpoint.kv.AuthenticationException
 
AuthenticationException(Throwable) - Constructor for exception com.couchbase.client.core.endpoint.kv.AuthenticationException
 
AUTO - Static variable in class com.couchbase.client.core.env.NetworkResolution
Based on heuristics discovers if internal or external resolution will be used.
AUTORELEASE_AFTER - Static variable in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
autoreleaseAfter() - Method in interface com.couchbase.client.core.env.CoreEnvironment
The time in milliseconds after which a non-subscribed observable is going to be automatically released.
autoreleaseAfter() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
autoreleaseAfter(long) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Sets the time after which any non-consumed buffers will be automatically released.

B

BACKPRESSURE_EXCEPTION - Static variable in class com.couchbase.client.core.CouchbaseCore
A preconstructed BackpressureException.
BackpressureException - Exception in com.couchbase.client.core
Identifies the need to back off on the supplier side when using a service, because the consumer is overloaded.
BackpressureException() - Constructor for exception com.couchbase.client.core.BackpressureException
 
BackpressureException(RingBufferDiagnostics) - Constructor for exception com.couchbase.client.core.BackpressureException
 
baggageItem(String, String) - Method in class com.couchbase.client.core.tracing.ThresholdLogSpanContext
Stores the given baggage item/value.
baggageItem(String) - Method in class com.couchbase.client.core.tracing.ThresholdLogSpanContext
Retrieve the baggage value by item.
baggageItems() - Method in class com.couchbase.client.core.tracing.ThresholdLogSpanContext
 
Base64 - Class in com.couchbase.client.core.utils
Utility class to perform base64 encoding/decoding.
beforeSend(CouchbaseRequest, Observable<CouchbaseResponse>) - Method in interface com.couchbase.client.core.hooks.CouchbaseCoreSendHook
Allows to hook in before the send method on core, make sure to return either the original tuple or the modified ones from the originals.
BestEffortRetryStrategy - Class in com.couchbase.client.core.retry
A RetryStrategy that will retry until the max request lifetime is reached.
BinaryMemcacheClientCodec - Class in com.couchbase.client.deps.io.netty.handler.codec.memcache.binary
The client codec that combines the proper encoder and decoder.
BinaryMemcacheClientCodec() - Constructor for class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheClientCodec
Create a new BinaryMemcacheClientCodec with the default settings applied.
BinaryMemcacheClientCodec(int) - Constructor for class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheClientCodec
Create a new BinaryMemcacheClientCodec and set a custom chunk size.
BinaryMemcacheClientCodec(int, boolean) - Constructor for class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheClientCodec
Create a new BinaryMemcacheClientCodec with custom settings.
BinaryMemcacheMessage - Interface in com.couchbase.client.deps.io.netty.handler.codec.memcache.binary
An interface that defines a binary Memcache message, providing common properties for BinaryMemcacheRequest and BinaryMemcacheResponse.
BinaryMemcacheObjectAggregator - Class in com.couchbase.client.deps.io.netty.handler.codec.memcache.binary
An object aggregator for the memcache binary protocol.
BinaryMemcacheObjectAggregator(int) - Constructor for class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheObjectAggregator
 
BinaryMemcacheOpcodes - Class in com.couchbase.client.deps.io.netty.handler.codec.memcache.binary
Represents all Opcodes that can occur in a BinaryMemcacheMessage.
BinaryMemcacheRequest - Interface in com.couchbase.client.deps.io.netty.handler.codec.memcache.binary
Represents a full BinaryMemcacheRequest, which contains the header and optional key and extras.
BinaryMemcacheRequestDecoder - Class in com.couchbase.client.deps.io.netty.handler.codec.memcache.binary
The decoder part which takes care of decoding the request-specific headers.
BinaryMemcacheRequestDecoder() - Constructor for class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheRequestDecoder
 
BinaryMemcacheRequestDecoder(int) - Constructor for class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheRequestDecoder
 
BinaryMemcacheRequestEncoder - Class in com.couchbase.client.deps.io.netty.handler.codec.memcache.binary
The encoder part which takes care of encoding the request headers.
BinaryMemcacheRequestEncoder() - Constructor for class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheRequestEncoder
 
BinaryMemcacheResponse - Interface in com.couchbase.client.deps.io.netty.handler.codec.memcache.binary
Represents a full BinaryMemcacheResponse, which contains the header and optional key and extras.
BinaryMemcacheResponseDecoder - Class in com.couchbase.client.deps.io.netty.handler.codec.memcache.binary
The decoder which takes care of decoding the response headers.
BinaryMemcacheResponseDecoder() - Constructor for class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheResponseDecoder
 
BinaryMemcacheResponseDecoder(int) - Constructor for class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheResponseDecoder
 
BinaryMemcacheResponseEncoder - Class in com.couchbase.client.deps.io.netty.handler.codec.memcache.binary
The encoder which takes care of encoding the response headers.
BinaryMemcacheResponseEncoder() - Constructor for class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheResponseEncoder
 
BinaryMemcacheResponseStatus - Class in com.couchbase.client.deps.io.netty.handler.codec.memcache.binary
Contains all possible status values a response can return.
BinaryRequest - Interface in com.couchbase.client.core.message.kv
Common marker interface for all BinaryRequests.
BinaryResponse - Interface in com.couchbase.client.core.message.kv
Marker interface which signals a binary response.
BinaryStoreRequest - Interface in com.couchbase.client.core.message.kv
 
BinarySubdocMultiLookupRequest - Interface in com.couchbase.client.core.message.kv.subdoc
A BinarySubdocRequest that describes multiple lookup operations on a single document.
BinarySubdocMultiMutationRequest - Interface in com.couchbase.client.core.message.kv.subdoc
A BinarySubdocRequest that describes multiple mutations on a single document.
BinarySubdocMutationRequest - Interface in com.couchbase.client.core.message.kv.subdoc
A BinarySubdocRequest that describes a mutation operation.
BinarySubdocRequest - Interface in com.couchbase.client.core.message.kv.subdoc
A type of BinaryRequest that deals with getting or mutating parts of a JSON document, aka a Sub-Document.
bind(ChannelHandlerContext, SocketAddress, ChannelPromise) - Method in class com.couchbase.client.core.endpoint.kv.KeyValueAuthHandler
 
bind(ChannelHandlerContext, SocketAddress, ChannelPromise) - Method in class com.couchbase.client.core.endpoint.kv.KeyValueErrorMapHandler
 
bind(ChannelHandlerContext, SocketAddress, ChannelPromise) - Method in class com.couchbase.client.core.endpoint.kv.KeyValueFeatureHandler
 
bind(ChannelHandlerContext, SocketAddress, ChannelPromise) - Method in class com.couchbase.client.core.endpoint.kv.KeyValueSelectBucketHandler
 
blockForSingle(Observable<? extends T>, long, TimeUnit) - Static method in class com.couchbase.client.core.utils.Blocking
Blocks on an Observable and returns a single event or throws an Exception.
Blocking - Class in com.couchbase.client.core.utils
Contains various utility methods related to blocking operations.
Blocking() - Constructor for class com.couchbase.client.core.utils.Blocking
 
body() - Method in class com.couchbase.client.core.message.config.RestApiRequest
 
body() - Method in class com.couchbase.client.core.message.config.RestApiResponse
 
body() - Method in class com.couchbase.client.core.message.view.UpsertDesignDocumentRequest
 
booleanPropertyOr(String, boolean) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
BOOTSTRAP_CARRIER_DIRECT_PORT - Static variable in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
BOOTSTRAP_CARRIER_ENABLED - Static variable in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
BOOTSTRAP_CARRIER_SSL_PORT - Static variable in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
BOOTSTRAP_HTTP_DIRECT_PORT - Static variable in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
BOOTSTRAP_HTTP_ENABLED - Static variable in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
BOOTSTRAP_HTTP_SSL_PORT - Static variable in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
BootstrapAdapter - Class in com.couchbase.client.core.endpoint
A wrapper for the IO Bootstrap class.
BootstrapAdapter(Bootstrap) - Constructor for class com.couchbase.client.core.endpoint.BootstrapAdapter
Create a new BootstrapAdapter.
bootstrapCarrierDirectPort() - Method in interface com.couchbase.client.core.env.CoreEnvironment
The port to use when bootstrapping through carrier publication without SSL.
bootstrapCarrierDirectPort() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
bootstrapCarrierDirectPort(int) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
If carrier publication bootstrap is enabled and not SSL, sets the port to use (default value ).
bootstrapCarrierEnabled() - Method in interface com.couchbase.client.core.env.CoreEnvironment
If bootstrapping through the advanced carrier publication is enabled.
bootstrapCarrierEnabled() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
bootstrapCarrierEnabled(boolean) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Toggles bootstrap via carrier publication (default value ).
bootstrapCarrierSslPort() - Method in interface com.couchbase.client.core.env.CoreEnvironment
The port to use when bootstrapping through carrier publication with SSL.
bootstrapCarrierSslPort() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
bootstrapCarrierSslPort(int) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
If carrier publication bootstrap and SSL are enabled, sets the port to use (default value ).
bootstrapHttpDirectPort() - Method in interface com.couchbase.client.core.env.CoreEnvironment
The port to use when bootstrapping through HTTP without SSL.
bootstrapHttpDirectPort() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
bootstrapHttpDirectPort(int) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
If Http bootstrap is enabled and not SSL, sets the port to use (default value ).
bootstrapHttpEnabled() - Method in interface com.couchbase.client.core.env.CoreEnvironment
If bootstrapping through HTTP is enabled.
bootstrapHttpEnabled() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
bootstrapHttpEnabled(boolean) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Toggles bootstrap via Http (default value ).
bootstrapHttpSslPort() - Method in interface com.couchbase.client.core.env.CoreEnvironment
The port to use when bootstrapping through HTTP with SSL.
bootstrapHttpSslPort() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
bootstrapHttpSslPort(int) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
If Http bootstrap and SSL are enabled, sets the port to use (default value ).
BootstrapMessage - Interface in com.couchbase.client.core.message
Marker interface for messages that should be allowed to go through the RequestHandler, despite no bucket configuration available to check upon.
bucket() - Method in class com.couchbase.client.core.endpoint.AbstractEndpoint
The name of the bucket.
bucket() - Method in class com.couchbase.client.core.message.AbstractCouchbaseRequest
 
bucket() - Method in interface com.couchbase.client.core.message.CouchbaseRequest
The associated bucket name for this request.
bucket() - Method in class com.couchbase.client.core.message.kv.AbstractKeyValueResponse
 
bucket() - Method in interface com.couchbase.client.core.message.kv.BinaryResponse
The name of the bucket where this response is coming from.
bucket() - Method in class com.couchbase.client.core.message.kv.MutationToken
 
BucketCapabilities - Enum in com.couchbase.client.core.config
Describes the bucket capabilities in an abstract fashion as provided by the server.
BucketClosedEvent - Class in com.couchbase.client.core.event.system
Event published when a bucket is closed.
BucketClosedEvent(String) - Constructor for class com.couchbase.client.core.event.system.BucketClosedEvent
 
BucketClosedException - Exception in com.couchbase.client.core
A RuntimeException being thrown whenever an operation on a bucket that has been closed is attempted.
BucketClosedException() - Constructor for exception com.couchbase.client.core.BucketClosedException
 
BucketClosedException(String) - Constructor for exception com.couchbase.client.core.BucketClosedException
 
BucketClosedException(String, Throwable) - Constructor for exception com.couchbase.client.core.BucketClosedException
 
BucketConfig - Interface in com.couchbase.client.core.config
Represents a Couchbase Bucket Configuration.
bucketConfig(String) - Method in interface com.couchbase.client.core.config.ClusterConfig
Returns the BucketConfig for the given bucket name.
bucketConfig(String) - Method in class com.couchbase.client.core.config.DefaultClusterConfig
 
BucketConfigParser - Class in com.couchbase.client.core.config.parser
An abstraction over the bucket parser which takes a raw config as a string and turns it into a BucketConfig.
BucketConfigParser() - Constructor for class com.couchbase.client.core.config.parser.BucketConfigParser
 
BucketConfigRequest - Class in com.couchbase.client.core.message.config
 
BucketConfigRequest(String, NetworkAddress, String, String) - Constructor for class com.couchbase.client.core.message.config.BucketConfigRequest
 
BucketConfigRequest(String, NetworkAddress, String, String, String) - Constructor for class com.couchbase.client.core.message.config.BucketConfigRequest
 
BucketConfigResponse - Class in com.couchbase.client.core.message.config
 
BucketConfigResponse(String, ResponseStatus) - Constructor for class com.couchbase.client.core.message.config.BucketConfigResponse
 
bucketConfigs() - Method in interface com.couchbase.client.core.config.ClusterConfig
 
bucketConfigs() - Method in class com.couchbase.client.core.config.DefaultClusterConfig
 
bucketName() - Method in class com.couchbase.client.core.config.ProposedBucketConfigContext
 
BucketNodeLocator - Enum in com.couchbase.client.core.config
Represents the node locator used for the specific bucket type.
BucketOpenedEvent - Class in com.couchbase.client.core.event.system
Event published when a bucket is opened.
BucketOpenedEvent(String) - Constructor for class com.couchbase.client.core.event.system.BucketOpenedEvent
 
BucketsConfigRequest - Class in com.couchbase.client.core.message.config
 
BucketsConfigRequest(String, String) - Constructor for class com.couchbase.client.core.message.config.BucketsConfigRequest
 
BucketsConfigResponse - Class in com.couchbase.client.core.message.config
 
BucketsConfigResponse(String, ResponseStatus) - Constructor for class com.couchbase.client.core.message.config.BucketsConfigResponse
 
BucketServiceMapping - Enum in com.couchbase.client.core.service
Defines the relationship between a bucket and a service.
BucketStreamingRequest - Class in com.couchbase.client.core.message.config
 
BucketStreamingRequest(String, String, String) - Constructor for class com.couchbase.client.core.message.config.BucketStreamingRequest
 
BucketStreamingRequest(String, String, String, String) - Constructor for class com.couchbase.client.core.message.config.BucketStreamingRequest
 
BucketStreamingResponse - Class in com.couchbase.client.core.message.config
 
BucketStreamingResponse(Observable<String>, String, ResponseStatus, CouchbaseRequest) - Constructor for class com.couchbase.client.core.message.config.BucketStreamingResponse
 
BucketType - Enum in com.couchbase.client.core.config
Represents the possible bucket types.
BUFFER_POOLING_ENABLED - Static variable in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
bufferPoolingEnabled() - Method in interface com.couchbase.client.core.env.CoreEnvironment
Returns if buffer pooling is enabled for greater GC efficiency.
bufferPoolingEnabled() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
bufferPoolingEnabled(boolean) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Forcefully disable buffer pooling by setting the value to false.
Buffers - Class in com.couchbase.client.core.utils
Collection of utilities around ByteBuf.
Buffers() - Constructor for class com.couchbase.client.core.utils.Buffers
 
build() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
 
build() - Method in class com.couchbase.client.core.message.kv.subdoc.multi.LookupCommandBuilder
 
build() - Method in class com.couchbase.client.core.message.kv.subdoc.multi.MutationCommandBuilder
 
build() - Method in class com.couchbase.client.core.metrics.DefaultLatencyMetricsCollectorConfig.Builder
 
build() - Method in class com.couchbase.client.core.metrics.DefaultMetricsCollectorConfig.Builder
 
build() - Method in class com.couchbase.client.core.tracing.DefaultOrphanResponseReporter.Builder
 
build() - Method in class com.couchbase.client.core.tracing.ThresholdLogReporter.Builder
 
builder() - Static method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
Builder() - Constructor for class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
 
builder() - Static method in class com.couchbase.client.core.message.kv.subdoc.multi.SubMultiLookupDocOptionsBuilder
 
builder() - Static method in class com.couchbase.client.core.message.kv.subdoc.multi.SubMultiMutationDocOptionsBuilder
 
builder() - Static method in class com.couchbase.client.core.metrics.DefaultLatencyMetricsCollectorConfig
 
Builder() - Constructor for class com.couchbase.client.core.metrics.DefaultLatencyMetricsCollectorConfig.Builder
 
Builder() - Constructor for class com.couchbase.client.core.metrics.DefaultMetricsCollectorConfig.Builder
 
builder() - Static method in class com.couchbase.client.core.tracing.DefaultOrphanResponseReporter
 
Builder() - Constructor for class com.couchbase.client.core.tracing.DefaultOrphanResponseReporter.Builder
 
builder() - Static method in class com.couchbase.client.core.tracing.ThresholdLogReporter
 
Builder() - Constructor for class com.couchbase.client.core.tracing.ThresholdLogReporter.Builder
 
buildInvalidMessage() - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheDecoder
Helper method to create a upstream message when the incoming parsing did fail.
buildInvalidMessage() - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheRequestDecoder
 
buildInvalidMessage() - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheResponseDecoder
 
buildSpan(String) - Method in class com.couchbase.client.core.tracing.ThresholdLogTracer
 
BYTE_BUF_RELEASER - Static variable in class com.couchbase.client.core.utils.Buffers
An rx Action1 that releases (once) a non-null ByteBuf provided its refCnt is > 0.
ByteBufJsonHelper - Class in com.couchbase.client.core.endpoint.util
An helper class providing utility methods to deal with parsing of structured data (like JSON) inside a ByteBuf buffer.
ByteBufJsonHelper() - Constructor for class com.couchbase.client.core.endpoint.util.ByteBufJsonHelper
 
ByteBufJsonParser - Class in com.couchbase.client.core.utils.yasjl
The ByteBufJsonParser allows to query for values identified by JsonPointer in Netty ByteBuf.
ByteBufJsonParser(JsonPointer[]) - Constructor for class com.couchbase.client.core.utils.yasjl.ByteBufJsonParser
Creates a new ByteBufJsonParser and initializes all of its internal processors.

C

C_CURLY - Static variable in class com.couchbase.client.core.utils.yasjl.JsonParserUtils
 
C_SQUARE - Static variable in class com.couchbase.client.core.utils.yasjl.JsonParserUtils
 
calculate(long) - Method in class com.couchbase.client.core.time.Delay
Calculate a specific delay based on the attempt passed in.
calculate(long) - Method in class com.couchbase.client.core.time.ExponentialDelay
 
calculate(long) - Method in class com.couchbase.client.core.time.FixedDelay
 
calculate(long) - Method in class com.couchbase.client.core.time.LinearDelay
 
calculateAlternatePower(long) - Method in class com.couchbase.client.core.time.ExponentialDelay
 
calculatePowerOfTwo(long) - Method in class com.couchbase.client.core.time.ExponentialDelay
 
call(ClusterFacade, String, String, long, boolean, Observe.PersistTo, Observe.ReplicateTo, RetryStrategy) - Static method in class com.couchbase.client.core.message.observe.Observe
 
call(ClusterFacade, String, String, long, boolean, Observe.PersistTo, Observe.ReplicateTo, Delay, RetryStrategy) - Static method in class com.couchbase.client.core.message.observe.Observe
 
call(ClusterFacade, String, String, long, boolean, MutationToken, Observe.PersistTo, Observe.ReplicateTo, Delay, RetryStrategy) - Static method in class com.couchbase.client.core.message.observe.Observe
 
call(ClusterFacade, String, String, long, boolean, Observe.PersistTo, Observe.ReplicateTo, RetryStrategy, Span) - Static method in class com.couchbase.client.core.message.observe.Observe
 
call(ClusterFacade, String, String, long, boolean, Observe.PersistTo, Observe.ReplicateTo, Delay, RetryStrategy, Span) - Static method in class com.couchbase.client.core.message.observe.Observe
 
call(ClusterFacade, String, String, long, boolean, MutationToken, Observe.PersistTo, Observe.ReplicateTo, Delay, RetryStrategy, Span) - Static method in class com.couchbase.client.core.message.observe.Observe
 
call(ClusterFacade, String, String, long, boolean, Observe.PersistTo, Observe.ReplicateTo, Delay, RetryStrategy, Span) - Static method in class com.couchbase.client.core.message.observe.ObserveViaCAS
 
call(ClusterFacade, String, String, MutationToken, Observe.PersistTo, Observe.ReplicateTo, Delay, RetryStrategy, Span, long) - Static method in class com.couchbase.client.core.message.observe.ObserveViaMutationToken
 
call(ClusterFacade, String, String) - Static method in class com.couchbase.client.core.message.stat.Stat
 
call(ByteBuf) - Method in interface com.couchbase.client.core.utils.yasjl.Callbacks.JsonPointerCB1
 
call(JsonPointer, ByteBuf) - Method in interface com.couchbase.client.core.utils.yasjl.Callbacks.JsonPointerCB2
 
CALLBACKS_ON_IO_POOL - Static variable in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
callbacksOnIoPool() - Method in interface com.couchbase.client.core.env.CoreEnvironment
Returns true if the Observable callbacks are completed on the IO event loops.
callbacksOnIoPool(boolean) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Set to true if the Observable callbacks should be completed on the IO event loops.
callbacksOnIoPool() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
CarrierLoader - Class in com.couchbase.client.core.config.loader
Loads a raw bucket configuration through the carrier mechanism (also commonly referred to as CCCP).
CarrierLoader(ClusterFacade, CoreEnvironment) - Constructor for class com.couchbase.client.core.config.loader.CarrierLoader
Creates a new CarrierLoader.
CarrierRefresher - Class in com.couchbase.client.core.config.refresher
Keeps the bucket config fresh through carrier configuration management.
CarrierRefresher(CoreEnvironment, ClusterFacade) - Constructor for class com.couchbase.client.core.config.refresher.CarrierRefresher
Creates a new CarrierRefresher.
cas() - Method in class com.couchbase.client.core.message.kv.AppendRequest
 
cas() - Method in class com.couchbase.client.core.message.kv.AppendResponse
 
cas() - Method in class com.couchbase.client.core.message.kv.CounterResponse
 
cas() - Method in class com.couchbase.client.core.message.kv.GetResponse
 
cas() - Method in class com.couchbase.client.core.message.kv.InsertResponse
 
cas() - Method in class com.couchbase.client.core.message.kv.ObserveRequest
 
cas() - Method in class com.couchbase.client.core.message.kv.ObserveResponse
 
cas() - Method in class com.couchbase.client.core.message.kv.ObserveSeqnoRequest
 
cas() - Method in class com.couchbase.client.core.message.kv.PrependRequest
 
cas() - Method in class com.couchbase.client.core.message.kv.PrependResponse
 
cas() - Method in class com.couchbase.client.core.message.kv.RemoveRequest
The CAS value of the request.
cas() - Method in class com.couchbase.client.core.message.kv.RemoveResponse
 
cas() - Method in class com.couchbase.client.core.message.kv.ReplaceRequest
The CAS value of the request.
cas() - Method in class com.couchbase.client.core.message.kv.ReplaceResponse
 
cas() - Method in interface com.couchbase.client.core.message.kv.subdoc.BinarySubdocMultiMutationRequest
 
cas() - Method in interface com.couchbase.client.core.message.kv.subdoc.BinarySubdocMutationRequest
 
cas() - Method in class com.couchbase.client.core.message.kv.subdoc.multi.MultiLookupResponse
 
cas() - Method in class com.couchbase.client.core.message.kv.subdoc.multi.MultiMutationResponse
 
cas() - Method in class com.couchbase.client.core.message.kv.subdoc.multi.SubMultiMutationRequest
 
cas() - Method in class com.couchbase.client.core.message.kv.subdoc.simple.AbstractSubdocMutationRequest
 
cas() - Method in class com.couchbase.client.core.message.kv.subdoc.simple.SimpleSubdocResponse
 
cas() - Method in class com.couchbase.client.core.message.kv.UnlockRequest
 
cas() - Method in class com.couchbase.client.core.message.kv.UpsertResponse
 
ceil() - Method in class com.couchbase.client.core.endpoint.kv.ErrorMap.RetrySpecification
 
CERT_AUTH_ENABLED - Static variable in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
certAuthEnabled() - Method in interface com.couchbase.client.core.env.CoreEnvironment
True if X.509 client certificate authentication is enabled.
certAuthEnabled(boolean) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Allows to enable X.509 client certificate authentication.
certAuthEnabled() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
channelActive(ChannelHandlerContext) - Method in class com.couchbase.client.core.endpoint.AbstractGenericHandler
 
channelActive(ChannelHandlerContext) - Method in class com.couchbase.client.core.endpoint.kv.KeyValueAuthHandler
Once the channel is marked as active, the SASL negotiation is started.
channelActive(ChannelHandlerContext) - Method in class com.couchbase.client.core.endpoint.kv.KeyValueErrorMapHandler
 
channelActive(ChannelHandlerContext) - Method in class com.couchbase.client.core.endpoint.kv.KeyValueFeatureHandler
 
channelActive(ChannelHandlerContext) - Method in class com.couchbase.client.core.endpoint.kv.KeyValueSelectBucketHandler
Once the channel is marked as active, select bucket command is sent if the HELLO request has SELECT_BUCKET feature enabled.
channelInactive(ChannelHandlerContext) - Method in class com.couchbase.client.core.endpoint.AbstractGenericHandler
 
channelInactive(ChannelHandlerContext) - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.AbstractMemcacheObjectAggregator
 
channelInactive(ChannelHandlerContext) - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheDecoder
When the channel goes inactive, release all frames to prevent data leaks.
channelRead0(ChannelHandlerContext, FullBinaryMemcacheResponse) - Method in class com.couchbase.client.core.endpoint.kv.KeyValueAuthHandler
Dispatches incoming SASL responses to the appropriate handler methods.
channelRead0(ChannelHandlerContext, FullBinaryMemcacheResponse) - Method in class com.couchbase.client.core.endpoint.kv.KeyValueErrorMapHandler
 
channelRead0(ChannelHandlerContext, FullBinaryMemcacheResponse) - Method in class com.couchbase.client.core.endpoint.kv.KeyValueFeatureHandler
 
channelRead0(ChannelHandlerContext, FullBinaryMemcacheResponse) - Method in class com.couchbase.client.core.endpoint.kv.KeyValueSelectBucketHandler
Handles incoming Select bucket responses.
channelWritabilityChanged(ChannelHandlerContext) - Method in class com.couchbase.client.core.endpoint.AbstractGenericHandler
 
CHARSET - Static variable in class com.couchbase.client.core.endpoint.AbstractGenericHandler
The default charset to use for all requests and responses.
checkFeaturesForRequest(CouchbaseRequest, BucketConfig) - Method in class com.couchbase.client.core.RequestHandler
Checks, for a sub-set of CouchbaseRequest, if the current environment has the necessary feature activated.
checkNode(Node) - Method in class com.couchbase.client.core.node.locate.AnalyticsLocator
 
checkNode(Node) - Method in class com.couchbase.client.core.node.locate.QueryLocator
 
checkNode(Node) - Method in class com.couchbase.client.core.node.locate.SearchLocator
 
checkNode(Node, CouchbaseBucketConfig) - Method in class com.couchbase.client.core.node.locate.ViewLocator
 
childOf(ThresholdLogSpanContext) - Static method in class com.couchbase.client.core.tracing.ThresholdLogReference
Creates a reference which represents the child of the given context.
cleanUpAndThrow(RuntimeException) - Method in class com.couchbase.client.core.message.kv.subdoc.simple.AbstractSubdocRequest
Utility method to ensure good cleanup when throwing an exception from a constructor.
clientRequestId() - Method in class com.couchbase.client.core.message.analytics.GenericAnalyticsResponse
 
clientRequestId() - Method in class com.couchbase.client.core.message.query.GenericQueryResponse
 
close(ChannelHandlerContext, ChannelPromise) - Method in class com.couchbase.client.core.endpoint.kv.KeyValueAuthHandler
 
close(ChannelHandlerContext, ChannelPromise) - Method in class com.couchbase.client.core.endpoint.kv.KeyValueErrorMapHandler
 
close(ChannelHandlerContext, ChannelPromise) - Method in class com.couchbase.client.core.endpoint.kv.KeyValueFeatureHandler
 
close(ChannelHandlerContext, ChannelPromise) - Method in class com.couchbase.client.core.endpoint.kv.KeyValueSelectBucketHandler
 
close() - Method in class com.couchbase.client.core.tracing.ThresholdLogScope
 
closeBucket(String) - Method in interface com.couchbase.client.core.config.ConfigurationProvider
 
closeBucket(String) - Method in class com.couchbase.client.core.config.DefaultConfigurationProvider
 
CloseBucketRequest - Class in com.couchbase.client.core.message.cluster
 
CloseBucketRequest(String) - Constructor for class com.couchbase.client.core.message.cluster.CloseBucketRequest
 
CloseBucketResponse - Class in com.couchbase.client.core.message.cluster
 
CloseBucketResponse(ResponseStatus) - Constructor for class com.couchbase.client.core.message.cluster.CloseBucketResponse
 
closeBuckets() - Method in interface com.couchbase.client.core.config.ConfigurationProvider
 
closeBuckets() - Method in class com.couchbase.client.core.config.DefaultConfigurationProvider
 
ClosingPositionBufProcessor - Class in com.couchbase.client.core.endpoint.util
A ByteBufProcessor to find a closing character position.
ClosingPositionBufProcessor(char, char) - Constructor for class com.couchbase.client.core.endpoint.util.ClosingPositionBufProcessor
 
ClosingPositionBufProcessor(char, char, boolean) - Constructor for class com.couchbase.client.core.endpoint.util.ClosingPositionBufProcessor
 
cluster() - Method in class com.couchbase.client.core.config.loader.AbstractLoader
Returns the ClusterFacade for child implementations.
cluster() - Method in class com.couchbase.client.core.config.refresher.AbstractRefresher
Returns the cluster reference.
ClusterConfig - Interface in com.couchbase.client.core.config
Represents a Couchbase Cluster Configuration.
ClusterConfigRequest - Class in com.couchbase.client.core.message.config
 
ClusterConfigRequest(String, String) - Constructor for class com.couchbase.client.core.message.config.ClusterConfigRequest
 
ClusterConfigRequest(String, String, String) - Constructor for class com.couchbase.client.core.message.config.ClusterConfigRequest
 
ClusterConfigResponse - Class in com.couchbase.client.core.message.config
 
ClusterConfigResponse(String, ResponseStatus) - Constructor for class com.couchbase.client.core.message.config.ClusterConfigResponse
 
ClusterFacade - Interface in com.couchbase.client.core
Represents a Couchbase Cluster.
clusterNodes() - Method in class com.couchbase.client.core.event.system.ConfigUpdatedEvent
Deprecated.
clusterNodesAsNetworkAddress() - Method in class com.couchbase.client.core.event.system.ConfigUpdatedEvent
Returns the NetworkAddress of all nodes that are part of the cluster config.
ClusterRequest - Interface in com.couchbase.client.core.message.cluster
 
code() - Method in enum com.couchbase.client.core.endpoint.kv.KeyValueStatus
 
collect() - Static method in class com.couchbase.client.core.env.Diagnostics
Collects all available infos in one map.
collectAndFormat() - Static method in class com.couchbase.client.core.env.Diagnostics
Collects all available infos and formats it in a better readable way.
com.couchbase.client.core - package com.couchbase.client.core
Couchbase Core IO - Domain Model and Architecture
com.couchbase.client.core.annotations - package com.couchbase.client.core.annotations
 
com.couchbase.client.core.config - package com.couchbase.client.core.config
 
com.couchbase.client.core.config.loader - package com.couchbase.client.core.config.loader
 
com.couchbase.client.core.config.parser - package com.couchbase.client.core.config.parser
 
com.couchbase.client.core.config.refresher - package com.couchbase.client.core.config.refresher
 
com.couchbase.client.core.endpoint - package com.couchbase.client.core.endpoint
 
com.couchbase.client.core.endpoint.analytics - package com.couchbase.client.core.endpoint.analytics
 
com.couchbase.client.core.endpoint.config - package com.couchbase.client.core.endpoint.config
 
com.couchbase.client.core.endpoint.kv - package com.couchbase.client.core.endpoint.kv
 
com.couchbase.client.core.endpoint.query - package com.couchbase.client.core.endpoint.query
 
com.couchbase.client.core.endpoint.query.parser - package com.couchbase.client.core.endpoint.query.parser
 
com.couchbase.client.core.endpoint.search - package com.couchbase.client.core.endpoint.search
 
com.couchbase.client.core.endpoint.util - package com.couchbase.client.core.endpoint.util
 
com.couchbase.client.core.endpoint.view - package com.couchbase.client.core.endpoint.view
 
com.couchbase.client.core.env - package com.couchbase.client.core.env
 
com.couchbase.client.core.env.resources - package com.couchbase.client.core.env.resources
 
com.couchbase.client.core.event - package com.couchbase.client.core.event
 
com.couchbase.client.core.event.consumers - package com.couchbase.client.core.event.consumers
 
com.couchbase.client.core.event.metrics - package com.couchbase.client.core.event.metrics
 
com.couchbase.client.core.event.system - package com.couchbase.client.core.event.system
 
com.couchbase.client.core.hooks - package com.couchbase.client.core.hooks
 
com.couchbase.client.core.lang - package com.couchbase.client.core.lang
 
com.couchbase.client.core.lang.backport.java.util - package com.couchbase.client.core.lang.backport.java.util
 
com.couchbase.client.core.logging - package com.couchbase.client.core.logging
 
com.couchbase.client.core.message - package com.couchbase.client.core.message
 
com.couchbase.client.core.message.analytics - package com.couchbase.client.core.message.analytics
 
com.couchbase.client.core.message.cluster - package com.couchbase.client.core.message.cluster
 
com.couchbase.client.core.message.config - package com.couchbase.client.core.message.config
 
com.couchbase.client.core.message.internal - package com.couchbase.client.core.message.internal
 
com.couchbase.client.core.message.kv - package com.couchbase.client.core.message.kv
 
com.couchbase.client.core.message.kv.subdoc - package com.couchbase.client.core.message.kv.subdoc
 
com.couchbase.client.core.message.kv.subdoc.multi - package com.couchbase.client.core.message.kv.subdoc.multi
 
com.couchbase.client.core.message.kv.subdoc.simple - package com.couchbase.client.core.message.kv.subdoc.simple
 
com.couchbase.client.core.message.observe - package com.couchbase.client.core.message.observe
 
com.couchbase.client.core.message.query - package com.couchbase.client.core.message.query
 
com.couchbase.client.core.message.search - package com.couchbase.client.core.message.search
 
com.couchbase.client.core.message.stat - package com.couchbase.client.core.message.stat
 
com.couchbase.client.core.message.view - package com.couchbase.client.core.message.view
 
com.couchbase.client.core.metrics - package com.couchbase.client.core.metrics
 
com.couchbase.client.core.node - package com.couchbase.client.core.node
 
com.couchbase.client.core.node.locate - package com.couchbase.client.core.node.locate
 
com.couchbase.client.core.retry - package com.couchbase.client.core.retry
 
com.couchbase.client.core.security.sasl - package com.couchbase.client.core.security.sasl
 
com.couchbase.client.core.service - package com.couchbase.client.core.service
 
com.couchbase.client.core.service.strategies - package com.couchbase.client.core.service.strategies
 
com.couchbase.client.core.state - package com.couchbase.client.core.state
 
com.couchbase.client.core.time - package com.couchbase.client.core.time
 
com.couchbase.client.core.tracing - package com.couchbase.client.core.tracing
 
com.couchbase.client.core.utils - package com.couchbase.client.core.utils
 
com.couchbase.client.core.utils.yasjl - package com.couchbase.client.core.utils.yasjl
 
com.couchbase.client.core.utils.yasjl.Callbacks - package com.couchbase.client.core.utils.yasjl.Callbacks
 
com.couchbase.client.deps.io.netty.handler.codec.memcache - package com.couchbase.client.deps.io.netty.handler.codec.memcache
Common superset of ascii and binary classes.
com.couchbase.client.deps.io.netty.handler.codec.memcache.binary - package com.couchbase.client.deps.io.netty.handler.codec.memcache.binary
Implementations and Interfaces for the Memcache Binary protocol.
commands() - Method in interface com.couchbase.client.core.message.kv.subdoc.BinarySubdocMultiLookupRequest
 
commands() - Method in interface com.couchbase.client.core.message.kv.subdoc.BinarySubdocMultiMutationRequest
 
commands() - Method in class com.couchbase.client.core.message.kv.subdoc.multi.SubMultiLookupRequest
 
commands() - Method in class com.couchbase.client.core.message.kv.subdoc.multi.SubMultiMutationRequest
 
CommonsLoggerFactory - Class in com.couchbase.client.core.logging
Logger factory which creates an Apache Commons Logging logger.
CommonsLoggerFactory() - Constructor for class com.couchbase.client.core.logging.CommonsLoggerFactory
 
compareTo(ErrorMap) - Method in class com.couchbase.client.core.endpoint.kv.ErrorMap
 
compareTo(LatencyMetricsIdentifier) - Method in class com.couchbase.client.core.metrics.NetworkLatencyMetricsIdentifier
 
compareTo(ThresholdLogSpan) - Method in class com.couchbase.client.core.tracing.ThresholdLogSpan
 
complete() - Method in class com.couchbase.client.core.message.AbstractCouchbaseRequest
 
complete() - Method in interface com.couchbase.client.core.message.CouchbaseRequest
Completes the underlying state holder.
completeRequestSpan(CouchbaseRequest) - Method in class com.couchbase.client.core.endpoint.AbstractGenericHandler
Helper method to complete the request span, called from child instances.
compressionMinRatio() - Method in interface com.couchbase.client.core.env.CoreEnvironment
If the document is greater than the min compression size it is used for compression, but only sent if the compressed document has a greater compression ratio as the one provided.
compressionMinRatio(double) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Allows to adjust the ratio over which the document is sent compressed over the wire - in percent.
compressionMinRatio() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
compressionMinSize() - Method in interface com.couchbase.client.core.env.CoreEnvironment
Returns the minimum size of a document to be considered for compression in the first place.
compressionMinSize(int) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Allows to adjust the minimum size of a document to be considered for compression - in bytes.
compressionMinSize() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
COMPUTATION_POOL_SIZE - Static variable in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
computationPoolSize() - Method in interface com.couchbase.client.core.env.CoreEnvironment
Returns the pool size (number of threads) for all computation tasks.
computationPoolSize(int) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Sets the pool size (number of threads to use) for all non blocking operations in the core and clients (default value is the number of CPUs).
computationPoolSize() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
config() - Method in interface com.couchbase.client.core.config.ConfigurationProvider
Returns the current config or null if not set.
config() - Method in class com.couchbase.client.core.config.DefaultConfigurationProvider
 
config() - Method in class com.couchbase.client.core.config.ProposedBucketConfigContext
 
config() - Method in class com.couchbase.client.core.endpoint.util.FailedChannel
 
config() - Method in class com.couchbase.client.core.message.cluster.GetClusterConfigResponse
 
config() - Method in class com.couchbase.client.core.message.config.BucketConfigResponse
 
config() - Method in class com.couchbase.client.core.message.config.BucketsConfigResponse
 
config() - Method in class com.couchbase.client.core.message.config.ClusterConfigResponse
 
config() - Method in class com.couchbase.client.core.message.config.InsertBucketResponse
 
config() - Method in class com.couchbase.client.core.message.config.UpdateBucketResponse
 
config() - Method in class com.couchbase.client.core.metrics.AbstractLatencyMetricsCollector
 
config() - Method in class com.couchbase.client.core.metrics.AbstractMetricsCollector
 
config() - Method in interface com.couchbase.client.core.metrics.LatencyMetricsCollector
 
config() - Method in interface com.couchbase.client.core.metrics.MetricsCollector
Its high-level configuration.
CONFIG_POLL_FLOOR_INTERVAL - Static variable in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
CONFIG_POLL_INTERVAL - Static variable in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
ConfigEndpoint - Class in com.couchbase.client.core.endpoint.config
 
ConfigEndpoint(String, String, String, int, CoreContext) - Constructor for class com.couchbase.client.core.endpoint.config.ConfigEndpoint
Deprecated.
ConfigEndpoint(String, String, String, String, int, CoreContext) - Constructor for class com.couchbase.client.core.endpoint.config.ConfigEndpoint
 
ConfigHandler - Class in com.couchbase.client.core.endpoint.config
The ConfigHandler is responsible for encoding ConfigRequests into lower level HttpRequests as well as decoding HttpObjects into CouchbaseResponses.
ConfigHandler(AbstractEndpoint, EventSink<ResponseEvent>, boolean, boolean) - Constructor for class com.couchbase.client.core.endpoint.config.ConfigHandler
Creates a new ConfigHandler with the default queue for requests.
ConfigLocator - Class in com.couchbase.client.core.node.locate
Locates the proper CONFIG node for a given config request.
ConfigLocator() - Constructor for class com.couchbase.client.core.node.locate.ConfigLocator
Generates the random initial value for the round robin counter used.
ConfigParserEnvironment - Interface in com.couchbase.client.core.env
A ConfigParserEnvironment interface defines all methods which environment implementation should have to be injected into configuration parser.
configPollFloorInterval() - Method in interface com.couchbase.client.core.env.CoreEnvironment
Returns the minimum polling interval allowed.
configPollFloorInterval(long) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Allows to set the minimum config polling interval.
configPollFloorInterval() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
configPollInterval() - Method in interface com.couchbase.client.core.env.CoreEnvironment
Returns the proactive polling interval for cluster configurations.
configPollInterval(long) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Allows to set the configuration poll interval which polls the server cluster configuration proactively.
configPollInterval() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
ConfigRequest - Interface in com.couchbase.client.core.message.config
Common marker interface for all ConfigRequests.
configRev() - Method in class com.couchbase.client.core.message.internal.PingReport
 
configs() - Method in interface com.couchbase.client.core.config.ConfigurationProvider
Returns an Observable, which pushes a new ClusterConfig once available.
configs() - Method in class com.couchbase.client.core.config.DefaultConfigurationProvider
 
configs() - Method in class com.couchbase.client.core.config.refresher.AbstractRefresher
 
configs() - Method in interface com.couchbase.client.core.config.refresher.Refresher
Returns the Observable which will push out new configuration updates.
configs() - Method in class com.couchbase.client.core.message.config.BucketStreamingResponse
 
ConfigService - Class in com.couchbase.client.core.service
 
ConfigService(String, String, String, int, CoreContext) - Constructor for class com.couchbase.client.core.service.ConfigService
Deprecated.
ConfigService(String, String, String, String, int, CoreContext) - Constructor for class com.couchbase.client.core.service.ConfigService
 
ConfigUpdatedEvent - Class in com.couchbase.client.core.event.system
Event published when a new bucket config is applied to the core.
ConfigUpdatedEvent(ClusterConfig) - Constructor for class com.couchbase.client.core.event.system.ConfigUpdatedEvent
 
ConfigurationException - Exception in com.couchbase.client.core.config
 
ConfigurationException() - Constructor for exception com.couchbase.client.core.config.ConfigurationException
 
ConfigurationException(String) - Constructor for exception com.couchbase.client.core.config.ConfigurationException
 
ConfigurationException(String, Throwable) - Constructor for exception com.couchbase.client.core.config.ConfigurationException
 
ConfigurationException(Throwable) - Constructor for exception com.couchbase.client.core.config.ConfigurationException
 
ConfigurationProvider - Interface in com.couchbase.client.core.config
 
connect() - Method in class com.couchbase.client.core.endpoint.AbstractEndpoint
 
connect(boolean) - Method in class com.couchbase.client.core.endpoint.AbstractEndpoint
An internal alternative to AbstractEndpoint.connect() where signalling that this is post-bootstrapping can be done.
connect(ChannelHandlerContext, SocketAddress, SocketAddress, ChannelPromise) - Method in class com.couchbase.client.core.endpoint.AbstractGenericHandler
 
connect() - Method in class com.couchbase.client.core.endpoint.BootstrapAdapter
Connect the underlying Bootstrap and return a ChannelFuture.
connect() - Method in interface com.couchbase.client.core.endpoint.Endpoint
Connect the Endpoint to the underlying channel.
connect(ChannelHandlerContext, SocketAddress, SocketAddress, ChannelPromise) - Method in class com.couchbase.client.core.endpoint.kv.KeyValueAuthHandler
 
connect(ChannelHandlerContext, SocketAddress, SocketAddress, ChannelPromise) - Method in class com.couchbase.client.core.endpoint.kv.KeyValueErrorMapHandler
 
connect(ChannelHandlerContext, SocketAddress, SocketAddress, ChannelPromise) - Method in class com.couchbase.client.core.endpoint.kv.KeyValueFeatureHandler
 
connect(ChannelHandlerContext, SocketAddress, SocketAddress, ChannelPromise) - Method in class com.couchbase.client.core.endpoint.kv.KeyValueSelectBucketHandler
 
connect() - Method in class com.couchbase.client.core.node.CouchbaseNode
 
connect() - Method in interface com.couchbase.client.core.node.Node
Connects all currently enabled Services.
connect() - Method in class com.couchbase.client.core.service.AbstractDynamicService
 
connect() - Method in class com.couchbase.client.core.service.PooledService
 
connect() - Method in interface com.couchbase.client.core.service.Service
Connects all currently enabled Service Endpoints.
ConnectionString - Class in com.couchbase.client.core.utils
Implements a ConnectionString.
ConnectionString(String) - Constructor for class com.couchbase.client.core.utils.ConnectionString
 
ConnectionString.Scheme - Enum in com.couchbase.client.core.utils
 
content() - Method in class com.couchbase.client.core.message.config.FlushResponse
 
content() - Method in class com.couchbase.client.core.message.config.GetDesignDocumentsResponse
 
content() - Method in class com.couchbase.client.core.message.config.GetUsersResponse
 
content() - Method in class com.couchbase.client.core.message.kv.AbstractKeyValueResponse
 
content() - Method in class com.couchbase.client.core.message.kv.AppendRequest
 
content() - Method in interface com.couchbase.client.core.message.kv.BinaryResponse
Contains the content of the response, potentially null or empty.
content() - Method in interface com.couchbase.client.core.message.kv.BinaryStoreRequest
 
content() - Method in class com.couchbase.client.core.message.kv.InsertRequest
The content of the document.
content() - Method in class com.couchbase.client.core.message.kv.PrependRequest
 
content() - Method in class com.couchbase.client.core.message.kv.ReplaceRequest
The content of the document.
content() - Method in interface com.couchbase.client.core.message.kv.subdoc.BinarySubdocMultiLookupRequest
The ByteBuf representing the whole list of BinarySubdocMultiLookupRequest.commands().
content() - Method in interface com.couchbase.client.core.message.kv.subdoc.BinarySubdocMultiMutationRequest
The ByteBuf representing the whole list of BinarySubdocMultiMutationRequest.commands().
content() - Method in interface com.couchbase.client.core.message.kv.subdoc.BinarySubdocRequest
The ByteBuf bearing the full content for this request.
content() - Method in class com.couchbase.client.core.message.kv.subdoc.multi.SubMultiLookupRequest
 
content() - Method in class com.couchbase.client.core.message.kv.subdoc.multi.SubMultiMutationRequest
 
content() - Method in class com.couchbase.client.core.message.kv.subdoc.simple.AbstractSubdocRequest
 
content() - Method in class com.couchbase.client.core.message.kv.UpsertRequest
The content of the document.
content() - Method in class com.couchbase.client.core.message.view.GetDesignDocumentResponse
 
content() - Method in class com.couchbase.client.core.message.view.RemoveDesignDocumentResponse
 
content() - Method in class com.couchbase.client.core.message.view.UpsertDesignDocumentResponse
 
content() - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.DefaultFullBinaryMemcacheRequest
 
content() - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.DefaultFullBinaryMemcacheResponse
 
content() - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.DefaultMemcacheContent
 
context() - Method in class com.couchbase.client.core.endpoint.AbstractEndpoint
The CoreContext reference.
context() - Method in class com.couchbase.client.core.message.ResponseStatusDetails
 
context() - Method in class com.couchbase.client.core.tracing.ThresholdLogSpan
 
CONTINUOUS_KEEPALIVE_ENABLED - Static variable in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
continuousKeepAliveEnabled() - Method in interface com.couchbase.client.core.env.CoreEnvironment
If set to true, KeepAlives will be sent on a regular basis in the interval also if there is traffic on the socket, not only if its idle.
continuousKeepAliveEnabled(boolean) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Allows to enable or disable the continous emitting of keepalive messages.
continuousKeepAliveEnabled() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
convert(ByteBuf) - Static method in class com.couchbase.client.core.message.ResponseStatusDetails
Helper method to convert a ByteBuf input into the details.
copy() - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.DefaultFullBinaryMemcacheRequest
 
copy() - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.DefaultFullBinaryMemcacheResponse
 
copy() - Method in interface com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.FullBinaryMemcacheRequest
 
copy() - Method in interface com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.FullBinaryMemcacheResponse
 
copy() - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.DefaultLastMemcacheContent
 
copy() - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.DefaultMemcacheContent
 
copy() - Method in interface com.couchbase.client.deps.io.netty.handler.codec.memcache.FullMemcacheMessage
 
copy() - Method in interface com.couchbase.client.deps.io.netty.handler.codec.memcache.LastMemcacheContent
 
copy() - Method in interface com.couchbase.client.deps.io.netty.handler.codec.memcache.MemcacheContent
 
CORE_GIT_VERSION - Static variable in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
CORE_VERSION - Static variable in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
coreBuild() - Method in interface com.couchbase.client.core.env.CoreEnvironment
Returns build information on the Couchbase Java SDK core.
coreBuild() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
CoreContext - Class in com.couchbase.client.core
The CoreContext contains required assets which are shared on a per-core basis.
CoreContext(CoreEnvironment, RingBuffer<ResponseEvent>) - Constructor for class com.couchbase.client.core.CoreContext
Creates a new CoreContext with no core id.
CoreContext(CoreEnvironment, RingBuffer<ResponseEvent>, long) - Constructor for class com.couchbase.client.core.CoreContext
Creates a new CoreContext with no a core id.
CoreEnvironment - Interface in com.couchbase.client.core.env
A CoreEnvironment provides all the core building blocks like environment settings and thread pools so that the application can work with it properly.
coreId() - Method in class com.couchbase.client.core.CoreContext
The core it, 0 if not set.
CoreScheduler - Class in com.couchbase.client.core.env
The Core scheduler which is modeled after the Event Loops Scheduler (which is package private).
CoreScheduler(int) - Constructor for class com.couchbase.client.core.env.CoreScheduler
Create a scheduler with specified pool size and using least-recent worker selection policy.
coreVersion() - Method in interface com.couchbase.client.core.env.CoreEnvironment
Returns version information on the core.
coreVersion() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
CouchbaseBucketConfig - Interface in com.couchbase.client.core.config
A configuration representing the couchbase bucket.
CouchbaseCore - Class in com.couchbase.client.core
The general implementation of a ClusterFacade.
CouchbaseCore() - Constructor for class com.couchbase.client.core.CouchbaseCore
Creates a new CouchbaseCore.
CouchbaseCore(CoreEnvironment) - Constructor for class com.couchbase.client.core.CouchbaseCore
Creates a new CouchbaseCore.
couchbaseCoreSendHook() - Method in interface com.couchbase.client.core.env.CoreEnvironment
Returns the CouchbaseCoreSendHook if set, null otherwise.
couchbaseCoreSendHook(CouchbaseCoreSendHook) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Allows to configure a custom core send hook, see the javadocs for it for more details.
couchbaseCoreSendHook() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
CouchbaseCoreSendHook - Interface in com.couchbase.client.core.hooks
This hook allows to intercept and modify the CouchbaseRequest in the path of the CouchbaseCore.send(CouchbaseRequest) method.
CouchbaseEvent - Interface in com.couchbase.client.core.event
Defines the generic couchbase event pushed through the event bus.
CouchbaseException - Exception in com.couchbase.client.core
Common parent exception to build a proper exception hierachy inside the driver.
CouchbaseException() - Constructor for exception com.couchbase.client.core.CouchbaseException
 
CouchbaseException(String) - Constructor for exception com.couchbase.client.core.CouchbaseException
 
CouchbaseException(String, Throwable) - Constructor for exception com.couchbase.client.core.CouchbaseException
 
CouchbaseException(Throwable) - Constructor for exception com.couchbase.client.core.CouchbaseException
 
CouchbaseLogger - Interface in com.couchbase.client.core.logging
Internal-use-only logger used by the SDK.
CouchbaseLoggerFactory - Class in com.couchbase.client.core.logging
Creates an CouchbaseLogger or changes the default factory implementation.
CouchbaseLoggerFactory() - Constructor for class com.couchbase.client.core.logging.CouchbaseLoggerFactory
 
CouchbaseLogLevel - Enum in com.couchbase.client.core.logging
The log level that CouchbaseLogger can log at.
CouchbaseMessage - Interface in com.couchbase.client.core.message
 
CouchbaseNode - Class in com.couchbase.client.core.node
The general implementation of a Node.
CouchbaseNode(NetworkAddress, CoreContext) - Constructor for class com.couchbase.client.core.node.CouchbaseNode
 
CouchbasePartitionInfo - Class in com.couchbase.client.core.config
Represents the partition information for a bucket.
CouchbaseRequest - Interface in com.couchbase.client.core.message
High-Level marker interface for all CouchbaseRequests.
CouchbaseResponse - Interface in com.couchbase.client.core.message
 
count() - Method in class com.couchbase.client.core.event.metrics.LatencyMetric
The number of latency entries recorded in the interval.
CounterRequest - Class in com.couchbase.client.core.message.kv
Request to handle increment/decrement of a counter.
CounterRequest(String, long, long, int, String) - Constructor for class com.couchbase.client.core.message.kv.CounterRequest
 
CounterResponse - Class in com.couchbase.client.core.message.kv
 
CounterResponse(ResponseStatus, short, String, long, long, MutationToken, CouchbaseRequest) - Constructor for class com.couchbase.client.core.message.kv.CounterResponse
 
countNonService() - Method in class com.couchbase.client.core.tracing.RingBufferDiagnostics
Returns the count of all requests not associated with a particular service
counts() - Method in class com.couchbase.client.core.tracing.RingBufferDiagnostics
Returns a map of the type of each request, along with the current count of each in the ringbuffer
create(int, int) - Static method in class com.couchbase.client.core.env.AnalyticsServiceConfig
 
create(int, int, int) - Static method in class com.couchbase.client.core.env.AnalyticsServiceConfig
 
create() - Static method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
create(int) - Static method in class com.couchbase.client.core.env.KeyValueServiceConfig
 
create(int, int) - Static method in class com.couchbase.client.core.env.QueryServiceConfig
 
create(int, int, int) - Static method in class com.couchbase.client.core.env.QueryServiceConfig
 
create(int, int) - Static method in class com.couchbase.client.core.env.SearchServiceConfig
 
create(int, int, int) - Static method in class com.couchbase.client.core.env.SearchServiceConfig
 
create(int, int) - Static method in class com.couchbase.client.core.env.ViewServiceConfig
 
create(int, int, int) - Static method in class com.couchbase.client.core.env.ViewServiceConfig
 
create() - Static method in class com.couchbase.client.core.event.consumers.LoggingConsumer
 
create(CouchbaseLogLevel, LoggingConsumer.OutputFormat) - Static method in class com.couchbase.client.core.event.consumers.LoggingConsumer
 
create(T1, T2) - Static method in class com.couchbase.client.core.lang.Tuple
Creates a tuple with two values.
create(T1, T2, T3) - Static method in class com.couchbase.client.core.lang.Tuple
Creates a tuple with three values.
create(T1, T2, T3, T4) - Static method in class com.couchbase.client.core.lang.Tuple
Creates a tuple with four values.
create(T1, T2, T3, T4, T5) - Static method in class com.couchbase.client.core.lang.Tuple
Creates a tuple with five values.
create(short, ResponseStatus, String, Lookup, ByteBuf) - Static method in class com.couchbase.client.core.message.kv.subdoc.multi.MultiResult
 
create(short, ResponseStatus, String, Mutation, ByteBuf) - Static method in class com.couchbase.client.core.message.kv.subdoc.multi.MultiResult
 
create() - Static method in class com.couchbase.client.core.metrics.DefaultLatencyMetricsCollectorConfig
 
create(long, TimeUnit) - Static method in class com.couchbase.client.core.metrics.DefaultLatencyMetricsCollectorConfig
 
create() - Static method in class com.couchbase.client.core.metrics.DefaultMetricsCollectorConfig
 
create(long, TimeUnit) - Static method in class com.couchbase.client.core.metrics.DefaultMetricsCollectorConfig
 
create(String, String, String, String, int, CoreContext) - Method in interface com.couchbase.client.core.service.Service.EndpointFactory
Create a new Endpoint.
create(String, String, String, String, int, CoreContext, ServiceType) - Method in class com.couchbase.client.core.service.ServiceFactory
 
create() - Static method in class com.couchbase.client.core.tracing.DefaultOrphanResponseReporter
 
create() - Static method in class com.couchbase.client.core.tracing.ThresholdLogReporter
 
create() - Static method in class com.couchbase.client.core.tracing.ThresholdLogTracer
Creates a new tracer with default settings.
create(ThresholdLogReporter) - Static method in class com.couchbase.client.core.tracing.ThresholdLogTracer
Creates a new tracer with a custom reporter.
create(String) - Static method in class com.couchbase.client.core.utils.ConnectionString
 
create(String) - Static method in class com.couchbase.client.core.utils.NetworkAddress
Creates a new NetworkAddress from either a hostname or ip address literal.
create(long, TimeUnit) - Static method in class com.couchbase.client.core.utils.UnicastAutoReleaseSubject
 
create(long, TimeUnit, Action0) - Static method in class com.couchbase.client.core.utils.UnicastAutoReleaseSubject
 
create(long, TimeUnit, Scheduler) - Static method in class com.couchbase.client.core.utils.UnicastAutoReleaseSubject
 
create(long, TimeUnit, Scheduler, Action0) - Static method in class com.couchbase.client.core.utils.UnicastAutoReleaseSubject
 
createContent(ByteBuf, ByteBuf...) - Method in class com.couchbase.client.core.message.kv.subdoc.simple.AbstractSubdocRequest
 
createDocument() - Method in interface com.couchbase.client.core.message.kv.subdoc.BinarySubdocMutationRequest
Deprecated.
createDocument(boolean) - Method in class com.couchbase.client.core.message.kv.subdoc.multi.SubMultiMutationDocOptionsBuilder
Deprecated.
createDocument() - Method in class com.couchbase.client.core.message.kv.subdoc.multi.SubMultiMutationDocOptionsBuilder
Deprecated.
createDocument() - Method in class com.couchbase.client.core.message.kv.subdoc.simple.AbstractSubdocMutationRequest
 
createDocument(boolean) - Method in class com.couchbase.client.core.message.kv.subdoc.simple.AbstractSubdocMutationRequest
 
createEndpoint() - Method in class com.couchbase.client.core.service.AbstractDynamicService
Helper method to create a new endpoint.
createException() - Method in class com.couchbase.client.core.tracing.RingBufferMonitor
 
createIntermediaryPath() - Method in interface com.couchbase.client.core.message.kv.subdoc.BinarySubdocMutationRequest
Sets whether missing nodes in the BinarySubdocRequest.path() should be created as part of this mutation, when possible.
createIntermediaryPath() - Method in class com.couchbase.client.core.message.kv.subdoc.multi.MutationCommand
 
createIntermediaryPath() - Method in class com.couchbase.client.core.message.kv.subdoc.multi.MutationCommandBuilder
 
createIntermediaryPath(boolean) - Method in class com.couchbase.client.core.message.kv.subdoc.multi.MutationCommandBuilder
 
createIntermediaryPath() - Method in class com.couchbase.client.core.message.kv.subdoc.simple.AbstractSubdocMutationRequest
 
createIntermediaryPath(boolean) - Method in class com.couchbase.client.core.message.kv.subdoc.simple.AbstractSubdocMutationRequest
Modifies the request so that it requires the creation of missing intermediary nodes in the path if set to true.
createKeepAliveRequest() - Method in class com.couchbase.client.core.endpoint.AbstractGenericHandler
Override to return a non-null request to be fired in the pipeline in case a keep alive is triggered.
createKeepAliveRequest() - Method in class com.couchbase.client.core.endpoint.analytics.AnalyticsHandler
 
createKeepAliveRequest() - Method in class com.couchbase.client.core.endpoint.kv.KeyValueHandler
 
createKeepAliveRequest() - Method in class com.couchbase.client.core.endpoint.query.QueryHandler
 
createKeepAliveRequest() - Method in class com.couchbase.client.core.endpoint.query.QueryHandlerV2
 
createKeepAliveRequest() - Method in class com.couchbase.client.core.endpoint.search.SearchHandler
 
createKeepAliveRequest() - Method in class com.couchbase.client.core.endpoint.view.ViewHandler
 
createSaslClient(String[], String, String, String, Map<String, ?>, CallbackHandler) - Static method in class com.couchbase.client.core.security.sasl.Sasl
Creates a new SaslClient and first tries the JVM built in clients before falling back to our custom implementations.
createSaslClient(String[], String, String, String, Map<String, ?>, CallbackHandler) - Method in class com.couchbase.client.core.security.sasl.ShaSaslClientFactory
 
createWithoutNoSubscriptionTimeout(Action0) - Static method in class com.couchbase.client.core.utils.UnicastAutoReleaseSubject
Creates a new UnicastAutoReleaseSubject without a no subscription timeout.
createWithoutNoSubscriptionTimeout() - Static method in class com.couchbase.client.core.utils.UnicastAutoReleaseSubject
Creates a new UnicastAutoReleaseSubject without a no subscription timeout.
createWorker() - Method in class com.couchbase.client.core.env.CoreScheduler
 
creationTime() - Method in class com.couchbase.client.core.message.AbstractCouchbaseRequest
 
creationTime() - Method in class com.couchbase.client.core.message.AbstractCouchbaseResponse
 
creationTime() - Method in interface com.couchbase.client.core.message.CouchbaseMessage
Returns the time in nanoseconds when the message was created.
ctx() - Method in interface com.couchbase.client.core.ClusterFacade
Exposes the currently used environment.
ctx() - Method in class com.couchbase.client.core.CouchbaseCore
 
ctx - Variable in class com.couchbase.client.deps.io.netty.handler.codec.memcache.AbstractMemcacheObjectAggregator
Holds the current channel handler context if set.
currentDispatchSpan() - Method in class com.couchbase.client.core.endpoint.AbstractGenericHandler
 
currentMessage - Variable in class com.couchbase.client.deps.io.netty.handler.codec.memcache.AbstractMemcacheObjectAggregator
Contains the current message that gets aggregated.
currentRequest() - Method in class com.couchbase.client.core.endpoint.AbstractGenericHandler
Returns the current request if set.
currentSeqNo() - Method in class com.couchbase.client.core.message.kv.FailoverObserveSeqnoResponse
 
currentSeqNo() - Method in class com.couchbase.client.core.message.kv.NoFailoverObserveSeqnoResponse
 
currentStates() - Method in class com.couchbase.client.core.state.AbstractStateZipper
Helper method to export the current internal states.
currentSubscriptions() - Method in class com.couchbase.client.core.state.AbstractStateZipper
Helper method to export the current internal subscriptions.
custom(String) - Static method in class com.couchbase.client.core.env.NetworkResolution
Provide a network resolution option which is not covered by the statics defined in this class.
customEndpointHandlers(ChannelPipeline) - Method in class com.couchbase.client.core.endpoint.AbstractEndpoint
Add custom endpoint handlers to the ChannelPipeline.
customEndpointHandlers(ChannelPipeline) - Method in class com.couchbase.client.core.endpoint.analytics.AnalyticsEndpoint
 
customEndpointHandlers(ChannelPipeline) - Method in class com.couchbase.client.core.endpoint.config.ConfigEndpoint
 
customEndpointHandlers(ChannelPipeline) - Method in class com.couchbase.client.core.endpoint.kv.KeyValueEndpoint
 
customEndpointHandlers(ChannelPipeline) - Method in class com.couchbase.client.core.endpoint.query.QueryEndpoint
 
customEndpointHandlers(ChannelPipeline) - Method in class com.couchbase.client.core.endpoint.search.SearchEndpoint
 
customEndpointHandlers(ChannelPipeline) - Method in class com.couchbase.client.core.endpoint.view.ViewEndpoint
 

D

DATATYPE_SNAPPY - Static variable in class com.couchbase.client.core.endpoint.kv.KeyValueHandler
The datatype byte used to signal snappy.
debug(Throwable) - Method in class com.couchbase.client.core.logging.AbstractCouchbaseLogger
 
debug(String) - Method in interface com.couchbase.client.core.logging.CouchbaseLogger
Log a message at the DEBUG level.
debug(String, Object) - Method in interface com.couchbase.client.core.logging.CouchbaseLogger
Log a message at the DEBUG level according to the specified format and argument.
debug(String, Object, Object) - Method in interface com.couchbase.client.core.logging.CouchbaseLogger
Log a message at the DEBUG level according to the specified format and arguments.
debug(String, Object...) - Method in interface com.couchbase.client.core.logging.CouchbaseLogger
Log a message at the DEBUG level according to the specified format and arguments.
debug(String, Throwable) - Method in interface com.couchbase.client.core.logging.CouchbaseLogger
Log an exception (throwable) at the DEBUG level with an accompanying message.
debug(Throwable) - Method in interface com.couchbase.client.core.logging.CouchbaseLogger
Log an exception (throwable) at the DEBUG level.
decode(ChannelHandlerContext, RESPONSE, List<Object>) - Method in class com.couchbase.client.core.endpoint.AbstractGenericHandler
 
decode(String) - Static method in class com.couchbase.client.core.utils.Base64
Decode a Base64 encoded string
decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheDecoder
 
decode(ChannelHandlerContext, MemcacheObject, List<Object>) - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheObjectAggregator
 
decodeHeader(ByteBuf) - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheDecoder
Decode and return the parsed BinaryMemcacheMessage.
decodeHeader(ByteBuf) - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheRequestDecoder
 
decodeHeader(ByteBuf) - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheResponseDecoder
 
decodeResponse(ChannelHandlerContext, RESPONSE) - Method in class com.couchbase.client.core.endpoint.AbstractGenericHandler
Decodes the incoming response and transforms it into a CouchbaseResponse.
decodeResponse(ChannelHandlerContext, HttpObject) - Method in class com.couchbase.client.core.endpoint.analytics.AnalyticsHandler
 
decodeResponse(ChannelHandlerContext, HttpObject) - Method in class com.couchbase.client.core.endpoint.config.ConfigHandler
 
decodeResponse(ChannelHandlerContext, FullBinaryMemcacheResponse) - Method in class com.couchbase.client.core.endpoint.kv.KeyValueHandler
 
decodeResponse(ChannelHandlerContext, HttpObject) - Method in class com.couchbase.client.core.endpoint.query.QueryHandler
 
decodeResponse(ChannelHandlerContext, HttpObject) - Method in class com.couchbase.client.core.endpoint.query.QueryHandlerV2
 
decodeResponse(ChannelHandlerContext, HttpObject) - Method in class com.couchbase.client.core.endpoint.search.SearchHandler
 
decodeResponse(ChannelHandlerContext, HttpObject) - Method in class com.couchbase.client.core.endpoint.view.ViewHandler
 
DecodingState - Enum in com.couchbase.client.core.endpoint
Describes the states of the decoding process.
DECREMENT - Static variable in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
DECREMENTQ - Static variable in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
DEFAULT - Static variable in class com.couchbase.client.core.env.NetworkResolution
Pick whatever the server returns in the config, this is the old and backwards compatible mode (server default).
DEFAULT_FORMAT - Static variable in class com.couchbase.client.core.event.consumers.LoggingConsumer
 
DEFAULT_IDLE_TIME - Static variable in class com.couchbase.client.core.env.AbstractServiceConfig
 
DEFAULT_MAX_CHUNK_SIZE - Static variable in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheDecoder
 
DEFAULT_MAX_COMPOSITEBUFFER_COMPONENTS - Static variable in class com.couchbase.client.deps.io.netty.handler.codec.memcache.AbstractMemcacheObjectAggregator
 
DEFAULT_PARTITION - Static variable in class com.couchbase.client.core.message.kv.AbstractKeyValueRequest
 
DEFAULT_SCHEME - Static variable in class com.couchbase.client.core.utils.ConnectionString
 
DefaultAlternateAddress - Class in com.couchbase.client.core.config
 
DefaultAlternateAddress(String, Map<String, Integer>) - Constructor for class com.couchbase.client.core.config.DefaultAlternateAddress
 
DefaultBinaryMemcacheRequest - Class in com.couchbase.client.deps.io.netty.handler.codec.memcache.binary
The default implementation of the BinaryMemcacheRequest.
DefaultBinaryMemcacheRequest() - Constructor for class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.DefaultBinaryMemcacheRequest
Create a new DefaultBinaryMemcacheRequest with the header only.
DefaultBinaryMemcacheRequest(byte[]) - Constructor for class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.DefaultBinaryMemcacheRequest
Create a new DefaultBinaryMemcacheRequest with the header and key.
DefaultBinaryMemcacheRequest(ByteBuf) - Constructor for class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.DefaultBinaryMemcacheRequest
Create a new DefaultBinaryMemcacheRequest with the header and extras.
DefaultBinaryMemcacheRequest(byte[], ByteBuf) - Constructor for class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.DefaultBinaryMemcacheRequest
Create a new DefaultBinaryMemcacheRequest with the header only.
DefaultBinaryMemcacheResponse - Class in com.couchbase.client.deps.io.netty.handler.codec.memcache.binary
The default implementation of the BinaryMemcacheResponse.
DefaultBinaryMemcacheResponse() - Constructor for class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.DefaultBinaryMemcacheResponse
Create a new DefaultBinaryMemcacheResponse with the header only.
DefaultBinaryMemcacheResponse(byte[]) - Constructor for class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.DefaultBinaryMemcacheResponse
Create a new DefaultBinaryMemcacheResponse with the header and key.
DefaultBinaryMemcacheResponse(ByteBuf) - Constructor for class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.DefaultBinaryMemcacheResponse
Create a new DefaultBinaryMemcacheResponse with the header and extras.
DefaultBinaryMemcacheResponse(byte[], ByteBuf) - Constructor for class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.DefaultBinaryMemcacheResponse
Create a new DefaultBinaryMemcacheResponse with the header, key and extras.
DefaultClusterConfig - Class in com.couchbase.client.core.config
Default implementation of a ClusterConfig.
DefaultClusterConfig() - Constructor for class com.couchbase.client.core.config.DefaultClusterConfig
Creates a new DefaultClusterConfig.
DefaultConfigurationProvider - Class in com.couchbase.client.core.config
The default implementation of a ConfigurationProvider.
DefaultConfigurationProvider(ClusterFacade, CoreEnvironment) - Constructor for class com.couchbase.client.core.config.DefaultConfigurationProvider
DefaultConfigurationProvider(ClusterFacade, CoreEnvironment, List<Loader>, Map<LoaderType, Refresher>) - Constructor for class com.couchbase.client.core.config.DefaultConfigurationProvider
DefaultCoreEnvironment - Class in com.couchbase.client.core.env
 
DefaultCoreEnvironment(DefaultCoreEnvironment.Builder) - Constructor for class com.couchbase.client.core.env.DefaultCoreEnvironment
 
DefaultCoreEnvironment.Builder<SELF extends DefaultCoreEnvironment.Builder<SELF>> - Class in com.couchbase.client.core.env
 
DefaultCouchbaseBucketConfig - Class in com.couchbase.client.core.config
 
DefaultCouchbaseBucketConfig(long, String, String, String, String, CouchbasePartitionInfo, List<NodeInfo>, List<PortInfo>, List<BucketCapabilities>, NetworkAddress) - Constructor for class com.couchbase.client.core.config.DefaultCouchbaseBucketConfig
Creates a new CouchbaseBucketConfig.
DefaultEventBus - Class in com.couchbase.client.core.event
The default event bus implementation.
DefaultEventBus(Scheduler) - Constructor for class com.couchbase.client.core.event.DefaultEventBus
 
DefaultFullBinaryMemcacheRequest - Class in com.couchbase.client.deps.io.netty.handler.codec.memcache.binary
The default implementation of a FullBinaryMemcacheRequest.
DefaultFullBinaryMemcacheRequest(byte[], ByteBuf) - Constructor for class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.DefaultFullBinaryMemcacheRequest
Create a new DefaultBinaryMemcacheRequest with the header, key and extras.
DefaultFullBinaryMemcacheRequest(byte[], ByteBuf, ByteBuf) - Constructor for class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.DefaultFullBinaryMemcacheRequest
Create a new DefaultBinaryMemcacheRequest with the header, key, extras and content.
DefaultFullBinaryMemcacheResponse - Class in com.couchbase.client.deps.io.netty.handler.codec.memcache.binary
The default implementation of a FullBinaryMemcacheResponse.
DefaultFullBinaryMemcacheResponse(byte[], ByteBuf) - Constructor for class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.DefaultFullBinaryMemcacheResponse
Create a new DefaultFullBinaryMemcacheResponse with the header, key and extras.
DefaultFullBinaryMemcacheResponse(byte[], ByteBuf, ByteBuf) - Constructor for class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.DefaultFullBinaryMemcacheResponse
Create a new DefaultFullBinaryMemcacheResponse with the header, key, extras and content.
DefaultLastMemcacheContent - Class in com.couchbase.client.deps.io.netty.handler.codec.memcache
The default implementation for the LastMemcacheContent.
DefaultLastMemcacheContent() - Constructor for class com.couchbase.client.deps.io.netty.handler.codec.memcache.DefaultLastMemcacheContent
 
DefaultLastMemcacheContent(ByteBuf) - Constructor for class com.couchbase.client.deps.io.netty.handler.codec.memcache.DefaultLastMemcacheContent
 
DefaultLatencyMetricsCollectorConfig - Class in com.couchbase.client.core.metrics
The default configuration for the latency metrics collectors.
DefaultLatencyMetricsCollectorConfig.Builder - Class in com.couchbase.client.core.metrics
 
DefaultMemcacheContent - Class in com.couchbase.client.deps.io.netty.handler.codec.memcache
The default MemcacheContent implementation.
DefaultMemcacheContent(ByteBuf) - Constructor for class com.couchbase.client.deps.io.netty.handler.codec.memcache.DefaultMemcacheContent
Creates a new instance with the specified content.
DefaultMemcachedBucketConfig - Class in com.couchbase.client.core.config
 
DefaultMemcachedBucketConfig(ConfigParserEnvironment, long, String, String, String, String, List<NodeInfo>, List<PortInfo>, List<BucketCapabilities>, NetworkAddress) - Constructor for class com.couchbase.client.core.config.DefaultMemcachedBucketConfig
Creates a new MemcachedBucketConfig.
DefaultMemcachedHashingStrategy - Class in com.couchbase.client.core.node
The default memcache bucket hashing strategy, compatible with 2.x Java SDK.
DefaultMetricsCollectorConfig - Class in com.couchbase.client.core.metrics
The default implementation with a builder for the MetricsCollectorConfig.
DefaultMetricsCollectorConfig(DefaultMetricsCollectorConfig.Builder) - Constructor for class com.couchbase.client.core.metrics.DefaultMetricsCollectorConfig
 
DefaultMetricsCollectorConfig.Builder - Class in com.couchbase.client.core.metrics
 
defaultMetricsLoggingConsumer(boolean, CouchbaseLogLevel, LoggingConsumer.OutputFormat) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
 
defaultMetricsLoggingConsumer(boolean, CouchbaseLogLevel) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
 
DefaultNodeInfo - Class in com.couchbase.client.core.config
Default implementation of NodeInfo.
DefaultNodeInfo(String, String, Map<String, Integer>, Map<String, AlternateAddress>) - Constructor for class com.couchbase.client.core.config.DefaultNodeInfo
Creates a new DefaultNodeInfo with no SSL services.
DefaultNodeInfo(NetworkAddress, Map<ServiceType, Integer>, Map<ServiceType, Integer>, Map<String, AlternateAddress>) - Constructor for class com.couchbase.client.core.config.DefaultNodeInfo
Creates a new DefaultNodeInfo with SSL services.
DefaultObjectMapper - Class in com.couchbase.client.core.utils
Provides global access to the services of a Jackson ObjectMapper with default configuration.
DefaultOrphanResponseReporter - Class in com.couchbase.client.core.tracing
The DefaultOrphanResponseReporter receives requests’s of orphan responses and stores them for aggregation and logging.
DefaultOrphanResponseReporter(DefaultOrphanResponseReporter.Builder) - Constructor for class com.couchbase.client.core.tracing.DefaultOrphanResponseReporter
Creates the OrphanResponseReporter using the given config.
DefaultOrphanResponseReporter.Builder - Class in com.couchbase.client.core.tracing
The builder to configure the DefaultOrphanResponseReporter
DefaultPartition - Class in com.couchbase.client.core.config
 
DefaultPartition(short, short[]) - Constructor for class com.couchbase.client.core.config.DefaultPartition
Creates a new DefaultPartition.
DefaultPortInfo - Class in com.couchbase.client.core.config
 
DefaultPortInfo(Map<String, Integer>, String, Map<String, AlternateAddress>) - Constructor for class com.couchbase.client.core.config.DefaultPortInfo
Creates a new DefaultPortInfo.
DefaultServiceRegistry - Class in com.couchbase.client.core.node
The default implementation of a ServiceRegistry.
DefaultServiceRegistry() - Constructor for class com.couchbase.client.core.node.DefaultServiceRegistry
Delay - Class in com.couchbase.client.core.time
Parent class of Delays and provides factory methods to create them.
DELETE - Static variable in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
deleteBucketConfig(String) - Method in interface com.couchbase.client.core.config.ClusterConfig
 
deleteBucketConfig(String) - Method in class com.couchbase.client.core.config.DefaultClusterConfig
 
DELETEQ - Static variable in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
delta() - Method in class com.couchbase.client.core.message.kv.CounterRequest
 
DELTA_BADVAL - Static variable in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheResponseStatus
 
deregister(ChannelHandlerContext, ChannelPromise) - Method in class com.couchbase.client.core.endpoint.kv.KeyValueAuthHandler
 
deregister(ChannelHandlerContext, ChannelPromise) - Method in class com.couchbase.client.core.endpoint.kv.KeyValueErrorMapHandler
 
deregister(ChannelHandlerContext, ChannelPromise) - Method in class com.couchbase.client.core.endpoint.kv.KeyValueFeatureHandler
 
deregister(ChannelHandlerContext, ChannelPromise) - Method in class com.couchbase.client.core.endpoint.kv.KeyValueSelectBucketHandler
 
deregister(T) - Method in class com.couchbase.client.core.state.AbstractStateZipper
 
deregister(T) - Method in interface com.couchbase.client.core.state.StateZipper
Deregisters a stream identified by the identifier from the state computation.
deregisterBucket(String) - Method in class com.couchbase.client.core.config.refresher.AbstractRefresher
 
deregisterBucket(String) - Method in interface com.couchbase.client.core.config.refresher.Refresher
De-registers a bucket from watching.
description() - Method in class com.couchbase.client.core.endpoint.kv.ErrorMap.ErrorCode
 
description() - Method in enum com.couchbase.client.core.endpoint.kv.KeyValueStatus
 
design() - Method in class com.couchbase.client.core.message.view.ViewQueryRequest
 
details() - Method in exception com.couchbase.client.core.CouchbaseException
 
details(ResponseStatusDetails) - Method in exception com.couchbase.client.core.CouchbaseException
 
detailsFromBinary(byte, ByteBuf) - Static method in class com.couchbase.client.core.endpoint.ResponseStatusConverter
 
determineNetworkResolution(BucketConfig, NetworkResolution, Set<NetworkAddress>) - Static method in class com.couchbase.client.core.config.DefaultConfigurationProvider
Helper method to figure out which network resolution should be used.
development() - Method in class com.couchbase.client.core.message.view.GetDesignDocumentRequest
 
development() - Method in class com.couchbase.client.core.message.view.GetDesignDocumentResponse
 
development() - Method in class com.couchbase.client.core.message.view.RemoveDesignDocumentRequest
 
development() - Method in class com.couchbase.client.core.message.view.UpsertDesignDocumentRequest
 
development() - Method in class com.couchbase.client.core.message.view.ViewQueryRequest
 
DiagnosticRequest - Interface in com.couchbase.client.core.message
Marker interface for extended information.
diagnostics(ServiceType) - Method in class com.couchbase.client.core.endpoint.AbstractEndpoint
 
diagnostics(ServiceType) - Method in interface com.couchbase.client.core.endpoint.Endpoint
Returns health information for this endpoint.
Diagnostics - Class in com.couchbase.client.core.env
Provides access to various metrics helpful for system diagnosis.
Diagnostics() - Constructor for class com.couchbase.client.core.env.Diagnostics
 
diagnostics() - Method in class com.couchbase.client.core.node.CouchbaseNode
 
diagnostics() - Method in interface com.couchbase.client.core.node.Node
Returns endpoint health information for all endpoints this node is currently associated with.
diagnostics(String) - Method in class com.couchbase.client.core.RequestHandler
Performs the logistics of collecting and assembling the individual health check information on a per-service basis.
diagnostics() - Method in class com.couchbase.client.core.service.AbstractDynamicService
 
diagnostics() - Method in class com.couchbase.client.core.service.PooledService
 
diagnostics() - Method in interface com.couchbase.client.core.service.Service
Returns endpoint health information for all endpoints this service is currently associated with.
DiagnosticsReport - Class in com.couchbase.client.core.message.internal
Aggregates the health of all Endpoints.
DiagnosticsReport(List<EndpointHealth>, String, String) - Constructor for class com.couchbase.client.core.message.internal.DiagnosticsReport
 
diagnosticsReport() - Method in class com.couchbase.client.core.message.internal.DiagnosticsResponse
 
DiagnosticsRequest - Class in com.couchbase.client.core.message.internal
 
DiagnosticsRequest(String) - Constructor for class com.couchbase.client.core.message.internal.DiagnosticsRequest
 
DiagnosticsResponse - Class in com.couchbase.client.core.message.internal
 
DiagnosticsResponse(DiagnosticsReport) - Constructor for class com.couchbase.client.core.message.internal.DiagnosticsResponse
 
diagostics() - Method in exception com.couchbase.client.core.BackpressureException
Returns a RingBufferDiagnostics which, if non-null, gives a granular breakdown of the contents of the ringbuffer at the time of this exception
disabled() - Static method in class com.couchbase.client.core.metrics.DefaultLatencyMetricsCollectorConfig
 
disabled() - Static method in class com.couchbase.client.core.metrics.DefaultMetricsCollectorConfig
 
disabled() - Static method in class com.couchbase.client.core.tracing.DefaultOrphanResponseReporter
 
disabled() - Static method in class com.couchbase.client.core.tracing.ThresholdLogReporter
 
disconnect() - Method in class com.couchbase.client.core.endpoint.AbstractEndpoint
 
disconnect() - Method in interface com.couchbase.client.core.endpoint.Endpoint
Disconnect the Endpoint from the underlying channel.
disconnect(ChannelHandlerContext, ChannelPromise) - Method in class com.couchbase.client.core.endpoint.kv.KeyValueAuthHandler
 
disconnect(ChannelHandlerContext, ChannelPromise) - Method in class com.couchbase.client.core.endpoint.kv.KeyValueErrorMapHandler
 
disconnect(ChannelHandlerContext, ChannelPromise) - Method in class com.couchbase.client.core.endpoint.kv.KeyValueFeatureHandler
 
disconnect(ChannelHandlerContext, ChannelPromise) - Method in class com.couchbase.client.core.endpoint.kv.KeyValueSelectBucketHandler
 
disconnect() - Method in class com.couchbase.client.core.node.CouchbaseNode
 
disconnect() - Method in interface com.couchbase.client.core.node.Node
Disconnects all currently enabled Services.
disconnect() - Method in class com.couchbase.client.core.service.AbstractDynamicService
 
disconnect() - Method in class com.couchbase.client.core.service.PooledService
 
disconnect() - Method in interface com.couchbase.client.core.service.Service
Disconnects all currently enabled Service Endpoints.
DISCONNECT_TIMEOUT - Static variable in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
DisconnectRequest - Class in com.couchbase.client.core.message.cluster
Disconnects all open buckets.
DisconnectRequest() - Constructor for class com.couchbase.client.core.message.cluster.DisconnectRequest
 
DisconnectResponse - Class in com.couchbase.client.core.message.cluster
A response to a DisconnectRequest.
DisconnectResponse(ResponseStatus) - Constructor for class com.couchbase.client.core.message.cluster.DisconnectResponse
 
disconnectTimeout() - Method in interface com.couchbase.client.core.env.CoreEnvironment
The default timeout for disconnect operations, set to DefaultCoreEnvironment.DISCONNECT_TIMEOUT.
disconnectTimeout(long) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Sets a custom disconnect timeout.
disconnectTimeout() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
discoverConfig(String, String, String, NetworkAddress) - Method in class com.couchbase.client.core.config.loader.AbstractLoader
Run the BucketConfig discovery process.
discoverConfig(String, String, String, NetworkAddress) - Method in class com.couchbase.client.core.config.loader.CarrierLoader
 
discoverConfig(String, String, String, NetworkAddress) - Method in class com.couchbase.client.core.config.loader.HttpLoader
 
dispatch(CouchbaseRequest) - Method in class com.couchbase.client.core.service.AbstractDynamicService
 
dispatch(CouchbaseRequest) - Method in class com.couchbase.client.core.service.AbstractLazyService
 
dispatch(CouchbaseRequest) - Method in class com.couchbase.client.core.service.AbstractOnDemandService
 
dispatch(CouchbaseRequest) - Method in class com.couchbase.client.core.service.AbstractPoolingService
 
dispatchHostname() - Method in class com.couchbase.client.core.message.AbstractCouchbaseRequest
 
dispatchHostname(String) - Method in class com.couchbase.client.core.message.AbstractCouchbaseRequest
 
dispatchHostname() - Method in interface com.couchbase.client.core.message.CouchbaseRequest
 
dispatchHostname(String) - Method in interface com.couchbase.client.core.message.CouchbaseRequest
 
dispose() - Method in class com.couchbase.client.core.security.sasl.ShaSaslClient
 
disposeIfNotSubscribed() - Method in class com.couchbase.client.core.utils.UnicastAutoReleaseSubject
This will eagerly dispose this Subject without waiting for the no subscription timeout period, if configured.
doBeginRead() - Method in class com.couchbase.client.core.endpoint.util.FailedChannel
 
doBind(SocketAddress) - Method in class com.couchbase.client.core.endpoint.util.FailedChannel
 
docFlags() - Method in interface com.couchbase.client.core.message.kv.subdoc.BinarySubdocMultiLookupRequest
 
docFlags() - Method in interface com.couchbase.client.core.message.kv.subdoc.BinarySubdocMultiMutationRequest
 
docFlags() - Method in class com.couchbase.client.core.message.kv.subdoc.multi.SubMultiLookupRequest
 
docFlags() - Method in class com.couchbase.client.core.message.kv.subdoc.multi.SubMultiMutationRequest
 
doClose() - Method in class com.couchbase.client.core.endpoint.util.FailedChannel
 
doConnect(Subject<LifecycleState, LifecycleState>, boolean) - Method in class com.couchbase.client.core.endpoint.AbstractEndpoint
Helper method to perform the actual connect and reconnect.
DocumentConcurrentlyModifiedException - Exception in com.couchbase.client.core
Exception indicating that the document which is observed has been modified in the meantime.
DocumentConcurrentlyModifiedException(String, Long) - Constructor for exception com.couchbase.client.core.DocumentConcurrentlyModifiedException
 
DocumentMutationLostException - Exception in com.couchbase.client.core
The observed document was lost during a hard failover, because the document did not reach the replica in time.
DocumentMutationLostException(String, Long) - Constructor for exception com.couchbase.client.core.DocumentMutationLostException
 
doDisconnect() - Method in class com.couchbase.client.core.endpoint.util.FailedChannel
 
doublePropertyOr(String, double) - Static method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
doWrite(ChannelOutboundBuffer) - Method in class com.couchbase.client.core.endpoint.util.FailedChannel
 
dumpParameters(StringBuilder) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
Dumps the environment parameters known to this implementation into a StringBuilder, which is returned for method chaining.
duplicate() - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.DefaultFullBinaryMemcacheRequest
 
duplicate() - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.DefaultFullBinaryMemcacheResponse
 
duplicate() - Method in interface com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.FullBinaryMemcacheRequest
 
duplicate() - Method in interface com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.FullBinaryMemcacheResponse
 
duplicate() - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.DefaultLastMemcacheContent
 
duplicate() - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.DefaultMemcacheContent
 
duplicate() - Method in interface com.couchbase.client.deps.io.netty.handler.codec.memcache.FullMemcacheMessage
 
duplicate() - Method in interface com.couchbase.client.deps.io.netty.handler.codec.memcache.LastMemcacheContent
 
duplicate() - Method in interface com.couchbase.client.deps.io.netty.handler.codec.memcache.MemcacheContent
 
durationMicros() - Method in class com.couchbase.client.core.tracing.ThresholdLogSpan
Returns the relative duration in microseconds.

E

E2BIG - Static variable in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheResponseStatus
 
EINVAL - Static variable in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheResponseStatus
 
emit(CouchbaseResponse) - Method in class com.couchbase.client.core.message.AbstractCouchbaseRequest
 
emit(CouchbaseResponse) - Method in interface com.couchbase.client.core.message.CouchbaseRequest
Emits the CouchbaseResponse into the underlying state holder (like a subject) without completing it as per contract.
EMIT_FREQUENCY - Static variable in class com.couchbase.client.core.metrics.DefaultMetricsCollectorConfig
 
EMIT_FREQUENCY_UNIT - Static variable in class com.couchbase.client.core.metrics.DefaultMetricsCollectorConfig
 
emitFrequency(long) - Method in class com.couchbase.client.core.metrics.DefaultLatencyMetricsCollectorConfig.Builder
 
emitFrequency(long) - Method in class com.couchbase.client.core.metrics.DefaultMetricsCollectorConfig.Builder
Overrides the default emit frequency for this metric collector.
emitFrequency() - Method in class com.couchbase.client.core.metrics.DefaultMetricsCollectorConfig
 
emitFrequency() - Method in interface com.couchbase.client.core.metrics.MetricsCollectorConfig
The interval frequency when to emit the metrics.
emitFrequencyUnit(TimeUnit) - Method in class com.couchbase.client.core.metrics.DefaultLatencyMetricsCollectorConfig.Builder
 
emitFrequencyUnit(TimeUnit) - Method in class com.couchbase.client.core.metrics.DefaultMetricsCollectorConfig.Builder
Overrides the default emit frequency unit for this metric collector.
emitFrequencyUnit() - Method in class com.couchbase.client.core.metrics.DefaultMetricsCollectorConfig
 
emitFrequencyUnit() - Method in interface com.couchbase.client.core.metrics.MetricsCollectorConfig
The time unit for the emit frequency.
EMPTY_BYTES - Static variable in class com.couchbase.client.core.endpoint.AbstractGenericHandler
Empty bytes to reuse.
EMPTY_LAST_CONTENT - Static variable in interface com.couchbase.client.deps.io.netty.handler.codec.memcache.LastMemcacheContent
 
encode(ChannelHandlerContext, REQUEST, List<Object>) - Method in class com.couchbase.client.core.endpoint.AbstractGenericHandler
 
encode(byte[]) - Static method in class com.couchbase.client.core.utils.Base64
Base64 encode a textual string according to RFC 3548
encode(ChannelHandlerContext, Object, List<Object>) - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.AbstractMemcacheObjectEncoder
 
encodeHeader(ByteBuf, M) - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheEncoder
Encode the header.
encodeHeader(ByteBuf, BinaryMemcacheRequest) - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheRequestEncoder
 
encodeHeader(ByteBuf, BinaryMemcacheResponse) - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheResponseEncoder
 
encodeMessage(ChannelHandlerContext, M) - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.AbstractMemcacheObjectEncoder
Take the given MemcacheMessage and encode it into a writable ByteBuf.
encodeMessage(ChannelHandlerContext, M) - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheEncoder
 
encodeRequest(ChannelHandlerContext, REQUEST) - Method in class com.couchbase.client.core.endpoint.AbstractGenericHandler
Encode the outgoing request and return it in encoded format.
encodeRequest(ChannelHandlerContext, AnalyticsRequest) - Method in class com.couchbase.client.core.endpoint.analytics.AnalyticsHandler
 
encodeRequest(ChannelHandlerContext, ConfigRequest) - Method in class com.couchbase.client.core.endpoint.config.ConfigHandler
 
encodeRequest(ChannelHandlerContext, BinaryRequest) - Method in class com.couchbase.client.core.endpoint.kv.KeyValueHandler
 
encodeRequest(ChannelHandlerContext, QueryRequest) - Method in class com.couchbase.client.core.endpoint.query.QueryHandler
 
encodeRequest(ChannelHandlerContext, QueryRequest) - Method in class com.couchbase.client.core.endpoint.query.QueryHandlerV2
 
encodeRequest(ChannelHandlerContext, SearchRequest) - Method in class com.couchbase.client.core.endpoint.search.SearchHandler
 
encodeRequest(ChannelHandlerContext, ViewRequest) - Method in class com.couchbase.client.core.endpoint.view.ViewHandler
 
endpoint() - Method in class com.couchbase.client.core.endpoint.AbstractGenericHandler
The parent endpoint.
Endpoint - Interface in com.couchbase.client.core.endpoint
Represents a stateful Endpoint which abstracts the underlying channel.
EndpointHealth - Class in com.couchbase.client.core.message.internal
Aggregates the health of one specific Endpoint.
EndpointHealth(ServiceType, LifecycleState, SocketAddress, SocketAddress, long, String) - Constructor for class com.couchbase.client.core.message.internal.EndpointHealth
 
endpoints() - Method in class com.couchbase.client.core.message.internal.DiagnosticsReport
 
endpoints(ServiceType) - Method in class com.couchbase.client.core.message.internal.DiagnosticsReport
 
endpoints() - Method in class com.couchbase.client.core.service.AbstractDynamicService
Returns the current list of endpoints.
endpoints() - Method in class com.couchbase.client.core.service.PooledService
Returns the current endpoint list, for testing verification purposes.
endpointStates() - Method in class com.couchbase.client.core.service.AbstractDynamicService
Returns the underlying endpoint state zipper.
EndpointStateZipper - Class in com.couchbase.client.core.service
Calculates a merged state for all registered endpoints.
EndpointStateZipper(LifecycleState) - Constructor for class com.couchbase.client.core.service.EndpointStateZipper
 
ENOMEM - Static variable in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheResponseStatus
 
env() - Method in class com.couchbase.client.core.config.loader.AbstractLoader
Returns the CoreEnvironment for child implementations.
env() - Method in class com.couchbase.client.core.endpoint.AbstractGenericHandler
Returns environment.
environment() - Method in class com.couchbase.client.core.CoreContext
Returns the current environment.
environment() - Method in class com.couchbase.client.core.endpoint.AbstractEndpoint
The CoreEnvironment reference.
EnvironmentException - Exception in com.couchbase.client.core.env
 
EnvironmentException(String) - Constructor for exception com.couchbase.client.core.env.EnvironmentException
 
EnvironmentException(String, Throwable) - Constructor for exception com.couchbase.client.core.env.EnvironmentException
 
ephemeral() - Method in interface com.couchbase.client.core.config.CouchbaseBucketConfig
If this couchbase bucket is ephemeral.
ephemeral() - Method in class com.couchbase.client.core.config.DefaultCouchbaseBucketConfig
 
equals(Object) - Method in class com.couchbase.client.core.config.DefaultAlternateAddress
 
equals(Object) - Method in class com.couchbase.client.core.config.ProposedBucketConfigContext
 
equals(Object) - Method in class com.couchbase.client.core.env.NetworkResolution
 
equals(Object) - Method in class com.couchbase.client.core.message.kv.MutationToken
 
equals(Object) - Method in class com.couchbase.client.core.message.kv.subdoc.multi.MultiResult
 
equals(Object) - Method in class com.couchbase.client.core.message.ResponseStatusDetails
 
equals(Object) - Method in class com.couchbase.client.core.metrics.NetworkLatencyMetricsIdentifier
 
equals(Object) - Method in class com.couchbase.client.core.node.CouchbaseNode
 
equals(Object) - Method in class com.couchbase.client.core.utils.NetworkAddress
 
error(Throwable) - Method in class com.couchbase.client.core.logging.AbstractCouchbaseLogger
 
error(String) - Method in interface com.couchbase.client.core.logging.CouchbaseLogger
Log a message at the ERROR level.
error(String, Object) - Method in interface com.couchbase.client.core.logging.CouchbaseLogger
Log a message at the ERROR level according to the specified format and argument.
error(String, Object, Object) - Method in interface com.couchbase.client.core.logging.CouchbaseLogger
Log a message at the ERROR level according to the specified format and arguments.
error(String, Object...) - Method in interface com.couchbase.client.core.logging.CouchbaseLogger
Log a message at the ERROR level according to the specified format and arguments.
error(String, Throwable) - Method in interface com.couchbase.client.core.logging.CouchbaseLogger
Log an exception (throwable) at the ERROR level with an accompanying message.
error(Throwable) - Method in interface com.couchbase.client.core.logging.CouchbaseLogger
Log an exception (throwable) at the ERROR level.
error() - Method in class com.couchbase.client.core.message.view.ViewQueryResponse
 
ErrorCode(String, String, List<ErrorMap.ErrorAttribute>, ErrorMap.RetrySpecification) - Constructor for class com.couchbase.client.core.endpoint.kv.ErrorMap.ErrorCode
 
ErrorMap - Class in com.couchbase.client.core.endpoint.kv
The ErrorMap contains mappings from errors to their attributes, negotiated between the client and the server.
ErrorMap(int, int, Map<String, ErrorMap.ErrorCode>) - Constructor for class com.couchbase.client.core.endpoint.kv.ErrorMap
 
ErrorMap.ErrorAttribute - Enum in com.couchbase.client.core.endpoint.kv
 
ErrorMap.ErrorCode - Class in com.couchbase.client.core.endpoint.kv
 
ErrorMap.RetrySpecification - Class in com.couchbase.client.core.endpoint.kv
 
ErrorMap.RetryStrategy - Enum in com.couchbase.client.core.endpoint.kv
 
errors() - Method in class com.couchbase.client.core.endpoint.kv.ErrorMap
 
errors() - Method in class com.couchbase.client.core.message.analytics.GenericAnalyticsResponse
If there were errors and/or warnings while executing the query, contains a ByteBuf for each error and each warning.
errors() - Method in class com.couchbase.client.core.message.query.GenericQueryResponse
If there were errors and/or warnings while executing the query, contains a ByteBuf for each error and each warning.
evaluateChallenge(byte[]) - Method in class com.couchbase.client.core.security.sasl.ShaSaslClient
 
eventBus() - Method in interface com.couchbase.client.core.env.CoreEnvironment
Returns the event bus where events are broadcasted on and can be published to.
eventBus(EventBus) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Sets the event bus to an alternative implementation.
eventBus() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
EventBus - Interface in com.couchbase.client.core.event
Defines the interface for a generic event bus.
Events - Class in com.couchbase.client.core.utils
Utility methods for event handling.
Events() - Constructor for class com.couchbase.client.core.utils.Events
 
EventType - Enum in com.couchbase.client.core.event
Different event types available.
EXCEPTION_EMPTY_PATH - Static variable in class com.couchbase.client.core.message.kv.subdoc.simple.AbstractSubdocRequest
An IllegalArgumentException that is thrown by constructors when a empty path is provided on an operation that doesn’t allow them.
EXCEPTION_NULL_PATH - Static variable in class com.couchbase.client.core.message.kv.subdoc.simple.AbstractSubdocRequest
A NullPointerException that is thrown by constructors when a null path is provided.
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class com.couchbase.client.core.endpoint.AbstractGenericHandler
 
expiration() - Method in interface com.couchbase.client.core.message.kv.BinaryStoreRequest
 
expiration() - Method in class com.couchbase.client.core.message.kv.InsertRequest
Returns the expiration time for this document.
expiration() - Method in class com.couchbase.client.core.message.kv.ReplaceRequest
Returns the expiration time for this document.
expiration() - Method in interface com.couchbase.client.core.message.kv.subdoc.BinarySubdocMultiMutationRequest
 
expiration() - Method in interface com.couchbase.client.core.message.kv.subdoc.BinarySubdocMutationRequest
 
expiration() - Method in class com.couchbase.client.core.message.kv.subdoc.multi.SubMultiMutationRequest
 
expiration() - Method in class com.couchbase.client.core.message.kv.subdoc.simple.AbstractSubdocMutationRequest
 
expiration() - Method in class com.couchbase.client.core.message.kv.UpsertRequest
Returns the expiration time for this document.
expiry() - Method in class com.couchbase.client.core.message.kv.CounterRequest
 
expiry() - Method in class com.couchbase.client.core.message.kv.GetRequest
 
expiry() - Method in class com.couchbase.client.core.message.kv.TouchRequest
 
exponential(TimeUnit) - Static method in class com.couchbase.client.core.time.Delay
Creates a new ExponentialDelay with default boundaries and factor (1, 2, 4, 8, 16, 32…).
exponential(TimeUnit, long) - Static method in class com.couchbase.client.core.time.Delay
Creates a new ExponentialDelay with custom upper boundary and default factor (eg.
exponential(TimeUnit, long, long) - Static method in class com.couchbase.client.core.time.Delay
Creates a new ExponentialDelay with custom boundaries and default factor (eg.
exponential(TimeUnit, long, long, long) - Static method in class com.couchbase.client.core.time.Delay
Creates a new ExponentialDelay with custom boundaries and factor (eg.
exponential(TimeUnit, long, long, long, int) - Static method in class com.couchbase.client.core.time.Delay
Creates a new ExponentialDelay on a base different from powers of two, with custom boundaries and factor (eg.
ExponentialDelay - Class in com.couchbase.client.core.time
Delay which increases exponentially on every attempt.
export() - Method in class com.couchbase.client.core.event.metrics.LatencyMetric
Exports this object to a plain map structure which can be easily converted into other target formats.
exportToJson() - Method in class com.couchbase.client.core.message.internal.DiagnosticsReport
Exports this report into the standard JSON format which is consistent across different language SDKs.
exportToJson(boolean) - Method in class com.couchbase.client.core.message.internal.DiagnosticsReport
Exports this report into the standard JSON format which is consistent across different language SDKs.
exportToJson() - Method in class com.couchbase.client.core.message.internal.PingReport
Exports this report into the RFC JSON format.
exportToJson(boolean) - Method in class com.couchbase.client.core.message.internal.PingReport
Exports this report into the RFC JSON format.
EXTERNAL - Static variable in class com.couchbase.client.core.env.NetworkResolution
Pins it to external resolution.
extract(Format<C>, C) - Method in class com.couchbase.client.core.tracing.ThresholdLogTracer
 

F

fail(Throwable) - Method in class com.couchbase.client.core.message.AbstractCouchbaseRequest
 
fail(Throwable) - Method in interface com.couchbase.client.core.message.CouchbaseRequest
Fails the CouchbaseResponse on the state holder as per contract.
FailedChannel - Class in com.couchbase.client.core.endpoint.util
The failed channel can be used to create a channel promise when no channel is available (because it failed).
FailedChannel() - Constructor for class com.couchbase.client.core.endpoint.util.FailedChannel
 
FailFastRetryStrategy - Class in com.couchbase.client.core.retry
A RetryStrategy that will never retry and cancel right away.
FailoverObserveSeqnoResponse - Class in com.couchbase.client.core.message.kv
Represents a observe seqno response.
FailoverObserveSeqnoResponse(boolean, short, long, long, long, long, long, ResponseStatus, short, String, CouchbaseRequest) - Constructor for class com.couchbase.client.core.message.kv.FailoverObserveSeqnoResponse
 
failSafe(Scheduler, boolean, Subject<CouchbaseResponse, CouchbaseResponse>, Throwable) - Static method in enum com.couchbase.client.core.utils.Observables
Helper method to fail a given observable while still making sure to move it onto the proper scheduler for handling if needed (similar to onNext).
findNextChar(ByteBuf, char) - Static method in class com.couchbase.client.core.endpoint.util.ByteBufJsonHelper
Shorthand for ByteBuf.bytesBefore(byte) with a simple char c, finds the number of bytes until next occurrence of the character c from the current readerIndex() in buf.
findNextCharNotPrefixedBy(ByteBuf, char, char) - Static method in class com.couchbase.client.core.endpoint.util.ByteBufJsonHelper
Find the number of bytes until next occurrence of the character c from the current readerIndex in buf, with the twist that if this occurrence is prefixed by the prefix character, we try to find another occurrence.
findSectionClosingPosition(ByteBuf, char, char) - Static method in class com.couchbase.client.core.endpoint.util.ByteBufJsonHelper
Finds the position of the correct closing character, taking into account the fact that before the correct one, other sub section with same opening and closing characters can be encountered.
findSectionClosingPosition(ByteBuf, int, char, char) - Static method in class com.couchbase.client.core.endpoint.util.ByteBufJsonHelper
Finds the position of the correct closing character, taking into account the fact that before the correct one, other sub section with same opening and closing characters can be encountered.
findSplitPosition(ByteBuf, char) - Static method in class com.couchbase.client.core.endpoint.util.ByteBufJsonHelper
Finds the position of the split character, taking into account the fact that the character could be found escaped in strings (such occurrences are ignored).
finish() - Method in class com.couchbase.client.core.tracing.ThresholdLogSpan
 
finish(long) - Method in class com.couchbase.client.core.tracing.ThresholdLogSpan
 
finishedDecoding() - Method in class com.couchbase.client.core.endpoint.AbstractGenericHandler
Notify that decoding is finished.
finishedDecoding() - Method in class com.couchbase.client.core.endpoint.config.ConfigHandler
 
finishedDecoding() - Method in class com.couchbase.client.core.endpoint.query.QueryHandlerV2
 
finishedDecoding() - Method in class com.couchbase.client.core.endpoint.search.SearchHandler
 
finishParsingAndReset() - Method in class com.couchbase.client.core.endpoint.query.parser.YasjlQueryResponseParser
Instruct the parser to finish the parsing and reset its internal state, turning it back to uninitialized as well.
firstErrorIndex() - Method in class com.couchbase.client.core.message.kv.subdoc.multi.MultiMutationResponse
 
firstErrorStatus() - Method in class com.couchbase.client.core.message.kv.subdoc.multi.MultiMutationResponse
 
fixed(long, TimeUnit) - Static method in class com.couchbase.client.core.time.Delay
Creates a new FixedDelay.
FixedDelay - Class in com.couchbase.client.core.time
Delay which is fixed for every attempt.
flags() - Method in interface com.couchbase.client.core.message.kv.BinaryStoreRequest
 
flags() - Method in class com.couchbase.client.core.message.kv.GetResponse
 
flags() - Method in class com.couchbase.client.core.message.kv.InsertRequest
Returns the flags for this document.
flags() - Method in class com.couchbase.client.core.message.kv.ReplaceRequest
Returns the flags for this document.
flags() - Method in class com.couchbase.client.core.message.kv.UpsertRequest
Returns the flags for this document.
floorDiv(long, long) - Static method in class com.couchbase.client.core.utils.MathUtils
Backport of floorDiv from the JDK since we need to support 1.6.
floorMod(long, long) - Static method in class com.couchbase.client.core.utils.MathUtils
Backport of floorMod from the JDK since we need to support 1.6.
flush(ChannelHandlerContext) - Method in class com.couchbase.client.core.endpoint.kv.KeyValueAuthHandler
 
flush(ChannelHandlerContext) - Method in class com.couchbase.client.core.endpoint.kv.KeyValueErrorMapHandler
 
flush(ChannelHandlerContext) - Method in class com.couchbase.client.core.endpoint.kv.KeyValueFeatureHandler
 
flush(ChannelHandlerContext) - Method in class com.couchbase.client.core.endpoint.kv.KeyValueSelectBucketHandler
 
FLUSH - Static variable in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
FLUSHQ - Static variable in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
FlushRequest - Class in com.couchbase.client.core.message.config
Sends a flush command to the cluster.
FlushRequest(String, String) - Constructor for class com.couchbase.client.core.message.config.FlushRequest
 
FlushRequest(String, String, String) - Constructor for class com.couchbase.client.core.message.config.FlushRequest
 
FlushResponse - Class in com.couchbase.client.core.message.config
 
FlushResponse(boolean, String, ResponseStatus) - Constructor for class com.couchbase.client.core.message.config.FlushResponse
 
followsFrom(ThresholdLogSpanContext) - Static method in class com.couchbase.client.core.tracing.ThresholdLogReference
Creates a reference which represents the follower of the given context.
FORCE_IPV4 - Static variable in class com.couchbase.client.core.utils.NetworkAddress
Flag which controls if even if ipv6 is present, IPv4 should be preferred.
FORCE_IPV4_PROPERTY - Static variable in class com.couchbase.client.core.utils.NetworkAddress
 
FORCE_SASL_PLAIN - Static variable in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
forceSaslPlain() - Method in interface com.couchbase.client.core.env.CoreEnvironment
Forces the KeyValue SASL Authentication method to PLAIN if set to true, specifically allowing LDAP-based users to authenticate.
forceSaslPlain(boolean) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Allows to forcre the KeyValue SASL authentication method to PLAIN which is used to allow authentication against LDAP-based users.
forceSaslPlain() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
forString(String) - Static method in class com.couchbase.client.core.utils.InetAddresses
Returns the InetAddress having the given string representation.
forwardPartitions() - Method in class com.couchbase.client.core.config.CouchbasePartitionInfo
 
fragment() - Method in interface com.couchbase.client.core.message.kv.subdoc.BinarySubdocMutationRequest
A ByteBuf containing the JSON fragment for the mutation.
fragment(ByteBuf) - Method in class com.couchbase.client.core.message.kv.subdoc.multi.MutationCommandBuilder
 
fragment() - Method in class com.couchbase.client.core.message.kv.subdoc.simple.AbstractSubdocMutationRequest
 
FRAMING_EXTRAS_TRACING - Static variable in class com.couchbase.client.core.endpoint.kv.KeyValueHandler
The byte used to signal this is a tracing extras frame.
fromBinary(short) - Static method in class com.couchbase.client.core.endpoint.ResponseStatusConverter
Convert the binary protocol status in a typesafe enum that can be acted upon later.
fromHostnames(List<String>) - Static method in class com.couchbase.client.core.utils.ConnectionString
 
fromHttp(int) - Static method in class com.couchbase.client.core.endpoint.ResponseStatusConverter
Convert the http protocol status in a typesafe enum that can be acted upon later.
fromValue(short) - Static method in enum com.couchbase.client.core.endpoint.ServerFeatures
 
ftsThreshold(long, TimeUnit) - Method in class com.couchbase.client.core.tracing.ThresholdLogReporter.Builder
Allows to customize the ftsThreshold.
FullBinaryMemcacheRequest - Interface in com.couchbase.client.deps.io.netty.handler.codec.memcache.binary
A BinaryMemcacheRequest that also includes the content.
FullBinaryMemcacheResponse - Interface in com.couchbase.client.deps.io.netty.handler.codec.memcache.binary
A BinaryMemcacheResponse that also includes the content.
FullMemcacheMessage - Interface in com.couchbase.client.deps.io.netty.handler.codec.memcache
Combines MemcacheMessage and LastMemcacheContent into one message.

G

GAT - Static variable in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
GATK - Static variable in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
GATKQ - Static variable in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
GATQ - Static variable in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
gcInfo(Map<String, Object>) - Static method in class com.couchbase.client.core.env.Diagnostics
Collects system information as delivered from the GarbageCollectorMXBean.
generateCouchbaseEvent() - Method in class com.couchbase.client.core.metrics.AbstractLatencyMetricsCollector
 
generateCouchbaseEvent() - Method in class com.couchbase.client.core.metrics.AbstractMetricsCollector
Generate the actual CouchbaseEvent to emit on every interval.
generateCouchbaseEvent() - Method in class com.couchbase.client.core.metrics.RuntimeMetricsCollector
 
generateLatencyMetricsEvent(Map<I, LatencyStats>) - Method in class com.couchbase.client.core.metrics.AbstractLatencyMetricsCollector
 
generateLatencyMetricsEvent(Map<NetworkLatencyMetricsIdentifier, LatencyStats>) - Method in class com.couchbase.client.core.metrics.NetworkLatencyMetricsCollector
 
GenericAnalyticsRequest - Class in com.couchbase.client.core.message.analytics
For the lack of a better name, a analytics request against a analytics server.
GenericAnalyticsRequest(String, boolean, String, String, String, InetAddress) - Constructor for class com.couchbase.client.core.message.analytics.GenericAnalyticsRequest
 
GenericAnalyticsResponse - Class in com.couchbase.client.core.message.analytics
The base response for Analytics (SQL++) requests.
GenericAnalyticsResponse(Observable<ByteBuf>, Observable<ByteBuf>, Observable<ByteBuf>, Observable<String>, Observable<ByteBuf>, CouchbaseRequest, ResponseStatus, String, String) - Constructor for class com.couchbase.client.core.message.analytics.GenericAnalyticsResponse
 
GenericQueryRequest - Class in com.couchbase.client.core.message.query
For the lack of a better name, a query request against a query server.
GenericQueryRequest(String, boolean, String, String, String, InetAddress, String) - Constructor for class com.couchbase.client.core.message.query.GenericQueryRequest
 
GenericQueryResponse - Class in com.couchbase.client.core.message.query
The base response for Query (N1QL) requests.
GenericQueryResponse(Observable<ByteBuf>, Observable<ByteBuf>, Observable<ByteBuf>, Observable<String>, Observable<ByteBuf>, Observable<ByteBuf>, CouchbaseRequest, ResponseStatus, String, String) - Constructor for class com.couchbase.client.core.message.query.GenericQueryResponse
 
get() - Method in class com.couchbase.client.core.endpoint.SSLEngineFactory
Returns a new SSLEngine constructed from the config settings.
get() - Method in class com.couchbase.client.core.event.DefaultEventBus
 
get() - Method in interface com.couchbase.client.core.event.EventBus
Subscribe to the event bus to retrieve CouchbaseEvents.
GET - Static variable in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
GetAllMutationTokensRequest - Class in com.couchbase.client.core.message.kv
Get the current high sequence numbers one could initialize streams for all partitions that are located on the server, or use in ObserveViaMutationToken.
GetAllMutationTokensRequest(NetworkAddress, String) - Constructor for class com.couchbase.client.core.message.kv.GetAllMutationTokensRequest
 
GetAllMutationTokensRequest(GetAllMutationTokensRequest.PartitionState, NetworkAddress, String) - Constructor for class com.couchbase.client.core.message.kv.GetAllMutationTokensRequest
 
GetAllMutationTokensRequest.PartitionState - Enum in com.couchbase.client.core.message.kv
 
GetAllMutationTokensResponse - Class in com.couchbase.client.core.message.kv
Represents response to GetAllMutationTokensRequest.
GetAllMutationTokensResponse(MutationToken[], ResponseStatus, short, String, CouchbaseRequest) - Constructor for class com.couchbase.client.core.message.kv.GetAllMutationTokensResponse
 
getBaggageItem(String) - Method in class com.couchbase.client.core.tracing.ThresholdLogSpan
 
getBinaryErrorMap() - Static method in class com.couchbase.client.core.endpoint.ResponseStatusConverter
Get the current error map used by the response status converter
GetBucketConfigRequest - Class in com.couchbase.client.core.message.kv
Request which fetches a bucket configuration through carrier publication.
GetBucketConfigRequest(String, NetworkAddress) - Constructor for class com.couchbase.client.core.message.kv.GetBucketConfigRequest
Creates a new GetBucketConfigRequest.
GetBucketConfigResponse - Class in com.couchbase.client.core.message.kv
Represents a response with a bucket configuration.
GetBucketConfigResponse(ResponseStatus, short, String, ByteBuf, NetworkAddress) - Constructor for class com.couchbase.client.core.message.kv.GetBucketConfigResponse
 
getCAS() - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
 
getCAS() - Method in interface com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheMessage
Returns the CAS identifier.
GetClusterConfigRequest - Class in com.couchbase.client.core.message.cluster
 
GetClusterConfigRequest() - Constructor for class com.couchbase.client.core.message.cluster.GetClusterConfigRequest
 
GetClusterConfigResponse - Class in com.couchbase.client.core.message.cluster
 
GetClusterConfigResponse(ClusterConfig, ResponseStatus) - Constructor for class com.couchbase.client.core.message.cluster.GetClusterConfigResponse
 
GetConfigProviderRequest - Class in com.couchbase.client.core.message.internal
Request to fetch the configuration provider from the core.
GetConfigProviderRequest() - Constructor for class com.couchbase.client.core.message.internal.GetConfigProviderRequest
 
GetConfigProviderResponse - Class in com.couchbase.client.core.message.internal
Response to fetch the configuration provider from the core.
GetConfigProviderResponse(ConfigurationProvider) - Constructor for class com.couchbase.client.core.message.internal.GetConfigProviderResponse
 
getDataType() - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
 
getDataType() - Method in interface com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheMessage
Returns the data type of the message.
getDecoderResult() - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.AbstractMemcacheObject
 
getDecoderResult() - Method in interface com.couchbase.client.deps.io.netty.handler.codec.memcache.MemcacheObject
Returns the result of decoding this message.
getDecodingState() - Method in class com.couchbase.client.core.endpoint.AbstractGenericHandler
 
getDefaultFactory() - Static method in class com.couchbase.client.core.logging.CouchbaseLoggerFactory
Returns the default factory.
GetDesignDocumentRequest - Class in com.couchbase.client.core.message.view
 
GetDesignDocumentRequest(String, boolean, String, String) - Constructor for class com.couchbase.client.core.message.view.GetDesignDocumentRequest
 
GetDesignDocumentRequest(String, boolean, String, String, String) - Constructor for class com.couchbase.client.core.message.view.GetDesignDocumentRequest
 
GetDesignDocumentResponse - Class in com.couchbase.client.core.message.view
 
GetDesignDocumentResponse(String, boolean, ByteBuf, ResponseStatus, CouchbaseRequest) - Constructor for class com.couchbase.client.core.message.view.GetDesignDocumentResponse
 
GetDesignDocumentsRequest - Class in com.couchbase.client.core.message.config
 
GetDesignDocumentsRequest(String, String) - Constructor for class com.couchbase.client.core.message.config.GetDesignDocumentsRequest
 
GetDesignDocumentsRequest(String, String, String) - Constructor for class com.couchbase.client.core.message.config.GetDesignDocumentsRequest
 
GetDesignDocumentsResponse - Class in com.couchbase.client.core.message.config
 
GetDesignDocumentsResponse(String, ResponseStatus, CouchbaseRequest) - Constructor for class com.couchbase.client.core.message.config.GetDesignDocumentsResponse
 
getExtras() - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
 
getExtras() - Method in interface com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheMessage
Returns a ByteBuf representation of the optional extras.
getExtrasLength() - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
 
getExtrasLength() - Method in interface com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheMessage
Return the extras length of the message.
getFramingExtras() - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
 
getFramingExtras() - Method in interface com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheMessage
Returns a ByteBuf representation of the optional framing extras.
getFramingExtrasLength() - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
 
getFramingExtrasLength() - Method in interface com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheMessage
Return the framing extras length of the message.
getInstance(Class<?>) - Static method in class com.couchbase.client.core.logging.CouchbaseLoggerFactory
Creates a new logger instance with the name of the specified class.
getInstance(String) - Static method in class com.couchbase.client.core.logging.CouchbaseLoggerFactory
Creates a new logger instance with the specified name.
GETK - Static variable in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
getKey() - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
 
getKey() - Method in interface com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheMessage
Returns the optional key of the document.
getKeyLength() - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
 
getKeyLength() - Method in interface com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheMessage
Returns the key length of the message.
GETKQ - Static variable in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
getMagic() - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
 
getMagic() - Method in interface com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheMessage
Returns the magic byte for the message.
getMaxContentLength() - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.AbstractMemcacheObjectAggregator
 
getMaxCumulationBufferComponents() - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.AbstractMemcacheObjectAggregator
Returns the maximum number of components in the cumulation buffer.
getMechanismName() - Method in class com.couchbase.client.core.security.sasl.ShaSaslClient
 
getMechanismNames(Map<String, ?>) - Method in class com.couchbase.client.core.security.sasl.ShaSaslClientFactory
 
getMessage() - Method in exception com.couchbase.client.core.CouchbaseException
 
getMessage() - Method in class com.couchbase.client.core.ResponseEvent
Get the response from the payload.
getNegotiatedProperty(String) - Method in class com.couchbase.client.core.security.sasl.ShaSaslClient
 
getObservable() - Method in class com.couchbase.client.core.ResponseEvent
 
getOpaque() - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
 
getOpaque() - Method in interface com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheMessage
Returns the opaque value.
getOpcode() - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
 
getOpcode() - Method in interface com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheMessage
Returns the opcode for the message.
GETQ - Static variable in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
getQueryParsingState() - Method in class com.couchbase.client.core.endpoint.analytics.AnalyticsHandler
 
getQueryParsingState() - Method in class com.couchbase.client.core.endpoint.query.QueryHandler
 
getRaw() - Method in enum com.couchbase.client.core.config.BucketCapabilities
 
getRedactionLevel() - Static method in class com.couchbase.client.core.logging.CouchbaseLoggerFactory
Returns the current redaction level.
GetRequest - Class in com.couchbase.client.core.message.kv
Fetch a document from the cluster and return it if found.
GetRequest(String, String) - Constructor for class com.couchbase.client.core.message.kv.GetRequest
 
GetRequest(String, String, boolean, boolean, int) - Constructor for class com.couchbase.client.core.message.kv.GetRequest
 
getRequest() - Method in class com.couchbase.client.core.RequestEvent
 
getReserved() - Method in interface com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheRequest
Returns the reserved field value.
getReserved() - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.DefaultBinaryMemcacheRequest
 
GetResponse - Class in com.couchbase.client.core.message.kv
Represents a response to a GetRequest.
GetResponse(ResponseStatus, short, long, int, String, ByteBuf, CouchbaseRequest) - Constructor for class com.couchbase.client.core.message.kv.GetResponse
 
getResponseContent() - Method in class com.couchbase.client.core.endpoint.query.QueryHandlerV2
 
GetSearchIndexRequest - Class in com.couchbase.client.core.message.search
Retrieves full text index definition.
GetSearchIndexRequest(String, String, String) - Constructor for class com.couchbase.client.core.message.search.GetSearchIndexRequest
 
GetSearchIndexResponse - Class in com.couchbase.client.core.message.search
Carries full text index definition as a payload.
GetSearchIndexResponse(String, ResponseStatus) - Constructor for class com.couchbase.client.core.message.search.GetSearchIndexResponse
 
getStatus() - Method in interface com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheResponse
Returns the status of the response.
getStatus() - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.DefaultBinaryMemcacheResponse
 
getTotalBodyLength() - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
 
getTotalBodyLength() - Method in interface com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheMessage
Returns the total body length.
GetUsersRequest - Class in com.couchbase.client.core.message.config
Get a user or list of users.
GetUsersResponse - Class in com.couchbase.client.core.message.config
 
GetUsersResponse(String, ResponseStatus, CouchbaseRequest) - Constructor for class com.couchbase.client.core.message.config.GetUsersResponse
 

H

handle(Callback[]) - Method in class com.couchbase.client.core.endpoint.kv.KeyValueAuthHandler
Callback handler needed for the SaslClient which supplies username and password.
handlerAdded(ChannelHandlerContext) - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.AbstractMemcacheObjectAggregator
 
handlerRemoved(ChannelHandlerContext) - Method in class com.couchbase.client.core.endpoint.AbstractGenericHandler
 
handlerRemoved(ChannelHandlerContext) - Method in class com.couchbase.client.core.endpoint.analytics.AnalyticsHandler
 
handlerRemoved(ChannelHandlerContext) - Method in class com.couchbase.client.core.endpoint.config.ConfigHandler
 
handlerRemoved(ChannelHandlerContext) - Method in class com.couchbase.client.core.endpoint.query.QueryHandler
 
handlerRemoved(ChannelHandlerContext) - Method in class com.couchbase.client.core.endpoint.query.QueryHandlerV2
 
handlerRemoved(ChannelHandlerContext) - Method in class com.couchbase.client.core.endpoint.search.SearchHandler
 
handlerRemoved(ChannelHandlerContext) - Method in class com.couchbase.client.core.endpoint.view.ViewHandler
 
handlerRemoved(ChannelHandlerContext) - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.AbstractMemcacheObjectAggregator
 
hasBucket(String) - Method in interface com.couchbase.client.core.config.ClusterConfig
True if there is a bucket config with the given name, false otherwise.
hasBucket(String) - Method in class com.couchbase.client.core.config.DefaultClusterConfig
 
hasFastForwardMap() - Method in interface com.couchbase.client.core.config.BucketConfig
Returns true if the config has a fast forward map that describes what the topology of the cluster will be after the current rebalance operation completes.
hasFastForwardMap() - Method in class com.couchbase.client.core.config.CouchbasePartitionInfo
 
hasFastForwardMap() - Method in class com.couchbase.client.core.config.DefaultCouchbaseBucketConfig
 
hasFastForwardMap() - Method in class com.couchbase.client.core.config.DefaultMemcachedBucketConfig
 
hash(NodeInfo, int) - Method in class com.couchbase.client.core.node.DefaultMemcachedHashingStrategy
 
hash(NodeInfo, int) - Method in class com.couchbase.client.core.node.LegacyMemcachedHashingStrategy
 
hash(NodeInfo, int) - Method in interface com.couchbase.client.core.node.MemcachedHashingStrategy
The hash for each node based on the node information and repetition.
hash(NodeInfo, int) - Method in class com.couchbase.client.core.node.StandardMemcachedHashingStrategy
 
hashCode() - Method in class com.couchbase.client.core.config.DefaultAlternateAddress
 
hashCode() - Method in class com.couchbase.client.core.config.ProposedBucketConfigContext
 
hashCode() - Method in class com.couchbase.client.core.env.NetworkResolution
 
hashCode() - Method in class com.couchbase.client.core.message.kv.MutationToken
 
hashCode() - Method in class com.couchbase.client.core.message.kv.subdoc.multi.MultiResult
 
hashCode() - Method in class com.couchbase.client.core.message.ResponseStatusDetails
 
hashCode() - Method in class com.couchbase.client.core.metrics.NetworkLatencyMetricsIdentifier
 
hashCode() - Method in class com.couchbase.client.core.node.CouchbaseNode
 
hashCode() - Method in class com.couchbase.client.core.utils.NetworkAddress
 
hasInitialResponse() - Method in class com.couchbase.client.core.security.sasl.ShaSaslClient
 
hasObservers() - Method in class com.couchbase.client.core.utils.UnicastAutoReleaseSubject
 
hasPrimaryPartitionsOnNode(NetworkAddress) - Method in interface com.couchbase.client.core.config.CouchbaseBucketConfig
Checks if the given hostname has active primary partitions assigned to it.
hasPrimaryPartitionsOnNode(NetworkAddress) - Method in class com.couchbase.client.core.config.DefaultCouchbaseBucketConfig
 
hasSubscribers() - Method in class com.couchbase.client.core.event.DefaultEventBus
 
hasSubscribers() - Method in interface com.couchbase.client.core.event.EventBus
Checks if the event bus has subscribers.
hasSubscribers() - Method in class com.couchbase.client.core.state.AbstractStateMachine
 
hasSubscribers() - Method in interface com.couchbase.client.core.state.Stateful
Returns true if there are subscribers observing the state stream.
headers() - Method in class com.couchbase.client.core.message.config.RestApiRequest
 
headers() - Method in class com.couchbase.client.core.message.config.RestApiResponse
 
HealthPinger - Class in com.couchbase.client.core.utils
The HealthPinger allows to “ping” individual services with real operations for their health.
HealthPinger() - Constructor for class com.couchbase.client.core.utils.HealthPinger
 
host() - Method in class com.couchbase.client.core.event.system.NodeConnectedEvent
The host address of the connected node.
host() - Method in class com.couchbase.client.core.event.system.NodeDisconnectedEvent
The host address of the disconnected node.
host() - Method in class com.couchbase.client.core.message.config.BucketStreamingResponse
 
host() - Method in class com.couchbase.client.core.metrics.NetworkLatencyMetricsIdentifier
 
hostname() - Method in interface com.couchbase.client.core.config.AlternateAddress
The inet address of the node.
hostname() - Method in class com.couchbase.client.core.config.DefaultAlternateAddress
 
hostname() - Method in class com.couchbase.client.core.config.DefaultNodeInfo
 
hostname() - Method in class com.couchbase.client.core.config.DefaultPortInfo
 
hostname() - Method in interface com.couchbase.client.core.config.NodeInfo
The inet address of the node.
hostname() - Method in interface com.couchbase.client.core.config.PortInfo
 
hostname() - Method in class com.couchbase.client.core.message.config.BucketConfigRequest
 
hostname() - Method in class com.couchbase.client.core.message.internal.AddNodeRequest
 
hostname() - Method in class com.couchbase.client.core.message.internal.AddNodeResponse
 
hostname() - Method in class com.couchbase.client.core.message.internal.AddServiceRequest
 
hostname() - Method in class com.couchbase.client.core.message.internal.AddServiceResponse
 
hostname() - Method in class com.couchbase.client.core.message.internal.RemoveNodeRequest
 
hostname() - Method in class com.couchbase.client.core.message.internal.RemoveServiceRequest
 
hostname() - Method in class com.couchbase.client.core.message.kv.GetAllMutationTokensRequest
 
hostname() - Method in class com.couchbase.client.core.message.kv.GetBucketConfigRequest
Returns the hostname of the node from where the config should be loaded.
hostname() - Method in class com.couchbase.client.core.message.kv.GetBucketConfigResponse
 
hostname() - Method in class com.couchbase.client.core.message.kv.NoopRequest
 
hostname() - Method in class com.couchbase.client.core.message.kv.StatRequest
 
hostname() - Method in class com.couchbase.client.core.message.kv.StatResponse
 
hostname() - Method in class com.couchbase.client.core.node.CouchbaseNode
 
hostname() - Method in interface com.couchbase.client.core.node.Node
Returns the configured hostname for the Node.
hostname() - Method in class com.couchbase.client.core.utils.NetworkAddress
Returns the hostname for this network address.
hosts() - Method in class com.couchbase.client.core.utils.ConnectionString
Get the list of hosts that could be resolved
HTTP_ACCEPTED - Static variable in class com.couchbase.client.core.endpoint.ResponseStatusConverter
 
HTTP_BAD_REQUEST - Static variable in class com.couchbase.client.core.endpoint.ResponseStatusConverter
 
HTTP_CREATED - Static variable in class com.couchbase.client.core.endpoint.ResponseStatusConverter
 
HTTP_INTERNAL_ERROR - Static variable in class com.couchbase.client.core.endpoint.ResponseStatusConverter
 
HTTP_NOT_FOUND - Static variable in class com.couchbase.client.core.endpoint.ResponseStatusConverter
 
HTTP_OK - Static variable in class com.couchbase.client.core.endpoint.ResponseStatusConverter
 
HTTP_UNAUTHORIZED - Static variable in class com.couchbase.client.core.endpoint.ResponseStatusConverter
 
HttpLoader - Class in com.couchbase.client.core.config.loader
Loads a raw bucket configuration through the Couchbase Server HTTP config interface.
HttpLoader(ClusterFacade, CoreEnvironment) - Constructor for class com.couchbase.client.core.config.loader.HttpLoader
Creates a new HttpLoader.
HttpRefresher - Class in com.couchbase.client.core.config.refresher
Keeps the bucket config fresh through a HTTP streaming connection.
HttpRefresher(CoreEnvironment, ClusterFacade) - Constructor for class com.couchbase.client.core.config.refresher.HttpRefresher
 
httpStatus() - Method in class com.couchbase.client.core.message.config.RestApiResponse
 
httpStatusCode() - Method in class com.couchbase.client.core.message.analytics.RawAnalyticsResponse
 
httpStatusCode() - Method in class com.couchbase.client.core.message.query.RawQueryResponse
 
httpStatusMsg() - Method in class com.couchbase.client.core.message.analytics.RawAnalyticsResponse
 
httpStatusMsg() - Method in class com.couchbase.client.core.message.query.RawQueryResponse
 

I

id() - Method in interface com.couchbase.client.core.ClusterFacade
Deprecated.
Use ClusterFacade.ctx() which also contains the ID.
id() - Method in class com.couchbase.client.core.CouchbaseCore
 
id() - Method in class com.couchbase.client.core.message.internal.DiagnosticsReport
 
id() - Method in class com.couchbase.client.core.message.internal.DiagnosticsRequest
 
id() - Method in class com.couchbase.client.core.message.internal.EndpointHealth
 
id() - Method in class com.couchbase.client.core.message.internal.PingReport
 
id() - Method in class com.couchbase.client.core.message.internal.PingServiceHealth
 
identityMap(CouchbaseEvent) - Static method in class com.couchbase.client.core.utils.Events
Takes a CouchbaseEvent and returns a map with event information.
idleTime() - Method in class com.couchbase.client.core.env.AbstractServiceConfig
The time in seconds (minimum, approx) after when idle the socket will be closed.
ignoreActiveSpan() - Method in class com.couchbase.client.core.tracing.ThresholdLogSpanBuilder
 
INCREMENT - Static variable in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
INCREMENTQ - Static variable in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
incrementRetryCount() - Method in class com.couchbase.client.core.message.AbstractCouchbaseRequest
 
incrementRetryCount() - Method in interface com.couchbase.client.core.message.CouchbaseRequest
Returns the old retry count and increments it by one.
InetAddresses - Class in com.couchbase.client.core.utils
 
InetAddresses() - Constructor for class com.couchbase.client.core.utils.InetAddresses
 
info(Throwable) - Method in class com.couchbase.client.core.logging.AbstractCouchbaseLogger
 
info(String) - Method in interface com.couchbase.client.core.logging.CouchbaseLogger
Log a message at the INFO level.
info(String, Object) - Method in interface com.couchbase.client.core.logging.CouchbaseLogger
Log a message at the INFO level according to the specified format and argument.
info(String, Object, Object) - Method in interface com.couchbase.client.core.logging.CouchbaseLogger
Log a message at the INFO level according to the specified format and arguments.
info(String, Object...) - Method in interface com.couchbase.client.core.logging.CouchbaseLogger
Log a message at the INFO level according to the specified format and arguments.
info(String, Throwable) - Method in interface com.couchbase.client.core.logging.CouchbaseLogger
Log an exception (throwable) at the INFO level with an accompanying message.
info(Throwable) - Method in interface com.couchbase.client.core.logging.CouchbaseLogger
Log an exception (throwable) at the INFO level.
info() - Method in class com.couchbase.client.core.message.analytics.GenericAnalyticsResponse
Contains a single ByteBuf representing the JSON object of query execution metrics (or empty if metrics haven’t been activated).
info() - Method in class com.couchbase.client.core.message.query.GenericQueryResponse
Contains a single ByteBuf representing the JSON object of query execution metrics (or empty if metrics haven’t been activated).
info() - Method in class com.couchbase.client.core.message.view.ViewQueryResponse
 
initial() - Method in class com.couchbase.client.core.message.kv.CounterRequest
 
initialize(ByteBuf, ResponseStatus, CouchbaseRequest) - Method in class com.couchbase.client.core.endpoint.query.parser.YasjlQueryResponseParser
Initialize this parser for a response parsing cycle.
initialize(ByteBuf) - Method in class com.couchbase.client.core.utils.yasjl.ByteBufJsonParser
(re)initializes this parser with new content.
inject(SpanContext, Format<C>, C) - Method in class com.couchbase.client.core.tracing.ThresholdLogTracer
 
InsertBucketRequest - Class in com.couchbase.client.core.message.config
 
InsertBucketRequest(String, String, String) - Constructor for class com.couchbase.client.core.message.config.InsertBucketRequest
 
InsertBucketResponse - Class in com.couchbase.client.core.message.config
 
InsertBucketResponse(String, ResponseStatus) - Constructor for class com.couchbase.client.core.message.config.InsertBucketResponse
 
insertDocument() - Method in interface com.couchbase.client.core.message.kv.subdoc.BinarySubdocMutationRequest
Add document only if it does not exist
insertDocument(boolean) - Method in class com.couchbase.client.core.message.kv.subdoc.multi.SubMultiMutationDocOptionsBuilder
 
insertDocument() - Method in class com.couchbase.client.core.message.kv.subdoc.multi.SubMultiMutationDocOptionsBuilder
 
insertDocument() - Method in class com.couchbase.client.core.message.kv.subdoc.simple.AbstractSubdocMutationRequest
 
insertDocument(boolean) - Method in class com.couchbase.client.core.message.kv.subdoc.simple.AbstractSubdocMutationRequest
 
InsertRequest - Class in com.couchbase.client.core.message.kv
Insert a document.
InsertRequest(String, ByteBuf, String) - Constructor for class com.couchbase.client.core.message.kv.InsertRequest
Creates a new InsertRequest.
InsertRequest(String, ByteBuf, String, boolean) - Constructor for class com.couchbase.client.core.message.kv.InsertRequest
 
InsertRequest(String, ByteBuf, int, int, String, boolean) - Constructor for class com.couchbase.client.core.message.kv.InsertRequest
Creates a new InsertRequest.
InsertRequest(String, ByteBuf, int, int, String) - Constructor for class com.couchbase.client.core.message.kv.InsertRequest
 
InsertResponse - Class in com.couchbase.client.core.message.kv
Response to an InsertRequest.
InsertResponse(ResponseStatus, short, long, String, ByteBuf, MutationToken, CouchbaseRequest) - Constructor for class com.couchbase.client.core.message.kv.InsertResponse
 
INSTANCE - Static variable in class com.couchbase.client.core.message.internal.SignalConfigReload
 
INSTANCE - Static variable in class com.couchbase.client.core.message.internal.SignalFlush
 
INSTANCE - Static variable in class com.couchbase.client.core.node.DefaultMemcachedHashingStrategy
 
INSTANCE - Static variable in class com.couchbase.client.core.node.LegacyMemcachedHashingStrategy
 
INSTANCE - Static variable in class com.couchbase.client.core.node.StandardMemcachedHashingStrategy
 
INSTANCE - Static variable in class com.couchbase.client.core.retry.BestEffortRetryStrategy
A reusable instance of this strategy.
INSTANCE - Static variable in class com.couchbase.client.core.retry.FailFastRetryStrategy
A reusable instance of this strategy.
INSTANCE - Static variable in class com.couchbase.client.core.service.ServiceFactory
 
INSTANCE - Static variable in class com.couchbase.client.core.service.strategies.PartitionSelectionStrategy
 
instance() - Static method in class com.couchbase.client.core.tracing.RingBufferMonitor
 
instanceCounter() - Static method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
InterfaceAudience - Class in com.couchbase.client.core.annotations
Defines the intended audience for each entity.
InterfaceAudience() - Constructor for class com.couchbase.client.core.annotations.InterfaceAudience
 
InterfaceAudience.Private - Annotation Type in com.couchbase.client.core.annotations
Intended to be only used within this library.
InterfaceAudience.Public - Annotation Type in com.couchbase.client.core.annotations
Intended to be used by any project or application that depends on this library.
InterfaceStability - Class in com.couchbase.client.core.annotations
Defines the stability annotations for each public or private class.
InterfaceStability() - Constructor for class com.couchbase.client.core.annotations.InterfaceStability
 
InterfaceStability.Committed - Annotation Type in com.couchbase.client.core.annotations
The annotated entity is considered committed and can only break compatibility at a major release.
InterfaceStability.Experimental - Annotation Type in com.couchbase.client.core.annotations
The annotated entity is considered experimental and no guarantees can be given in terms of compatibility and stability.
InterfaceStability.Uncommitted - Annotation Type in com.couchbase.client.core.annotations
The annotated entity is considered stable, but compatibility can be broken at each minor release.
InternalRequest - Interface in com.couchbase.client.core.message.internal
Marker interface for all internal CouchbaseRequests that are potentially treated differently and with priority.
interval() - Method in class com.couchbase.client.core.endpoint.kv.ErrorMap.RetrySpecification
 
intPropertyOr(String, int) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
IO_POOL_SIZE - Static variable in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
ioPool() - Method in interface com.couchbase.client.core.env.CoreEnvironment
Returns the IO pool for the underlying IO framework, used as the default pool if not overridden for the individual services.
ioPool(EventLoopGroup) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Deprecated.
ioPool(EventLoopGroup, ShutdownHook) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Sets the I/O Pool implementation for the underlying IO framework, along with the action to execute when this environment is shut down.
ioPool() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
IoPoolShutdownHook - Class in com.couchbase.client.core.env.resources
IoPoolShutdownHook(EventLoopGroup) - Constructor for class com.couchbase.client.core.env.resources.IoPoolShutdownHook
 
ioPoolSize() - Method in interface com.couchbase.client.core.env.CoreEnvironment
Returns the configured IO pool size.
ioPoolSize(int) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Sets the pool size (number of threads to use) for I/O operations (default value is the number of CPUs).
ioPoolSize() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
isActive() - Method in class com.couchbase.client.core.endpoint.util.FailedChannel
 
isActive() - Method in class com.couchbase.client.core.message.AbstractCouchbaseRequest
 
isActive() - Method in interface com.couchbase.client.core.message.CouchbaseRequest
Checks if the request is unsubscribed on a timeout
isCompatible(EventLoop) - Method in class com.couchbase.client.core.endpoint.util.FailedChannel
 
isComplete() - Method in class com.couchbase.client.core.security.sasl.ShaSaslClient
 
isDebugEnabled() - Method in interface com.couchbase.client.core.logging.CouchbaseLogger
Is the logger instance enabled for the DEBUG level?
isDone() - Method in class com.couchbase.client.core.message.config.FlushResponse
 
isEnabled(CouchbaseLogLevel) - Method in class com.couchbase.client.core.logging.AbstractCouchbaseLogger
 
isEnabled(CouchbaseLogLevel) - Method in interface com.couchbase.client.core.logging.CouchbaseLogger
Is the logger instance enabled for the specified level?
isEnabled() - Method in class com.couchbase.client.core.metrics.AbstractMetricsCollector
 
isEnabled() - Method in interface com.couchbase.client.core.metrics.MetricsCollector
True if this collector actually emits something.
isErrorEnabled() - Method in interface com.couchbase.client.core.logging.CouchbaseLogger
Is the logger instance enabled for the ERROR level?
isEscaped(byte) - Method in class com.couchbase.client.core.endpoint.util.AbstractStringAwareBufProcessor
Detects opening and closing of JSON strings and keep track of it in order to mark characters in the string (delimiter quotes included) as escaped.
isFree() - Method in class com.couchbase.client.core.endpoint.AbstractEndpoint
 
isFree() - Method in interface com.couchbase.client.core.endpoint.Endpoint
If this endpoint is free to take a request.
isInetAddress(String) - Static method in class com.couchbase.client.core.utils.InetAddresses
 
isInfoEnabled() - Method in interface com.couchbase.client.core.logging.CouchbaseLogger
Is the logger instance enabled for the INFO level?
isInitialized() - Method in class com.couchbase.client.core.endpoint.query.parser.YasjlQueryResponseParser
True if this parser is currently initialized and ready to parse a response.
isJson() - Method in interface com.couchbase.client.core.message.kv.BinaryStoreRequest
 
isJson() - Method in class com.couchbase.client.core.message.kv.InsertRequest
 
isJson() - Method in class com.couchbase.client.core.message.kv.ReplaceRequest
 
isJson() - Method in class com.couchbase.client.core.message.kv.UpsertRequest
 
isJsonFormat() - Method in class com.couchbase.client.core.message.analytics.GenericAnalyticsRequest
 
isJsonFormat() - Method in class com.couchbase.client.core.message.query.GenericQueryRequest
 
isNumber(byte) - Static method in class com.couchbase.client.core.utils.yasjl.JsonParserUtils
 
isOpen() - Method in class com.couchbase.client.core.endpoint.util.FailedChannel
 
isPipelined() - Method in class com.couchbase.client.core.env.AbstractServiceConfig
If this service is pipelined (more than one request at the same time on the same socket).
isShutdown() - Method in class com.couchbase.client.core.env.CoreScheduler
 
isShutdown() - Method in class com.couchbase.client.core.env.resources.IoPoolShutdownHook
 
isShutdown() - Method in class com.couchbase.client.core.env.resources.NettyShutdownHook
 
isShutdown() - Method in class com.couchbase.client.core.env.resources.NoOpShutdownHook
 
isShutdown() - Method in interface com.couchbase.client.core.env.resources.ShutdownHook
 
isState(S) - Method in class com.couchbase.client.core.state.AbstractStateMachine
 
isState(S) - Method in interface com.couchbase.client.core.state.Stateful
Check if the given state is the same as the current one.
isSuccess() - Method in enum com.couchbase.client.core.message.ResponseStatus
Check if the current ResponseStatus is success.
isTraceEnabled() - Method in interface com.couchbase.client.core.logging.CouchbaseLogger
Is the logger instance enabled for the TRACE level?
isWarnEnabled() - Method in interface com.couchbase.client.core.logging.CouchbaseLogger
Is the logger instance enabled for the WARN level?

J

JdkLoggerFactory - Class in com.couchbase.client.core.logging
Logger factory which creates a java.util.logging logger.
JdkLoggerFactory() - Constructor for class com.couchbase.client.core.logging.JdkLoggerFactory
 
JSON_COLON - Static variable in class com.couchbase.client.core.utils.yasjl.JsonParserUtils
 
JSON_COMMA - Static variable in class com.couchbase.client.core.utils.yasjl.JsonParserUtils
 
JSON_ES - Static variable in class com.couchbase.client.core.utils.yasjl.JsonParserUtils
 
JSON_F - Static variable in class com.couchbase.client.core.utils.yasjl.JsonParserUtils
 
JSON_MINUS - Static variable in class com.couchbase.client.core.utils.yasjl.JsonParserUtils
 
JSON_N - Static variable in class com.couchbase.client.core.utils.yasjl.JsonParserUtils
 
JSON_PLUS - Static variable in class com.couchbase.client.core.utils.yasjl.JsonParserUtils
 
JSON_ST - Static variable in class com.couchbase.client.core.utils.yasjl.JsonParserUtils
 
JSON_T - Static variable in class com.couchbase.client.core.utils.yasjl.JsonParserUtils
 
JSON_ZERO - Static variable in class com.couchbase.client.core.utils.yasjl.JsonParserUtils
 
JsonArrayByteBufProcessor - Class in com.couchbase.client.core.utils.yasjl
Process JSON array
JsonArrayByteBufProcessor(JsonStringByteBufProcessor) - Constructor for class com.couchbase.client.core.utils.yasjl.JsonArrayByteBufProcessor
 
JsonBOMByteBufProcessor - Class in com.couchbase.client.core.utils.yasjl
Processes byte order mark.
JsonBOMByteBufProcessor() - Constructor for class com.couchbase.client.core.utils.yasjl.JsonBOMByteBufProcessor
 
JsonBooleanFalseByteBufProcessor - Class in com.couchbase.client.core.utils.yasjl
Processes JSON false value
JsonBooleanFalseByteBufProcessor() - Constructor for class com.couchbase.client.core.utils.yasjl.JsonBooleanFalseByteBufProcessor
 
JsonBooleanTrueByteBufProcessor - Class in com.couchbase.client.core.utils.yasjl
Processes JSON true value
JsonBooleanTrueByteBufProcessor() - Constructor for class com.couchbase.client.core.utils.yasjl.JsonBooleanTrueByteBufProcessor
 
JsonNullByteBufProcessor - Class in com.couchbase.client.core.utils.yasjl
Processes JSON null value
JsonNullByteBufProcessor() - Constructor for class com.couchbase.client.core.utils.yasjl.JsonNullByteBufProcessor
 
JsonNumberByteBufProcessor - Class in com.couchbase.client.core.utils.yasjl
Process JSON number
JsonNumberByteBufProcessor() - Constructor for class com.couchbase.client.core.utils.yasjl.JsonNumberByteBufProcessor
 
JsonObjectByteBufProcessor - Class in com.couchbase.client.core.utils.yasjl
Processes JSON object value
JsonObjectByteBufProcessor(JsonStringByteBufProcessor) - Constructor for class com.couchbase.client.core.utils.yasjl.JsonObjectByteBufProcessor
 
JsonParserUtils - Class in com.couchbase.client.core.utils.yasjl
 
JsonParserUtils() - Constructor for class com.couchbase.client.core.utils.yasjl.JsonParserUtils
 
JsonParserUtils.Mode - Enum in com.couchbase.client.core.utils.yasjl
 
JsonPointer - Class in com.couchbase.client.core.utils.yasjl
Represents a pointer in the JSON tree structure.
JsonPointer(String, JsonPointerCB) - Constructor for class com.couchbase.client.core.utils.yasjl.JsonPointer
Creates a new JsonPointer with a path and a callback.
JsonPointerCB - Interface in com.couchbase.client.core.utils.yasjl.Callbacks
 
JsonPointerCB1 - Interface in com.couchbase.client.core.utils.yasjl.Callbacks
 
JsonPointerCB2 - Interface in com.couchbase.client.core.utils.yasjl.Callbacks
 
JsonPointerTree - Class in com.couchbase.client.core.utils.yasjl
Represents a tree structure of stored JsonPointer.
jsonQuery(String, String, String, String) - Static method in class com.couchbase.client.core.message.analytics.GenericAnalyticsRequest
Create a GenericAnalyticsRequest and mark it as containing a full Analytics query in Json form (including additional query parameters).
jsonQuery(String, String, String, String, InetAddress) - Static method in class com.couchbase.client.core.message.analytics.GenericAnalyticsRequest
Create a GenericAnalyticsRequest and mark it as containing a full Analytics query in Json form (including additional query parameters).
jsonQuery(String, String, String) - Static method in class com.couchbase.client.core.message.analytics.RawAnalyticsRequest
Create a RawAnalyticsRequest containing a full Analytics query in Json form (including additional query parameters).
jsonQuery(String, String, String, String) - Static method in class com.couchbase.client.core.message.analytics.RawAnalyticsRequest
Create a RawAnalyticsRequest containing a full Analytics query in Json form (including additional query parameters).
jsonQuery(String, String, String, InetAddress) - Static method in class com.couchbase.client.core.message.analytics.RawAnalyticsRequest
Create a RawAnalyticsRequest containing a full Analytics query in Json form (including additional query parameters).
jsonQuery(String, String, String, String, InetAddress) - Static method in class com.couchbase.client.core.message.analytics.RawAnalyticsRequest
Create a RawAnalyticsRequest containing a full Analytics query in Json form (including additional query parameters).
jsonQuery(String, String, String, String) - Static method in class com.couchbase.client.core.message.query.GenericQueryRequest
Create a GenericQueryRequest and mark it as containing a full N1QL query in Json form (including additional query parameters like named arguments, etc…).
jsonQuery(String, String, String, String, String) - Static method in class com.couchbase.client.core.message.query.GenericQueryRequest
Create a GenericQueryRequest and mark it as containing a full N1QL query in Json form (including additional query parameters like named arguments, etc…).
jsonQuery(String, String, String, InetAddress, String) - Static method in class com.couchbase.client.core.message.query.GenericQueryRequest
Create a GenericQueryRequest and mark it as containing a full N1QL query in Json form (including additional query parameters like named arguments, etc…).
jsonQuery(String, String, String, String, InetAddress, String) - Static method in class com.couchbase.client.core.message.query.GenericQueryRequest
Create a GenericQueryRequest and mark it as containing a full N1QL query in Json form (including additional query parameters like named arguments, etc…).
jsonQuery(String, String, String, String) - Static method in class com.couchbase.client.core.message.query.RawQueryRequest
Create a RawQueryRequest containing a full N1QL query in Json form (including additional query parameters like named arguments, etc…).
jsonQuery(String, String, String, String, String) - Static method in class com.couchbase.client.core.message.query.RawQueryRequest
Create a RawQueryRequest containing a full N1QL query in Json form (including additional query parameters like named arguments, etc…).
jsonQuery(String, String, String, InetAddress, String) - Static method in class com.couchbase.client.core.message.query.RawQueryRequest
Create a RawQueryRequest containing a full N1QL query in Json form (including additional query parameters like named arguments, etc…).
jsonQuery(String, String, String, String, InetAddress, String) - Static method in class com.couchbase.client.core.message.query.RawQueryRequest
Create a RawQueryRequest containing a full N1QL query in Json form (including additional query parameters like named arguments, etc…).
jsonResponse() - Method in class com.couchbase.client.core.message.analytics.RawAnalyticsResponse
 
jsonResponse() - Method in class com.couchbase.client.core.message.query.RawQueryResponse
 
JsonStringByteBufProcessor - Class in com.couchbase.client.core.utils.yasjl
Processes JSON String value
JsonStringByteBufProcessor() - Constructor for class com.couchbase.client.core.utils.yasjl.JsonStringByteBufProcessor
 
JsonWhiteSpaceByteBufProcessor - Class in com.couchbase.client.core.utils.yasjl
Processes JSON ws
JsonWhiteSpaceByteBufProcessor() - Constructor for class com.couchbase.client.core.utils.yasjl.JsonWhiteSpaceByteBufProcessor
 

K

KeepAlive - Interface in com.couchbase.client.core.message
Marker interface to identify a request that handles a keepalive.
KEEPALIVE_ERROR_THRESHOLD - Static variable in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
KEEPALIVE_TIMEOUT - Static variable in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
keepAliveErrorThreshold() - Method in interface com.couchbase.client.core.env.CoreEnvironment
Specifies the number of times a KeepAlive message on a socket can fail before the connection is recycled.
keepAliveErrorThreshold(long) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Allows to customize the errors on keepalive messages threshold after which the connection will be recycled.
keepAliveErrorThreshold() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
keepAliveInterval() - Method in interface com.couchbase.client.core.env.CoreEnvironment
The time in milliseconds after which some service will issue a form of keep-alive request.
keepAliveInterval(long) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Sets the time of inactivity, in milliseconds, after which some services will issue a form of keep-alive request to their corresponding server/nodes (default is 30s, values <= 0 deactivate the idle check).
KEEPALIVEINTERVAL - Static variable in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
keepAliveInterval() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
KeepAliveRequest() - Constructor for class com.couchbase.client.core.endpoint.analytics.AnalyticsHandler.KeepAliveRequest
 
KeepAliveRequest() - Constructor for class com.couchbase.client.core.endpoint.kv.KeyValueHandler.KeepAliveRequest
 
KeepAliveRequest() - Constructor for class com.couchbase.client.core.endpoint.query.QueryHandler.KeepAliveRequest
 
KeepAliveRequest() - Constructor for class com.couchbase.client.core.endpoint.query.QueryHandlerV2.KeepAliveRequest
 
KeepAliveRequest() - Constructor for class com.couchbase.client.core.endpoint.search.SearchHandler.KeepAliveRequest
 
KeepAliveRequest() - Constructor for class com.couchbase.client.core.endpoint.view.ViewHandler.KeepAliveRequest
 
KeepAliveResponse(ResponseStatus, CouchbaseRequest) - Constructor for class com.couchbase.client.core.endpoint.analytics.AnalyticsHandler.KeepAliveResponse
 
KeepAliveResponse(ResponseStatus, short, CouchbaseRequest) - Constructor for class com.couchbase.client.core.endpoint.kv.KeyValueHandler.KeepAliveResponse
 
KeepAliveResponse(ResponseStatus, CouchbaseRequest) - Constructor for class com.couchbase.client.core.endpoint.query.QueryHandler.KeepAliveResponse
 
KeepAliveResponse(ResponseStatus, CouchbaseRequest) - Constructor for class com.couchbase.client.core.endpoint.query.QueryHandlerV2.KeepAliveResponse
 
KeepAliveResponse(ResponseStatus, CouchbaseRequest) - Constructor for class com.couchbase.client.core.endpoint.search.SearchHandler.KeepAliveResponse
 
KeepAliveResponse(ResponseStatus, CouchbaseRequest) - Constructor for class com.couchbase.client.core.endpoint.view.ViewHandler.KeepAliveResponse
 
keepAliveTimeout() - Method in interface com.couchbase.client.core.env.CoreEnvironment
Specifies the timeout of a keepalive operation on the socket in milliseconds.
keepAliveTimeout(long) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Allows to customize the timeout used for keepalive operations.
keepAliveTimeout() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
ketamaNodes() - Method in class com.couchbase.client.core.config.DefaultMemcachedBucketConfig
 
ketamaNodes() - Method in interface com.couchbase.client.core.config.MemcachedBucketConfig
 
key() - Method in class com.couchbase.client.core.message.kv.AbstractKeyValueRequest
 
key() - Method in interface com.couchbase.client.core.message.kv.BinaryRequest
The key of the document.
key() - Method in class com.couchbase.client.core.message.kv.StatResponse
 
KEY_DECODE_MICROS - Static variable in class com.couchbase.client.core.tracing.ThresholdLogReporter
 
KEY_DISPATCH_MICROS - Static variable in class com.couchbase.client.core.tracing.ThresholdLogReporter
 
KEY_EEXISTS - Static variable in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheResponseStatus
 
KEY_ENCODE_MICROS - Static variable in class com.couchbase.client.core.tracing.ThresholdLogReporter
 
KEY_ENOENT - Static variable in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheResponseStatus
 
KEY_SERVER_MICROS - Static variable in class com.couchbase.client.core.tracing.ThresholdLogReporter
 
KEY_TOTAL_MICROS - Static variable in class com.couchbase.client.core.tracing.ThresholdLogReporter
 
keyBytes() - Method in class com.couchbase.client.core.message.kv.AbstractKeyValueRequest
 
keyBytes() - Method in interface com.couchbase.client.core.message.kv.BinaryRequest
The raw byte representation of the key.
keys() - Method in class com.couchbase.client.core.message.view.ViewQueryRequest
 
KEYVALUE_ENDPOINTS - Static variable in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
KeyValueAuthHandler - Class in com.couchbase.client.core.endpoint.kv
A SASL Client which communicates through the memcache binary protocol.
KeyValueAuthHandler(String, String, boolean) - Constructor for class com.couchbase.client.core.endpoint.kv.KeyValueAuthHandler
Creates a new KeyValueAuthHandler.
KeyValueEndpoint - Class in com.couchbase.client.core.endpoint.kv
This endpoint defines the pipeline for binary requests and responses.
KeyValueEndpoint(String, String, String, int, CoreContext) - Constructor for class com.couchbase.client.core.endpoint.kv.KeyValueEndpoint
Deprecated.
KeyValueEndpoint(String, String, String, String, int, CoreContext) - Constructor for class com.couchbase.client.core.endpoint.kv.KeyValueEndpoint
Create a new KeyValueEndpoint.
KeyValueErrorMapHandler - Class in com.couchbase.client.core.endpoint.kv
This handler is added dynamically by the KeyValueFeatureHandler to load and store the extended error map from the server.
KeyValueErrorMapHandler() - Constructor for class com.couchbase.client.core.endpoint.kv.KeyValueErrorMapHandler
 
KeyValueFeatureHandler - Class in com.couchbase.client.core.endpoint.kv
This handler negotiates the enabled features through the HELLO command.
KeyValueFeatureHandler(CoreContext) - Constructor for class com.couchbase.client.core.endpoint.kv.KeyValueFeatureHandler
 
KeyValueHandler - Class in com.couchbase.client.core.endpoint.kv
The KeyValueHandler is responsible for encoding BinaryRequests into lower level BinaryMemcacheRequests as well as decoding FullBinaryMemcacheResponses into CouchbaseResponses.
KeyValueHandler(AbstractEndpoint, EventSink<ResponseEvent>, boolean, boolean) - Constructor for class com.couchbase.client.core.endpoint.kv.KeyValueHandler
Creates a new KeyValueHandler with the default queue for requests.
KeyValueHandler.KeepAliveRequest - Class in com.couchbase.client.core.endpoint.kv
 
KeyValueHandler.KeepAliveResponse - Class in com.couchbase.client.core.endpoint.kv
 
KeyValueLocator - Class in com.couchbase.client.core.node.locate
This Locator finds the proper Nodes for every incoming BinaryRequest.
KeyValueLocator() - Constructor for class com.couchbase.client.core.node.locate.KeyValueLocator
 
KeyValueSelectBucketHandler - Class in com.couchbase.client.core.endpoint.kv
A Select bucket handler required for Spock cluster
KeyValueSelectBucketHandler(String) - Constructor for class com.couchbase.client.core.endpoint.kv.KeyValueSelectBucketHandler
KeyValueService - Class in com.couchbase.client.core.service
 
KeyValueService(String, String, String, int, CoreContext) - Constructor for class com.couchbase.client.core.service.KeyValueService
Deprecated.
KeyValueService(String, String, String, String, int, CoreContext) - Constructor for class com.couchbase.client.core.service.KeyValueService
Creates a new KeyValueService.
keyValueServiceConfig(KeyValueServiceConfig) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Allows to set a custom configuration for the KV service.
KeyValueServiceConfig - Class in com.couchbase.client.core.env
 
KeyValueStatus - Enum in com.couchbase.client.core.endpoint.kv
Enum describing all known response status codes that could be seen on the KeyValue protocol.
kvEndpoints() - Method in interface com.couchbase.client.core.env.CoreEnvironment
The number of key/value service endpoints.
kvEndpoints(int) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
kvEndpoints() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
kvIoPool() - Method in interface com.couchbase.client.core.env.CoreEnvironment
If set returns the IO Pool for the KV service, if not returns null.
kvIoPool(EventLoopGroup, ShutdownHook) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Sets the KV I/O Pool implementation for the underlying IO framework, along with the action to execute when this environment is shut down.
kvIoPool() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
kvServiceConfig() - Method in interface com.couchbase.client.core.env.CoreEnvironment
Returns the current KeyValueService configuration.
kvServiceConfig() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
kvThreshold(long, TimeUnit) - Method in class com.couchbase.client.core.tracing.ThresholdLogReporter.Builder
Allows to customize the kvThreshold.

L

lastActivity() - Method in class com.couchbase.client.core.message.internal.EndpointHealth
 
lastLocalId() - Method in class com.couchbase.client.core.message.AbstractCouchbaseRequest
 
lastLocalId(String) - Method in class com.couchbase.client.core.message.AbstractCouchbaseRequest
 
lastLocalId() - Method in interface com.couchbase.client.core.message.CouchbaseRequest
 
lastLocalId(String) - Method in interface com.couchbase.client.core.message.CouchbaseRequest
 
lastLocalSocket() - Method in class com.couchbase.client.core.message.AbstractCouchbaseRequest
 
lastLocalSocket(String) - Method in class com.couchbase.client.core.message.AbstractCouchbaseRequest
 
lastLocalSocket() - Method in interface com.couchbase.client.core.message.CouchbaseRequest
 
lastLocalSocket(String) - Method in interface com.couchbase.client.core.message.CouchbaseRequest
 
LastMemcacheContent - Interface in com.couchbase.client.deps.io.netty.handler.codec.memcache
The MemcacheContent which signals the end of the content batch.
lastPersistedSeqNo() - Method in class com.couchbase.client.core.message.kv.FailoverObserveSeqnoResponse
 
lastPersistedSeqNo() - Method in class com.couchbase.client.core.message.kv.NoFailoverObserveSeqnoResponse
 
lastRemoteSocket() - Method in class com.couchbase.client.core.message.AbstractCouchbaseRequest
 
lastRemoteSocket(String) - Method in class com.couchbase.client.core.message.AbstractCouchbaseRequest
 
lastRemoteSocket() - Method in interface com.couchbase.client.core.message.CouchbaseRequest
 
lastRemoteSocket(String) - Method in interface com.couchbase.client.core.message.CouchbaseRequest
 
lastResponse() - Method in class com.couchbase.client.core.endpoint.AbstractEndpoint
 
lastResponse() - Method in interface com.couchbase.client.core.endpoint.Endpoint
Returns the timestamp of the last response completed.
lastSeqNoReceived() - Method in class com.couchbase.client.core.message.kv.FailoverObserveSeqnoResponse
 
latencies() - Method in class com.couchbase.client.core.event.metrics.LatencyMetricsEvent
Returns all latency metrics per unique identifier.
latency() - Method in class com.couchbase.client.core.message.internal.PingServiceHealth
 
LatencyMetric - Class in com.couchbase.client.core.event.metrics
A latency metric value object which contains percentile and other related information.
LatencyMetric(long, long, long, Map<Double, Long>, TimeUnit) - Constructor for class com.couchbase.client.core.event.metrics.LatencyMetric
 
LatencyMetricsCollector<I extends LatencyMetricsIdentifier> - Interface in com.couchbase.client.core.metrics
A collector which collects and emits latency measurements.
LatencyMetricsCollectorConfig - Interface in com.couchbase.client.core.metrics
Additional configuration for the latency metrics collector.
LatencyMetricsEvent<I extends LatencyMetricsIdentifier> - Class in com.couchbase.client.core.event.metrics
A common base class for latency metric events.
LatencyMetricsEvent(Map<I, LatencyMetric>) - Constructor for class com.couchbase.client.core.event.metrics.LatencyMetricsEvent
 
LatencyMetricsIdentifier - Interface in com.couchbase.client.core.metrics
A class which uniquely identifies a latency metric.
LegacyMemcachedHashingStrategy - Class in com.couchbase.client.core.node
The legacy memcache bucket hashing strategy, compatible with Java SDK 1.x.
LifecycleState - Enum in com.couchbase.client.core.state
Represents common lifecycle states of components.
linear(TimeUnit) - Static method in class com.couchbase.client.core.time.Delay
Creates a new LinearDelay with no bounds and default factor.
linear(TimeUnit, long) - Static method in class com.couchbase.client.core.time.Delay
Creates a new LinearDelay with a custom upper boundary and the default factor.
linear(TimeUnit, long, long) - Static method in class com.couchbase.client.core.time.Delay
Creates a new LinearDelay with a custom boundaries and the default factor.
linear(TimeUnit, long, long, long) - Static method in class com.couchbase.client.core.time.Delay
Creates a new LinearDelay with a custom boundaries and factor.
LinearDelay - Class in com.couchbase.client.core.time
Delay which increases linearly for every attempt.
loadConfig(NetworkAddress, String, String) - Method in class com.couchbase.client.core.config.loader.AbstractLoader
Initiate the config loading process.
loadConfig(NetworkAddress, String, String, String) - Method in class com.couchbase.client.core.config.loader.AbstractLoader
Initiate the config loading process.
loadConfig(NetworkAddress, String, String) - Method in interface com.couchbase.client.core.config.loader.Loader
Deprecated.
loadConfig(NetworkAddress, String, String, String) - Method in interface com.couchbase.client.core.config.loader.Loader
 
Loader - Interface in com.couchbase.client.core.config.loader
 
LoaderType - Enum in com.couchbase.client.core.config
.
local() - Method in class com.couchbase.client.core.message.internal.EndpointHealth
 
local() - Method in class com.couchbase.client.core.message.internal.PingServiceHealth
 
localAddress0() - Method in class com.couchbase.client.core.endpoint.util.FailedChannel
 
localhost() - Static method in class com.couchbase.client.core.utils.NetworkAddress
Creates a new NetworkAddress for loopback.
localSocket() - Method in class com.couchbase.client.core.message.analytics.PingRequest
 
localSocket(SocketAddress) - Method in class com.couchbase.client.core.message.analytics.PingRequest
 
localSocket() - Method in interface com.couchbase.client.core.message.DiagnosticRequest
 
localSocket(SocketAddress) - Method in interface com.couchbase.client.core.message.DiagnosticRequest
 
localSocket() - Method in class com.couchbase.client.core.message.kv.NoopRequest
 
localSocket(SocketAddress) - Method in class com.couchbase.client.core.message.kv.NoopRequest
 
localSocket() - Method in class com.couchbase.client.core.message.query.PingRequest
 
localSocket(SocketAddress) - Method in class com.couchbase.client.core.message.query.PingRequest
 
localSocket() - Method in class com.couchbase.client.core.message.search.PingRequest
 
localSocket(SocketAddress) - Method in class com.couchbase.client.core.message.search.PingRequest
 
localSocket() - Method in class com.couchbase.client.core.message.view.PingRequest
 
localSocket(SocketAddress) - Method in class com.couchbase.client.core.message.view.PingRequest
 
locate(CouchbaseRequest) - Method in class com.couchbase.client.core.node.DefaultServiceRegistry
 
locate(CouchbaseRequest) - Method in interface com.couchbase.client.core.node.ServiceRegistry
 
locateAndDispatch(CouchbaseRequest, List<Node>, ClusterConfig, CoreEnvironment, RingBuffer<ResponseEvent>) - Method in class com.couchbase.client.core.node.locate.ConfigLocator
 
locateAndDispatch(CouchbaseRequest, List<Node>, ClusterConfig, CoreEnvironment, RingBuffer<ResponseEvent>) - Method in class com.couchbase.client.core.node.locate.KeyValueLocator
 
locateAndDispatch(CouchbaseRequest, List<Node>, ClusterConfig, CoreEnvironment, RingBuffer<ResponseEvent>) - Method in interface com.couchbase.client.core.node.locate.Locator
Given with the environment and node information, the implementation locates the right set of nodes and dispatches the request into them.
locateAndDispatch(CouchbaseRequest, List<Node>, ClusterConfig, CoreEnvironment, RingBuffer<ResponseEvent>) - Method in class com.couchbase.client.core.node.locate.QueryLocator
 
locateAndDispatch(CouchbaseRequest, List<Node>, ClusterConfig, CoreEnvironment, RingBuffer<ResponseEvent>) - Method in class com.couchbase.client.core.node.locate.ViewLocator
 
locator() - Method in class com.couchbase.client.core.config.AbstractBucketConfig
 
locator() - Method in interface com.couchbase.client.core.config.BucketConfig
The type of node locator in use for this bucket.
Locator - Interface in com.couchbase.client.core.node.locate
 
locator(CouchbaseRequest) - Method in class com.couchbase.client.core.RequestHandler
Helper method to detect the correct locator for the given request type.
lock() - Method in class com.couchbase.client.core.message.kv.GetRequest
 
log(CouchbaseLogLevel, String, Throwable) - Method in class com.couchbase.client.core.logging.AbstractCouchbaseLogger
 
log(CouchbaseLogLevel, Throwable) - Method in class com.couchbase.client.core.logging.AbstractCouchbaseLogger
 
log(CouchbaseLogLevel, String) - Method in class com.couchbase.client.core.logging.AbstractCouchbaseLogger
 
log(CouchbaseLogLevel, String, Object) - Method in class com.couchbase.client.core.logging.AbstractCouchbaseLogger
 
log(CouchbaseLogLevel, String, Object, Object) - Method in class com.couchbase.client.core.logging.AbstractCouchbaseLogger
 
log(CouchbaseLogLevel, String, Object...) - Method in class com.couchbase.client.core.logging.AbstractCouchbaseLogger
 
log(CouchbaseLogLevel, String) - Method in interface com.couchbase.client.core.logging.CouchbaseLogger
Log a message at the specified level.
log(CouchbaseLogLevel, String, Object) - Method in interface com.couchbase.client.core.logging.CouchbaseLogger
Log a message at the specified level according to the specified format and argument.
log(CouchbaseLogLevel, String, Object, Object) - Method in interface com.couchbase.client.core.logging.CouchbaseLogger
Log a message at the specified level according to the specified format and arguments.
log(CouchbaseLogLevel, String, Object...) - Method in interface com.couchbase.client.core.logging.CouchbaseLogger
Log a message at the specified level according to the specified format and arguments.
log(CouchbaseLogLevel, String, Throwable) - Method in interface com.couchbase.client.core.logging.CouchbaseLogger
Log an exception (throwable) at the specified level with an accompanying message.
log(CouchbaseLogLevel, Throwable) - Method in interface com.couchbase.client.core.logging.CouchbaseLogger
Log an exception (throwable) at the specified level.
log(Map<String, ?>) - Method in class com.couchbase.client.core.tracing.ThresholdLogSpan
 
log(String) - Method in class com.couchbase.client.core.tracing.ThresholdLogSpan
 
log(long, Map<String, ?>) - Method in class com.couchbase.client.core.tracing.ThresholdLogSpan
 
log(long, String) - Method in class com.couchbase.client.core.tracing.ThresholdLogSpan
 
Log4JLoggerFactory - Class in com.couchbase.client.core.logging
Logger factory which creates an Apache Log4J logger.
Log4JLoggerFactory() - Constructor for class com.couchbase.client.core.logging.Log4JLoggerFactory
 
LoggingConsumer - Class in com.couchbase.client.core.event.consumers
Consumes CouchbaseEvents and logs them.
LoggingConsumer.OutputFormat - Enum in com.couchbase.client.core.event.consumers
The target output format to log.
logIdent(Channel, Endpoint) - Static method in class com.couchbase.client.core.endpoint.AbstractEndpoint
Simple log helper to give logs a common prefix.
logIdent(ChannelHandlerContext, Endpoint) - Static method in class com.couchbase.client.core.endpoint.AbstractGenericHandler
Simple log helper to give logs a common prefix.
logIdent(NetworkAddress) - Static method in class com.couchbase.client.core.node.CouchbaseNode
Simple log helper to give logs a common prefix.
logIdent(String, Service) - Static method in class com.couchbase.client.core.service.AbstractDynamicService
Simple log helper to give logs a common prefix.
logInterval(long, TimeUnit) - Method in class com.couchbase.client.core.tracing.DefaultOrphanResponseReporter.Builder
Allows to customize the log interval.
logInterval(long, TimeUnit) - Method in class com.couchbase.client.core.tracing.ThresholdLogReporter.Builder
Allows to customize the log interval.
longPropertyOr(String, long) - Static method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
Lookup - Enum in com.couchbase.client.core.message.kv.subdoc.multi
Enumeration of possible mutations inside a sub-document LookupCommand.
lookup() - Method in class com.couchbase.client.core.message.kv.subdoc.multi.LookupCommand
 
lookup() - Method in class com.couchbase.client.core.message.kv.subdoc.multi.LookupCommandBuilder
 
LookupCommand - Class in com.couchbase.client.core.message.kv.subdoc.multi
A single lookup description inside a TODO.
LookupCommand(Lookup, String) - Constructor for class com.couchbase.client.core.message.kv.subdoc.multi.LookupCommand
Deprecated.
LookupCommand(LookupCommandBuilder) - Constructor for class com.couchbase.client.core.message.kv.subdoc.multi.LookupCommand
 
LookupCommandBuilder - Class in com.couchbase.client.core.message.kv.subdoc.multi
Builder for LookupCommand
LookupCommandBuilder(Lookup, String) - Constructor for class com.couchbase.client.core.message.kv.subdoc.multi.LookupCommandBuilder
Create a multi-lookup command.

M

mapping() - Method in class com.couchbase.client.core.service.AbstractDynamicService
 
mapping() - Method in class com.couchbase.client.core.service.PooledService
 
mapping() - Method in interface com.couchbase.client.core.service.Service
Returns the mapping for the given Service.
mapping() - Method in enum com.couchbase.client.core.service.ServiceType
 
markTainted(BucketConfig) - Method in class com.couchbase.client.core.config.refresher.CarrierRefresher
 
markTainted(BucketConfig) - Method in class com.couchbase.client.core.config.refresher.HttpRefresher
 
markTainted(BucketConfig) - Method in interface com.couchbase.client.core.config.refresher.Refresher
Marks the given bucket as tainted.
markUntainted(BucketConfig) - Method in class com.couchbase.client.core.config.refresher.CarrierRefresher
 
markUntainted(BucketConfig) - Method in class com.couchbase.client.core.config.refresher.HttpRefresher
 
markUntainted(BucketConfig) - Method in interface com.couchbase.client.core.config.refresher.Refresher
Mark the given bucket as not tainted.
master() - Method in class com.couchbase.client.core.config.DefaultPartition
 
master() - Method in interface com.couchbase.client.core.config.Partition
Returns the master node index for this partition.
master() - Method in class com.couchbase.client.core.message.kv.FailoverObserveSeqnoResponse
 
master() - Method in class com.couchbase.client.core.message.kv.NoFailoverObserveSeqnoResponse
 
master() - Method in class com.couchbase.client.core.message.kv.ObserveRequest
 
master() - Method in class com.couchbase.client.core.message.kv.ObserveResponse
 
master() - Method in class com.couchbase.client.core.message.kv.ObserveSeqnoRequest
 
MathUtils - Class in com.couchbase.client.core.utils
Various math utility methods, also backports from later JDK versions.
MathUtils() - Constructor for class com.couchbase.client.core.utils.MathUtils
 
max() - Method in class com.couchbase.client.core.event.metrics.LatencyMetric
The maximum latency recorded in the interval.
MAX_REQUEST_LIFETIME - Static variable in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
maxAllowedInstances() - Static method in class com.couchbase.client.core.env.DefaultCoreEnvironment
Returns the number of maximal allowed instances before warning log will be emitted.
maxAllowedInstances(int) - Static method in class com.couchbase.client.core.env.DefaultCoreEnvironment
Allows to set the maximum allowed instances to higher than 1 to silence warning logs in environments where it can be disregarded.
maxDuration() - Method in class com.couchbase.client.core.endpoint.kv.ErrorMap.RetrySpecification
 
maxEndpoints() - Method in class com.couchbase.client.core.env.AbstractServiceConfig
The maximum endpoints per node which will be established.
maxRequestLifetime() - Method in interface com.couchbase.client.core.env.CoreEnvironment
Returns the maximum time in milliseconds a request is allowed to life.
maxRequestLifetime(long) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Sets the maximum time in milliseconds a request is allowed to live.
maxRequestLifetime() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
maxRetryDuration(long) - Method in class com.couchbase.client.core.message.AbstractCouchbaseRequest
 
maxRetryDuration() - Method in class com.couchbase.client.core.message.AbstractCouchbaseRequest
 
maxRetryDuration(long) - Method in interface com.couchbase.client.core.message.CouchbaseRequest
Sets the maximum retry duration for the request.
maxRetryDuration() - Method in interface com.couchbase.client.core.message.CouchbaseRequest
Returns the maximum retry duration for the request.
MEM_BEAN - Static variable in class com.couchbase.client.core.env.Diagnostics
 
MemcacheContent - Interface in com.couchbase.client.deps.io.netty.handler.codec.memcache
An Memcache content chunk.
MEMCACHED_HASHING_STRATEGY - Static variable in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
MemcachedBucketConfig - Interface in com.couchbase.client.core.config
A configuration representing a memcached bucket.
memcachedHashingStrategy() - Method in interface com.couchbase.client.core.env.ConfigParserEnvironment
Allows to specify a custom strategy to hash memcached bucket documents.
memcachedHashingStrategy(MemcachedHashingStrategy) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Sets a custom memcached node hashing strategy, mainly used for compatibility with other clients.
memcachedHashingStrategy() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
MemcachedHashingStrategy - Interface in com.couchbase.client.core.node
This interface defines different hashing strategies used for ketama hashing in memcached buckets.
MemcacheMessage - Interface in com.couchbase.client.deps.io.netty.handler.codec.memcache
Marker interface for both ascii and binary messages.
MemcacheObject - Interface in com.couchbase.client.deps.io.netty.handler.codec.memcache
Defines a common interface for all MemcacheObject implementations.
memInfo(Map<String, Object>) - Static method in class com.couchbase.client.core.env.Diagnostics
Collects system information as delivered from the MemoryMXBean.
message() - Method in class com.couchbase.client.core.logging.RedactableArgument
The message of this redactable argument.
message() - Method in class com.couchbase.client.core.message.config.UpsertUserResponse
 
meta(Object) - Static method in class com.couchbase.client.core.logging.RedactableArgument
A redactable argument of meta data.
metadata() - Method in class com.couchbase.client.core.endpoint.util.FailedChannel
 
method() - Method in class com.couchbase.client.core.message.config.RestApiRequest
 
MetricsCollector - Interface in com.couchbase.client.core.metrics
A generic metrics collector.
MetricsCollectorConfig - Interface in com.couchbase.client.core.metrics
A generic configuration for a metrics collector.
min() - Method in class com.couchbase.client.core.event.metrics.LatencyMetric
The minimum latency recorded in the interval.
MIN_COMPRESSION_RATIO - Static variable in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
MIN_COMPRESSION_SIZE - Static variable in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
minEndpoints() - Method in class com.couchbase.client.core.env.AbstractServiceConfig
The minimum endpoints per node which will always be established.
MINIMUM_WINDOW_FOR_CLIENTID_TOKEN - Static variable in class com.couchbase.client.core.endpoint.analytics.AnalyticsHandler
This is a window of characters allowing to detect the clientContextID token (including room for JSON separators, etc…).
MINIMUM_WINDOW_FOR_CLIENTID_TOKEN - Static variable in class com.couchbase.client.core.endpoint.query.QueryHandler
This is a window of characters allowing to detect the clientContextID token (including room for JSON separators, etc…).
MultiLookupResponse - Class in com.couchbase.client.core.message.kv.subdoc.multi
The response for a BinarySubdocMultiLookupRequest.
MultiLookupResponse(ResponseStatus, short, String, List<MultiResult<Lookup>>, BinarySubdocMultiLookupRequest, long) - Constructor for class com.couchbase.client.core.message.kv.subdoc.multi.MultiLookupResponse
 
MultiMutationResponse - Class in com.couchbase.client.core.message.kv.subdoc.multi
MultiMutationResponse(ResponseStatus, short, String, int, short, BinarySubdocMultiMutationRequest, long, MutationToken) - Constructor for class com.couchbase.client.core.message.kv.subdoc.multi.MultiMutationResponse
Creates a MultiMutationResponse that failed at subdocument level.
MultiMutationResponse(ResponseStatus, short, String, BinarySubdocMultiMutationRequest, long, MutationToken) - Constructor for class com.couchbase.client.core.message.kv.subdoc.multi.MultiMutationResponse
Creates a unsuccessful MultiMutationResponse that failed at document level.
MultiMutationResponse(String, BinarySubdocMultiMutationRequest, long, MutationToken, List<MultiResult<Mutation>>) - Constructor for class com.couchbase.client.core.message.kv.subdoc.multi.MultiMutationResponse
Creates an successful MultiMutationResponse.
MultiResult<OPERATION> - Class in com.couchbase.client.core.message.kv.subdoc.multi
The result corresponding to an individual LookupCommand or MutationCommand.
Mutation - Enum in com.couchbase.client.core.message.kv.subdoc.multi
Enumeration of possible mutations inside a sub-document MutationCommand.
mutation() - Method in class com.couchbase.client.core.message.kv.subdoc.multi.MutationCommand
 
mutation() - Method in class com.couchbase.client.core.message.kv.subdoc.multi.MutationCommandBuilder
 
MUTATION_TOKENS_ENABLED - Static variable in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
mutationCas() - Method in exception com.couchbase.client.core.DocumentConcurrentlyModifiedException
 
mutationCas() - Method in exception com.couchbase.client.core.DocumentMutationLostException
 
mutationCas() - Method in interface com.couchbase.client.core.OriginalMutationResult
If the originating operation used to be a mutation and was successful, this getter allows to retrieve the cas value returned.
mutationCas() - Method in exception com.couchbase.client.core.ReplicaNotAvailableException
 
mutationCas() - Method in exception com.couchbase.client.core.ReplicaNotConfiguredException
 
MutationCommand - Class in com.couchbase.client.core.message.kv.subdoc.multi
A single mutation description inside a BinarySubdocMultiMutationRequest.
MutationCommand(Mutation, String, ByteBuf, boolean) - Constructor for class com.couchbase.client.core.message.kv.subdoc.multi.MutationCommand
Deprecated.
MutationCommand(Mutation, String, ByteBuf) - Constructor for class com.couchbase.client.core.message.kv.subdoc.multi.MutationCommand
Deprecated.
MutationCommand(Mutation, String) - Constructor for class com.couchbase.client.core.message.kv.subdoc.multi.MutationCommand
Deprecated.
MutationCommand(MutationCommandBuilder) - Constructor for class com.couchbase.client.core.message.kv.subdoc.multi.MutationCommand
Create a multi-mutation command.
MutationCommandBuilder - Class in com.couchbase.client.core.message.kv.subdoc.multi
Builder for MutationCommand.
MutationCommandBuilder(Mutation, String) - Constructor for class com.couchbase.client.core.message.kv.subdoc.multi.MutationCommandBuilder
Create a multi-mutation command.
MutationCommandBuilder(Mutation, String, ByteBuf) - Constructor for class com.couchbase.client.core.message.kv.subdoc.multi.MutationCommandBuilder
Create a multi-mutation command.
mutationToken() - Method in class com.couchbase.client.core.message.kv.AppendResponse
 
mutationToken() - Method in class com.couchbase.client.core.message.kv.CounterResponse
 
mutationToken() - Method in class com.couchbase.client.core.message.kv.InsertResponse
 
MutationToken - Class in com.couchbase.client.core.message.kv
Value object to contain vbucket UUID and sequence number.
MutationToken(long, long, long, String) - Constructor for class com.couchbase.client.core.message.kv.MutationToken
 
mutationToken() - Method in class com.couchbase.client.core.message.kv.PrependResponse
 
mutationToken() - Method in class com.couchbase.client.core.message.kv.RemoveResponse
 
mutationToken() - Method in class com.couchbase.client.core.message.kv.ReplaceResponse
 
mutationToken() - Method in class com.couchbase.client.core.message.kv.subdoc.multi.MultiMutationResponse
 
mutationToken() - Method in class com.couchbase.client.core.message.kv.subdoc.simple.SimpleSubdocResponse
 
mutationToken() - Method in class com.couchbase.client.core.message.kv.UpsertResponse
 
mutationTokens() - Method in class com.couchbase.client.core.message.kv.GetAllMutationTokensResponse
 
mutationTokensEnabled() - Method in interface com.couchbase.client.core.env.CoreEnvironment
Returns true if extended mutation tokens are enabled.
mutationTokensEnabled(boolean) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
If mutation tokens are enabled, they can be used for advanced durability requirements, as well as optimized RYOW consistency.
mutationTokensEnabled() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 

N

n1qlThreshold(long, TimeUnit) - Method in class com.couchbase.client.core.tracing.ThresholdLogReporter.Builder
Allows to customize the n1qlThreshold.
name() - Method in class com.couchbase.client.core.config.AbstractBucketConfig
 
name() - Method in interface com.couchbase.client.core.config.BucketConfig
The name of the bucket.
name() - Method in class com.couchbase.client.core.endpoint.kv.ErrorMap.ErrorCode
 
name() - Method in class com.couchbase.client.core.env.NetworkResolution
Returns the wire representation of the network resolution setting.
name() - Method in class com.couchbase.client.core.event.system.BucketClosedEvent
 
name() - Method in class com.couchbase.client.core.event.system.BucketOpenedEvent
 
name() - Method in class com.couchbase.client.core.logging.AbstractCouchbaseLogger
 
name() - Method in interface com.couchbase.client.core.logging.CouchbaseLogger
Return the name of this CouchbaseLogger instance.
name() - Method in class com.couchbase.client.core.message.view.GetDesignDocumentRequest
 
name() - Method in class com.couchbase.client.core.message.view.GetDesignDocumentResponse
 
name() - Method in class com.couchbase.client.core.message.view.RemoveDesignDocumentRequest
 
name() - Method in class com.couchbase.client.core.message.view.UpsertDesignDocumentRequest
 
nameAndAddress() - Method in class com.couchbase.client.core.utils.NetworkAddress
Prints a safe representation of the hostname (if available) and the IP address.
nameOrAddress() - Method in class com.couchbase.client.core.utils.NetworkAddress
Returns the hostname if available and if not returns the address.
NettyShutdownHook - Class in com.couchbase.client.core.env.resources
ShutdownHook hook that attempts to terminate Netty threads gracefully.
NettyShutdownHook() - Constructor for class com.couchbase.client.core.env.resources.NettyShutdownHook
 
NETWORK_RESOLUTION - Static variable in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
NetworkAddress - Class in com.couchbase.client.core.utils
A convenient wrapper class around network primitives in Java.
networkLatencyMetricsCollector() - Method in interface com.couchbase.client.core.env.CoreEnvironment
Returns the collector responsible for aggregating and publishing network latency information.
networkLatencyMetricsCollector() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
NetworkLatencyMetricsCollector - Class in com.couchbase.client.core.metrics
The collector for core network latencies.
NetworkLatencyMetricsCollector(EventBus, Scheduler, LatencyMetricsCollectorConfig) - Constructor for class com.couchbase.client.core.metrics.NetworkLatencyMetricsCollector
 
networkLatencyMetricsCollectorConfig(LatencyMetricsCollectorConfig) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Sets a custom configuration for the NetworkLatencyMetricsCollector.
NetworkLatencyMetricsEvent - Class in com.couchbase.client.core.event.metrics
This event represents network latencies captured in the core layer.
NetworkLatencyMetricsEvent(Map<NetworkLatencyMetricsIdentifier, LatencyMetric>) - Constructor for class com.couchbase.client.core.event.metrics.NetworkLatencyMetricsEvent
 
NetworkLatencyMetricsIdentifier - Class in com.couchbase.client.core.metrics
The unique identifier for a network latency metric.
NetworkLatencyMetricsIdentifier(String, String, String, String) - Constructor for class com.couchbase.client.core.metrics.NetworkLatencyMetricsIdentifier
 
networkResolution() - Method in interface com.couchbase.client.core.env.CoreEnvironment
Allows to configure the network resolution, default being automatic.
networkResolution(NetworkResolution) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Allows to tune the network resolution setting, pinning it to either internal or external instead of relying on the automatic mechanism.
networkResolution() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
NetworkResolution - Class in com.couchbase.client.core.env
Configuration options for CoreEnvironment.networkResolution().
newInstance(String) - Method in class com.couchbase.client.core.logging.CommonsLoggerFactory
 
newInstance(String) - Method in class com.couchbase.client.core.logging.CouchbaseLoggerFactory
Creates a new logger instance with the specified name.
newInstance(String) - Method in class com.couchbase.client.core.logging.JdkLoggerFactory
 
newInstance(String) - Method in class com.couchbase.client.core.logging.Log4JLoggerFactory
 
newInstance(String) - Method in class com.couchbase.client.core.logging.Slf4JLoggerFactory
 
newInstance() - Method in class com.couchbase.client.core.RequestEventFactory
 
newInstance() - Method in class com.couchbase.client.core.ResponseEventFactory
 
newUnsafe() - Method in class com.couchbase.client.core.endpoint.util.FailedChannel
 
newVbucketUUID() - Method in class com.couchbase.client.core.message.kv.FailoverObserveSeqnoResponse
 
newWaitStrategy() - Method in interface com.couchbase.client.core.env.WaitStrategyFactory
 
NO_IDLE_TIME - Static variable in class com.couchbase.client.core.env.AbstractServiceConfig
 
Node - Interface in com.couchbase.client.core.node
Represents a Couchbase Node.
nodeAtIndex(int) - Method in interface com.couchbase.client.core.config.CouchbaseBucketConfig
Returns information for the node at the given index.
nodeAtIndex(int) - Method in class com.couchbase.client.core.config.DefaultCouchbaseBucketConfig
 
nodeBy(NetworkAddress) - Method in class com.couchbase.client.core.RequestHandler
Returns the node by its hostname.
NodeConnectedEvent - Class in com.couchbase.client.core.event.system
Event published when a node is connected.
NodeConnectedEvent(NetworkAddress) - Constructor for class com.couchbase.client.core.event.system.NodeConnectedEvent
 
NodeDisconnectedEvent - Class in com.couchbase.client.core.event.system
Event published when a node is disconnected.
NodeDisconnectedEvent(NetworkAddress) - Constructor for class com.couchbase.client.core.event.system.NodeDisconnectedEvent
 
nodeForId(byte[]) - Method in class com.couchbase.client.core.config.DefaultMemcachedBucketConfig
 
nodeForId(byte[]) - Method in interface com.couchbase.client.core.config.MemcachedBucketConfig
Returns the target node address for the given document id.
nodeIndexForMaster(int, boolean) - Method in interface com.couchbase.client.core.config.CouchbaseBucketConfig
Returns the node index for the given partition index and master.
nodeIndexForMaster(int, boolean) - Method in class com.couchbase.client.core.config.DefaultCouchbaseBucketConfig
 
nodeIndexForReplica(int, int, boolean) - Method in interface com.couchbase.client.core.config.CouchbaseBucketConfig
Returns the node index for the given partition index and the replica.
nodeIndexForReplica(int, int, boolean) - Method in class com.couchbase.client.core.config.DefaultCouchbaseBucketConfig
 
NodeInfo - Interface in com.couchbase.client.core.config
 
nodes() - Method in class com.couchbase.client.core.config.AbstractBucketConfig
 
nodes() - Method in interface com.couchbase.client.core.config.BucketConfig
The list of nodes associated with this bucket.
nodes() - Method in class com.couchbase.client.core.message.cluster.SeedNodesRequest
Returns the set list of seed hostnames.
NoFailoverObserveSeqnoResponse - Class in com.couchbase.client.core.message.kv
Represents a observe seqno response.
NoFailoverObserveSeqnoResponse(boolean, short, long, long, long, ResponseStatus, short, String, CouchbaseRequest) - Constructor for class com.couchbase.client.core.message.kv.NoFailoverObserveSeqnoResponse
 
NOOP - Static variable in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
NoopRequest - Class in com.couchbase.client.core.message.kv
 
NoopRequest(String, NetworkAddress) - Constructor for class com.couchbase.client.core.message.kv.NoopRequest
 
NoopResponse - Class in com.couchbase.client.core.message.kv
 
NoopResponse(ResponseStatus, short, CouchbaseRequest) - Constructor for class com.couchbase.client.core.message.kv.NoopResponse
 
NoOpShutdownHook - Class in com.couchbase.client.core.env.resources
ShutdownHook hook that does nothing and returns true.
NoOpShutdownHook() - Constructor for class com.couchbase.client.core.env.resources.NoOpShutdownHook
 
NOT_STORED - Static variable in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheResponseStatus
 
NotConnectedException - Exception in com.couchbase.client.core.state
Thrown if the stateful component is not connected.
NotConnectedException() - Constructor for exception com.couchbase.client.core.state.NotConnectedException
 
NotConnectedException(String) - Constructor for exception com.couchbase.client.core.state.NotConnectedException
 
NotConnectedException(String, Throwable) - Constructor for exception com.couchbase.client.core.state.NotConnectedException
 
NotConnectedException(Throwable) - Constructor for exception com.couchbase.client.core.state.NotConnectedException
 
notifyChannelInactive() - Method in class com.couchbase.client.core.endpoint.AbstractEndpoint
Helper method that is called from inside the event loop to notify the upper Endpoint of a disconnect.
notifyResponseDecoded(boolean) - Method in class com.couchbase.client.core.endpoint.AbstractEndpoint
Called by the underlying channel to notify when the channel finished decoding the current response.
numberOfPartitions() - Method in interface com.couchbase.client.core.config.CouchbaseBucketConfig
Returns the total number of partitions.
numberOfPartitions() - Method in class com.couchbase.client.core.config.DefaultCouchbaseBucketConfig
 
numberOfReplicas() - Method in interface com.couchbase.client.core.config.CouchbaseBucketConfig
The number of configured replicas for this bucket.
numberOfReplicas() - Method in class com.couchbase.client.core.config.CouchbasePartitionInfo
 
numberOfReplicas() - Method in class com.couchbase.client.core.config.DefaultCouchbaseBucketConfig
 
numEnvs() - Method in class com.couchbase.client.core.event.system.TooManyEnvironmentsEvent
The number of open environments at the time of the event.

O

O_CURLY - Static variable in class com.couchbase.client.core.utils.yasjl.JsonParserUtils
 
O_SQUARE - Static variable in class com.couchbase.client.core.utils.yasjl.JsonParserUtils
 
Objects - Class in com.couchbase.client.core.lang.backport.java.util
Backport of some utility methods from Java 1.7+
observable() - Method in class com.couchbase.client.core.message.AbstractCouchbaseRequest
 
observable() - Method in interface com.couchbase.client.core.message.CouchbaseRequest
Get the underlying Observable.
Observables - Enum in com.couchbase.client.core.utils
Various utilities to help with Observables.
Observe - Class in com.couchbase.client.core.message.observe
Utility class to handle observe calls and polling logic.
Observe() - Constructor for class com.couchbase.client.core.message.observe.Observe
 
Observe.PersistTo - Enum in com.couchbase.client.core.message.observe
Defines the possible disk persistence constraints to observe.
Observe.ReplicateTo - Enum in com.couchbase.client.core.message.observe
Defines the possible replication constraints to observe.
OBSERVE_INTERVAL_DELAY - Static variable in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
observeIntervalDelay() - Method in interface com.couchbase.client.core.env.CoreEnvironment
Returns the Delay for Observe poll operations.
observeIntervalDelay(Delay) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Sets the Delay for Observe poll operations (default value is a delay growing exponentially between 10us and 100ms).
observeIntervalDelay() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
ObserveRequest - Class in com.couchbase.client.core.message.kv
 
ObserveRequest(String, long, boolean, short, String) - Constructor for class com.couchbase.client.core.message.kv.ObserveRequest
 
ObserveResponse - Class in com.couchbase.client.core.message.kv
.
ObserveResponse(ResponseStatus, short, byte, boolean, long, String, CouchbaseRequest) - Constructor for class com.couchbase.client.core.message.kv.ObserveResponse
 
ObserveResponse.ObserveStatus - Enum in com.couchbase.client.core.message.kv
 
ObserveSeqnoRequest - Class in com.couchbase.client.core.message.kv
Observe through sequence numbers instead of cas.
ObserveSeqnoRequest(long, boolean, short, String, String, long) - Constructor for class com.couchbase.client.core.message.kv.ObserveSeqnoRequest
 
observeStatus() - Method in class com.couchbase.client.core.message.kv.ObserveResponse
 
ObserveViaCAS - Class in com.couchbase.client.core.message.observe
Utility class to handle observe calls and polling logic.
ObserveViaCAS() - Constructor for class com.couchbase.client.core.message.observe.ObserveViaCAS
 
ObserveViaMutationToken - Class in com.couchbase.client.core.message.observe
Document observe through mutation token information.
ObserveViaMutationToken() - Constructor for class com.couchbase.client.core.message.observe.ObserveViaMutationToken
 
OldAnalyticsService - Class in com.couchbase.client.core.service
The Service is composed of and manages AnalyticsEndpoints.
OldAnalyticsService(String, String, String, int, CoreContext) - Constructor for class com.couchbase.client.core.service.OldAnalyticsService
Deprecated.
OldAnalyticsService(String, String, String, String, int, CoreContext) - Constructor for class com.couchbase.client.core.service.OldAnalyticsService
Creates a new OldAnalyticsService.
OldKeyValueService - Class in com.couchbase.client.core.service
 
OldKeyValueService(String, String, String, int, CoreContext) - Constructor for class com.couchbase.client.core.service.OldKeyValueService
Deprecated.
OldKeyValueService(String, String, String, String, int, CoreContext) - Constructor for class com.couchbase.client.core.service.OldKeyValueService
Creates a new KeyValueService.
OldQueryService - Class in com.couchbase.client.core.service
The QueryService is composed of and manages QueryEndpoints.
OldQueryService(String, String, String, int, CoreContext) - Constructor for class com.couchbase.client.core.service.OldQueryService
Deprecated.
OldQueryService(String, String, String, String, int, CoreContext) - Constructor for class com.couchbase.client.core.service.OldQueryService
Creates a new QueryService.
OldSearchService - Class in com.couchbase.client.core.service
 
OldSearchService(String, String, String, int, CoreContext) - Constructor for class com.couchbase.client.core.service.OldSearchService
Deprecated.
OldSearchService(String, String, String, String, int, CoreContext) - Constructor for class com.couchbase.client.core.service.OldSearchService
Creates a new ViewService.
oldVbucketUUID() - Method in class com.couchbase.client.core.message.kv.FailoverObserveSeqnoResponse
 
OldViewService - Class in com.couchbase.client.core.service
The ViewService is composed of and manages ViewEndpoints.
OldViewService(String, String, String, int, CoreContext) - Constructor for class com.couchbase.client.core.service.OldViewService
Deprecated.
OldViewService(String, String, String, String, int, CoreContext) - Constructor for class com.couchbase.client.core.service.OldViewService
Creates a new ViewService.
onCompleted() - Method in class com.couchbase.client.core.event.consumers.LoggingConsumer
 
onCompleted() - Method in class com.couchbase.client.core.utils.UnicastAutoReleaseSubject
 
onError(Throwable) - Method in class com.couchbase.client.core.event.consumers.LoggingConsumer
 
onError(Throwable) - Method in class com.couchbase.client.core.utils.UnicastAutoReleaseSubject
 
onEvent(RequestEvent, long, boolean) - Method in class com.couchbase.client.core.RequestHandler
 
onEvent(ResponseEvent, long, boolean) - Method in class com.couchbase.client.core.ResponseHandler
Handles ResponseEvents that come into the response RingBuffer.
onKeepAliveFired(ChannelHandlerContext, CouchbaseRequest) - Method in class com.couchbase.client.core.endpoint.AbstractGenericHandler
Override to customize the behavior when a keep alive has been triggered and a keep alive request sent.
onKeepAliveResponse(ChannelHandlerContext, CouchbaseResponse) - Method in class com.couchbase.client.core.endpoint.AbstractGenericHandler
Override to customize the behavior when a keep alive has been responded to.
onNext(CouchbaseEvent) - Method in class com.couchbase.client.core.event.consumers.LoggingConsumer
 
onNext(T) - Method in class com.couchbase.client.core.utils.UnicastAutoReleaseSubject
 
OP_APPEND - Static variable in class com.couchbase.client.core.endpoint.kv.KeyValueHandler
 
OP_COUNTER_DECR - Static variable in class com.couchbase.client.core.endpoint.kv.KeyValueHandler
 
OP_COUNTER_INCR - Static variable in class com.couchbase.client.core.endpoint.kv.KeyValueHandler
 
OP_GET - Static variable in class com.couchbase.client.core.endpoint.kv.KeyValueHandler
 
OP_GET_ALL_MUTATION_TOKENS - Static variable in class com.couchbase.client.core.endpoint.kv.KeyValueHandler
 
OP_GET_AND_LOCK - Static variable in class com.couchbase.client.core.endpoint.kv.KeyValueHandler
 
OP_GET_AND_TOUCH - Static variable in class com.couchbase.client.core.endpoint.kv.KeyValueHandler
 
OP_GET_BUCKET_CONFIG - Static variable in class com.couchbase.client.core.endpoint.kv.KeyValueHandler
 
OP_GET_REPLICA - Static variable in class com.couchbase.client.core.endpoint.kv.KeyValueHandler
 
OP_INSERT - Static variable in class com.couchbase.client.core.endpoint.kv.KeyValueHandler
 
OP_NOOP - Static variable in class com.couchbase.client.core.endpoint.kv.KeyValueHandler
 
OP_OBSERVE - Static variable in class com.couchbase.client.core.endpoint.kv.KeyValueHandler
 
OP_OBSERVE_SEQ - Static variable in class com.couchbase.client.core.endpoint.kv.KeyValueHandler
 
OP_PREPEND - Static variable in class com.couchbase.client.core.endpoint.kv.KeyValueHandler
 
OP_REMOVE - Static variable in class com.couchbase.client.core.endpoint.kv.KeyValueHandler
 
OP_REPLACE - Static variable in class com.couchbase.client.core.endpoint.kv.KeyValueHandler
 
OP_STAT - Static variable in class com.couchbase.client.core.endpoint.kv.KeyValueHandler
 
OP_SUB_ARRAY_ADD_UNIQUE - Static variable in class com.couchbase.client.core.endpoint.kv.KeyValueHandler
 
OP_SUB_ARRAY_INSERT - Static variable in class com.couchbase.client.core.endpoint.kv.KeyValueHandler
 
OP_SUB_ARRAY_PUSH_FIRST - Static variable in class com.couchbase.client.core.endpoint.kv.KeyValueHandler
 
OP_SUB_ARRAY_PUSH_LAST - Static variable in class com.couchbase.client.core.endpoint.kv.KeyValueHandler
 
OP_SUB_COUNTER - Static variable in class com.couchbase.client.core.endpoint.kv.KeyValueHandler
 
OP_SUB_DELETE - Static variable in class com.couchbase.client.core.endpoint.kv.KeyValueHandler
 
OP_SUB_DICT_ADD - Static variable in class com.couchbase.client.core.endpoint.kv.KeyValueHandler
 
OP_SUB_DICT_UPSERT - Static variable in class com.couchbase.client.core.endpoint.kv.KeyValueHandler
 
OP_SUB_EXIST - Static variable in class com.couchbase.client.core.endpoint.kv.KeyValueHandler
 
OP_SUB_GET - Static variable in class com.couchbase.client.core.endpoint.kv.KeyValueHandler
 
OP_SUB_GET_COUNT - Static variable in class com.couchbase.client.core.endpoint.kv.KeyValueHandler
 
OP_SUB_MULTI_LOOKUP - Static variable in class com.couchbase.client.core.endpoint.kv.KeyValueHandler
 
OP_SUB_MULTI_MUTATION - Static variable in class com.couchbase.client.core.endpoint.kv.KeyValueHandler
 
OP_SUB_REPLACE - Static variable in class com.couchbase.client.core.endpoint.kv.KeyValueHandler
 
OP_TOUCH - Static variable in class com.couchbase.client.core.endpoint.kv.KeyValueHandler
 
OP_UNLOCK - Static variable in class com.couchbase.client.core.endpoint.kv.KeyValueHandler
 
OP_UPSERT - Static variable in class com.couchbase.client.core.endpoint.kv.KeyValueHandler
 
opaque() - Method in class com.couchbase.client.core.message.kv.AbstractKeyValueRequest
 
opaque() - Method in interface com.couchbase.client.core.message.kv.BinaryRequest
A opaque value representing this request.
opcode() - Method in interface com.couchbase.client.core.message.kv.subdoc.BinarySubdocRequest
 
opCode() - Method in enum com.couchbase.client.core.message.kv.subdoc.multi.Lookup
 
opCode() - Method in class com.couchbase.client.core.message.kv.subdoc.multi.LookupCommand
 
opCode() - Method in class com.couchbase.client.core.message.kv.subdoc.multi.LookupCommandBuilder
 
opCode() - Method in enum com.couchbase.client.core.message.kv.subdoc.multi.Mutation
 
opCode() - Method in class com.couchbase.client.core.message.kv.subdoc.multi.MutationCommand
 
opCode() - Method in class com.couchbase.client.core.message.kv.subdoc.multi.MutationCommandBuilder
 
opCode() - Method in enum com.couchbase.client.core.message.kv.subdoc.simple.SubArrayRequest.ArrayOperation
 
opcode() - Method in class com.couchbase.client.core.message.kv.subdoc.simple.SubArrayRequest
 
opcode() - Method in class com.couchbase.client.core.message.kv.subdoc.simple.SubCounterRequest
opcode() - Method in class com.couchbase.client.core.message.kv.subdoc.simple.SubDeleteRequest
opcode() - Method in class com.couchbase.client.core.message.kv.subdoc.simple.SubDictAddRequest
opcode() - Method in class com.couchbase.client.core.message.kv.subdoc.simple.SubDictUpsertRequest
opcode() - Method in class com.couchbase.client.core.message.kv.subdoc.simple.SubExistRequest
opcode() - Method in class com.couchbase.client.core.message.kv.subdoc.simple.SubGetCountRequest
opcode() - Method in class com.couchbase.client.core.message.kv.subdoc.simple.SubGetRequest
opcode() - Method in class com.couchbase.client.core.message.kv.subdoc.simple.SubReplaceRequest
openBucket(String, String) - Method in interface com.couchbase.client.core.config.ConfigurationProvider
Start to fetch a config for the given bucket and also watch for changes, depending on the mechanism used.
openBucket(String, String, String) - Method in interface com.couchbase.client.core.config.ConfigurationProvider
Start to fetch a config for the given bucket and also watch for changes, depending on the mechanism used.
openBucket(String, String) - Method in class com.couchbase.client.core.config.DefaultConfigurationProvider
 
openBucket(String, String, String) - Method in class com.couchbase.client.core.config.DefaultConfigurationProvider
 
OpenBucketRequest - Class in com.couchbase.client.core.message.cluster
 
OpenBucketRequest(String, String) - Constructor for class com.couchbase.client.core.message.cluster.OpenBucketRequest
 
OpenBucketRequest(String, String, String) - Constructor for class com.couchbase.client.core.message.cluster.OpenBucketRequest
 
OpenBucketResponse - Class in com.couchbase.client.core.message.cluster
 
OpenBucketResponse(ResponseStatus) - Constructor for class com.couchbase.client.core.message.cluster.OpenBucketResponse
 
openBuckets() - Method in class com.couchbase.client.core.event.system.ConfigUpdatedEvent
Returns all open bucket names.
operation() - Method in class com.couchbase.client.core.message.kv.subdoc.multi.MultiResult
 
OPERATION_TRACING_ENABLED - Static variable in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
OPERATION_TRACING_SERVER_DUR_ENABLED - Static variable in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
operationId() - Method in class com.couchbase.client.core.message.AbstractCouchbaseRequest
Default implementation, sub requests need to override this.
operationId() - Method in interface com.couchbase.client.core.message.CouchbaseRequest
A unique operation id, used for tracing purposes.
operationId() - Method in class com.couchbase.client.core.message.kv.AbstractKeyValueRequest
 
operationId() - Method in class com.couchbase.client.core.message.query.GenericQueryRequest
 
operationName() - Method in class com.couchbase.client.core.tracing.ThresholdLogSpan
Returns the operation name.
operationTracingEnabled() - Method in interface com.couchbase.client.core.env.CoreEnvironment
True if tracing is enabled on the environment.
operationTracingEnabled(boolean) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Allows to enable/disable the tracing support.
operationTracingEnabled() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
operationTracingServerDurationEnabled() - Method in interface com.couchbase.client.core.env.CoreEnvironment
True if additional server duration tracing is enabled.
operationTracingServerDurationEnabled(boolean) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Allows to enable/disable the negotiation of server duration-enabled tracing.
operationTracingServerDurationEnabled() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
origin() - Method in class com.couchbase.client.core.config.ProposedBucketConfigContext
Returns the origin, might be null.
OriginalMutationResult - Interface in com.couchbase.client.core
Represents mutation metadata which can be inspected after a mutation and during/after is respective observe poll cycles.
ORPHAN_REPORTING_ENABLED - Static variable in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
orphanResponseReporter() - Method in interface com.couchbase.client.core.env.CoreEnvironment
Returns the current orphan response reporter implementation.
orphanResponseReporter(OrphanResponseReporter) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
 
orphanResponseReporter() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
OrphanResponseReporter - Interface in com.couchbase.client.core.tracing
 
orphanResponseReportingEnabled() - Method in interface com.couchbase.client.core.env.CoreEnvironment
Check if orphan response reporting is enabled.
orphanResponseReportingEnabled(boolean) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
 
orphanResponseReportingEnabled() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
OS_BEAN - Static variable in class com.couchbase.client.core.env.Diagnostics
 

P

PACKAGE_NAME_AND_VERSION - Static variable in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
packageNameAndVersion() - Method in interface com.couchbase.client.core.env.CoreEnvironment
Returns name and the version of the package.
packageNameAndVersion(String) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Sets the String to be used as identifier for the library namespace and version.
packageNameAndVersion() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
paddedHex(long) - Static method in class com.couchbase.client.core.endpoint.kv.KeyValueFeatureHandler
Helper method to create a padded hex long value.
params() - Method in class com.couchbase.client.core.utils.ConnectionString
 
parse(String, ConfigParserEnvironment, NetworkAddress) - Static method in class com.couchbase.client.core.config.parser.BucketConfigParser
Parse a raw configuration into a BucketConfig.
parse() - Method in class com.couchbase.client.core.endpoint.query.parser.YasjlQueryResponseParser
Instruct the parser to run a new parsing cycle on the current response content.
parse() - Method in class com.couchbase.client.core.utils.yasjl.ByteBufJsonParser
Instructs the parser to start parsing the current buffer.
Partition - Interface in com.couchbase.client.core.config
 
partition() - Method in class com.couchbase.client.core.message.kv.AbstractKeyValueRequest
 
partition(short) - Method in class com.couchbase.client.core.message.kv.AbstractKeyValueRequest
 
partition() - Method in interface com.couchbase.client.core.message.kv.BinaryRequest
The partition (vbucket) to use for this request.
partition(short) - Method in interface com.couchbase.client.core.message.kv.BinaryRequest
Set the partition ID.
partition() - Method in class com.couchbase.client.core.message.kv.GetAllMutationTokensRequest
 
partition() - Method in class com.couchbase.client.core.message.kv.GetBucketConfigRequest
 
partition() - Method in class com.couchbase.client.core.message.kv.StatRequest
 
PARTITION_NOT_EXISTENT - Static variable in class com.couchbase.client.core.config.DefaultCouchbaseBucketConfig
 
partitionHosts() - Method in class com.couchbase.client.core.config.CouchbasePartitionInfo
 
partitions() - Method in class com.couchbase.client.core.config.CouchbasePartitionInfo
 
PartitionSelectionStrategy - Class in com.couchbase.client.core.service.strategies
Selects the Endpoint based on the information enclosed in the CouchbaseRequest.
partitionState() - Method in class com.couchbase.client.core.message.kv.GetAllMutationTokensRequest
 
password() - Method in class com.couchbase.client.core.config.AbstractBucketConfig
 
password(String) - Method in class com.couchbase.client.core.config.AbstractBucketConfig
 
password() - Method in interface com.couchbase.client.core.config.BucketConfig
The password of the bucket/user.
password(String) - Method in interface com.couchbase.client.core.config.BucketConfig
Setter to inject the password manually into the config.
password() - Method in class com.couchbase.client.core.endpoint.AbstractEndpoint
The password of the bucket/user.
password() - Method in class com.couchbase.client.core.message.AbstractCouchbaseRequest
 
password() - Method in interface com.couchbase.client.core.message.CouchbaseRequest
The password associated with the bucket/ user
path() - Method in class com.couchbase.client.core.endpoint.search.SearchHandler.KeepAliveRequest
 
path() - Method in class com.couchbase.client.core.message.config.BucketConfigRequest
 
path() - Method in class com.couchbase.client.core.message.config.BucketsConfigRequest
 
path() - Method in class com.couchbase.client.core.message.config.BucketStreamingRequest
 
path() - Method in class com.couchbase.client.core.message.config.ClusterConfigRequest
 
path() - Method in interface com.couchbase.client.core.message.config.ConfigRequest
 
path() - Method in class com.couchbase.client.core.message.config.FlushRequest
 
path() - Method in class com.couchbase.client.core.message.config.GetDesignDocumentsRequest
 
path() - Method in class com.couchbase.client.core.message.config.GetUsersRequest
 
path() - Method in class com.couchbase.client.core.message.config.InsertBucketRequest
 
path() - Method in class com.couchbase.client.core.message.config.RemoveBucketRequest
 
path() - Method in class com.couchbase.client.core.message.config.RemoveUserRequest
 
path() - Method in class com.couchbase.client.core.message.config.RestApiRequest
 
path() - Method in class com.couchbase.client.core.message.config.UpdateBucketRequest
 
path() - Method in class com.couchbase.client.core.message.config.UpsertUserRequest
 
path() - Method in interface com.couchbase.client.core.message.kv.subdoc.BinarySubdocRequest
Returns the path inside a JSON document where values will be obtained/mutated.
path() - Method in class com.couchbase.client.core.message.kv.subdoc.multi.LookupCommand
 
path() - Method in class com.couchbase.client.core.message.kv.subdoc.multi.LookupCommandBuilder
 
path() - Method in class com.couchbase.client.core.message.kv.subdoc.multi.MultiResult
 
path() - Method in class com.couchbase.client.core.message.kv.subdoc.multi.MutationCommand
 
path() - Method in class com.couchbase.client.core.message.kv.subdoc.multi.MutationCommandBuilder
 
path() - Method in class com.couchbase.client.core.message.kv.subdoc.simple.AbstractSubdocRequest
 
path() - Method in class com.couchbase.client.core.message.search.GetSearchIndexRequest
 
path() - Method in class com.couchbase.client.core.message.search.PingRequest
 
path() - Method in class com.couchbase.client.core.message.search.RemoveSearchIndexRequest
 
path() - Method in class com.couchbase.client.core.message.search.SearchQueryRequest
 
path() - Method in interface com.couchbase.client.core.message.search.SearchRequest
 
path() - Method in class com.couchbase.client.core.message.search.UpsertSearchIndexRequest
 
pathLength() - Method in interface com.couchbase.client.core.message.kv.subdoc.BinarySubdocRequest
 
pathLength() - Method in class com.couchbase.client.core.message.kv.subdoc.simple.AbstractSubdocRequest
 
pathWithParameters() - Method in class com.couchbase.client.core.message.config.RestApiRequest
 
payload() - Method in class com.couchbase.client.core.message.config.InsertBucketRequest
 
payload() - Method in class com.couchbase.client.core.message.config.UpdateBucketRequest
 
payload() - Method in class com.couchbase.client.core.message.config.UpsertUserRequest
 
payload() - Method in class com.couchbase.client.core.message.search.GetSearchIndexResponse
 
payload() - Method in class com.couchbase.client.core.message.search.RemoveSearchIndexResponse
 
payload() - Method in class com.couchbase.client.core.message.search.SearchQueryRequest
 
payload() - Method in class com.couchbase.client.core.message.search.SearchQueryResponse
 
payload() - Method in class com.couchbase.client.core.message.search.UpsertSearchIndexRequest
 
payload() - Method in class com.couchbase.client.core.message.search.UpsertSearchIndexResponse
 
percentiles() - Method in class com.couchbase.client.core.event.metrics.LatencyMetric
Configured latencies with their values recorded in the interval.
ping(CoreEnvironment, String, String, ClusterFacade, String, long, TimeUnit, ServiceType...) - Static method in class com.couchbase.client.core.utils.HealthPinger
Performs a service ping against all or (if given) the services provided.
PingReport - Class in com.couchbase.client.core.message.internal
Contains a report for all the internal service health states.
PingReport(List<PingServiceHealth>, String, String, long) - Constructor for class com.couchbase.client.core.message.internal.PingReport
 
PingRequest - Class in com.couchbase.client.core.message.analytics
 
PingRequest(InetAddress, String, String) - Constructor for class com.couchbase.client.core.message.analytics.PingRequest
 
PingRequest - Class in com.couchbase.client.core.message.query
 
PingRequest(InetAddress, String, String) - Constructor for class com.couchbase.client.core.message.query.PingRequest
 
PingRequest - Class in com.couchbase.client.core.message.search
 
PingRequest(InetAddress, String, String) - Constructor for class com.couchbase.client.core.message.search.PingRequest
 
PingRequest - Class in com.couchbase.client.core.message.view
 
PingRequest(InetAddress, String, String) - Constructor for class com.couchbase.client.core.message.view.PingRequest
 
PingResponse - Class in com.couchbase.client.core.message.analytics
 
PingResponse(ResponseStatus, CouchbaseRequest) - Constructor for class com.couchbase.client.core.message.analytics.PingResponse
 
PingResponse - Class in com.couchbase.client.core.message.query
 
PingResponse(ResponseStatus, CouchbaseRequest) - Constructor for class com.couchbase.client.core.message.query.PingResponse
 
PingResponse - Class in com.couchbase.client.core.message.search
 
PingResponse(ResponseStatus, CouchbaseRequest) - Constructor for class com.couchbase.client.core.message.search.PingResponse
 
PingResponse - Class in com.couchbase.client.core.message.view
 
PingResponse(ResponseStatus, CouchbaseRequest) - Constructor for class com.couchbase.client.core.message.view.PingResponse
 
PingServiceHealth - Class in com.couchbase.client.core.message.internal
Represents health for a specific service on ping.
PingServiceHealth(ServiceType, PingServiceHealth.PingState, String, long, SocketAddress, SocketAddress, String) - Constructor for class com.couchbase.client.core.message.internal.PingServiceHealth
 
PingServiceHealth.PingState - Enum in com.couchbase.client.core.message.internal
 
PooledService - Class in com.couchbase.client.core.service
A generic implementation of a service pool.
port() - Method in class com.couchbase.client.core.config.loader.AbstractLoader
Port to use for the ServiceType.
port() - Method in class com.couchbase.client.core.config.loader.CarrierLoader
 
port() - Method in class com.couchbase.client.core.config.loader.HttpLoader
 
port() - Method in class com.couchbase.client.core.message.internal.AddServiceRequest
 
PortInfo - Interface in com.couchbase.client.core.config
 
ports() - Method in class com.couchbase.client.core.config.DefaultPortInfo
 
ports() - Method in interface com.couchbase.client.core.config.PortInfo
 
PrelocatedRequest - Interface in com.couchbase.client.core.message
A CouchbaseRequest that can be targeted at a specific node through the corresponding InetAddress, shortcutting the dispatch usually performed by a Locator..
PREPEND - Static variable in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
PREPENDQ - Static variable in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
PrependRequest - Class in com.couchbase.client.core.message.kv
 
PrependRequest(String, long, ByteBuf, String) - Constructor for class com.couchbase.client.core.message.kv.PrependRequest
 
PrependResponse - Class in com.couchbase.client.core.message.kv
.
PrependResponse(ResponseStatus, short, long, String, ByteBuf, MutationToken, CouchbaseRequest) - Constructor for class com.couchbase.client.core.message.kv.PrependResponse
 
pretty(boolean) - Method in class com.couchbase.client.core.tracing.DefaultOrphanResponseReporter.Builder
Allows to set the JSON output to pretty, making it more readable but also more verbose.
pretty(boolean) - Method in class com.couchbase.client.core.tracing.ThresholdLogReporter.Builder
Allows to set the JSON output to pretty, making it more readable but also more verbose.
prettyWriter() - Static method in class com.couchbase.client.core.utils.DefaultObjectMapper
 
process(byte) - Method in class com.couchbase.client.core.endpoint.util.ClosingPositionBufProcessor
 
process(byte) - Method in class com.couchbase.client.core.endpoint.util.SplitPositionBufProcessor
 
process(byte) - Method in class com.couchbase.client.core.endpoint.util.StringClosingPositionBufProcessor
 
process(byte) - Method in class com.couchbase.client.core.endpoint.util.WhitespaceSkipper
 
process(byte) - Method in class com.couchbase.client.core.utils.yasjl.JsonArrayByteBufProcessor
 
process(byte) - Method in class com.couchbase.client.core.utils.yasjl.JsonBOMByteBufProcessor
 
process(byte) - Method in class com.couchbase.client.core.utils.yasjl.JsonBooleanFalseByteBufProcessor
 
process(byte) - Method in class com.couchbase.client.core.utils.yasjl.JsonBooleanTrueByteBufProcessor
 
process(byte) - Method in class com.couchbase.client.core.utils.yasjl.JsonNullByteBufProcessor
 
process(byte) - Method in class com.couchbase.client.core.utils.yasjl.JsonNumberByteBufProcessor
 
process(byte) - Method in class com.couchbase.client.core.utils.yasjl.JsonObjectByteBufProcessor
 
process(byte) - Method in class com.couchbase.client.core.utils.yasjl.JsonStringByteBufProcessor
 
process(byte) - Method in class com.couchbase.client.core.utils.yasjl.JsonWhiteSpaceByteBufProcessor
 
profileInfo() - Method in class com.couchbase.client.core.message.query.GenericQueryResponse
Contains a single ByteBuf representing the JSON object of query profile information (or empty if profile haven’t been activated).
proposeBucketConfig(ProposedBucketConfigContext) - Method in interface com.couchbase.client.core.config.ConfigurationProvider
Propose a new bucket config with surrounding context.
proposeBucketConfig(ProposedBucketConfigContext) - Method in class com.couchbase.client.core.config.DefaultConfigurationProvider
 
ProposedBucketConfigContext - Class in com.couchbase.client.core.config
This context keeps together a bunch of related information needed to turn a raw config into a parsed one.
ProposedBucketConfigContext(String, String, NetworkAddress) - Constructor for class com.couchbase.client.core.config.ProposedBucketConfigContext
Creates a new proposed bucket config context.
provider() - Method in class com.couchbase.client.core.config.refresher.AbstractRefresher
 
provider(ConfigurationProvider) - Method in class com.couchbase.client.core.config.refresher.AbstractRefresher
 
provider(ConfigurationProvider) - Method in interface com.couchbase.client.core.config.refresher.Refresher
 
provider() - Method in class com.couchbase.client.core.message.internal.GetConfigProviderResponse
 
publish(CouchbaseEvent) - Method in class com.couchbase.client.core.event.DefaultEventBus
 
publish(CouchbaseEvent) - Method in interface com.couchbase.client.core.event.EventBus
Publish a CouchbaseEvent into the bus.
publishResponse(CouchbaseResponse, Subject<CouchbaseResponse, CouchbaseResponse>) - Method in class com.couchbase.client.core.endpoint.AbstractGenericHandler
Publishes a response with the attached observable.
pushConfig(ProposedBucketConfigContext) - Method in class com.couchbase.client.core.config.refresher.AbstractRefresher
Push a BucketConfig into the config stream.

Q

query() - Method in class com.couchbase.client.core.message.analytics.GenericAnalyticsRequest
 
query() - Method in class com.couchbase.client.core.message.query.GenericQueryRequest
 
query() - Method in class com.couchbase.client.core.message.view.ViewQueryRequest
 
QUERY_ENDPOINTS - Static variable in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
QUERY_STATE_DONE - Static variable in class com.couchbase.client.core.endpoint.analytics.AnalyticsHandler
 
QUERY_STATE_DONE - Static variable in class com.couchbase.client.core.endpoint.query.QueryHandler
 
QUERY_STATE_ERROR - Static variable in class com.couchbase.client.core.endpoint.analytics.AnalyticsHandler
 
QUERY_STATE_ERROR - Static variable in class com.couchbase.client.core.endpoint.query.QueryHandler
 
QUERY_STATE_INFO - Static variable in class com.couchbase.client.core.endpoint.analytics.AnalyticsHandler
 
QUERY_STATE_INFO - Static variable in class com.couchbase.client.core.endpoint.query.QueryHandler
 
QUERY_STATE_INITIAL - Static variable in class com.couchbase.client.core.endpoint.analytics.AnalyticsHandler
 
QUERY_STATE_INITIAL - Static variable in class com.couchbase.client.core.endpoint.query.QueryHandler
 
QUERY_STATE_NO_INFO - Static variable in class com.couchbase.client.core.endpoint.analytics.AnalyticsHandler
 
QUERY_STATE_NO_INFO - Static variable in class com.couchbase.client.core.endpoint.query.QueryHandler
 
QUERY_STATE_ROWS - Static variable in class com.couchbase.client.core.endpoint.analytics.AnalyticsHandler
 
QUERY_STATE_ROWS - Static variable in class com.couchbase.client.core.endpoint.query.QueryHandler
 
QUERY_STATE_ROWS_DECIDE - Static variable in class com.couchbase.client.core.endpoint.analytics.AnalyticsHandler
 
QUERY_STATE_ROWS_DECIDE - Static variable in class com.couchbase.client.core.endpoint.query.QueryHandler
 
QUERY_STATE_ROWS_RAW - Static variable in class com.couchbase.client.core.endpoint.analytics.AnalyticsHandler
 
QUERY_STATE_ROWS_RAW - Static variable in class com.couchbase.client.core.endpoint.query.QueryHandler
 
QUERY_STATE_SIGNATURE - Static variable in class com.couchbase.client.core.endpoint.analytics.AnalyticsHandler
 
QUERY_STATE_SIGNATURE - Static variable in class com.couchbase.client.core.endpoint.query.QueryHandler
 
QUERY_STATE_STATUS - Static variable in class com.couchbase.client.core.endpoint.analytics.AnalyticsHandler
 
QUERY_STATE_STATUS - Static variable in class com.couchbase.client.core.endpoint.query.QueryHandler
 
QUERY_STATE_WARNING - Static variable in class com.couchbase.client.core.endpoint.analytics.AnalyticsHandler
 
QUERY_STATE_WARNING - Static variable in class com.couchbase.client.core.endpoint.query.QueryHandler
 
QueryEndpoint - Class in com.couchbase.client.core.endpoint.query
This endpoint defines the pipeline for query requests and responses (N1QL).
QueryEndpoint(String, String, String, int, CoreContext) - Constructor for class com.couchbase.client.core.endpoint.query.QueryEndpoint
Deprecated.
QueryEndpoint(String, String, String, String, int, CoreContext) - Constructor for class com.couchbase.client.core.endpoint.query.QueryEndpoint
 
queryEndpoints() - Method in interface com.couchbase.client.core.env.CoreEnvironment
The number of query service endpoints.
queryEndpoints(int) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
queryEndpoints() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
QueryHandler - Class in com.couchbase.client.core.endpoint.query
The QueryHandler is responsible for encoding QueryRequests into lower level HttpRequests as well as decoding HttpObjects into CouchbaseResponses.
QueryHandler(AbstractEndpoint, RingBuffer<ResponseEvent>, boolean, boolean) - Constructor for class com.couchbase.client.core.endpoint.query.QueryHandler
Creates a new QueryHandler with the default queue for requests.
QueryHandler.KeepAliveRequest - Class in com.couchbase.client.core.endpoint.query
 
QueryHandler.KeepAliveResponse - Class in com.couchbase.client.core.endpoint.query
 
QueryHandlerV2 - Class in com.couchbase.client.core.endpoint.query
The QueryHandlerV2 is responsible for encoding QueryRequests into lower level HttpRequests as well as decoding HttpObjects into CouchbaseResponses.
QueryHandlerV2(AbstractEndpoint, RingBuffer<ResponseEvent>, boolean, boolean) - Constructor for class com.couchbase.client.core.endpoint.query.QueryHandlerV2
Creates a new QueryHandlerV2 with the default queue for requests.
QueryHandlerV2.KeepAliveRequest - Class in com.couchbase.client.core.endpoint.query
 
QueryHandlerV2.KeepAliveResponse - Class in com.couchbase.client.core.endpoint.query
 
queryIoPool() - Method in interface com.couchbase.client.core.env.CoreEnvironment
If set returns the IO Pool for the query service, if not returns null.
queryIoPool(EventLoopGroup, ShutdownHook) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Sets the Query I/O Pool implementation for the underlying IO framework, along with the action to execute when this environment is shut down.
queryIoPool() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
QueryLocator - Class in com.couchbase.client.core.node.locate
 
QueryLocator() - Constructor for class com.couchbase.client.core.node.locate.QueryLocator
Generates the random initial value for the round robin counter used.
queryParameters() - Method in class com.couchbase.client.core.message.config.RestApiRequest
 
QueryRequest - Interface in com.couchbase.client.core.message.query
 
QueryService - Class in com.couchbase.client.core.service
The QueryService is composed of and manages QueryEndpoints.
QueryService(String, String, String, int, CoreContext) - Constructor for class com.couchbase.client.core.service.QueryService
Deprecated.
QueryService(String, String, String, String, int, CoreContext) - Constructor for class com.couchbase.client.core.service.QueryService
Creates a new QueryService.
queryServiceConfig() - Method in interface com.couchbase.client.core.env.CoreEnvironment
Returns the current QueryService configuration.
queryServiceConfig(QueryServiceConfig) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Allows to set a custom configuration for the Query service.
queryServiceConfig() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
QueryServiceConfig - Class in com.couchbase.client.core.env
 
queryStatus() - Method in class com.couchbase.client.core.message.analytics.GenericAnalyticsResponse
Contains a single String denoting the status of the query (success, running, errors, completed, stopped, timeout, fatal).
queryStatus() - Method in class com.couchbase.client.core.message.query.GenericQueryResponse
Contains a single String denoting the status of the query (success, running, errors, completed, stopped, timeout, fatal).
QUIT - Static variable in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
QUITQ - Static variable in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 

R

RandomSelectionStrategy - Class in com.couchbase.client.core.service.strategies
Selects the Endpoint based on a random selection of connected Endpoints.
RandomSelectionStrategy() - Constructor for class com.couchbase.client.core.service.strategies.RandomSelectionStrategy
 
raw() - Method in enum com.couchbase.client.core.endpoint.kv.ErrorMap.ErrorAttribute
 
RawAnalyticsRequest - Class in com.couchbase.client.core.message.analytics
A AnalyticsRequest that can also be prelocated, but expects a response with the uninterpreted JSON payload returned by the query service.
RawAnalyticsResponse - Class in com.couchbase.client.core.message.analytics
The response to a RawAnalyticsRequest, which only contains the raw JSON payload returned by the Analytics service, as a ByteBuf.
RawAnalyticsResponse(ResponseStatus, CouchbaseRequest, ByteBuf, int, String) - Constructor for class com.couchbase.client.core.message.analytics.RawAnalyticsResponse
 
rawHostname() - Method in interface com.couchbase.client.core.config.AlternateAddress
Contains the string representation from the hostname the same way it is represented in the config.
rawHostname() - Method in class com.couchbase.client.core.config.DefaultAlternateAddress
 
rawHostname() - Method in class com.couchbase.client.core.config.DefaultNodeInfo
 
rawHostname() - Method in interface com.couchbase.client.core.config.NodeInfo
Contains the string representation from the hostname the same way it is represented in the config.
RawQueryRequest - Class in com.couchbase.client.core.message.query
A QueryRequest that can also be prelocated, but expects a response with the uninterpreted JSON payload returned by the query service.
RawQueryResponse - Class in com.couchbase.client.core.message.query
The response to a RawQueryRequest, which only contains the raw JSON payload returned by the Query service, as a ByteBuf.
RawQueryResponse(ResponseStatus, CouchbaseRequest, ByteBuf, int, String) - Constructor for class com.couchbase.client.core.message.query.RawQueryResponse
 
read(ChannelHandlerContext) - Method in class com.couchbase.client.core.endpoint.kv.KeyValueAuthHandler
 
read(ChannelHandlerContext) - Method in class com.couchbase.client.core.endpoint.kv.KeyValueErrorMapHandler
 
read(ChannelHandlerContext) - Method in class com.couchbase.client.core.endpoint.kv.KeyValueFeatureHandler
 
read(ChannelHandlerContext) - Method in class com.couchbase.client.core.endpoint.kv.KeyValueSelectBucketHandler
 
reader() - Static method in class com.couchbase.client.core.utils.DefaultObjectMapper
 
readErrorCodeFromErrorMap(short) - Static method in class com.couchbase.client.core.endpoint.ResponseStatusConverter
Get the error code from Key Value error map
readResolve() - Method in class com.couchbase.client.core.logging.AbstractCouchbaseLogger
 
readTree(String) - Static method in class com.couchbase.client.core.utils.DefaultObjectMapper
 
readTree(byte[]) - Static method in class com.couchbase.client.core.utils.DefaultObjectMapper
 
readTree(Reader) - Static method in class com.couchbase.client.core.utils.DefaultObjectMapper
 
readTree(InputStream) - Static method in class com.couchbase.client.core.utils.DefaultObjectMapper
 
readValue(String, Class<T>) - Static method in class com.couchbase.client.core.utils.DefaultObjectMapper
 
readValue(String, TypeReference<T>) - Static method in class com.couchbase.client.core.utils.DefaultObjectMapper
 
readValue(byte[], Class<T>) - Static method in class com.couchbase.client.core.utils.DefaultObjectMapper
 
readValue(byte[], int, int, Class<T>) - Static method in class com.couchbase.client.core.utils.DefaultObjectMapper
 
readValue(byte[], TypeReference<T>) - Static method in class com.couchbase.client.core.utils.DefaultObjectMapper
 
readValue(byte[], int, int, TypeReference<T>) - Static method in class com.couchbase.client.core.utils.DefaultObjectMapper
 
readValue(Reader, Class<T>) - Static method in class com.couchbase.client.core.utils.DefaultObjectMapper
 
readValue(Reader, TypeReference<T>) - Static method in class com.couchbase.client.core.utils.DefaultObjectMapper
 
readValue(InputStream, Class<T>) - Static method in class com.couchbase.client.core.utils.DefaultObjectMapper
 
readValue(InputStream, TypeReference<T>) - Static method in class com.couchbase.client.core.utils.DefaultObjectMapper
 
readValueAsMap(String) - Static method in class com.couchbase.client.core.utils.DefaultObjectMapper
 
readValueAsMap(byte[]) - Static method in class com.couchbase.client.core.utils.DefaultObjectMapper
 
readValueAsMap(Reader) - Static method in class com.couchbase.client.core.utils.DefaultObjectMapper
 
readValueAsMap(InputStream) - Static method in class com.couchbase.client.core.utils.DefaultObjectMapper
 
reconfigure(ClusterConfig) - Method in class com.couchbase.client.core.RequestHandler
Helper method which grabs the current configuration and checks if the node setup is out of sync.
RECONNECT_DELAY - Static variable in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
reconnectDelay() - Method in interface com.couchbase.client.core.env.CoreEnvironment
Returns the Delay for node reconnects.
reconnectDelay(Delay) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Sets the Delay for node reconnects (default value is a delay growing exponentially between 32ms and 4096ms).
reconnectDelay() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
record(I, long) - Method in class com.couchbase.client.core.metrics.AbstractLatencyMetricsCollector
 
record(I, long) - Method in interface com.couchbase.client.core.metrics.LatencyMetricsCollector
Records a latency for the given identifier.
RedactableArgument - Class in com.couchbase.client.core.logging
Represents a logging argument which is subject to redaction.
RedactableArgument.ArgumentType - Enum in com.couchbase.client.core.logging
The type of the redactable argument.
RedactionLevel - Enum in com.couchbase.client.core.logging
Allows to specify the level of log redaction.
refCnt() - Method in class com.couchbase.client.core.message.kv.AbstractKeyValueResponse
 
refCnt() - Method in class com.couchbase.client.core.message.view.GetDesignDocumentResponse
 
refCnt() - Method in class com.couchbase.client.core.message.view.RemoveDesignDocumentResponse
 
refCnt() - Method in class com.couchbase.client.core.message.view.UpsertDesignDocumentResponse
 
refCnt() - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
 
refCnt() - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.DefaultFullBinaryMemcacheRequest
 
refCnt() - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.DefaultFullBinaryMemcacheResponse
 
refCnt() - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.DefaultMemcacheContent
 
reference() - Method in class com.couchbase.client.core.message.ResponseStatusDetails
 
refresh(ClusterConfig) - Method in class com.couchbase.client.core.config.refresher.CarrierRefresher
 
refresh(ClusterConfig) - Method in class com.couchbase.client.core.config.refresher.HttpRefresher
 
refresh(ClusterConfig) - Method in interface com.couchbase.client.core.config.refresher.Refresher
If pull based, refresh configs for registered buckets.
Refresher - Interface in com.couchbase.client.core.config.refresher
A Refresher keeps bucket configs up to date.
register(T, Stateful<S>) - Method in class com.couchbase.client.core.state.AbstractStateZipper
 
register(T, Stateful<S>) - Method in interface com.couchbase.client.core.state.StateZipper
Register the given stream to be zipped into the state computation.
registerBucket(String, String) - Method in class com.couchbase.client.core.config.refresher.AbstractRefresher
 
registerBucket(String, String, String) - Method in class com.couchbase.client.core.config.refresher.AbstractRefresher
 
registerBucket(String, String) - Method in class com.couchbase.client.core.config.refresher.HttpRefresher
 
registerBucket(String, String, String) - Method in class com.couchbase.client.core.config.refresher.HttpRefresher
 
registerBucket(String, String) - Method in interface com.couchbase.client.core.config.refresher.Refresher
Deprecated.
registerBucket(String, String, String) - Method in interface com.couchbase.client.core.config.refresher.Refresher
Registers a bucket to be watched for new configurations.
registrations() - Method in class com.couchbase.client.core.config.refresher.AbstractRefresher
 
release() - Method in class com.couchbase.client.core.message.kv.AbstractKeyValueResponse
 
release(int) - Method in class com.couchbase.client.core.message.kv.AbstractKeyValueResponse
 
release() - Method in class com.couchbase.client.core.message.view.GetDesignDocumentResponse
 
release(int) - Method in class com.couchbase.client.core.message.view.GetDesignDocumentResponse
 
release() - Method in class com.couchbase.client.core.message.view.RemoveDesignDocumentResponse
 
release(int) - Method in class com.couchbase.client.core.message.view.RemoveDesignDocumentResponse
 
release() - Method in class com.couchbase.client.core.message.view.UpsertDesignDocumentResponse
 
release(int) - Method in class com.couchbase.client.core.message.view.UpsertDesignDocumentResponse
 
release() - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
 
release(int) - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
 
release() - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.DefaultFullBinaryMemcacheRequest
 
release(int) - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.DefaultFullBinaryMemcacheRequest
 
release() - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.DefaultFullBinaryMemcacheResponse
 
release(int) - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.DefaultFullBinaryMemcacheResponse
 
release() - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.DefaultMemcacheContent
 
release(int) - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.DefaultMemcacheContent
 
remote() - Method in class com.couchbase.client.core.message.internal.EndpointHealth
 
remote() - Method in class com.couchbase.client.core.message.internal.PingServiceHealth
 
remoteAddress() - Method in class com.couchbase.client.core.endpoint.AbstractEndpoint
 
remoteAddress() - Method in interface com.couchbase.client.core.endpoint.Endpoint
Returns the remote address as String representation.
remoteAddress0() - Method in class com.couchbase.client.core.endpoint.util.FailedChannel
 
remoteHostname() - Method in class com.couchbase.client.core.endpoint.AbstractGenericHandler
 
remoteHttpHost(ChannelHandlerContext) - Method in class com.couchbase.client.core.endpoint.AbstractGenericHandler
Helper method to return the remote http host, cached.
remoteSocket() - Method in class com.couchbase.client.core.message.analytics.PingRequest
 
remoteSocket(SocketAddress) - Method in class com.couchbase.client.core.message.analytics.PingRequest
 
remoteSocket() - Method in interface com.couchbase.client.core.message.DiagnosticRequest
 
remoteSocket(SocketAddress) - Method in interface com.couchbase.client.core.message.DiagnosticRequest
 
remoteSocket() - Method in class com.couchbase.client.core.message.kv.NoopRequest
 
remoteSocket(SocketAddress) - Method in class com.couchbase.client.core.message.kv.NoopRequest
 
remoteSocket() - Method in class com.couchbase.client.core.message.query.PingRequest
 
remoteSocket(SocketAddress) - Method in class com.couchbase.client.core.message.query.PingRequest
 
remoteSocket() - Method in class com.couchbase.client.core.message.search.PingRequest
 
remoteSocket(SocketAddress) - Method in class com.couchbase.client.core.message.search.PingRequest
 
remoteSocket() - Method in class com.couchbase.client.core.message.view.PingRequest
 
remoteSocket(SocketAddress) - Method in class com.couchbase.client.core.message.view.PingRequest
 
remove(I) - Method in class com.couchbase.client.core.metrics.AbstractLatencyMetricsCollector
Helper method to remove an item out of the stored metrics.
RemoveBucketRequest - Class in com.couchbase.client.core.message.config
 
RemoveBucketRequest(String, String, String) - Constructor for class com.couchbase.client.core.message.config.RemoveBucketRequest
 
RemoveBucketResponse - Class in com.couchbase.client.core.message.config
 
RemoveBucketResponse(ResponseStatus) - Constructor for class com.couchbase.client.core.message.config.RemoveBucketResponse
 
RemoveDesignDocumentRequest - Class in com.couchbase.client.core.message.view
 
RemoveDesignDocumentRequest(String, boolean, String, String) - Constructor for class com.couchbase.client.core.message.view.RemoveDesignDocumentRequest
 
RemoveDesignDocumentRequest(String, boolean, String, String, String) - Constructor for class com.couchbase.client.core.message.view.RemoveDesignDocumentRequest
 
RemoveDesignDocumentResponse - Class in com.couchbase.client.core.message.view
 
RemoveDesignDocumentResponse(ResponseStatus, ByteBuf, CouchbaseRequest) - Constructor for class com.couchbase.client.core.message.view.RemoveDesignDocumentResponse
 
removeNode(NetworkAddress) - Method in class com.couchbase.client.core.RequestHandler
Remove a Node identified by its hostname.
RemoveNodeRequest - Class in com.couchbase.client.core.message.internal
 
RemoveNodeRequest(NetworkAddress) - Constructor for class com.couchbase.client.core.message.internal.RemoveNodeRequest
 
RemoveNodeResponse - Class in com.couchbase.client.core.message.internal
 
RemoveNodeResponse(ResponseStatus) - Constructor for class com.couchbase.client.core.message.internal.RemoveNodeResponse
 
RemoveRequest - Class in com.couchbase.client.core.message.kv
 
RemoveRequest(String, String) - Constructor for class com.couchbase.client.core.message.kv.RemoveRequest
 
RemoveRequest(String, long, String) - Constructor for class com.couchbase.client.core.message.kv.RemoveRequest
 
removeRequest(CouchbaseRequest) - Method in class com.couchbase.client.core.tracing.RingBufferMonitor
 
RemoveResponse - Class in com.couchbase.client.core.message.kv
Represents a response to a RemoveRequest.
RemoveResponse(ResponseStatus, short, long, String, ByteBuf, MutationToken, CouchbaseRequest) - Constructor for class com.couchbase.client.core.message.kv.RemoveResponse
 
RemoveSearchIndexRequest - Class in com.couchbase.client.core.message.search
Removes full text search index.
RemoveSearchIndexRequest(String, String, String) - Constructor for class com.couchbase.client.core.message.search.RemoveSearchIndexRequest
 
RemoveSearchIndexResponse - Class in com.couchbase.client.core.message.search
Result of full text search index removing.
RemoveSearchIndexResponse(String, ResponseStatus) - Constructor for class com.couchbase.client.core.message.search.RemoveSearchIndexResponse
 
removeService(RemoveServiceRequest) - Method in class com.couchbase.client.core.node.CouchbaseNode
 
removeService(Service, String) - Method in class com.couchbase.client.core.node.DefaultServiceRegistry
 
removeService(RemoveServiceRequest) - Method in interface com.couchbase.client.core.node.Node
 
removeService(Service, String) - Method in interface com.couchbase.client.core.node.ServiceRegistry
 
removeService(RemoveServiceRequest) - Method in class com.couchbase.client.core.RequestHandler
Remove a service from a node.
RemoveServiceRequest - Class in com.couchbase.client.core.message.internal
 
RemoveServiceRequest(ServiceType, String, NetworkAddress) - Constructor for class com.couchbase.client.core.message.internal.RemoveServiceRequest
 
RemoveServiceResponse - Class in com.couchbase.client.core.message.internal
 
RemoveServiceResponse(ResponseStatus) - Constructor for class com.couchbase.client.core.message.internal.RemoveServiceResponse
 
RemoveUserRequest - Class in com.couchbase.client.core.message.config
 
RemoveUserRequest(String, String, String, String) - Constructor for class com.couchbase.client.core.message.config.RemoveUserRequest
 
RemoveUserResponse - Class in com.couchbase.client.core.message.config
 
RemoveUserResponse(ResponseStatus) - Constructor for class com.couchbase.client.core.message.config.RemoveUserResponse
 
REPLACE - Static variable in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
replaceHostWildcard(String, NetworkAddress) - Method in class com.couchbase.client.core.config.loader.AbstractLoader
Replaces the host wildcard from an incoming config with a proper hostname.
REPLACEQ - Static variable in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
ReplaceRequest - Class in com.couchbase.client.core.message.kv
 
ReplaceRequest(String, ByteBuf, String) - Constructor for class com.couchbase.client.core.message.kv.ReplaceRequest
Creates a new ReplaceRequest.
ReplaceRequest(String, ByteBuf, String, boolean) - Constructor for class com.couchbase.client.core.message.kv.ReplaceRequest
 
ReplaceRequest(String, ByteBuf, long, String) - Constructor for class com.couchbase.client.core.message.kv.ReplaceRequest
Creates a new ReplaceRequest.
ReplaceRequest(String, ByteBuf, long, String, boolean) - Constructor for class com.couchbase.client.core.message.kv.ReplaceRequest
 
ReplaceRequest(String, ByteBuf, long, int, int, String) - Constructor for class com.couchbase.client.core.message.kv.ReplaceRequest
Creates a new ReplaceRequest.
ReplaceRequest(String, ByteBuf, long, int, int, String, boolean) - Constructor for class com.couchbase.client.core.message.kv.ReplaceRequest
 
ReplaceResponse - Class in com.couchbase.client.core.message.kv
 
ReplaceResponse(ResponseStatus, short, long, String, ByteBuf, MutationToken, CouchbaseRequest) - Constructor for class com.couchbase.client.core.message.kv.ReplaceResponse
 
replica(int) - Method in class com.couchbase.client.core.config.DefaultPartition
 
replica(int) - Method in interface com.couchbase.client.core.config.Partition
Returns the replica index for this partition.
replica() - Method in class com.couchbase.client.core.message.kv.ObserveRequest
 
replica() - Method in class com.couchbase.client.core.message.kv.ObserveSeqnoRequest
 
replica() - Method in class com.couchbase.client.core.message.kv.ReplicaGetRequest
 
ReplicaGetRequest - Class in com.couchbase.client.core.message.kv
Fetch a document from one or more and/or active nodes replicas.
ReplicaGetRequest(String, String, short) - Constructor for class com.couchbase.client.core.message.kv.ReplicaGetRequest
 
ReplicaNotAvailableException - Exception in com.couchbase.client.core
This exception is thrown when the given operation targeting a specific replica is not fulfillable because the replica is not available (the node has been failed over or is marked as down).
ReplicaNotAvailableException(String, Long) - Constructor for exception com.couchbase.client.core.ReplicaNotAvailableException
 
ReplicaNotConfiguredException - Exception in com.couchbase.client.core
This exception is thrown when the given operation targeting a specific replica is not fulfillable because the replica is not configured (for example replica 2 is asked for, but only 1 is configured).
ReplicaNotConfiguredException(String, Long) - Constructor for exception com.couchbase.client.core.ReplicaNotConfiguredException
 
report(CouchbaseResponse) - Method in class com.couchbase.client.core.tracing.DefaultOrphanResponseReporter
Reports the given CouchbaseRequest as a orphan response.
report(CouchbaseResponse) - Method in interface com.couchbase.client.core.tracing.OrphanResponseReporter
 
report(ThresholdLogSpan) - Method in class com.couchbase.client.core.tracing.ThresholdLogReporter
Reports the given span, but it doesn’t have to be a potential slow.
reportSpan(ThresholdLogSpan) - Method in class com.couchbase.client.core.tracing.ThresholdLogTracer
Feeds the span into the reporter for further processing.
request() - Method in class com.couchbase.client.core.message.AbstractCouchbaseResponse
Stub method implementation which needs to be overridden by all responses that support cloning.
request() - Method in class com.couchbase.client.core.message.config.RestApiResponse
 
request() - Method in interface com.couchbase.client.core.message.CouchbaseResponse
Potentially has the associated request attached.
request() - Method in class com.couchbase.client.core.message.kv.subdoc.multi.MultiLookupResponse
 
request() - Method in class com.couchbase.client.core.message.kv.subdoc.multi.MultiMutationResponse
 
request() - Method in class com.couchbase.client.core.message.kv.subdoc.simple.SimpleSubdocResponse
 
request() - Method in class com.couchbase.client.core.metrics.NetworkLatencyMetricsIdentifier
 
request() - Method in class com.couchbase.client.core.tracing.ThresholdLogSpan
 
request(CouchbaseRequest) - Method in class com.couchbase.client.core.tracing.ThresholdLogSpan
 
REQUEST_BUFFER_SIZE - Static variable in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
REQUEST_MAGIC_BYTE - Static variable in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.DefaultBinaryMemcacheRequest
Default magic byte for a request.
requestBufferSize() - Method in interface com.couchbase.client.core.env.CoreEnvironment
Returns the size of the request ringbuffer.
requestBufferSize(int) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Sets the size of the RingBuffer structure that queues requests (default value ).
requestBufferSize() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
requestBufferWaitStrategy() - Method in interface com.couchbase.client.core.env.CoreEnvironment
Waiting strategy used by request EventProcessors to wait for data from RingBuffer
requestBufferWaitStrategy(WaitStrategyFactory) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Sets a custom waiting strategy for requests.
requestBufferWaitStrategy() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
RequestCancelledException - Exception in com.couchbase.client.core
This exception is thrown when there is a problem in the underlying network I/O.
RequestCancelledException() - Constructor for exception com.couchbase.client.core.RequestCancelledException
 
RequestCancelledException(String) - Constructor for exception com.couchbase.client.core.RequestCancelledException
 
RequestCancelledException(String, Throwable) - Constructor for exception com.couchbase.client.core.RequestCancelledException
 
RequestCancelledException(Throwable) - Constructor for exception com.couchbase.client.core.RequestCancelledException
 
RequestEvent - Class in com.couchbase.client.core
A pre allocated event which carries a CouchbaseRequest and associated information.
RequestEvent() - Constructor for class com.couchbase.client.core.RequestEvent
 
RequestEventFactory - Class in com.couchbase.client.core
A factory to preallocate RequestEvents.
RequestEventFactory() - Constructor for class com.couchbase.client.core.RequestEventFactory
 
RequestHandler - Class in com.couchbase.client.core
The RequestHandler is responsible for adding and removing Nodes as well as dispatching Service management operations.
RequestHandler(CoreContext, Observable<ClusterConfig>) - Constructor for class com.couchbase.client.core.RequestHandler
Create a new RequestHandler.
requestId() - Method in class com.couchbase.client.core.message.analytics.GenericAnalyticsResponse
 
requestId() - Method in class com.couchbase.client.core.message.query.GenericQueryResponse
 
requireNonNull(T) - Static method in class com.couchbase.client.core.lang.backport.java.util.Objects
Returns the given object if it is non-null, otherwise throws NullPointerException.
requireNonNull(T, String) - Static method in class com.couchbase.client.core.lang.backport.java.util.Objects
Returns the given object if it is non-null, otherwise throws NullPointerException with the given message.
reset() - Method in class com.couchbase.client.core.tracing.RingBufferMonitor
 
reset() - Method in class com.couchbase.client.core.utils.yasjl.JsonArrayByteBufProcessor
 
reset() - Method in class com.couchbase.client.core.utils.yasjl.JsonBooleanFalseByteBufProcessor
 
reset() - Method in class com.couchbase.client.core.utils.yasjl.JsonBooleanTrueByteBufProcessor
 
reset() - Method in class com.couchbase.client.core.utils.yasjl.JsonNullByteBufProcessor
 
reset() - Method in class com.couchbase.client.core.utils.yasjl.JsonObjectByteBufProcessor
 
reset() - Method in class com.couchbase.client.core.utils.yasjl.JsonStringByteBufProcessor
 
resetDecoder() - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheDecoder
Prepare for next decoding iteration.
RESPONSE_BUFFER_SIZE - Static variable in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
RESPONSE_MAGIC_BYTE - Static variable in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.DefaultBinaryMemcacheResponse
Default magic byte for a request.
RESPONSE_TRANSLATOR - Static variable in class com.couchbase.client.core.ResponseHandler
Translates CouchbaseRequests into RequestEvents.
responseBuffer() - Method in class com.couchbase.client.core.endpoint.AbstractEndpoint
The RingBuffer response buffer reference.
responseBufferSize() - Method in interface com.couchbase.client.core.env.CoreEnvironment
Returns the size of the response ringbuffer.
responseBufferSize(int) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Sets the size of the RingBuffer structure that queues responses (default value ).
responseBufferSize() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
responseCode() - Method in class com.couchbase.client.core.message.view.ViewQueryResponse
 
ResponseEvent - Class in com.couchbase.client.core
A pre allocated event which carries a CouchbaseResponse and associated information.
ResponseEvent() - Constructor for class com.couchbase.client.core.ResponseEvent
 
ResponseEventFactory - Class in com.couchbase.client.core
A factory to preallocate ResponseEvents.
ResponseEventFactory() - Constructor for class com.couchbase.client.core.ResponseEventFactory
 
ResponseHandler - Class in com.couchbase.client.core
 
ResponseHandler(CoreEnvironment, ClusterFacade, ConfigurationProvider) - Constructor for class com.couchbase.client.core.ResponseHandler
Creates a new ResponseHandler.
responsePhrase() - Method in class com.couchbase.client.core.message.view.ViewQueryResponse
 
responseRingBuffer() - Method in class com.couchbase.client.core.CoreContext
Returns the response ring buffer.
responses() - Method in class com.couchbase.client.core.message.kv.subdoc.multi.MultiLookupResponse
 
responses() - Method in class com.couchbase.client.core.message.kv.subdoc.multi.MultiMutationResponse
 
ResponseStatus - Enum in com.couchbase.client.core.message
Typesafe status code returned by CouchbaseResponses.
ResponseStatusConverter - Class in com.couchbase.client.core.endpoint
Helper class to easily convert different handler status types to a common one.
ResponseStatusConverter() - Constructor for class com.couchbase.client.core.endpoint.ResponseStatusConverter
 
ResponseStatusDetails - Class in com.couchbase.client.core.message
Container for extended response status information.
RestApiRequest - Class in com.couchbase.client.core.message.config
A generic HTTP request to perform on the cluster REST API port (8091).
RestApiRequest(String, String, HttpMethod, String, Map<String, String>, Map<String, Object>, String) - Constructor for class com.couchbase.client.core.message.config.RestApiRequest
Create a new API request.
RestApiResponse - Class in com.couchbase.client.core.message.config
Response to a RestApiRequest.
RestApiResponse(RestApiRequest, HttpResponseStatus, HttpHeaders, String) - Constructor for class com.couchbase.client.core.message.config.RestApiResponse
Create a new RestApiResponse.
retain() - Method in class com.couchbase.client.core.message.kv.AbstractKeyValueResponse
 
retain(int) - Method in class com.couchbase.client.core.message.kv.AbstractKeyValueResponse
 
retain() - Method in class com.couchbase.client.core.message.view.GetDesignDocumentResponse
 
retain(int) - Method in class com.couchbase.client.core.message.view.GetDesignDocumentResponse
 
retain() - Method in class com.couchbase.client.core.message.view.RemoveDesignDocumentResponse
 
retain(int) - Method in class com.couchbase.client.core.message.view.RemoveDesignDocumentResponse
 
retain() - Method in class com.couchbase.client.core.message.view.UpsertDesignDocumentResponse
 
retain(int) - Method in class com.couchbase.client.core.message.view.UpsertDesignDocumentResponse
 
retain() - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
 
retain(int) - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
 
retain() - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.DefaultBinaryMemcacheRequest
 
retain(int) - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.DefaultBinaryMemcacheRequest
 
retain() - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.DefaultBinaryMemcacheResponse
 
retain(int) - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.DefaultBinaryMemcacheResponse
 
retain() - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.DefaultFullBinaryMemcacheRequest
 
retain(int) - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.DefaultFullBinaryMemcacheRequest
 
retain() - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.DefaultFullBinaryMemcacheResponse
 
retain(int) - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.DefaultFullBinaryMemcacheResponse
 
retain(int) - Method in interface com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.FullBinaryMemcacheRequest
 
retain() - Method in interface com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.FullBinaryMemcacheRequest
 
retain(int) - Method in interface com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.FullBinaryMemcacheResponse
 
retain() - Method in interface com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.FullBinaryMemcacheResponse
 
retain() - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.DefaultLastMemcacheContent
 
retain(int) - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.DefaultLastMemcacheContent
 
retain() - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.DefaultMemcacheContent
 
retain(int) - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.DefaultMemcacheContent
 
retain(int) - Method in interface com.couchbase.client.deps.io.netty.handler.codec.memcache.FullMemcacheMessage
 
retain() - Method in interface com.couchbase.client.deps.io.netty.handler.codec.memcache.FullMemcacheMessage
 
retain(int) - Method in interface com.couchbase.client.deps.io.netty.handler.codec.memcache.LastMemcacheContent
 
retain() - Method in interface com.couchbase.client.deps.io.netty.handler.codec.memcache.LastMemcacheContent
 
retry(CouchbaseRequest, EventSink<ResponseEvent>) - Static method in class com.couchbase.client.core.retry.RetryHelper
Always retry the request and send it into the response buffer.
RETRY_DELAY - Static variable in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
RETRY_STRATEGY - Static variable in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
retryAfter(long) - Method in class com.couchbase.client.core.message.AbstractCouchbaseRequest
 
retryAfter() - Method in class com.couchbase.client.core.message.AbstractCouchbaseRequest
 
retryAfter(long) - Method in interface com.couchbase.client.core.message.CouchbaseRequest
Sets the initial retry after time for the request.
retryAfter() - Method in interface com.couchbase.client.core.message.CouchbaseRequest
Gets the initial retry after time for the request.
retryCount() - Method in class com.couchbase.client.core.message.AbstractCouchbaseRequest
 
retryCount() - Method in interface com.couchbase.client.core.message.CouchbaseRequest
Returns the current retry count.
retryDelay() - Method in interface com.couchbase.client.core.env.CoreEnvironment
Returns the Delay for request retries.
retryDelay(Delay) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Sets the Delay for retries of requests (default value is a delay growing exponentially between 100us and 100ms).
retryDelay() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
retryDelay(Delay) - Method in class com.couchbase.client.core.message.AbstractCouchbaseRequest
 
retryDelay() - Method in class com.couchbase.client.core.message.AbstractCouchbaseRequest
 
retryDelay(Delay) - Method in interface com.couchbase.client.core.message.CouchbaseRequest
Sets the retry delay config
retryDelay() - Method in interface com.couchbase.client.core.message.CouchbaseRequest
Returns the retry delay config
RetryHelper - Class in com.couchbase.client.core.retry
A helper class which contains methods related to retrying operations.
RetryHelper() - Constructor for class com.couchbase.client.core.retry.RetryHelper
 
retryOrCancel(CoreEnvironment, CouchbaseRequest, EventSink<ResponseEvent>) - Static method in class com.couchbase.client.core.retry.RetryHelper
Either retry or cancel a request, based on the strategy used.
retrySpec() - Method in class com.couchbase.client.core.endpoint.kv.ErrorMap.ErrorCode
 
RetrySpecification(ErrorMap.RetryStrategy, int, int, int, int) - Constructor for class com.couchbase.client.core.endpoint.kv.ErrorMap.RetrySpecification
 
retryStrategy() - Method in interface com.couchbase.client.core.env.CoreEnvironment
The retry strategy on how to dispatch requests in the failure case.
retryStrategy(RetryStrategy) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Sets the RetryStrategy to be used during request retries (default value is a BestEffortRetryStrategy).
retryStrategy() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
RetryStrategy - Interface in com.couchbase.client.core.retry
Base interface for all RetryStrategy implementations.
rev() - Method in interface com.couchbase.client.core.config.BucketConfig
Revision number (optional) for that configuration.
rev() - Method in class com.couchbase.client.core.config.DefaultCouchbaseBucketConfig
 
rev() - Method in class com.couchbase.client.core.config.DefaultMemcachedBucketConfig
 
REVERSE_DNS_PROPERTY - Static variable in class com.couchbase.client.core.utils.NetworkAddress
 
revision() - Method in class com.couchbase.client.core.endpoint.kv.ErrorMap
 
RingBufferDiagnostics - Class in com.couchbase.client.core.tracing
Provides a granular breakdown of the queries in the ringbuffer
RingBufferDiagnostics(Map<ServiceType, Integer>, int) - Constructor for class com.couchbase.client.core.tracing.RingBufferDiagnostics
 
RingBufferMonitor - Class in com.couchbase.client.core.tracing
Stores diagnostics on the main ringbuffer to provide additional context to BackpressureExceptions.
RoundRobinSelectionStrategy - Class in com.couchbase.client.core.service.strategies
Selects the Endpoint based on a round-robin selection of connected Endpoints.
RoundRobinSelectionStrategy() - Constructor for class com.couchbase.client.core.service.strategies.RoundRobinSelectionStrategy
 
rows() - Method in class com.couchbase.client.core.message.analytics.GenericAnalyticsResponse
Contains one ByteBuf for each result item returned by the server.
rows() - Method in class com.couchbase.client.core.message.query.GenericQueryResponse
Contains one ByteBuf for each result item returned by the server.
rows() - Method in class com.couchbase.client.core.message.view.ViewQueryResponse
 
RUNTIME_BEAN - Static variable in class com.couchbase.client.core.env.Diagnostics
 
runtimeInfo(Map<String, Object>) - Static method in class com.couchbase.client.core.env.Diagnostics
Collects system information as delivered from the RuntimeMXBean.
runtimeMetricsCollector() - Method in interface com.couchbase.client.core.env.CoreEnvironment
Returns the collector responsible for aggregating and publishing runtime information like gc and memory.
runtimeMetricsCollector() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
RuntimeMetricsCollector - Class in com.couchbase.client.core.metrics
A MetricsCollector which collects and emits system information like gc, memory or thread usage.
RuntimeMetricsCollector(EventBus, Scheduler, MetricsCollectorConfig) - Constructor for class com.couchbase.client.core.metrics.RuntimeMetricsCollector
 
runtimeMetricsCollectorConfig(MetricsCollectorConfig) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Sets a custom configuration for the RuntimeMetricsCollector.
RuntimeMetricsEvent - Class in com.couchbase.client.core.event.metrics
This event contains collected system stats, like GC, Thread and Memory usage.
RuntimeMetricsEvent(Map<String, Object>) - Constructor for class com.couchbase.client.core.event.metrics.RuntimeMetricsEvent
 

S

sampleSize(int) - Method in class com.couchbase.client.core.tracing.DefaultOrphanResponseReporter.Builder
Allows to customize the sample size per service.
sampleSize(int) - Method in class com.couchbase.client.core.tracing.ThresholdLogReporter.Builder
Allows to customize the sample size per service.
Sasl - Class in com.couchbase.client.core.security.sasl
A wrapper for Sasl which first tries the mechanisms that are supported out of the box and then tries our extended range (provided by ShaSaslClient.
Sasl() - Constructor for class com.couchbase.client.core.security.sasl.Sasl
 
SASL_AUTH - Static variable in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
SASL_LIST_MECHS - Static variable in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
SASL_LIST_MECHS_OPCODE - Static variable in class com.couchbase.client.core.endpoint.kv.KeyValueAuthHandler
The memcache opcode for the SASL mechs list.
SASL_STEP - Static variable in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
scheduleDirect(Action0) - Method in class com.couchbase.client.core.env.CoreScheduler
Schedules the action directly on one of the event loop workers without the additional infrastructure and checking.
scheduler() - Method in interface com.couchbase.client.core.env.CoreEnvironment
Returns the scheduler which should be used for all core actions that need to happen asynchronously.
scheduler(Scheduler) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Deprecated.
scheduler(Scheduler, ShutdownHook) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Sets the Scheduler implementation for the underlying computation framework, along with the action to execute when this environment is shut down.
scheduler() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
scheme() - Method in class com.couchbase.client.core.utils.ConnectionString
 
scope() - Method in class com.couchbase.client.core.message.internal.PingServiceHealth
 
scopeManager() - Method in class com.couchbase.client.core.tracing.ThresholdLogTracer
 
sdk() - Method in class com.couchbase.client.core.message.internal.DiagnosticsReport
 
sdk() - Method in class com.couchbase.client.core.message.internal.PingReport
 
SEARCH_ENDPOINTS - Static variable in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
SearchEndpoint - Class in com.couchbase.client.core.endpoint.search
This endpoint defines the pipeline for search requests and responses (CBFT).
SearchEndpoint(String, String, String, int, CoreContext) - Constructor for class com.couchbase.client.core.endpoint.search.SearchEndpoint
Deprecated.
SearchEndpoint(String, String, String, String, int, CoreContext) - Constructor for class com.couchbase.client.core.endpoint.search.SearchEndpoint
 
searchEndpoints() - Method in interface com.couchbase.client.core.env.CoreEnvironment
The number of search service endpoints.
searchEndpoints(int) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
searchEndpoints() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
SearchHandler - Class in com.couchbase.client.core.endpoint.search
The SearchHandler is responsible for encoding SearchRequests into lower level HttpRequests as well as decoding HttpObjects into CouchbaseResponses.
SearchHandler(AbstractEndpoint, EventSink<ResponseEvent>, boolean, boolean) - Constructor for class com.couchbase.client.core.endpoint.search.SearchHandler
 
SearchHandler.KeepAliveRequest - Class in com.couchbase.client.core.endpoint.search
 
SearchHandler.KeepAliveResponse - Class in com.couchbase.client.core.endpoint.search
 
searchIoPool() - Method in interface com.couchbase.client.core.env.CoreEnvironment
If set returns the IO Pool for the search service, if not returns null.
searchIoPool(EventLoopGroup, ShutdownHook) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Sets the Search I/O Pool implementation for the underlying IO framework, along with the action to execute when this environment is shut down.
searchIoPool() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
SearchLocator - Class in com.couchbase.client.core.node.locate
Round robin node locator for CBFT.
SearchLocator() - Constructor for class com.couchbase.client.core.node.locate.SearchLocator
 
SearchQueryRequest - Class in com.couchbase.client.core.message.search
Runs query against search index.
SearchQueryRequest(String, String, String, String, String) - Constructor for class com.couchbase.client.core.message.search.SearchQueryRequest
 
SearchQueryResponse - Class in com.couchbase.client.core.message.search
Result of the full text search query.
SearchQueryResponse(String, ResponseStatus) - Constructor for class com.couchbase.client.core.message.search.SearchQueryResponse
 
SearchRequest - Interface in com.couchbase.client.core.message.search
Common marker interface for all SearchRequests.
SearchService - Class in com.couchbase.client.core.service
 
SearchService(String, String, String, int, CoreContext) - Constructor for class com.couchbase.client.core.service.SearchService
Deprecated.
SearchService(String, String, String, String, int, CoreContext) - Constructor for class com.couchbase.client.core.service.SearchService
Creates a new SearchService.
searchServiceConfig() - Method in interface com.couchbase.client.core.env.CoreEnvironment
Returns the current SearchService configuration.
searchServiceConfig(SearchServiceConfig) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Allows to set a custom configuration for the Search service.
searchServiceConfig() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
SearchServiceConfig - Class in com.couchbase.client.core.env
 
SecureEnvironment - Interface in com.couchbase.client.core.env
A SecureEnvironment interface defines all methods which environment implementation should have to be accepted by SSLEngineFactory.
seedHosts(Set<NetworkAddress>, boolean) - Method in interface com.couchbase.client.core.config.ConfigurationProvider
Set the initial seed hosts for bootstrap.
seedHosts(Set<NetworkAddress>, boolean) - Method in class com.couchbase.client.core.config.DefaultConfigurationProvider
 
SeedNodesRequest - Class in com.couchbase.client.core.message.cluster
Set up the bootstrap nodes for a ClusterFacade.
SeedNodesRequest() - Constructor for class com.couchbase.client.core.message.cluster.SeedNodesRequest
Creates a SeedNodesRequest with the default hostname (“localhost”).
SeedNodesRequest(String...) - Constructor for class com.couchbase.client.core.message.cluster.SeedNodesRequest
Creates a SeedNodesRequest with the given hostnames.
SeedNodesRequest(List<String>) - Constructor for class com.couchbase.client.core.message.cluster.SeedNodesRequest
Creates a SeedNodesRequest with the given list of hostnames.
SeedNodesResponse - Class in com.couchbase.client.core.message.cluster
Returns the status of a SeedNodesRequest.
SeedNodesResponse(ResponseStatus) - Constructor for class com.couchbase.client.core.message.cluster.SeedNodesResponse
Create a new SeedNodesResponse.
select(CouchbaseRequest, List<Endpoint>) - Method in class com.couchbase.client.core.service.strategies.PartitionSelectionStrategy
 
select(CouchbaseRequest, List<Endpoint>) - Method in class com.couchbase.client.core.service.strategies.RandomSelectionStrategy
 
select(CouchbaseRequest, List<Endpoint>) - Method in class com.couchbase.client.core.service.strategies.RoundRobinSelectionStrategy
Selects an Endpoint for the given CouchbaseRequest.
select(CouchbaseRequest, List<Endpoint>) - Method in interface com.couchbase.client.core.service.strategies.SelectionStrategy
Selects an Endpoint for the given CouchbaseRequest.
SelectionStrategy - Interface in com.couchbase.client.core.service.strategies
Interface which defines a generic selection strategy to select a Endpoint.
self() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
 
send(CouchbaseRequest) - Method in interface com.couchbase.client.core.ClusterFacade
Sends a CouchbaseRequest into the cluster and eventually returns a CouchbaseResponse.
send(CouchbaseRequest) - Method in class com.couchbase.client.core.CouchbaseCore
 
send(CouchbaseRequest) - Method in class com.couchbase.client.core.endpoint.AbstractEndpoint
 
send(CouchbaseRequest) - Method in interface com.couchbase.client.core.endpoint.Endpoint
Sends a CouchbaseRequest into the endpoint and eventually returns a CouchbaseResponse.
send(CouchbaseRequest) - Method in class com.couchbase.client.core.node.CouchbaseNode
 
send(CouchbaseRequest) - Method in interface com.couchbase.client.core.node.Node
Sends a CouchbaseRequest into the node and eventually returns a CouchbaseResponse.
send(CouchbaseRequest) - Method in class com.couchbase.client.core.service.AbstractDynamicService
 
send(CouchbaseRequest) - Method in class com.couchbase.client.core.service.PooledService
 
send(CouchbaseRequest) - Method in interface com.couchbase.client.core.service.Service
Sends a CouchbaseRequest into the service and eventually returns a CouchbaseResponse.
sendTo() - Method in class com.couchbase.client.core.message.analytics.GenericAnalyticsRequest
 
sendTo() - Method in class com.couchbase.client.core.message.analytics.PingRequest
 
sendTo() - Method in interface com.couchbase.client.core.message.PrelocatedRequest
The node to send this request to, or null to use default node location process.
sendTo() - Method in class com.couchbase.client.core.message.query.GenericQueryRequest
 
sendTo() - Method in class com.couchbase.client.core.message.query.PingRequest
 
sendTo() - Method in class com.couchbase.client.core.message.search.PingRequest
 
sendTo() - Method in class com.couchbase.client.core.message.view.PingRequest
 
sequenceNumber() - Method in class com.couchbase.client.core.message.kv.MutationToken
 
serverDuration() - Method in class com.couchbase.client.core.message.kv.AbstractKeyValueResponse
 
serverDuration(long) - Method in class com.couchbase.client.core.message.kv.AbstractKeyValueResponse
 
serverDuration() - Method in interface com.couchbase.client.core.message.kv.BinaryResponse
Returns the reported server duration, if set.
serverDuration(long) - Method in interface com.couchbase.client.core.message.kv.BinaryResponse
Sets the server duration.
ServerFeatures - Enum in com.couchbase.client.core.endpoint
Features the client negotiates with the server on a per-connection basis.
ServerFeaturesEvent - Class in com.couchbase.client.core.endpoint
An event sent by the KeyValueFeatureHandler to list all the negotiated features.
ServerFeaturesEvent(List<ServerFeatures>) - Constructor for class com.couchbase.client.core.endpoint.ServerFeaturesEvent
 
serverStatusCode() - Method in class com.couchbase.client.core.message.kv.AbstractKeyValueResponse
 
serverStatusCode() - Method in interface com.couchbase.client.core.message.kv.BinaryResponse
 
service() - Method in class com.couchbase.client.core.metrics.NetworkLatencyMetricsIdentifier
 
Service - Interface in com.couchbase.client.core.service
Represents a Service on a Node.
Service.EndpointFactory - Interface in com.couchbase.client.core.service
A helper factory which generates endpoints.
SERVICE_ANALYTICS - Static variable in class com.couchbase.client.core.tracing.ThresholdLogReporter
 
SERVICE_FTS - Static variable in class com.couchbase.client.core.tracing.ThresholdLogReporter
 
SERVICE_KV - Static variable in class com.couchbase.client.core.tracing.ThresholdLogReporter
 
SERVICE_N1QL - Static variable in class com.couchbase.client.core.tracing.ThresholdLogReporter
 
SERVICE_VIEW - Static variable in class com.couchbase.client.core.tracing.ThresholdLogReporter
 
serviceBy(ServiceType, String) - Method in class com.couchbase.client.core.node.DefaultServiceRegistry
 
serviceBy(ServiceType, String) - Method in interface com.couchbase.client.core.node.ServiceRegistry
 
serviceEnabled(ServiceType) - Method in class com.couchbase.client.core.config.AbstractBucketConfig
 
serviceEnabled(ServiceType) - Method in interface com.couchbase.client.core.config.BucketConfig
Check if the service is enabled on the bucket.
serviceEnabled(ServiceType) - Method in class com.couchbase.client.core.node.CouchbaseNode
 
serviceEnabled(ServiceType) - Method in interface com.couchbase.client.core.node.Node
True if the given ServiceType is currently enabled on this node, false otherwise.
ServiceFactory - Class in com.couchbase.client.core.service
 
ServiceNotAvailableException - Exception in com.couchbase.client.core
Exception which states that the service is not available for the bucket.
ServiceNotAvailableException() - Constructor for exception com.couchbase.client.core.ServiceNotAvailableException
 
ServiceNotAvailableException(String) - Constructor for exception com.couchbase.client.core.ServiceNotAvailableException
 
ServiceNotAvailableException(String, Throwable) - Constructor for exception com.couchbase.client.core.ServiceNotAvailableException
 
ServiceNotAvailableException(Throwable) - Constructor for exception com.couchbase.client.core.ServiceNotAvailableException
 
ServiceRegistry - Interface in com.couchbase.client.core.node
Handles the registration of services and their associated buckets.
services() - Method in interface com.couchbase.client.core.config.AlternateAddress
The exposed non-ssl services.
services() - Method in class com.couchbase.client.core.config.DefaultAlternateAddress
 
services() - Method in class com.couchbase.client.core.config.DefaultNodeInfo
 
services() - Method in interface com.couchbase.client.core.config.NodeInfo
The exposed non-ssl services.
services() - Method in class com.couchbase.client.core.message.internal.PingReport
 
services() - Method in class com.couchbase.client.core.node.DefaultServiceRegistry
 
services() - Method in interface com.couchbase.client.core.node.ServiceRegistry
Returns all currently stored services, across buckets and globally.
ServiceStateZipper - Class in com.couchbase.client.core.node
Calculates a merged state for all registered services.
ServiceStateZipper(LifecycleState) - Constructor for class com.couchbase.client.core.node.ServiceStateZipper
 
serviceType() - Method in class com.couchbase.client.core.endpoint.AbstractGenericHandler
Returns the ServiceType associated with this handler.
serviceType() - Method in class com.couchbase.client.core.endpoint.analytics.AnalyticsHandler
 
serviceType() - Method in class com.couchbase.client.core.endpoint.config.ConfigHandler
 
serviceType() - Method in class com.couchbase.client.core.endpoint.kv.KeyValueHandler
 
serviceType() - Method in class com.couchbase.client.core.endpoint.query.QueryHandler
 
serviceType() - Method in class com.couchbase.client.core.endpoint.query.QueryHandlerV2
 
serviceType() - Method in class com.couchbase.client.core.endpoint.search.SearchHandler
 
serviceType() - Method in class com.couchbase.client.core.endpoint.view.ViewHandler
 
ServiceType - Enum in com.couchbase.client.core.service
Represents the different ServiceTypes and how they map onto buckets.
SET - Static variable in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
setBaggageItem(String, String) - Method in class com.couchbase.client.core.tracing.ThresholdLogSpan
 
setBucketConfig(String, BucketConfig) - Method in interface com.couchbase.client.core.config.ClusterConfig
Set a bucket config for the given bucket name.
setBucketConfig(String, BucketConfig) - Method in class com.couchbase.client.core.config.DefaultClusterConfig
 
setCAS(long) - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
 
setCAS(long) - Method in interface com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheMessage
Sets the CAS identifier.
setContent(ByteBuf) - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.DefaultFullBinaryMemcacheRequest
 
setContent(ByteBuf) - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.DefaultFullBinaryMemcacheResponse
 
setContent(ByteBuf) - Method in interface com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.FullBinaryMemcacheRequest
 
setContent(ByteBuf) - Method in interface com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.FullBinaryMemcacheResponse
 
setDataType(byte) - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
 
setDataType(byte) - Method in interface com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheMessage
Sets the data type of the message.
setDecoderResult(DecoderResult) - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.AbstractMemcacheObject
 
setDecoderResult(DecoderResult) - Method in interface com.couchbase.client.deps.io.netty.handler.codec.memcache.MemcacheObject
Updates the result of decoding this message.
setDefaultFactory(CouchbaseLoggerFactory) - Static method in class com.couchbase.client.core.logging.CouchbaseLoggerFactory
Changes the default factory.
setExtras(ByteBuf) - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
 
setExtras(ByteBuf) - Method in interface com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheMessage
Sets the extras buffer on the message.
setExtrasLength(byte) - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
 
setExtrasLength(byte) - Method in interface com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheMessage
Set the extras length of the message.
setFramingExtras(ByteBuf) - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
 
setFramingExtras(ByteBuf) - Method in interface com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheMessage
Sets the framing extras buffer on the message.
setFramingExtrasLength(byte) - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
 
setFramingExtrasLength(byte) - Method in interface com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheMessage
Set the framing extras length of the message.
setKey(byte[]) - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
 
setKey(byte[]) - Method in interface com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheMessage
Sets the key of the document.
setKeyLength(short) - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
 
setKeyLength(short) - Method in interface com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheMessage
Set the key length of the message.
setLastKeepAliveLatency(long) - Method in class com.couchbase.client.core.endpoint.AbstractEndpoint
Called by the underlying channel when a keepalive is returned to record how long it took.
setMagic(byte) - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
 
setMagic(byte) - Method in interface com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheMessage
Sets the magic byte.
setMaxCumulationBufferComponents(int) - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.AbstractMemcacheObjectAggregator
Sets the maximum number of components in the cumulation buffer.
setMessage(CouchbaseMessage) - Method in class com.couchbase.client.core.ResponseEvent
Set the new response as a payload for this event.
setObservable(Subject<CouchbaseResponse, CouchbaseResponse>) - Method in class com.couchbase.client.core.ResponseEvent
 
setOpaque(int) - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
 
setOpaque(int) - Method in interface com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheMessage
Sets the opaque value.
setOpcode(byte) - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
 
setOpcode(byte) - Method in interface com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheMessage
Sets the opcode for the message.
setOperationName(String) - Method in class com.couchbase.client.core.tracing.ThresholdLogSpan
 
SETQ - Static variable in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
setRedactionLevel(RedactionLevel) - Static method in class com.couchbase.client.core.logging.CouchbaseLoggerFactory
Changes the redaction level.
setRequest(CouchbaseRequest) - Method in class com.couchbase.client.core.RequestEvent
Set the new request as a payload for this event.
setReserved(short) - Method in interface com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheRequest
Sets the reserved field value.
setReserved(short) - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.DefaultBinaryMemcacheRequest
 
setSkip(int) - Method in class com.couchbase.client.core.service.strategies.RoundRobinSelectionStrategy
Force a value to the skip counter, mainly for testing purposes.
setStatus(short) - Method in interface com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheResponse
Sets the status of the response.
setStatus(short) - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.DefaultBinaryMemcacheResponse
 
setTag(String, String) - Method in class com.couchbase.client.core.tracing.ThresholdLogSpan
 
setTag(String, boolean) - Method in class com.couchbase.client.core.tracing.ThresholdLogSpan
 
setTag(String, Number) - Method in class com.couchbase.client.core.tracing.ThresholdLogSpan
 
setTotalBodyLength(int) - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.AbstractBinaryMemcacheMessage
 
setTotalBodyLength(int) - Method in interface com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheMessage
Sets the total body length.
ShaSaslClient - Class in com.couchbase.client.core.security.sasl
Implementation of a SCRAM-SHA512, SCRAM-SHA256 and SCRAM-SHA1 enabled SaslClient.
ShaSaslClient(CallbackHandler, int) - Constructor for class com.couchbase.client.core.security.sasl.ShaSaslClient
 
ShaSaslClientFactory - Class in com.couchbase.client.core.security.sasl
The SaslClientFactory supporting SCRAM-SHA512, SCRAM-SHA256 and SCRAM-SHA1 authentication methods.
ShaSaslClientFactory() - Constructor for class com.couchbase.client.core.security.sasl.ShaSaslClientFactory
 
shouldRetry(CouchbaseRequest, CoreEnvironment) - Method in class com.couchbase.client.core.retry.BestEffortRetryStrategy
 
shouldRetry(CouchbaseRequest, CoreEnvironment) - Method in class com.couchbase.client.core.retry.FailFastRetryStrategy
 
shouldRetry(CouchbaseRequest, CoreEnvironment) - Method in interface com.couchbase.client.core.retry.RetryStrategy
Decides whether the given CouchbaseRequest should be retried or cancelled.
shouldRetryObserve() - Method in class com.couchbase.client.core.retry.BestEffortRetryStrategy
 
shouldRetryObserve() - Method in class com.couchbase.client.core.retry.FailFastRetryStrategy
 
shouldRetryObserve() - Method in interface com.couchbase.client.core.retry.RetryStrategy
Decides whether ObserveRequests should be retried or cancelled when an error happens.
shouldSendKeepAlive() - Method in class com.couchbase.client.core.endpoint.AbstractGenericHandler
Helper method to check if conditions are met to send a keepalive right now.
shutdown() - Method in interface com.couchbase.client.core.config.ConfigurationProvider
Shutdown the ConfigurationProvider into a terminal state where it cannot be used anymore and all its non-bucket resources are freed.
shutdown() - Method in class com.couchbase.client.core.config.DefaultConfigurationProvider
 
shutdown() - Method in class com.couchbase.client.core.config.refresher.CarrierRefresher
 
shutdown() - Method in class com.couchbase.client.core.config.refresher.HttpRefresher
 
shutdown() - Method in interface com.couchbase.client.core.config.refresher.Refresher
Shuts down all open registration streams.
shutdown() - Method in interface com.couchbase.client.core.env.CoreEnvironment
Shutdown the CoreEnvironment with the default timeout.
shutdown(long, TimeUnit) - Method in interface com.couchbase.client.core.env.CoreEnvironment
Shutdown the CoreEnvironment with a custom timeout.
shutdown() - Method in class com.couchbase.client.core.env.CoreScheduler
 
shutdown() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
shutdown(long, TimeUnit) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
shutdown() - Method in class com.couchbase.client.core.env.resources.IoPoolShutdownHook
 
shutdown() - Method in class com.couchbase.client.core.env.resources.NettyShutdownHook
 
shutdown() - Method in class com.couchbase.client.core.env.resources.NoOpShutdownHook
 
shutdown() - Method in interface com.couchbase.client.core.env.resources.ShutdownHook
 
shutdown() - Method in class com.couchbase.client.core.metrics.AbstractLatencyMetricsCollector
 
shutdown() - Method in class com.couchbase.client.core.metrics.AbstractMetricsCollector
 
shutdown() - Method in interface com.couchbase.client.core.metrics.MetricsCollector
Shuts down the collector (non-reversible) and frees bound resources.
shutdown() - Method in class com.couchbase.client.core.tracing.DefaultOrphanResponseReporter
Stop the reporter and its associated threads.
shutdown() - Method in interface com.couchbase.client.core.tracing.OrphanResponseReporter
 
shutdown() - Method in class com.couchbase.client.core.tracing.ThresholdLogReporter
Stop the reporter and its associated threads.
shutdown() - Method in class com.couchbase.client.core.tracing.ThresholdLogTracer
 
shutdownAsync() - Method in interface com.couchbase.client.core.env.CoreEnvironment
Shutdown the CoreEnvironment in an asynchronous fashion.
shutdownAsync() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
ShutdownHook - Interface in com.couchbase.client.core.env.resources
Interface to describe shutdown behavior for a resource that can be asynchronously shut down.
sideEffectRequestToCancel(REQUEST) - Method in class com.couchbase.client.core.endpoint.AbstractGenericHandler
This method can be overridden as it is called every time an operation is cancelled.
sideEffectRequestToCancel(BinaryRequest) - Method in class com.couchbase.client.core.endpoint.kv.KeyValueHandler
Releasing the content of requests that are to be cancelled.
signalConfigReload() - Method in class com.couchbase.client.core.endpoint.AbstractEndpoint
Signal a “config reload” event to the upper config layers.
SignalConfigReload - Class in com.couchbase.client.core.message.internal
 
SignalFlush - Class in com.couchbase.client.core.message.internal
 
signalOutdated() - Method in interface com.couchbase.client.core.config.ConfigurationProvider
 
signalOutdated() - Method in class com.couchbase.client.core.config.DefaultConfigurationProvider
 
signature() - Method in class com.couchbase.client.core.message.analytics.GenericAnalyticsResponse
Contains a single ByteBuf representing the Analytics json signature of the results.
signature() - Method in class com.couchbase.client.core.message.query.GenericQueryResponse
Contains a single ByteBuf representing the N1QL json signature of the results.
simpleStatement(String, String, String) - Static method in class com.couchbase.client.core.message.analytics.GenericAnalyticsRequest
Creates a GenericAnalyticsRequest and mark it as containing a single simple statement (e.g.
simpleStatement(String, String, String, String) - Static method in class com.couchbase.client.core.message.analytics.GenericAnalyticsRequest
Creates a GenericAnalyticsRequest and mark it as containing a single simple statement (e.g.
simpleStatement(String, String, String) - Static method in class com.couchbase.client.core.message.query.GenericQueryRequest
Creates a GenericQueryRequest and mark it as containing a single simple statement (e.g.
simpleStatement(String, String, String, String) - Static method in class com.couchbase.client.core.message.query.GenericQueryRequest
Creates a GenericQueryRequest and mark it as containing a single simple statement (e.g.
SimpleSubdocResponse - Class in com.couchbase.client.core.message.kv.subdoc.simple
A general-purpose response suitable for most “simple” sub-document operations (BinarySubdocRequest and BinarySubdocMutationRequest), as opposed to “multi-specification” sub-document operations.
SimpleSubdocResponse(ResponseStatus, short, String, ByteBuf, BinarySubdocRequest, long, MutationToken) - Constructor for class com.couchbase.client.core.message.kv.subdoc.simple.SimpleSubdocResponse
 
skip - Variable in class com.couchbase.client.core.service.strategies.RoundRobinSelectionStrategy
 
Slf4JLoggerFactory - Class in com.couchbase.client.core.logging
Logger factory which creates a SLF4J logger.
Slf4JLoggerFactory() - Constructor for class com.couchbase.client.core.logging.Slf4JLoggerFactory
 
SOCKET_CONNECT_TIMEOUT - Static variable in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
socketConnectTimeout() - Method in interface com.couchbase.client.core.env.CoreEnvironment
Returns the amount of time the SDK will wait on the socket connect until an error is raised and handled.
socketConnectTimeout(int) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Sets a custom socket connect timeout.
socketConnectTimeout() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
span() - Method in class com.couchbase.client.core.message.AbstractCouchbaseRequest
 
span(Span, CoreEnvironment) - Method in class com.couchbase.client.core.message.AbstractCouchbaseRequest
 
span() - Method in interface com.couchbase.client.core.message.CouchbaseRequest
Returns the Span for this request if set.
span(Span, CoreEnvironment) - Method in interface com.couchbase.client.core.message.CouchbaseRequest
Allows to set a custom span that should be used.
span() - Method in class com.couchbase.client.core.tracing.ThresholdLogScope
 
spanContext() - Method in class com.couchbase.client.core.tracing.ThresholdLogReference
Returns the current span context.
spanQueueSize(int) - Method in class com.couchbase.client.core.tracing.ThresholdLogReporter.Builder
Allows to configure the queue size for the individual span queues used to track the spans over threshold.
spatial() - Method in class com.couchbase.client.core.message.view.ViewQueryRequest
 
SplitPositionBufProcessor - Class in com.couchbase.client.core.endpoint.util
A ByteBufProcessor to find the position of a single character usable as a split pivot.
SplitPositionBufProcessor(char) - Constructor for class com.couchbase.client.core.endpoint.util.SplitPositionBufProcessor
 
SplitPositionBufProcessor(char, boolean) - Constructor for class com.couchbase.client.core.endpoint.util.SplitPositionBufProcessor
 
SSL_ENABLED - Static variable in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
SSL_KEYSTORE - Static variable in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
SSL_KEYSTORE_FILE - Static variable in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
SSL_KEYSTORE_PASSWORD - Static variable in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
SSL_TRUSTSTORE - Static variable in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
SSL_TRUSTSTORE_FILE - Static variable in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
SSL_TRUSTSTORE_PASSWORD - Static variable in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
sslEnabled(boolean) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Set if SSL should be enabled (default value ).
sslEnabled() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
sslEnabled() - Method in interface com.couchbase.client.core.env.SecureEnvironment
Identifies if SSL should be enabled.
SSLEngineFactory - Class in com.couchbase.client.core.endpoint
Creates a SSLEngine which will be passed into the handler if SSL is enabled.
SSLEngineFactory(SecureEnvironment) - Constructor for class com.couchbase.client.core.endpoint.SSLEngineFactory
Create a new engine factory.
SSLException - Exception in com.couchbase.client.core.endpoint
Generic SSLException.
SSLException() - Constructor for exception com.couchbase.client.core.endpoint.SSLException
 
SSLException(String) - Constructor for exception com.couchbase.client.core.endpoint.SSLException
 
SSLException(String, Throwable) - Constructor for exception com.couchbase.client.core.endpoint.SSLException
 
SSLException(Throwable) - Constructor for exception com.couchbase.client.core.endpoint.SSLException
 
sslKeystore(KeyStore) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Sets the SSL Keystore directly and not indirectly via filepath.
sslKeystore() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
sslKeystore() - Method in interface com.couchbase.client.core.env.SecureEnvironment
Allows to directly configure a KeyStore.
sslKeystoreFile(String) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Defines the location of the SSL Keystore file (default value null, none).
sslKeystoreFile() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
sslKeystoreFile() - Method in interface com.couchbase.client.core.env.SecureEnvironment
Identifies the filepath to the ssl keystore.
sslKeystorePassword(String) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Sets the SSL Keystore password to be used with the Keystore file (default value null, none).
sslKeystorePassword() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
sslKeystorePassword() - Method in interface com.couchbase.client.core.env.SecureEnvironment
The password which is used to protect the keystore.
sslPorts() - Method in class com.couchbase.client.core.config.DefaultPortInfo
 
sslPorts() - Method in interface com.couchbase.client.core.config.PortInfo
 
sslServices() - Method in interface com.couchbase.client.core.config.AlternateAddress
The exposed ssl services.
sslServices() - Method in class com.couchbase.client.core.config.DefaultAlternateAddress
 
sslServices() - Method in class com.couchbase.client.core.config.DefaultNodeInfo
 
sslServices() - Method in interface com.couchbase.client.core.config.NodeInfo
The exposed ssl services.
sslTruststore(KeyStore) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Sets the SSL Keystore for the TrustStore directly and not indirectly via filepath.
sslTruststore() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
sslTruststore() - Method in interface com.couchbase.client.core.env.SecureEnvironment
Allows to directly configure a KeyStore.
sslTruststoreFile(String) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Defines the location of the SSL TrustStore keystore file (default value null, none).
sslTruststoreFile() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
sslTruststoreFile() - Method in interface com.couchbase.client.core.env.SecureEnvironment
Identifies the filepath to the ssl TrustManager keystore.
sslTruststorePassword(String) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Sets the SSL TrustStore password to be used with the Keystore file (default value null, none).
sslTruststorePassword() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
sslTruststorePassword() - Method in interface com.couchbase.client.core.env.SecureEnvironment
The password which is used to protect the TrustManager keystore.
StandardMemcachedHashingStrategy - Class in com.couchbase.client.core.node
A MemcachedHashingStrategy which is compatible with libcouchbase and SDKs that are built on top.
start() - Method in class com.couchbase.client.core.env.CoreScheduler
 
start() - Method in class com.couchbase.client.core.tracing.ThresholdLogSpanBuilder
 
startActive(boolean) - Method in class com.couchbase.client.core.tracing.ThresholdLogSpanBuilder
 
startManual() - Method in class com.couchbase.client.core.tracing.ThresholdLogSpanBuilder
 
Stat - Class in com.couchbase.client.core.message.stat
Utility class to handle STAT calls logic.
Stat() - Constructor for class com.couchbase.client.core.message.stat.Stat
 
STAT - Static variable in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
state() - Method in class com.couchbase.client.core.message.internal.EndpointHealth
 
state() - Method in class com.couchbase.client.core.message.internal.PingServiceHealth
 
state() - Method in class com.couchbase.client.core.state.AbstractStateMachine
 
state() - Method in interface com.couchbase.client.core.state.Stateful
Returns the current state.
Stateful<S extends Enum> - Interface in com.couchbase.client.core.state
A stateful component that changes its state and notifies subscribed parties.
states() - Method in class com.couchbase.client.core.state.AbstractStateMachine
 
states() - Method in interface com.couchbase.client.core.state.Stateful
Returns a infinite observable which gets updated when the state of the component changes.
StateZipper<T,S extends Enum> - Interface in com.couchbase.client.core.state
Describes a generic StateZipper.
StatRequest - Class in com.couchbase.client.core.message.kv
 
StatRequest(String, NetworkAddress, String) - Constructor for class com.couchbase.client.core.message.kv.StatRequest
 
StatResponse - Class in com.couchbase.client.core.message.kv
 
StatResponse(ResponseStatus, short, String, String, String, String, CouchbaseRequest) - Constructor for class com.couchbase.client.core.message.kv.StatResponse
 
status() - Method in class com.couchbase.client.core.message.AbstractCouchbaseResponse
 
status() - Method in interface com.couchbase.client.core.message.CouchbaseResponse
The typesafe status of the response.
status() - Method in class com.couchbase.client.core.message.kv.subdoc.multi.MultiResult
Returns the individual operation’s status.
status() - Method in class com.couchbase.client.core.metrics.NetworkLatencyMetricsIdentifier
 
statusCode() - Method in class com.couchbase.client.core.message.kv.subdoc.multi.MultiResult
 
statusDetails() - Method in class com.couchbase.client.core.message.AbstractCouchbaseResponse
 
statusDetails(ResponseStatusDetails) - Method in class com.couchbase.client.core.message.AbstractCouchbaseResponse
 
statusDetails() - Method in interface com.couchbase.client.core.message.CouchbaseResponse
If set, provides more detailed information into the response status than the always available ResponseStatus enum.
statusDetails(ResponseStatusDetails) - Method in interface com.couchbase.client.core.message.CouchbaseResponse
Set the status details if not set previously.
strategy() - Method in class com.couchbase.client.core.endpoint.kv.ErrorMap.RetrySpecification
 
strategy() - Method in enum com.couchbase.client.core.endpoint.kv.ErrorMap.RetryStrategy
 
streamingUri() - Method in class com.couchbase.client.core.config.AbstractBucketConfig
 
streamingUri() - Method in interface com.couchbase.client.core.config.BucketConfig
The HTTP Streaming URI for this bucket.
StringClosingPositionBufProcessor - Class in com.couchbase.client.core.endpoint.util
A ByteBufProcessor to find the closing position of a JSON string.
StringClosingPositionBufProcessor() - Constructor for class com.couchbase.client.core.endpoint.util.StringClosingPositionBufProcessor
 
stringify(ResponseStatus, ResponseStatusDetails) - Static method in class com.couchbase.client.core.message.ResponseStatusDetails
Stringify the status details and the status in a best effort manner.
stringPropertyOr(String, String) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
SubArrayRequest - Class in com.couchbase.client.core.message.kv.subdoc.simple
A request covering all sub-document array operations (see SubArrayRequest.ArrayOperation).
SubArrayRequest(String, String, SubArrayRequest.ArrayOperation, ByteBuf, String, int, long) - Constructor for class com.couchbase.client.core.message.kv.subdoc.simple.SubArrayRequest
Creates a new SubArrayRequest of type arrayOp.
SubArrayRequest(String, String, SubArrayRequest.ArrayOperation, ByteBuf, String) - Constructor for class com.couchbase.client.core.message.kv.subdoc.simple.SubArrayRequest
Creates a new SubArrayRequest of type arrayOp.
SubArrayRequest.ArrayOperation - Enum in com.couchbase.client.core.message.kv.subdoc.simple
 
SubCounterRequest - Class in com.couchbase.client.core.message.kv.subdoc.simple
A sub-document counter operation.
SubCounterRequest(String, String, long, String, int, long) - Constructor for class com.couchbase.client.core.message.kv.subdoc.simple.SubCounterRequest
Creates a new SubCounterRequest.
SubCounterRequest(String, String, long, String) - Constructor for class com.couchbase.client.core.message.kv.subdoc.simple.SubCounterRequest
Creates a new SubCounterRequest.
SubDeleteRequest - Class in com.couchbase.client.core.message.kv.subdoc.simple
A sub-document delete operation.
SubDeleteRequest(String, String, String, int, long) - Constructor for class com.couchbase.client.core.message.kv.subdoc.simple.SubDeleteRequest
Creates a new SubDeleteRequest.
SubDeleteRequest(String, String, String) - Constructor for class com.couchbase.client.core.message.kv.subdoc.simple.SubDeleteRequest
Creates a new SubDeleteRequest.
SubDictAddRequest - Class in com.couchbase.client.core.message.kv.subdoc.simple
A sub-document dictionary add operation.
SubDictAddRequest(String, String, ByteBuf, String) - Constructor for class com.couchbase.client.core.message.kv.subdoc.simple.SubDictAddRequest
Creates a new SubDictAddRequest.
SubDictAddRequest(String, String, ByteBuf, String, int, long) - Constructor for class com.couchbase.client.core.message.kv.subdoc.simple.SubDictAddRequest
Creates a new SubDictAddRequest.
SubDictUpsertRequest - Class in com.couchbase.client.core.message.kv.subdoc.simple
A sub-document dictionary upsert operation.
SubDictUpsertRequest(String, String, ByteBuf, String) - Constructor for class com.couchbase.client.core.message.kv.subdoc.simple.SubDictUpsertRequest
Creates a new SubDictUpsertRequest.
SubDictUpsertRequest(String, String, ByteBuf, String, int, long) - Constructor for class com.couchbase.client.core.message.kv.subdoc.simple.SubDictUpsertRequest
Creates a new SubDictUpsertRequest.
SUBDOC_BITMASK_MKDIR_P - Static variable in class com.couchbase.client.core.endpoint.kv.KeyValueHandler
The bitmask for sub-document extras “command” section (third byte of the extras) that activates the creation of missing intermediate nodes in the JSON path.
SUBDOC_DOCFLAG_ACCESS_DELETED - Static variable in class com.couchbase.client.core.endpoint.kv.KeyValueHandler
The bitmask for sub-document access deleted
SUBDOC_DOCFLAG_INSERT - Static variable in class com.couchbase.client.core.endpoint.kv.KeyValueHandler
The bitmask for sub-document insert document
SUBDOC_DOCFLAG_MKDOC - Static variable in class com.couchbase.client.core.endpoint.kv.KeyValueHandler
The bitmask for sub-document create document
SUBDOC_FLAG_XATTR_PATH - Static variable in class com.couchbase.client.core.endpoint.kv.KeyValueHandler
The bitmask for sub-document xattr/hidden section of the document
SubExistRequest - Class in com.couchbase.client.core.message.kv.subdoc.simple
A sub-document exist operation.
SubExistRequest(String, String, String) - Constructor for class com.couchbase.client.core.message.kv.subdoc.simple.SubExistRequest
Creates a new SubExistRequest.
SubGetCountRequest - Class in com.couchbase.client.core.message.kv.subdoc.simple
A sub-document get count operation.
SubGetCountRequest(String, String, String) - Constructor for class com.couchbase.client.core.message.kv.subdoc.simple.SubGetCountRequest
Creates a new SubGetCountRequest.
SubGetRequest - Class in com.couchbase.client.core.message.kv.subdoc.simple
A sub-document get operation.
SubGetRequest(String, String, String) - Constructor for class com.couchbase.client.core.message.kv.subdoc.simple.SubGetRequest
Creates a new SubGetRequest.
SubMultiLookupDocOptionsBuilder - Class in com.couchbase.client.core.message.kv.subdoc.multi
Document options for SubMultiLookupRequest
SubMultiLookupDocOptionsBuilder() - Constructor for class com.couchbase.client.core.message.kv.subdoc.multi.SubMultiLookupDocOptionsBuilder
 
SubMultiLookupRequest - Class in com.couchbase.client.core.message.kv.subdoc.multi
Concrete implementation of a BinarySubdocMultiLookupRequest.
SubMultiLookupRequest(String, String, SubMultiLookupDocOptionsBuilder, LookupCommand...) - Constructor for class com.couchbase.client.core.message.kv.subdoc.multi.SubMultiLookupRequest
Creates a new SubMultiLookupRequest.
SubMultiLookupRequest(String, String, LookupCommand...) - Constructor for class com.couchbase.client.core.message.kv.subdoc.multi.SubMultiLookupRequest
Creates a new SubMultiLookupRequest.
SubMultiMutationDocOptionsBuilder - Class in com.couchbase.client.core.message.kv.subdoc.multi
Document options for SubMultiMutationRequest
SubMultiMutationDocOptionsBuilder() - Constructor for class com.couchbase.client.core.message.kv.subdoc.multi.SubMultiMutationDocOptionsBuilder
 
SubMultiMutationRequest - Class in com.couchbase.client.core.message.kv.subdoc.multi
Concrete implementation of a BinarySubdocMultiMutationRequest.
SubMultiMutationRequest(String, String, int, long, SubMultiMutationDocOptionsBuilder, List<MutationCommand>) - Constructor for class com.couchbase.client.core.message.kv.subdoc.multi.SubMultiMutationRequest
SubMultiMutationRequest(String, String, int, long, SubMultiMutationDocOptionsBuilder, MutationCommand...) - Constructor for class com.couchbase.client.core.message.kv.subdoc.multi.SubMultiMutationRequest
SubMultiMutationRequest(String, String, List<MutationCommand>) - Constructor for class com.couchbase.client.core.message.kv.subdoc.multi.SubMultiMutationRequest
SubMultiMutationRequest(String, String, SubMultiMutationDocOptionsBuilder, List<MutationCommand>) - Constructor for class com.couchbase.client.core.message.kv.subdoc.multi.SubMultiMutationRequest
SubMultiMutationRequest(String, String, MutationCommand...) - Constructor for class com.couchbase.client.core.message.kv.subdoc.multi.SubMultiMutationRequest
SubMultiMutationRequest(String, String, SubMultiMutationDocOptionsBuilder, MutationCommand...) - Constructor for class com.couchbase.client.core.message.kv.subdoc.multi.SubMultiMutationRequest
SubReplaceRequest - Class in com.couchbase.client.core.message.kv.subdoc.simple
A sub-document replace operation.
SubReplaceRequest(String, String, ByteBuf, String, int, long) - Constructor for class com.couchbase.client.core.message.kv.subdoc.simple.SubReplaceRequest
Creates a new SubReplaceRequest.
SubReplaceRequest(String, String, ByteBuf, String) - Constructor for class com.couchbase.client.core.message.kv.subdoc.simple.SubReplaceRequest
Creates a new SubReplaceRequest.
subscriber(Subscriber) - Method in class com.couchbase.client.core.message.AbstractCouchbaseRequest
 
subscriber(Subscriber) - Method in interface com.couchbase.client.core.message.CouchbaseRequest
Optionally add subscriber to check for the timeouts
succeed(CouchbaseResponse) - Method in class com.couchbase.client.core.message.AbstractCouchbaseRequest
 
succeed(CouchbaseResponse) - Method in interface com.couchbase.client.core.message.CouchbaseRequest
Emits the CouchbaseResponse into the underlying state holder (like a subject) and completes it as well per contract.
SUCCESS - Static variable in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheResponseStatus
 
supportedFeatures() - Method in class com.couchbase.client.core.endpoint.ServerFeaturesEvent
 
swap() - Method in class com.couchbase.client.core.lang.Tuple2
Create a new Tuple2 where the two values are swapped.
system(Object) - Static method in class com.couchbase.client.core.logging.RedactableArgument
A redactable argument of system data.
systemInfo(Map<String, Object>) - Static method in class com.couchbase.client.core.env.Diagnostics
Collects system information as delivered from the OperatingSystemMXBean.

T

tag(String) - Method in class com.couchbase.client.core.tracing.ThresholdLogSpan
Returns a tag if set, null otherwise.
tags() - Method in class com.couchbase.client.core.tracing.ThresholdLogSpan
Returns the set tags.
tainted() - Method in interface com.couchbase.client.core.config.BucketConfig
Returns true if the config indicates the cluster is undergoing a transition (such as a rebalance operation).
tainted() - Method in class com.couchbase.client.core.config.CouchbasePartitionInfo
 
tainted() - Method in class com.couchbase.client.core.config.DefaultCouchbaseBucketConfig
 
tainted() - Method in class com.couchbase.client.core.config.DefaultMemcachedBucketConfig
 
TARGET_PERCENTILES - Static variable in class com.couchbase.client.core.metrics.DefaultLatencyMetricsCollectorConfig
 
TARGET_UNIT - Static variable in class com.couchbase.client.core.metrics.DefaultLatencyMetricsCollectorConfig
 
targetPercentiles(Double[]) - Method in class com.couchbase.client.core.metrics.DefaultLatencyMetricsCollectorConfig.Builder
Overrides the emitted percentiles.
targetPercentiles() - Method in class com.couchbase.client.core.metrics.DefaultLatencyMetricsCollectorConfig
 
targetPercentiles() - Method in interface com.couchbase.client.core.metrics.LatencyMetricsCollectorConfig
The percentiles which should be exposed in the metric.
targetUnit(TimeUnit) - Method in class com.couchbase.client.core.metrics.DefaultLatencyMetricsCollectorConfig.Builder
Overrides the target unit for the latencies recorded.
targetUnit() - Method in class com.couchbase.client.core.metrics.DefaultLatencyMetricsCollectorConfig
 
targetUnit() - Method in interface com.couchbase.client.core.metrics.LatencyMetricsCollectorConfig
The target unit for the emitted latencies.
TCP_NODELAY_ENALED - Static variable in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
tcpNodelayEnabled() - Method in interface com.couchbase.client.core.env.CoreEnvironment
Returns true if TCP_NODELAY is enabled (therefore Nagle’ing is disabled).
tcpNodelayEnabled(boolean) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
If TCP_NODELAY is manually disabled, Nagle’ing will take effect on both the client and (if supported) the server side.
tcpNodelayEnabled() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
terminate() - Method in class com.couchbase.client.core.state.AbstractStateZipper
 
terminate() - Method in interface com.couchbase.client.core.state.StateZipper
Terminate the zipper and deregister all registered streams.
THREAD_BEAN - Static variable in class com.couchbase.client.core.env.Diagnostics
 
threadInfo(Map<String, Object>) - Static method in class com.couchbase.client.core.env.Diagnostics
Collects system information as delivered from the ThreadMXBean.
ThresholdLogReference - Class in com.couchbase.client.core.tracing
Represents a reference from one span to another one.
ThresholdLogReporter - Class in com.couchbase.client.core.tracing
The ThresholdLogReporter retrieves spans from (usually) a Tracer and stores them for threshold-based aggregation and logging.
ThresholdLogReporter.Builder - Class in com.couchbase.client.core.tracing
The builder used to configure the ThresholdLogReporter.
ThresholdLogScope - Class in com.couchbase.client.core.tracing
ThresholdLogScope is a simple Scope implementation that relies on Java’s thread-local storage primitive, very similar to the one shipped with “opentracing-util”.
ThresholdLogScopeManager - Class in com.couchbase.client.core.tracing
A ScopeManager implementation built on top of Java’s thread-local storage primitive, very similar to the one shipped with “opentracing-util”.
ThresholdLogScopeManager() - Constructor for class com.couchbase.client.core.tracing.ThresholdLogScopeManager
 
ThresholdLogSpan - Class in com.couchbase.client.core.tracing
 
ThresholdLogSpanBuilder - Class in com.couchbase.client.core.tracing
Allows to build a Span in a builder fashion.
ThresholdLogSpanContext - Class in com.couchbase.client.core.tracing
Holds baggage items for the slow operation spans.
ThresholdLogSpanContext() - Constructor for class com.couchbase.client.core.tracing.ThresholdLogSpanContext
Creates a new ThresholdLogSpanContext with empty baggage.
ThresholdLogTracer - Class in com.couchbase.client.core.tracing
This Tracer implementation logs operations over a certain threshold based on the given configuration.
timeUnit() - Method in class com.couchbase.client.core.event.metrics.LatencyMetric
Returns the time unit for the percentiles, min and max values.
toAddrString(InetAddress) - Static method in class com.couchbase.client.core.utils.InetAddresses
Returns the string representation of an InetAddress.
toJson(CouchbaseEvent, boolean) - Static method in class com.couchbase.client.core.utils.Events
Takes a CouchbaseEvent and generates a JSON string.
tokens() - Method in class com.couchbase.client.core.utils.yasjl.JsonPointer
Returns the list of currently stored tokens.
toMap() - Method in interface com.couchbase.client.core.event.CouchbaseEvent
Converts the event into a map representation of simple types.
toMap() - Method in class com.couchbase.client.core.event.metrics.NetworkLatencyMetricsEvent
 
toMap() - Method in class com.couchbase.client.core.event.metrics.RuntimeMetricsEvent
 
toMap() - Method in class com.couchbase.client.core.event.system.BucketClosedEvent
 
toMap() - Method in class com.couchbase.client.core.event.system.BucketOpenedEvent
 
toMap() - Method in class com.couchbase.client.core.event.system.ConfigUpdatedEvent
 
toMap() - Method in class com.couchbase.client.core.event.system.NodeConnectedEvent
 
toMap() - Method in class com.couchbase.client.core.event.system.NodeDisconnectedEvent
 
toMap() - Method in class com.couchbase.client.core.event.system.TooManyEnvironmentsEvent
 
toMap() - Method in class com.couchbase.client.core.message.internal.EndpointHealth
 
toMap() - Method in class com.couchbase.client.core.message.internal.PingServiceHealth
 
TooManyEnvironmentsEvent - Class in com.couchbase.client.core.event.system
Event published when more than one Environments are created.
TooManyEnvironmentsEvent(int) - Constructor for class com.couchbase.client.core.event.system.TooManyEnvironmentsEvent
 
toString() - Method in exception com.couchbase.client.core.BackpressureException
 
toString() - Method in class com.couchbase.client.core.config.CouchbasePartitionInfo
 
toString() - Method in class com.couchbase.client.core.config.DefaultAlternateAddress
 
toString() - Method in class com.couchbase.client.core.config.DefaultClusterConfig
 
toString() - Method in class com.couchbase.client.core.config.DefaultCouchbaseBucketConfig
 
toString() - Method in class com.couchbase.client.core.config.DefaultMemcachedBucketConfig
 
toString() - Method in class com.couchbase.client.core.config.DefaultNodeInfo
 
toString() - Method in class com.couchbase.client.core.config.DefaultPartition
 
toString() - Method in class com.couchbase.client.core.config.DefaultPortInfo
 
toString() - Method in class com.couchbase.client.core.endpoint.kv.ErrorMap.ErrorCode
 
toString() - Method in class com.couchbase.client.core.endpoint.kv.ErrorMap.RetrySpecification
 
toString() - Method in class com.couchbase.client.core.endpoint.kv.ErrorMap
 
toString() - Method in class com.couchbase.client.core.env.AbstractServiceConfig
 
toString() - Method in class com.couchbase.client.core.env.AnalyticsServiceConfig
 
toString() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
toString() - Method in class com.couchbase.client.core.env.KeyValueServiceConfig
 
toString() - Method in class com.couchbase.client.core.env.NetworkResolution
 
toString() - Method in class com.couchbase.client.core.env.QueryServiceConfig
 
toString() - Method in class com.couchbase.client.core.env.SearchServiceConfig
 
toString() - Method in class com.couchbase.client.core.env.ViewServiceConfig
 
toString() - Method in class com.couchbase.client.core.event.metrics.LatencyMetric
 
toString() - Method in class com.couchbase.client.core.event.metrics.LatencyMetricsEvent
 
toString() - Method in class com.couchbase.client.core.event.metrics.NetworkLatencyMetricsEvent
 
toString() - Method in class com.couchbase.client.core.event.metrics.RuntimeMetricsEvent
 
toString() - Method in class com.couchbase.client.core.event.system.BucketClosedEvent
 
toString() - Method in class com.couchbase.client.core.event.system.BucketOpenedEvent
 
toString() - Method in class com.couchbase.client.core.event.system.ConfigUpdatedEvent
 
toString() - Method in class com.couchbase.client.core.event.system.NodeConnectedEvent
 
toString() - Method in class com.couchbase.client.core.event.system.NodeDisconnectedEvent
 
toString() - Method in class com.couchbase.client.core.event.system.TooManyEnvironmentsEvent
 
toString() - Method in class com.couchbase.client.core.lang.Tuple2
 
toString() - Method in class com.couchbase.client.core.lang.Tuple3
 
toString() - Method in class com.couchbase.client.core.lang.Tuple4
 
toString() - Method in class com.couchbase.client.core.lang.Tuple5
 
toString() - Method in class com.couchbase.client.core.logging.AbstractCouchbaseLogger
 
toString() - Method in class com.couchbase.client.core.logging.RedactableArgument
 
toString() - Method in class com.couchbase.client.core.message.AbstractCouchbaseRequest
 
toString() - Method in class com.couchbase.client.core.message.AbstractCouchbaseResponse
 
toString() - Method in class com.couchbase.client.core.message.config.BucketConfigResponse
 
toString() - Method in class com.couchbase.client.core.message.config.BucketsConfigResponse
 
toString() - Method in class com.couchbase.client.core.message.config.ClusterConfigResponse
 
toString() - Method in class com.couchbase.client.core.message.config.InsertBucketResponse
 
toString() - Method in class com.couchbase.client.core.message.config.UpdateBucketResponse
 
toString() - Method in class com.couchbase.client.core.message.internal.AddServiceRequest
 
toString() - Method in class com.couchbase.client.core.message.internal.DiagnosticsReport
 
toString() - Method in class com.couchbase.client.core.message.internal.EndpointHealth
 
toString() - Method in class com.couchbase.client.core.message.internal.PingReport
 
toString() - Method in class com.couchbase.client.core.message.internal.PingServiceHealth
 
toString() - Method in class com.couchbase.client.core.message.kv.AbstractKeyValueResponse
 
toString() - Method in class com.couchbase.client.core.message.kv.FailoverObserveSeqnoResponse
 
toString() - Method in class com.couchbase.client.core.message.kv.GetAllMutationTokensResponse
 
toString() - Method in class com.couchbase.client.core.message.kv.GetResponse
 
toString() - Method in class com.couchbase.client.core.message.kv.MutationToken
 
toString() - Method in class com.couchbase.client.core.message.kv.NoFailoverObserveSeqnoResponse
 
toString() - Method in class com.couchbase.client.core.message.kv.ObserveResponse
 
toString() - Method in class com.couchbase.client.core.message.kv.StatResponse
 
toString() - Method in class com.couchbase.client.core.message.kv.subdoc.multi.MultiResult
 
toString() - Method in class com.couchbase.client.core.message.kv.subdoc.multi.SubMultiLookupDocOptionsBuilder
 
toString() - Method in class com.couchbase.client.core.message.kv.subdoc.multi.SubMultiMutationDocOptionsBuilder
 
toString() - Method in class com.couchbase.client.core.message.ResponseStatusDetails
 
toString() - Method in class com.couchbase.client.core.message.search.GetSearchIndexResponse
 
toString() - Method in class com.couchbase.client.core.message.search.RemoveSearchIndexResponse
 
toString() - Method in class com.couchbase.client.core.message.search.SearchQueryResponse
 
toString() - Method in class com.couchbase.client.core.message.search.UpsertSearchIndexResponse
 
toString() - Method in class com.couchbase.client.core.metrics.NetworkLatencyMetricsIdentifier
 
toString() - Method in class com.couchbase.client.core.node.CouchbaseNode
 
toString() - Method in class com.couchbase.client.core.node.DefaultServiceRegistry
 
toString() - Method in class com.couchbase.client.core.RequestEvent
 
toString() - Method in class com.couchbase.client.core.ResponseEvent
 
toString() - Method in class com.couchbase.client.core.retry.BestEffortRetryStrategy
 
toString() - Method in class com.couchbase.client.core.retry.FailFastRetryStrategy
 
toString() - Method in class com.couchbase.client.core.time.ExponentialDelay
 
toString() - Method in class com.couchbase.client.core.time.FixedDelay
 
toString() - Method in class com.couchbase.client.core.time.LinearDelay
 
toString() - Method in class com.couchbase.client.core.tracing.RingBufferDiagnostics
 
toString() - Method in class com.couchbase.client.core.tracing.ThresholdLogSpan
 
toString() - Method in class com.couchbase.client.core.utils.ConnectionString
 
toString() - Method in class com.couchbase.client.core.utils.NetworkAddress
 
toString() - Method in class com.couchbase.client.core.utils.yasjl.JsonPointer
 
toString() - Method in class com.couchbase.client.core.utils.yasjl.JsonPointerTree
 
toString() - Method in class com.couchbase.client.deps.io.netty.handler.codec.memcache.DefaultMemcacheContent
 
totalCount() - Method in class com.couchbase.client.core.tracing.RingBufferDiagnostics
Returns the count of all requests in the ringbuffer
touch() - Method in class com.couchbase.client.core.message.kv.GetRequest
 
TOUCH - Static variable in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
touchesReplica() - Method in enum com.couchbase.client.core.message.observe.Observe.PersistTo
Identifies if this enum property will touch a replica or just the master.
touchesReplica() - Method in enum com.couchbase.client.core.message.observe.Observe.ReplicateTo
Identifies if this enum property will touch a replica or just the master.
TouchRequest - Class in com.couchbase.client.core.message.kv
 
TouchRequest(String, int, String) - Constructor for class com.couchbase.client.core.message.kv.TouchRequest
 
TouchResponse - Class in com.couchbase.client.core.message.kv
.
TouchResponse(ResponseStatus, short, String, ByteBuf, CouchbaseRequest) - Constructor for class com.couchbase.client.core.message.kv.TouchResponse
 
toUriString(InetAddress) - Static method in class com.couchbase.client.core.utils.InetAddresses
Returns the string representation of an InetAddress suitable for inclusion in a URI.
trace(Throwable) - Method in class com.couchbase.client.core.logging.AbstractCouchbaseLogger
 
trace(String) - Method in interface com.couchbase.client.core.logging.CouchbaseLogger
Log a message at the TRACE level.
trace(String, Object) - Method in interface com.couchbase.client.core.logging.CouchbaseLogger
Log a message at the TRACE level according to the specified format and argument.
trace(String, Object, Object) - Method in interface com.couchbase.client.core.logging.CouchbaseLogger
Log a message at the TRACE level according to the specified format and arguments.
trace(String, Object...) - Method in interface com.couchbase.client.core.logging.CouchbaseLogger
Log a message at the TRACE level according to the specified format and arguments.
trace(String, Throwable) - Method in interface com.couchbase.client.core.logging.CouchbaseLogger
Log an exception (throwable) at the TRACE level with an accompanying message.
trace(Throwable) - Method in interface com.couchbase.client.core.logging.CouchbaseLogger
Log an exception (throwable) at the TRACE level.
tracer() - Method in interface com.couchbase.client.core.env.CoreEnvironment
If tracing is enabled, contains the current tracer that should be used.
tracer(Tracer) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Allows to specify a custom tracer.
tracer() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
transitionState(S) - Method in class com.couchbase.client.core.state.AbstractStateMachine
Transition into a new state.
triggerEmit() - Method in class com.couchbase.client.core.metrics.AbstractMetricsCollector
 
triggerEmit() - Method in interface com.couchbase.client.core.metrics.MetricsCollector
Triggers the immediate emission of whatever is currently collected.
Tuple - Class in com.couchbase.client.core.lang
Static factory class for various Tuples.
Tuple2<T1,T2> - Class in com.couchbase.client.core.lang
A container for two values.
Tuple3<T1,T2,T3> - Class in com.couchbase.client.core.lang
A container for three values.
Tuple4<T1,T2,T3,T4> - Class in com.couchbase.client.core.lang
A container for four values.
Tuple5<T1,T2,T3,T4,T5> - Class in com.couchbase.client.core.lang
A container for five values.
type() - Method in interface com.couchbase.client.core.config.BucketConfig
The bucket type.
type() - Method in class com.couchbase.client.core.config.DefaultCouchbaseBucketConfig
 
type() - Method in class com.couchbase.client.core.config.DefaultMemcachedBucketConfig
 
type() - Method in interface com.couchbase.client.core.event.CouchbaseEvent
The type of the event.
type() - Method in class com.couchbase.client.core.event.metrics.LatencyMetricsEvent
 
type() - Method in class com.couchbase.client.core.event.metrics.RuntimeMetricsEvent
 
type() - Method in class com.couchbase.client.core.event.system.BucketClosedEvent
 
type() - Method in class com.couchbase.client.core.event.system.BucketOpenedEvent
 
type() - Method in class com.couchbase.client.core.event.system.ConfigUpdatedEvent
 
type() - Method in class com.couchbase.client.core.event.system.NodeConnectedEvent
 
type() - Method in class com.couchbase.client.core.event.system.NodeDisconnectedEvent
 
type() - Method in class com.couchbase.client.core.event.system.TooManyEnvironmentsEvent
 
type() - Method in class com.couchbase.client.core.logging.RedactableArgument
The type of this redactable argument.
type() - Method in class com.couchbase.client.core.message.internal.AddServiceRequest
 
type() - Method in class com.couchbase.client.core.message.internal.EndpointHealth
 
type() - Method in class com.couchbase.client.core.message.internal.PingServiceHealth
 
type() - Method in class com.couchbase.client.core.message.internal.RemoveServiceRequest
 
type() - Method in class com.couchbase.client.core.service.AnalyticsService
 
type() - Method in class com.couchbase.client.core.service.ConfigService
 
type() - Method in class com.couchbase.client.core.service.KeyValueService
 
type() - Method in class com.couchbase.client.core.service.OldAnalyticsService
 
type() - Method in class com.couchbase.client.core.service.OldKeyValueService
 
type() - Method in class com.couchbase.client.core.service.OldQueryService
 
type() - Method in class com.couchbase.client.core.service.OldSearchService
 
type() - Method in class com.couchbase.client.core.service.OldViewService
 
type() - Method in class com.couchbase.client.core.service.QueryService
 
type() - Method in class com.couchbase.client.core.service.SearchService
 
type() - Method in interface com.couchbase.client.core.service.Service
Returns the type for the given Service.
type() - Method in class com.couchbase.client.core.service.ViewService
 
type() - Method in class com.couchbase.client.core.tracing.ThresholdLogReference
Returns the type of reference.

U

UnicastAutoReleaseSubject<T> - Class in com.couchbase.client.core.utils
This Subject can be used to auto-release reference counted objects when not subscribed before.
unit() - Method in class com.couchbase.client.core.time.Delay
Returns the TimeUnit associated with this Delay.
UNKNOWN_COMMAND - Static variable in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheResponseStatus
 
UnlockRequest - Class in com.couchbase.client.core.message.kv
 
UnlockRequest(String, long, String) - Constructor for class com.couchbase.client.core.message.kv.UnlockRequest
 
UnlockResponse - Class in com.couchbase.client.core.message.kv
 
UnlockResponse(ResponseStatus, short, String, ByteBuf, CouchbaseRequest) - Constructor for class com.couchbase.client.core.message.kv.UnlockResponse
 
unwrap(byte[], int, int) - Method in class com.couchbase.client.core.security.sasl.ShaSaslClient
 
updateBinaryErrorMap(ErrorMap) - Static method in class com.couchbase.client.core.endpoint.ResponseStatusConverter
Updates the current error map in use for all uses of the response status converter.
UpdateBucketRequest - Class in com.couchbase.client.core.message.config
 
UpdateBucketRequest(String, String, String, String) - Constructor for class com.couchbase.client.core.message.config.UpdateBucketRequest
 
UpdateBucketResponse - Class in com.couchbase.client.core.message.config
 
UpdateBucketResponse(String, ResponseStatus) - Constructor for class com.couchbase.client.core.message.config.UpdateBucketResponse
 
UpsertDesignDocumentRequest - Class in com.couchbase.client.core.message.view
 
UpsertDesignDocumentRequest(String, String, boolean, String, String) - Constructor for class com.couchbase.client.core.message.view.UpsertDesignDocumentRequest
 
UpsertDesignDocumentRequest(String, String, boolean, String, String, String) - Constructor for class com.couchbase.client.core.message.view.UpsertDesignDocumentRequest
 
UpsertDesignDocumentResponse - Class in com.couchbase.client.core.message.view
 
UpsertDesignDocumentResponse(ResponseStatus, ByteBuf, CouchbaseRequest) - Constructor for class com.couchbase.client.core.message.view.UpsertDesignDocumentResponse
 
upsertDocument() - Method in interface com.couchbase.client.core.message.kv.subdoc.BinarySubdocMutationRequest
Upsert document if it does not exist
upsertDocument(boolean) - Method in class com.couchbase.client.core.message.kv.subdoc.multi.SubMultiMutationDocOptionsBuilder
 
upsertDocument() - Method in class com.couchbase.client.core.message.kv.subdoc.multi.SubMultiMutationDocOptionsBuilder
 
upsertDocument() - Method in class com.couchbase.client.core.message.kv.subdoc.simple.AbstractSubdocMutationRequest
 
upsertDocument(boolean) - Method in class com.couchbase.client.core.message.kv.subdoc.simple.AbstractSubdocMutationRequest
 
UpsertRequest - Class in com.couchbase.client.core.message.kv
Insert or update a document.
UpsertRequest(String, ByteBuf, String, boolean) - Constructor for class com.couchbase.client.core.message.kv.UpsertRequest
 
UpsertRequest(String, ByteBuf, String) - Constructor for class com.couchbase.client.core.message.kv.UpsertRequest
Creates a new UpsertRequest.
UpsertRequest(String, ByteBuf, int, int, String) - Constructor for class com.couchbase.client.core.message.kv.UpsertRequest
 
UpsertRequest(String, ByteBuf, int, int, String, boolean) - Constructor for class com.couchbase.client.core.message.kv.UpsertRequest
Creates a new UpsertRequest.
UpsertResponse - Class in com.couchbase.client.core.message.kv
Response to an UpsertRequest.
UpsertResponse(ResponseStatus, short, long, String, ByteBuf, MutationToken, CouchbaseRequest) - Constructor for class com.couchbase.client.core.message.kv.UpsertResponse
 
UpsertSearchIndexRequest - Class in com.couchbase.client.core.message.search
Inserts or updates full text search index definition.
UpsertSearchIndexRequest(String, String, String, String) - Constructor for class com.couchbase.client.core.message.search.UpsertSearchIndexRequest
 
UpsertSearchIndexResponse - Class in com.couchbase.client.core.message.search
Contains result of the create/update action on full text search index.
UpsertSearchIndexResponse(String, ResponseStatus) - Constructor for class com.couchbase.client.core.message.search.UpsertSearchIndexResponse
 
UpsertUserRequest - Class in com.couchbase.client.core.message.config
 
UpsertUserRequest(String, String, String, String, String) - Constructor for class com.couchbase.client.core.message.config.UpsertUserRequest
 
UpsertUserResponse - Class in com.couchbase.client.core.message.config
 
UpsertUserResponse(String, ResponseStatus) - Constructor for class com.couchbase.client.core.message.config.UpsertUserResponse
 
uri() - Method in class com.couchbase.client.core.config.AbstractBucketConfig
 
uri() - Method in interface com.couchbase.client.core.config.BucketConfig
The HTTP Uri for this bucket configuration.
useAlternateNetwork() - Method in class com.couchbase.client.core.config.AbstractBucketConfig
 
useAlternateNetwork(String) - Method in class com.couchbase.client.core.config.AbstractBucketConfig
 
useAlternateNetwork() - Method in interface com.couchbase.client.core.config.BucketConfig
Non null if alternate addresses should be used, false otherwise.
useAlternateNetwork(String) - Method in interface com.couchbase.client.core.config.BucketConfig
Setter to set if external networking should be used or not.
useAlternateNetwork() - Method in class com.couchbase.client.core.config.DefaultNodeInfo
 
useAlternateNetwork(String) - Method in class com.couchbase.client.core.config.DefaultNodeInfo
 
useAlternateNetwork() - Method in interface com.couchbase.client.core.config.NodeInfo
True if alternate addresses should be used, false otherwise.
useAlternateNetwork(String) - Method in interface com.couchbase.client.core.config.NodeInfo
Setter to set if external networking should be used or not.
user(Object) - Static method in class com.couchbase.client.core.logging.RedactableArgument
A redactable argument of user data.
user(String, String, String, String) - Static method in class com.couchbase.client.core.message.config.GetUsersRequest
 
USER_AGENT - Static variable in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
userAgent() - Method in interface com.couchbase.client.core.env.CoreEnvironment
Library identification string, which can be used as User-Agent header in HTTP requests.
userAgent(String) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Sets the USER-AGENT String to be sent in HTTP requests headers (should usually not be tweaked, default value is computed from the SDK DefaultCoreEnvironment.packageNameAndVersion()).
userAgent() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
userEventTriggered(ChannelHandlerContext, Object) - Method in class com.couchbase.client.core.endpoint.AbstractGenericHandler
 
userEventTriggered(ChannelHandlerContext, Object) - Method in class com.couchbase.client.core.endpoint.kv.KeyValueErrorMapHandler
 
userEventTriggered(ChannelHandlerContext, Object) - Method in class com.couchbase.client.core.endpoint.kv.KeyValueHandler
 
userEventTriggered(ChannelHandlerContext, Object) - Method in class com.couchbase.client.core.endpoint.kv.KeyValueSelectBucketHandler
 
username() - Method in class com.couchbase.client.core.config.AbstractBucketConfig
 
username(String) - Method in class com.couchbase.client.core.config.AbstractBucketConfig
 
username() - Method in interface com.couchbase.client.core.config.BucketConfig
User authorized for the bucket access.
username(String) - Method in interface com.couchbase.client.core.config.BucketConfig
Set user authorized for the bucket access.
username() - Method in class com.couchbase.client.core.endpoint.AbstractEndpoint
Username of the bucket.
username() - Method in class com.couchbase.client.core.message.AbstractCouchbaseRequest
 
username() - Method in interface com.couchbase.client.core.message.CouchbaseRequest
User authorized for bucket access
username() - Method in class com.couchbase.client.core.utils.ConnectionString
 
users(String, String) - Static method in class com.couchbase.client.core.message.config.GetUsersRequest
 
usersFromDomain(String, String, String) - Static method in class com.couchbase.client.core.message.config.GetUsersRequest
 
uuid() - Method in class com.couchbase.client.core.config.AbstractBucketConfig
 
uuid() - Method in interface com.couchbase.client.core.config.BucketConfig
Returns the UUID of the bucket, or null if the bucket does not have a UUID.

V

value() - Method in enum com.couchbase.client.core.endpoint.ServerFeatures
Returns the actual byte value for the wire protocol.
value() - Method in class com.couchbase.client.core.message.kv.CounterResponse
 
value() - Method in enum com.couchbase.client.core.message.kv.GetAllMutationTokensRequest.PartitionState
 
value() - Method in enum com.couchbase.client.core.message.kv.ObserveResponse.ObserveStatus
 
value() - Method in class com.couchbase.client.core.message.kv.StatResponse
 
value() - Method in class com.couchbase.client.core.message.kv.subdoc.multi.MultiResult
 
value() - Method in enum com.couchbase.client.core.message.observe.Observe.PersistTo
Returns the actual internal persistence representation for the enum.
value() - Method in enum com.couchbase.client.core.message.observe.Observe.ReplicateTo
Returns the actual internal replication representation for the enum.
value1() - Method in class com.couchbase.client.core.lang.Tuple2
Get the first value.
value1() - Method in class com.couchbase.client.core.lang.Tuple3
Get the first value.
value1() - Method in class com.couchbase.client.core.lang.Tuple4
Get the first value.
value1() - Method in class com.couchbase.client.core.lang.Tuple5
Get the first value.
value2() - Method in class com.couchbase.client.core.lang.Tuple2
Get the second value.
value2() - Method in class com.couchbase.client.core.lang.Tuple3
Get the second value.
value2() - Method in class com.couchbase.client.core.lang.Tuple4
Get the second value.
value2() - Method in class com.couchbase.client.core.lang.Tuple5
Get the second value.
value3() - Method in class com.couchbase.client.core.lang.Tuple3
Get the third value.
value3() - Method in class com.couchbase.client.core.lang.Tuple4
Get the third value.
value3() - Method in class com.couchbase.client.core.lang.Tuple5
Get the third value.
value4() - Method in class com.couchbase.client.core.lang.Tuple4
Get the fourth value.
value4() - Method in class com.couchbase.client.core.lang.Tuple5
Get the fourth value.
value5() - Method in class com.couchbase.client.core.lang.Tuple5
Get the fifth value.
valueOf(String) - Static method in enum com.couchbase.client.core.config.BucketCapabilities
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.couchbase.client.core.config.BucketNodeLocator
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.couchbase.client.core.config.BucketType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.couchbase.client.core.config.LoaderType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.couchbase.client.core.endpoint.DecodingState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.couchbase.client.core.endpoint.kv.ErrorMap.ErrorAttribute
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.couchbase.client.core.endpoint.kv.ErrorMap.RetryStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.couchbase.client.core.endpoint.kv.KeyValueStatus
Returns the enum constant of this type with the specified name.
valueOf(short) - Static method in enum com.couchbase.client.core.endpoint.kv.KeyValueStatus
Determine the right KeyValueStatus for the given status code.
valueOf(String) - Static method in enum com.couchbase.client.core.endpoint.ServerFeatures
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.couchbase.client.core.event.consumers.LoggingConsumer.OutputFormat
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.couchbase.client.core.event.EventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.couchbase.client.core.logging.CouchbaseLogLevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.couchbase.client.core.logging.RedactableArgument.ArgumentType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.couchbase.client.core.logging.RedactionLevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.couchbase.client.core.message.internal.PingServiceHealth.PingState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.couchbase.client.core.message.kv.GetAllMutationTokensRequest.PartitionState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.couchbase.client.core.message.kv.ObserveResponse.ObserveStatus
Returns the enum constant of this type with the specified name.
valueOf(byte) - Static method in enum com.couchbase.client.core.message.kv.ObserveResponse.ObserveStatus
 
valueOf(String) - Static method in enum com.couchbase.client.core.message.kv.subdoc.multi.Lookup
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.couchbase.client.core.message.kv.subdoc.multi.Mutation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.couchbase.client.core.message.kv.subdoc.simple.SubArrayRequest.ArrayOperation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.couchbase.client.core.message.observe.Observe.PersistTo
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.couchbase.client.core.message.observe.Observe.ReplicateTo
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.couchbase.client.core.message.ResponseStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.couchbase.client.core.service.BucketServiceMapping
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.couchbase.client.core.service.ServiceType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.couchbase.client.core.state.LifecycleState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.couchbase.client.core.utils.ConnectionString.Scheme
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.couchbase.client.core.utils.Observables
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.couchbase.client.core.utils.yasjl.JsonParserUtils.Mode
Returns the enum constant of this type with the specified name.
values() - Static method in enum com.couchbase.client.core.config.BucketCapabilities
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.couchbase.client.core.config.BucketNodeLocator
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.couchbase.client.core.config.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.core.config.LoaderType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.couchbase.client.core.endpoint.DecodingState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.couchbase.client.core.endpoint.kv.ErrorMap.ErrorAttribute
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.couchbase.client.core.endpoint.kv.ErrorMap.RetryStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.couchbase.client.core.endpoint.kv.KeyValueStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.couchbase.client.core.endpoint.ServerFeatures
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.couchbase.client.core.event.consumers.LoggingConsumer.OutputFormat
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.couchbase.client.core.event.EventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.couchbase.client.core.logging.CouchbaseLogLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.couchbase.client.core.logging.RedactableArgument.ArgumentType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.couchbase.client.core.logging.RedactionLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.couchbase.client.core.message.internal.PingServiceHealth.PingState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.couchbase.client.core.message.kv.GetAllMutationTokensRequest.PartitionState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.couchbase.client.core.message.kv.ObserveResponse.ObserveStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.couchbase.client.core.message.kv.subdoc.multi.Lookup
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.couchbase.client.core.message.kv.subdoc.multi.Mutation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.couchbase.client.core.message.kv.subdoc.simple.SubArrayRequest.ArrayOperation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.couchbase.client.core.message.observe.Observe.PersistTo
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.couchbase.client.core.message.observe.Observe.ReplicateTo
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.couchbase.client.core.message.ResponseStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.couchbase.client.core.service.BucketServiceMapping
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.couchbase.client.core.service.ServiceType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.couchbase.client.core.state.LifecycleState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.couchbase.client.core.utils.ConnectionString.Scheme
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.couchbase.client.core.utils.Observables
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.couchbase.client.core.utils.yasjl.JsonParserUtils.Mode
Returns an array containing the constants of this enum type, in the order they are declared.
vbucketID() - Method in class com.couchbase.client.core.message.kv.FailoverObserveSeqnoResponse
 
vbucketID() - Method in class com.couchbase.client.core.message.kv.MutationToken
 
vbucketID() - Method in class com.couchbase.client.core.message.kv.NoFailoverObserveSeqnoResponse
 
vbucketUUID() - Method in class com.couchbase.client.core.message.kv.MutationToken
 
vbucketUUID() - Method in class com.couchbase.client.core.message.kv.NoFailoverObserveSeqnoResponse
 
vbucketUUID() - Method in class com.couchbase.client.core.message.kv.ObserveSeqnoRequest
 
version() - Method in class com.couchbase.client.core.endpoint.kv.ErrorMap
 
version() - Method in class com.couchbase.client.core.message.internal.PingReport
 
VERSION - Static variable in class com.couchbase.client.deps.io.netty.handler.codec.memcache.binary.BinaryMemcacheOpcodes
 
view() - Method in class com.couchbase.client.core.message.view.ViewQueryRequest
 
VIEW_ENDPOINTS - Static variable in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
ViewEndpoint - Class in com.couchbase.client.core.endpoint.view
This endpoint defines the pipeline for binary requests and responses.
ViewEndpoint(String, String, String, int, CoreContext) - Constructor for class com.couchbase.client.core.endpoint.view.ViewEndpoint
Deprecated.
ViewEndpoint(String, String, String, String, int, CoreContext) - Constructor for class com.couchbase.client.core.endpoint.view.ViewEndpoint
 
viewEndpoints() - Method in interface com.couchbase.client.core.env.CoreEnvironment
The number of view service endpoints.
viewEndpoints(int) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
viewEndpoints() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
ViewHandler - Class in com.couchbase.client.core.endpoint.view
The ViewHandler is responsible for encoding ViewRequests into lower level HttpRequests as well as decoding HttpObjects into CouchbaseResponses.
ViewHandler(AbstractEndpoint, RingBuffer<ResponseEvent>, boolean, boolean) - Constructor for class com.couchbase.client.core.endpoint.view.ViewHandler
Creates a new ViewHandler with the default queue for requests.
ViewHandler.KeepAliveRequest - Class in com.couchbase.client.core.endpoint.view
 
ViewHandler.KeepAliveResponse - Class in com.couchbase.client.core.endpoint.view
 
viewIoPool() - Method in interface com.couchbase.client.core.env.CoreEnvironment
If set returns the IO Pool for the View service, if not returns null.
viewIoPool(EventLoopGroup, ShutdownHook) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Sets the View I/O Pool implementation for the underlying IO framework, along with the action to execute when this environment is shut down.
viewIoPool() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
ViewLocator - Class in com.couchbase.client.core.node.locate
 
ViewLocator() - Constructor for class com.couchbase.client.core.node.locate.ViewLocator
Generates the random initial value for the round robin counter used.
ViewQueryRequest - Class in com.couchbase.client.core.message.view
 
ViewQueryRequest(String, String, boolean, String, String, String, String) - Constructor for class com.couchbase.client.core.message.view.ViewQueryRequest
 
ViewQueryRequest(String, String, boolean, String, String, String, String, String) - Constructor for class com.couchbase.client.core.message.view.ViewQueryRequest
 
ViewQueryRequest(String, String, boolean, boolean, String, String, String, String) - Constructor for class com.couchbase.client.core.message.view.ViewQueryRequest
 
ViewQueryRequest(String, String, boolean, boolean, String, String, String, String, String) - Constructor for class com.couchbase.client.core.message.view.ViewQueryRequest
 
ViewQueryResponse - Class in com.couchbase.client.core.message.view
 
ViewQueryResponse(Observable<ByteBuf>, Observable<ByteBuf>, Observable<String>, int, String, ResponseStatus, CouchbaseRequest) - Constructor for class com.couchbase.client.core.message.view.ViewQueryResponse
 
ViewRequest - Interface in com.couchbase.client.core.message.view
 
ViewService - Class in com.couchbase.client.core.service
The ViewService is composed of and manages ViewEndpoints.
ViewService(String, String, String, int, CoreContext) - Constructor for class com.couchbase.client.core.service.ViewService
Deprecated.
ViewService(String, String, String, String, int, CoreContext) - Constructor for class com.couchbase.client.core.service.ViewService
Creates a new ViewService.
viewServiceConfig() - Method in interface com.couchbase.client.core.env.CoreEnvironment
Returns the current ViewService configuration.
viewServiceConfig(ViewServiceConfig) - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment.Builder
Allows to set a custom configuration for the View service.
viewServiceConfig() - Method in class com.couchbase.client.core.env.DefaultCoreEnvironment
 
ViewServiceConfig - Class in com.couchbase.client.core.env
 
viewThreshold(long, TimeUnit) - Method in class com.couchbase.client.core.tracing.ThresholdLogReporter.Builder
Allows to customize the viewThreshold.

W

WaitStrategyFactory - Interface in com.couchbase.client.core.env
Factory to create a new WaitStrategy when called.
warn(Throwable) - Method in class com.couchbase.client.core.logging.AbstractCouchbaseLogger
 
warn(String) - Method in interface com.couchbase.client.core.logging.CouchbaseLogger
Log a message at the WARN level.
warn(String, Object) - Method in interface com.couchbase.client.core.logging.CouchbaseLogger
Log a message at the WARN level according to the specified format and argument.
warn(String, Object...) - Method in interface com.couchbase.client.core.logging.CouchbaseLogger
Log a message at the WARN level according to the specified format and arguments.
warn(String, Object, Object) - Method in interface com.couchbase.client.core.logging.CouchbaseLogger
Log a message at the WARN level according to the specified format and arguments.
warn(String, Throwable) - Method in interface com.couchbase.client.core.logging.CouchbaseLogger
Log an exception (throwable) at the WARN level with an accompanying message.
warn(Throwable) - Method in interface com.couchbase.client.core.logging.CouchbaseLogger
Log an exception (throwable) at the WARN level.
whenState(Endpoint, LifecycleState, Action1<LifecycleState>) - Static method in class com.couchbase.client.core.service.AbstractDynamicService
Waits until the endpoint goes into the given state, calls the action and then unsubscribes.
WhitespaceSkipper - Class in com.couchbase.client.core.endpoint.util
This ByteBufProcessor loops while it encounters whitespace or new lines (‘ ’, ‘\t’, ‘\r’ and ‘\n’).
WhitespaceSkipper() - Constructor for class com.couchbase.client.core.endpoint.util.WhitespaceSkipper
 
withStartTimestamp(long) - Method in class com.couchbase.client.core.tracing.ThresholdLogSpanBuilder
 
withTag(String, String) - Method in class com.couchbase.client.core.tracing.ThresholdLogSpanBuilder
 
withTag(String, boolean) - Method in class com.couchbase.client.core.tracing.ThresholdLogSpanBuilder
 
withTag(String, Number) - Method in class com.couchbase.client.core.tracing.ThresholdLogSpanBuilder
 
withTraceIdentifier(String) - Method in class com.couchbase.client.core.utils.UnicastAutoReleaseSubject
 
wrap(byte[], int, int) - Method in class com.couchbase.client.core.security.sasl.ShaSaslClient
 
wrapColdWithAutoRelease(Observable<T>) - Static method in class com.couchbase.client.core.utils.Buffers
Wrap an observable and free a reference counted item if unsubscribed in the meantime.
write(ChannelHandlerContext, Object, ChannelPromise) - Method in class com.couchbase.client.core.endpoint.AbstractGenericHandler
 
write(ChannelHandlerContext, Object, ChannelPromise) - Method in class com.couchbase.client.core.endpoint.kv.KeyValueAuthHandler
 
write(ChannelHandlerContext, Object, ChannelPromise) - Method in class com.couchbase.client.core.endpoint.kv.KeyValueErrorMapHandler
 
write(ChannelHandlerContext, Object, ChannelPromise) - Method in class com.couchbase.client.core.endpoint.kv.KeyValueFeatureHandler
 
write(ChannelHandlerContext, Object, ChannelPromise) - Method in class com.couchbase.client.core.endpoint.kv.KeyValueSelectBucketHandler
 
writer() - Static method in class com.couchbase.client.core.utils.DefaultObjectMapper
 
writeValue(OutputStream, Object) - Static method in class com.couchbase.client.core.utils.DefaultObjectMapper
 
writeValue(Writer, Object) - Static method in class com.couchbase.client.core.utils.DefaultObjectMapper
 
writeValueAsBytes(Object) - Static method in class com.couchbase.client.core.utils.DefaultObjectMapper
 
writeValueAsString(Object) - Static method in class com.couchbase.client.core.utils.DefaultObjectMapper
 
WS_CR - Static variable in class com.couchbase.client.core.utils.yasjl.JsonParserUtils
 
WS_LF - Static variable in class com.couchbase.client.core.utils.yasjl.JsonParserUtils
 
WS_SPACE - Static variable in class com.couchbase.client.core.utils.yasjl.JsonParserUtils
 
WS_TAB - Static variable in class com.couchbase.client.core.utils.yasjl.JsonParserUtils
 

X

xattr() - Method in interface com.couchbase.client.core.message.kv.subdoc.BinarySubdocMutationRequest
Access to extended attribute section of the couchbase document
xattr() - Method in class com.couchbase.client.core.message.kv.subdoc.multi.LookupCommand
 
xattr() - Method in class com.couchbase.client.core.message.kv.subdoc.multi.LookupCommandBuilder
Access to extended attribute section of the couchbase document
xattr(boolean) - Method in class com.couchbase.client.core.message.kv.subdoc.multi.LookupCommandBuilder
Access to extended attribute section of the couchbase document
xattr() - Method in class com.couchbase.client.core.message.kv.subdoc.multi.MutationCommand
 
xattr() - Method in class com.couchbase.client.core.message.kv.subdoc.multi.MutationCommandBuilder
 
xattr(boolean) - Method in class com.couchbase.client.core.message.kv.subdoc.multi.MutationCommandBuilder
 
xattr() - Method in class com.couchbase.client.core.message.kv.subdoc.simple.AbstractSubdocMutationRequest
 
xattr(boolean) - Method in class com.couchbase.client.core.message.kv.subdoc.simple.AbstractSubdocMutationRequest
 
xattr() - Method in class com.couchbase.client.core.message.kv.subdoc.simple.SubExistRequest
 
xattr(boolean) - Method in class com.couchbase.client.core.message.kv.subdoc.simple.SubExistRequest
 
xattr() - Method in class com.couchbase.client.core.message.kv.subdoc.simple.SubGetCountRequest
 
xattr(boolean) - Method in class com.couchbase.client.core.message.kv.subdoc.simple.SubGetCountRequest
 
xattr() - Method in class com.couchbase.client.core.message.kv.subdoc.simple.SubGetRequest
 
xattr(boolean) - Method in class com.couchbase.client.core.message.kv.subdoc.simple.SubGetRequest
 

Y

YasjlQueryResponseParser - Class in com.couchbase.client.core.endpoint.query.parser
A N1QL/Query response parser, based on yasjl.
YasjlQueryResponseParser(Scheduler, long, CoreEnvironment) - Constructor for class com.couchbase.client.core.endpoint.query.parser.YasjlQueryResponseParser

Z

zipWith(Collection<LifecycleState>) - Method in class com.couchbase.client.core.node.ServiceStateZipper
 
zipWith(Collection<LifecycleState>) - Method in class com.couchbase.client.core.service.EndpointStateZipper
 
zipWith(Collection<S>) - Method in class com.couchbase.client.core.state.AbstractStateZipper
The zip function to map from N states to one that represents the state of the zipper.
A B C D E F G H I J K L M N O P Q R S T U V W X Y Z 
Skip navigation links

Copyright © 2018 Couchbase, Inc.. All rights reserved.