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.
|
| AbstractMapPropertyLoader<B extends CoreEnvironment.Builder> |
Loads properties from a string/string map.
|
| AbstractPooledEndpointServiceConfig |
|
| AbstractPooledEndpointServiceConfig.Builder<SELF extends AbstractPooledEndpointServiceConfig.Builder<?>> |
|
| AbstractRetry<T,S> |
|
| AccessorUtil |
|
| ActiveTransactionRecord |
|
| ActiveTransactionRecord.ParsedHLC |
|
| ActiveTransactionRecordEntry |
|
| ActiveTransactionRecordEntryNotFoundException |
|
| ActiveTransactionRecordFullException |
|
| ActiveTransactionRecordIds |
|
| ActiveTransactionRecordNotFoundException |
|
| ActiveTransactionRecords |
|
| ActiveTransactionRecordStats |
Simple data class, so all fields are public.
|
| ActiveTransactionRecordUtil |
|
| AggregateErrorContext |
An error context which combines more than one context to dump.
|
| AggregatingCounter |
At the moment this is a NOOP implementation because we do not perform any aggregations
on the counters.
|
| AggregatingValueRecorder |
Aggregates value information in a histogram.
|
| AlreadyShutdownException |
Thrown if a resource is already permanently terminated and tried to be used afterwards.
|
| AlternateAddress |
|
| AmbiguousTimeoutException |
This is a special case of the timeout exception, signaling that the timeout happened with an ambiguous cause.
|
| AnalyticsChunkHeader |
|
| AnalyticsChunkResponseParser |
|
| AnalyticsChunkRow |
|
| AnalyticsChunkTrailer |
|
| AnalyticsEndpoint |
|
| AnalyticsEndpoint.AnalyticsPipelineInitializer |
|
| AnalyticsErrorContext |
|
| AnalyticsException |
There was a problem fulfilling the analytics request.
|
| AnalyticsHandlerSwitcher |
|
| AnalyticsLocator |
|
| AnalyticsMessageHandler |
|
| AnalyticsRequest |
|
| AnalyticsResponse |
|
| AnalyticsService |
|
| AnalyticsServiceConfig |
|
| AnalyticsServiceConfig.Builder |
|
| AppendRequest |
|
| AppendResponse |
|
| AttemptExpiredException |
|
| AttemptNotFoundOnQueryException |
Query does not recognise the passed txid.
|
| AttemptState |
The possible states for a transaction attempt.
|
| AuthenticationFailureException |
Every exception that has to do with authentication problems should either
instantiate or subclass from this type.
|
| AuthenticationStatus |
The last known authentication status for an endpoint.
|
| Authenticator |
|
| AuthErrorDecider |
|
| Backoff |
Backoff function
|
| BackoffDelay |
|
| BackupEndpoint |
|
| BackupEndpoint.BackupPipelineInitializer |
|
| BackupService |
|
| BaseBucketLoader |
The BaseBucketLoader contains all common functionality needed for the actual loader
implementations.
|
| 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.
|
| BaseManagerRequest<R extends Response> |
Base class for the manager requests, mainly to define the service type in a uniform way.
|
| BaseRequest<R extends Response> |
|
| BaseResponse |
The parent class for all responses passing through the SDK.
|
| BeforeSendRequestCallback |
This callback is executed once an operation reaches the core and gets sent to a node.
|
| BestEffortRetryStrategy |
Retries operations on a best-effort basis until they time out.
|
| BinaryAccessor |
|
| 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.
|
| BucketConfigRefreshFailedEvent |
|
| BucketConfigRefreshFailedEvent.Reason |
The reason with severity for the failure.
|
| BucketConfigRefreshFailedEvent.RefresherType |
The type of refresher that causes the failure.
|
| BucketConfigRequest |
|
| BucketConfigResponse |
|
| BucketConfigStreamingRequest |
Performs a (potential endless) streaming request against the cluster manager for the given bucket.
|
| BucketConfigStreamingResponse |
|
| BucketConfigUpdatedEvent |
This event is raised when a bucket config has been updated.
|
| BucketConfigUtil |
Defines helpful routines for working with bucket configs.
|
| BucketExistsException |
|
| BucketLoader |
The BucketLoader is responsible for initially loading a fresh configuration from the
cluster.
|
| BucketNodeLocator |
Represents the node locator used for the specific bucket type.
|
| BucketNotFlushableException |
|
| BucketNotFoundDuringLoadException |
Exception raised if during config load the bucket is not found (think: http 404).
|
| BucketNotFoundException |
|
| BucketNotReadyDuringLoadException |
Exception raised if during config load the bucket is found, but not deemed ready yet.
|
| BucketOpenedEvent |
This event is raised once a bucket has been opened.
|
| BucketOpenFailedEvent |
Reports a bucket open failure which has not been retried.
|
| BucketOpenInitiatedEvent |
This event is raised when a bucket is supposed to be opened.
|
| BucketOpenRetriedEvent |
This event is raised if a bucket could not be opened and is retried, for debugging reasons.
|
| BucketRefresher |
The BucketRefresher is responsible to keep the configurations up to date after the initial
bootstrap/load.
|
| BucketType |
Represents the possible bucket types.
|
| Bytes |
Defines useful constants and methods regarding bytes.
|
| CancellationErrorContext |
When a cancellation (i.e.
|
| CancellationReason |
Describes the reason why a Request has been cancelled.
|
| CarrierBucketConfigRequest |
|
| CarrierBucketConfigResponse |
|
| CarrierGlobalConfigRequest |
A request to fetch a global configuration.
|
| CarrierGlobalConfigResponse |
|
| CasMismatchException |
Indicates an optimistic locking failure.
|
| CasMode |
Metadata related to the CAS.
|
| CbAnnotations |
|
| CbCollections |
|
| CbObjects |
|
| CbPreconditions |
|
| CbStrings |
|
| CbThrowables |
|
| CbTracing |
|
| CertificateAuthenticator |
Performs authentication through a client certificate instead of supplying username and password.
|
| 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.
|
| 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.CompletionCallback |
Defines if a request is considered a success or a failure.
|
| CircuitBreaker.State |
Represents all the states a circuit breaker can be in, possibly.
|
| CircuitBreakerConfig |
|
| CircuitBreakerConfig.Builder |
|
| ClassicCoreBaseSearchIndexManager |
|
| ClassicCoreClusterSearchIndexManager |
|
| ClassicCoreCollectionManagerOps |
|
| ClassicCoreKvBinaryOps |
|
| ClassicCoreKvOps |
|
| ClassicCoreQueryMetaData |
|
| ClassicCoreQueryMetrics |
|
| ClassicCoreQueryOps |
|
| ClassicCoreQueryResult |
|
| ClassicCoreReactiveQueryResult |
|
| ClassicCoreScopeSearchIndexManager |
|
| ClassicCoreSearchOps |
|
| ClassicExpiryHelper |
|
| ClassicHelper |
|
| CleanerFactory |
Used for testing/mocking.
|
| CleanerHooks |
|
| CleanerMockFactory |
Used for testing/mocking.
|
| CleanupFailedEvent |
The cleanup attempt failed and was unable to cleanly return a CleanupResultEvent with !success
|
| CleanupRequest |
|
| ClientRecord |
Represents the ClientRecord doc, a single document that contains an entry for every client (app) current
participating
in the cleanup of 'lost' transactions.
|
| ClientRecordDetails |
Utility class to store the result of a client checking/updating the Client Record doc.
|
| ClientRecordFactory |
Used for testing/mocking.
|
| ClientRecordFactoryMock |
Used for testing/mocking.
|
| ClusterCapabilities |
Contains all the cluster capabilities this SDK supports (depending on the server version, the cluster may
export more than these).
|
| ClusterConfig |
The ClusterConfig holds bucket and global configurations in a central place.
|
| ClusterManagerBucketLoader |
This loader is responsible for loading a config from the cluster manager.
|
| ClusterManagerBucketRefresher |
|
| ClusterState |
Describes the cluster state from the clients perspective in a simplified and aggregated state.
|
| CodecFlags |
|
| CodecFlags.CommonFlags |
The common flags enum.
|
| CollectionExistsException |
|
| 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.
|
| CollectionMapRefreshFailedEvent.Reason |
|
| CollectionMapRefreshIgnoredEvent |
This event is raised if an individual collection refresh is ignored.
|
| CollectionMapRefreshSucceededEvent |
This event is raised if an individual collection map refresh attempt succeeded.
|
| CollectionNotFoundException |
|
| CollectionOutdatedHandledEvent |
|
| CollectionsManifest |
|
| CollectionsManifestCollection |
|
| CollectionsManifestScope |
|
| CommitNotPermittedException |
The transaction is not allowed to commit in the current state.
|
| CommonExceptions |
|
| CompilationFailureException |
The query failed to compile.
|
| CompositeStateful<T,IN,OUT> |
Represents a stateful component of one or more individual stateful elements.
|
| CompressionConfig |
Allows configuring and customizing the compression configuration.
|
| CompressionConfig.Builder |
|
| ConcurrentOperationsDetectedOnSameDocumentException |
Concurrent Key-Value operations on the same document have been detected.
|
| ConfigException |
|
| ConfigIgnoredEvent |
|
| ConfigIgnoredEvent.Reason |
The reason why the proposed config got ignored.
|
| ConfigPushFailedEvent |
This event is raised if a config cannot be pushed to downstream subscribers.
|
| ConfigRefreshFailure |
|
| ConfigurationProfile |
|
| ConfigurationProvider |
The ConfigurationProvider is responsible for grabbing, converting and managing
bucket and cluster configurations.
|
| ConnectionString |
|
| ConnectionString.PortType |
|
| ConnectionString.Scheme |
|
| ConnectionString.UnresolvedSocket |
|
| ConnectionStringIgnoredEvent |
Deprecated.
|
| ConnectionStringPropertyLoader |
This PropertyLoader takes a connection string and applies all properties
that are supported and it knows about.
|
| ConnectionStringUtil |
Contains various helper methods when dealing with the connection string.
|
| 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.
|
| ConsistencyUtil |
Helper routines for tests to wait for all nodes to have a consistent view of a resource.
|
| 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.
|
| Core.ResponseMetricIdentifier |
|
| CoreAbstractCompoundQuery |
|
| CoreAbstractSearchFacetResult |
|
| CoreAnalyticsLinkManager |
|
| CoreAsyncResponse<T> |
|
| CoreAsyncUtils |
|
| CoreBooleanFieldQuery |
|
| CoreBooleanQuery |
|
| CoreBucketAndScope |
|
| CoreBucketManager |
|
| CoreBuildQueryIndexOptions |
Allows customizing how deferred indexes are built.
|
| CoreCollectionManager |
|
| CoreCollectionQueryIndexManager |
|
| CoreCommonOptions |
|
| CoreConjunctionQuery |
|
| CoreContext |
The CoreContext is bound to a core and provides both exportable and
usable state for the rest of the application to use.
|
| CoreCoordinate |
|
| CoreCouchbaseOps |
Provides access to the various Core*Ops instances.
|
| CoreCounterResult |
|
| CoreCreatedEvent |
This event is emitted when a Core is created.
|
| CoreCreatePrimaryQueryIndexOptions |
Allows customizing how a query primary index is created.
|
| CoreCreateQueryIndexOptions |
Allows customizing how a query index is created.
|
| CoreCreateQueryIndexSharedOptions |
Allows customizing how a query primary index is created.
|
| CoreDateRange |
|
| CoreDateRangeFacet |
|
| CoreDateRangeQuery |
|
| CoreDateRangeSearchFacetResult |
|
| CoreDisjunctionQuery |
|
| CoreDocIdQuery |
|
| CoreDropPrimaryQueryIndexOptions |
Allows customizing how primary indexes are dropped.
|
| CoreDropQueryIndexOptions |
Allows customizing how query indexes are dropped.
|
| CoreDurability |
Either a synchronous DurabilityLevel, or "persist to and replicate to" for legacy durability.
|
| CoreEncodedContent |
|
| CoreEnvironment |
The Environment is the main place in the SDK where configuration and state lives (i.e.
|
| CoreEnvironment.Builder<SELF extends CoreEnvironment.Builder<SELF>> |
|
| CoreEventingFunctionManager |
Encapsulates common functionality around the eventing management APIs.
|
| CoreExistsResult |
|
| CoreExpiry |
A relative or absolute expiry.
|
| CoreGeoBoundingBoxQuery |
|
| CoreGeoDistanceQuery |
|
| CoreGeoPolygonQuery |
|
| CoreGetAllQueryIndexesOptions |
Allows customizing how query indexes are loaded.
|
| CoreGetResult |
|
| CoreHighlightStyle |
|
| CoreHttpClient |
|
| CoreHttpPath |
The "path" component of a URI, with support for path parameters
whose replacement values are automatically url-encoded.
|
| CoreHttpRequest |
|
| CoreHttpRequest.Builder |
Builder for dynamic HTTP requests
|
| CoreHttpResponse |
|
| CoreIdGenerator |
|
| CoreKeyspace |
|
| CoreKvBinaryOps |
|
| CoreKvBinaryParamValidators |
|
| CoreKvOps |
|
| CoreKvParamValidators |
|
| CoreKvResponseMetadata |
|
| CoreKvResult |
|
| CoreLimiter |
|
| CoreLookupInMacro |
Convenience macros to retrieve document metadata using a lookupIn Sub-Document call.
|
| CoreMatchAllQuery |
|
| CoreMatchNoneQuery |
|
| CoreMatchOperator |
|
| CoreMatchPhraseQuery |
|
| CoreMatchQuery |
|
| CoreMergedTransactionConfig |
|
| CoreMutationResult |
|
| CoreMutationState |
|
| CoreNumericRange |
|
| CoreNumericRangeFacet |
|
| CoreNumericRangeQuery |
|
| CoreNumericRangeSearchFacetResult |
|
| CorePhraseQuery |
|
| CorePrefixQuery |
|
| CoreProtostellar |
|
| CoreProtostellarAccessors |
Used to generically handle the core functionality of sending a GRPC request over Protostellar and handling the response.
|
| CoreProtostellarCollectionManagerRequests |
For creating Protostellar GRPC requests.
|
| CoreProtostellarCollectionManagerResponses |
For converting Protostellar GRPC responses.
|
| CoreProtostellarErrorHandlingUtil |
|
| CoreProtostellarKeyValueRequests |
For creating Protostellar GRPC KV requests.
|
| CoreProtostellarKeyValueResponses |
For converting Protostellar GRPC KV responses.
|
| CoreProtoStellarKvBinaryRequests |
|
| CoreProtostellarKvBinaryResponses |
For converting Protostellar GRPC KV responses.
|
| CoreProtostellarUtil |
|
| CoreQueryContext |
|
| CoreQueryIndex |
Contains the properties of a Query Index.
|
| CoreQueryIndexManager |
|
| CoreQueryMetaData |
|
| CoreQueryMetrics |
Query Metrics contains the query result metrics containing counts and timings
|
| CoreQueryOps |
|
| CoreQueryOptions |
|
| CoreQueryOptionsTransactions |
Transactions does some rather complex things with CoreQueryOptions.
|
| CoreQueryOptionsTransactions.ParameterPassthrough |
|
| CoreQueryOptionsTransactions.QueryOptionsParameter |
|
| CoreQueryProfile |
Query profiling information received from the server query engine.
|
| CoreQueryResult |
The result of a N1QL query, including rows and associated metadata.
|
| CoreQueryScanConsistency |
The possible values for scan consistency in a N1QL request.
|
| CoreQueryStatus |
|
| CoreQueryStringQuery |
|
| CoreQueryType |
|
| CoreQueryWarning |
Represents a single warning returned from the query engine.
|
| CoreRangeScan |
|
| CoreRangeScanId |
Encapsulates an ID returned by the server for each stream.
|
| CoreRangeScanItem |
Represents one individual document returned from a kv range scan stream.
|
| CoreReactiveQueryResult |
|
| CoreReactiveSearchResult |
|
| CoreRegexpQuery |
|
| CoreSamplingScan |
Performs a KV range scan using random sampling.
|
| CoreScanOptions |
Allows to customize the various range and sampling scan options.
|
| CoreScanTerm |
A single CoreScanTerm identifying either the point to scan from or to scan to.
|
| CoreScanType |
Either RangeScan or SampleScan
|
| CoreScopeAndCollection |
|
| CoreSearchDateRange |
|
| CoreSearchFacet |
|
| CoreSearchFacetResult |
|
| CoreSearchFieldMissing |
|
| CoreSearchFieldMode |
|
| CoreSearchFieldType |
|
| CoreSearchGeoDistanceUnits |
|
| CoreSearchIndex |
|
| CoreSearchIndexManager |
The same interface is used for ScopeSearchIndexManager and SearchIndexManager, as there is
no API difference between them at this level.
|
| CoreSearchMetaData |
|
| CoreSearchMetrics |
|
| CoreSearchNumericRange |
|
| CoreSearchOps |
|
| CoreSearchOptions |
|
| CoreSearchQuery |
|
| CoreSearchResult |
|
| CoreSearchRow |
|
| CoreSearchRowLocation |
|
| CoreSearchRowLocations |
|
| CoreSearchScanConsistency |
|
| CoreSearchSort |
|
| CoreSearchSortField |
|
| CoreSearchSortGeoDistance |
|
| CoreSearchSortId |
|
| CoreSearchSortScore |
|
| CoreSearchStatus |
|
| CoreSearchTermRange |
|
| CoreSingleQueryTransactionOptions |
|
| CoreStoreSemantics |
|
| CoreSubdocGetCommand |
|
| CoreSubdocGetResult |
|
| CoreSubdocMutateCommand |
|
| CoreSubdocMutateResult |
|
| CoreTermFacet |
|
| CoreTermQuery |
|
| CoreTermRangeQuery |
|
| CoreTermSearchFacetResult |
|
| CoreTransactionAttemptContext |
Provides methods to allow an application's transaction logic to read, mutate, insert and delete documents, as well
as commit or rollback the transaction.
|
| CoreTransactionAttemptContextHooks |
Can be used for testing transactions, but is for internal use only.
|
| CoreTransactionCommitAmbiguousException |
The transaction expired at the point of trying to commit it.
|
| CoreTransactionContext |
Stores some context related to a transaction.
|
| CoreTransactionExpiredException |
The transaction could not be fully completed in the configured timeout.
|
| CoreTransactionFailedException |
The transaction failed to reach the Committed point.
|
| CoreTransactionGetResult |
Represents a value fetched from Couchbase, along with additional transactional metadata.
|
| CoreTransactionKeyspace |
A keyspace represents a triple of bucket, scope and collection.
|
| CoreTransactionLogger |
A logger optimized for logging transactions-specific info.
|
| CoreTransactionOptions |
Tunables for an individual transaction.
|
| CoreTransactionRequest |
This doesn't correspond to an individual server request.
|
| CoreTransactionResponse |
|
| CoreTransactionResult |
|
| CoreTransactionsCleanup |
Owns cleanup threads.
|
| CoreTransactionsCleanupConfig |
|
| CoreTransactionsConfig |
|
| CoreTransactionsContext |
Holds transactions state that has the same lifetime as a Core.
|
| CoreTransactionsCounters |
|
| CoreTransactionsReactive |
|
| CoreTransactionsSchedulers |
Mainly to aid debugging, transactions use their own pool of schedulers.
|
| CoreViewIndexManager |
|
| CoreWatchQueryIndexesOptions |
Allows customizing how the query indexes are watched.
|
| CoreWildcardQuery |
|
| CouchbaseBlockHoundIntegration |
Integrates the Couchbase infrastructure with BlockHound.
|
| CouchbaseBucketConfig |
|
| CouchbaseException |
The parent class for all exceptions created by this SDK (or clients using it).
|
| CouchbaseForkPoolThreadFactory |
|
| CouchbaseSaslClientFactory |
This SaslClientFactory supports all couchbase supported SASL authentication
mechanisms.
|
| CouchbaseThreadFactory |
|
| Counter |
Represents a generic Counter interface for metrics.
|
| CryptoManager |
Provides low-level encryption routines for implementing Field-Level Encryption as specified by
Couchbase RFC-0032.
|
| CustomTlsCiphersEnabledEvent |
This event is emitted if the user has configured a custom list of tls ciphers.
|
| DatasetExistsException |
|
| DatasetNotFoundException |
The queried dataset is not found on the server.
|
| DataverseExistsException |
|
| DataverseNotFoundException |
|
| Deadline |
|
| DebugUtil |
|
| DecodingFailureException |
Raised when provided content could not be successfully decoded.
|
| DecrementRequest |
|
| DecrementResponse |
|
| DefaultConfigurationProvider |
|
| DefaultConfigurationProvider.AlternateAddressHolder |
This class is needed since both port info and node info need to be abstracted for alternate address resolving.
|
| DefaultContext<T> |
|
| DefaultErrorUtil |
|
| DefaultEventBus |
|
| DefaultEventBus.Builder |
|
| DefaultLoggerFormatter |
|
| DefaultRepeat<T> |
|
| DefaultRetry<T> |
|
| DeltaInvalidException |
Subdocument exception thrown when the delta in an arithmetic operation (eg counter) is invalid.
|
| DesignDocumentNotFoundException |
|
| DiagnosticsResult |
This report provides insight into the current cluster state from the point of view of the client.
|
| DmlFailureException |
This exception is raised when the server fails to execute a DML query.
|
| DnsSrv |
The default implementation for performing DNS SRV lookups.
|
| DnsSrvLookupDisabledEvent |
Raised if dns srv lookup was not performed, either because it has been disabled on the environment or because
the hostname list passed in did not qualify.
|
| DnsSrvLookupFailedEvent |
The client attempted a DNS SRV lookup but it failed.
|
| DnsSrvLookupFailedEvent.Reason |
|
| DnsSrvRecordsLoadedEvent |
Raised when the SDK could properly load hostnames from a DNS SRV record.
|
| DnsSrvRefreshAttemptCompletedEvent |
This event is raised if a DNS SRV refresh attempt completed successfully.
|
| DnsSrvRefreshAttemptFailedEvent |
This event is raised in case a DNS SRV refresh attempt failed (see description for more details).
|
| DnsSrvRefreshAttemptFailedEvent.Reason |
|
| DocRecord |
|
| DocumentAlreadyAliveException |
Sub-Document exception thrown when ReviveDocument has been used with a document that already exists
|
| DocumentAlreadyInTransactionException |
|
| DocumentExistsException |
Indicates an operation failed because the key already exists.
|
| DocumentGetter |
Responsible for doing transaction-aware get()s.
|
| DocumentLockedException |
Thrown when the server reports a temporary failure that
is very likely to be lock-related (like an already locked
key or a bad cas used for unlock).
|
| DocumentMetadata |
Stores some $document metadata from when the document is fetched
|
| DocumentMutationLostException |
|
| DocumentNotFoundException |
Indicates an operation failed because the key does not exist.
|
| DocumentNotJsonException |
Subdocument exception thrown when the targeted enclosing document itself is not JSON.
|
| DocumentTooDeepException |
Subdocument exception thrown when document is too deep to parse.
|
| DocumentUnretrievableException |
Indicates an operation completed but no successful document was retrievable.
|
| 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 |
Specifies enhanced durability options for the mutation.
|
| DurabilityLevelNotAvailableException |
This exception is raised when a durability level has been requested that is not available on the server.
|
| DurabilityLevelUtil |
|
| DurabilityTimeoutCoercedEvent |
This event is raised if a durability timeout has been provided out of the allowed range and is coerced into a
sane and supported value.
|
| DurableWriteInProgressException |
Returned if an attempt is made to mutate a key which already has a durable write pending.
|
| DurableWriteReCommitInProgressException |
The requested key has a SyncWrite which is being re-committed.
|
| Encodable<T> |
|
| EncodingFailureException |
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 |
|
| EndpointDiagnostics |
A diagnostic report for an individual endpoint.
|
| 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.
|
| EndpointPingReport |
|
| EndpointSelectionStrategy |
|
| EndpointState |
Represents all states an Endpoint can be in.
|
| EndpointStateChangedEvent |
This event is raised when an endpoint changes its underlying state.
|
| EndpointWriteFailedEvent |
This event is raised if the actual IO write and flush (into netty) failed.
|
| EnhancedPreparedStatementStrategy |
Server remembers query plan; client sends just the prepared statement name.
|
| EnumLookupTable<E extends Enum<E>> |
Provides efficient lookup for enums whose values are associated with small integers.
|
| ErrorClass |
|
| ErrorCodeAndMessage |
A numeric error code and associated human-readable error message.
|
| ErrorContext |
The ErrorContext is the parent interface for all service-specific error contexts that are thrown as part of
the CouchbaseException.
|
| 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.
|
| EventingEndpoint |
|
| EventingEndpoint.EventingPipelineInitializer |
|
| EventingErrorContext |
|
| EventingFunctionCompilationFailureException |
Raised if the eventing function failed to compile on the server.
|
| EventingFunctionDeployedException |
Raised if the eventing function is currently deployed.
|
| EventingFunctionIdenticalKeyspaceException |
Raised if the source and metadata keyspace are the same.
|
| EventingFunctionNotBootstrappedException |
Raised if the eventing function is not bootstrapped at the time of request.
|
| EventingFunctionNotDeployedException |
Raised if the eventing function is not deployed.
|
| EventingFunctionNotFoundException |
Raised if the eventing function is not found.
|
| EventingService |
|
| EventSubscription |
Subscription for a consumer on a EventBus that can be used
to unsubscribe once done.
|
| Extension |
All protocol extensions known about by this implementation.
|
| ExternalSupplier<T> |
This supplier signals the entity passed in is not owned.
|
| FailFastRetryStrategy |
An internal strategy to fail fast any request that goes through it.
|
| FeatureNegotiatingHandler |
The FeatureNegotiatingHandler is responsible for sending the KV "hello" command
and to handshake enabled features on both sides.
|
| FeatureNotAvailableException |
Exception which states that the feature is not available for the bucket.
|
| FeaturesNegotiatedEvent |
Captures the end of the KV feature negotiation.
|
| FeaturesNegotiationFailedEvent |
|
| ForwardCompatibility |
A mechanism to help ensure that older clients can be prevented from interacting with transactions created by future
clients that they do not know how to process.
|
| ForwardCompatibilityFailureException |
This transaction has been prevented from interacting with documents or metadata owned by another transaction,
due to compatibility issues.
|
| ForwardCompatibilityRequiresRetryException |
|
| ForwardCompatibilityStage |
Points in the protocol where forward compatibility can be checked.
|
| GenericErrorContext |
|
| GenericFailureDetectedEvent |
|
| GenericHttpRequestErrorContext |
|
| GenericManagerRequest |
Deprecated.
|
| GenericManagerResponse |
|
| GenericRequestErrorContext |
This generic error context can be constructed from any request and will pull out as much information
as possible.
|
| GetAndLockRequest |
Represents a KV GetAndTouch operation.
|
| GetAndLockResponse |
|
| GetAndTouchRequest |
Represents a KV GetAndTouch operation.
|
| GetAndTouchResponse |
|
| GetCollectionIdRequest |
|
| GetCollectionIdResponse |
|
| GetCollectionManifestRequest |
|
| GetCollectionManifestResponse |
|
| GetMetaRequest |
Represents a kv get meta operation.
|
| GetMetaResponse |
|
| GetRequest |
Represents a KV Get (full document) operation.
|
| GetResponse |
|
| GlobalConfig |
The GlobalConfig represents a configuration which is not tied to a bucket.
|
| GlobalConfigNotFoundException |
Exception thrown if global configs are supported but the server tells the client that there is currently
non available.
|
| GlobalConfigParser |
|
| GlobalConfigRetriedEvent |
This event is raised if fetching the global config failed and can be retried.
|
| GlobalConfigUpdatedEvent |
|
| GlobalLoader |
The GlobalLoader is different to the bucket-based loaders in that it tries to fetch a cluster global
configuration which is not bound to a specific bucket.
|
| GlobalRefresher |
|
| Golang |
Helper methods that have to do with certain golang-specific format the server uses.
|
| GroupNotFoundException |
|
| HandlerUtils |
Various netty IO handler utilities.
|
| HealthPinger |
The HealthPinger allows to "ping" individual services with real operations for their health.
|
| HighIdleHttpConnectionTimeoutConfiguredEvent |
This event is raised if the user configures a idleHttpConnectionTimeout over 4.5 seconds, which will have some
negative side effects on most services.
|
| HostAndPort |
A host (hostname or IP address) and a port number.
|
| HttpChannelContext |
|
| 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>> |
|
| HttpStatusCodeException |
|
| IdleEndpointRemovedEvent |
|
| IdleStreamingEndpointClosedEvent |
Raised when a http config streaming connection is closed because of the configured configIdleRedialTimeout.
|
| IllegalDocumentStateEvent |
Indicates that a document has been modified by a non-transactional write while it is in a transaction.
|
| IncrementRequest |
|
| IncrementResponse |
|
| IndexesNotReadyException |
|
| IndexExistsException |
|
| IndexFailureException |
Indicates an operation failed because there has been an issue with the query planner or similar.
|
| IndexNotFoundException |
|
| IndividualGlobalConfigLoadFailedEvent |
Raised if an individual global config load event failed but it is not raised as a warning because progress
has been made from another host so it can be ignored (but is still relevant for debugging purposes).
|
| IndividualGlobalConfigRefreshFailedEvent |
Raised if an individual global config refresh event failed, but it is not raised as a warning since we expect
the next attempt(s) to complete.
|
| 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.
|
| InitGlobalConfigFailedEvent |
Raised when a global config could not be loaded.
|
| InitGlobalConfigFailedEvent.Reason |
The reasons why the global config init failed.
|
| InsecureSecurityConfigDetectedEvent |
This event is raised if the SDK sees a potentially insecurely configured security config.
|
| InsertRequest |
Uses the KV "add" command to insert documents if they do not already exist.
|
| InsertResponse |
|
| InternalEndpointDiagnostics |
|
| InternalServerFailureException |
Indicates an operation failed because there has been an internal error in the server.
|
| InvalidArgumentException |
|
| InvalidPacketDetectedEvent |
This event is created if somewhere in the IO layer an invalid packet
was detected.
|
| InvalidPropertyException |
Thrown when an environment config property cannot be applied.
|
| 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.
|
| JobQueueFullException |
Indicates the analytics server job queue is full
|
| JsonPathParser |
Parses a JSON projections string into a Seq of `PathElement`s.
|
| JsonStreamParser |
|
| JsonStreamParser.Builder |
|
| KetamaRing<E> |
|
| KeyValueBaseResponse |
The parent class for all KV responses passing through the SDK that potentially contain flexible extras.
|
| KeyValueBucketLoader |
This loader is responsible for initially loading a configuration through the kv protocol.
|
| KeyValueBucketRefresher |
|
| KeyValueChannelContext |
Holds context to encode KV operations based on what got negotiated in the channel.
|
| KeyValueEndpoint |
|
| KeyValueEndpoint.KeyValuePipelineInitializer |
|
| KeyValueErrorContext |
|
| KeyValueErrorMapCodeHandledEvent |
Raised if an unknown error is decoded and handled through the KV error map.
|
| KeyValueIoErrorContext |
|
| 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.
|
| KeyValueRequest<R extends Response> |
Main parent interface for all Key/Value requests.
|
| KeyValueService |
|
| KeyValueServiceConfig |
|
| KeyValueServiceConfig.Builder |
|
| KvPingRequest |
|
| KvPingResponse |
|
| LastCoreRangeScanItem |
|
| LatencyMetricsAggregatedEvent |
This event is emitted every configured aggregating meter interval.
|
| LegacyPreparedStatementStrategy |
Client remembers query plan and sends it on every request.
|
| LinkExistsException |
|
| LinkNotFoundException |
|
| Locator |
|
| LockTokens |
|
| LogDeferDocId |
|
| LogDeferThrowable |
|
| LogEvent |
|
| LoggerConfig |
The LoggerConfig allows to customize various aspects of the SDKs logging behavior.
|
| LoggerConfig.Builder |
|
| LoggerConfig.Defaults |
|
| LoggerFormatter |
Interface allowing to customize the output format of the logger (right now only used for console logging).
|
| LoggingEventConsumer |
Consumes Events and logs them per configuration.
|
| LoggingEventConsumer.Logger |
Generic logger interface.
|
| LoggingMeter |
The default metrics implementation which aggregates latency information and emits it at a regular interval.
|
| LoggingMeterConfig |
|
| LoggingMeterConfig.Builder |
|
| LoggingMeterConfig.Defaults |
|
| LogRedaction |
Static utility methods for global log redaction settings.
|
| LostCleanupDistributed |
Runs the algorithm to find 'lost' transactions, distributing the work between clients.
|
| LRUCache<K,V> |
Implements a generic LRU cache which evicts after the max size is reached.
|
| ManagerEndpoint |
|
| ManagerEndpoint.ManagerPipelineInitializer |
|
| ManagerErrorContext |
|
| ManagerHandlerSwitcher |
|
| ManagerMessageHandler |
This handler dispatches requests and responses against the cluster manager service.
|
| ManagerRequest<R extends Response> |
Parent interface for all requests going to the cluster manager.
|
| 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.FlexibleExtras |
|
| 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.
|
| Meter |
The generic interface for all metric implementations in the client.
|
| MeterException |
Generic exception that captures all meter-related errors.
|
| MeteringUnits |
Tracks read and write units used.
|
| MeteringUnits.MeteringUnitsBuilder |
|
| MonoBridge<T> |
Protects against concurrent op cancellation.
|
| MultiAddressNameResolverFactory |
|
| MultiObserveViaCasRequest |
Special observe request implementation to handle more than one key at the same time.
|
| MultiObserveViaCasResponse |
|
| MutationToken |
Value object to contain partition details and sequence number.
|
| MutationTokenAggregator |
Helper class that language-specific clients may use to implement MutationState.
|
| MutationTokenOutdatedException |
|
| NameAndTags |
Helper class which consolidates names and tags for caching purposes.
|
| NanoTimestamp |
|
| NetworkAddress |
A convenient wrapper class around network primitives in Java.
|
| NetworkResolution |
Configuration options for the network resolution setting.
|
| Node |
|
| NodeConnectedEvent |
Deprecated.
|
| NodeContext |
|
| NodeCreatedEvent |
Sent when a node is created, prior to connecting to services on the node.
|
| 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.
|
| NodeStateChangedEvent |
|
| NonChunkedEventingMessageHandler |
|
| NonChunkedHttpMessageHandler |
|
| NonChunkedHttpRequest<R extends Response> |
|
| NoopCircuitBreaker |
A simple noop implementation of the CircuitBreaker if disabled by the user.
|
| NoopCounter |
|
| NoopMeter |
|
| NoopRequest |
Represents a NOOP KV Request, doing nothing.
|
| NoopRequestSpan |
|
| NoopRequestTracer |
A simple NOOP implementation of the tracer, useful if tracing needs to be disabled completely.
|
| NoopResponse |
|
| NoopValueRecorder |
|
| NotMyVbucketReceivedEvent |
This event is raised if a KV response with "not my vbucket" is received.
|
| 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.
|
| OperationTypes |
|
| OptionsUtil |
|
| OrphanRecordDroppedEvent |
The client had to drop the orphan record because there queue is already full with processing other orphaned
events.
|
| OrphanReporter |
|
| OrphanReporterConfig |
|
| OrphanReporterConfig.Builder |
|
| OrphanReporterConfig.Defaults |
|
| OrphanReporterFailureDetectedEvent |
Raised when an exception happens during orphan reporting.
|
| OrphansRecordedEvent |
Emits orphaned requests which can be used to analyze slow requests.
|
| OverThresholdRequestsRecordedEvent |
Emits the over threshold requests which can be used to analyze slow requests.
|
| OwnedSupplier<T> |
A special supplier which allows the SDK to distinguish passed in suppliers vs.
|
| ParsingFailureException |
Indicates an operation failed because parsing of the input returned with an error.
|
| Partition |
|
| PartitionInfo |
Represents the partition information for a bucket.
|
| PartitionSelectionStrategy |
|
| PasswordAuthenticator |
Performs authentication against a couchbase server cluster using username and password.
|
| PasswordAuthenticator.Builder |
|
| PathArray |
|
| PathElement |
|
| 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.
|
| PathObjectOrField |
|
| PathTooDeepException |
Subdocument exception thrown when path is too deep to parse.
|
| PingResult |
|
| PingState |
|
| PipelineErrorHandler |
|
| PipelineInitializer |
Interface which provides a common API to initialize endpoint-specific pipelines.
|
| PlanningFailureException |
Indicates an operation failed because there has been an issue with the query planner.
|
| PortInfo |
|
| PredeterminedPartitionRequest<R extends Response> |
Parent class for requests which have their partition already set at creation time.
|
| PreparedStatement |
Prepared statement cache entry.
|
| PreparedStatementFailureException |
Indicates an operation failed because there has been an issue with query prepared statements.
|
| PreparedStatementRetriedEvent |
|
| PreparedStatementStrategy |
|
| PrependRequest |
|
| PrependResponse |
|
| PreviousOperationFailedException |
A previous operation in the application's lambda failed, and so the currently-attempt operation is also not
permitted to proceed.
|
| ProjectionsApplier |
Helper functions to aid with parsing get-with-projections calls.
|
| 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.
|
| ProposedGlobalConfigContext |
This context keeps together a bunch of related information needed to turn a raw
config into a parsed one.
|
| ProtostellarBaseRequest |
Where the public API requires a Request, create one dynamically.
|
| ProtostellarCollectionManagerRequest<TGrpcRequest> |
|
| ProtostellarContext |
|
| ProtostellarCoreCollectionManagerOps |
|
| ProtostellarCoreKvBinaryOps |
|
| ProtostellarCoreKvOps |
|
| ProtostellarCoreQueryMetaData |
|
| ProtostellarCoreQueryMetrics |
|
| ProtostellarCoreQueryOps |
|
| ProtostellarCoreQueryResult |
|
| ProtostellarCoreReactiveQueryResult |
|
| ProtostellarCoreSearchOps |
|
| ProtostellarEndpoint |
Wraps a GRPC ManagedChannel.
|
| ProtostellarKeyValueRequest<TGrpcRequest> |
|
| ProtostellarPool |
Maintains a pool of ProtostellarEndpoints.
|
| ProtostellarRequest<TGrpcRequest> |
Holds onto a GRPC request, along with pertaining mutable and immutable state bound to the request's lifetime.
|
| ProtostellarRequestBehaviour |
Determines what to do with a request.
|
| ProtostellarStatsCollector |
|
| ProtostellarUtil |
|
| QueryChunkHeader |
|
| QueryChunkResponseParser |
|
| QueryChunkRow |
|
| QueryChunkTrailer |
|
| QueryEndpoint |
|
| QueryEndpoint.QueryPipelineInitializer |
|
| QueryErrorContext |
|
| QueryException |
There was a problem fulfilling the query request.
|
| QueryHandlerSwitcher |
|
| QueryMessageHandler |
|
| QueryRequest |
|
| QueryResponse |
|
| QueryService |
|
| QueryServiceConfig |
|
| QueryServiceConfig.Builder |
|
| QueryUtil |
|
| QuotaLimitedException |
This error is raised if the operation failed due to hitting a quota-limit on the server side.
|
| RangeScanCanceledException |
|
| RangeScanCancelRequest |
|
| RangeScanCancelResponse |
|
| RangeScanContext |
|
| RangeScanContinueRequest |
|
| RangeScanContinueResponse |
|
| RangeScanCreateRequest |
|
| RangeScanCreateResponse |
|
| RangeScanIdFailureException |
|
| RangeScanOrchestrator |
Main entry point from higher level languages to perform KV range scans.
|
| RangeScanPartitionFailedException |
This is an internal exception used to signal exceptional states in the range scan orchestrator.
|
| RateLimitedException |
This error is raised if the operation failed due to hitting a rate-limit on the server side.
|
| ReactiveLock |
A mutex pessimistic lock, compatible with reactive.
|
| ReactiveLock.Waiter |
|
| ReactiveWaitGroup |
Provides locking functionality in line with Go's WaitGroups, in a reactive compatible way.
|
| ReactiveWaitGroup.Waiter |
|
| 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.
|
| ReducedAnalyticsErrorContext |
|
| ReducedKeyValueErrorContext |
|
| ReducedQueryErrorContext |
|
| ReducedSearchErrorContext |
|
| ReducedViewErrorContext |
|
| RemoveRequest |
Represents a KV delete operation.
|
| RemoveResponse |
|
| Repeat<T> |
|
| RepeatContext<T> |
|
| ReplaceRequest |
Uses the KV replace command to replace a document if it exists.
|
| ReplaceResponse |
|
| ReplicaGetRequest |
|
| ReplicaHelper |
|
| ReplicaHelper.GetReplicaResponse |
Deprecated.
|
| ReplicaNotAvailableException |
|
| ReplicaNotConfiguredException |
|
| Request<R extends Response> |
Represents a Request flowing through the client.
|
| RequestCallback |
Marker interface for different callbacks in the request lifecycle.
|
| RequestCanceledException |
|
| RequestContext |
Additional context which might be attached to an individual Request.
|
| RequestNotRetriedEvent |
This event is raised if a request is not retried anymore.
|
| RequestRetryScheduledEvent |
|
| RequestSpan |
Wrapper interface for all spans flowing through the SDK.
|
| RequestSpan.StatusCode |
Provides an abstraction over underlying tracing status codes.
|
| RequestTarget |
|
| RequestTracer |
|
| 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.
|
| ResponseStatusDetails |
Container for extended response status information.
|
| Retry<T> |
Retry function that may be used with retryWhen in Flux and Mono.
|
| RetryAction |
The RetryAction describes how and when a request should be retried.
|
| RetryAtrCommitException |
Indicates that committing the ATR entry should be retried.
|
| RetryContext<T> |
|
| RetryExhaustedException |
|
| RetryOperationException |
Indicates that this operation should be retried.
|
| RetryOrchestrator |
The RetryOrchestrator is responsible for checking if a request is eligible for retry
and if so dispatch it properly and update state.
|
| RetryOrchestratorProtostellar |
|
| RetryReason |
Provides more insight into why an operation has been retried.
|
| RetryStrategy |
|
| RetryTransactionException |
Indicates that this transaction should be retried.
|
| RollbackNotPermittedException |
The transaction is not allowed to rollback in the current state.
|
| 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.
|
| SaslAuthenticationRestartedEvent |
This event is raised if we need to re-do the SASL auth for a connection because the mechanisms did not match up
with the best-effort first try.
|
| SaslHelper |
|
| SaslListMechanismsHandler |
|
| SaslMechanism |
Describes the support SASL authentication mechanisms.
|
| SaslMechanismsListedEvent |
This debug event signals that SASL auth mechanisms have been listed from the server.
|
| SaslMechanismsListingFailedEvent |
|
| SaslMechanismsSelectedEvent |
This debug event signals that a SASL auth mechanism has been negotiated
between the client and the server.
|
| SchedulerClock |
|
| ScopedRequest |
Deprecated.
|
| ScopeExistsException |
|
| ScopeNotFoundException |
|
| ScramSaslClientFactory |
|
| Sdk2CompatibleMemcachedHashingStrategy |
This Memcached Hashing Strategy is compatible with the SDK 2 "DefaultMemcachedHashingStrategy".
|
| SearchChunkHeader |
|
| SearchChunkResponseParser |
|
| SearchChunkRow |
|
| SearchChunkTrailer |
|
| SearchEndpoint |
|
| SearchEndpoint.SearchPipelineInitializer |
|
| SearchErrorContext |
|
| SearchHandlerSwitcher |
|
| SearchRequest |
|
| SearchResponse |
|
| SearchService |
|
| SearchServiceConfig |
|
| SearchServiceConfig.Builder |
|
| SecureConnectionFailedEvent |
|
| SecurityConfig |
The SecurityConfig allows to enable transport encryption between the client and the servers.
|
| SecurityConfig.Builder |
This builder allows to customize the default security configuration.
|
| SecurityConfig.Defaults |
|
| SecurityConfig.InternalMethods |
|
| SecurityException |
|
| SeedNode |
The SeedNode represents a combination of hostname/ip and port that is used during the SDK bootstrap.
|
| SeedNodeOutdatedException |
Used to signal that the seed node used for an operation is outdated and might need to be refreshed.
|
| SeedNodesUpdatedEvent |
This event is emitted when seed nodes are updated in the configuration provider.
|
| SeedNodesUpdateFailedEvent |
This event is raised if a seed nodes update cannot be pushed to downstream subscribers.
|
| SelectBucketCompletedEvent |
This event gets created as soon as a bucket has been selected during the
KV bootstrap process for each socket/node.
|
| 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.
|
| ServerOutOfMemoryException |
Thrown when Couchbase Server returns with an Out of Memory error.
|
| 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 |
|
| 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.
|
| ServiceStateChangedEvent |
This event is raised every time a Service changes its state.
|
| ServiceType |
Describes the types of services available in a couchbase cluster.
|
| ShutdownCompletedEvent |
Raised when a core is successfully shut down.
|
| ShutdownInitiatedEvent |
This event is raised when the core is beginning to shut down.
|
| SimpleEventBus |
This super simple event bus should be used in testing only to assert certain
events got pushed through.
|
| SimpleEventBusLogger |
Simple wrapper around logging to the Couchbase event bus.
|
| SinceCouchbase |
Specifies the earliest version of Couchbase Server that supports the annotated feature.
|
| SingleStateful<S> |
Represents a single stateful component.
|
| SpanWrapper |
Wraps a RequestSpan, with the value-add that it automatically records how long the operation took for
transaction logging.
|
| SpanWrapperUtil |
|
| 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.
|
| StagedMutation |
|
| StagedMutationType |
|
| StandardMemcachedHashingStrategy |
|
| Stateful<S> |
Common interface for stateful components.
|
| StreamWindow |
A sliding window over the contents of a byte stream.
|
| SubdocCommandType |
|
| SubdocGetRequest |
|
| SubdocGetRequest.Command |
|
| SubdocGetResponse |
|
| SubdocMutateRequest |
|
| SubdocMutateRequest.Command |
|
| SubdocMutateResponse |
|
| SubDocumentErrorContext |
|
| SubDocumentField |
|
| SubDocumentOpResponseStatus |
|
| Supported |
Defines what is support by this implementation (extensions and protocol version).
|
| SyncDurabilityRequest |
Marker interface to signal that the given request supports synchronous durability.
|
| SystemPropertyPropertyLoader |
|
| TargetedRequest |
Deprecated.
|
| TemporaryFailureException |
Thrown when the server reports a temporary failure.
|
| TestFailAmbiguousException |
Used only in testing: injects an error that will be handled as FAIL_AMBIGUOUS.
|
| TestFailHardException |
Used only in testing: injects an error that will be handled as FAIL_HARD.
|
| TestFailOtherException |
Used only in testing: injects an error that will be handled as FAIL_OTHER.
|
| TestFailTransientException |
Used only in testing: injects a FAIL_TRANSIENT error.
|
| TestTransactionAttemptContextFactory |
Can be used for testing transactions, but is for internal use only.
|
| ThreadStopRequestedException |
|
| ThresholdLoggingTracer |
The default tracing implementation, which tracks the top N slowest requests per service and dumps them at
configurable intervals.
|
| ThresholdLoggingTracer.Builder |
|
| ThresholdLoggingTracerConfig |
|
| ThresholdLoggingTracerConfig.Builder |
|
| ThresholdLoggingTracerConfig.Defaults |
|
| ThresholdRequestSpan |
|
| ThresholdRequestTracerConfig |
Deprecated. |
| ThresholdRequestTracerConfig.Builder |
Deprecated. |
| ThresholdRequestTracerConfig.Defaults |
|
| TimeoutConfig |
|
| TimeoutConfig.Builder |
|
| TimeoutException |
The TimeoutException signals that an operation timed out before it could be completed.
|
| 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 or for rescheduling needs.
|
| TlsRequiredButNotEnabledEvent |
|
| TooManyInstancesDetectedEvent |
This event is raised if too many instances of the SDK are created as configured.
|
| TooManyInstancesException |
Raised if more SDK instances are created than allowed in configuration.
|
| TouchRequest |
|
| TouchResponse |
|
| TracerException |
Generic exception that captures all tracer-related errors.
|
| TracingIdentifiers |
Holds static tracing identifiers throughout the SDK.
|
| TracingUtils |
Contains various utils to set attributes for tracing spans.
|
| TrafficCaptureHandler |
Similar to the netty LoggingHandler, but it dumps the traffic into the event bus for later
consumption instead of logging it right away.
|
| TransactionAlreadyAbortedException |
|
| TransactionAlreadyCommittedException |
|
| TransactionAttemptContextFactory |
|
| TransactionCleanupAttemptEvent |
Emitted when the lost transactions cleanup process discovered a lost transaction and attempted to clean it up.
|
| TransactionCleanupEndRunEvent |
Emitted periodically with a summary of cleanup data since the last event.
|
| TransactionCleanupStartRunEvent |
Emitted periodically with a summary of what will be done soon for cleanup.
|
| TransactionEvent |
All transaction events derive from this.
|
| TransactionFields |
|
| TransactionKVHandler |
Transactions does a lot of KV work from core-io.
|
| TransactionLinks |
Stores the transaction links stored on each document in a transaction
|
| TransactionLogEvent |
A transaction log message.
|
| TransactionMarker |
Used to indicate that we are inside a transaction, and placed in ThreadLocalStorage (or reactive context).
|
| TransactionMarkerOwner |
Used to manage ThreadLocalStorage (or reactive context) of TransactionMarker.
|
| TransactionOperationFailedException |
This operation (such as a replace, get or insert) either failed or ambiguously succeeded.
|
| TransactionOperationFailedException.Builder |
|
| TransactionOperationFailedException.FinalErrorToRaise |
|
| TransactionsCleaner |
Handles cleaning up expired/lost transactions.
|
| TransactionsStartedEvent |
An event that's fired when transactions are successfully initialised.
|
| TriFunction<T,U,V,R> |
|
| UnambiguousTimeoutException |
This is a special case of the timeout exception, signaling that the timeout happened with no ambiguous cause.
|
| UnexpectedEndpointConnectionFailedEvent |
During connecting to an endpoint, an exception/error was raised which was not expected.
|
| UnexpectedEndpointDisconnectedEvent |
This event is usually raised if the server closes the socket and the client didn't expect it.
|
| UnknownResponseReceivedEvent |
|
| UnknownResponseStatusReceivedEvent |
|
| UnknownSaslMechanismDetectedEvent |
This event is raised if the client detects an unknown SASL mechanism it cannot turn into an enum.
|
| UnlockRequest |
|
| UnlockResponse |
|
| UnmonitoredRequest |
Requests implementing this interface will not be reported in various places.
|
| 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 |
|
| UrlQueryStringBuilder |
|
| UsedBy |
Indicates the target element is not intended for public use,
but some other Couchbase project depends on it.
|
| UsedBy.Project |
|
| UserAgent |
Represents a user-agent for this client.
|
| UserNotFoundException |
|
| Validators |
Common validators used throughout the client.
|
| ValueInvalidException |
Subdocument exception thrown when the provided value cannot be inserted at the given path.
|
| ValueRecorder |
Represents a generic value recorder for the metrics interface.
|
| ValueTooDeepException |
Subdocument exception thrown when proposed value would make the document too deep to parse.
|
| ValueTooLargeException |
Thrown when the request is too big for some reason.
|
| ViewChunkHeader |
|
| ViewChunkResponseParser |
Parses the individual response http chunks for a view request.
|
| ViewChunkRow |
|
| ViewChunkTrailer |
|
| ViewEndpoint |
|
| ViewEndpoint.ViewPipelineInitializer |
|
| ViewError |
|
| ViewErrorContext |
|
| ViewHandlerSwitcher |
|
| ViewLocator |
The ViewLocator extends the round-robin locator with some custom checks.
|
| ViewNotFoundException |
|
| ViewRequest |
|
| ViewResponse |
|
| ViewService |
|
| ViewServiceConfig |
|
| ViewServiceConfig.Builder |
|
| ViewServiceException |
There was a problem fulfilling the view request.
|
| WaitUntilReadyCompletedEvent |
|
| WaitUntilReadyCompletedEvent.Reason |
|
| WaitUntilReadyContext |
|
| WaitUntilReadyHelper |
Helper class to perform the "wait until ready" logic.
|
| WaitUntilReadyHelper.WaitUntilReadyState |
Encapsulates the state of where a wait until ready flow is in.
|
| WanDevelopmentProfile |
The "wan-development" environment profile.
|
| WatchdogInvalidStateIdentifiedEvent |
Raised if the watchdog in the core identifies an invalid state (and then tries to fix it).
|
| WatchdogRunFailedEvent |
Raised when the watchdog itself runs into an error that is logged.
|
| WrappedTransactionOperationFailedException |
TransactionOperationFailedException is raised as an opaque signal that something went wrong with a transaction
operation.
|
| WriteTrafficCapturedEvent |
|
| XattrCannotModifyVirtualAttributeException |
Subdocument exception thrown when the virtual attribute cannot be modified.
|
| XattrInvalidFlagComboException |
Deprecated. |
| XattrInvalidKeyComboException |
Subdocument exception thrown when more than one xattr key has been requested.
|
| XattrInvalidOrderException |
Deprecated. |
| XattrNoAccessException |
Subdocument exception thrown when an extended attribute cannot be accessed.
|
| XattrUnknownMacroException |
Subdocument exception thrown when a macro has been requested which is not recognised by the server.
|
| XattrUnknownVirtualAttributeException |
Subdocument exception thrown when a virtual attribute has been requested which is not recognised by the server.
|