Categorygithub.com/couchbase/gocb/v2
modulepackage
2.9.4
Repository: https://github.com/couchbase/gocb.git
Documentation: pkg.go.dev

# README

GoDoc

Couchbase Go Client

The Go SDK library allows you to connect to a Couchbase cluster from Go. It is written in pure Go, and uses the included gocbcore library to handle communicating to the cluster over the Couchbase binary protocol.

Useful Links

Source

The project source is hosted at https://github.com/couchbase/gocb.

Documentation

You can explore our API reference through godoc at https://pkg.go.dev/github.com/couchbase/gocb.

You can also find documentation for the Go SDK on the official Couchbase docs.

Bug Tracker

Issues are tracked on Couchbase's public issues.couchbase.com. Contact the site admins regarding login or other problems at issues.couchbase.com (officially) or ask around on the forum (unofficially).

Discussion

You can chat with us on Discord or the official Couchbase forums.

Installing

To install the latest stable version, run:

go get github.com/couchbase/gocb/v2@latest

To install the latest developer version, run:

go get github.com/couchbase/gocb/v2@master

Testing

You can run tests in the usual Go way:

go test -race ./...

Which will execute both the unit test suite and the integration test suite. By default, the integration test suite is run against a mock Couchbase Server. See the testmain_test.go file for information on command line arguments for running tests against a real server instance.

Release train

Releases are targeted for every third Tuesday of the month. This is subject to change based on priorities.

Linting

Linting is performed used golangci-lint. To run:

make lint

License

Copyright 2016 Couchbase Inc.

Licensed under the Apache License, Version 2.0.

See LICENSE for further details.

# Packages

No description provided by the author
No description provided by the author

# Functions

