Uses of Class
com.couchbase.client.core.annotation.Stability.Internal
-
-
Uses of Stability.Internal in com.couchbase.client.core
Classes in com.couchbase.client.core with annotations of type Stability.Internal Modifier and Type Class Description static class
Core.ResponseMetricIdentifier
class
CoreKeyspace
class
CoreLimiter
class
CoreProtostellar
class
Timer
TheTimer
acts as the main timing facility for various operations, for example to track and time out requests if they run for too long or for rescheduling needs.Methods in com.couchbase.client.core with annotations of type Stability.Internal Modifier and Type Method Description CoreContext
CoreContext. alternateAddress(Optional<String> alternateAddress)
Sets the alternate address on this context.ClusterConfig
Core. clusterConfig()
This API provides access to the current config that is published throughout the core.CoreCollectionManager
Core. collectionManager(String bucketName)
ConfigurationProvider
Core. configurationProvider()
Returns the attached configuration provider.Stream<EndpointDiagnostics>
Core. diagnostics()
Mono<Void>
Core. ensureServiceAt(NodeIdentifier identifier, ServiceType serviceType, int port, Optional<String> bucket, Optional<String> alternateAddress)
This method can be used by a caller to make sure a certain service is enabled at the given target node.CoreHttpClient
Core. httpClient(RequestTarget target)
Returns a client for issuing HTTP requests to servers in the cluster.void
Core. initGlobalConfig()
Instructs the client to, if possible, load and initialize the global config.Stream<InternalEndpointDiagnostics>
Core. internalDiagnostics()
boolean
Core. isProtostellar()
CoreKvBinaryOps
Core. kvBinaryOps(CoreKeyspace keyspace)
CoreKvOps
Core. kvOps(CoreKeyspace keyspace)
void
Core. openBucket(String name)
Attempts to open a bucket and fails theMono
if there is a persistent error as the reason.CoreProtostellar
Core. protostellar()
CoreQueryOps
Core. queryOps()
ValueRecorder
Core. responseMetric(Core.ResponseMetricIdentifier rmi)
ValueRecorder
Core. responseMetric(Request<?> request)
ValueRecorder
CoreProtostellar. responseMetric(Core.ResponseMetricIdentifier rmi)
CoreSearchOps
Core. searchOps(CoreBucketAndScope scope)
<R extends Response>
voidCore. send(Request<R> request, boolean registerForTimeout)
Sends a command into the core layer and allows to avoid timeout registration.Optional<Flux<ServiceState>>
Core. serviceState(NodeIdentifier nodeIdentifier, ServiceType type, Optional<String> bucket)
If present, returns a flux that allows to monitor the state changes of a specific service.Mono<Void>
Core. shutdown()
Mono<Void>
Core. shutdown(Duration timeout)
Shuts down this core and all associated, owned resources.CoreTransactionsCleanup
Core. transactionsCleanup()
CoreTransactionsContext
Core. transactionsContext()
static <T> Mono<T>
Reactor. wrap(CompletableFuture<T> response, Runnable cancellationTask)
Converts the given future into a mono. -
Uses of Stability.Internal in com.couchbase.client.core.annotation
Classes in com.couchbase.client.core.annotation with annotations of type Stability.Internal Modifier and Type Class Description interface
SinceCouchbase
Specifies the earliest version of Couchbase Server that supports the annotated feature.interface
UsedBy
Indicates the target element is not intended for public use, but some other Couchbase project depends on it. -
Uses of Stability.Internal in com.couchbase.client.core.api
Classes in com.couchbase.client.core.api with annotations of type Stability.Internal Modifier and Type Interface Description interface
CoreCouchbaseOps
Provides access to the variousCore*Ops
instances. -
Uses of Stability.Internal in com.couchbase.client.core.api.kv
Classes in com.couchbase.client.core.api.kv with annotations of type Stability.Internal Modifier and Type Class Description class
CoreAsyncResponse<T>
Associates aCompletableFuture
with a cancellation task.class
CoreCounterResult
class
CoreDurability
Either a synchronousDurabilityLevel
, or "persist to and replicate to" for legacy durability.interface
CoreEncodedContent
class
CoreExistsResult
class
CoreExpiry
A relative or absolute expiry.class
CoreGetResult
interface
CoreKvBinaryOps
interface
CoreKvOps
class
CoreKvParamValidators
class
CoreKvResponseMetadata
class
CoreKvResult
class
CoreLookupInMacro
Convenience macros to retrieve document metadata using a lookupIn Sub-Document call.class
CoreMutationResult
class
CoreStoreSemantics
class
CoreSubdocGetCommand
class
CoreSubdocGetResult
class
CoreSubdocMutateResult
-
Uses of Stability.Internal in com.couchbase.client.core.api.manager
Classes in com.couchbase.client.core.api.manager with annotations of type Stability.Internal Modifier and Type Class Description class
CoreBucketAndScope
interface
CoreBuildQueryIndexOptions
Allows customizing how deferred indexes are built.interface
CoreCreatePrimaryQueryIndexOptions
Allows customizing how a query primary index is created.interface
CoreCreateQueryIndexOptions
Allows customizing how a query index is created.interface
CoreCreateQueryIndexSharedOptions
Allows customizing how a query primary index is created.interface
CoreDropPrimaryQueryIndexOptions
Allows customizing how primary indexes are dropped.interface
CoreDropQueryIndexOptions
Allows customizing how query indexes are dropped.interface
CoreGetAllQueryIndexesOptions
Allows customizing how query indexes are loaded.class
CoreQueryIndex
Contains the properties of a Query Index.class
CoreScopeAndCollection
interface
CoreWatchQueryIndexesOptions
Allows customizing how the query indexes are watched. -
Uses of Stability.Internal in com.couchbase.client.core.api.manager.search
Classes in com.couchbase.client.core.api.manager.search with annotations of type Stability.Internal Modifier and Type Class Description class
ClassicCoreBaseSearchIndexManager
class
ClassicCoreClusterSearchIndexManager
class
ClassicCoreScopeSearchIndexManager
class
CoreSearchIndex
interface
CoreSearchIndexManager
The same interface is used for ScopeSearchIndexManager and SearchIndexManager, as there is no API difference between them at this level.Constructors in com.couchbase.client.core.api.manager.search with annotations of type Stability.Internal Constructor Description ClassicCoreBaseSearchIndexManager(Core core)
ClassicCoreClusterSearchIndexManager(Core core)
ClassicCoreScopeSearchIndexManager(Core core, CoreBucketAndScope scope)
-
Uses of Stability.Internal in com.couchbase.client.core.api.query
Classes in com.couchbase.client.core.api.query with annotations of type Stability.Internal Modifier and Type Class Description class
CoreQueryContext
class
CoreQueryMetaData
interface
CoreQueryOps
interface
CoreQueryOptions
class
CoreQueryOptionsTransactions
Transactions does some rather complex things with CoreQueryOptions.class
CoreQueryProfile
Query profiling information received from the server query engine.class
CoreQueryResult
The result of a N1QL query, including rows and associated metadata.class
CoreQueryScanConsistency
The possible values for scan consistency in a N1QL request.class
CoreQueryStatus
class
CoreQueryWarning
Represents a single warning returned from the query engine.class
CoreReactiveQueryResult
-
Uses of Stability.Internal in com.couchbase.client.core.api.search
Classes in com.couchbase.client.core.api.search with annotations of type Stability.Internal Modifier and Type Class Description class
ClassicCoreSearchOps
class
CoreHighlightStyle
class
CoreSearchKeyset
class
CoreSearchMetaData
interface
CoreSearchOps
interface
CoreSearchOptions
class
CoreSearchQuery
class
CoreSearchScanConsistency
Methods in com.couchbase.client.core.api.search with annotations of type Stability.Internal Modifier and Type Method Description static void
ClassicCoreSearchOps. injectOptions(String indexName, com.couchbase.client.core.deps.com.fasterxml.jackson.databind.node.ObjectNode queryJson, Duration timeout, CoreSearchOptions opts)
-
Uses of Stability.Internal in com.couchbase.client.core.api.search.facet
Classes in com.couchbase.client.core.api.search.facet with annotations of type Stability.Internal Modifier and Type Class Description class
CoreDateRange
class
CoreDateRangeFacet
class
CoreNumericRange
class
CoreNumericRangeFacet
class
CoreSearchFacet
class
CoreTermFacet
-
Uses of Stability.Internal in com.couchbase.client.core.api.search.queries
Classes in com.couchbase.client.core.api.search.queries with annotations of type Stability.Internal Modifier and Type Class Description class
CoreAbstractCompoundQuery
class
CoreBooleanFieldQuery
class
CoreBooleanQuery
class
CoreConjunctionQuery
class
CoreDateRangeQuery
class
CoreDisjunctionQuery
class
CoreDocIdQuery
class
CoreGeoBoundingBoxQuery
class
CoreGeoCoordinates
To create a new instance:class
CoreGeoDistanceQuery
class
CoreGeohash
interface
CoreGeoPoint
class
CoreGeoPolygonQuery
class
CoreMatchAllQuery
class
CoreMatchNoneQuery
class
CoreMatchOperator
class
CoreMatchPhraseQuery
class
CoreMatchQuery
class
CoreNumericRangeQuery
class
CorePhraseQuery
class
CorePrefixQuery
class
CoreQueryStringQuery
class
CoreRegexpQuery
class
CoreTermQuery
class
CoreTermRangeQuery
class
CoreWildcardQuery
-
Uses of Stability.Internal in com.couchbase.client.core.api.search.result
Classes in com.couchbase.client.core.api.search.result with annotations of type Stability.Internal Modifier and Type Class Description class
CoreAbstractSearchFacetResult
class
CoreDateRangeSearchFacetResult
class
CoreNumericRangeSearchFacetResult
class
CoreReactiveSearchResult
class
CoreSearchDateRange
A range (or bucket) for aCoreDateRangeSearchFacetResult
.interface
CoreSearchFacetResult
class
CoreSearchMetrics
class
CoreSearchNumericRange
class
CoreSearchResult
class
CoreSearchRowLocation
class
CoreSearchRowLocations
class
CoreSearchStatus
class
CoreSearchTermRange
class
CoreTermSearchFacetResult
-
Uses of Stability.Internal in com.couchbase.client.core.api.search.sort
Classes in com.couchbase.client.core.api.search.sort with annotations of type Stability.Internal Modifier and Type Class Description class
CoreSearchFieldMissing
class
CoreSearchFieldMode
class
CoreSearchFieldType
class
CoreSearchGeoDistanceUnits
class
CoreSearchSort
class
CoreSearchSortField
class
CoreSearchSortGeoDistance
class
CoreSearchSortId
class
CoreSearchSortScore
class
CoreSearchSortString
A sort tier specified as a string. -
Uses of Stability.Internal in com.couchbase.client.core.api.shared
Classes in com.couchbase.client.core.api.shared with annotations of type Stability.Internal Modifier and Type Class Description class
CoreMutationState
-
Uses of Stability.Internal in com.couchbase.client.core.callbacks
Classes in com.couchbase.client.core.callbacks with annotations of type Stability.Internal Modifier and Type Interface Description interface
BeforeSendRequestCallback
This callback is executed once an operation reaches the core and gets sent to a node. -
Uses of Stability.Internal in com.couchbase.client.core.classic
Classes in com.couchbase.client.core.classic with annotations of type Stability.Internal Modifier and Type Class Description class
ClassicExpiryHelper
class
ClassicHelper
-
Uses of Stability.Internal in com.couchbase.client.core.classic.kv
Classes in com.couchbase.client.core.classic.kv with annotations of type Stability.Internal Modifier and Type Class Description class
BinaryAccessor
class
ClassicCoreKvBinaryOps
class
ClassicCoreKvOps
-
Uses of Stability.Internal in com.couchbase.client.core.classic.manager
Classes in com.couchbase.client.core.classic.manager with annotations of type Stability.Internal Modifier and Type Class Description class
ClassicCoreCollectionManagerOps
-
Uses of Stability.Internal in com.couchbase.client.core.classic.query
Classes in com.couchbase.client.core.classic.query with annotations of type Stability.Internal Modifier and Type Class Description class
ClassicCoreQueryMetaData
class
ClassicCoreQueryMetrics
class
ClassicCoreQueryOps
class
ClassicCoreQueryResult
class
ClassicCoreReactiveQueryResult
class
EnhancedPreparedStatementStrategy
Server remembers query plan; client sends just the prepared statement name.class
LegacyPreparedStatementStrategy
Client remembers query plan and sends it on every request.class
PreparedStatementStrategy
Methods in com.couchbase.client.core.classic.query with annotations of type Stability.Internal Modifier and Type Method Description static com.couchbase.client.core.deps.com.fasterxml.jackson.databind.node.ObjectNode
ClassicCoreQueryOps. convertOptions(CoreQueryOptions opts)
static ClassicCoreQueryMetaData
ClassicCoreQueryMetaData. from(QueryChunkHeader header, QueryChunkTrailer trailer)
Constructors in com.couchbase.client.core.classic.query with annotations of type Stability.Internal Constructor Description ClassicCoreQueryMetaData(QueryChunkHeader header, QueryChunkTrailer trailer)
ClassicCoreReactiveQueryResult(QueryResponse response, NodeIdentifier lastDispatchedTo)
-
Uses of Stability.Internal in com.couchbase.client.core.cnc
Classes in com.couchbase.client.core.cnc with annotations of type Stability.Internal Modifier and Type Class Description class
CbTracing
static interface
LoggingEventConsumer.Logger
Generic logger interface.class
OrphanReporter
class
SimpleEventBus
This super simple event bus should be used in testing only to assert certain events got pushed through.class
TracingIdentifiers
Holds static tracing identifiers throughout the SDK.Methods in com.couchbase.client.core.cnc with annotations of type Stability.Internal Modifier and Type Method Description void
RequestSpan. requestContext(RequestContext requestContext)
Allows to set a request context to the request span.Constructors in com.couchbase.client.core.cnc with annotations of type Stability.Internal Constructor Description OrphanReporter(EventBus eventBus, OrphanReporterConfig config)
Creates a newOrphanReporter
. -
Uses of Stability.Internal in com.couchbase.client.core.cnc.events.transaction
Constructors in com.couchbase.client.core.cnc.events.transaction with annotations of type Stability.Internal Constructor Description TransactionLogEvent(long timestamp, long threadId, String threadName, String transactionId, String secondaryId, String fmt, Object[] values, Event.Severity level)
-
Uses of Stability.Internal in com.couchbase.client.core.cnc.metrics
Classes in com.couchbase.client.core.cnc.metrics with annotations of type Stability.Internal Modifier and Type Class Description class
NameAndTags
Helper class which consolidates names and tags for caching purposes. -
Uses of Stability.Internal in com.couchbase.client.core.config
Classes in com.couchbase.client.core.config with annotations of type Stability.Internal Modifier and Type Class Description class
ConfigRefreshFailure
interface
ConfigurationProvider
TheConfigurationProvider
is responsible for grabbing, converting and managing bucket and cluster configurations.class
KetamaRing<E>
A Ketama ring (or "continuum", if you prefer) with Couchbase-specific parameters defined by Couchbase SDK RFC 26 (Ketama Hashing)Methods in com.couchbase.client.core.config with annotations of type Stability.Internal Modifier and Type Method Description void
ClusterConfig. deleteBucketConfig(String bucketName)
void
ClusterConfig. deleteGlobalConfig()
void
ClusterConfig. setBucketConfig(BucketConfig config)
void
ClusterConfig. setGlobalConfig(GlobalConfig config)
-
Uses of Stability.Internal in com.couchbase.client.core.config.refresher
Classes in com.couchbase.client.core.config.refresher with annotations of type Stability.Internal Modifier and Type Class Description class
KeyValueBucketRefresher
TheKeyValueBucketRefresher
keeps configs up-to-date through the KV service. -
Uses of Stability.Internal in com.couchbase.client.core.diagnostics
Classes in com.couchbase.client.core.diagnostics with annotations of type Stability.Internal Modifier and Type Class Description class
HealthPinger
TheHealthPinger
allows to "ping" individual services with real operations for their health.class
InternalEndpointDiagnostics
class
WaitUntilReadyHelper
Helper class to perform the "wait until ready" logic.static class
WaitUntilReadyHelper.WaitUntilReadyState
Encapsulates the state of where a wait until ready flow is in.Methods in com.couchbase.client.core.diagnostics with annotations of type Stability.Internal Modifier and Type Method Description static Mono<PingResult>
HealthPinger. ping(Core core, Optional<Duration> timeout, RetryStrategy retryStrategy, Set<ServiceType> serviceTypes, Optional<String> reportId, Optional<String> bucketName)
Performs a service ping against all or (if given) the services provided.static CompletableFuture<Void>
WaitUntilReadyHelper. waitUntilReady(Core core, Set<ServiceType> serviceTypes, Duration timeout, ClusterState desiredState, Optional<String> bucketName)
Constructors in com.couchbase.client.core.diagnostics with annotations of type Stability.Internal Constructor Description DiagnosticsResult(Map<ServiceType,List<EndpointDiagnostics>> endpoints, String sdk, String id)
Creates the new diagnostics report.EndpointDiagnostics(ServiceType type, EndpointState state, CircuitBreaker.State circuitBreakerState, String local, String remote, Optional<String> namespace, Optional<Long> lastActivityUs, Optional<String> id, Optional<Throwable> lastConnectAttemptFailure)
EndpointPingReport(ServiceType type, String id, String local, String remote, PingState state, Optional<String> namespace, Duration latency, Optional<String> error)
PingResult(Map<ServiceType,List<EndpointPingReport>> endpoints, String sdk, String id)
Creates the new ping report. -
Uses of Stability.Internal in com.couchbase.client.core.endpoint
Classes in com.couchbase.client.core.endpoint with annotations of type Stability.Internal Modifier and Type Class Description class
MultiAddressNameResolverFactory
class
ProtostellarPool
Maintains a pool of ProtostellarEndpoints.Methods in com.couchbase.client.core.endpoint with annotations of type Stability.Internal Modifier and Type Method Description AuthenticationStatus
EndpointContext. authenticationStatus()
void
EndpointContext. authenticationStatus(AuthenticationStatus authenticationStatus)
void
BaseEndpoint. decrementOutstandingRequests()
Helper method to decrement outstanding requests, even if they haven't finished yet.InternalEndpointDiagnostics
Endpoint. internalDiagnostics()
long
BaseEndpoint. lastConnectedAt()
void
BaseEndpoint. markRequestCompletion()
Called from the event loop handlers to mark a request as being completed.void
BaseEndpoint. notifyChannelInactive()
This method is called from inside the channel to tell the endpoint hat it got inactive.CompletableFuture<Void>
ProtostellarEndpoint. waitUntilReady(Deadline deadline, boolean waitingForReady)
Waits until the ManagedChannel is in READY state. -
Uses of Stability.Internal in com.couchbase.client.core.endpoint.http
Classes in com.couchbase.client.core.endpoint.http with annotations of type Stability.Internal Modifier and Type Interface Description interface
CoreCommonOptions
class
CoreHttpClient
class
CoreHttpPath
The "path" component of a URI, with support for path parameters whose replacement values are automatically url-encoded.class
CoreHttpRequest
static class
CoreHttpRequest.Builder
Builder for dynamic HTTP requestsclass
CoreHttpResponse
-
Uses of Stability.Internal in com.couchbase.client.core.env
Classes in com.couchbase.client.core.env with annotations of type Stability.Internal Modifier and Type Class Description class
CouchbaseForkPoolThreadFactory
class
CouchbaseThreadFactory
static class
LoggerConfig.Defaults
static class
LoggingMeterConfig.Defaults
static class
OrphanReporterConfig.Defaults
class
OwnedSupplier<T>
A special supplier which allows the SDK to distinguish passed in suppliers vs.interface
RequestCallback
Marker interface for different callbacks in the request lifecycle.static class
SecurityConfig.Defaults
static class
SecurityConfig.InternalMethods
static class
ThresholdLoggingTracerConfig.Defaults
static class
ThresholdRequestTracerConfig.Defaults
Deprecated.Fields in com.couchbase.client.core.env with annotations of type Stability.Internal Modifier and Type Field Description static int
IoEnvironment. DEFAULT_EVENT_LOOP_THREAD_COUNT
Methods in com.couchbase.client.core.env with annotations of type Stability.Internal Modifier and Type Method Description SELF
CoreEnvironment.Builder. addRequestCallback(RequestCallback requestCallback)
Allows to configure callbacks across the lifetime of a request.default void
Authenticator. applyTlsProperties(com.couchbase.client.core.deps.io.netty.handler.ssl.SslContextBuilder sslContextBuilder)
The authenticator gets the chance to attach the client certificate to the ssl context if needed.default void
Authenticator. authHttpRequest(ServiceType serviceType, com.couchbase.client.core.deps.io.netty.handler.codec.http.HttpRequest request)
Allows to add authentication credentials to the http request for the given service.default void
Authenticator. authKeyValueConnection(EndpointContext endpointContext, com.couchbase.client.core.deps.io.netty.channel.ChannelPipeline pipeline)
Allows the authenticator to add KV handlers during connection bootstrap to perform authentication.IoEnvironment
IoEnvironment.Builder. build()
LoggerConfig.Builder
LoggerConfig.Builder. customLogger(LoggingEventConsumer.Logger customLogger)
Allows to specify a custom logger.LoggingEventConsumer.Logger
LoggerConfig. customLogger()
Returns a custom logger if configured for testing.static LoggerConfig.Builder
LoggerConfig. customLogger(LoggingEventConsumer.Logger customLogger)
Allows to specify a custom logger.Executor
CoreEnvironment. executor()
Returns the executor used to schedule non-reactive async tasks across the SDK.static ThresholdRequestTracerConfig.Builder
ThresholdRequestTracerConfig.Builder. fromNewBuilder(ThresholdLoggingTracerConfig.Builder newBuilder)
Deprecated.com.couchbase.client.core.deps.io.grpc.CallCredentials
Authenticator. protostellarCallCredentials()
com.couchbase.client.core.deps.io.grpc.CallCredentials
CertificateAuthenticator. protostellarCallCredentials()
List<RequestCallback>
CoreEnvironment. requestCallbacks()
default boolean
Authenticator. supportsNonTls()
If this authenticator supports non-encrypted connections.default boolean
Authenticator. supportsTls()
If this authenticator supports encrypted connections.ThresholdLoggingTracerConfig.Builder
ThresholdRequestTracerConfig.Builder. toNewBuillder()
Deprecated.Converts this deprecated builder into its non-deprecated version.Constructors in com.couchbase.client.core.env with annotations of type Stability.Internal Constructor Description OwnedSupplier(T value)
-
Uses of Stability.Internal in com.couchbase.client.core.error
Classes in com.couchbase.client.core.error with annotations of type Stability.Internal Modifier and Type Class Description class
BucketNotFoundDuringLoadException
Exception raised if during config load the bucket is not found (think: http 404).class
BucketNotReadyDuringLoadException
Exception raised if during config load the bucket is found, but not deemed ready yet.class
DefaultErrorUtil
class
HttpStatusCodeException
class
IndexesNotReadyException
class
RangeScanPartitionFailedException
This is an internal exception used to signal exceptional states in the range scan orchestrator.class
UnsupportedConfigMechanismException
Methods in com.couchbase.client.core.error with annotations of type Stability.Internal Modifier and Type Method Description byte[]
AnalyticsException. content()
static List<ErrorCodeAndMessage>
ErrorCodeAndMessage. from(byte[] content)
static List<ErrorCodeAndMessage>
ErrorCodeAndMessage. fromJsonArray(byte[] jsonArray)
boolean
PreparedStatementFailureException. retryable()
Constructors in com.couchbase.client.core.error with annotations of type Stability.Internal Constructor Description BucketExistsException(String bucketName, ErrorContext context)
CollectionExistsException(String collectionName, ErrorContext context)
InternalServerFailureException(Throwable cause, ErrorContext ctx)
RequestCanceledException(String message, CancellationReason reason, Throwable cause, CancellationErrorContext ctx)
ScopeExistsException(String scopeName, ErrorContext context)
ScopeNotFoundException(String scopeName, ErrorContext context)
-
Uses of Stability.Internal in com.couchbase.client.core.error.context
Methods in com.couchbase.client.core.error.context with annotations of type Stability.Internal Modifier and Type Method Description void
GenericErrorContext. put(String key, Object value)
-
Uses of Stability.Internal in com.couchbase.client.core.error.subdoc
Classes in com.couchbase.client.core.error.subdoc with annotations of type Stability.Internal Modifier and Type Class Description class
DocumentAlreadyAliveException
Sub-Document exception thrown when ReviveDocument has been used with a document that already exists -
Uses of Stability.Internal in com.couchbase.client.core.error.transaction
Classes in com.couchbase.client.core.error.transaction with annotations of type Stability.Internal Modifier and Type Class Description class
RetryTransactionException
Indicates that this transaction should be retried.class
TransactionOperationFailedException
This operation (such as a replace, get or insert) either failed or ambiguously succeeded.static class
TransactionOperationFailedException.FinalErrorToRaise
Methods in com.couchbase.client.core.error.transaction with annotations of type Stability.Internal Modifier and Type Method Description boolean
TransactionOperationFailedException. autoRollbackAttempt()
boolean
TransactionOperationFailedException. retryTransaction()
TransactionOperationFailedException.FinalErrorToRaise
TransactionOperationFailedException. toRaise()
-
Uses of Stability.Internal in com.couchbase.client.core.error.transaction.internal
Classes in com.couchbase.client.core.error.transaction.internal with annotations of type Stability.Internal Modifier and Type Class Description class
CoreTransactionCommitAmbiguousException
The transaction expired at the point of trying to commit it.class
CoreTransactionExpiredException
The transaction could not be fully completed in the configured timeout.class
CoreTransactionFailedException
The transaction failed to reach the Committed point.class
ForwardCompatibilityRequiresRetryException
class
RetryAtrCommitException
Indicates that committing the ATR entry should be retried.class
RetryOperationException
Indicates that this operation should be retried.class
TestFailAmbiguousException
Used only in testing: injects an error that will be handled as FAIL_AMBIGUOUS.class
TestFailHardException
Used only in testing: injects an error that will be handled as FAIL_HARD.class
TestFailOtherException
Used only in testing: injects an error that will be handled as FAIL_OTHER.class
TestFailTransientException
Used only in testing: injects a FAIL_TRANSIENT error.class
ThreadStopRequestedException
interface
WrappedTransactionOperationFailedException
TransactionOperationFailedException is raised as an opaque signal that something went wrong with a transaction operation. -
Uses of Stability.Internal in com.couchbase.client.core.io.netty
Classes in com.couchbase.client.core.io.netty with annotations of type Stability.Internal Modifier and Type Class Description class
SslHandlerFactory
This factory createsSslHandler
based on a given configuration.class
TracingUtils
Contains various utils to set attributes for tracing spans.Methods in com.couchbase.client.core.io.netty with annotations of type Stability.Internal Modifier and Type Method Description static List<String>
SslHandlerFactory. defaultCiphers(boolean nativeTlsEnabled)
Lists the default ciphers used for this platform.static boolean
SslHandlerFactory. opensslAvailable()
True if the native ssl transport is available, false otherwise. -
Uses of Stability.Internal in com.couchbase.client.core.io.netty.kv
Classes in com.couchbase.client.core.io.netty.kv with annotations of type Stability.Internal Modifier and Type Class Description class
ErrorMapLoadingHandler
This handler tries to load the KV Error Map in a best effort manner.class
FeatureNegotiatingHandler
TheFeatureNegotiatingHandler
is responsible for sending the KV "hello" command and to handshake enabled features on both sides.class
SaslListMechanismsHandler
TheSaslListMechanismsHandler
asks the server KV engine which SASL mechanism it supports.class
SelectBucketHandler
TheSelectBucketHandler
is responsible for, selecting the right bucket on this KV connection.class
ServerFeature
TheServerFeature
enum describes all the different negotiation modes between the server and the SDK.Methods in com.couchbase.client.core.io.netty.kv with annotations of type Stability.Internal Modifier and Type Method Description Set<SaslMechanism>
SaslAuthenticationHandler. allowedMechanisms()
Returns the allowed mechanisms for this handler, useful for testing assertions. -
Uses of Stability.Internal in com.couchbase.client.core.json
Classes in com.couchbase.client.core.json with annotations of type Stability.Internal Modifier and Type Class Description class
Mapper
Provides utilities for encoding and decoding JSON data. -
Uses of Stability.Internal in com.couchbase.client.core.kv
Classes in com.couchbase.client.core.kv with annotations of type Stability.Internal Modifier and Type Interface Description interface
CoreRangeScan
Performs a KV range scan to scan between twoCoreScanTerms
.interface
CoreSamplingScan
Performs a KV range scan using random sampling.interface
CoreScanOptions
Allows to customize the various range and sampling scan options.class
CoreScanTerm
A singleCoreScanTerm
identifying either the point to scan from or to scan to.interface
CoreScanType
Either RangeScan or SampleScanclass
RangeScanOrchestrator
Main entry point from higher level languages to perform KV range scans. -
Uses of Stability.Internal in com.couchbase.client.core.manager
Classes in com.couchbase.client.core.manager with annotations of type Stability.Internal Modifier and Type Class Description class
CoreAnalyticsLinkManager
class
CoreBucketManager
interface
CoreCollectionManager
class
CoreCollectionQueryIndexManager
class
CoreEventingFunctionManager
Encapsulates common functionality around the eventing management APIs.class
CoreQueryIndexManager
class
CoreQueryType
class
CoreViewIndexManager
-
Uses of Stability.Internal in com.couchbase.client.core.msg
Classes in com.couchbase.client.core.msg with annotations of type Stability.Internal Modifier and Type Class Description class
RequestTarget
Methods in com.couchbase.client.core.msg with annotations of type Stability.Internal Modifier and Type Method Description RequestContext
RequestContext. clientContext(Map<String,Object> clientContext)
Allows to set a custom payload for this request.RequestContext
RequestContext. dispatchLatency(long dispatchLatency)
Allows to set the dispatch duration of the request.RequestContext
RequestContext. encodeLatency(long encodeLatency)
RequestContext
RequestContext. incrementRetryAttempts(Duration lastRetryDuration, RetryReason reason)
RequestContext
RequestContext. lastChannelId(String lastChannelId)
RequestContext
RequestContext. lastDispatchedFrom(HostAndPort lastDispatchedFrom)
RequestContext
RequestContext. lastDispatchedTo(HostAndPort lastDispatchedTo)
NodeIdentifier
RequestContext. lastDispatchedToNode()
RequestContext
RequestContext. lastDispatchedToNode(NodeIdentifier lastDispatchedToNode)
RequestContext
RequestContext. logicallyComplete()
RequestContext
RequestContext. logicallyComplete(Throwable err)
Signals that this request is completed fully, including streaming sections or logical sub-requests also being completed (i.e.RequestContext
RequestContext. serverLatency(long serverLatency)
Constructors in com.couchbase.client.core.msg with annotations of type Stability.Internal Constructor Description RequestContext(CoreContext ctx, Request<? extends Response> request)
RequestContext(Core core, long contextId, CoreEnvironment environment, Authenticator authenticator, Request<? extends Response> request)
-
Uses of Stability.Internal in com.couchbase.client.core.msg.kv
Classes in com.couchbase.client.core.msg.kv with annotations of type Stability.Internal Modifier and Type Class Description class
GetResponse
Represents the response of aGetRequest
.class
MutationTokenAggregator
Helper class that language-specific clients may use to implementMutationState
.class
RangeScanCancelRequest
class
RangeScanCancelResponse
class
SubDocumentField
Methods in com.couchbase.client.core.msg.kv with annotations of type Stability.Internal Modifier and Type Method Description byte
DurabilityLevel. code()
static DurabilityLevel
DurabilityLevel. decodeFromManagementApi(String input)
Decodes the string representation of the durability level from the management API into an enum.String
DurabilityLevel. encodeForManagementApi()
Encodes theDurabilityLevel
so that the management API understands it. -
Uses of Stability.Internal in com.couchbase.client.core.msg.manager
Methods in com.couchbase.client.core.msg.manager with annotations of type Stability.Internal Modifier and Type Method Description void
BucketConfigStreamingResponse. completeStream()
void
BucketConfigStreamingResponse. failStream(Throwable e)
void
BucketConfigStreamingResponse. pushConfig(String config)
-
Uses of Stability.Internal in com.couchbase.client.core.msg.query
Classes in com.couchbase.client.core.msg.query with annotations of type Stability.Internal Modifier and Type Class Description class
PreparedStatement
Prepared statement cache entry.Methods in com.couchbase.client.core.msg.query with annotations of type Stability.Internal Modifier and Type Method Description QueryRequest
QueryRequest. toExecuteRequest(String preparedStatementName, String encodedPlan, RequestTracer requestTracer)
Returns a copy of this request tailored to execute a prepared statement.QueryRequest
QueryRequest. toPrepareRequest(boolean autoExecute, RequestTracer requestTracer)
Returns a new request that creates a prepared statement using this request as a template. -
Uses of Stability.Internal in com.couchbase.client.core.node
Classes in com.couchbase.client.core.node with annotations of type Stability.Internal Modifier and Type Interface Description interface
MemcachedHashingStrategy
This interface defines different hashing strategies used for ketama hashing in memcached buckets.Methods in com.couchbase.client.core.node with annotations of type Stability.Internal Modifier and Type Method Description Stream<InternalEndpointDiagnostics>
Node. internalDiagnostics()
-
Uses of Stability.Internal in com.couchbase.client.core.protostellar
Classes in com.couchbase.client.core.protostellar with annotations of type Stability.Internal Modifier and Type Class Description class
CoreProtostellarErrorHandlingUtil
class
CoreProtostellarUtil
class
ProtostellarCollectionManagerRequest<TGrpcRequest>
class
ProtostellarContext
class
ProtostellarKeyValueRequest<TGrpcRequest>
class
ProtostellarRequest<TGrpcRequest>
Holds onto a GRPC request, along with pertaining mutable and immutable state bound to the request's lifetime.class
ProtostellarStatsCollector
Constructors in com.couchbase.client.core.protostellar with annotations of type Stability.Internal Constructor Description ProtostellarBaseRequest(CoreProtostellar core, ProtostellarRequest<?> request)
-
Uses of Stability.Internal in com.couchbase.client.core.protostellar.kv
Classes in com.couchbase.client.core.protostellar.kv with annotations of type Stability.Internal Modifier and Type Class Description class
CoreProtostellarKeyValueRequests
For creating Protostellar GRPC KV requests.class
CoreProtostellarKeyValueResponses
For converting Protostellar GRPC KV responses.class
CoreProtoStellarKvBinaryRequests
class
CoreProtostellarKvBinaryResponses
For converting Protostellar GRPC KV responses.class
ProtostellarCoreKvBinaryOps
class
ProtostellarCoreKvOps
-
Uses of Stability.Internal in com.couchbase.client.core.protostellar.manager
Classes in com.couchbase.client.core.protostellar.manager with annotations of type Stability.Internal Modifier and Type Class Description class
CoreProtostellarCollectionManagerRequests
For creating Protostellar GRPC requests.class
CoreProtostellarCollectionManagerResponses
For converting Protostellar GRPC responses.class
ProtostellarCoreCollectionManagerOps
-
Uses of Stability.Internal in com.couchbase.client.core.protostellar.query
Classes in com.couchbase.client.core.protostellar.query with annotations of type Stability.Internal Modifier and Type Class Description class
ProtostellarCoreQueryMetaData
class
ProtostellarCoreQueryMetrics
class
ProtostellarCoreQueryOps
class
ProtostellarCoreReactiveQueryResult
-
Uses of Stability.Internal in com.couchbase.client.core.protostellar.search
Classes in com.couchbase.client.core.protostellar.search with annotations of type Stability.Internal Modifier and Type Class Description class
ProtostellarCoreSearchOps
-
Uses of Stability.Internal in com.couchbase.client.core.retry
Classes in com.couchbase.client.core.retry with annotations of type Stability.Internal Modifier and Type Class Description class
AuthErrorDecider
class
FailFastRetryStrategy
An internal strategy to fail fast any request that goes through it.class
ProtostellarRequestBehaviour
Determines what to do with a request.class
RetryOrchestrator
TheRetryOrchestrator
is responsible for checking if a request is eligible for retry and if so dispatch it properly and update state.class
RetryOrchestratorProtostellar
Methods in com.couchbase.client.core.retry with annotations of type Stability.Internal Modifier and Type Method Description static Duration
RetryOrchestrator. capDuration(Duration uncappedDuration, Request<? extends Response> request)
Calculates the potentially capped retry duration so we do not schedule a longer retry than the actual total timeout.static Duration
RetryOrchestratorProtostellar. capDuration(Duration uncappedDuration, ProtostellarRequest<?> request)
static Duration
RetryOrchestrator. controlledBackoff(int retryAttempt)
Helper method for a simple, bounded controlled backoff for the "always retry" handler so that it doesn't spam quickly all the time. -
Uses of Stability.Internal in com.couchbase.client.core.service
Methods in com.couchbase.client.core.service with annotations of type Stability.Internal Modifier and Type Method Description Stream<InternalEndpointDiagnostics>
Service. internalDiagnostics()
-
Uses of Stability.Internal in com.couchbase.client.core.service.kv
Classes in com.couchbase.client.core.service.kv with annotations of type Stability.Internal Modifier and Type Class Description class
ReplicaHelper
-
Uses of Stability.Internal in com.couchbase.client.core.transaction
Classes in com.couchbase.client.core.transaction with annotations of type Stability.Internal Modifier and Type Class Description class
AccessorUtil
class
CoreTransactionAttemptContext
Provides methods to allow an application's transaction logic to read, mutate, insert and delete documents, as well as commit or rollback the transaction.class
CoreTransactionContext
Stores some context related to a transaction.class
CoreTransactionGetResult
Represents a value fetched from Couchbase, along with additional transactional metadata.class
CoreTransactionKeyspace
A keyspace represents a triple of bucket, scope and collection.class
CoreTransactionResult
class
CoreTransactionsReactive
Methods in com.couchbase.client.core.transaction with annotations of type Stability.Internal Modifier and Type Method Description static CoreTransactionGetResult
CoreTransactionGetResult. createFrom(CollectionIdentifier collection, String documentId, SubdocGetResponse doc)
static CoreTransactionGetResult
CoreTransactionGetResult. createFrom(CoreTransactionGetResult doc, byte[] content)
Constructors in com.couchbase.client.core.transaction with annotations of type Stability.Internal Constructor Description CoreTransactionGetResult(String id, byte[] content, long cas, CollectionIdentifier collection, TransactionLinks links, Optional<DocumentMetadata> documentMetadata, Optional<com.couchbase.client.core.deps.com.fasterxml.jackson.databind.JsonNode> txnMeta, Optional<String> crc32OfGet)
-
Uses of Stability.Internal in com.couchbase.client.core.transaction.atr
Classes in com.couchbase.client.core.transaction.atr with annotations of type Stability.Internal Modifier and Type Class Description class
ActiveTransactionRecordIds
-
Uses of Stability.Internal in com.couchbase.client.core.transaction.cleanup
Classes in com.couchbase.client.core.transaction.cleanup with annotations of type Stability.Internal Modifier and Type Class Description class
ActiveTransactionRecordStats
Simple data class, so all fields are public.class
CleanerFactory
Used for testing/mocking.class
CleanerHooks
class
CleanerMockFactory
Used for testing/mocking.class
CleanupRequest
class
ClientRecord
Represents the ClientRecord doc, a single document that contains an entry for every client (app) current participating in the cleanup of 'lost' transactions.class
ClientRecordDetails
Utility class to store the result of a client checking/updating the Client Record doc.class
ClientRecordFactory
Used for testing/mocking.class
ClientRecordFactoryMock
Used for testing/mocking.class
CoreTransactionsCleanup
Owns cleanup threads.class
LostCleanupDistributed
Runs the algorithm to find 'lost' transactions, distributing the work between clients.class
TransactionsCleaner
Handles cleaning up expired/lost transactions. -
Uses of Stability.Internal in com.couchbase.client.core.transaction.components
Classes in com.couchbase.client.core.transaction.components with annotations of type Stability.Internal Modifier and Type Class Description class
ActiveTransactionRecord
static class
ActiveTransactionRecord.ParsedHLC
class
ActiveTransactionRecordEntry
class
ActiveTransactionRecords
class
ActiveTransactionRecordUtil
class
CasMode
Metadata related to the CAS.class
DocRecord
class
DocumentGetter
Responsible for doing transaction-aware get()s.class
DocumentMetadata
Stores some $document metadata from when the document is fetchedclass
DurabilityLevelUtil
class
OperationTypes
class
TransactionLinks
Stores the transaction links stored on each document in a transactionMethods in com.couchbase.client.core.transaction.components with annotations of type Stability.Internal Modifier and Type Method Description Optional<String>
TransactionLinks. stagedContent()
-
Uses of Stability.Internal in com.couchbase.client.core.transaction.config
Classes in com.couchbase.client.core.transaction.config with annotations of type Stability.Internal Modifier and Type Class Description class
CoreMergedTransactionConfig
MergesCoreTransactionOptions
andCoreTransactionsConfig
.class
CoreSingleQueryTransactionOptions
class
CoreTransactionOptions
Tunables for an individual transaction.class
CoreTransactionsCleanupConfig
class
CoreTransactionsConfig
Methods in com.couchbase.client.core.transaction.config with annotations of type Stability.Internal Modifier and Type Method Description static CoreTransactionsCleanupConfig
CoreTransactionsCleanupConfig. createDefault()
static CoreTransactionsConfig
CoreTransactionsConfig. createDefault()
-
Uses of Stability.Internal in com.couchbase.client.core.transaction.context
Classes in com.couchbase.client.core.transaction.context with annotations of type Stability.Internal Modifier and Type Class Description class
CoreTransactionsContext
Holds transactions state that has the same lifetime as a Core.class
CoreTransactionsCounters
-
Uses of Stability.Internal in com.couchbase.client.core.transaction.error.internal
Classes in com.couchbase.client.core.transaction.error.internal with annotations of type Stability.Internal Modifier and Type Class Description class
ErrorClass
-
Uses of Stability.Internal in com.couchbase.client.core.transaction.forwards
Classes in com.couchbase.client.core.transaction.forwards with annotations of type Stability.Internal Modifier and Type Class Description class
Extension
All protocol extensions known about by this implementation.class
ForwardCompatibility
A mechanism to help ensure that older clients can be prevented from interacting with transactions created by future clients that they do not know how to process.class
ForwardCompatibilityStage
Points in the protocol where forward compatibility can be checked.class
Supported
Defines what is support by this implementation (extensions and protocol version). -
Uses of Stability.Internal in com.couchbase.client.core.transaction.log
Classes in com.couchbase.client.core.transaction.log with annotations of type Stability.Internal Modifier and Type Class Description class
CoreTransactionLogger
A logger optimized for logging transactions-specific info.class
SimpleEventBusLogger
Simple wrapper around logging to the Couchbase event bus. -
Uses of Stability.Internal in com.couchbase.client.core.transaction.support
Classes in com.couchbase.client.core.transaction.support with annotations of type Stability.Internal Modifier and Type Class Description class
AttemptState
The possible states for a transaction attempt.class
OptionsUtil
class
SpanWrapper
Wraps a RequestSpan, with the value-add that it automatically records how long the operation took for transaction logging.class
SpanWrapperUtil
class
StagedMutation
class
StagedMutationType
class
TransactionAttemptContextFactory
class
TransactionFields
-
Uses of Stability.Internal in com.couchbase.client.core.transaction.threadlocal
Classes in com.couchbase.client.core.transaction.threadlocal with annotations of type Stability.Internal Modifier and Type Class Description class
TransactionMarker
Used to indicate that we are inside a transaction, and placed in ThreadLocalStorage (or reactive context).class
TransactionMarkerOwner
Used to manage ThreadLocalStorage (or reactive context) of TransactionMarker. -
Uses of Stability.Internal in com.couchbase.client.core.transaction.util
Classes in com.couchbase.client.core.transaction.util with annotations of type Stability.Internal Modifier and Type Class Description class
CoreTransactionAttemptContextHooks
Can be used for testing transactions, but is for internal use only.class
CoreTransactionsSchedulers
Mainly to aid debugging, transactions use their own pool of schedulers.class
DebugUtil
class
LockTokens
class
LogDeferDocId
class
LogDeferThrowable
class
MeteringUnits
Tracks read and write units used.static class
MeteringUnits.MeteringUnitsBuilder
class
MonoBridge<T>
Protects against concurrent op cancellation.class
QueryUtil
class
ReactiveLock
A mutex pessimistic lock, compatible with reactive.class
ReactiveWaitGroup
Provides locking functionality in line with Go's WaitGroups, in a reactive compatible way.class
TestTransactionAttemptContextFactory
Can be used for testing transactions, but is for internal use only.class
TransactionKVHandler
Transactions does a lot of KV work from core-io.interface
TriFunction<T,U,V,R>
-
Uses of Stability.Internal in com.couchbase.client.core.util
Classes in com.couchbase.client.core.util with annotations of type Stability.Internal Modifier and Type Class Description class
BucketConfigUtil
Defines helpful routines for working with bucket configs.class
CbAnnotations
class
CbCollections
class
CbObjects
class
CbPreconditions
class
CbStrings
class
CbThrowables
static class
ConnectionString.PortType
class
ConnectionStringUtil
Contains various helper methods when dealing with the connection string.class
ConsistencyUtil
Helper routines for tests to wait for all nodes to have a consistent view of a resource.class
CoreAsyncUtils
class
CoreIdGenerator
class
CouchbaseBlockHoundIntegration
Integrates the Couchbase infrastructure withBlockHound
.class
Deadline
class
DnsSrv
The default implementation for performing DNS SRV lookups.class
EnumLookupTable<E extends Enum<E>>
Provides efficient lookup for enums whose values are associated with small integers.class
NanoTimestamp
class
NetworkAddress
A convenient wrapper class around network primitives in Java.class
ProtostellarUtil
class
UrlQueryStringBuilder
Methods in com.couchbase.client.core.util with annotations of type Stability.Internal Modifier and Type Method Description static NetworkAddress
NetworkAddress. create(String input)
Creates a newNetworkAddress
from either a hostname or ip address literal.static List<String>
ConnectionStringUtil. fromDnsSrvOrThrowIfTlsRequired(String serviceName, boolean secure)
String
NetworkAddress. hostname()
Returns the hostname for this network address.ConnectionString
ConnectionString. withParams(Map<String,String> params)
ConnectionString
ConnectionString. withScheme(ConnectionString.Scheme scheme)
-