All Classes Interface Summary Class Summary Enum Summary Exception Summary Annotation Types Summary
Class |
Description |
AbstractBinaryMemcacheDecoder<M extends BinaryMemcacheMessage> |
|
AbstractBinaryMemcacheEncoder<M extends BinaryMemcacheMessage> |
|
AbstractBinaryMemcacheMessage |
|
AbstractBucketConfig |
|
AbstractCouchbaseLogger |
|
AbstractCouchbaseRequest |
Default implementation for a CouchbaseRequest , should be extended by child messages.
|
AbstractCouchbaseResponse |
|
AbstractDynamicService |
Parent implementation of a dynamic Service .
|
AbstractEndpoint |
The common parent implementation for all Endpoint s.
|
AbstractGenericHandler<RESPONSE,ENCODED,REQUEST extends CouchbaseRequest> |
Generic handler which acts as the common base type for all implementing handlers.
|
AbstractKeyValueRequest |
|
AbstractKeyValueResponse |
|
AbstractLatencyMetricsCollector<I extends LatencyMetricsIdentifier,E extends LatencyMetricsEvent> |
The default abstract implementation for a latency metrics collector.
|
AbstractLazyService |
This service lazily creates an Endpoint if needed and reuses it.
|
AbstractLoader |
An AbstractLoader which provides common basic processing for all implementing loaders.
|
AbstractMemcacheObject |
|
AbstractMemcacheObjectAggregator |
|
AbstractMemcacheObjectDecoder |
Abstract super class for both ascii and binary decoders.
|
AbstractMemcacheObjectEncoder<M extends MemcacheMessage> |
|
AbstractMetricsCollector |
A common base class for all metrics collectors which emit events.
|
AbstractOnDemandService |
Abstract implementation of a service which enables and disables endpoints on demand.
|
AbstractPoolingService |
Abstract implementation of a (fixed size) pooling Service.
|
AbstractRefresher |
Common implementation for all refreshers.
|
AbstractServiceConfig |
Defines a general config for a Service .
|
AbstractStateMachine<S extends Enum> |
Abstract Stateful implementation which acts like a simple state machine.
|
AbstractStateZipper<T,S extends Enum> |
|
AbstractStringAwareBufProcessor |
|
AbstractSubdocMutationRequest |
|
AbstractSubdocRequest |
|
AddNodeRequest |
|
AddNodeResponse |
|
AddServiceRequest |
|
AddServiceResponse |
|
AlternateAddress |
|
AnalyticsEndpoint |
This endpoint defines the pipeline for analytics requests and responses.
|
AnalyticsHandler |
|
AnalyticsHandler.KeepAliveRequest |
|
AnalyticsHandler.KeepAliveResponse |
|
AnalyticsHandlerV2 |
|
AnalyticsHandlerV2.KeepAliveRequest |
|
AnalyticsHandlerV2.KeepAliveResponse |
|
AnalyticsLocator |
Round robin node locator for Analytics.
|
AnalyticsQueryResultRequest |
Deferred analytics query result request
|
AnalyticsQueryStatusRequest |
Deferred analytics query status request
|
AnalyticsRequest |
Marker interface for all requests against the Analytics Service
|
AnalyticsService |
|
AnalyticsServiceConfig |
Allows to configure a Analytics Service on a per-node basis.
|
AppendRequest |
|
AppendResponse |
|
AuthenticationException |
|
BackpressureException |
Identifies the need to back off on the supplier side when using a service, because the consumer is overloaded.
|
Base64 |
Utility class to perform base64 encoding/decoding.
|
BestEffortRetryStrategy |
A RetryStrategy that will retry until the max request lifetime is reached.
|
BinaryMemcacheClientCodec |
The client codec that combines the proper encoder and decoder.
|
BinaryMemcacheMessage |
|
BinaryMemcacheObjectAggregator |
An object aggregator for the memcache binary protocol.
|
BinaryMemcacheOpcodes |
|
BinaryMemcacheRequest |
|
BinaryMemcacheRequestDecoder |
The decoder part which takes care of decoding the request-specific headers.
|
BinaryMemcacheRequestEncoder |
The encoder part which takes care of encoding the request headers.
|
BinaryMemcacheResponse |
|
BinaryMemcacheResponseDecoder |
The decoder which takes care of decoding the response headers.
|
BinaryMemcacheResponseEncoder |
The encoder which takes care of encoding the response headers.
|
BinaryMemcacheResponseStatus |
Contains all possible status values a response can return.
|
BinaryRequest |
|
BinaryResponse |
Marker interface which signals a binary response.
|
BinaryStoreRequest |
|
BinarySubdocMultiLookupRequest |
|
BinarySubdocMultiMutationRequest |
|
BinarySubdocMutationRequest |
|
BinarySubdocRequest |
A type of BinaryRequest that deals with getting or mutating parts of
a JSON document, aka a Sub-Document.
|
Blocking |
Contains various utility methods related to blocking operations.
|
BootstrapAdapter |
|
BootstrapMessage |
Marker interface for messages that should be allowed to go through the
RequestHandler, despite no bucket configuration available to check upon.
|
BucketCapabilities |
Describes the bucket capabilities in an abstract fashion as provided by
the server.
|
BucketClosedEvent |
Event published when a bucket is closed.
|
BucketClosedException |
A RuntimeException being thrown whenever an operation on a bucket that
has been closed is attempted.
|
BucketConfig |
Represents a Couchbase Bucket Configuration.
|
BucketConfigParser |
An abstraction over the bucket parser which takes a raw config as a string and turns it into a
BucketConfig .
|
BucketConfigRequest |
|
BucketConfigResponse |
|
BucketNodeLocator |
Represents the node locator used for the specific bucket type.
|
BucketOpenedEvent |
Event published when a bucket is opened.
|
BucketsConfigRequest |
|
BucketsConfigResponse |
|
BucketServiceMapping |
Defines the relationship between a bucket and a service.
|
BucketStreamingRequest |
|
BucketStreamingResponse |
|
BucketType |
Represents the possible bucket types.
|
Buffers |
Collection of utilities around ByteBuf .
|
ByteBufJsonHelper |
An helper class providing utility methods to deal with parsing of structured
data (like JSON) inside a ByteBuf buffer.
|
ByteBufJsonParser |
|
CarrierLoader |
Loads a raw bucket configuration through the carrier mechanism (also commonly referred to as CCCP).
|
CarrierRefresher |
Keeps the bucket config fresh through carrier configuration management.
|
CloseBucketRequest |
|
CloseBucketResponse |
|
ClosingPositionBufProcessor |
|
ClusterConfig |
Represents a Couchbase Cluster Configuration.
|
ClusterConfigRequest |
|
ClusterConfigResponse |
|
ClusterFacade |
Represents a Couchbase Cluster.
|
ClusterRequest |
|
CommonsLoggerFactory |
|
ConfigEndpoint |
|
ConfigHandler |
|
ConfigLocator |
Locates the proper CONFIG node for a given config request.
|
ConfigParserEnvironment |
A ConfigParserEnvironment interface defines all methods which environment implementation should have
to be injected into configuration parser.
|
ConfigRequest |
|
ConfigService |
|
ConfigUpdatedEvent |
Event published when a new bucket config is applied to the core.
|
ConfigurationException |
|
ConfigurationProvider |
|
ConnectionString |
|
ConnectionString.Scheme |
|
ConnectionString.UnresolvedSocket |
|
CoreContext |
The CoreContext contains required assets which are shared on
a per-core basis.
|
CoreEnvironment |
A CoreEnvironment provides all the core building blocks like environment settings and thread pools so
that the application can work with it properly.
|
CoreScheduler |
The Core scheduler which is modeled after the Event Loops Scheduler (which is package private).
|
CouchbaseBucketConfig |
A configuration representing the couchbase bucket.
|
CouchbaseCore |
|
CouchbaseCoreSendHook |
|
CouchbaseEvent |
Defines the generic couchbase event pushed through the event bus.
|
CouchbaseException |
Common parent exception to build a proper exception hierachy inside the driver.
|
CouchbaseLogger |
Internal-use-only logger used by the SDK.
|
CouchbaseLoggerFactory |
|
CouchbaseLogLevel |
|
CouchbaseMessage |
|
CouchbaseNode |
The general implementation of a Node .
|
CouchbasePartitionInfo |
Represents the partition information for a bucket.
|
CouchbaseRequest |
|
CouchbaseResponse |
|
CounterRequest |
Request to handle increment/decrement of a counter.
|
CounterResponse |
|
DecodingState |
Describes the states of the decoding process.
|
DefaultAlternateAddress |
|
DefaultBinaryMemcacheRequest |
|
DefaultBinaryMemcacheResponse |
|
DefaultClusterConfig |
|
DefaultConfigurationProvider |
|
DefaultCoreEnvironment |
|
DefaultCoreEnvironment.Builder<SELF extends DefaultCoreEnvironment.Builder<SELF>> |
|
DefaultCouchbaseBucketConfig |
|
DefaultEventBus |
The default event bus implementation.
|
DefaultFullBinaryMemcacheRequest |
|
DefaultFullBinaryMemcacheResponse |
|
DefaultLastMemcacheContent |
|
DefaultLatencyMetricsCollectorConfig |
The default configuration for the latency metrics collectors.
|
DefaultLatencyMetricsCollectorConfig.Builder |
|
DefaultMemcacheContent |
|
DefaultMemcachedBucketConfig |
|
DefaultMemcachedHashingStrategy |
The default memcache bucket hashing strategy, compatible with 2.x Java SDK.
|
DefaultMetricsCollectorConfig |
|
DefaultMetricsCollectorConfig.Builder |
|
DefaultNodeInfo |
|
DefaultObjectMapper |
Provides global access to the services of a Jackson ObjectMapper
with default configuration.
|
DefaultOrphanResponseReporter |
|
DefaultOrphanResponseReporter.Builder |
|
DefaultPartition |
|
DefaultPortInfo |
|
DefaultServiceRegistry |
|
Delay |
Parent class of Delay s and provides factory methods to create them.
|
DiagnosticRequest |
Marker interface for extended information.
|
Diagnostics |
Provides access to various metrics helpful for system diagnosis.
|
DiagnosticsReport |
|
DiagnosticsRequest |
|
DiagnosticsResponse |
|
DisconnectRequest |
Disconnects all open buckets.
|
DisconnectResponse |
|
DocumentConcurrentlyModifiedException |
Exception indicating that the document which is observed has been modified in the meantime.
|
DocumentMutationLostException |
The observed document was lost during a hard failover, because the document did not reach the replica in time.
|
Endpoint |
Represents a stateful Endpoint which abstracts the underlying channel.
|
EndpointHealth |
Aggregates the health of one specific Endpoint .
|
EndpointStateZipper |
Calculates a merged state for all registered endpoints.
|
EnvironmentException |
|
ErrorMap |
The ErrorMap contains mappings from errors to their attributes, negotiated
between the client and the server.
|
ErrorMap.ErrorAttribute |
|
ErrorMap.ErrorCode |
|
ErrorMap.RetrySpecification |
|
ErrorMap.RetryStrategy |
|
EventBus |
Defines the interface for a generic event bus.
|
Events |
Utility methods for event handling.
|
EventType |
Different event types available.
|
ExponentialDelay |
Delay which increases exponentially on every attempt.
|
FailedChannel |
The failed channel can be used to create a channel promise when no channel
is available (because it failed).
|
FailFastRetryStrategy |
|
FailoverObserveSeqnoResponse |
Represents a observe seqno response.
|
FixedDelay |
Delay which is fixed for every attempt.
|
FlushRequest |
Sends a flush command to the cluster.
|
FlushResponse |
|
FullBinaryMemcacheRequest |
|
FullBinaryMemcacheResponse |
|
FullMemcacheMessage |
|
GenericAnalyticsRequest |
For the lack of a better name, a analytics request against a analytics server.
|
GenericAnalyticsResponse |
The base response for Analytics (SQL++) requests.
|
GenericQueryRequest |
For the lack of a better name, a query request against a query server.
|
GenericQueryResponse |
The base response for Query (N1QL) requests.
|
GetAllMutationTokensRequest |
Get the current high sequence numbers one could initialize streams
for all partitions that are located on the server, or use in ObserveViaMutationToken .
|
GetAllMutationTokensRequest.PartitionState |
|
GetAllMutationTokensResponse |
|
GetBucketConfigRequest |
Request which fetches a bucket configuration through carrier publication.
|
GetBucketConfigResponse |
Represents a response with a bucket configuration.
|
GetClusterConfigRequest |
|
GetClusterConfigResponse |
|
GetConfigProviderRequest |
Request to fetch the configuration provider from the core.
|
GetConfigProviderResponse |
Response to fetch the configuration provider from the core.
|
GetDesignDocumentRequest |
|
GetDesignDocumentResponse |
|
GetDesignDocumentsRequest |
|
GetDesignDocumentsResponse |
|
GetRequest |
Fetch a document from the cluster and return it if found.
|
GetResponse |
|
GetSearchIndexRequest |
Retrieves full text index definition.
|
GetSearchIndexResponse |
Carries full text index definition as a payload.
|
GetUsersRequest |
Get a user or list of users.
|
GetUsersResponse |
|
HealthPinger |
The HealthPinger allows to "ping" individual services with
real operations for their health.
|
HttpLoader |
Loads a raw bucket configuration through the Couchbase Server HTTP config interface.
|
HttpRefresher |
Keeps the bucket config fresh through a HTTP streaming connection.
|
InetAddresses |
|
InsertBucketRequest |
|
InsertBucketResponse |
|
InsertRequest |
Insert a document.
|
InsertResponse |
|
InterfaceAudience |
Defines the intended audience for each entity.
|
InterfaceAudience.Private |
Intended to be only used within this library.
|
InterfaceAudience.Public |
Intended to be used by any project or application that depends on this library.
|
InterfaceStability |
Defines the stability annotations for each public or private class.
|
InterfaceStability.Committed |
The annotated entity is considered committed and can only break compatibility at a major release.
|
InterfaceStability.Experimental |
The annotated entity is considered experimental and no guarantees can be given in terms of
compatibility and stability.
|
InterfaceStability.Uncommitted |
The annotated entity is considered stable, but compatibility can be broken at each minor release.
|
InternalRequest |
Marker interface for all internal CouchbaseRequest s that are potentially treated differently and with
priority.
|
IoPoolShutdownHook |
|
JdkLoggerFactory |
|
JsonArrayByteBufProcessor |
Process JSON array
|
JsonBOMByteBufProcessor |
Processes byte order mark.
|
JsonBooleanFalseByteBufProcessor |
Processes JSON false value
|
JsonBooleanTrueByteBufProcessor |
Processes JSON true value
|
JsonNullByteBufProcessor |
Processes JSON null value
|
JsonNumberByteBufProcessor |
Process JSON number
|
JsonObjectByteBufProcessor |
Processes JSON object value
|
JsonParserUtils |
|
JsonParserUtils.Mode |
|
JsonPointer |
Represents a pointer in the JSON tree structure.
|
JsonPointerCB |
|
JsonPointerCB1 |
|
JsonPointerCB2 |
|
JsonPointerTree |
|
JsonStringByteBufProcessor |
Processes JSON String value
|
JsonWhiteSpaceByteBufProcessor |
Processes JSON ws
|
KeepAlive |
Marker interface to identify a request that handles a keepalive.
|
KeyValueAuthHandler |
A SASL Client which communicates through the memcache binary protocol.
|
KeyValueEndpoint |
This endpoint defines the pipeline for binary requests and responses.
|
KeyValueErrorMapHandler |
This handler is added dynamically by the KeyValueFeatureHandler to load and store the extended
error map from the server.
|
KeyValueFeatureHandler |
This handler negotiates the enabled features through the HELLO command.
|
KeyValueHandler |
|
KeyValueHandler.KeepAliveRequest |
|
KeyValueHandler.KeepAliveResponse |
|
KeyValueLocator |
|
KeyValueSelectBucketHandler |
A Select bucket handler required for Spock cluster
|
KeyValueService |
|
KeyValueServiceConfig |
Allows to configure a KV Service on a per-node basis.
|
KeyValueStatus |
Enum describing all known response status codes that could be seen on the KeyValue protocol.
|
LastMemcacheContent |
|
LatencyMetric |
A latency metric value object which contains percentile and other related information.
|
LatencyMetricsCollector<I extends LatencyMetricsIdentifier> |
A collector which collects and emits latency measurements.
|
LatencyMetricsCollectorConfig |
Additional configuration for the latency metrics collector.
|
LatencyMetricsEvent<I extends LatencyMetricsIdentifier> |
A common base class for latency metric events.
|
LatencyMetricsIdentifier |
A class which uniquely identifies a latency metric.
|
LegacyMemcachedHashingStrategy |
The legacy memcache bucket hashing strategy, compatible with Java SDK 1.x.
|
LifecycleState |
**Represents common lifecycle states of components.**
|
LinearDelay |
Delay which increases linearly for every attempt.
|
Loader |
|
LoaderType |
.
|
Locator |
|
Log4JLoggerFactory |
|
LoggingConsumer |
|
LoggingConsumer.OutputFormat |
The target output format to log.
|
Lookup |
Enumeration of possible mutations inside a sub-document LookupCommand .
|
LookupCommand |
A single lookup description inside a TODO.
|
LookupCommandBuilder |
|
MathUtils |
Various math utility methods, also backports from later JDK versions.
|
MemcacheContent |
An Memcache content chunk.
|
MemcachedBucketConfig |
A configuration representing a memcached bucket.
|
MemcachedHashingStrategy |
This interface defines different hashing strategies used for ketama hashing in memcached buckets.
|
MemcacheMessage |
Marker interface for both ascii and binary messages.
|
MemcacheObject |
|
MetricsCollector |
A generic metrics collector.
|
MetricsCollectorConfig |
A generic configuration for a metrics collector.
|
MultiLookupResponse |
|
MultiMutationResponse |
|
MultiResult<OPERATION> |
|
Mutation |
|
MutationCommand |
|
MutationCommandBuilder |
|
MutationToken |
Value object to contain vbucket UUID and sequence number.
|
NettyShutdownHook |
ShutdownHook hook that attempts to terminate Netty threads gracefully.
|
NetworkAddress |
A convenient wrapper class around network primitives in Java.
|
NetworkLatencyMetricsCollector |
The collector for core network latencies.
|
NetworkLatencyMetricsEvent |
This event represents network latencies captured in the core layer.
|
NetworkLatencyMetricsIdentifier |
The unique identifier for a network latency metric.
|
NetworkResolution |
|
Node |
Represents a Couchbase Node.
|
NodeConnectedEvent |
Event published when a node is connected.
|
NodeDisconnectedEvent |
Event published when a node is disconnected.
|
NodeInfo |
|
NoFailoverObserveSeqnoResponse |
Represents a observe seqno response.
|
NoopRequest |
|
NoopResponse |
|
NoOpShutdownHook |
|
NotConnectedException |
Thrown if the stateful component is not connected.
|
Objects |
Backport of some utility methods from Java 1.7+
|
Observables |
|
Observe |
Utility class to handle observe calls and polling logic.
|
Observe.PersistTo |
Defines the possible disk persistence constraints to observe.
|
Observe.ReplicateTo |
Defines the possible replication constraints to observe.
|
ObserveRequest |
|
ObserveResponse |
.
|
ObserveResponse.ObserveStatus |
|
ObserveSeqnoRequest |
Observe through sequence numbers instead of cas.
|
ObserveViaCAS |
Utility class to handle observe calls and polling logic.
|
ObserveViaMutationToken |
Document observe through mutation token information.
|
OldAnalyticsService |
|
OldKeyValueService |
|
OldQueryService |
|
OldSearchService |
|
OldViewService |
|
OpenBucketRequest |
|
OpenBucketResponse |
|
OriginalMutationResult |
Represents mutation metadata which can be inspected after
a mutation and during/after is respective observe poll
cycles.
|
OrphanResponseReporter |
|
Partition |
|
PartitionSelectionStrategy |
|
PingReport |
Contains a report for all the internal service health states.
|
PingRequest |
|
PingRequest |
|
PingRequest |
|
PingRequest |
|
PingResponse |
|
PingResponse |
|
PingResponse |
|
PingResponse |
|
PingServiceHealth |
Represents health for a specific service on ping.
|
PingServiceHealth.PingState |
|
PooledService |
A generic implementation of a service pool.
|
PortInfo |
|
PrelocatedRequest |
A CouchbaseRequest that can be targeted at a specific node through the corresponding
hostname, shortcutting the dispatch usually performed by a
Locator ..
|
PrependRequest |
|
PrependResponse |
.
|
ProposedBucketConfigContext |
This context keeps together a bunch of related information needed to turn a raw
config into a parsed one.
|
QueryEndpoint |
This endpoint defines the pipeline for query requests and responses (N1QL).
|
QueryHandler |
|
QueryHandler.KeepAliveRequest |
|
QueryHandler.KeepAliveResponse |
|
QueryHandlerV2 |
|
QueryHandlerV2.KeepAliveRequest |
|
QueryHandlerV2.KeepAliveResponse |
|
QueryLocator |
|
QueryRequest |
|
QueryService |
|
QueryServiceConfig |
Allows to configure a Query Service on a per-node basis.
|
RandomSelectionStrategy |
|
RawAnalyticsRequest |
A AnalyticsRequest that can also be prelocated , but expects a
response with the uninterpreted JSON payload returned by the query service.
|
RawAnalyticsResponse |
|
RawQueryRequest |
A QueryRequest that can also be prelocated , but expects a
response with the uninterpreted JSON payload returned by the query service.
|
RawQueryResponse |
The response to a RawQueryRequest , which only contains the raw JSON payload returned by
the Query service, as a ByteBuf .
|
RedactableArgument |
Represents a logging argument which is subject to redaction.
|
RedactableArgument.ArgumentType |
The type of the redactable argument.
|
RedactionLevel |
Allows to specify the level of log redaction.
|
Refresher |
|
RemoveBucketRequest |
|
RemoveBucketResponse |
|
RemoveDesignDocumentRequest |
|
RemoveDesignDocumentResponse |
|
RemoveNodeRequest |
|
RemoveNodeResponse |
|
RemoveRequest |
|
RemoveResponse |
|
RemoveSearchIndexRequest |
Removes full text search index.
|
RemoveSearchIndexResponse |
Result of full text search index removing.
|
RemoveServiceRequest |
|
RemoveServiceResponse |
|
RemoveUserRequest |
|
RemoveUserResponse |
|
ReplaceRequest |
|
ReplaceResponse |
|
ReplicaGetRequest |
Fetch a document from one or more and/or active nodes replicas.
|
ReplicaNotAvailableException |
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).
|
ReplicaNotConfiguredException |
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).
|
RequestCancelledException |
This exception is thrown when there is a problem in the underlying network I/O.
|
RequestEvent |
A pre allocated event which carries a CouchbaseRequest and associated information.
|
RequestEventFactory |
|
RequestHandler |
|
ResponseEvent |
|
ResponseEventFactory |
|
ResponseHandler |
|
ResponseStatus |
|
ResponseStatusConverter |
Helper class to easily convert different handler status types to a common one.
|
ResponseStatusDetails |
Container for extended response status information.
|
RestApiRequest |
A generic HTTP request to perform on the cluster REST API port (8091).
|
RestApiResponse |
|
RetryHelper |
A helper class which contains methods related to retrying operations.
|
RetryStrategy |
|
RingBufferDiagnostics |
Provides a granular breakdown of the queries in the ringbuffer
|
RingBufferMonitor |
Stores diagnostics on the main ringbuffer to provide additional context to BackpressureExceptions.
|
RoundRobinSelectionStrategy |
|
RuntimeMetricsCollector |
A MetricsCollector which collects and emits system information like gc, memory or thread usage.
|
RuntimeMetricsEvent |
This event contains collected system stats, like GC, Thread and Memory usage.
|
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 .
|
SearchEndpoint |
This endpoint defines the pipeline for search requests and responses (CBFT).
|
SearchHandler |
|
SearchHandler.KeepAliveRequest |
|
SearchHandler.KeepAliveResponse |
|
SearchLocator |
Round robin node locator for CBFT.
|
SearchQueryRequest |
Runs query against search index.
|
SearchQueryResponse |
Result of the full text search query.
|
SearchRequest |
|
SearchService |
|
SearchServiceConfig |
Allows to configure a Search Service on a per-node basis.
|
SecureEnvironment |
|
SeedNodesRequest |
**Set up the bootstrap nodes for a ClusterFacade .**
For stability reasons, it is advised to always provide more than one seed node (but not necessarily all nodes from
the cluster) so that the cluster can correctly bootstrap the bucket, even if one of the hosts in the list is
currently not available.
|
SeedNodesResponse |
|
SelectionStrategy |
Interface which defines a generic selection strategy to select a Endpoint .
|
ServerFeatures |
Features the client negotiates with the server on a per-connection basis.
|
ServerFeaturesEvent |
|
Service |
|
Service.EndpointFactory |
A helper factory which generates endpoints.
|
ServiceFactory |
|
ServiceNotAvailableException |
Exception which states that the service is not available for the bucket.
|
ServiceRegistry |
Handles the registration of services and their associated buckets.
|
ServiceStateZipper |
Calculates a merged state for all registered services.
|
ServiceType |
Represents the different ServiceType s and how they map onto buckets.
|
ShaSaslClient |
Implementation of a SCRAM-SHA512, SCRAM-SHA256 and SCRAM-SHA1 enabled SaslClient .
|
ShaSaslClientFactory |
The SaslClientFactory supporting SCRAM-SHA512, SCRAM-SHA256 and SCRAM-SHA1
authentication methods.
|
ShutdownHook |
Interface to describe shutdown behavior for a resource that
can be asynchronously shut down.
|
SignalConfigReload |
|
SignalFlush |
|
SimpleSubdocResponse |
|
Slf4JLoggerFactory |
Logger factory which creates a SLF4J
logger.
|
SplitPositionBufProcessor |
A ByteBufProcessor to find the position of a single character usable as a split pivot.
|
SSLEngineFactory |
Creates a SSLEngine which will be passed into the handler if SSL is enabled.
|
SSLException |
|
StandardMemcachedHashingStrategy |
|
Stat |
Utility class to handle STAT calls logic.
|
Stateful<S extends Enum> |
A stateful component that changes its state and notifies subscribed parties.
|
StateZipper<T,S extends Enum> |
|
StatRequest |
|
StatResponse |
|
StringClosingPositionBufProcessor |
|
SubArrayRequest |
|
SubArrayRequest.ArrayOperation |
|
SubCounterRequest |
A sub-document counter operation.
|
SubDeleteRequest |
A sub-document delete operation.
|
SubDictAddRequest |
A sub-document dictionary add operation.
|
SubDictUpsertRequest |
A sub-document dictionary upsert operation.
|
SubExistRequest |
A sub-document exist operation.
|
SubGetCountRequest |
A sub-document get count operation.
|
SubGetRequest |
A sub-document get operation.
|
SubMultiLookupDocOptionsBuilder |
|
SubMultiLookupRequest |
|
SubMultiMutationDocOptionsBuilder |
|
SubMultiMutationRequest |
|
SubReplaceRequest |
A sub-document replace operation.
|
ThresholdLogReference |
Represents a reference from one span to another one.
|
ThresholdLogReporter |
The ThresholdLogReporter retrieves spans from (usually) a Tracer
and stores them for threshold-based aggregation and logging.
|
ThresholdLogReporter.Builder |
|
ThresholdLogScope |
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 |
A ScopeManager implementation built on top of Java's thread-local storage primitive,
very similar to the one shipped with "opentracing-util".
|
ThresholdLogSpan |
|
ThresholdLogSpanBuilder |
Allows to build a Span in a builder fashion.
|
ThresholdLogSpanContext |
Holds baggage items for the slow operation spans.
|
ThresholdLogTracer |
This Tracer implementation logs operations over a certain threshold based
on the given configuration.
|
TooManyEnvironmentsEvent |
Event published when more than one Environments are created.
|
TouchRequest |
|
TouchResponse |
.
|
Tuple |
Static factory class for various Tuples.
|
Tuple2<T1,T2> |
A container for two values.
|
Tuple3<T1,T2,T3> |
A container for three values.
|
Tuple4<T1,T2,T3,T4> |
A container for four values.
|
Tuple5<T1,T2,T3,T4,T5> |
A container for five values.
|
UnicastAutoReleaseSubject<T> |
This Subject can be used to auto-release reference counted objects when not subscribed before.
|
UnlockRequest |
|
UnlockResponse |
|
UpdateBucketRequest |
|
UpdateBucketResponse |
|
UpsertDesignDocumentRequest |
|
UpsertDesignDocumentResponse |
|
UpsertRequest |
Insert or update a document.
|
UpsertResponse |
|
UpsertSearchIndexRequest |
Inserts or updates full text search index definition.
|
UpsertSearchIndexResponse |
Contains result of the create/update action on full text search index.
|
UpsertUserRequest |
|
UpsertUserResponse |
|
ViewEndpoint |
This endpoint defines the pipeline for binary requests and responses.
|
ViewHandler |
|
ViewHandler.KeepAliveRequest |
|
ViewHandler.KeepAliveResponse |
|
ViewLocator |
|
ViewQueryRequest |
|
ViewQueryResponse |
|
ViewRequest |
|
ViewService |
|
ViewServiceConfig |
Allows to configure a View Service on a per-node basis.
|
WaitStrategyFactory |
Factory to create a new WaitStrategy when called.
|
WhitespaceSkipper |
This ByteBufProcessor loops while it encounters whitespace
or new lines (' ', '\t', '\r' and '\n').
|
YasjlAnalyticsDeferredResponseParser |
Analytics query response parser, based on yasjl.
|
YasjlAnalyticsResponseParser |
Analytics query response parser, based on yasjl.
|
YasjlQueryResponseParser |
A N1QL/Query response parser, based on yasjl.
|