ArrayAddUniqueSpec adds an dictionary add unique operation to this mutation operation set.
ArrayAppendSpec adds an element(s) to the end (i.e.
ArrayInsertSpec inserts an element at a given position within an array.
ArrayPrependSpec adds an element to the beginning (i.e.
Connect creates and returns a Cluster instance created using the provided options and a connection string.
CountSpec allows you to retrieve the number of items in an array or keys within an dictionary within an element of a document.
DecrementSpec adds a decrement operation to this mutation operation set.
DefaultStdioLogger gets the default standard I/O logger.
ExistsSpec is similar to Path(), but does not actually retrieve the value from the server.
GetSpec indicates a path to be retrieved from the document.
Identifier returns a string representation of the current SDK identifier.
IncrementSpec adds an increment operation to this mutation operation set.
InsertSpec inserts a value at the specified path within the document.
NewAggregatingMeter creates a new LoggingMeter.
NewAzureBlobExternalAnalyticsLink creates a new AzureBlobExternalAnalyticsLink.
NewBestEffortRetryStrategy returns a new BestEffortRetryStrategy which will use the supplied calculator function to calculate retry durations.
NewCouchbaseRemoteAnalyticsLink creates a new CouchbaseRemoteAnalyticsLink.
NewJSONTranscoder returns a new JSONTranscoder.
NewLegacyTranscoder returns a new LegacyTranscoder.
NewLoggingMeter creates a new LoggingMeter.
NewLostTransactionsCleanup returns a LostTransactionsCleaner implementation.
NewMutationState creates a new MutationState for tracking mutation state.
NewRangeScanForPrefix creates a new range scan for the given prefix, starting at the prefix and ending at the prefix plus maximum.
NewRawBinaryTranscoder returns a new RawBinaryTranscoder.
NewRawJSONTranscoder returns a new RawJSONTranscoder.
NewRawStringTranscoder returns a new RawStringTranscoder.
NewS3ExternalAnalyticsLink creates a new S3ExternalAnalyticsLink with the scope field populated.
No description provided by the author
NewTransactionsCleaner returns a TransactionsCleaner implementation.
RemoveSpec removes the field at path.
ReplaceSpec replaces the value of the field at path.
ScanTermMaximum represents the maximum value that a ScanTerm can represent.
ScanTermMinimum represents the minimum value that a ScanTerm can represent.
SetLogger sets a logger to be used by the library.
SetLogRedactionLevel specifies the level with which logs should be redacted.
TransactionsProtocolExtensions returns a list strings representing the various features that this specific version of the library supports within its protocol version.
TransactionsProtocolVersion returns the protocol version that this library supports.
UpsertSpec creates a new value at the specified path within the document if it does not exist, if it does exist then it updates it.
VerboseStdioLogger is a more verbose level of DefaultStdioLogger().
Version returns a string representation of the current SDK version.

# Constants

No description provided by the author
No description provided by the author
No description provided by the author
No description provided by the author
No description provided by the author
No description provided by the author
AnalyticsScanConsistencyNotBounded indicates no data consistency is required.
AnalyticsScanConsistencyRequestPlus indicates that request-level data consistency is required.
AnsiHightlightStyle specifies to use ANSI tags to highlight search result hits.
No description provided by the author
No description provided by the author
No description provided by the author
No description provided by the author
No description provided by the author
No description provided by the author
ClusterConfigProfileWanDevelopment represents a wan development profile that can be applied to the ClusterOptions overwriting any properties that exist on the profile.
ClusterStateDegraded indicates that all services will function, but possibly not optimally.
ClusterStateOffline indicates that no nodes were reachable.
ClusterStateOnline indicates that all nodes are online and reachable.
CompressionModeActive specifies to use active compression for a bucket.
CompressionModeOff specifies to use no compression for a bucket.
CompressionModePassive specifies to use passive compression for a bucket.
ConflictResolutionTypeCustom specifies to use a custom bucket conflict resolution.
ConflictResolutionTypeSequenceNumber specifies to use sequence number conflict resolution on the bucket.
ConflictResolutionTypeTimestamp specifies to use timestamp conflict resolution on the bucket.
CouchbaseBucketType indicates a Couchbase bucket type.
DefaultHighlightStyle specifies to use the default to highlight search result hits.
DesignDocumentNamespaceDevelopment means that a design document resides in the development namespace.
DesignDocumentNamespaceProduction means that a design document resides in the production namespace.
DurabilityLevelMajority specifies that a mutation must be replicated (held in memory) to a majority of nodes.
DurabilityLevelMajorityAndPersistOnMaster specifies that a mutation must be replicated (held in memory) to a majority of nodes and also persisted (written to disk) on the active node.
DurabilityLevelNone specifies that no durability level should be applied.
DurabilityLevelPersistToMajority specifies that a mutation must be persisted (written to disk) to a majority of nodes.
DurabilityLevelUnknown specifies that the durability level is not set and will default to the default durability level.
EndpointStateConnected indicates the endpoint socket is connected and ready.
EndpointStateConnecting indicates the endpoint socket is connecting.
EndpointStateDisconnected indicates the endpoint socket is unreachable.
EndpointStateDisconnecting indicates the endpoint socket is disconnecting.
EphemeralBucketType indicates an Ephemeral bucket type.
EvictionPolicyTypeFull specifies to use full eviction for a couchbase bucket.
EvictionPolicyTypeNoEviction specifies to use no eviction for an ephemeral bucket.
EvictionPolicyTypeNotRecentlyUsed specifies to use not recently used (nru) eviction for an ephemeral bucket.
EvictionPolicyTypeValueOnly specifies to use value only eviction for a couchbase bucket.
ExternalDomain specifies users that are externally stored (in LDAP for instance).
HistoryRetentionCollectionDefaultDisabled specifies that history is disabled.
HistoryRetentionCollectionDefaultEnabled specifies that history is enabled.
HistoryRetentionCollectionDefaultUnset specifies that history is not set and defaults to the default server value.
HTMLHighlightStyle specifies to use HTML tags to highlight search result hits.
LocalDomain specifies users that are locally stored in Couchbase.
Various logging levels (or subsystems) which can categorize the message.
Various logging levels (or subsystems) which can categorize the message.
Various logging levels (or subsystems) which can categorize the message.
Various logging levels (or subsystems) which can categorize the message.
Various logging levels (or subsystems) which can categorize the message.
Various logging levels (or subsystems) which can categorize the message.
Various logging levels (or subsystems) which can categorize the message.
MemcachedBucketType indicates a Memcached bucket type.
MutationMacroCAS can be used to tell the server to use the CAS macro.
MutationMacroSeqNo can be used to tell the server to use the seqno macro.
MutationMacroValueCRC32c can be used to tell the server to use the value_crc32c macro.
PingStateError indicates that the ping operation failed.
PingStateOk indicates that the ping operation was successful.
PingStateTimeout indicates that the ping operation timed out.
PlainSaslMechanism represents that PLAIN auth should be performed.
QueryIndexTypeGsi indicates that GSI was used to build the index.
QueryIndexTypeView indicates that views were used to build the index.
QueryProfileModeNone disables query profiling.
QueryProfileModePhases includes phase profiling information in the query response.
QueryProfileModeTimings includes timing profiling information in the query response.
QueryScanConsistencyNotBounded indicates no data consistency is required.
QueryScanConsistencyRequestPlus indicates that request-level data consistency is required.
QueryStatusAborted indicates that a query was aborted.
QueryStatusClosed indicates that a query was closed.
QueryStatusCompleted indicates a query has completed.
QueryStatusErrors indicates a query completed with errors.
QueryStatusFatal indicates that a query ended with a fatal error.
QueryStatusRunning indicates the query is still running.
QueryStatusStopped indicates a query has been stopped.
QueryStatusSuccess indicates the query was successful.
QueryStatusTimeout indicates a query timed out.
QueryStatusUnknown indicates that the query status is unknown.
QueryUseReplicaLevelNotSet indicates to not set any replica level for the request.
QueryUseReplicaLevelOff indicates to disable replica reads.
QueryUseReplicaLevelOn indicates to enable replica reads.
No description provided by the author
No description provided by the author
RedactFull indicates to fully redact all possible identifying information from logs.
RedactNone indicates to perform no redactions.
RedactPartial indicates to redact all possible user-identifying information from logs.
ScramSha1SaslMechanism represents that SCRAM SHA1 auth should be performed.
ScramSha256SaslMechanism represents that SCRAM SHA256 auth should be performed.
ScramSha512SaslMechanism represents that SCRAM SHA512 auth should be performed.
SearchScanConsistencyNotBounded indicates no data consistency is required.
ServiceTypeAnalytics represents an analytics service.
ServiceTypeEventing represents an eventing service.
ServiceTypeKeyValue represents a memcached service.
ServiceTypeManagement represents a management service.
ServiceTypeQuery represents a query service.
ServiceTypeSearch represents a full-text-search service.
ServiceTypeViews represents a views service.
StorageBackendCouchstore specifies to use the couchstore storage type.
StorageBackendMagma specifies to use the magma storage type.
StoreSemanticsInsert signifies to create the document, and fail if it exists.
StoreSemanticsReplace signifies to Replace the document, and fail if it does not exist.
StoreSemanticsUpsert signifies to replace the document or create it if it doesn't exist.
SubdocDocFlagAccessDeleted indicates that you wish to receive soft-deleted documents.
SubdocDocFlagAddDoc indices that the document should be created only if it does not already exist.
SubdocDocFlagCreateAsDeleted indicates that you wish to create a document in deleted state.
SubdocDocFlagMkDoc indicates that the document should be created if it does not already exist.
SubdocDocFlagNone indicates no special behaviours.
SubdocFlagCreatePath indicates you wish to recursively create the tree of paths if it does not already exist within the document.
SubdocFlagNone indicates no special behaviours.
SubdocFlagUseMacros indicates that you wish macro substitution to occur on the value.
SubdocFlagXattr indicates your path refers to an extended attribute rather than the document.
TransactionAttemptStateAborted indicates that this attempt is in aborted state.
TransactionAttemptStateCommitted indicates that this attempt is in committed state.
TransactionAttemptStateCommitting indicates that this attempt is in committing state.
TransactionAttemptStateCompleted indicates that this attempt is in completed state.
TransactionAttemptStateNothingWritten indicates that nothing has been written in this attempt.
TransactionAttemptStatePending indicates that this attempt is in pending state.
TransactionAttemptStateRolledBack indicates that this attempt is in rolled back state.
TransactionErrorReasonSuccess indicates the transaction succeeded and did not fail.
TransactionErrorReasonTransactionCommitAmbiguous indicates the transaction should be failed and the commit was ambiguous.
TransactionErrorReasonTransactionExpired indicates the transaction should be failed because it expired.
TransactionErrorReasonTransactionFailed indicates the transaction should be failed because it failed.
TransactionErrorReasonTransactionFailedPostCommit indicates the transaction should be failed because it failed post commit.
ViewErrorModeContinue indicates to continue gathering results on error.
ViewErrorModeStop indicates to stop gathering results on error.
ViewOrderingAscending indicates the query results should be sorted from lowest to highest.
ViewOrderingDescending indicates the query results should be sorted from highest to lowest.
ViewScanConsistencyNotBounded indicates that no special behaviour should be used.
ViewScanConsistencyRequestPlus indicates to update the index before querying it.
ViewScanConsistencyUpdateAfter indicates to update the index asynchronously after querying.

# Variables

AnalyticsTemporaryFailureRetryReason indicates that an analytics operation failed due to a temporary failure.
CircuitBreakerOpenRetryReason indicates that the operation failed because the circuit breaker on the connection was open.
ErrAmbiguous indicates that a failure occured but the outcome was not known.
ErrAmbiguousTimeout occurs when an operation does not receive a response in a timely manner, and it cannot be established whether the operation has mutated any data.
ErrAnalyticsLinkExists occurs when the analytics link already exists.
ErrAtrEntryNotFound indicates that an expected ATR entry was missing.
ErrAtrFull indicates that the ATR record was too full to accept a new mutation.
ErrAtrNotFound indicates that an expected ATR document was missing.
ErrAttemptExpired indicates an transactionAttempt expired.
No description provided by the author
ErrAuthenticationFailure occurs when authentication has failed.
ErrBucketExists occurs when creating a bucket failed because it already exists.
ErrBucketNotFlushable occurs when a bucket could not be flushed because flushing is not enabled.
ErrBucketNotFound occurs when the requested bucket could not be found.
ErrCasMismatch occurs when an operation has been performed with a cas value that does not the value on the server.
ErrCircuitBreakerOpen occurs when the operation was cancelled because the circuit breaker was open # UNCOMMITTED: This API may change in the future.
ErrCollectionExists occurs when creating a collection failed because it already exists.
ErrCollectionNotFound occurs when the requested collection could not be found.
ErrCompilationFailure occurs when there was an issue executing the analytics query because it could not be compiled.
ErrDatasetExists occurs when creating an analytics dataset failed because it already exists.
ErrDatasetNotFound occurs when the analytics dataset requested could not be found.
ErrDataverseExists occurs when creating an analytics dataverse failed because it already exists.
ErrDataverseNotFound occurs when the analytics dataverse requested could not be found.
ErrDecodingFailure occurs when decoding of a value failed.
ErrDeltaInvalid occurs when a sub-document counter operation is performed and the specified delta is not valid.
ErrDesignDocumentNotFound occurs when the design document requested could not be found.
ErrDocAlreadyInTransaction indicates that a document is already in a transaction.
ErrDocumentExists occurs when an attempt is made to insert a document but a document with that key already exists.
ErrDocumentLocked occurs when a mutation operation is attempted against a document that is locked.
ErrDocumentNotFound occurs when the requested document could not be found.
ErrDocumentNotJSON occurs when a sub-document operation is performed on a document which is not JSON.
ErrDocumentNotLocked occurs when unlock is called on a document that is not locked.
ErrDocumentTooDeep occurs when an operation would cause a document to be nested beyond the depth limits allowed by the sub-document specification.
ErrDocumentUnretrievable occurs when GetAnyReplica cannot find the document on any replica.
ErrDurabilityAmbiguous occurs when an SyncWrite does not complete in the specified time and the result is ambiguous.
ErrDurabilityImpossible occurs when a request is performed with impossible durability level requirements.
ErrDurabilityLevelNotAvailable occurs when an invalid durability level was requested.
ErrDurableWriteInProgress occurs when an attempt is made to write to a key that has a SyncWrite pending.
ErrDurableWriteReCommitInProgress occurs when an SyncWrite is being recommitted.
ErrEncodingFailure occurs when encoding of a value failed.
ErrEventingFunctionCompilationFailure occurs when the eventing function requested could not be compiled.
ErrEventingFunctionDeployed occurs when the eventing function requested is not undeployed.
ErrEventingFunctionIdenticalKeyspace occurs when the eventing function requested uses the same keyspace for source and metadata.
ErrEventingFunctionNotBootstrapped occurs when the eventing function requested is not bootstrapped.
ErrEventingFunctionNotDeployed occurs when the eventing function requested is not deployed.
ErrEventingFunctionNotFound occurs when the eventing function requested could not be found.
ErrFeatureNotAvailable occurs when an operation is performed on a bucket which does not support it.
ErrForwardCompatibilityFailure indicates an operation failed due to involving a document in another transaction which contains features this transaction does not support.
ErrGroupNotFound occurs when the group requested could not be found.
ErrHard indicates that an unrecoverable error occured.
ErrIllegalState is used for when a transaction enters an illegal State.
ErrIndexExists occurs when creating an index that already exists.
ErrIndexFailure occurs when there was an issue with the index specified.
ErrIndexNotFound occurs when the requested index could not be found.
ErrInternalServerFailure occurs when the server encounters an internal server error.
ErrInvalidArgument occurs when an invalid argument is provided for an operation.
ErrJobQueueFull occurs when the analytics service job queue is full.
ErrLinkNotFound occurs when the analytics link requested could not be found.
ErrMutationLost occurs when a mutation was lost.
ErrMutationTokenOutdated occurs when snapshot requirements are specified but the requirements do not align with the server.
ErrNoResult occurs when no results are available to a query.
ErrNumberTooBig occurs when a sub-document operation is performed with a bad range.
ErrOther indicates an non-specific error has occured.
ErrOverload occurs when too many operations are dispatched and all queues are full.
ErrParsingFailure occurs when a query has failed to be parsed by the server.
ErrPathExists occurs when a sub-document operation expects a path not to exists, but the path was found in the document.
ErrPathInvalid occurs when a sub-document path could not be parsed.
ErrPathMismatch occurs when a sub-document operation specifies a path which does not match the document structure (field access on an array).
ErrPathNotFound occurs when a sub-document operation targets a path which does not exist in the specified document.
ErrPathTooBig occurs when a sub-document path is too big.
ErrPathTooDeep occurs when an operation would cause a document to be nested beyond the depth limits allowed by the sub-document specification.
ErrPlanningFailure occurs when the query service was unable to create a query plan.
ErrPreparedStatementFailure occurs when there was an issue with the prepared statement.
ErrPreviousOperationFailed indicates a previous operation already failed.
ErrQuotaLimitedFailure occurs when a request triggers a resource to exceed the allowed quota.
ErrRateLimitedFailure occurs when a request is rate limited by the server.
ErrRequestCanceled occurs when an operation has been canceled.
ErrScopeExists occurs when creating a scope failed because it already exists.
ErrScopeNotFound occurs when the requested scope could not be found.
ErrServiceNotAvailable occurs when the requested service is not available.
SDK specific error definitions.
ErrTemporaryFailure occurs when an operation has failed for a reason that is temporary.
ErrTimeout occurs when an operation does not receive a response in a timely manner.
ErrTransactionAbortedExternally indicates the transaction was aborted externally.
ErrTransient indicates a transient error occured which may succeed at a later point in time.
ErrUnambiguousTimeout occurs when an operation does not receive a response in a timely manner, and we are confident that the operation has not mutated any data.
ErrUnsupportedOperation occurs when an operation that is unsupported or unknown is performed against the server.
ErrUserExists occurs when creating a user failed because it already exists.
ErrUserNotFound occurs when the user requested could not be found.
ErrValueInvalid occurs when a sub-document operation could not insert.
ErrValueNotJSON occurs when a sub-document operation is performed on a document which is not JSON.
ErrValueTooDeep occurs when a sub-document operation specifies a value which is deeper than the depth limits of the sub-document specification.
ErrValueTooLarge occurs when a document has gone over the maximum size allowed by the server.
ErrViewNotFound occurs when the view requested could not be found.
ErrWriteWriteConflict indicates that another transaction conflicted with this one.
ErrXattrCannotModifyVirtualAttribute occurs when a mutation is attempted upon a virtual attribute (which are immutable by definition).
ErrXattrInvalidFlagCombo occurs when an invalid set of extended-attribute flags is passed to a sub-document operation.
ErrXattrInvalidKeyCombo occurs when an invalid set of key operations are specified for a extended-attribute sub-document operation.
ErrXattrInvalidOrder occurs when a set key key operations are specified for a extended-attribute sub-document operation in the incorrect order.
ErrXattrUnknownMacro occurs when an invalid macro value is specified.
ErrXattrUnknownVirtualAttribute occurs when an invalid virtual attribute is specified.
EventingFunctionBucketAccessReadOnly represents readonly access to a bucket for an eventing function.
EventingFunctionBucketAccessReadWrite represents readwrite access to a bucket for an eventing function.
EventingFunctionDCPBoundaryEverything will deploy the eventing function for all data mutations.
EventingFunctionDCPBoundaryFromNow will deploy the eventing function for only data mutations occurring post deployment.
EventingFunctionDeploymentStatusDeployed represents that the eventing function is currently deployed.
EventingFunctionDeploymentStatusUndeployed represents that the eventing function is currently undeployed.
EventingFunctionLanguageCompatibilityVersion600 represents the eventing function language compatibility 6.0.0.
EventingFunctionLanguageCompatibilityVersion650 represents the eventing function language compatibility 6.5.0.
EventingFunctionLanguageCompatibilityVersion662 represents the eventing function language compatibility 6.6.2.
EventingFunctionLanguageCompatibilityVersion720 represents the eventing function language compatibility 7.2.0.
EventingFunctionLogLevelDebug represents to log messages at DEBUG for the eventing function.
EventingFunctionLogLevelError represents to log messages at ERROR for the eventing function.
EventingFunctionLogLevelInfo represents to log messages at INFO for the eventing function.
EventingFunctionLogLevelTrace represents to log messages at TRACE for the eventing function.
EventingFunctionLogLevelWarning represents to log messages at WARNING for the eventing function.
EventingFunctionProcessingStatusPaused represents that the eventing function is currently paused.
EventingFunctionProcessingStatusRunning represents that the eventing function is currently running.
EventingFunctionStateDeployed represents that the eventing function is deployed.
EventingFunctionStateDeploying represents that the eventing function is deploying.
EventingFunctionStatePaused represents that the eventing function is paused.
EventingFunctionStatePausing represents that the eventing function is pausing.
EventingFunctionStateUndeployed represents that the eventing function is undeployed.
EventingFunctionStateUndeploying represents that the eventing function is undeploying.
KVCollectionOutdatedRetryReason indicates that the operation failed because the collection ID on the request is outdated.
KVErrMapRetryReason indicates that the operation failed for an unsupported reason but the KV error map indicated that the operation can be retried.
KVLockedRetryReason indicates that the operation failed because the document was locked.
KVNotMyVBucketRetryReason indicates that the operation failed because it was sent to the wrong node for the vbucket.
KVSyncWriteInProgressRetryReason indicates that the operation failed because a sync write is in progress.
KVSyncWriteRecommitInProgressRetryReason indicates that the operation failed because a sync write recommit is in progress.
KVTemporaryFailureRetryReason indicates that the operation failed because of a temporary failure.
NodeNotAvailableRetryReason indicates that the operation failed because the requested node was not available.
NotReadyRetryReason indicates the SDK connections are not setup and ready to be used.
QueryErrorRetryable indicates that the operation is retryable as indicated by the query engine.
QueryIndexNotFoundRetryReason indicates that the operation failed to to a missing query index.
QueryPreparedStatementFailureRetryReason indicates that the operation failed due to a prepared statement failure.
SearchTooManyRequestsRetryReason indicates that a search operation failed due to too many requests.
ServiceNotAvailableRetryReason indicates that the operation failed because the requested service was not available.
ServiceResponseCodeIndicatedRetryReason indicates that the operation failed and the service responded stating that the request should be retried.
SocketCloseInFlightRetryReason indicates that the operation failed because the socket was closed whilst the operation was in flight.
SocketNotAvailableRetryReason indicates that the operation failed because the underlying socket was not available.
UnknownRetryReason indicates that the operation failed for an unknown reason.

# Structs

AggregatingMeterOptions is the set of options available when creating a LoggingMeter.
AllowQueryingSearchIndexOptions is the set of options available to the search index AllowQuerying operation.
AnalyticsDataset contains information about an analytics dataset.
AnalyticsError is the error type of all analytics query errors.
AnalyticsErrorDesc represents a specific error returned from the analytics service.
AnalyticsIndex contains information about an analytics index.
AnalyticsIndexManager provides methods for performing Couchbase Analytics index management.
AnalyticsMetaData provides access to the meta-data properties of a query result.
AnalyticsMetrics encapsulates various metrics gathered during a queries execution.
AnalyticsOptions is the set of options available to an Analytics query.
AnalyticsResult allows access to the results of a query.
AnalyticsResultRaw provides raw access to analytics query data.
AnalyticsWarning encapsulates any warnings returned by a query.
AnalyzeDocumentOptions is the set of options available to the search index AnalyzeDocument operation.
AppendOp represents a type of `BulkOp` used for Append operations.
AppendOptions are the options available to the Append operation.
ArrayAddUniqueSpecOptions are the options available to subdocument ArrayAddUnique operations.
ArrayAppendSpecOptions are the options available to subdocument ArrayAppend operations.
ArrayInsertSpecOptions are the options available to subdocument ArrayInsert operations.
ArrayPrependSpecOptions are the options available to subdocument ArrayPrepend operations.
AuthCertRequest encapsulates the data for a certificate request from the new Authenticator interface.
AuthCredsRequest encapsulates the data for a credential request from the new Authenticator interface.
AzureBlobExternalAnalyticsLink describes an external analytics link which uses the Microsoft Azure Blob Storage service.
BestEffortRetryStrategy represents a strategy that will keep retrying until it succeeds (or the caller times out the request).
BinaryCollection is a set of binary operations.
Bucket represents a single bucket within a cluster.
BucketManager provides methods for performing bucket management operations.
BucketSettings holds information about the settings for a bucket.
BuildDeferredQueryIndexOptions is the set of options available to the query indexes BuildDeferredIndexes operation.
BulkOpOptions are the set of options available when performing BulkOps using Do.
CertificateAuthenticator implements an Authenticator which can be used with certificate authentication.
ChangePasswordOptions is the set of options available to the user manager ChangePassword operation.
CircuitBreakerConfig are the settings for configuring circuit breakers.
Cluster represents a connection to a specific Couchbase cluster.
ClusterCloseOptions is the set of options available when disconnecting from a Cluster.
ClusterOptions is the set of options available for creating a Cluster.
Collection represents a single collection.
CollectionHistorySettings specifies settings for whether history retention should be enabled or disabled for this collection.
CollectionManager provides methods for performing collections management.
CollectionManagerV2 provides methods for performing collections management.
CollectionQueryIndexManager provides methods for performing Couchbase query index management against collections.
CollectionSpec describes the specification of a collection.
CompressionConfig specifies options for controlling compression applied to documents before sending to Couchbase Server.
ConnectAnalyticsLinkOptions is the set of options available to the AnalyticsManager ConnectLink operation.
CouchbaseList represents a list document.
CouchbaseMap represents a map document.
CouchbaseQueue represents a queue document.
CouchbaseRemoteAnalyticsEncryptionSettings are the settings available for setting encryption level on a link.
CouchbaseRemoteAnalyticsLink describes a remote analytics link which uses a Couchbase data service that is not part of the same cluster as the Analytics Service.
CouchbaseSet represents a set document.
CounterResult is the return type of counter operations.
CounterSpecOptions are the options available to subdocument Increment and Decrement operations.
CountSpecOptions are the options available to LookupIn subdoc Count operations.
CreateAnalyticsDatasetOptions is the set of options available to the AnalyticsManager CreateDataset operation.
CreateAnalyticsDataverseOptions is the set of options available to the AnalyticsManager CreateDataverse operation.
CreateAnalyticsIndexOptions is the set of options available to the AnalyticsManager CreateIndex operation.
CreateAnalyticsLinkOptions is the set of options available to the analytics manager CreateLink function.
CreateBucketOptions is the set of options available to the bucket manager CreateBucket operation.
CreateBucketSettings are the settings available when creating a bucket.
CreateCollectionOptions is the set of options available to the CreateCollection operation.
CreateCollectionSettings specifies settings for a collection to be created.
CreatePrimaryQueryIndexOptions is the set of options available to the query indexes CreatePrimaryIndex operation.
CreateQueryIndexOptions is the set of options available to the query indexes CreateIndex operation.
CreateScopeOptions is the set of options available to the CreateScope operation.
DecrementOp represents a type of `BulkOp` used for Decrement operations.
DecrementOptions are the options available to the Decrement operation.
DeployEventingFunctionOptions are the options available when using the DeployFunction operation.
DesignDocument represents a Couchbase design document containing multiple views.
DiagnosticsOptions are the options that are available for use with the Diagnostics operation.
DiagnosticsResult encapsulates the results of a Diagnostics operation.
DisallowQueryingSearchIndexOptions is the set of options available to the search index DisallowQuerying operation.
DisconnectAnalyticsLinkOptions is the set of options available to the AnalyticsManager DisconnectLink operation.
DropAnalyticsDatasetOptions is the set of options available to the AnalyticsManager DropDataset operation.
DropAnalyticsDataverseOptions is the set of options available to the AnalyticsManager DropDataverse operation.
DropAnalyticsIndexOptions is the set of options available to the AnalyticsManager DropIndex operation.
DropAnalyticsLinkOptions is the set of options available to the analytics manager DropLink function.
DropBucketOptions is the set of options available to the bucket manager DropBucket operation.
DropCollectionOptions is the set of options available to the DropCollection operation.
DropDesignDocumentOptions is the set of options available to the ViewIndexManager Upsert operation.
DropEventingFunctionOptions are the options available when using the DropFunction operation.
DropGroupOptions is the set of options available to the group manager Drop operation.
DropPrimaryQueryIndexOptions is the set of options available to the query indexes DropPrimaryIndex operation.
DropQueryIndexOptions is the set of options available to the query indexes DropIndex operation.
DropScopeOptions is the set of options available to the DropScope operation.
DropSearchIndexOptions is the set of options available to the search index DropIndex operation.
DropUserOptions is the set of options available to the user manager Drop operation.
EndPointDiagnostics represents a single entry in a diagnostics report.
EndpointPingReport represents a single entry in a ping report.
EventingFunction represents an eventing function.
EventingFunctionBucketBinding represents an eventing function binding allowing the function access to buckets, scopes, and collections.
EventingFunctionConstantBinding represents an eventing function binding allowing the function to utilize global variables.
EventingFunctionKeyspace represents a triple of bucket, collection, and scope names.
EventingFunctionManager provides methods for performing eventing function management operations.
EventingFunctionSettings are the settings for an EventingFunction.
EventingFunctionsStatusOptions are the options available when using the FunctionsStatus operation.
EventingFunctionState represents the current state of an eventing function.
EventingFunctionUrlAuthBasic specifies that basic authentication is used for the EventingFunctionUrlBinding.
EventingFunctionUrlAuthBearer specifies that bearer token authentication is used for the EventingFunctionUrlBinding.
EventingFunctionUrlAuthDigest specifies that digest authentication is used for the EventingFunctionUrlBinding.
EventingFunctionUrlBinding represents an eventing function binding allowing the function access external resources via cURL.
EventingFunctionUrlNoAuth specifies that no authentication is used for the EventingFunctionUrlBinding.
EventingStatus represents the current state of all eventing functions.
ExistsOptions are the options available to the Exists command.
ExistsResult is the return type of Exist operations.
ExistsSpecOptions are the options available to LookupIn subdoc Exists operations.
FlushBucketOptions is the set of options available to the bucket manager FlushBucket operation.
FreezePlanSearchIndexOptions is the set of options available to the search index FreezePlan operation.
GenericError wraps errors that come from the SDK, and can be returned from any service.
GetAllAnalyticsDatasetsOptions is the set of options available to the AnalyticsManager GetAllDatasets operation.
GetAllAnalyticsIndexesOptions is the set of options available to the AnalyticsManager GetAllIndexes operation.
GetAllBucketsOptions is the set of options available to the bucket manager GetAll operation.
GetAllDesignDocumentsOptions is the set of options available to the ViewIndexManager GetAllDesignDocuments operation.
GetAllEventingFunctionsOptions are the options available when using the GetAllFunctions operation.
GetAllGroupsOptions is the set of options available to the group manager GetAll operation.
GetAllQueryIndexesOptions is the set of options available to the query indexes GetAllIndexes operation.
GetAllReplicaOptions are the options available to the GetAllReplicas command.
GetAllReplicasResult represents the results of a GetAllReplicas operation.
GetAllScopesOptions is the set of options available to the GetAllScopes operation.
GetAllSearchIndexOptions is the set of options available to the search indexes GetAllIndexes operation.
GetAllUsersOptions is the set of options available to the user manager GetAll operation.
GetAnalyticsLinksOptions are the options available to the AnalyticsManager GetLinks function.
GetAndLockOptions are the options available to the GetAndLock operation.
GetAndTouchOp represents a type of `BulkOp` used for GetAndTouch operations.
GetAndTouchOptions are the options available to the GetAndTouch operation.
GetAnyReplicaOptions are the options available to the GetAnyReplica command.
GetBucketOptions is the set of options available to the bucket manager GetBucket operation.
GetDesignDocumentOptions is the set of options available to the ViewIndexManager GetDesignDocument operation.
GetEventingFunctionOptions are the options available when using the GetFunction operation.
GetGroupOptions is the set of options available to the group manager Get operation.
GetIndexedDocumentsCountOptions is the set of options available to the search index GetIndexedDocumentsCount operation.
GetNodesMetadataOptions is the set of options available to the GetNodesMetadata operation.
GetOp represents a type of `BulkOp` used for Get operations.
GetOptions are the options available to a Get operation.
GetPendingMutationsAnalyticsOptions is the set of options available to the user manager GetPendingMutations operation.
GetReplicaResult is the return type of GetReplica operations.
GetResult is the return type of Get operations.
GetRolesOptions is the set of options available to the user manager GetRoles operation.
GetSearchIndexOptions is the set of options available to the search indexes GetIndex operation.
GetSpecOptions are the options available to LookupIn subdoc Get operations.
GetUserOptions is the set of options available to the user manager Get operation.
Group represents a user group on the server.
HTTPError is the error type of management HTTP errors.
IncrementOp represents a type of `BulkOp` used for Increment operations.
IncrementOptions are the options available to the Increment operation.
InsertOp represents a type of `BulkOp` used for Insert operations.
InsertOptions are options that can be applied to an Insert operation.
InsertSpecOptions are the options available to subdocument Insert operations.
InternalBucket is used for internal functionality.
InternalCluster is used for internal functionality.
InternalConfig specifies options for controlling various internal items.
InternalTransactionAttemptContext is used for internal dealings.
IoConfig specifies IO related configuration options.
JSONTranscoder implements the default transcoding behavior and applies JSON transcoding to all values.
KeyValueError wraps key-value errors that occur within the SDK.
LegacyTranscoder implements the behaviour for a backward-compatible transcoder.
LoggingMeter is a Meter implementation providing a simplified, but useful, view into current SDK state.
LoggingMeterOptions is the set of options available when creating a LoggingMeter.
LookupInAllReplicaOptions are the set of options available to LookupInAllReplicas.
LookupInAllReplicasResult represents the results of a LookupInAllReplicas operation.
LookupInAnyReplicaOptions are the set of options available to LookupInAnyReplica.
LookupInOptions are the set of options available to LookupIn.
LookupInReplicaResult is the return type of LookupInReplica operations.
LookupInResult is the return type for LookupIn.
LookupInSpec is the representation of an operation available when calling LookupIn.
MutateInOptions are the set of options available to MutateIn.
MutateInResult is the return type of any mutate in related operations.
MutateInSpec is the representation of an operation available when calling MutateIn.
MutationResult is the return type of any store related operations.
MutationState holds and aggregates MutationToken's across multiple operations.
MutationStateInternal specifies internal operations.
MutationToken holds the mutation state information from an operation.
NewAzureBlobExternalAnalyticsLinkOptions are the options available when creating a new AzureBlobExternalAnalyticsLink.
NewCouchbaseRemoteAnalyticsLinkOptions are the options available when creating a new CouchbaseRemoteAnalyticsLink.
NewS3ExternalAnalyticsLinkOptions are the options available when creating a new S3ExternalAnalyticsLink.
NodeMetadata contains information about a node in the cluster.
NoopMeter is a Meter implementation which performs no metrics operations.
NoopTracer is a RequestTracer implementation that does not perform any tracing.
NoRetryRetryAction represents an action that indicates to not retry.
Origin indicates why a user has a specific role.
OrphanReporterConfig specifies options for controlling the orphan reporter which records when the SDK receives responses for requests that are no longer in the system (usually due to being timed out).
PasswordAuthenticator implements an Authenticator which uses an RBAC username and password.
PauseEventingFunctionOptions are the options available when using the PauseFunction operation.
PauseIngestSearchIndexOptions is the set of options available to the search index PauseIngest operation.
PingOptions are the options available to the Ping operation.
PingResult encapsulates the details from a executed ping operation.
PrependOp represents a type of `BulkOp` used for Prepend operations.
PrependOptions are the options available to the Prepend operation.
PublishDesignDocumentOptions is the set of options available to the ViewIndexManager PublishDesignDocument operation.
QueryError is the error type of all query errors.
QueryErrorDesc represents a specific error returned from the query service.
QueryIndex represents a Couchbase GSI index.
QueryIndexManager provides methods for performing Couchbase query index management.
QueryMetaData provides access to the meta-data properties of a query result.
QueryMetrics encapsulates various metrics gathered during a queries execution.
QueryOptions represents the options available when executing a query.
QueryResult allows access to the results of a query.
QueryResultInternal provides access to internal only functionality.
QueryResultRaw provides raw access to query data.
QueryWarning encapsulates any warnings returned by a query.
RangeScan indicates that the Scan operation should scan a range of keys.
RawBinaryTranscoder implements passthrough behavior of raw binary data.
RawJSONTranscoder implements passthrough behavior of JSON data.
RawStringTranscoder implements passthrough behavior of raw string data.
RemoveOp represents a type of `BulkOp` used for Remove operations.
RemoveOptions are the options available to the Remove command.
RemoveSpecOptions are the options available to subdocument Remove operations.
ReplaceAnalyticsLinkOptions is the set of options available to the analytics manager ReplaceLink function.
ReplaceOp represents a type of `BulkOp` used for Replace operations.
ReplaceOptions are the options available to a Replace operation.
ReplaceSpecOptions are the options available to subdocument Replace operations.
Result is the base type for the return types of operations.
ResumeEventingFunctionOptions are the options available when using the ResumeFunction operation.
ResumeIngestSearchIndexOptions is the set of options available to the search index ResumeIngest operation.
Role represents a specific permission.
RoleAndDescription represents a role with its display name and description.
RoleAndOrigins associates a role with its origins.
S3ExternalAnalyticsLink describes an external analytics link which uses the AWS S3 service to access data.
SamplingScan indicates that the Scan operation should perform random sampling.
ScanOptions are the set of options available to the Scan operation.
ScanResult is the return type of Scan operations.
ScanResultItem represents an item that is returning on the stream from a Scan operation.
ScanTerm represents a term that can be used during a Scan operation.
Scope represents a single scope within a bucket.
ScopeEventingFunctionManager provides methods for performing scoped eventing function management operations.
ScopeSearchIndexManager provides methods for performing scope-level search index management operations.
ScopeSpec describes the specification of a scope.
SearchDateRangeFacetResult holds the results of a date facet in search results.
SearchError is the error type of all search query errors.
SearchFacetResult provides access to the result of a faceted query.
SearchHighlightOptions are the options available for search highlighting.
SearchIndex is used to define a search index.
SearchIndexManager provides methods for performing Couchbase search index management.
SearchMetaData provides access to the meta-data properties of a search query result.
SearchMetrics encapsulates various metrics gathered during a search queries execution.
SearchNumericRangeFacetResult holds the results of a numeric facet in search results.
SearchOptions represents a pending search query.
SearchRequest is used for describing a search request used with Search.
SearchResult allows access to the results of a search query.
SearchResultRaw provides raw access to search data.
SearchRow represents a single hit returned from a search query.
SearchRowLocation represents the location of a row match.
SearchTermFacetResult holds the results of a term facet in search results.
SecurityConfig specifies options for controlling security related items such as TLS root certificates and verification skipping.
SingleQueryTransactionOptions specifies various tunable query options related to single query transactions.
ThresholdLoggingOptions is the set of options available for configuring threshold logging.
ThresholdLoggingTracer is a specialized Tracer implementation which will automatically log operations which fall outside of a set of thresholds.
TimeoutError wraps timeout errors that occur within the SDK.
TimeoutsConfig specifies options for various operation timeouts.
TouchOp represents a type of `BulkOp` used for Touch operations.
TouchOptions are the options available to the Touch operation.
TransactionAttemptContext represents a single attempt to execute a transaction.
TransactionCleanupAttempt represents the result of running cleanup for a transaction transactionAttempt.
TransactionCleanupRequest represents a complete transaction transactionAttempt that requires cleanup.
No description provided by the author
TransactionDocRecord represents an individual document operation requiring cleanup.
No description provided by the author
No description provided by the author
No description provided by the author
TransactionGetResult represents the result of a Get operation which was performed.
TransactionKeyspace specifies a specific location where ATR entries should be placed when performing transactions.
TransactionLogItem represents an entry in the transaction in memory logging.
TransactionOperationFailedError is used when a transaction operation fails.
TransactionOptions specifies options which can be overridden on a per transaction basis.
TransactionQueryOptions specifies the set of options available when running queries as a part of a transaction.
TransactionQueryResult allows access to the results of a query.
TransactionResult represents the result of a transaction which was executed.
Transactions can be used to perform transactions.
TransactionsCleanupConfig specifies various tunable options related to transactions cleanup.
TransactionsClientRecordDetails is the result of processing a client record.
TransactionsConfig specifies various tunable options related to transactions.
TransactionsForwardCompatibilityEntry represents a forward compatibility entry.
TransactionsInternal exposes internal methods that are useful for testing and/or other forms of internal use.
TransactionsProcessATRStats is the stats recorded when running a ProcessATR request.
TransactionsQueryConfig specifies various tunable query options related to transactions.
UndeployEventingFunctionOptions are the options available when using the UndeployFunction operation.
UnfreezePlanSearchIndexOptions is the set of options available to the search index UnfreezePlan operation.
UnlockOptions are the options available to the GetAndLock operation.
UpdateBucketOptions is the set of options available to the bucket manager UpdateBucket operation.
UpdateCollectionOptions is the set of options available to the UpdateCollection operation.
UpdateCollectionSettings specifies the settings for a collection that should be updated.
UpsertDesignDocumentOptions is the set of options available to the ViewIndexManager UpsertDesignDocument operation.
UpsertEventingFunctionOptions are the options available when using the UpsertFunction operation.
UpsertGroupOptions is the set of options available to the group manager Upsert operation.
UpsertOp represents a type of `BulkOp` used for Upsert operations.
UpsertOptions are options that can be applied to an Upsert operation.
UpsertSearchIndexOptions is the set of options available to the search index manager UpsertIndex operation.
UpsertSpecOptions are the options available to subdocument Upsert operations.
UpsertUserOptions is the set of options available to the user manager Upsert operation.
User represents a user which was retrieved from the server.
UserAndMetadata represents a user and user meta-data from the server.
UserManager provides methods for performing Couchbase user management.
View represents a Couchbase view within a design document.
ViewError is the error type of all view query errors.
ViewErrorDesc represents a specific error returned from the views service.
ViewIndexManager provides methods for performing View management.
ViewMetaData provides access to the meta-data properties of a view query result.
ViewOptions represents the options available when executing view query.
ViewResult implements an iterator interface which can be used to iterate over the rows of the query results.
ViewResultRaw provides raw access to views data.
ViewRow represents a single row returned from a view query.
WaitUntilReadyOptions is the set of options available to the WaitUntilReady operations.
WatchQueryIndexOptions is the set of options available to the query indexes Watch operation.
WithDurationRetryAction represents an action that indicates to retry with a given duration.

# Interfaces

AnalyticsLink describes an external or remote analytics link, used to access data external to the cluster.
Authenticator provides an interface to authenticate to each service.
BulkOp represents a single operation that can be submitted (within a list of more operations) to .Do() You can create a bulk operation by instantiating one of the implementations of BulkOp, such as GetOp, UpsertOp, ReplaceOp, and more.
Counter is used for incrementing a synchronous count metric.
EventingFunctionUrlAuth represents an authentication method for EventingFunctionUrlBinding for an eventing function.
Logger defines a logging interface.
LostTransactionsCleaner is responsible for performing cleanup of lost transactions.
Meter handles metrics information for SDK operations.
No description provided by the author
No description provided by the author
No description provided by the author
RequestSpan is the interface for spans that are created by a RequestTracer.
RequestSpanContext is the interface for external span contexts that can be passed in into the SDK option blocks.
RequestTracer describes the tracing abstraction in the SDK.
RetryAction is used by a RetryStrategy to calculate the duration to wait before retrying an operation.
RetryReason represents the reason for an operation possibly being retried.
RetryRequest is a request that can possibly be retried.
RetryStrategy is to determine if an operation should be retried, and if so how long to wait before retrying.
ScanType represents the mode of execution to use for a Scan operation.
TransactionCleanupHooks provides a number of internal hooks used for testing.
TransactionClientRecordHooks provides a number of internal hooks used for testing.
TransactionHooks provides a number of internal hooks used for testing.
TransactionLogger is the logger used for logging in transactions.
TransactionsCleaner is responsible for performing cleanup of completed transactions.
Transcoder provides an interface for transforming Go values to and from raw bytes for storage and retreival from Couchbase data storage.
ValueRecorder is used for grouping synchronous count metrics.

# Type aliases

No description provided by the author
No description provided by the author
AnalyticsScanConsistency indicates the level of data consistency desired for an analytics query.
AttemptFunc represents the lambda used by the Transactions Run function.
AuthDomain specifies the user domain of a specific user.
BackoffCalculator defines how backoff durations will be calculated by the retry API.
BucketType specifies the kind of bucket.
Capability represents a server capability.
CapabilityStatus represents a status for a server capability.
Cas represents the specific state of a document on the cluster.
CircuitBreakerCallback is the callback used by the circuit breaker to determine if an error should count toward the circuit breaker failure count.
ClusterConfigProfile represents a named profile that can be applied to ClusterOptions.
ClusterState specifies the current state of the cluster.
CompressionMode specifies the kind of compression to use for a bucket.
ConflictResolutionType specifies the kind of conflict resolution to use for a bucket.
DesignDocumentNamespace represents which namespace a design document resides in.
DurabilityLevel specifies the level of synchronous replication to use.
EndpointState specifies the current state of an endpoint.
EventingFunctionBucketAccess represents the level of access an eventing function has to a bucket.
EventingFunctionDCPBoundary sets what data mutations to deploy the eventing function for.
EventingFunctionDeploymentStatus represents the current deployment status for the eventing function.
EventingFunctionLanguageCompatibility represents the eventing function language compatibility for backward compatibility.
EventingFunctionLogLevel represents the granularity at which to log messages for the eventing function.
EventingFunctionProcessingStatus represents the current processing status for the eventing function.
EventingFunctionStatus describes the current state of an eventing function.
EvictionPolicyType specifies the kind of eviction policy to use for a bucket.
HistoryRetentionCollectionDefault specifies whether history is enabled on the bucket.
LogLevel specifies the severity of a log message.
LogRedactLevel specifies the degree with which to redact the logs.
MutationMacro can be supplied to MutateIn operations to perform ExpandMacros operations.
PingState specifies the result of the ping operation.
QueryIndexType provides information on the type of indexer used for an index.
QueryProfileMode specifies the profiling mode to use during a query.
QueryScanConsistency indicates the level of data consistency desired for a query.
QueryStatus provides information about the current status of a query.
QueryUseReplicaLevel specifies whether to enable replica reads for the request.
No description provided by the author
SaslMechanism represents a type of auth that can be performed.
SearchHighlightStyle indicates the type of highlighting to use for a search query.
SearchScanConsistency indicates the level of data consistency desired for a search query.
ServiceType specifies a particular Couchbase service type.
StorageBackend specifies the storage type to use for the bucket.
StoreSemantics is used to define the document level action to take during a MutateIn operation.
SubdocDocFlag specifies document-level flags for a sub-document operation.
SubdocFlag provides special handling flags for sub-document operations.
TransactionAttemptState represents the current state of a transaction attempt.
TransactionErrorReason is the reason why a transaction should be failed.
TransactionsBucketProviderFn is a function used to provide a bucket for a particular bucket by name.
No description provided by the author
UserPassPair represents a username and password pair.
ViewErrorMode specifies the behaviour of the query engine should an error occur during the gathering of view index results which would result in only partial results being available.
ViewOrdering specifies the ordering for the view queries results.
ViewScanConsistency specifies the consistency required for a view query.