All Classes

Class Description
AbstractByteArrayFragmentTranscoder
An AbstractFragmentTranscoder that further implements decoding and encoding of messaging, easing the implementation of a concrete FragmentTranscoder based on byte arrays zero-copied from ByteBuf.
AbstractClusterApiClient<T extends RestBuilderMarker>
An utility class to execute generic HTTP calls on a cluster's REST API.
AbstractCompoundQuery
Base class for FTS queries that are composite, compounding several other AbstractFtsQuery.
AbstractDocument<T>
Common parent implementation of a Document.
AbstractFacetResult  
AbstractFragmentTranscoder
A common implementation base of the FragmentTranscoder interface for transcoding sub-document fragments.
AbstractFtsQuery
A base class for all FTS query classes.
AbstractN1qlQuery
An abstract base for N1QL N1qlQuery.
AbstractPath
.
AbstractTranscoder<D extends Document<T>,​T>
Base Transcoder which should be extended for compatibility.
AggregateFunctions
DSL for N1QL functions in the aggregate category.
Alias
.
AnalyticsDeferredResultHandle
An async handle to fetch the status and results of a deferred Analytics Query
AnalyticsIngester
This class allows to take results from an analytics result and turn it back into KV operations that will be inserted.
AnalyticsIngester.IngestMethod
Describes how the data should be ingested back into the kv service.
AnalyticsIngester.IngestOptions  
AnalyticsMetrics
Represents Analytics Metrics as part of the response.
AnalyticsParams
Parameters for Analytics Queries.
AnalyticsQuery
Base class for an analytics query.
AnalyticsQueryExecutor  
AnalyticsQueryResult
Represents the results of a AnalyticsQuery, in a blocking fashion.
AnalyticsQueryRow  
ArrayFunctions
DSL for N1QL functions in the Array category.
AsElement  
AsPath
.
AsyncAnalyticsDeferredResultHandle
An async handle to fetch the status and results of a deferred Analytics Query
AsyncAnalyticsQueryResult  
AsyncAnalyticsQueryRow  
AsyncBucket
Defines operations that can be executed asynchronously against a Couchbase Server bucket.
AsyncBucketManager
Provides management capabilities for a AsyncBucket.
AsyncCluster
Represents a Couchbase Server Cluster.
AsyncClusterApiClient
An utility class to execute generic HTTP calls asynchronously on a cluster's REST API.
AsyncClusterManager
Provides management capabilities for a Couchbase Server Cluster.
AsyncLookupInBuilder
A builder for subdocument lookups.
AsyncMutateInBuilder
A builder for subdocument mutations.
AsyncN1qlQueryResult
A representation of an N1QL query result.
AsyncN1qlQueryRow  
AsyncRawQueryExecutor
A utility class that allows to perform N1QL and FTS queries asynchronously and receive a raw version of the service's JSON response.
AsyncRepository
The async repository abstraction for entities on top of an AsyncBucket.
AsyncRestBuilder
A builder class to incrementally construct REST API requests and execute them asynchronously
AsyncSearchQueryResult
The asynchronous interface for FTS query results.
AsyncSpatialViewResult
Contains the result of a SpatialViewQuery.
AsyncSpatialViewRow
Represents a row fetched from the Spatial View.
AsyncViewResult
Represents the result from a ViewQuery.
AsyncViewRow
Represents a row fetched from the View.
AuthDomain
The possible authentication domains that can be used when managing users with RBAC.
AuthenticationException
Describes authentication issues, usually during bootstrap.
Authenticator
An Authenticator abstracts credential management for various couchbase operations (all of which fall into one CredentialContext).
AuthenticatorException
This exception is commonly raised when an attempt to retrieve a credential in an Authenticator is made, but cannot be fulfilled.
BadDeltaException
Subdocument exception thrown when the delta in an arithmetic operation (eg counter) is invalid.
BinaryDocument
Represents raw ByteBuf content in a document.
BinaryTranscoder  
Blocking Deprecated.
this class has been moved into core (Blocking
BooleanFieldQuery
A FTS query that queries fields explicitly indexed as boolean.
BooleanQuery
A compound FTS query that allows various combinations of sub-queries.
Bootstrap
Utility classes for bootstrapping.
Bucket
Defines operations that can be executed synchronously against a Couchbase Server bucket.
BucketAlreadyExistsException
Exception identifying that a bucket does already exist.
BucketConsumer
Consumes CouchbaseEvents and logs them into a bucket as JSON.
BucketConsumer.StoreType
How the event should be stored.
BucketDoesNotExistException
Exception identifying that a bucket does not exist.
BucketFlusher
Helper class to flush a bucket properly and wait for it to be completed.
BucketInfo
Provides information about a Bucket.
BucketManager
Provides management capabilities for a Bucket.
BucketSettings
BucketSettings represent changeable properties for a Bucket.
BucketType
The type of the bucket.
BuildIndexElement
Element for initial clause of a BUILD index statement.
BuildIndexPath
Starting path of the Index building DSL.
ByteArrayDocument
Handles a byte array as the document value.
ByteArrayTranscoder
A transcoder to encode and decode ByteArrayDocuments.
CannotInsertValueException
Subdocument exception thrown when the provided value cannot be inserted at the given path.
CannotRetryException
A CouchbaseException that denotes that a retry cycle failed because the maximum allowed attempt count was reached.
Case
DSL for creating CASE...END constructs.
Case.CaseClause  
Case.ThenClause  
Case.WhenClause  
CASMismatchException
Identifying a CAS mismatch on a replace operation..
CertAuthenticator
This Authenticator enables client certificate based authentication.
ClassicAuthenticator
An Authenticator based on login/password credentials.
Cluster
Represents a Couchbase Server Cluster.
ClusterApiClient
An utility class to execute generic HTTP calls synchronously on a cluster's REST API.
ClusterInfo
Provides information about a Cluster.
ClusterManager
Provides management capabilities for a Couchbase Server Cluster.
Collections
DSL for N1QL Collections (aka comprehensions, ANY, EVERY, ARRAY and FIRST...).
Collections.SatisfiesBuilder  
Collections.WhenBuilder  
ComparisonFunctions
DSL for N1QL functions in the Comparison category.
CompressionMode
The compression mode used for bucket settings.
ConditionalFunctions
DSL for N1QL Conditional functions (for unknowns and numbers).
ConjunctionQuery
A compound FTS query that performs a logical AND between all its sub-queries (conjunction).
ConnectionString Deprecated.
ConnectionString.Scheme  
Coordinate
The Coordinate represents the longitude and latitude of a point.
CouchbaseArrayList<E>
A CouchbaseArrayList is a List backed by a Couchbase document (more specifically a JSON array).
CouchbaseArraySet<T>
A CouchbaseArraySet is a Set backed by a Couchbase document (more specifically a JSON array).
CouchbaseAsyncBucket  
CouchbaseAsyncCluster
Main asynchronous entry point to a Couchbase Cluster.
CouchbaseAsyncRepository  
CouchbaseBucket  
CouchbaseCluster
Main synchronous entry point to a Couchbase Cluster.
CouchbaseEnvironment
The CouchbaseEnvironment which shares state across Clusters.
CouchbaseFeature
Enumeration of all Couchbase Features supported by this SDK.
CouchbaseMap<V>
A CouchbaseMap is a Map backed by a Couchbase document (more specifically a JSON object).
CouchbaseOutOfMemoryException
Thrown when Couchbase Server returns with an Out of Memory error.
CouchbaseQueue<E>
A CouchbaseQueue is a Queue backed by a Couchbase document (more specifically a JSON array).
CouchbaseRepository  
CreateIndexPath
Starting path of the Index creation DSL.
Credential
A simple class that internally represents an implicit credential for authenticated operations in the SDK.
CredentialContext
Enum of the contexts that can be used to retrieve an implicit credential from an Authenticator.
CryptoManager
Encryption configuration manager set on the couchbase environment for encryption/decryption
CryptoProvider
CryptoProvider interface for cryptographic algorithm provider implementations.
CryptoProviderAliasNullException
CryptoProviderAliasNullException is thrown when the supplied argument to the crypto manager fetch the crypto provider by name is null.
CryptoProviderDecryptFailedException
CryptoProviderDecryptFailedException is thrown when the encrypted field fetched from the server cannot be decrypted.
CryptoProviderEncryptFailedException
CryptoProviderEncryptFailedException is thrown when the field cannot be encrypted.
CryptoProviderKeySizeException
CryptoProviderKeySizeException is thrown when the supplied key's size does not match the Crypto provider's expected key size
CryptoProviderMissingPrivateKeyException
CryptoProviderMissingPrivateKeyException is thrown when the private key is not set on the Crypto provider.
CryptoProviderMissingPublicKeyException
CryptoProviderMissingPublicKeyException is thrown when the public key is not set on the Crypto provider.
CryptoProviderMissingSigningKeyException
CryptoProviderMissingSigningKeyException is thrown when the signing key is not set on the Crypto provider.
CryptoProviderNotFoundException
CryptoProviderNotFoundException is thrown when the provider is not registered on the Crypto manager.
CryptoProviderSigningFailedException
CryptoProviderSigningFailedException is thrown when the crypto provider is not able to sign/verify
DateFunctions
DSL for N1QL functions in the Date category.
DateFunctions.DatePart  
DateFunctions.DatePartExt  
DateRange
A range (or bucket) for a DateRangeFacetResult.
DateRangeFacet
A facet that categorizes hits inside date ranges (or buckets) provided by the user.
DateRangeFacetResult
Represents the result for a DateRangeFacet.
DateRangeQuery
A FTS query that matches documents on a range of dates.
DefaultAnalyticsDeferredResultHandle
Default implementation of AnalyticsDeferredResultHandle
DefaultAnalyticsQueryResult  
DefaultAnalyticsQueryRow  
DefaultAsPath
.
DefaultAsyncAnalyticsDeferredResultHandle
Default implementation of AsyncAnalyticsDeferredResultHandle
DefaultAsyncAnalyticsQueryResult  
DefaultAsyncAnalyticsQueryRow  
DefaultAsyncBucketManager
Default implementation of a AsyncBucketManager.
DefaultAsyncClusterManager  
DefaultAsyncN1qlQueryResult
The default implementation of an AsyncN1qlQueryResult.
DefaultAsyncN1qlQueryRow  
DefaultAsyncSearchQueryResult
The default implementation for an AsyncSearchQueryResult
DefaultAsyncSpatialViewResult
Default implementation of a AsyncSpatialViewResult.
DefaultAsyncSpatialViewRow
Default implementation of a AsyncSpatialViewRow.
DefaultAsyncViewResult  
DefaultAsyncViewRow
Default implementation of a AsyncViewRow.
DefaultBucketInfo
Default implementation of BucketInfo.
DefaultBucketManager  
DefaultBucketSettings  
DefaultBucketSettings.Builder  
DefaultBuildIndexPath
DefaultClusterInfo
Default implementation for a ClusterInfo.
DefaultClusterManager  
DefaultCouchbaseEnvironment
The default implementation of a CouchbaseEnvironment.
DefaultCouchbaseEnvironment.Builder  
DefaultCreateIndexPath
DefaultDateRangeFacetResult
Implementation of a DateRangeFacetResult.
DefaultDeleteUsePath  
DefaultDropPath
DefaultEntityConverter  
DefaultFromPath
.
DefaultGroupByPath
.
DefaultHavingPath
.
DefaultHintPath
DefaultHitLocations
A default implementation of a HitLocations.
DefaultIndexNamesPath
DefaultInitialInsertPath  
DefaultInitialUpdateUnsetPath  
DefaultInsertValuesPath  
DefaultJoinPath
.
DefaultKeysPath
.
DefaultLetPath
.
DefaultLettingPath
.
DefaultLimitPath  
DefaultMergeDeletePath  
DefaultMergeDeleteWherePath
.
DefaultMergeInsertPath  
DefaultMergeInsertWherePath  
DefaultMergeKeyClausePath
.
DefaultMergeSourcePath  
DefaultMergeUpdatePath
.
DefaultMergeUpdateSetOrUnsetPath  
DefaultMergeUpdateSetPath  
DefaultMergeUpdateUnsetPath  
DefaultMergeUpdateWherePath  
DefaultMutateLimitPath  
DefaultMutateWherePath  
DefaultN1qlQueryResult  
DefaultN1qlQueryRow  
DefaultNestPath
.
DefaultNumericRangeFacetResult
Implementation of a NumericRangeFacetResult.
DefaultOffsetPath
.
DefaultOnPath
See OnPath.
DefaultOnPrimaryPath
DefaultOrderByPath
.
DefaultReturningPath  
DefaultSearchMetrics
The default implementation for a SearchMetrics
DefaultSearchQueryResult
The default implementation for a SearchQueryResult
DefaultSearchQueryRow
The default implementation for a SearchQueryRow
DefaultSearchStatus
The default implementation for a SearchStatus
DefaultSelectPath
.
DefaultSelectResultPath
.
DefaultSpatialViewResult
Default implementation of the SpatialViewResult.
DefaultSpatialViewRow
Default implementation of the SpatialViewRow.
DefaultTermFacetResult
Implementation of a TermFacetResult.
DefaultUnnestPath
.
DefaultUpdateSetOrUnsetPath  
DefaultUpdateSetPath  
DefaultUpdateUnsetPath  
DefaultUpdateUsePath  
DefaultUsingPath
DefaultUsingWithPath
DefaultView
Implementation of a regular, non spatial view.
DefaultViewResult  
DefaultViewRow  
DefaultWherePath
.
DefaultWherePath
DefaultWithPath
Delete  
DeleteUsePath  
DesignDocument
Represents a design document to store and load.
DesignDocument.Option
Optional design document options.
DesignDocumentAlreadyExistsException  
DesignDocumentDoesNotExistException
Exception to indicate that Design document does not exist in the server
DesignDocumentException  
DigestUtils
Utility methods around hashes, message digests, etc...
DisjunctionQuery
A compound FTS query that performs a logical OR between all its sub-queries (disjunction).
DocIdQuery
A FTS query that matches on Couchbase document IDs.
Document<T>
Represents a Couchbase Server Document which is stored in and retrieved from a AsyncBucket.
DocumentAlreadyExistsException
Raised when the document already exists and an insert operation is used..
DocumentDoesNotExistException
Raised when the document does not exist and a replace operation is used..
DocumentFragment<OPERATION>
A fragment of a JSON Document, that is to say one or several JSON values from the document (including String, JsonObject, JsonArray, etc...), as returned and used in the sub-document API.
DocumentNotJsonException
Subdocument exception thrown when the targeted enclosing document itself is not JSON.
DocumentTooDeepException
Subdocument exception thrown when document is too deep to parse.
DropIndexElement
Element for the initial clause of a DROP index statement.
DropPath
Initial path of the Index dropping DSL.
DurabilityException
Raised if the durability requirement could not be met.
EjectionMethod
The ejection method used on the bucket.
Element
The Element interface describes keywords in the N1QL DSL.
EncryptedField
Annotation for encrypted field
EntityConverter<D extends Document<?>>  
EntityDocument<T>
The entity document is used to carry enclosed entities for the repository implementation.
EntityMetadata
Represents the metadata for a document entity.
ExceptElement  
Exists
Contains the logic to execute and handle exists requests.
Expression
Represents a N1QL Expression.
FacetResult
Base interface for all facet results.
Field  
FieldMissing  
FieldMode  
FieldType  
FlushDisabledException  
Form
A utility method / builder class to create form bodies for a RestBuilder or AsyncRestBuilder.
FragmentTranscoder
An interface for transcoding sub-document fragments (as read and written by the subdocument API, eg.
FromElement  
FromPath
.
FtsConsistencyTimeoutException
An exception denoting that the search engine couldn't satisfy an FTS request with consistency before the specified timeout.
FtsMalformedRequestException
An exception denoting that the search engine couldn't parse an FTS request.
FtsServerOverloadException
An exception denoting that the search engine couldn't parse an FTS request.
GeoBoundingBoxQuery
A FTS query which allows to match geo bounding boxes.
GeoDistanceQuery
A FTS query which allows to match on geo distances.
GeoPolygonQuery
A FTS query which allows to match on geo polygons.
Get
Contains the logic to execute and handle get requests.
Get.GetFilter  
Get.GetMap<D>  
GroupByElement  
GroupByPath
.
HashJoinHintElement
Hash Join hint for hash based join
HashSide
Hash side for hash based join
HavingElement  
HavingPath
.
HighlightStyle
Enumeration of the highlighting styles recognized by the FTS engine.
HintIndexElement
Element of the Index DSL to create various forms of indexes.
HintPath
Hint clause (especially for specifying indexes to use) after a from clause.
HitLocation
A FTS result hit location indicates at which position a given term occurs inside a given field.
HitLocations
Represents the locations of a search result hit.
Id
Identifies a field which will not be stored in the document but rather used as the document ID.
Index
DSL starting point for creating and managing N1QL indexes.
IndexAlreadyExistsException
An exception indicating that an index already exists, for instance when trying to create one using BucketManager.createN1qlIndex(String, List, Expression, boolean, boolean).
IndexDoesNotExistException
An exception indicating that an index does not exist, for instance when trying to delete one using BucketManager.dropN1qlIndex(String, boolean).
IndexElement
Element of the Index DSL to create various forms of indexes.
IndexesNotReadyException
An exception used to denote that a particular set of secondary N1QL indexes are not in a "online" state.
IndexInfo
Contains meta-information about a N1QL index.
IndexNamesElement
Element for listing index names when Building an Index.
IndexNamesPath
Path of the Index building DSL to specify which index(es) to build.
IndexReference
IndexReference wraps an index name and an index type (with the `USING GSI|VIEW` syntax).
IndexType
Enum of the different types of indexes supported by N1QL.
InitialInsertPath  
InitialUpdateUnsetPath  
Insert  
InsertSelectElement  
InsertValueElement  
InsertValueElement.InsertPosition  
InsertValuesPath  
IntersectElement  
InvalidPasswordException
This exception is commonly raised when the password for a resource does not match.
JacksonFragmentTranscoder
A Jackson-based implementation of a FragmentTranscoder, based on AbstractByteArrayFragmentTranscoder.
JacksonTransformers  
JoinElement  
JoinPath
.
JoinType
.
JsonArray
Represents a JSON array that can be stored and loaded from Couchbase Server.
JsonArrayDocument
Stores a properly encoded JSON array as the toplevel type.
JsonArrayDocumentIterator<E>
An Iterator that can iterate over a JsonArrayDocument identified by id in the given bucket.
JsonArrayTranscoder
A transcoder to encode and decode JsonDocuments.
JsonBooleanDocument  
JsonBooleanTranscoder
A transcoder to encode and decode JsonBooleanDocuments.
JsonCryptoTranscoder
A transcoder to encode and decode with encryption/decryption support for JsonDocuments.
JsonDocument
Represents a Document that contains a JsonObject as the content.
JsonDoubleDocument
Stores a properly encoded JSON scalar double or float as the toplevel type.
JsonDoubleTranscoder
A transcoder to encode and decode JsonDoubleDocuments.
JsonFunctions
DSL for N1QL functions in the JSON category.
JsonLongDocument
Stores a properly encoded JSON scalar long or int as the toplevel type.
JsonLongTranscoder
A transcoder to encode and decode JsonDoubleDocuments.
JsonNull
Represents the JSON form of "NULL".
JsonObject
Represents a JSON object that can be stored and loaded from Couchbase Server.
JsonStringDocument
Stores a properly encoded JSON scalar quoted string as the toplevel type.
JsonStringTranscoder
A transcoder to encode and decode JsonStringDocuments.
JsonTranscoder
A transcoder to encode and decode JsonDocuments.
JsonValue
Represents a JSON value (either a JsonObject or a JsonArray.
KeysElement  
KeysElement.ClauseType  
KeysPath
.
KeyStoreProvider
Key provider interface for key store implementation.
LegacyDocument
This document is fully compatible with Java SDK 1.* stored documents.
LegacyTranscoder
A Transcoder which mimics the behavior of the Java SDK 1.* series for compatibility.
LetElement  
LetPath  
LettingElement  
LettingPath
.
LimitElement  
LimitPath  
LookupInBuilder
A builder for subdocument lookups.
LookupSpec
Internally represents a single lookup operation in a batch of subdocument operations.
LRUCache<K,​V>
Implements a generic LRU cache which evicts after the max size is reached.
MatchAllQuery
A FTS query that matches all indexed documents (usually for debugging purposes).
MatchNoneQuery
A FTS query that matches 0 document (usually for debugging purposes).
MatchPhraseQuery
A FTS query that matches several given terms (a "phrase"), applying further processing like analyzers to them.
MatchQuery
A FTS query that matches a given term, applying further processing to it like analyzers, stemming and even fuzziness.
Merge  
MergeDeleteElement  
MergeDeletePath  
MergeDeleteWherePath  
MergeInsertElement  
MergeInsertPath  
MergeInsertWherePath  
MergeKeyClausePath  
MergeSourcePath  
MergeUpdatePath
.
MergeUpdateSetOrUnsetPath  
MergeUpdateSetPath  
MergeUpdateUnsetPath  
MergeUpdateWherePath  
MetaFunctions
DSL for N1QL functions in the misc/meta category.
MixedAuthenticationException
This exception is commonly raised when the PasswordAuthenticator containing RBAC user credentials and bucket credentials are used together
MultiMutationException
Exception denoting that at least one error occurred when applying multiple mutations using the sub-document API (a MutateInBuilder.execute() with at least two mutations).
MultiValue<T>
An internal representation of multiple values to insert in an array via the sub-document API.
Mutate
Contains the logic to execute and handle mutation requests.
MutateInBuilder
A builder for subdocument mutations.
MutateLimitPath  
MutateWherePath  
MutationOptionBuilder
MutationOptionBuilder allows to set following constraints on data structure mutation operations - cas - expiry - persistence - replication - create Document
MutationSpec
Internally represents a single mutation in a batch of subdocument mutations.
MutationState
Aggregation of one or more MutationToken into one MutationState.
N1qlMetrics
A class that represents N1QL metrics.
N1qlParams
Parameter Object for queries that allows to fluently set most of the N1QL query parameters: - server side timeout - client context ID - scan consistency (with associated scan vector and/or scan wait if relevant) - max parallelism Note that these are different from statement-related named parameters or positional parameters.
N1qlProfile
N1ql profile options
N1qlQuery
Contract to describe N1QL queries.
N1qlQueryExecutor
A class used to execute various N1QL queries.
N1qlQueryResult
Represents the results of a N1qlQuery, in a blocking fashion.
N1qlQueryRow  
NamedPreparedStatementException
An exception marking the fact that a Named Prepared Statement in N1QL couldn't be executed and that there was a fallback to re-preparing it.
NestedLoopJoinHintElement
Hint to use Nested loop join
NestElement  
NestPath
.
NodeLocatorHelper
Helper class to provide direct access on how document IDs are mapped onto nodes.
NumberFunctions
DSL for N1QL functions in the Numbers category.
NumberTooBigException
Subdocument exception thrown when existing number value in document is too big.
NumericRange
A range (or bucket) for a NumericRangeFacetResult.
NumericRangeFacet
A facet that categorizes hits into numerical ranges (or buckets) provided by the user.
NumericRangeFacetResult
Represents the result of a NumericRangeFacet.
NumericRangeQuery
A FTS query that matches documents on a range of values.
ObjectFunctions
DSL for N1QL functions in the Object category.
OffsetElement  
OffsetPath
.
OnElement
Element of the Index DSL that targets the keyspace on which to apply an index.
OnError
Set the behavior on error for a view query.
OnPath
On path in the Index creation DSL.
OnPrimaryPath
On path in the primary Index creation DSL.
OnSubscribeDeferAndWatch<T>
Defers the execution of a Subject and in addition watches for early unsubscription and cleans up buffers if the content is ReferenceCounted.
OrderByElement  
OrderByPath
.
ParameterizedAnalyticsQuery
This query type extends the simple one so that it properly serializes parameterized queries, both named and/or positional ones.
ParameterizedN1qlQuery
Represent a N1QL query with an optionally parameterized statement (in which case the values must be passed according to the type and number of placeholders).
PasswordAuthenticator
Authenticator for RBAC users in Couchbase
Path
.
PathExistsException
Subdocument exception thrown when a path already exists and it shouldn't (for example, when using MutateInBuilder.insert(String, Object, boolean) subdoc insert}).
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.
PatternMatchingFunctions
DSL for N1QL functions in the Pattern Matching category.
PersistTo
Defines the possible disk persistence constraints to observe.
PhraseQuery
A FTS query that matches several terms (a "phrase") as is.
PrefixQuery
A FTS query that allows for simple matching on a given prefix.
PreparedN1qlQuery
Represent a N1QL query, with a parameterized prepared statement plan (for which the values must be passed according to the type and number of placeholders).
PreparedPayload
The payload necessary to perform a PreparedN1qlQuery, as returned when issuing a PrepareStatement.
PrepareStatement
A PREPARE Statement that wraps another Statement in order to send it to the server and produce a PreparedPayload.
PropertyMetadata
Represents the metadata for a document property inside an EntityMetadata.
QueryExecutionException
A CouchbaseException representing various errors during N1QL querying, when an actual Exception wrapping a JsonObject is needed.
QueryStringQuery
A FTS query that performs a search according to the "query string" syntax.
RawJsonDocument
Represents a Document that contains a already encoded JSON document.
RawJsonTranscoder
A transcoder to encode and decode a RawJsonDocuments.
RawQueryExecutor
A utility class that allows to perform N1QL and FTS queries synchronously and receive a raw version of the service's JSON response.
ReflectionBasedEntityMetadata
Reflection based implementation for entity metadata.
ReflectionBasedPropertyMetadata
The property metadata implementation based on java reflection.
RegexpQuery
A FTS query that allows for simple matching of regular expressions.
ReplicaMode
Represents the different modes to read from replica nodes.
ReplicaReader
Helper class to deal with reading from zero to N replicas and returning results.
ReplicateTo
Defines the possible replication constraints to observe.
Repository
The repository abstraction for entities on top of a bucket.
RepositoryMappingException  
RequestTooBigException
Thrown when the request is too big for some reason.
RestBuilder
A builder class to incrementally construct REST API requests and execute them synchronously
RestBuilderMarker
Marker interface for RestBuilder and AsyncRestBuilder.
ResultMappingUtils
Helpers to map subdocument results for datastructures
Retry
Utility methods to deal with retrying Observables.
RetryBuilder
Builder for RetryWhenFunction.
RetryBuilder.InversePredicate  
RetryBuilder.OnRetryAction
An interface alias for Action4<Integer, Throwable, Long, TimeUnit>, suitable for RetryBuilder.doOnRetry(Action4).
RetryBuilder.ShouldStopOnError  
RetryWhenFunction
Combine a mapping of errors to their attempt number with a flatmap that induces a retry delay into a function that can be passed to an Observable's retryWhen operation.
RetryWithDelayHandler
A class that allows to produce a "retry" delay depending on the number of retry attempts.
ReturningElement  
ReturningElement.ReturningType  
ReturningPath  
ScanConsistency
The possible values for scan_consistency in a N1QL request.
SearchConsistency
An enum listing the various consistency levels for FTS searches that don't need additional parameters (like a mutation token vector).
SearchFacet
Base class for all FTS facets in querying.
SearchMetrics
Provides statistics on an FTS query result (number of hits, time taken...).
SearchQuery
The FTS API entry point.
SearchQueryExecutor
Contains the full execution logic for a search query.
SearchQueryResult
The main interface for FTS query results.
SearchQueryRow
An FTS result row (or hit).
SearchSort
Base class for all FTS sort options in querying.
SearchSortField
Sort by a field in the hits.
SearchSortGeoDistance
Sort by a location and unit in the hits.
SearchSortId
Sort by the document ID.
SearchSortScore
Sort by the hit score.
SearchStatus
Represents the status of a FTS query.
SearchUtils
Utility class around FTS (Full Text Search), and especially handling of the default FTS date format (which corresponds to RFC 3339).
Select
.
SelectElement  
SelectPath
.
SelectResultPath
.
SelectType
.
SerializableDocument
Handles content which implements Serializable.
SerializableStatement
A Statement that is also explicitly Serializable.
SerializableTranscoder
A transcoder to encode and decode SerializableDocuments.
SetElement  
SetElement.SetPosition  
SimpleAnalyticsQuery
The simplest form of Analytics AnalyticsQuery with a plain un-parameterized Statements.
SimpleN1qlQuery
The simplest form of N1QL N1qlQuery with a plain un-parameterized Statement.
Sort
.
Sort.Order  
SpatialView
Implementation of a spatial view.
SpatialViewQuery
Fluent DSL for a Spatial View Query.
SpatialViewResult
Represents the result from a ViewQuery.
SpatialViewRow
Represents a SpatialViewRow fetched from the View.
Stale
Sets the staleness requirement for the view query.
Statement  
StringDocument
Handles a raw string as the document value.
StringFunctions
DSL for N1QL functions in the Strings category.
StringTranscoder
A transcoder to encode and decode StringDocuments.
SubdocHelper
Helper class to the subdocument API.
SubdocOperationResult<OPERATION>
Internally represent result corresponding to a single LookupSpec or MutationSpec, as part of a DocumentFragment.
SubdocOptionsBuilder
Sub-document options builder.
SubDocumentException
An abstract common class for all CouchbaseException that relates to the sub-document feature.
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).
TermFacet
A facet that gives the number of occurrences of the most recurring terms in all hits.
TermFacetResult
Represents the result for a TermFacet.
TermQuery
A FTS query that matches terms (without further analysis).
TermRange
A range (or bucket) for a TermFacetResult.
TermRangeQuery
A FTS query that matches documents on a range of values.
Transcoder<D extends Document<T>,​T>  
TranscoderUtils
Helper methods and flags for the shipped Transcoders.
TranscoderUtils.ByteBufToArray
A class that holds information from a ByteBuf that allows to read its corresponding byte array.
TranscoderUtils.CommonFlags
The common flags enum.
TranscodingException  
TransparentReplicaGetHelper
The TransparentReplicaGetHelper abstracts common logic to first grab the active document and if that fails tries all available replicas and returns the first result.
TypeFunctions
DSL for N1QL functions in the Type category.
UnionElement  
UnnestElement  
UnnestPath
.
UnsetElement  
UnsetElement.UnsetPosition  
Update  
UpdateForClause
UpdateForClause is a clause used in N1QL Updates, more specifically in the "set" part.
UpdateSetOrUnsetPath  
UpdateSetPath  
UpdateUnsetPath  
UpdateUsePath  
Upsert  
User
Rbac user in couchbase
UserRole
Authorizing role for the user
UserSettings
Setting for the user - full name, password, roles
UsingElement
Element of the Index DSL that describes what kind of index to build.
UsingPath
Using path of the Index dropping DSL.
UsingWithPath
Using path of the Index creation DSL.
Utils  
ValueTooDeepException
Subdocument exception thrown when proposed value would make the document too deep to parse.
Version
Representation of a software version, up to major.minor.patch granularity.
View
Represents a View definition to store and load.
ViewDoesNotExistException  
ViewQuery
Fluent DSL for a View Query.
ViewQueryResponseMapper
Encapsulates functionality required to map from a ViewQueryResponse into a AsyncViewResult.
ViewResult
Represents the result from a ViewQuery.
ViewRetryHandler
Generic View retry handler based on response code and value inspection.
ViewRow
Represents a ViewRow fetched from the View.
WhereElement  
WherePath
Where clause in the Index creation DSL.
WherePath
Filters resulting rows based on the given expression.
WildcardQuery
An FTS query that allows for simple matching using wildcard characters (* and ?).
WithIndexOptionElement
Element of the Index DSL that allows to describe additional options for index creation.
WithPath
With path of the Index creation DSL (setting options).
XattrOrderingException
This exception is raised when non-xattr based commands are set before xattr-based ones.