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 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.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.void
Core. openBucket(String name)
Attempts to open a bucket and fails theMono
if there is a persistent error as the reason.ValueRecorder
Core. responseMetric(Request<?> request)
<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()
-
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. -
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.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 Interface Description interface
ConfigurationProvider
TheConfigurationProvider
is responsible for grabbing, converting and managing bucket and cluster configurations.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
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, 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
Methods in com.couchbase.client.core.endpoint with annotations of type Stability.Internal Modifier and Type Method Description void
BaseEndpoint. decrementOutstandingRequests()
Helper method to decrement outstanding requests, even if they haven't finished yet.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. -
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 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.static ThresholdRequestTracerConfig.Builder
ThresholdRequestTracerConfig.Builder. fromNewBuilder(ThresholdLoggingTracerConfig.Builder newBuilder)
Deprecated.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
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()
-
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.manager
Classes in com.couchbase.client.core.manager with annotations of type Stability.Internal Modifier and Type Class Description class
CoreAnalyticsLinkManager
class
CoreBucketManager
class
CoreCollectionManager
class
CoreEventingFunctionManager
Encapsulates common functionality around the eventing management APIs.class
CoreQueryIndexManager
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()
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)
Creates a newRequestContext
. -
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
MutationTokenAggregator
Helper class that language-specific clients may use to implementMutationState
.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
CoreQueryAccessor
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
PreparedStatement
Prepared statement cache entry.class
PreparedStatementStrategy
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. -
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
FailFastRetryStrategy
An internal strategy to fail fast any request that goes through it.class
RetryOrchestrator
TheRetryOrchestrator
is responsible for checking if a request is eligible for retry and if so dispatch it properly and update state.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. -
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.static class
CoreTransactionAttemptContext.BufferedQueryResponse
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.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
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
CouchbaseBlockHoundIntegration
Integrates the Couchbase infrastructure withBlockHound
.class
DnsSrv
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
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.String
NetworkAddress. hostname()
Returns the hostname for this network address.
-