All Classes Interface Summary Class Summary Enum Summary Exception Summary Annotation Types Summary
Class |
Description |
AbstractBucketConfig |
|
AbstractContext |
Common parent method for all contexts.
|
AbstractEvent |
This Event implementation can be used as a base event to inherit from.
|
AbstractRetry<T,S> |
|
AlreadyShutdownException |
Thrown if a resource is already permanently terminated and tried to be used afterwards.
|
AlternateAddress |
|
AnalyticsChunkHeader |
|
AnalyticsChunkResponseParser |
|
AnalyticsChunkRow |
|
AnalyticsChunkTrailer |
|
AnalyticsEndpoint |
|
AnalyticsEndpoint.AnalyticsPipelineInitializer |
|
AnalyticsMessageHandler |
|
AnalyticsRequest |
|
AnalyticsResponse |
|
AnalyticsService |
|
AnalyticsServiceConfig |
|
AnalyticsServiceConfig.Builder |
|
AnalyticsServiceException |
There was a problem fulfilling the analytics request.
|
Analyzer |
|
AppendRequest |
|
AppendResponse |
|
AuthenticationException |
Every exception that has to do with authentication problems should either
instantiate or subclass from this type.
|
Backoff |
Backoff function
|
BackoffDelay |
|
BadDeltaException |
Subdocument exception thrown when the delta in an arithmetic operation (eg counter) is invalid.
|
BaseChunkResponseParser<H extends ChunkHeader,ROW extends ChunkRow,T extends ChunkTrailer> |
|
BaseEndpoint |
This BaseEndpoint implements all common logic for endpoints that wrap the IO layer.
|
BaseKeyValueRequest<R extends Response> |
The BaseKeyValueRequest should be subclassed by all KeyValue requests since it
provides common ground for all of them (i.e.
|
BaseLoader |
The BaseLoader contains all common functionality needed for the actual loader
implementations.
|
BaseManagerRequest<R extends Response> |
|
BaseRequest<R extends Response> |
|
BaseResponse |
The parent class for all responses passing through the SDK.
|
BestEffortRetryStrategy |
|
BucketCapabilities |
Describes the bucket capabilities in an abstract fashion as provided by
the server.
|
BucketClosedEvent |
This event is raised once a bucket has been closed.
|
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 .
|
BucketNodeLocator |
Represents the node locator used for the specific bucket type.
|
BucketOpenedEvent |
This event is raised once a bucket has been opened.
|
BucketType |
Represents the possible bucket types.
|
Bytes |
|
CancellationReason |
Describes the reason why a Request has been cancelled.
|
CannotInsertValueException |
Subdocument exception thrown when the provided value cannot be inserted at the given path.
|
CarrierBucketConfigRequest |
|
CarrierBucketConfigResponse |
|
CASMismatchException |
Indicates an optimistic locking failure.
|
ChannelAttributes |
This class holds all kinds of channel attributes that are in used across
the KV channel.
|
ChannelClosedProactivelyEvent |
This warning indicates that the client closed an active IO channel/socket proactively because
it detected an invalid state.
|
ChannelClosedProactivelyEvent.Reason |
Specifies the reasons why a channel has been proactively closed by the SDK.
|
ChannelContext |
Holds context to encode KV operations based on what got negotiated in the channel.
|
ChunkDecodable<H extends ChunkHeader,ROW extends ChunkRow,T extends ChunkTrailer,R extends ChunkedResponse<H,ROW,T>> |
Marker interface to describe how the chunked response can be decoded.
|
ChunkedHandlerSwitcher |
Parent class for all pipelines which need to switch between a chunked and a non-chunked handler structure.
|
ChunkedMessageHandler<H extends ChunkHeader,ROW extends ChunkRow,T extends ChunkTrailer,R extends ChunkedResponse<H,ROW,T>,REQ extends HttpRequest<H,ROW,T,R>> |
Implements the chunk stream handling for all generic http stream based services.
|
ChunkedResponse<H extends ChunkHeader,R extends ChunkRow,T extends ChunkTrailer> |
Describes a full chunked response with its required sections.
|
ChunkHeader |
Marker interface to describe the leading bits of a chunked response.
|
ChunkResponseParser<H extends ChunkHeader,ROW extends ChunkRow,T extends ChunkTrailer> |
Defines the common parser interface for all chunked response parser implementations.
|
ChunkRow |
Marker interface to describe a row emitted from a chunked response.
|
ChunkTrailer |
Marker interface to describe the trailing bits of a chunked response.
|
CircuitBreaker |
|
CircuitBreaker.State |
Represents all the states a circuit breaker can be in, possibly.
|
CircuitBreakerConfig |
|
CircuitBreakerConfig.Builder |
|
ClusterCapabilities |
Contains all the cluster capabilities this SDK supports (depending on the server version, the cluster may
export more than these).
|
ClusterConfig |
|
ClusterManagerLoader |
This loader is responsible for loading a config from the cluster manager.
|
ClusterManagerRefresher |
|
CodecFlags |
|
CodecFlags.CommonFlags |
The common flags enum.
|
CollectionDoesNotExistException |
This exception is raised when collections are enabled, but the given collection name
(or combination of scope and collection) does not exist.
|
CollectionIdentifier |
|
CollectionMap |
The CollectionMap maps a locator to the encoded collection ID representation.
|
CollectionMapDecodingFailedEvent |
This event is raised if a collection map could be loaded, but afterwards cannot be decoded and used
as intended.
|
CollectionMapRefreshFailedEvent |
This event is raised if a collection map could not be refreshed properly.
|
CollectionsManifest |
|
CollectionsManifestCollection |
|
CollectionsManifestScope |
|
CollectionsNotAvailableException |
This exception is raised when collections are not available on the connected cluster, likely
because a version is used that does not support them.
|
CommonExceptions |
|
CompressionConfig |
Allows configuring and customizing the compression configuration.
|
CompressionConfig.Builder |
|
ConfigException |
|
ConfigIgnoredEvent |
|
ConfigIgnoredEvent.Reason |
The reason why the proposed config got ignored.
|
ConfigUpdatedEvent |
|
ConfigurationProvider |
The ConfigurationProvider is responsible for grabbing, converting and managing
bucket and cluster configurations.
|
ConnectionString |
|
ConnectionString.Scheme |
|
ConnectionString.UnresolvedSocket |
|
ConnectionStringPropertyLoader |
This PropertyLoader takes a connection string and applies all properties
that are supported and it knows about.
|
ConnectTimings |
This class gets populated with timings and success/failure of different steps in the
channel bootstrap process and later allows to extract useful information for debugging.
|
Context |
Context represents some state that is passed throughout the system.
|
Context.ExportFormat |
The format into which the context can be exported.
|
CopyingStreamWindow |
A stream window implementation that copies input data into a single accumulator buffer.
|
Core |
The main entry point into the core layer.
|
CoreContext |
The CoreContext is bound to a core and provides both exportable and
usable state for the rest of the application to use.
|
CoreEnvironment |
The CoreEnvironment is an extendable, configurable and stateful
config designed to be passed into a core instance.
|
CoreEnvironment.Builder<SELF extends CoreEnvironment.Builder<SELF>> |
|
CouchbaseBucketConfig |
|
CouchbaseException |
The parent class for all exceptions created by this SDK (or clients using it).
|
CouchbaseOutOfMemoryException |
Thrown when Couchbase Server returns with an Out of Memory error.
|
CouchbaseSaslClientFactory |
This SaslClientFactory supports all couchbase supported SASL authentication
mechanisms.
|
Credentials |
The Credentials encapsulate different ways of carrying credentials throughout
the client.
|
DecodingFailedException |
Raised when provided content could not be successfully decoded.
|
DecrementRequest |
|
DecrementResponse |
|
DefaultConfigurationProvider |
|
DefaultContext<T> |
|
DefaultErrorUtil |
|
DefaultEventBus |
|
DefaultEventBus.Builder |
|
DefaultRepeat<T> |
|
DefaultRetry<T> |
|
DiagnosticsMonitor |
The DiagnosticsMonitor keeps a close eye on system resources and emits events
if they are over a configurable threshold.
|
DiagnosticsMonitor.Builder |
Allows to configure the diagnostics monitor.
|
DocumentMutationLostException |
|
DocumentNotJsonException |
Subdocument exception thrown when the targeted enclosing document itself is not JSON.
|
DocumentTooDeepException |
Subdocument exception thrown when document is too deep to parse.
|
DurabilityAmbiguousException |
Naming TBD!
The synchronous replication durability work can return an ambiguous error (or we timeout waiting for the response,
which is effectively the same).
|
DurabilityImpossibleException |
The given durability requirements are currently impossible to achieve, as not enough configured replicas
are currently available.
|
DurabilityLevel |
|
DurabilityLevelNotAvailableException |
This exception is raised when a durability level has been requested that is not available on the server.
|
DurableWriteInProgressException |
Returned if an attempt is made to mutate a key which already has a durable write pending.
|
Encodable<T> |
|
EncodingFailedException |
Raised when provided content could not be successfully encoded.
|
Endpoint |
The parent interface for all endpoints.
|
EndpointConnectedEvent |
This event is published when an endpoint is connected properly.
|
EndpointConnectionAbortedEvent |
This event is published when an endpoint is in the phase of reconnecting because
of an error, but disconnect was called in the meantime and as a result any
further reconnect attempts are aborted.
|
EndpointConnectionFailedEvent |
This event is published when an endpoint connect attempt failed.
|
EndpointConnectionIgnoredEvent |
This event is published when an endpoint is connected properly but
a disconnect signal came before so it is ignored.
|
EndpointContext |
|
EndpointDisconnectedEvent |
This event is generated when an endpoint is correctly disconnected.
|
EndpointDisconnectionFailedEvent |
This event is raised if an endpoint disconnect attempt failed for some reason.
|
EndpointSelectionStrategy |
|
EndpointState |
Represents all states an Endpoint can be in.
|
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 |
|
ErrorMapLoadedEvent |
The KV error map got negotiated loaded from the server.
|
ErrorMapLoadingFailedEvent |
If loading the KV error map for some reason fails, this event will capture
the KV status code.
|
ErrorMapLoadingHandler |
This handler tries to load the KV Error Map in a best effort manner.
|
ErrorMapUndecodableEvent |
If the KV error map could be loaded, but the decoding of the
buffer from JSON failed, this event will be raised.
|
Event |
The parent interface for all events pushed through the command and
control system.
|
Event.Category |
Describes the category of any given event.
|
Event.Severity |
Describes the severity of any given event.
|
EventBus |
The EventBus is the main demarcation line between internal behavior and external
visibility.
|
EventBus.PublishResult |
Signals if a publish call was successful and if not why.
|
EventSubscription |
Subscription for a consumer on a EventBus that can be used
to unsubscribe once done.
|
ExternalSupplier<T> |
|
FailFastRetryStrategy |
|
FeatureNegotiatingHandler |
The FeatureNegotiatingHandler is responsible for sending the KV "hello" command
and to handshake enabled features on both sides.
|
FeaturesNegotiatedEvent |
Captures the end of the KV feature negotiation.
|
FeaturesNegotiationFailedEvent |
|
GarbageCollectionsDetectedEvent |
|
GcAnalyzer |
The GcAnalyzer takes incoming GarbageCollectionNotificationInfo from the
JVM and analyzes it.
|
GcAnalyzer.Concurrency |
Concurrency of a given algorithm/gc type.
|
GcAnalyzer.GcGeneration |
Specifies the generation that got collected in this event.
|
GcAnalyzer.GcType |
Holds the known type of garbage collectors and their representations in the
GC logs in textual format.
|
GenericFailureDetectedEvent |
|
GetAndLockRequest |
Represents a KV GetAndTouch operation.
|
GetAndLockResponse |
|
GetAndTouchRequest |
Represents a KV GetAndTouch operation.
|
GetAndTouchResponse |
|
GetCollectionIdRequest |
|
GetCollectionIdResponse |
|
GetCollectionManifestRequest |
|
GetCollectionManifestResponse |
|
GetRequest |
Represents a KV Get (full document) operation.
|
GetResponse |
|
GetSearchIndexRequest |
|
GetSearchIndexResponse |
|
Golang |
Helper methods that have to do with certain golang-specific format the server uses.
|
HttpProtocol |
Helper methods that need to be used when dealing with the HTTP protocol.
|
HttpRequest<H extends ChunkHeader,ROW extends ChunkRow,T extends ChunkTrailer,R extends ChunkedResponse<H,ROW,T>> |
|
IncrementRequest |
|
IncrementResponse |
|
IndividualReplicaGetFailedEvent |
When a replica get fetches more than one in one shot and an individual item fails it
will be ignored, but this event is logged to aid with debugging.
|
InsertRequest |
Uses the KV "add" command to insert documents if they do not already exist.
|
InsertResponse |
|
InvalidPacketDetectedEvent |
This event is created if somewhere in the IO layer an invalid packet
was detected.
|
InvalidRequestDetectedEvent |
If this event is raised, it indicates a serious bug in the system.
|
IoConfig |
|
IoConfig.Builder |
|
IoContext |
The IoContext is used to extend the core context with IO related metadata
that is useful during event generation.
|
IoEnvironment |
|
IoEnvironment.Builder |
|
IterationContext<T> |
Context provided to retry or repeat callbacks.
|
Jitter |
Jitter function that is applied to the backoff delay.
|
JsonStreamParser |
|
JsonStreamParser.Builder |
|
KeyExistsException |
Indicates an operation failed because the key already exists.
|
KeyNotFoundException |
Indicates an operation failed because the key does not exist.
|
KeyValueEndpoint |
|
KeyValueEndpoint.KeyValuePipelineInitializer |
|
KeyValueLoader |
This loader is responsible for initially loading a configuration through the kv protocol.
|
KeyValueLocator |
A Locator responsible for locating the right node based on the partition of the
key.
|
KeyValueMessageHandler |
This handler is responsible for writing KV requests and completing their associated responses
once they arrive.
|
KeyValueRefresher |
|
KeyValueRequest<R extends Response> |
Main parent interface for all Key/Value requests.
|
KeyValueService |
|
KeyValueServiceConfig |
|
KeyValueServiceConfig.Builder |
|
Loader |
The Loader is responsible for initially loading a fresh configuration from the
cluster.
|
Locator |
|
LoggerConfig |
|
LoggerConfig.Builder |
|
LoggingEventConsumer |
Consumes Events and logs them per configuration.
|
LoggingEventConsumer.Logger |
Generic logger interface.
|
LogRedaction |
Static utility methods for global log redaction settings.
|
LRUCache<K,V> |
Implements a generic LRU cache which evicts after the max size is reached.
|
ManagerEndpoint |
|
ManagerEndpoint.ManagerPipelineInitializer |
|
ManagerLocator |
|
ManagerMessageHandler |
This handler dispatches requests and responses against the cluster manager service.
|
ManagerRequest<R extends Response> |
|
ManagerService |
|
Mapper |
Provides utilities for encoding and decoding JSON data.
|
MapperException |
This exception is usually raised when a JSON encoding or decoding was not successful.
|
MatchedValue |
|
MemcachedBucketConfig |
|
MemcachedHashingStrategy |
This interface defines different hashing strategies used for ketama hashing in memcached buckets.
|
MemcacheProtocol |
The MemcacheProtocol class holds static helpers that deal with the encoding
and decoding as well as access of the memcache binary protocol.
|
MemcacheProtocol.Datatype |
|
MemcacheProtocol.Magic |
|
MemcacheProtocol.Opcode |
Contains all known/used kv protocol opcodes.
|
MemcacheProtocol.Status |
|
MemcacheProtocolDecodeHandler |
The MemcacheProtocolDecodeHandler is a lightweight decoder that understands the
KV header and aggregates header and value into one buffer before passing it on.
|
MemcacheProtocolVerificationHandler |
This handler makes sure that the KV protocol packets passed around
are not malformed.
|
MultiMutationException |
Exception denoting that at least one error occurred when applying
multiple mutations using the sub-document API.
|
MutationToken |
Value object to contain vbucket UUID and sequence number.
|
NetworkResolution |
Configuration options for the network resolution setting.
|
Node |
|
NodeConnectedEvent |
This event is generated when a node is correctly connected.
|
NodeContext |
|
NodeDisconnectedEvent |
This event is generated when a node is correctly disconnected.
|
NodeDisconnectIgnoredEvent |
|
NodeDisconnectIgnoredEvent.Reason |
Enumerates the reasons why a disconnect nod event could be ignored by the system.
|
NodeIdentifier |
Identifies a node uniquely in the cluster.
|
NodeInfo |
|
NodeLocatorBugIdentifiedEvent |
|
NodePartitionLengthNotEqualEvent |
|
NodeState |
Holds all the different states a Node can be in.
|
NonChunkedHttpMessageHandler |
|
NonChunkedHttpRequest<R extends Response> |
|
NoopCircuitBreaker |
A simple noop implementation of the CircuitBreaker if disabled by the user.
|
NoopRequest |
Represents a NOOP KV Request, doing nothing.
|
NoopResponse |
|
NumberTooBigException |
Subdocument exception thrown when existing number value in document is too big.
|
Observe |
Implements traditional observe-based durability requirements.
|
Observe.ObservePersistTo |
Defines the possible disk persistence constraints to observe.
|
Observe.ObserveReplicateTo |
Defines the possible replication constraints to observe.
|
ObserveContext |
|
ObserveViaCasRequest |
|
ObserveViaCasResponse |
|
ObserveViaCasResponse.ObserveStatus |
|
ObserveViaSeqnoRequest |
|
ObserveViaSeqnoResponse |
|
OperationDoesNotExist |
Raised when a requested subdoc operation does not exist.
|
OwnedSupplier<T> |
|
Partition |
|
PartitionInfo |
Represents the partition information for a bucket.
|
PartitionSelectionStrategy |
|
PathExistsException |
Subdocument exception thrown when a path already exists and it shouldn't
|
PathInvalidException |
Subdocument exception thrown when path has a syntax error, or path syntax is incorrect for the operation
(for example, if operation requires an array index).
|
PathMismatchException |
Subdocument exception thrown when the path structure conflicts with the document structure
(for example, if a path mentions foo.bar[0].baz, but foo.bar is actually a JSON object).
|
PathNotFoundException |
Subdocument exception thrown when a path does not exist in the document.
|
PathTooDeepException |
Subdocument exception thrown when path is too deep to parse.
|
PauseAnalyzer |
Analyzes JVM pauses by utilizing the great PauseDetector from LatencyUtils.
|
PausesDetectedEvent |
When the analyzer detects a JVM pause, an event will be raised.
|
PipelineErrorHandler |
|
PipelineInitializer |
Interface which provides a common API to initialize endpoint-specific pipelines.
|
PortInfo |
|
PrependRequest |
|
PrependResponse |
|
PropertyLoader<B extends CoreEnvironment.Builder> |
|
ProposedBucketConfigContext |
This context keeps together a bunch of related information needed to turn a raw
config into a parsed one.
|
QueryChunkHeader |
|
QueryChunkResponseParser |
|
QueryChunkRow |
|
QueryChunkTrailer |
|
QueryEndpoint |
|
QueryEndpoint.QueryPipelineInitializer |
|
QueryMessageHandler |
|
QueryRequest |
|
QueryResponse |
|
QueryService |
|
QueryServiceConfig |
|
QueryServiceConfig.Builder |
|
QueryServiceException |
There was a problem fulfilling the query request.
|
QueryStreamException |
Exception thrown when the Query stream subscribers
- did not send enough requests to consume the entire chunked response in the stream
- do not consume the request response
- do not send a request before the stream times out and releases the response
further on the socket, so the socket can be used for other requests.
|
Reactor |
This class provides utility methods when working with reactor.
|
ReadTrafficCapturedEvent |
|
ReconfigurationCompletedEvent |
Client got a new config and completed the reconfiguration properly without issue.
|
ReconfigurationErrorDetectedEvent |
The client ran into an error during a config reconfiguration event.
|
ReconfigurationIgnoredEvent |
Client got a new config, but for some valid reason the event is ignored.
|
RedactableArgument |
Wraps a piece of information that is subject to log redaction.
|
RedactionLevel |
Allows to specify the level of log redaction.
|
Refresher |
The Refresher is responsible to keep the configurations up to date after the initial
bootstrap/load.
|
RemoveRequest |
Represents a KV delete operation.
|
RemoveResponse |
|
RemoveSearchIndexRequest |
|
RemoveSearchIndexResponse |
|
Repeat<T> |
|
RepeatContext<T> |
|
ReplaceRequest |
Uses the KV replace command to replace a document if it exists.
|
ReplaceResponse |
|
ReplicaGetRequest |
|
ReplicaNotAvailableException |
|
ReplicaNotConfiguredException |
|
Request<R extends Response> |
Represents a Request flowing through the client.
|
RequestCanceledException |
|
RequestContext |
Additional context which might be attached to an individual Request .
|
RequestNotRetriedEvent |
This event is raised if a request is not retried anymore.
|
RequestRetriedEvent |
|
RequestTimeoutException |
|
RequestTooBigException |
Thrown when the request is too big for some reason.
|
Response |
This interface is the base entity for all Responses flowing through the client.
|
ResponseStatus |
The ResponseStatus describes what kind of response came back for a specific
request.
|
ResponseStatusConverter |
|
ResponseStatusDetails |
Container for extended response status information.
|
Retry<T> |
|
RetryableOperationException |
This operation has returned a temporary error, and the application can retry it.
|
RetryContext<T> |
|
RetryExhaustedException |
|
RetryOrchestrator |
The RetryOrchestrator is responsible for checking if a request is eligible for retry
and if so dispatch it properly and update state.
|
RetryStrategy |
|
RoleBasedCredentials |
|
RoundRobinLocator |
A Locator which implements node selection on a round-robin basis.
|
RoundRobinSelectionStrategy |
|
SaslAuthenticationCompletedEvent |
|
SaslAuthenticationFailedEvent |
If something goes wrong during the SASL authentication process, this event is raised.
|
SaslAuthenticationHandler |
This handler is responsible for perform SASL authentication against the KV engine.
|
SaslMechanism |
|
SaslMechanismsSelectedEvent |
This debug event signals that a SASL auth mechanism has been negotiated
between the client and the server.
|
SchedulerClock |
|
ScopedRequest |
|
ScramSaslClientFactory |
|
SearchChunkHeader |
|
SearchChunkResponseParser |
|
SearchChunkRow |
|
SearchChunkTrailer |
|
SearchEndpoint |
|
SearchEndpoint.SearchPipelineInitializer |
|
SearchHandlerSwitcher |
|
SearchRequest |
|
SearchResponse |
|
SearchService |
|
SearchServiceConfig |
|
SearchServiceConfig.Builder |
|
SearchServiceException |
There was a problem fulfilling the search request.
|
SecureConnectionFailedEvent |
|
SecurityConfig |
|
SecurityConfig.Builder |
|
SecurityException |
|
SeedNode |
|
SelectBucketCompletedEvent |
This event gets created as soon as a bucket has been selected during the
KV bootstrap process for each socket/node.
|
SelectBucketDisabledEvent |
This event is triggered when during the HELLO negotiation it was
determined that the server does not support the select bucket
command.
|
SelectBucketFailedEvent |
If selecting a bucket during KV bootstrap fails, this is a really problematic
issue and needs to be looked at.
|
SelectBucketHandler |
|
ServerFeature |
The ServerFeature enum describes all the different negotiation modes
between the server and the SDK.
|
Service |
The parent interface for all service implementations.
|
ServiceAddedEvent |
|
ServiceAddIgnoredEvent |
|
ServiceAddIgnoredEvent.Reason |
Enumerates the reasons why a add service event could be ignored by the system.
|
ServiceConfig |
|
ServiceConfig |
|
ServiceConfig.Builder |
|
ServiceConnectInitiatedEvent |
|
ServiceContext |
|
ServiceDisconnectInitiatedEvent |
|
ServiceNotAvailableException |
Exception which states that the service is not available for the bucket.
|
ServiceReconfigurationFailedEvent |
|
ServiceRemovedEvent |
|
ServiceRemoveIgnoredEvent |
|
ServiceRemoveIgnoredEvent.Reason |
Enumerates the reasons why a remove service event could be ignored by the system.
|
ServiceScope |
|
ServiceState |
Holds all states a Service can be in.
|
ServiceType |
Describes the types of services available in a couchbase cluster.
|
ShutdownCompletedEvent |
Raised when a core is successfully shut down.
|
SslHandlerFactory |
This factory creates SslHandler based on a given configuration.
|
Stability |
This annotation describes the stability guarantees of the annotated
interface, class or method.
|
Stability.Committed |
A committed interface is the highest grade of stability, and is the preferred attribute
level for consumers of the library.
|
Stability.Internal |
This is internal API and may not be relied on at all.
|
Stability.Uncommitted |
No commitment is made about the interface.
|
Stability.Volatile |
Types/Methods/Interfaces marked as volatile can change any time and
for any reason.
|
StandardMemcachedHashingStrategy |
|
StreamWindow |
A sliding window over the contents of a byte stream.
|
SubdocCommandType |
|
SubdocField |
|
SubdocGetRequest |
|
SubdocGetRequest.Command |
|
SubdocGetResponse |
|
SubdocMutateRequest |
|
SubdocMutateRequest.Command |
|
SubdocMutateResponse |
|
SubDocumentException |
An abstract common class for all CouchbaseException that relates
to the sub-document feature.
|
SubDocumentOpResponseStatus |
|
SystemPropertyPropertyLoader |
|
TargetedRequest |
|
TemporaryFailureException |
Thrown when the server reports a temporary failure.
|
TemporaryLockFailureException |
Thrown when the server reports a temporary failure and it
is very likely to be lock-related (like an already locked
key or a bad cas used for unlock).
|
TerseBucketConfigRequest |
|
TerseBucketConfigResponse |
|
TimeoutConfig |
|
TimeoutConfig.Builder |
|
Timer |
The Timer acts as the main timing facility for various operations, for
example to track and time out requests if they run for too long.
|
TouchRequest |
|
TouchResponse |
|
TracingUtils |
|
TracingUtils.OpName |
|
TrafficCaptureHandler |
Similar to the netty LoggingHandler, but it dumps the traffic into the event bus for later
consumption instead of logging it right away.
|
UnexpectedEndpointConnectionFailedEvent |
During connecting to an endpoint, an exception/error was raised which was not expected.
|
UnknownResponseReceivedEvent |
|
UnlockRequest |
|
UnlockResponse |
|
UnsignedLEB128 |
Encodes and decodes the unsigned LEB128 (Little Endian Base 128) format.
|
UnsolicitedFeaturesReturnedEvent |
If the server sends us unsolicited features during the HELLO negotiation,
this event will be raised - it is a warning severity since it indicates
a server bug.
|
UnsupportedConfigMechanismException |
|
UnsupportedResponseTypeReceivedEvent |
|
UpsertRequest |
Uses the KV "set" command to unconditionally replace or insert documents regardless if they
exist or not.
|
UpsertResponse |
|
UpsertSearchIndexRequest |
|
UpsertSearchIndexResponse |
|
UrlQueryStringBuilder |
|
UserAgent |
Represents a user-agent for this client.
|
Utils |
Provides various helper utilities for forking with a KV channel.
|
Validators |
Common validators used throughout the client.
|
ValueTooDeepException |
Subdocument exception thrown when proposed value would make the document too deep to parse.
|
ViewChunkHeader |
|
ViewChunkResponseParser |
|
ViewChunkRow |
|
ViewChunkTrailer |
|
ViewEndpoint |
|
ViewEndpoint.ViewPipelineInitializer |
|
ViewError |
|
ViewMessageHandler |
|
ViewRequest |
|
ViewResponse |
|
ViewService |
|
ViewServiceConfig |
|
ViewServiceConfig.Builder |
|
ViewServiceException |
There was a problem fulfilling the view request.
|
WriteTrafficCapturedEvent |
|
XattrInvalidFlagComboException |
Subdocument exception thrown when a macro has been requested when not using extended attributes.
|
XattrUnknownMacroException |
Subdocument exception thrown when a macro has been requested which is not recognised by the server.
|