- absoluteTimeout() - Method in class com.couchbase.client.core.msg.BaseRequest
-
- absoluteTimeout() - Method in interface com.couchbase.client.core.msg.Request
-
The absolute timestamp when the request should time out.
- AbstractBucketConfig - Class in com.couchbase.client.core.config
-
- AbstractBucketConfig(String, String, BucketNodeLocator, String, String, List<NodeInfo>, List<PortInfo>, List<BucketCapabilities>, String, Map<String, Set<ClusterCapabilities>>) - Constructor for class com.couchbase.client.core.config.AbstractBucketConfig
-
- AbstractContext - Class in com.couchbase.client.core.cnc
-
Common parent method for all contexts.
- AbstractContext() - Constructor for class com.couchbase.client.core.cnc.AbstractContext
-
- AbstractEvent - Class in com.couchbase.client.core.cnc
-
This
Event
implementation can be used as a base event to inherit from.
- AbstractEvent(Event.Severity, Event.Category, Duration, Context) - Constructor for class com.couchbase.client.core.cnc.AbstractEvent
-
- AbstractEvent(Event.Severity, String, Duration, Context) - Constructor for class com.couchbase.client.core.cnc.AbstractEvent
-
Creates a new abstract event.
- AbstractPooledEndpointServiceConfig - Class in com.couchbase.client.core.service
-
- AbstractPooledEndpointServiceConfig.Builder<SELF extends AbstractPooledEndpointServiceConfig.Builder<?>> - Class in com.couchbase.client.core.service
-
- AbstractRetry<T,S> - Class in com.couchbase.client.core.retry.reactor
-
- accept(Event) - Method in class com.couchbase.client.core.cnc.LoggingEventConsumer
-
- active() - Method in class com.couchbase.client.core.config.Partition
-
- active() - Method in class com.couchbase.client.core.msg.kv.ObserveViaCasRequest
-
- active() - Method in class com.couchbase.client.core.msg.kv.ObserveViaCasResponse
-
- active() - Method in class com.couchbase.client.core.msg.kv.ObserveViaSeqnoRequest
-
- active() - Method in class com.couchbase.client.core.msg.kv.ObserveViaSeqnoResponse
-
- add(ByteBuf) - Method in class com.couchbase.client.core.json.stream.CopyingStreamWindow
-
- add(ByteBuf) - Method in interface com.couchbase.client.core.json.stream.StreamWindow
-
Appends the given buffer to the end of the stream.
- add(String, String) - Method in class com.couchbase.client.core.util.UrlQueryStringBuilder
-
- add(String, int) - Method in class com.couchbase.client.core.util.UrlQueryStringBuilder
-
- add(String, long) - Method in class com.couchbase.client.core.util.UrlQueryStringBuilder
-
- add(String, boolean) - Method in class com.couchbase.client.core.util.UrlQueryStringBuilder
-
- addEvent(String, Instant) - Method in interface com.couchbase.client.core.cnc.RequestSpan
-
Sets an event on the span, which is translated to the corresponding implementation specific event.
- addEvent(String, Instant) - Method in class com.couchbase.client.core.cnc.tracing.NoopRequestSpan
-
- addEvent(String, Instant) - Method in class com.couchbase.client.core.cnc.tracing.ThresholdRequestSpan
-
- address() - Method in class com.couchbase.client.core.env.SeedNode
-
The ip address or hostname of this seed node.
- address() - Method in class com.couchbase.client.core.msg.manager.BucketConfigStreamingResponse
-
- address() - Method in class com.couchbase.client.core.node.NodeIdentifier
-
- addService(ServiceType, int, Optional<String>) - Method in class com.couchbase.client.core.node.Node
-
- after() - Method in class com.couchbase.client.core.io.netty.kv.ErrorMap.RetrySpecification
-
- AggregateErrorContext - Class in com.couchbase.client.core.error.context
-
An error context which combines more than one context to dump.
- AggregateErrorContext(List<ErrorContext>) - Constructor for class com.couchbase.client.core.error.context.AggregateErrorContext
-
- AggregatingCounter - Class in com.couchbase.client.core.cnc.metrics
-
At the moment this is a NOOP implementation because we do not perform any aggregations
on the counters.
- AggregatingCounter() - Constructor for class com.couchbase.client.core.cnc.metrics.AggregatingCounter
-
- AggregatingMeter - Class in com.couchbase.client.core.cnc.metrics
-
The default metrics implementation which aggregates latency information and emits it at a regular interval.
- AggregatingMeterConfig - Class in com.couchbase.client.core.env
-
- aggregatingMeterConfig(AggregatingMeterConfig.Builder) - Method in class com.couchbase.client.core.env.CoreEnvironment.Builder
-
- aggregatingMeterConfig() - Method in class com.couchbase.client.core.env.CoreEnvironment.Builder
-
- AggregatingMeterConfig.Builder - Class in com.couchbase.client.core.env
-
- AggregatingValueRecorder - Class in com.couchbase.client.core.cnc.metrics
-
Aggregates value information in a histogram.
- AggregatingValueRecorder(String, Map<String, String>) - Constructor for class com.couchbase.client.core.cnc.metrics.AggregatingValueRecorder
-
- allBut(Class<? extends Throwable>...) - Static method in interface com.couchbase.client.core.retry.reactor.Retry
-
Returns a retry function that retries errors resulting from all exceptions except
the specified non-retriable exceptions, once.
- allNodeAddresses() - Method in class com.couchbase.client.core.config.ClusterConfig
-
- allowedMechanisms() - Method in class com.couchbase.client.core.cnc.events.io.SaslMechanismsSelectedEvent
-
- allowedMechanisms() - Method in class com.couchbase.client.core.io.netty.kv.SaslAuthenticationHandler
-
Returns the allowed mechanisms for this handler, useful for testing assertions.
- allowedSaslMechanisms(Set<SaslMechanism>) - Method in class com.couchbase.client.core.env.PasswordAuthenticator.Builder
-
Allows to set a list of allowed SASL mechanisms for the NON-TLS connections.
- allowsRequest() - Method in interface com.couchbase.client.core.endpoint.CircuitBreaker
-
Returns true if requests are allowed to go through and be tracked.
- allowsRequest() - Method in class com.couchbase.client.core.endpoint.NoopCircuitBreaker
-
- AlreadyShutdownException - Exception in com.couchbase.client.core.error
-
Thrown if a resource is already permanently terminated and tried to be used afterwards.
- AlreadyShutdownException() - Constructor for exception com.couchbase.client.core.error.AlreadyShutdownException
-
- AlternateAddress - Class in com.couchbase.client.core.config
-
- AlternateAddress(String, Map<String, Integer>) - Constructor for class com.couchbase.client.core.config.AlternateAddress
-
- alternateAddress() - Method in class com.couchbase.client.core.CoreContext
-
Returns the alternate address identifier, if present.
- alternateAddress(Optional<String>) - Method in class com.couchbase.client.core.CoreContext
-
Sets the alternate address on this context.
- alternateAddress() - Method in class com.couchbase.client.core.node.NodeContext
-
- alternateAddresses() - Method in class com.couchbase.client.core.config.DefaultConfigurationProvider.AlternateAddressHolder
-
- alternateAddresses() - Method in class com.couchbase.client.core.config.NodeInfo
-
- alternateAddresses() - Method in class com.couchbase.client.core.config.PortInfo
-
- alternateRequestEnabled() - Method in class com.couchbase.client.core.io.netty.kv.KeyValueChannelContext
-
- AmbiguousTimeoutException - Exception in com.couchbase.client.core.error
-
This is a special case of the timeout exception, signaling that the timeout happened with an ambiguous cause.
- AmbiguousTimeoutException(String, CancellationErrorContext) - Constructor for exception com.couchbase.client.core.error.AmbiguousTimeoutException
-
- AnalyticsChunkHeader - Class in com.couchbase.client.core.msg.analytics
-
- AnalyticsChunkHeader(String, Optional<String>, Optional<byte[]>) - Constructor for class com.couchbase.client.core.msg.analytics.AnalyticsChunkHeader
-
- AnalyticsChunkResponseParser - Class in com.couchbase.client.core.io.netty.analytics
-
- AnalyticsChunkResponseParser() - Constructor for class com.couchbase.client.core.io.netty.analytics.AnalyticsChunkResponseParser
-
- AnalyticsChunkRow - Class in com.couchbase.client.core.msg.analytics
-
- AnalyticsChunkRow(byte[]) - Constructor for class com.couchbase.client.core.msg.analytics.AnalyticsChunkRow
-
- AnalyticsChunkTrailer - Class in com.couchbase.client.core.msg.analytics
-
- AnalyticsChunkTrailer(String, byte[], Optional<byte[]>, Optional<byte[]>) - Constructor for class com.couchbase.client.core.msg.analytics.AnalyticsChunkTrailer
-
- analyticsCircuitBreakerConfig(CircuitBreakerConfig.Builder) - Static method in class com.couchbase.client.core.env.IoConfig
-
- analyticsCircuitBreakerConfig() - Method in class com.couchbase.client.core.env.IoConfig
-
- analyticsCircuitBreakerConfig(CircuitBreakerConfig.Builder) - Method in class com.couchbase.client.core.env.IoConfig.Builder
-
- analyticsCircuitBreakerConfig() - Method in class com.couchbase.client.core.env.IoConfig.Builder
-
- AnalyticsEndpoint - Class in com.couchbase.client.core.endpoint
-
- AnalyticsEndpoint(ServiceContext, String, int) - Constructor for class com.couchbase.client.core.endpoint.AnalyticsEndpoint
-
- AnalyticsEndpoint.AnalyticsPipelineInitializer - Class in com.couchbase.client.core.endpoint
-
- AnalyticsErrorContext - Class in com.couchbase.client.core.error.context
-
- AnalyticsErrorContext(RequestContext, List<ErrorCodeAndMessage>) - Constructor for class com.couchbase.client.core.error.context.AnalyticsErrorContext
-
- analyticsEventLoopGroup(EventLoopGroup) - Static method in class com.couchbase.client.core.env.IoEnvironment
-
Allows to specify a custom event loop group (I/O event loop thread pool) for the analytics service.
- analyticsEventLoopGroup() - Method in class com.couchbase.client.core.env.IoEnvironment
-
Returns the EventLoopGroup
to be used for analytics traffic.
- analyticsEventLoopGroup(EventLoopGroup) - Method in class com.couchbase.client.core.env.IoEnvironment.Builder
-
Allows to specify a custom event loop group (I/O event loop thread pool) for the analytics service.
- AnalyticsException - Exception in com.couchbase.client.core.error
-
There was a problem fulfilling the analytics request.
- AnalyticsException(AnalyticsException) - Constructor for exception com.couchbase.client.core.error.AnalyticsException
-
- AnalyticsException(byte[]) - Constructor for exception com.couchbase.client.core.error.AnalyticsException
-
- AnalyticsException(byte[], Throwable) - Constructor for exception com.couchbase.client.core.error.AnalyticsException
-
- AnalyticsHandlerSwitcher - Class in com.couchbase.client.core.io.netty.analytics
-
- AnalyticsHandlerSwitcher(BaseEndpoint, EndpointContext) - Constructor for class com.couchbase.client.core.io.netty.analytics.AnalyticsHandlerSwitcher
-
- AnalyticsMessageHandler - Class in com.couchbase.client.core.io.netty.analytics
-
- AnalyticsMessageHandler(BaseEndpoint, EndpointContext) - Constructor for class com.couchbase.client.core.io.netty.analytics.AnalyticsMessageHandler
-
- AnalyticsPingRequest - Class in com.couchbase.client.core.msg.analytics
-
- AnalyticsPingRequest(Duration, CoreContext, RetryStrategy, NodeIdentifier) - Constructor for class com.couchbase.client.core.msg.analytics.AnalyticsPingRequest
-
- AnalyticsPingResponse - Class in com.couchbase.client.core.msg.analytics
-
- AnalyticsRequest - Class in com.couchbase.client.core.msg.analytics
-
- AnalyticsRequest(Duration, CoreContext, RetryStrategy, Authenticator, byte[], int, boolean, String, String, RequestSpan) - Constructor for class com.couchbase.client.core.msg.analytics.AnalyticsRequest
-
- AnalyticsResponse - Class in com.couchbase.client.core.msg.analytics
-
- AnalyticsService - Class in com.couchbase.client.core.service
-
- AnalyticsService(AnalyticsServiceConfig, CoreContext, String, int) - Constructor for class com.couchbase.client.core.service.AnalyticsService
-
- AnalyticsServiceConfig - Class in com.couchbase.client.core.service
-
- AnalyticsServiceConfig.Builder - Class in com.couchbase.client.core.service
-
- analyticsThreshold(Duration) - Method in class com.couchbase.client.core.cnc.tracing.ThresholdRequestTracer.Builder
-
Allows to customize the analyticsThreshold.
- analyticsThreshold(Duration) - Static method in class com.couchbase.client.core.env.ThresholdRequestTracerConfig
-
Allows to customize the analyticsThreshold.
- analyticsThreshold() - Method in class com.couchbase.client.core.env.ThresholdRequestTracerConfig
-
- analyticsThreshold(Duration) - Method in class com.couchbase.client.core.env.ThresholdRequestTracerConfig.Builder
-
Allows to customize the analyticsThreshold.
- analyticsTimeout(Duration) - Static method in class com.couchbase.client.core.env.TimeoutConfig
-
- analyticsTimeout() - Method in class com.couchbase.client.core.env.TimeoutConfig
-
- analyticsTimeout(Duration) - Method in class com.couchbase.client.core.env.TimeoutConfig.Builder
-
Sets the timeout to use for analytics operations.
- any() - Static method in interface com.couchbase.client.core.retry.reactor.Retry
-
Returns a retry function that retries any exception, once.
- anyOf(Class<? extends Throwable>...) - Static method in interface com.couchbase.client.core.retry.reactor.Retry
-
Returns a retry function that retries errors resulting from any of the
specified exceptions, once.
- AppendRequest - Class in com.couchbase.client.core.msg.kv
-
- AppendRequest(Duration, CoreContext, CollectionIdentifier, RetryStrategy, String, byte[], long, Optional<DurabilityLevel>, RequestSpan) - Constructor for class com.couchbase.client.core.msg.kv.AppendRequest
-
- AppendResponse - Class in com.couchbase.client.core.msg.kv
-
- AppendResponse(ResponseStatus, long, Optional<MutationToken>) - Constructor for class com.couchbase.client.core.msg.kv.AppendResponse
-
- applicationContext() - Method in class com.couchbase.client.core.retry.reactor.DefaultContext
-
- applicationContext() - Method in interface com.couchbase.client.core.retry.reactor.IterationContext
-
Application context that may be used to perform any rollbacks before
a retry.
- apply(Flux<Long>) - Method in class com.couchbase.client.core.retry.reactor.DefaultRepeat
-
- apply(Flux<Throwable>) - Method in class com.couchbase.client.core.retry.reactor.DefaultRetry
-
- apply(Publisher<S>) - Method in interface com.couchbase.client.core.retry.reactor.Repeat
-
Transforms the source into a repeating
Flux
based on the properties
configured for this function.
- apply(Publisher<S>) - Method in interface com.couchbase.client.core.retry.reactor.Retry
-
Transforms the source into a retrying
Flux
based on the properties
configured for this function.
- applyTlsProperties(SslContextBuilder) - Method in interface com.couchbase.client.core.env.Authenticator
-
The authenticator gets the chance to attach the client certificate to the ssl context if needed.
- applyTlsProperties(SslContextBuilder) - Method in class com.couchbase.client.core.env.CertificateAuthenticator
-
- attachContext(Map<String, Object>) - Method in interface com.couchbase.client.core.cnc.LoggingEventConsumer.Logger
-
Writes a diagnostics key/value pair.
- attempt() - Method in class com.couchbase.client.core.cnc.events.endpoint.EndpointConnectionFailedEvent
-
- attributes() - Method in class com.couchbase.client.core.io.netty.kv.ErrorMap.ErrorCode
-
- AuthenticationFailureException - Exception in com.couchbase.client.core.error
-
Every exception that has to do with authentication problems should either
instantiate or subclass from this type.
- AuthenticationFailureException(String, ErrorContext, Throwable) - Constructor for exception com.couchbase.client.core.error.AuthenticationFailureException
-
- authenticator() - Method in class com.couchbase.client.core.CoreContext
-
Returns the authenticator used for this core.
- Authenticator - Interface in com.couchbase.client.core.env
-
- authHttpRequest(ServiceType, HttpRequest) - Method in interface com.couchbase.client.core.env.Authenticator
-
Allows to add authentication credentials to the http request for the given service.
- authHttpRequest(ServiceType, HttpRequest) - Method in class com.couchbase.client.core.env.PasswordAuthenticator
-
- authKeyValueConnection(EndpointContext, ChannelPipeline) - Method in interface com.couchbase.client.core.env.Authenticator
-
Allows the authenticator to add KV handlers during connection bootstrap to perform
authentication.
- authKeyValueConnection(EndpointContext, ChannelPipeline) - Method in class com.couchbase.client.core.env.PasswordAuthenticator
-
- AUTO - Static variable in class com.couchbase.client.core.env.NetworkResolution
-
Based on heuristics discovers if internal or
external resolution will be used.
- cancel(CancellationReason) - Method in class com.couchbase.client.core.msg.BaseRequest
-
- cancel(CancellationReason) - Method in interface com.couchbase.client.core.msg.Request
-
Cancels this request.
- cancel() - Method in class com.couchbase.client.core.msg.RequestContext
-
Allows to cancel the attached
Request
from anywhere in the code.
- CancellationErrorContext - Class in com.couchbase.client.core.error.context
-
When a cancellation (i.e.
- CancellationErrorContext(RequestContext) - Constructor for class com.couchbase.client.core.error.context.CancellationErrorContext
-
- cancellationReason() - Method in class com.couchbase.client.core.msg.BaseRequest
-
- CancellationReason - Class in com.couchbase.client.core.msg
-
Describes the reason why a
Request
has been cancelled.
- cancellationReason() - Method in interface com.couchbase.client.core.msg.Request
-
- cancelled() - Method in class com.couchbase.client.core.msg.BaseRequest
-
- cancelled() - Method in interface com.couchbase.client.core.msg.Request
-
Allows to check if this request has been cancelled before it got a chance
to be either failed or succeeded.
- CANCELLED_VIA_CONTEXT - Static variable in class com.couchbase.client.core.msg.CancellationReason
-
The user or some other code proactively cancelled the request by cancelling
it through its attached context.
- capDuration(Duration, Request<? extends Response>) - Static method in class com.couchbase.client.core.retry.RetryOrchestrator
-
Calculates the potentially capped retry duration so we do not schedule a longer retry than the actual
total timeout.
- captureTraffic(ServiceType...) - Method in class com.couchbase.client.core.env.IoConfig.Builder
-
Captures the traffic for all services provided as an argument (all if empty).
- captureTraffic(ServiceType...) - Static method in class com.couchbase.client.core.env.IoConfig
-
Captures the traffic for all services provided as an argument (all if empty).
- CarrierBucketConfigRequest - Class in com.couchbase.client.core.msg.kv
-
- CarrierBucketConfigRequest(Duration, CoreContext, CollectionIdentifier, RetryStrategy, NodeIdentifier) - Constructor for class com.couchbase.client.core.msg.kv.CarrierBucketConfigRequest
-
- CarrierBucketConfigResponse - Class in com.couchbase.client.core.msg.kv
-
- CarrierGlobalConfigRequest - Class in com.couchbase.client.core.msg.kv
-
A request to fetch a global configuration.
- CarrierGlobalConfigRequest(Duration, CoreContext, RetryStrategy, NodeIdentifier) - Constructor for class com.couchbase.client.core.msg.kv.CarrierGlobalConfigRequest
-
- CarrierGlobalConfigResponse - Class in com.couchbase.client.core.msg.kv
-
- cas(ByteBuf) - Static method in enum com.couchbase.client.core.io.netty.kv.MemcacheProtocol
-
Helper method to extract the cas from a message.
- cas() - Method in class com.couchbase.client.core.msg.kv.AppendResponse
-
- cas() - Method in class com.couchbase.client.core.msg.kv.DecrementResponse
-
- cas() - Method in class com.couchbase.client.core.msg.kv.GetAndLockResponse
-
Returns the CAS value of the document at the time of the fetch.
- cas() - Method in class com.couchbase.client.core.msg.kv.GetAndTouchResponse
-
Returns the CAS value of the document at the time of the fetch.
- cas() - Method in class com.couchbase.client.core.msg.kv.GetMetaResponse
-
Returns the CAS value of the document at the time of the fetch.
- cas() - Method in class com.couchbase.client.core.msg.kv.GetResponse
-
Returns the CAS value of the document at the time of the fetch.
- cas() - Method in class com.couchbase.client.core.msg.kv.IncrementResponse
-
- cas() - Method in class com.couchbase.client.core.msg.kv.InsertResponse
-
- cas() - Method in class com.couchbase.client.core.msg.kv.ObserveViaCasResponse
-
- cas() - Method in class com.couchbase.client.core.msg.kv.PrependResponse
-
- cas() - Method in class com.couchbase.client.core.msg.kv.RemoveResponse
-
- cas() - Method in class com.couchbase.client.core.msg.kv.ReplaceResponse
-
- cas() - Method in class com.couchbase.client.core.msg.kv.SubdocGetResponse
-
- cas() - Method in class com.couchbase.client.core.msg.kv.SubdocMutateResponse
-
- cas() - Method in class com.couchbase.client.core.msg.kv.TouchResponse
-
- cas() - Method in class com.couchbase.client.core.msg.kv.UnlockResponse
-
- cas() - Method in class com.couchbase.client.core.msg.kv.UpsertResponse
-
- cas() - Method in class com.couchbase.client.core.service.kv.ObserveContext
-
- CasMismatchException - Exception in com.couchbase.client.core.error
-
Indicates an optimistic locking failure.
- CasMismatchException(ErrorContext) - Constructor for exception com.couchbase.client.core.error.CasMismatchException
-
- category() - Method in class com.couchbase.client.core.cnc.AbstractEvent
-
- category() - Method in interface com.couchbase.client.core.cnc.Event
-
The Category of this event.
- CATEGORY_PREFIX - Static variable in interface com.couchbase.client.core.cnc.Event
-
- cause() - Method in interface com.couchbase.client.core.cnc.Event
-
If present, holds the cause for this event.
- cause() - Method in class com.couchbase.client.core.cnc.events.config.BucketOpenRetriedEvent
-
- cause() - Method in class com.couchbase.client.core.cnc.events.config.CollectionMapDecodingFailedEvent
-
- cause() - Method in class com.couchbase.client.core.cnc.events.config.CollectionMapRefreshFailedEvent
-
- cause() - Method in class com.couchbase.client.core.cnc.events.config.ConfigIgnoredEvent
-
- cause() - Method in class com.couchbase.client.core.cnc.events.config.IndividualGlobalConfigLoadFailedEvent
-
- cause() - Method in class com.couchbase.client.core.cnc.events.core.DnsSrvLookupFailedEvent
-
- cause() - Method in class com.couchbase.client.core.cnc.events.core.InitGlobalConfigFailedEvent
-
- cause() - Method in class com.couchbase.client.core.cnc.events.core.ReconfigurationErrorDetectedEvent
-
- cause() - Method in class com.couchbase.client.core.cnc.events.core.ServiceReconfigurationFailedEvent
-
- cause() - Method in class com.couchbase.client.core.cnc.events.endpoint.EndpointConnectionFailedEvent
-
- cause() - Method in class com.couchbase.client.core.cnc.events.endpoint.EndpointDisconnectionFailedEvent
-
Returns the cause of the failure.
- cause() - Method in class com.couchbase.client.core.cnc.events.endpoint.EndpointWriteFailedEvent
-
- cause() - Method in class com.couchbase.client.core.cnc.events.endpoint.UnexpectedEndpointConnectionFailedEvent
-
The cause of the unexpected connecting error.
- cause() - Method in class com.couchbase.client.core.cnc.events.io.GenericFailureDetectedEvent
-
- cause() - Method in class com.couchbase.client.core.cnc.events.request.PreparedStatementRetriedEvent
-
- cause() - Method in class com.couchbase.client.core.cnc.events.request.RequestNotRetriedEvent
-
- cause() - Method in class com.couchbase.client.core.cnc.events.request.SuspiciousExpiryDurationEvent
-
Deprecated.
- cause() - Method in class com.couchbase.client.core.cnc.events.tracing.OrphanReporterFailureDetectedEvent
-
- CbAnnotations - Class in com.couchbase.client.core.util
-
- CbCollections - Class in com.couchbase.client.core.util
-
- CbObjects - Class in com.couchbase.client.core.util
-
- CbStrings - Class in com.couchbase.client.core.util
-
- CbThrowables - Class in com.couchbase.client.core.util
-
- ceil() - Method in class com.couchbase.client.core.io.netty.kv.ErrorMap.RetrySpecification
-
- CertificateAuthenticator - Class in com.couchbase.client.core.env
-
Performs authentication through a client certificate instead of supplying username and password.
- CHANNEL_ID_KEY - Static variable in class com.couchbase.client.core.io.netty.kv.ChannelAttributes
-
Holds the channel ID negotiated with KV engine once set.
- channelActive(ChannelHandlerContext) - Method in class com.couchbase.client.core.io.netty.chunk.ChunkedMessageHandler
-
- channelActive(ChannelHandlerContext) - Method in class com.couchbase.client.core.io.netty.ChunkedHandlerSwitcher
-
When the channel becomes active, make sure that the chunked handler is added since that is the most
likely needed one upfront (and the most perf critical one).
- channelActive(ChannelHandlerContext) - Method in class com.couchbase.client.core.io.netty.kv.ErrorMapLoadingHandler
-
- channelActive(ChannelHandlerContext) - Method in class com.couchbase.client.core.io.netty.kv.FeatureNegotiatingHandler
-
As soon as the channel is active start sending the hello request but also schedule
a timeout properly.
- channelActive(ChannelHandlerContext) - Method in class com.couchbase.client.core.io.netty.kv.KeyValueMessageHandler
-
Actions to be performed when the channel becomes active.
- channelActive(ChannelHandlerContext) - Method in class com.couchbase.client.core.io.netty.kv.SaslAuthenticationHandler
-
- channelActive(ChannelHandlerContext) - Method in class com.couchbase.client.core.io.netty.kv.SaslListMechanismsHandler
-
As soon as the channel is active start sending the request but also schedule
a timeout properly.
- channelActive(ChannelHandlerContext) - Method in class com.couchbase.client.core.io.netty.kv.SelectBucketHandler
-
- channelActive(ChannelHandlerContext) - Method in class com.couchbase.client.core.io.netty.manager.ManagerMessageHandler
-
- channelActive(ChannelHandlerContext) - Method in class com.couchbase.client.core.io.netty.NonChunkedHttpMessageHandler
-
When this channel is marked active it also needs to propagate that to the aggregator.
- channelActive(ChannelHandlerContext) - Method in class com.couchbase.client.core.io.netty.PipelineErrorHandler
-
- channelActive(ChannelHandlerContext) - Method in class com.couchbase.client.core.io.netty.TrafficCaptureHandler
-
- ChannelAttributes - Class in com.couchbase.client.core.io.netty.kv
-
This class holds all kinds of channel attributes that are in used across
the KV channel.
- ChannelClosedProactivelyEvent - Class in com.couchbase.client.core.cnc.events.io
-
This warning indicates that the client closed an active IO channel/socket proactively because
it detected an invalid state.
- ChannelClosedProactivelyEvent(IoContext, ChannelClosedProactivelyEvent.Reason) - Constructor for class com.couchbase.client.core.cnc.events.io.ChannelClosedProactivelyEvent
-
- ChannelClosedProactivelyEvent.Reason - Enum in com.couchbase.client.core.cnc.events.io
-
Specifies the reasons why a channel has been proactively closed by the SDK.
- channelFutureIntoMono(ChannelFuture) - Method in class com.couchbase.client.core.endpoint.BaseEndpoint
-
Helper method to convert a netty
ChannelFuture
into an async
Mono
.
- channelId() - Method in class com.couchbase.client.core.endpoint.EndpointContext
-
- channelId() - Method in class com.couchbase.client.core.io.netty.HttpChannelContext
-
- channelId() - Method in class com.couchbase.client.core.io.netty.kv.KeyValueChannelContext
-
- channelId() - Method in class com.couchbase.client.core.msg.analytics.AnalyticsPingResponse
-
- channelId() - Method in class com.couchbase.client.core.msg.kv.KvPingResponse
-
- channelId() - Method in class com.couchbase.client.core.msg.query.QueryPingResponse
-
- channelId() - Method in class com.couchbase.client.core.msg.search.SearchPingResponse
-
- channelId() - Method in class com.couchbase.client.core.msg.view.ViewPingResponse
-
- channelInactive(ChannelHandlerContext) - Method in class com.couchbase.client.core.io.netty.chunk.ChunkedMessageHandler
-
- channelInactive(ChannelHandlerContext) - Method in class com.couchbase.client.core.io.netty.kv.KeyValueMessageHandler
-
- channelInactive(ChannelHandlerContext) - Method in class com.couchbase.client.core.io.netty.manager.ManagerMessageHandler
-
- channelInactive(ChannelHandlerContext) - Method in class com.couchbase.client.core.io.netty.NonChunkedHttpMessageHandler
-
- channelInactive(ChannelHandlerContext) - Method in class com.couchbase.client.core.io.netty.PipelineErrorHandler
-
- channelRead(ChannelHandlerContext, Object) - Method in class com.couchbase.client.core.io.netty.chunk.ChunkedMessageHandler
-
- channelRead(ChannelHandlerContext, Object) - Method in class com.couchbase.client.core.io.netty.kv.ErrorMapLoadingHandler
-
- channelRead(ChannelHandlerContext, Object) - Method in class com.couchbase.client.core.io.netty.kv.FeatureNegotiatingHandler
-
As soon as we get a response, turn it into a list of negotiated server features.
- channelRead(ChannelHandlerContext, Object) - Method in class com.couchbase.client.core.io.netty.kv.KeyValueMessageHandler
-
- channelRead(ChannelHandlerContext, Object) - Method in class com.couchbase.client.core.io.netty.kv.MemcacheProtocolVerificationHandler
-
Makes sure that incoming responses are valid.
- channelRead(ChannelHandlerContext, Object) - Method in class com.couchbase.client.core.io.netty.kv.SaslAuthenticationHandler
-
- channelRead(ChannelHandlerContext, Object) - Method in class com.couchbase.client.core.io.netty.kv.SaslListMechanismsHandler
-
As soon as we get a response, turn it into a list of SASL mechanisms the server supports.
- channelRead(ChannelHandlerContext, Object) - Method in class com.couchbase.client.core.io.netty.kv.SelectBucketHandler
-
- channelRead(ChannelHandlerContext, Object) - Method in class com.couchbase.client.core.io.netty.manager.ManagerMessageHandler
-
- channelRead(ChannelHandlerContext, Object) - Method in class com.couchbase.client.core.io.netty.NonChunkedHttpMessageHandler
-
Parses the full http response and sends it to decode into the request.
- channelRead(ChannelHandlerContext, Object) - Method in class com.couchbase.client.core.io.netty.TrafficCaptureHandler
-
- checkServiceNotAvailable(Request<? extends Response>, ClusterConfig) - Method in class com.couchbase.client.core.node.RoundRobinLocator
-
Can be overridden to check if a request should be cancelled immediately that the service is not
supported.
- checkServiceNotAvailable(Request<? extends Response>, ClusterConfig) - Method in class com.couchbase.client.core.node.ViewLocator
-
- ChunkDecodable<H extends ChunkHeader,ROW extends ChunkRow,T extends ChunkTrailer,R extends ChunkedResponse<H,ROW,T>> - Interface in com.couchbase.client.core.msg.chunk
-
Marker interface to describe how the chunked response can be decoded.
- ChunkedHandlerSwitcher - Class in com.couchbase.client.core.io.netty
-
Parent class for all pipelines which need to switch between a chunked and a non-chunked handler structure.
- ChunkedHandlerSwitcher(ChunkedMessageHandler, NonChunkedHttpMessageHandler, Class<? extends Request>) - Constructor for class com.couchbase.client.core.io.netty.ChunkedHandlerSwitcher
-
Creates a new chunked handler switcher.
- ChunkedMessageHandler<H extends ChunkHeader,ROW extends ChunkRow,T extends ChunkTrailer,R extends ChunkedResponse<H,ROW,T>,REQ extends HttpRequest<H,ROW,T,R>> - Class in com.couchbase.client.core.io.netty.chunk
-
Implements the chunk stream handling for all generic http stream based services.
- ChunkedMessageHandler(BaseEndpoint, EndpointContext, ChunkResponseParser<H, ROW, T>) - Constructor for class com.couchbase.client.core.io.netty.chunk.ChunkedMessageHandler
-
- ChunkedResponse<H extends ChunkHeader,R extends ChunkRow,T extends ChunkTrailer> - Interface in com.couchbase.client.core.msg.chunk
-
Describes a full chunked response with its required sections.
- ChunkHeader - Interface in com.couchbase.client.core.msg.chunk
-
Marker interface to describe the leading bits of a chunked response.
- ChunkResponseParser<H extends ChunkHeader,ROW extends ChunkRow,T extends ChunkTrailer> - Interface in com.couchbase.client.core.io.netty.chunk
-
Defines the common parser interface for all chunked response parser implementations.
- ChunkRow - Interface in com.couchbase.client.core.msg.chunk
-
Marker interface to describe a row emitted from a chunked response.
- ChunkTrailer - Interface in com.couchbase.client.core.msg.chunk
-
Marker interface to describe the trailing bits of a chunked response.
- CircuitBreaker - Interface in com.couchbase.client.core.endpoint
-
- circuitBreaker() - Method in class com.couchbase.client.core.endpoint.EndpointContext
-
- CircuitBreaker.CompletionCallback - Interface in com.couchbase.client.core.endpoint
-
Defines if a request is considered a success or a failure.
- CircuitBreaker.State - Enum in com.couchbase.client.core.endpoint
-
Represents all the states a circuit breaker can be in, possibly.
- CircuitBreakerConfig - Class in com.couchbase.client.core.endpoint
-
- CircuitBreakerConfig.Builder - Class in com.couchbase.client.core.endpoint
-
- cleanup() - Method in class com.couchbase.client.core.io.netty.chunk.BaseChunkResponseParser
-
- cleanup() - Method in interface com.couchbase.client.core.io.netty.chunk.ChunkResponseParser
-
Releases resources managed by the parser and prepares it for reuse.
- clearContext() - Method in interface com.couchbase.client.core.cnc.LoggingEventConsumer.Logger
-
Clears the diagnostics context for this thread.
- clientContext() - Method in class com.couchbase.client.core.msg.RequestContext
-
Returns the custom user payload of this request.
- clientContext(Map<String, Object>) - Method in class com.couchbase.client.core.msg.RequestContext
-
Allows to set a custom payload for this request.
- clientContextId() - Method in class com.couchbase.client.core.msg.analytics.AnalyticsChunkHeader
-
- clientContextId() - Method in class com.couchbase.client.core.msg.query.QueryChunkHeader
-
- clientHash() - Method in class com.couchbase.client.core.env.CoreEnvironment
-
If present, returns the git hash for the client at build time.
- clientVersion() - Method in class com.couchbase.client.core.env.CoreEnvironment
-
If present, returns the client version at build time.
- close() - Method in class com.couchbase.client.core.json.stream.CopyingStreamWindow
-
- close() - Method in class com.couchbase.client.core.json.stream.JsonStreamParser
-
Releases resources managed by the parser.
- close() - Method in interface com.couchbase.client.core.json.stream.StreamWindow
-
Releases all buffers owned by the window.
- close() - Method in class com.couchbase.client.core.util.CompositeStateful
-
Closes the composite permanently and deregisters all elements.
- close() - Method in class com.couchbase.client.core.util.SingleStateful
-
Doesn't have to be called, added for good measure.
- closeBucket(String) - Method in interface com.couchbase.client.core.config.ConfigurationProvider
-
Initiates the bucket closing process.
- closeBucket(String) - Method in class com.couchbase.client.core.config.DefaultConfigurationProvider
-
- closeChannelWithReason(IoContext, ChannelHandlerContext, ChannelClosedProactivelyEvent.Reason) - Static method in class com.couchbase.client.core.io.netty.HandlerUtils
-
Proactively close this channel with the given reason.
- clusterCapabilities() - Method in class com.couchbase.client.core.config.AbstractBucketConfig
-
- clusterCapabilities() - Method in interface com.couchbase.client.core.config.BucketConfig
-
Returns the cluster capabilities reported by the server.
- ClusterCapabilities - Enum in com.couchbase.client.core.config
-
Contains all the cluster capabilities this SDK supports (depending on the server version, the cluster may
export more than these).
- clusterCapabilities() - Method in class com.couchbase.client.core.config.ClusterConfig
-
Returns the current cluster capabilities.
- clusterCapabilities() - Method in class com.couchbase.client.core.config.GlobalConfig
-
All global cluster capabilities.
- ClusterConfig - Class in com.couchbase.client.core.config
-
The
ClusterConfig
holds bucket and global configurations in a central place.
- ClusterConfig() - Constructor for class com.couchbase.client.core.config.ClusterConfig
-
- clusterConfig() - Method in class com.couchbase.client.core.Core
-
This API provides access to the current config that is published throughout the core.
- clusterLevelQuery(ServiceType) - Static method in exception com.couchbase.client.core.error.FeatureNotAvailableException
-
- ClusterManagerBucketLoader - Class in com.couchbase.client.core.config.loader
-
This loader is responsible for loading a config from the cluster manager.
- ClusterManagerBucketLoader(Core) - Constructor for class com.couchbase.client.core.config.loader.ClusterManagerBucketLoader
-
- ClusterManagerBucketRefresher - Class in com.couchbase.client.core.config.refresher
-
- ClusterManagerBucketRefresher(ConfigurationProvider, Core) - Constructor for class com.couchbase.client.core.config.refresher.ClusterManagerBucketRefresher
-
- clusterManagerPort() - Method in class com.couchbase.client.core.env.SeedNode
-
If present, the cluster manager port.
- ClusterState - Enum in com.couchbase.client.core.diagnostics
-
Describes the cluster state from the clients perspective in a simplified and aggregated state.
- code() - Method in class com.couchbase.client.core.error.ErrorCodeAndMessage
-
- code() - Method in exception com.couchbase.client.core.error.HttpStatusCodeException
-
- code() - Method in exception com.couchbase.client.core.error.QueryException
-
Returns the numeric error code from the query service.
- code() - Method in enum com.couchbase.client.core.msg.kv.DurabilityLevel
-
- CodecFlags - Enum in com.couchbase.client.core.msg.kv
-
- CodecFlags.CommonFlags - Enum in com.couchbase.client.core.msg.kv
-
The common flags enum.
- collection() - Method in class com.couchbase.client.core.io.CollectionIdentifier
-
- CollectionExistsException - Exception in com.couchbase.client.core.error
-
- CollectionExistsException(String) - Constructor for exception com.couchbase.client.core.error.CollectionExistsException
-
- collectionId() - Method in class com.couchbase.client.core.msg.kv.GetCollectionIdResponse
-
- CollectionIdentifier - Class in com.couchbase.client.core.io
-
- CollectionIdentifier(String, Optional<String>, Optional<String>) - Constructor for class com.couchbase.client.core.io.CollectionIdentifier
-
- collectionIdentifier() - Method in class com.couchbase.client.core.msg.kv.BaseKeyValueRequest
-
- collectionIdentifier() - Method in interface com.couchbase.client.core.msg.kv.KeyValueRequest
-
- collectionIdentifier() - Method in class com.couchbase.client.core.service.kv.ObserveContext
-
- collectionMap() - Method in interface com.couchbase.client.core.config.ConfigurationProvider
-
Returns the attached collection map.
- collectionMap() - Method in class com.couchbase.client.core.config.DefaultConfigurationProvider
-
- CollectionMap - Class in com.couchbase.client.core.io
-
The
CollectionMap
maps a locator to the encoded collection ID representation.
- CollectionMap() - Constructor for class com.couchbase.client.core.io.CollectionMap
-
- collectionMap() - Method in class com.couchbase.client.core.io.netty.kv.KeyValueChannelContext
-
- CollectionMapDecodingFailedEvent - Class in com.couchbase.client.core.cnc.events.config
-
This event is raised if a collection map could be loaded, but afterwards cannot be decoded and used
as intended.
- CollectionMapDecodingFailedEvent(Context, Throwable) - Constructor for class com.couchbase.client.core.cnc.events.config.CollectionMapDecodingFailedEvent
-
- CollectionMapRefreshFailedEvent - Class in com.couchbase.client.core.cnc.events.config
-
This event is raised if a collection map could not be refreshed properly.
- CollectionMapRefreshFailedEvent(Duration, Context, Throwable, CollectionMapRefreshFailedEvent.Reason) - Constructor for class com.couchbase.client.core.cnc.events.config.CollectionMapRefreshFailedEvent
-
- CollectionMapRefreshFailedEvent.Reason - Enum in com.couchbase.client.core.cnc.events.config
-
- collectionMapRefreshInProgress() - Method in interface com.couchbase.client.core.config.ConfigurationProvider
-
Returns true if a collection map refresh is in progress.
- collectionMapRefreshInProgress() - Method in class com.couchbase.client.core.config.DefaultConfigurationProvider
-
- collectionName() - Method in exception com.couchbase.client.core.error.CollectionExistsException
-
- collectionName() - Method in exception com.couchbase.client.core.error.CollectionNotFoundException
-
- CollectionNotFoundException - Exception in com.couchbase.client.core.error
-
- CollectionNotFoundException(String) - Constructor for exception com.couchbase.client.core.error.CollectionNotFoundException
-
- collections() - Method in class com.couchbase.client.core.config.CollectionsManifestScope
-
- collections() - Static method in exception com.couchbase.client.core.error.FeatureNotAvailableException
-
- collectionsEnabled() - Method in class com.couchbase.client.core.io.netty.kv.KeyValueChannelContext
-
- CollectionsManifest - Class in com.couchbase.client.core.config
-
- CollectionsManifest(String, List<CollectionsManifestScope>) - Constructor for class com.couchbase.client.core.config.CollectionsManifest
-
- CollectionsManifestCollection - Class in com.couchbase.client.core.config
-
- CollectionsManifestCollection(String, String, int) - Constructor for class com.couchbase.client.core.config.CollectionsManifestCollection
-
- CollectionsManifestScope - Class in com.couchbase.client.core.config
-
- CollectionsManifestScope(String, String, List<CollectionsManifestCollection>) - Constructor for class com.couchbase.client.core.config.CollectionsManifestScope
-
- com.couchbase.client.core - package com.couchbase.client.core
-
- com.couchbase.client.core.annotation - package com.couchbase.client.core.annotation
-
- com.couchbase.client.core.cnc - package com.couchbase.client.core.cnc
-
- com.couchbase.client.core.cnc.events.config - package com.couchbase.client.core.cnc.events.config
-
- com.couchbase.client.core.cnc.events.core - package com.couchbase.client.core.cnc.events.core
-
- com.couchbase.client.core.cnc.events.endpoint - package com.couchbase.client.core.cnc.events.endpoint
-
- com.couchbase.client.core.cnc.events.io - package com.couchbase.client.core.cnc.events.io
-
- com.couchbase.client.core.cnc.events.metrics - package com.couchbase.client.core.cnc.events.metrics
-
- com.couchbase.client.core.cnc.events.node - package com.couchbase.client.core.cnc.events.node
-
- com.couchbase.client.core.cnc.events.request - package com.couchbase.client.core.cnc.events.request
-
- com.couchbase.client.core.cnc.events.service - package com.couchbase.client.core.cnc.events.service
-
- com.couchbase.client.core.cnc.events.tracing - package com.couchbase.client.core.cnc.events.tracing
-
- com.couchbase.client.core.cnc.metrics - package com.couchbase.client.core.cnc.metrics
-
- com.couchbase.client.core.cnc.tracing - package com.couchbase.client.core.cnc.tracing
-
- com.couchbase.client.core.config - package com.couchbase.client.core.config
-
- com.couchbase.client.core.config.loader - package com.couchbase.client.core.config.loader
-
- com.couchbase.client.core.config.refresher - package com.couchbase.client.core.config.refresher
-
- com.couchbase.client.core.diagnostics - package com.couchbase.client.core.diagnostics
-
- com.couchbase.client.core.encryption - package com.couchbase.client.core.encryption
-
- com.couchbase.client.core.endpoint - package com.couchbase.client.core.endpoint
-
- com.couchbase.client.core.env - package com.couchbase.client.core.env
-
- com.couchbase.client.core.error - package com.couchbase.client.core.error
-
- com.couchbase.client.core.error.context - package com.couchbase.client.core.error.context
-
- com.couchbase.client.core.error.subdoc - package com.couchbase.client.core.error.subdoc
-
- com.couchbase.client.core.io - package com.couchbase.client.core.io
-
- com.couchbase.client.core.io.netty - package com.couchbase.client.core.io.netty
-
- com.couchbase.client.core.io.netty.analytics - package com.couchbase.client.core.io.netty.analytics
-
- com.couchbase.client.core.io.netty.chunk - package com.couchbase.client.core.io.netty.chunk
-
- com.couchbase.client.core.io.netty.kv - package com.couchbase.client.core.io.netty.kv
-
- com.couchbase.client.core.io.netty.kv.sasl - package com.couchbase.client.core.io.netty.kv.sasl
-
- com.couchbase.client.core.io.netty.manager - package com.couchbase.client.core.io.netty.manager
-
- com.couchbase.client.core.io.netty.query - package com.couchbase.client.core.io.netty.query
-
- com.couchbase.client.core.io.netty.search - package com.couchbase.client.core.io.netty.search
-
- com.couchbase.client.core.io.netty.view - package com.couchbase.client.core.io.netty.view
-
- com.couchbase.client.core.json - package com.couchbase.client.core.json
-
- com.couchbase.client.core.json.stream - package com.couchbase.client.core.json.stream
-
- com.couchbase.client.core.logging - package com.couchbase.client.core.logging
-
- com.couchbase.client.core.msg - package com.couchbase.client.core.msg
-
- com.couchbase.client.core.msg.analytics - package com.couchbase.client.core.msg.analytics
-
- com.couchbase.client.core.msg.chunk - package com.couchbase.client.core.msg.chunk
-
- com.couchbase.client.core.msg.kv - package com.couchbase.client.core.msg.kv
-
- com.couchbase.client.core.msg.manager - package com.couchbase.client.core.msg.manager
-
- com.couchbase.client.core.msg.query - package com.couchbase.client.core.msg.query
-
- com.couchbase.client.core.msg.search - package com.couchbase.client.core.msg.search
-
- com.couchbase.client.core.msg.view - package com.couchbase.client.core.msg.view
-
- com.couchbase.client.core.node - package com.couchbase.client.core.node
-
- com.couchbase.client.core.projections - package com.couchbase.client.core.projections
-
- com.couchbase.client.core.retry - package com.couchbase.client.core.retry
-
- com.couchbase.client.core.retry.reactor - package com.couchbase.client.core.retry.reactor
-
- com.couchbase.client.core.scheduler - package com.couchbase.client.core.scheduler
-
- com.couchbase.client.core.service - package com.couchbase.client.core.service
-
- com.couchbase.client.core.service.kv - package com.couchbase.client.core.service.kv
-
- com.couchbase.client.core.service.strategy - package com.couchbase.client.core.service.strategy
-
- com.couchbase.client.core.util - package com.couchbase.client.core.util
-
- Command(SubdocCommandType, String, boolean, int) - Constructor for class com.couchbase.client.core.msg.kv.SubdocGetRequest.Command
-
- Command(SubdocCommandType, String, byte[], boolean, boolean, boolean, int) - Constructor for class com.couchbase.client.core.msg.kv.SubdocMutateRequest.Command
-
- COMMON_FORMAT_MASK - Static variable in enum com.couchbase.client.core.msg.kv.CodecFlags
-
32bit flag is composed of:
- 3 compression bits
- 1 bit reserved for future use
- 4 format flags bits.
- CommonExceptions - Class in com.couchbase.client.core.error
-
- companionValue() - Method in class com.couchbase.client.core.retry.reactor.DefaultContext
-
- companionValue() - Method in interface com.couchbase.client.core.retry.reactor.RepeatContext
-
Returns the value provided in the companion Flux for repeats.
- compareAndTransition(S, S) - Method in class com.couchbase.client.core.util.SingleStateful
-
If the expected state is in place the new one is applied and consumers notified.
- compareTo(ErrorMap) - Method in class com.couchbase.client.core.io.netty.kv.ErrorMap
-
- CompilationFailureException - Exception in com.couchbase.client.core.error
-
The query failed to compile.
- CompilationFailureException(ErrorContext) - Constructor for exception com.couchbase.client.core.error.CompilationFailureException
-
- completed() - Method in class com.couchbase.client.core.msg.BaseRequest
-
- completed() - Method in interface com.couchbase.client.core.msg.Request
-
Allows to check if this request is completed already.
- completedRequest(KeyValueRequest<?>, ResponseStatus) - Static method in class com.couchbase.client.core.error.context.KeyValueErrorContext
-
- completeRows() - Method in class com.couchbase.client.core.io.netty.chunk.BaseChunkResponseParser
-
Completes the row flux.
- completeStream() - Method in class com.couchbase.client.core.msg.manager.BucketConfigStreamingResponse
-
- completeTrailer(T) - Method in class com.couchbase.client.core.io.netty.chunk.BaseChunkResponseParser
-
Called from the child implementation to complete the trailing bits.
- completionCallback(CircuitBreaker.CompletionCallback) - Method in class com.couchbase.client.core.endpoint.CircuitBreakerConfig.Builder
-
Allows customizing of the completion callback which defines what is considered a failure and what success.
- completionCallback(CircuitBreaker.CompletionCallback) - Static method in class com.couchbase.client.core.endpoint.CircuitBreakerConfig
-
- completionCallback() - Method in class com.couchbase.client.core.endpoint.CircuitBreakerConfig
-
- CompositeStateful<T,IN,OUT> - Class in com.couchbase.client.core.util
-
Represents a stateful component of one or more individual stateful elements.
- CompressionConfig - Class in com.couchbase.client.core.env
-
Allows configuring and customizing the compression configuration.
- compressionConfig(CompressionConfig.Builder) - Method in class com.couchbase.client.core.env.CoreEnvironment.Builder
-
Allows to customize document value compression settings.
- compressionConfig() - Method in class com.couchbase.client.core.env.CoreEnvironment.Builder
-
Returns the currently stored config builder.
- compressionConfig() - Method in class com.couchbase.client.core.env.CoreEnvironment
-
Returns the current compression configuration.
- compressionConfig() - Method in class com.couchbase.client.core.io.netty.kv.KeyValueChannelContext
-
- CompressionConfig.Builder - Class in com.couchbase.client.core.env
-
- compressionEnabled() - Method in class com.couchbase.client.core.io.netty.kv.KeyValueChannelContext
-
- config() - Method in class com.couchbase.client.core.cnc.events.config.BucketConfigUpdatedEvent
-
- config() - Method in class com.couchbase.client.core.cnc.events.config.ConfigIgnoredEvent
-
- config() - Method in class com.couchbase.client.core.cnc.events.config.GlobalConfigUpdatedEvent
-
- config() - Method in interface com.couchbase.client.core.config.ConfigurationProvider
-
- config() - Method in class com.couchbase.client.core.config.DefaultConfigurationProvider
-
- config() - Method in class com.couchbase.client.core.config.ProposedBucketConfigContext
-
- config() - Method in class com.couchbase.client.core.config.ProposedGlobalConfigContext
-
- config() - Method in class com.couchbase.client.core.msg.manager.BucketConfigResponse
-
- ConfigException - Exception in com.couchbase.client.core.error
-
- ConfigException() - Constructor for exception com.couchbase.client.core.error.ConfigException
-
- ConfigException(String) - Constructor for exception com.couchbase.client.core.error.ConfigException
-
- ConfigException(String, Throwable) - Constructor for exception com.couchbase.client.core.error.ConfigException
-
- ConfigException(Throwable) - Constructor for exception com.couchbase.client.core.error.ConfigException
-
- configIdleRedialTimeout(Duration) - Method in class com.couchbase.client.core.env.IoConfig.Builder
-
- configIdleRedialTimeout(Duration) - Static method in class com.couchbase.client.core.env.IoConfig
-
- configIdleRedialTimeout() - Method in class com.couchbase.client.core.env.IoConfig
-
- ConfigIgnoredEvent - Class in com.couchbase.client.core.cnc.events.config
-
- ConfigIgnoredEvent(Context, ConfigIgnoredEvent.Reason, Optional<Exception>, Optional<String>) - Constructor for class com.couchbase.client.core.cnc.events.config.ConfigIgnoredEvent
-
- ConfigIgnoredEvent.Reason - Enum in com.couchbase.client.core.cnc.events.config
-
The reason why the proposed config got ignored.
- configPollInterval(Duration) - Method in class com.couchbase.client.core.env.IoConfig.Builder
-
- configPollInterval(Duration) - Static method in class com.couchbase.client.core.env.IoConfig
-
- configPollInterval() - Method in class com.couchbase.client.core.env.IoConfig
-
- configs() - Method in interface com.couchbase.client.core.config.ConfigurationProvider
-
This is a hot stream which when attached will return the current config as well as
all subsequent ones.
- configs() - Method in class com.couchbase.client.core.config.DefaultConfigurationProvider
-
- configs() - Method in class com.couchbase.client.core.msg.manager.BucketConfigStreamingResponse
-
- ConfigurationProvider - Interface in com.couchbase.client.core.config
-
The
ConfigurationProvider
is responsible for grabbing, converting and managing
bucket and cluster configurations.
- configurationProvider() - Method in class com.couchbase.client.core.Core
-
Returns the attached configuration provider.
- connect() - Method in class com.couchbase.client.core.endpoint.BaseEndpoint
-
Starts the connect process of this endpoint.
- connect() - Method in interface com.couchbase.client.core.endpoint.Endpoint
-
- connect(ChannelHandlerContext, SocketAddress, SocketAddress, ChannelPromise) - Method in class com.couchbase.client.core.io.netty.kv.ErrorMapLoadingHandler
-
Intercepts the connect process inside the pipeline to only propagate either
success or failure if the error map loading process is completed either way.
- connect(ChannelHandlerContext, SocketAddress, SocketAddress, ChannelPromise) - Method in class com.couchbase.client.core.io.netty.kv.FeatureNegotiatingHandler
-
Intercepts the connect process inside the pipeline to only propagate either
success or failure if the hello process is completed either way.
- connect(ChannelHandlerContext, SocketAddress, SocketAddress, ChannelPromise) - Method in class com.couchbase.client.core.io.netty.kv.SaslAuthenticationHandler
-
Intercepts the connect process inside the pipeline to only propagate either
success or failure if the hello process is completed either way.
- connect(ChannelHandlerContext, SocketAddress, SocketAddress, ChannelPromise) - Method in class com.couchbase.client.core.io.netty.kv.SaslListMechanismsHandler
-
Intercepts the connect process inside the pipeline to only propagate either
success or failure if the hello process is completed either way.
- connect(ChannelHandlerContext, SocketAddress, SocketAddress, ChannelPromise) - Method in class com.couchbase.client.core.io.netty.kv.SelectBucketHandler
-
- connect() - Method in interface com.couchbase.client.core.service.Service
-
- ConnectionString - Class in com.couchbase.client.core.util
-
- ConnectionString(String) - Constructor for class com.couchbase.client.core.util.ConnectionString
-
- ConnectionString.PortType - Enum in com.couchbase.client.core.util
-
- ConnectionString.Scheme - Enum in com.couchbase.client.core.util
-
- ConnectionString.UnresolvedSocket - Class in com.couchbase.client.core.util
-
- ConnectionStringPropertyLoader - Class in com.couchbase.client.core.env
-
This
PropertyLoader
takes a connection string and applies all properties
that are supported and it knows about.
- ConnectionStringPropertyLoader(String) - Constructor for class com.couchbase.client.core.env.ConnectionStringPropertyLoader
-
- ConnectionStringUtil - Class in com.couchbase.client.core.util
-
Contains various helper methods when dealing with the connection string.
- connectTimeout(Duration) - Method in class com.couchbase.client.core.env.TimeoutConfig.Builder
-
Sets the timeout to use for connecting and socket connects.
- connectTimeout(Duration) - Static method in class com.couchbase.client.core.env.TimeoutConfig
-
- connectTimeout() - Method in class com.couchbase.client.core.env.TimeoutConfig
-
- ConnectTimings - Class in com.couchbase.client.core.io.netty.kv
-
This class gets populated with timings and success/failure of different steps in the
channel bootstrap process and later allows to extract useful information for debugging.
- content() - Method in class com.couchbase.client.core.cnc.events.io.ErrorMapUndecodableEvent
-
Returns the content in string form.
- content() - Method in exception com.couchbase.client.core.error.AnalyticsException
-
- content() - Method in exception com.couchbase.client.core.error.ViewServiceException
-
- content() - Method in class com.couchbase.client.core.msg.analytics.AnalyticsPingResponse
-
- content() - Method in class com.couchbase.client.core.msg.analytics.GenericAnalyticsResponse
-
- content() - Method in class com.couchbase.client.core.msg.kv.CarrierBucketConfigResponse
-
- content() - Method in class com.couchbase.client.core.msg.kv.CarrierGlobalConfigResponse
-
- content() - Method in class com.couchbase.client.core.msg.kv.GetAndLockResponse
-
Returns the content, but might be empty or null.
- content() - Method in class com.couchbase.client.core.msg.kv.GetAndTouchResponse
-
Returns the content, but might be empty or null.
- content() - Method in class com.couchbase.client.core.msg.kv.GetResponse
-
Returns the content, but might be empty or null.
- content() - Method in class com.couchbase.client.core.msg.manager.GenericManagerResponse
-
- content() - Method in class com.couchbase.client.core.msg.query.QueryPingResponse
-
- content() - Method in class com.couchbase.client.core.msg.search.GenericSearchResponse
-
- content() - Method in class com.couchbase.client.core.msg.search.SearchPingResponse
-
- content() - Method in class com.couchbase.client.core.msg.view.GenericViewResponse
-
- content() - Method in class com.couchbase.client.core.msg.view.ViewPingResponse
-
- context() - Method in class com.couchbase.client.core.cnc.AbstractEvent
-
- Context - Interface in com.couchbase.client.core.cnc
-
Context represents some state that is passed throughout the system.
- context() - Method in interface com.couchbase.client.core.cnc.Event
-
The context this event is referencing.
- context() - Method in class com.couchbase.client.core.Core
-
- context() - Method in class com.couchbase.client.core.endpoint.BaseEndpoint
-
- context() - Method in interface com.couchbase.client.core.endpoint.Endpoint
-
Returns the context for this endpoint.
- context() - Method in exception com.couchbase.client.core.error.CouchbaseException
-
Returns the error context, if present.
- context() - Method in class com.couchbase.client.core.error.ErrorCodeAndMessage
-
Returns an unmodifiable map of any additional information returned by the server.
- context() - Method in exception com.couchbase.client.core.error.RequestCanceledException
-
- context() - Method in exception com.couchbase.client.core.error.subdoc.DeltaInvalidException
-
- context() - Method in exception com.couchbase.client.core.error.subdoc.DocumentNotJsonException
-
- context() - Method in exception com.couchbase.client.core.error.subdoc.DocumentTooDeepException
-
- context() - Method in exception com.couchbase.client.core.error.subdoc.NumberTooBigException
-
- context() - Method in exception com.couchbase.client.core.error.subdoc.PathExistsException
-
- context() - Method in exception com.couchbase.client.core.error.subdoc.PathInvalidException
-
- context() - Method in exception com.couchbase.client.core.error.subdoc.PathMismatchException
-
- context() - Method in exception com.couchbase.client.core.error.subdoc.PathNotFoundException
-
- context() - Method in exception com.couchbase.client.core.error.subdoc.PathTooDeepException
-
- context() - Method in exception com.couchbase.client.core.error.subdoc.ValueInvalidException
-
- context() - Method in exception com.couchbase.client.core.error.subdoc.ValueTooDeepException
-
- context() - Method in exception com.couchbase.client.core.error.subdoc.XattrCannotModifyVirtualAttributeException
-
- context() - Method in exception com.couchbase.client.core.error.subdoc.XattrInvalidFlagComboException
-
Deprecated.
- context() - Method in exception com.couchbase.client.core.error.subdoc.XattrInvalidKeyComboException
-
- context() - Method in exception com.couchbase.client.core.error.subdoc.XattrInvalidOrderException
-
Deprecated.
- context() - Method in exception com.couchbase.client.core.error.subdoc.XattrNoAccessException
-
- context() - Method in exception com.couchbase.client.core.error.subdoc.XattrUnknownMacroException
-
- context() - Method in exception com.couchbase.client.core.error.subdoc.XattrUnknownVirtualAttributeException
-
- context() - Method in exception com.couchbase.client.core.error.TimeoutException
-
- context() - Method in class com.couchbase.client.core.msg.BaseRequest
-
- context() - Method in class com.couchbase.client.core.msg.kv.ResponseStatusDetails
-
- context() - Method in interface com.couchbase.client.core.msg.Request
-
If attached, returns the context for this request.
- context() - Method in interface com.couchbase.client.core.service.Service
-
Returns the underlying contextual metadata for this service.
- Context.ExportFormat - Interface in com.couchbase.client.core.cnc
-
The format into which the context can be exported.
- contexts() - Method in class com.couchbase.client.core.error.context.AggregateErrorContext
-
- convert(byte[]) - Static method in class com.couchbase.client.core.msg.kv.ResponseStatusDetails
-
Helper method to convert a ByteBuf
input into the details.
- convertValue(Object, Class<T>) - Static method in class com.couchbase.client.core.json.Mapper
-
Converts an object to the requested type using
ObjectMapper.convertValue(Object, Class)
.
- convertValue(Object, TypeReference<T>) - Static method in class com.couchbase.client.core.json.Mapper
-
Converts an object to the requested type using
ObjectMapper.convertValue(Object, TypeReference)
.
- CopyingStreamWindow - Class in com.couchbase.client.core.json.stream
-
A stream window implementation that copies input data into a single accumulator buffer.
- CopyingStreamWindow(ByteBufAllocator) - Constructor for class com.couchbase.client.core.json.stream.CopyingStreamWindow
-
- copyToUnmodifiableList(Collection<T>) - Static method in class com.couchbase.client.core.util.CbCollections
-
Returns a new unmodifiable list with the same contents as the given collection.
- copyToUnmodifiableSet(Collection<T>) - Static method in class com.couchbase.client.core.util.CbCollections
-
Returns a new unmodifiable set with the same contents as the given collection.
- core() - Method in class com.couchbase.client.core.config.loader.BaseBucketLoader
-
Returns the attached
Core
to be used by implementations.
- Core - Class in com.couchbase.client.core
-
The main entry point into the core layer.
- Core(CoreEnvironment, Authenticator, Set<SeedNode>) - Constructor for class com.couchbase.client.core.Core
-
Creates a new Core.
- core() - Method in class com.couchbase.client.core.CoreContext
-
Returns the core to which this context belongs.
- CoreContext - Class in com.couchbase.client.core
-
The
CoreContext
is bound to a core and provides both exportable and
usable state for the rest of the application to use.
- CoreContext(Core, long, CoreEnvironment, Authenticator) - Constructor for class com.couchbase.client.core.CoreContext
-
- CoreCreatedEvent - Class in com.couchbase.client.core.cnc.events.core
-
This event is emitted when a
Core
is created.
- CoreCreatedEvent(CoreContext, CoreEnvironment, Set<SeedNode>) - Constructor for class com.couchbase.client.core.cnc.events.core.CoreCreatedEvent
-
- CoreEnvironment - Class in com.couchbase.client.core.env
-
The Environment is the main place in the SDK where configuration and state lives (i.e.
- CoreEnvironment(CoreEnvironment.Builder) - Constructor for class com.couchbase.client.core.env.CoreEnvironment
-
- CoreEnvironment.Builder<SELF extends CoreEnvironment.Builder<SELF>> - Class in com.couchbase.client.core.env
-
- coreHash() - Method in class com.couchbase.client.core.env.CoreEnvironment
-
If present, returns the git hash for the core at build time.
- coreVersion() - Method in class com.couchbase.client.core.env.CoreEnvironment
-
If present, returns the core version at build time.
- CouchbaseBucketConfig - Class in com.couchbase.client.core.config
-
- CouchbaseBucketConfig(long, String, String, String, String, PartitionInfo, List<NodeInfo>, List<PortInfo>, List<BucketCapabilities>, Map<String, Set<ClusterCapabilities>>, String) - Constructor for class com.couchbase.client.core.config.CouchbaseBucketConfig
-
- CouchbaseException - Exception in com.couchbase.client.core.error
-
The parent class for all exceptions created by this SDK (or clients using it).
- CouchbaseException() - Constructor for exception com.couchbase.client.core.error.CouchbaseException
-
Deprecated.
- CouchbaseException(Throwable) - Constructor for exception com.couchbase.client.core.error.CouchbaseException
-
Deprecated.
- CouchbaseException(String) - Constructor for exception com.couchbase.client.core.error.CouchbaseException
-
- CouchbaseException(String, ErrorContext) - Constructor for exception com.couchbase.client.core.error.CouchbaseException
-
- CouchbaseException(String, Throwable) - Constructor for exception com.couchbase.client.core.error.CouchbaseException
-
- CouchbaseException(String, Throwable, ErrorContext) - Constructor for exception com.couchbase.client.core.error.CouchbaseException
-
- CouchbaseSaslClientFactory - Class in com.couchbase.client.core.io.netty.kv.sasl
-
This
SaslClientFactory
supports all couchbase supported SASL authentication
mechanisms.
- CouchbaseSaslClientFactory() - Constructor for class com.couchbase.client.core.io.netty.kv.sasl.CouchbaseSaslClientFactory
-
- Counter - Interface in com.couchbase.client.core.cnc
-
Represents a generic Counter interface for metrics.
- counter(String, Map<String, String>) - Method in interface com.couchbase.client.core.cnc.Meter
-
Creates a new counter.
- counter(String, Map<String, String>) - Method in class com.couchbase.client.core.cnc.metrics.AggregatingMeter
-
Note that since we are not performing any aggregations on the counter type, this pretty much
is a NOOP for performance reasons.
- counter(String, Map<String, String>) - Method in class com.couchbase.client.core.cnc.metrics.NoopMeter
-
- COUNTER_NOT_EXISTS_EXPIRY - Static variable in class com.couchbase.client.core.msg.kv.IncrementRequest
-
- create(Scheduler) - Static method in class com.couchbase.client.core.cnc.DefaultEventBus
-
- create() - Static method in class com.couchbase.client.core.cnc.LoggingEventConsumer
-
- create(LoggerConfig) - Static method in class com.couchbase.client.core.cnc.LoggingEventConsumer
-
- create(EventBus, AggregatingMeterConfig) - Static method in class com.couchbase.client.core.cnc.metrics.AggregatingMeter
-
- create(EventBus) - Static method in class com.couchbase.client.core.cnc.tracing.ThresholdRequestTracer
-
Short-hand to create the tracer with the event bus that needs to be used.
- create(EventBus, ThresholdRequestTracerConfig) - Static method in class com.couchbase.client.core.cnc.tracing.ThresholdRequestTracer
-
Creates a tracer with config and a reference to the event bus.
- create(CoreEnvironment, Authenticator, Set<SeedNode>) - Static method in class com.couchbase.client.core.Core
-
Creates a new
Core
with the given environment.
- create() - Static method in class com.couchbase.client.core.env.AggregatingMeterConfig
-
- create() - Static method in class com.couchbase.client.core.env.CompressionConfig
-
- create() - Static method in class com.couchbase.client.core.env.CoreEnvironment
-
- create() - Static method in class com.couchbase.client.core.env.IoConfig
-
- create() - Static method in class com.couchbase.client.core.env.IoEnvironment
-
- create() - Static method in class com.couchbase.client.core.env.LoggerConfig
-
- create() - Static method in class com.couchbase.client.core.env.OrphanReporterConfig
-
- create(String, String) - Static method in class com.couchbase.client.core.env.PasswordAuthenticator
-
Creates a new password authenticator with the default settings.
- create() - Static method in class com.couchbase.client.core.env.SecurityConfig
-
- create(String) - Static method in class com.couchbase.client.core.env.SeedNode
-
Creates a seed node from a hostname and the default ports.
- create(String, Optional<Integer>, Optional<Integer>) - Static method in class com.couchbase.client.core.env.SeedNode
-
Creates a seed node from a hostname and custom ports.
- create() - Static method in class com.couchbase.client.core.env.ThresholdRequestTracerConfig
-
- create() - Static method in class com.couchbase.client.core.env.TimeoutConfig
-
- create(String, CollectionIdentifier) - Static method in class com.couchbase.client.core.error.context.ReducedKeyValueErrorContext
-
- create(String, String, String, String) - Static method in class com.couchbase.client.core.error.context.ReducedKeyValueErrorContext
-
- create(String) - Static method in class com.couchbase.client.core.error.context.ReducedKeyValueErrorContext
-
- create(CoreContext, NodeIdentifier, Optional<String>) - Static method in class com.couchbase.client.core.node.Node
-
- create(Predicate<? super RepeatContext<T>>, long) - Static method in class com.couchbase.client.core.retry.reactor.DefaultRepeat
-
- create(Predicate<? super RetryContext<T>>) - Static method in class com.couchbase.client.core.retry.reactor.DefaultRetry
-
- create(Predicate<? super RepeatContext<T>>, long) - Static method in interface com.couchbase.client.core.retry.reactor.Repeat
-
Repeat function that repeats n times, only if the predicate returns true.
- create(long) - Static method in class com.couchbase.client.core.Timer
-
Creates a new
Timer
with default values.
- create(OUT, Function<Collection<IN>, OUT>, BiConsumer<OUT, OUT>) - Static method in class com.couchbase.client.core.util.CompositeStateful
-
Creates a new transformer with an initial state and the transform function that should be applied.
- create(OUT, Function<Collection<IN>, OUT>) - Static method in class com.couchbase.client.core.util.CompositeStateful
-
Creates a new transformer with an initial state and the transform function that should be applied.
- create(String) - Static method in class com.couchbase.client.core.util.ConnectionString
-
- create() - Static method in class com.couchbase.client.core.util.UrlQueryStringBuilder
-
Returns a new instance that performs URL-encoding on parameter names as well as values.
- createAndStart(long) - Static method in class com.couchbase.client.core.Timer
-
Creates and starts a timer with default values.
- createArrayNode() - Static method in class com.couchbase.client.core.json.Mapper
-
Returns a new empty ArrayNode.
- createAsDeleted() - Method in class com.couchbase.client.core.io.netty.kv.KeyValueChannelContext
-
- createCommonFlags(int) - Static method in enum com.couchbase.client.core.msg.kv.CodecFlags
-
Takes a integer representation of flags and moves them to the common flags MSBs.
- createdAt() - Method in class com.couchbase.client.core.cnc.AbstractEvent
-
- createdAt() - Method in interface com.couchbase.client.core.cnc.Event
-
Contains a nano timestamp when the event was created.
- createdAt() - Method in class com.couchbase.client.core.msg.BaseRequest
-
- createdAt() - Method in interface com.couchbase.client.core.msg.Request
-
Holds the nanoTime when the request got created.
- createEndpoint() - Method in class com.couchbase.client.core.service.AnalyticsService
-
- createEndpoint() - Method in class com.couchbase.client.core.service.KeyValueService
-
- createEndpoint() - Method in class com.couchbase.client.core.service.ManagerService
-
- createEndpoint() - Method in class com.couchbase.client.core.service.QueryService
-
- createEndpoint() - Method in class com.couchbase.client.core.service.SearchService
-
- createEndpoint() - Method in class com.couchbase.client.core.service.ViewService
-
- createForUrlSafeNames() - Static method in class com.couchbase.client.core.util.UrlQueryStringBuilder
-
Returns a new instance that assumes none of the parameter names need URL-encoding.
- createNode(NodeIdentifier, Optional<String>) - Method in class com.couchbase.client.core.Core
-
Create a
Node
from the given identifier.
- createObjectNode() - Static method in class com.couchbase.client.core.json.Mapper
-
Returns a new empty ObjectNode.
- createSaslClient(String[], String, String, String, Map<String, ?>, CallbackHandler) - Method in class com.couchbase.client.core.io.netty.kv.sasl.CouchbaseSaslClientFactory
-
- createSaslClient(String[], String, String, String, Map<String, ?>, CallbackHandler) - Method in class com.couchbase.client.core.io.netty.kv.sasl.ScramSaslClientFactory
-
- createService(ServiceType, int, Optional<String>) - Method in class com.couchbase.client.core.node.Node
-
Helper method to create the
Service
based on the service type provided.
- credentials() - Method in class com.couchbase.client.core.msg.query.QueryRequest
-
- CryptoManager - Interface in com.couchbase.client.core.encryption
-
Provides low-level encryption routines for implementing Field-Level Encryption as specified by
Couchbase RFC-0032.
- currentSeqNo() - Method in class com.couchbase.client.core.msg.kv.ObserveViaSeqnoResponse
-
- customLogger(LoggingEventConsumer.Logger) - Method in class com.couchbase.client.core.env.LoggerConfig.Builder
-
Allows to specify a custom logger.
- customLogger(LoggingEventConsumer.Logger) - Static method in class com.couchbase.client.core.env.LoggerConfig
-
- customLogger() - Method in class com.couchbase.client.core.env.LoggerConfig
-
- data() - Method in class com.couchbase.client.core.msg.analytics.AnalyticsChunkRow
-
- data() - Method in class com.couchbase.client.core.msg.query.QueryChunkRow
-
- data() - Method in class com.couchbase.client.core.msg.search.SearchChunkRow
-
- data() - Method in class com.couchbase.client.core.msg.view.ViewChunkRow
-
- DatasetExistsException - Exception in com.couchbase.client.core.error
-
- DatasetExistsException(ErrorContext) - Constructor for exception com.couchbase.client.core.error.DatasetExistsException
-
- DatasetNotFoundException - Exception in com.couchbase.client.core.error
-
The queried dataset is not found on the server.
- DatasetNotFoundException(ErrorContext) - Constructor for exception com.couchbase.client.core.error.DatasetNotFoundException
-
- datatype(ByteBuf) - Static method in enum com.couchbase.client.core.io.netty.kv.MemcacheProtocol
-
Helper method to return the datatype from a request or response.
- datatype() - Method in enum com.couchbase.client.core.io.netty.kv.MemcacheProtocol.Datatype
-
Returns the datatype byte for the given enum.
- DataverseExistsException - Exception in com.couchbase.client.core.error
-
- DataverseExistsException(ErrorContext) - Constructor for exception com.couchbase.client.core.error.DataverseExistsException
-
- DataverseNotFoundException - Exception in com.couchbase.client.core.error
-
- DataverseNotFoundException(ErrorContext) - Constructor for exception com.couchbase.client.core.error.DataverseNotFoundException
-
- debug(String) - Method in interface com.couchbase.client.core.cnc.LoggingEventConsumer.Logger
-
Log a message at the DEBUG level.
- debug(String, Object...) - Method in interface com.couchbase.client.core.cnc.LoggingEventConsumer.Logger
-
Log a message at the DEBUG level according to the specified format
and arguments.
- debug(String, Throwable) - Method in interface com.couchbase.client.core.cnc.LoggingEventConsumer.Logger
-
Log an exception (throwable) at the DEBUG level with an
accompanying message.
- debug() - Method in class com.couchbase.client.core.msg.view.ViewChunkHeader
-
- decode(FullHttpResponse, HttpChannelContext) - Method in class com.couchbase.client.core.msg.analytics.AnalyticsPingRequest
-
- decode(ResponseStatus, AnalyticsChunkHeader, Flux<AnalyticsChunkRow>, Mono<AnalyticsChunkTrailer>) - Method in class com.couchbase.client.core.msg.analytics.AnalyticsRequest
-
- decode(FullHttpResponse, HttpChannelContext) - Method in class com.couchbase.client.core.msg.analytics.GenericAnalyticsRequest
-
- decode(ResponseStatus, H, Flux<ROW>, Mono<T>) - Method in interface com.couchbase.client.core.msg.chunk.ChunkDecodable
-
Decodes a chunked response into the response format.
- decode(ByteBuf, KeyValueChannelContext) - Method in class com.couchbase.client.core.msg.kv.AppendRequest
-
- decode(ByteBuf, KeyValueChannelContext) - Method in class com.couchbase.client.core.msg.kv.CarrierBucketConfigRequest
-
- decode(ByteBuf, KeyValueChannelContext) - Method in class com.couchbase.client.core.msg.kv.CarrierGlobalConfigRequest
-
- decode(ByteBuf, KeyValueChannelContext) - Method in class com.couchbase.client.core.msg.kv.DecrementRequest
-
- decode(ByteBuf, KeyValueChannelContext) - Method in class com.couchbase.client.core.msg.kv.GetAndLockRequest
-
- decode(ByteBuf, KeyValueChannelContext) - Method in class com.couchbase.client.core.msg.kv.GetAndTouchRequest
-
- decode(ByteBuf, KeyValueChannelContext) - Method in class com.couchbase.client.core.msg.kv.GetCollectionIdRequest
-
- decode(ByteBuf, KeyValueChannelContext) - Method in class com.couchbase.client.core.msg.kv.GetCollectionManifestRequest
-
- decode(ByteBuf, KeyValueChannelContext) - Method in class com.couchbase.client.core.msg.kv.GetMetaRequest
-
- decode(ByteBuf, KeyValueChannelContext) - Method in class com.couchbase.client.core.msg.kv.GetRequest
-
- decode(ByteBuf, KeyValueChannelContext) - Method in class com.couchbase.client.core.msg.kv.IncrementRequest
-
- decode(ByteBuf, KeyValueChannelContext) - Method in class com.couchbase.client.core.msg.kv.InsertRequest
-
- decode(ByteBuf, KeyValueChannelContext) - Method in interface com.couchbase.client.core.msg.kv.KeyValueRequest
-
Decode the encoded response into its message representation.
- decode(ByteBuf, KeyValueChannelContext) - Method in class com.couchbase.client.core.msg.kv.KvPingRequest
-
- decode(ByteBuf, KeyValueChannelContext) - Method in class com.couchbase.client.core.msg.kv.MultiObserveViaCasRequest
-
- decode(ByteBuf, KeyValueChannelContext) - Method in class com.couchbase.client.core.msg.kv.NoopRequest
-
- decode(ByteBuf, KeyValueChannelContext) - Method in class com.couchbase.client.core.msg.kv.ObserveViaCasRequest
-
- decode(ByteBuf, KeyValueChannelContext) - Method in class com.couchbase.client.core.msg.kv.ObserveViaSeqnoRequest
-
- decode(ByteBuf, KeyValueChannelContext) - Method in class com.couchbase.client.core.msg.kv.PrependRequest
-
- decode(ByteBuf, KeyValueChannelContext) - Method in class com.couchbase.client.core.msg.kv.RemoveRequest
-
- decode(ByteBuf, KeyValueChannelContext) - Method in class com.couchbase.client.core.msg.kv.ReplaceRequest
-
- decode(ByteBuf, KeyValueChannelContext) - Method in class com.couchbase.client.core.msg.kv.SubdocGetRequest
-
- decode(ByteBuf, KeyValueChannelContext) - Method in class com.couchbase.client.core.msg.kv.SubdocMutateRequest
-
- decode(ByteBuf, KeyValueChannelContext) - Method in class com.couchbase.client.core.msg.kv.TouchRequest
-
- decode(ByteBuf, KeyValueChannelContext) - Method in class com.couchbase.client.core.msg.kv.UnlockRequest
-
- decode(ByteBuf, KeyValueChannelContext) - Method in class com.couchbase.client.core.msg.kv.UpsertRequest
-
- decode(HttpResponse, byte[]) - Method in class com.couchbase.client.core.msg.manager.BucketConfigRequest
-
- decode(HttpResponse, byte[]) - Method in class com.couchbase.client.core.msg.manager.BucketConfigStreamingRequest
-
- decode(HttpResponse, byte[]) - Method in class com.couchbase.client.core.msg.manager.GenericManagerRequest
-
- decode(HttpResponse, byte[]) - Method in interface com.couchbase.client.core.msg.manager.ManagerRequest
-
Decodes a manager response into its response entity.
- decode(FullHttpResponse, HttpChannelContext) - Method in interface com.couchbase.client.core.msg.NonChunkedHttpRequest
-
- decode(FullHttpResponse, HttpChannelContext) - Method in class com.couchbase.client.core.msg.query.QueryPingRequest
-
- decode(ResponseStatus, QueryChunkHeader, Flux<QueryChunkRow>, Mono<QueryChunkTrailer>) - Method in class com.couchbase.client.core.msg.query.QueryRequest
-
- decode(FullHttpResponse, HttpChannelContext) - Method in class com.couchbase.client.core.msg.search.GenericSearchRequest
-
- decode(FullHttpResponse, HttpChannelContext) - Method in class com.couchbase.client.core.msg.search.SearchPingRequest
-
- decode(ResponseStatus, SearchChunkHeader, Flux<SearchChunkRow>, Mono<SearchChunkTrailer>) - Method in class com.couchbase.client.core.msg.search.SearchRequest
-
- decode(FullHttpResponse, HttpChannelContext) - Method in class com.couchbase.client.core.msg.view.GenericViewRequest
-
- decode(FullHttpResponse, HttpChannelContext) - Method in class com.couchbase.client.core.msg.view.ViewPingRequest
-
- decode(ResponseStatus, ViewChunkHeader, Flux<ViewChunkRow>, Mono<ViewChunkTrailer>) - Method in class com.couchbase.client.core.msg.view.ViewRequest
-
- decode(byte[]) - Static method in class com.couchbase.client.core.util.UnsignedLEB128
-
Given a byte array starting with an unsigned LEB128 value, returns the decoded form
of that value.
- decodeCertificates(List<String>) - Static method in class com.couchbase.client.core.env.SecurityConfig
-
Helper method to decode string-encoded certificates into their x.509 format.
- decodeFromManagementApi(String) - Static method in enum com.couchbase.client.core.msg.kv.DurabilityLevel
-
Decodes the string representation of the durability level from the management API into an enum.
- decodeInto(byte[], Class<T>) - Static method in class com.couchbase.client.core.json.Mapper
-
Decodes a byte array into the given class.
- decodeInto(String, Class<T>) - Static method in class com.couchbase.client.core.json.Mapper
-
Decodes a String into the given class.
- decodeInto(byte[], TypeReference<T>) - Static method in class com.couchbase.client.core.json.Mapper
-
Decodes a byte array into the given type.
- decodeInto(String, TypeReference<T>) - Static method in class com.couchbase.client.core.json.Mapper
-
Decodes a String into the given type.
- decodeIntoTree(byte[]) - Static method in class com.couchbase.client.core.json.Mapper
-
Decodes a byte array into a tree of JSON nodes.
- decodeStatus(HttpResponseStatus) - Static method in class com.couchbase.client.core.io.netty.HttpProtocol
-
Converts the http protocol status into its generic format.
- decodeStatus(ByteBuf) - Static method in enum com.couchbase.client.core.io.netty.kv.MemcacheProtocol
-
Decodes and converts the status from a message.
- decodeStatus(short) - Static method in enum com.couchbase.client.core.io.netty.kv.MemcacheProtocol
-
Converts the KeyValue protocol status into its generic format.
- decodeSubDocumentStatus(short) - Static method in enum com.couchbase.client.core.io.netty.kv.MemcacheProtocol
-
Converts a KeyValue protocol status into its generic format.
- decodingFailure() - Method in class com.couchbase.client.core.io.netty.chunk.BaseChunkResponseParser
-
- decodingFailure() - Method in interface com.couchbase.client.core.io.netty.chunk.ChunkResponseParser
-
If the parser fails due to malformed input the cause is returned here.
- DecodingFailureException - Exception in com.couchbase.client.core.error
-
Raised when provided content could not be successfully decoded.
- DecodingFailureException() - Constructor for exception com.couchbase.client.core.error.DecodingFailureException
-
- DecodingFailureException(String) - Constructor for exception com.couchbase.client.core.error.DecodingFailureException
-
- DecodingFailureException(String, Throwable) - Constructor for exception com.couchbase.client.core.error.DecodingFailureException
-
- DecodingFailureException(Throwable) - Constructor for exception com.couchbase.client.core.error.DecodingFailureException
-
- decrementOutstandingRequests() - Method in class com.couchbase.client.core.endpoint.BaseEndpoint
-
Helper method to decrement outstanding requests, even if they haven't finished yet.
- DecrementRequest - Class in com.couchbase.client.core.msg.kv
-
- DecrementRequest(Duration, CoreContext, CollectionIdentifier, RetryStrategy, String, long, Optional<Long>, long, Optional<DurabilityLevel>, RequestSpan) - Constructor for class com.couchbase.client.core.msg.kv.DecrementRequest
-
- DecrementResponse - Class in com.couchbase.client.core.msg.kv
-
- DecrementResponse(ResponseStatus, long, long, Optional<MutationToken>) - Constructor for class com.couchbase.client.core.msg.kv.DecrementResponse
-
- decrypt(Map<String, Object>) - Method in interface com.couchbase.client.core.encryption.CryptoManager
-
Selects an appropriate decrypter based on the contents of the
encrypted node and uses it to decrypt the data.
- DEFAULT - Static variable in class com.couchbase.client.core.env.NetworkResolution
-
Pick whatever the server returns in the config, this is the
old and backwards compatible mode (server default).
- DEFAULT_ANALYTICS_TIMEOUT - Static variable in class com.couchbase.client.core.env.TimeoutConfig
-
- DEFAULT_COLLECTION - Static variable in class com.couchbase.client.core.io.CollectionIdentifier
-
- DEFAULT_COMPLETION_CALLBACK - Static variable in class com.couchbase.client.core.endpoint.CircuitBreakerConfig
-
- DEFAULT_CONFIG_IDLE_REDIAL_TIMEOUT - Static variable in class com.couchbase.client.core.env.IoConfig
-
- DEFAULT_CONFIG_POLL_INTERVAL - Static variable in class com.couchbase.client.core.env.IoConfig
-
- DEFAULT_CONNECT_TIMEOUT - Static variable in class com.couchbase.client.core.env.TimeoutConfig
-
- DEFAULT_DISCONNECT_TIMEOUT - Static variable in class com.couchbase.client.core.env.TimeoutConfig
-
- DEFAULT_DNS_SECURE_SERVICE - Static variable in class com.couchbase.client.core.util.DnsSrv
-
The default DNS prefix for encrypted connections.
- DEFAULT_DNS_SERVICE - Static variable in class com.couchbase.client.core.util.DnsSrv
-
The default DNS prefix for not encrypted connections.
- DEFAULT_DNS_SRV_ENABLED - Static variable in class com.couchbase.client.core.env.IoConfig
-
- DEFAULT_ENABLED - Static variable in class com.couchbase.client.core.endpoint.CircuitBreakerConfig
-
- DEFAULT_ENABLED - Static variable in class com.couchbase.client.core.env.CompressionConfig
-
- DEFAULT_ENCRYPTED_FIELD_NAME_PREFIX - Static variable in interface com.couchbase.client.core.encryption.CryptoManager
-
The prefix to use when mangling the names of encrypted fields
according to the default name mangling strategy.
- DEFAULT_ENCRYPTER_ALIAS - Static variable in interface com.couchbase.client.core.encryption.CryptoManager
-
The name that refers to the default encrypter if one is present.
- DEFAULT_ENDPOINTS - Static variable in class com.couchbase.client.core.service.KeyValueServiceConfig
-
- DEFAULT_ERROR_THRESHOLD_PERCENTAGE - Static variable in class com.couchbase.client.core.endpoint.CircuitBreakerConfig
-
- DEFAULT_IDLE_HTTP_CONNECTION_TIMEOUT - Static variable in class com.couchbase.client.core.env.IoConfig
-
- DEFAULT_IDLE_TIME - Static variable in class com.couchbase.client.core.service.AbstractPooledEndpointServiceConfig
-
By default, idle pooled endpoints are cleaned up every 4.5 seconds so that
they do not clash with idle socket close attempts by the server.
- DEFAULT_KV_DURABLE_TIMEOUT - Static variable in class com.couchbase.client.core.env.TimeoutConfig
-
- DEFAULT_KV_TIMEOUT - Static variable in class com.couchbase.client.core.env.TimeoutConfig
-
- DEFAULT_MANAGEMENT_TIMEOUT - Static variable in class com.couchbase.client.core.env.TimeoutConfig
-
- DEFAULT_MAX_ENDPOINTS - Static variable in class com.couchbase.client.core.service.AbstractPooledEndpointServiceConfig
-
By default, the maximum number of pooled endpoints is 12 per node.
- DEFAULT_MAX_HTTP_CONNECTIONS - Static variable in class com.couchbase.client.core.env.IoConfig
-
- DEFAULT_MAX_NUM_REQUESTS_IN_RETRY - Static variable in class com.couchbase.client.core.env.CoreEnvironment
-
Default maximum requests being queued in retry before performing backpressure cancellations.
- DEFAULT_MIN_ENDPOINTS - Static variable in class com.couchbase.client.core.service.AbstractPooledEndpointServiceConfig
-
By default, pooled endpoints start with 0 so they do not occupy any resources if not needed.
- DEFAULT_MIN_RATIO - Static variable in class com.couchbase.client.core.env.CompressionConfig
-
- DEFAULT_MIN_SIZE - Static variable in class com.couchbase.client.core.env.CompressionConfig
-
- DEFAULT_MUTATION_TOKENS_ENABLED - Static variable in class com.couchbase.client.core.env.IoConfig
-
- DEFAULT_NATIVE_IO_ENABLED - Static variable in class com.couchbase.client.core.env.IoEnvironment
-
Native IO is enabled by default.
- DEFAULT_NETWORK_RESOLUTION - Static variable in class com.couchbase.client.core.env.IoConfig
-
- DEFAULT_NUM_KV_CONNECTIONS - Static variable in class com.couchbase.client.core.env.IoConfig
-
- DEFAULT_QUERY_TIMEOUT - Static variable in class com.couchbase.client.core.env.TimeoutConfig
-
- DEFAULT_ROLLING_WINDOW - Static variable in class com.couchbase.client.core.endpoint.CircuitBreakerConfig
-
- DEFAULT_SCHEME - Static variable in class com.couchbase.client.core.util.ConnectionString
-
- DEFAULT_SCOPE - Static variable in class com.couchbase.client.core.io.CollectionIdentifier
-
- DEFAULT_SEARCH_TIMEOUT - Static variable in class com.couchbase.client.core.env.TimeoutConfig
-
- DEFAULT_SLEEP_WINDOW - Static variable in class com.couchbase.client.core.endpoint.CircuitBreakerConfig
-
- DEFAULT_TCP_KEEPALIVE_ENABLED - Static variable in class com.couchbase.client.core.env.IoConfig
-
- DEFAULT_TCP_KEEPALIVE_TIME - Static variable in class com.couchbase.client.core.env.IoConfig
-
- DEFAULT_VIEW_TIMEOUT - Static variable in class com.couchbase.client.core.env.TimeoutConfig
-
- DEFAULT_VOLUME_THRESHOLD - Static variable in class com.couchbase.client.core.endpoint.CircuitBreakerConfig
-
- defaultAgentTitle() - Method in class com.couchbase.client.core.env.CoreEnvironment
-
Returns the default user agent name that is used as part of the resulting string.
- DefaultConfigurationProvider - Class in com.couchbase.client.core.config
-
- DefaultConfigurationProvider(Core, Set<SeedNode>) - Constructor for class com.couchbase.client.core.config.DefaultConfigurationProvider
-
Creates a new configuration provider.
- DefaultConfigurationProvider.AlternateAddressHolder - Class in com.couchbase.client.core.config
-
This class is needed since both port info and node info need to be abstracted for alternate address resolving.
- DefaultContext<T> - Class in com.couchbase.client.core.retry.reactor
-
- DefaultContext(T, long, BackoffDelay, long) - Constructor for class com.couchbase.client.core.retry.reactor.DefaultContext
-
- DefaultContext(T, long, BackoffDelay, Throwable) - Constructor for class com.couchbase.client.core.retry.reactor.DefaultContext
-
- DefaultErrorUtil - Class in com.couchbase.client.core.error
-
- DefaultEventBus - Class in com.couchbase.client.core.cnc
-
- DefaultEventBus.Builder - Class in com.couchbase.client.core.cnc
-
- defaultIfNull(T, T) - Static method in class com.couchbase.client.core.util.CbObjects
-
- defaultIfNull(T, Supplier<? extends T>) - Static method in class com.couchbase.client.core.util.CbObjects
-
- DefaultRepeat<T> - Class in com.couchbase.client.core.retry.reactor
-
- DefaultRetry<T> - Class in com.couchbase.client.core.retry.reactor
-
- delay() - Method in class com.couchbase.client.core.retry.reactor.BackoffDelay
-
- deleteBucketConfig(String) - Method in class com.couchbase.client.core.config.ClusterConfig
-
- deleted() - Method in class com.couchbase.client.core.msg.kv.GetMetaResponse
-
Returns true if the deleted flag is set in the extras.
- deleteGlobalConfig() - Method in class com.couchbase.client.core.config.ClusterConfig
-
- DeltaInvalidException - Exception in com.couchbase.client.core.error.subdoc
-
Subdocument exception thrown when the delta in an arithmetic operation (eg counter) is invalid.
- DeltaInvalidException(SubDocumentErrorContext) - Constructor for exception com.couchbase.client.core.error.subdoc.DeltaInvalidException
-
- demangle(String) - Method in interface com.couchbase.client.core.encryption.CryptoManager
-
- deregister(String) - Method in interface com.couchbase.client.core.config.refresher.BucketRefresher
-
Deregisters a bucket from refreshing (stopping the refresh).
- deregister(String) - Method in class com.couchbase.client.core.config.refresher.ClusterManagerBucketRefresher
-
- deregister(String) - Method in class com.couchbase.client.core.config.refresher.KeyValueBucketRefresher
-
- deregister(T) - Method in class com.couchbase.client.core.util.CompositeStateful
-
Deregisters a stateful element from the composite.
- description() - Method in interface com.couchbase.client.core.cnc.Event
-
A textual description with more information about the event.
- description() - Method in class com.couchbase.client.core.cnc.events.config.BucketConfigRefreshFailedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.config.BucketConfigUpdatedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.config.BucketOpenRetriedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.config.CollectionMapDecodingFailedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.config.CollectionMapRefreshFailedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.config.ConfigIgnoredEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.config.GlobalConfigUpdatedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.config.HighIdleHttpConnectionTimeoutConfiguredEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.config.IndividualGlobalConfigLoadFailedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.config.InsecureSecurityConfigDetectedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.config.SeedNodesUpdatedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.core.BucketClosedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.core.BucketOpenedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.core.BucketOpenInitiatedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.core.CoreCreatedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.core.DnsSrvLookupDisabledEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.core.DnsSrvLookupFailedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.core.DnsSrvRecordsLoadedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.core.InitGlobalConfigFailedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.core.ReconfigurationCompletedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.core.ReconfigurationErrorDetectedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.core.ReconfigurationIgnoredEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.core.ServiceReconfigurationFailedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.core.ShutdownCompletedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.core.ShutdownInitiatedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.endpoint.EndpointConnectedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.endpoint.EndpointConnectionAbortedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.endpoint.EndpointConnectionFailedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.endpoint.EndpointConnectionIgnoredEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.endpoint.EndpointDisconnectedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.endpoint.EndpointDisconnectionFailedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.endpoint.EndpointStateChangedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.endpoint.EndpointWriteFailedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.endpoint.UnexpectedEndpointConnectionFailedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.endpoint.UnexpectedEndpointDisconnectedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.io.ChannelClosedProactivelyEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.io.DurabilityTimeoutCoercedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.io.ErrorMapLoadedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.io.ErrorMapLoadingFailedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.io.ErrorMapUndecodableEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.io.FeaturesNegotiatedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.io.FeaturesNegotiationFailedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.io.GenericFailureDetectedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.io.IdleStreamingEndpointClosedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.io.InvalidPacketDetectedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.io.InvalidRequestDetectedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.io.KeyValueErrorMapCodeHandledEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.io.ReadTrafficCapturedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.io.SaslAuthenticationCompletedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.io.SaslAuthenticationFailedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.io.SaslAuthenticationRestartedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.io.SaslMechanismsListedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.io.SaslMechanismsListingFailedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.io.SaslMechanismsSelectedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.io.SecureConnectionFailedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.io.SelectBucketCompletedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.io.SelectBucketFailedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.io.UnknownResponseReceivedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.io.UnknownResponseStatusReceivedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.io.UnknownSaslMechanismDetectedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.io.UnsolicitedFeaturesReturnedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.io.UnsupportedResponseTypeReceivedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.io.WriteTrafficCapturedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.metrics.LatencyMetricsAggregatedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.node.NodeConnectedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.node.NodeDisconnectedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.node.NodeDisconnectIgnoredEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.node.NodeLocatorBugIdentifiedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.node.NodePartitionLengthNotEqualEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.node.NodeStateChangedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.request.IndividualReplicaGetFailedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.request.PreparedStatementRetriedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.request.RequestNotRetriedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.request.RequestRetryScheduledEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.request.SuspiciousExpiryDurationEvent
-
Deprecated.
- description() - Method in class com.couchbase.client.core.cnc.events.service.IdleEndpointRemovedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.service.ServiceAddedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.service.ServiceAddIgnoredEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.service.ServiceConnectInitiatedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.service.ServiceDisconnectInitiatedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.service.ServiceRemovedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.service.ServiceRemoveIgnoredEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.service.ServiceStateChangedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.tracing.OrphanRecordDroppedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.tracing.OrphanReporterFailureDetectedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.tracing.OrphansRecordedEvent
-
- description() - Method in class com.couchbase.client.core.cnc.events.tracing.OverThresholdRequestsRecordedEvent
-
- description() - Method in class com.couchbase.client.core.io.netty.kv.ErrorMap.ErrorCode
-
- DesignDocumentNotFoundException - Exception in com.couchbase.client.core.error
-
- determineNetworkResolution(List<DefaultConfigurationProvider.AlternateAddressHolder>, NetworkResolution, Set<String>) - Static method in class com.couchbase.client.core.config.DefaultConfigurationProvider
-
Helper method to figure out which network resolution should be used.
- diagnosticContextEnabled() - Method in class com.couchbase.client.core.env.LoggerConfig
-
- diagnostics() - Method in class com.couchbase.client.core.Core
-
- diagnostics() - Method in class com.couchbase.client.core.endpoint.BaseEndpoint
-
Collects and assembles the endpoint diagnostics for this specific endpoint.
- diagnostics() - Method in interface com.couchbase.client.core.endpoint.Endpoint
-
Returns diagnostics information for this endpoint.
- diagnostics() - Method in class com.couchbase.client.core.node.Node
-
- diagnostics() - Method in interface com.couchbase.client.core.service.Service
-
Returns diagnostics information for this service.
- DiagnosticsResult - Class in com.couchbase.client.core.diagnostics
-
This report provides insight into the current cluster state from the point of view of the client.
- DiagnosticsResult(Map<ServiceType, List<EndpointDiagnostics>>, String, String) - Constructor for class com.couchbase.client.core.diagnostics.DiagnosticsResult
-
Creates the new diagnostics report.
- disabled() - Static method in class com.couchbase.client.core.env.AggregatingMeterConfig
-
- disableSlf4J(boolean) - Method in class com.couchbase.client.core.env.LoggerConfig.Builder
-
- disableSlf4J(boolean) - Static method in class com.couchbase.client.core.env.LoggerConfig
-
- disableSlf4J() - Method in class com.couchbase.client.core.env.LoggerConfig
-
- disconnect() - Method in class com.couchbase.client.core.endpoint.BaseEndpoint
-
- disconnect() - Method in interface com.couchbase.client.core.endpoint.Endpoint
-
- disconnect() - Method in class com.couchbase.client.core.node.Node
-
Instruct this
Node
to disconnect.
- disconnect() - Method in interface com.couchbase.client.core.service.Service
-
Instruct this
Service
to disconnect.
- disconnectingEndpoints() - Method in class com.couchbase.client.core.cnc.events.service.ServiceDisconnectInitiatedEvent
-
- disconnectTimeout(Duration) - Method in class com.couchbase.client.core.env.TimeoutConfig.Builder
-
Sets the timeout to use for disconnection operations.
- disconnectTimeout(Duration) - Static method in class com.couchbase.client.core.env.TimeoutConfig
-
- disconnectTimeout() - Method in class com.couchbase.client.core.env.TimeoutConfig
-
- discoverConfig(NodeIdentifier, String) - Method in class com.couchbase.client.core.config.loader.BaseBucketLoader
-
To be implemented by the actual child, performs the actual fetching of a config.
- discoverConfig(NodeIdentifier, String) - Method in class com.couchbase.client.core.config.loader.ClusterManagerBucketLoader
-
- discoverConfig(NodeIdentifier, String) - Method in class com.couchbase.client.core.config.loader.KeyValueBucketLoader
-
- dispatch(Request<? extends Response>, List<Node>, ClusterConfig, CoreContext) - Method in class com.couchbase.client.core.node.KeyValueLocator
-
- dispatch(Request<? extends Response>, List<Node>, ClusterConfig, CoreContext) - Method in interface com.couchbase.client.core.node.Locator
-
Given the environment and node information, the implementation locates the right set of
nodes and dispatches the request into them.
- dispatch(Request<? extends Response>, List<Node>, ClusterConfig, CoreContext) - Method in class com.couchbase.client.core.node.RoundRobinLocator
-
- dispatchLatency() - Method in class com.couchbase.client.core.msg.RequestContext
-
Returns the duration of the dispatch phase if set.
- dispatchLatency(long) - Method in class com.couchbase.client.core.msg.RequestContext
-
Allows to set the dispatch duration of the request.
- DnsSrv - Class in com.couchbase.client.core.util
-
- dnsSrvEnabled() - Method in class com.couchbase.client.core.env.IoConfig
-
- DnsSrvLookupDisabledEvent - Class in com.couchbase.client.core.cnc.events.core
-
Raised if dns srv lookup was not performed, either because it has been disabled on the environment or because
the hostname list passed in did not qualify.
- DnsSrvLookupDisabledEvent(boolean, boolean) - Constructor for class com.couchbase.client.core.cnc.events.core.DnsSrvLookupDisabledEvent
-
- DnsSrvLookupFailedEvent - Class in com.couchbase.client.core.cnc.events.core
-
The client attempted a DNS SRV lookup but it failed.
- DnsSrvLookupFailedEvent(Event.Severity, Duration, Throwable, DnsSrvLookupFailedEvent.Reason) - Constructor for class com.couchbase.client.core.cnc.events.core.DnsSrvLookupFailedEvent
-
- DnsSrvLookupFailedEvent.Reason - Enum in com.couchbase.client.core.cnc.events.core
-
- DnsSrvRecordsLoadedEvent - Class in com.couchbase.client.core.cnc.events.core
-
Raised when the SDK could properly load hostnames from a DNS SRV record.
- DnsSrvRecordsLoadedEvent(Duration, List<String>) - Constructor for class com.couchbase.client.core.cnc.events.core.DnsSrvRecordsLoadedEvent
-
- doCleanup() - Method in class com.couchbase.client.core.io.netty.analytics.AnalyticsChunkResponseParser
-
- doCleanup() - Method in class com.couchbase.client.core.io.netty.chunk.BaseChunkResponseParser
-
Give subclasses a chance to reset their state.
- doCleanup() - Method in class com.couchbase.client.core.io.netty.query.QueryChunkResponseParser
-
- doCleanup() - Method in class com.couchbase.client.core.io.netty.search.SearchChunkResponseParser
-
- doCleanup() - Method in class com.couchbase.client.core.io.netty.view.ViewChunkResponseParser
-
- DocumentExistsException - Exception in com.couchbase.client.core.error
-
Indicates an operation failed because the key already exists.
- DocumentExistsException(ErrorContext) - Constructor for exception com.couchbase.client.core.error.DocumentExistsException
-
- DocumentLockedException - Exception in com.couchbase.client.core.error
-
Thrown when the server reports a temporary failure that
is very likely to be lock-related (like an already locked
key or a bad cas used for unlock).
- DocumentLockedException(KeyValueErrorContext) - Constructor for exception com.couchbase.client.core.error.DocumentLockedException
-
- DocumentMutationLostException - Exception in com.couchbase.client.core.error
-
- DocumentNotFoundException - Exception in com.couchbase.client.core.error
-
Indicates an operation failed because the key does not exist.
- DocumentNotFoundException(ErrorContext) - Constructor for exception com.couchbase.client.core.error.DocumentNotFoundException
-
- DocumentNotJsonException - Exception in com.couchbase.client.core.error.subdoc
-
Subdocument exception thrown when the targeted enclosing document itself is not JSON.
- DocumentNotJsonException(SubDocumentErrorContext) - Constructor for exception com.couchbase.client.core.error.subdoc.DocumentNotJsonException
-
- DocumentTooDeepException - Exception in com.couchbase.client.core.error.subdoc
-
Subdocument exception thrown when document is too deep to parse.
- DocumentTooDeepException(SubDocumentErrorContext) - Constructor for exception com.couchbase.client.core.error.subdoc.DocumentTooDeepException
-
- DocumentUnretrievableException - Exception in com.couchbase.client.core.error
-
Indicates an operation completed but no successful document was retrievable.
- DocumentUnretrievableException(ErrorContext) - Constructor for exception com.couchbase.client.core.error.DocumentUnretrievableException
-
- domain() - Method in exception com.couchbase.client.core.error.UserNotFoundException
-
- doOnRepeat(Consumer<? super RepeatContext<T>>) - Method in class com.couchbase.client.core.retry.reactor.DefaultRepeat
-
- doOnRepeat(Consumer<? super RepeatContext<T>>) - Method in interface com.couchbase.client.core.retry.reactor.Repeat
-
Returns a repeat function that invokes the provided onRepeat
callback before every repeat.
- doOnRetry(Consumer<? super RetryContext<T>>) - Method in class com.couchbase.client.core.retry.reactor.DefaultRetry
-
- doOnRetry(Consumer<? super RetryContext<T>>) - Method in interface com.couchbase.client.core.retry.reactor.Retry
-
Returns a retry function that invokes the provided onRetry
callback before every retry.
- doOnValue(String, Consumer<MatchedValue>) - Method in class com.couchbase.client.core.json.stream.JsonStreamParser.Builder
-
Register a callback to invoke when the target of the JSON pointer is found.
- DOUBLE_COMPAT_FLAGS - Static variable in enum com.couchbase.client.core.msg.kv.CodecFlags
-
- DOUBLE_LEGACY_FLAGS - Static variable in enum com.couchbase.client.core.msg.kv.CodecFlags
-
- DurabilityAmbiguousException - Exception in com.couchbase.client.core.error
-
Naming TBD!
The synchronous replication durability work can return an ambiguous error (or we timeout waiting for the response,
which is effectively the same).
- DurabilityAmbiguousException(KeyValueErrorContext) - Constructor for exception com.couchbase.client.core.error.DurabilityAmbiguousException
-
- DurabilityImpossibleException - Exception in com.couchbase.client.core.error
-
The given durability requirements are currently impossible to achieve, as not enough configured replicas
are currently available.
- DurabilityImpossibleException(KeyValueErrorContext) - Constructor for exception com.couchbase.client.core.error.DurabilityImpossibleException
-
- durabilityLevel() - Method in class com.couchbase.client.core.msg.kv.AppendRequest
-
- durabilityLevel() - Method in class com.couchbase.client.core.msg.kv.DecrementRequest
-
- DurabilityLevel - Enum in com.couchbase.client.core.msg.kv
-
Specifies enhanced durability options for the mutation.
- durabilityLevel() - Method in class com.couchbase.client.core.msg.kv.IncrementRequest
-
- durabilityLevel() - Method in class com.couchbase.client.core.msg.kv.InsertRequest
-
- durabilityLevel() - Method in class com.couchbase.client.core.msg.kv.PrependRequest
-
- durabilityLevel() - Method in class com.couchbase.client.core.msg.kv.RemoveRequest
-
- durabilityLevel() - Method in class com.couchbase.client.core.msg.kv.ReplaceRequest
-
- durabilityLevel() - Method in class com.couchbase.client.core.msg.kv.SubdocMutateRequest
-
- durabilityLevel() - Method in interface com.couchbase.client.core.msg.kv.SyncDurabilityRequest
-
Returns the durability level if present.
- durabilityLevel() - Method in class com.couchbase.client.core.msg.kv.UpsertRequest
-
- DurabilityLevelNotAvailableException - Exception in com.couchbase.client.core.error
-
This exception is raised when a durability level has been requested that is not available on the server.
- DurabilityLevelNotAvailableException(KeyValueErrorContext) - Constructor for exception com.couchbase.client.core.error.DurabilityLevelNotAvailableException
-
- DurabilityTimeoutCoercedEvent - Class in com.couchbase.client.core.cnc.events.io
-
This event is raised if a durability timeout has been provided out of the allowed range and is coerced into a
sane and supported value.
- DurabilityTimeoutCoercedEvent(Context, long, long) - Constructor for class com.couchbase.client.core.cnc.events.io.DurabilityTimeoutCoercedEvent
-
- DurableWriteInProgressException - Exception in com.couchbase.client.core.error
-
Returned if an attempt is made to mutate a key which already has a durable write pending.
- DurableWriteInProgressException(KeyValueErrorContext) - Constructor for exception com.couchbase.client.core.error.DurableWriteInProgressException
-
- DurableWriteReCommitInProgressException - Exception in com.couchbase.client.core.error
-
The requested key has a SyncWrite which is being re-committed.
- DurableWriteReCommitInProgressException(KeyValueErrorContext) - Constructor for exception com.couchbase.client.core.error.DurableWriteReCommitInProgressException
-
- duration() - Method in class com.couchbase.client.core.cnc.AbstractEvent
-
- duration() - Method in interface com.couchbase.client.core.cnc.Event
-
Returns the duration of this event.
- duration() - Method in class com.couchbase.client.core.retry.RetryAction
-
If present, the operation should be retried after the given duration.
- emitInterval(Duration) - Method in class com.couchbase.client.core.cnc.tracing.ThresholdRequestTracer.Builder
-
Allows to customize the emit interval
- emitInterval(Duration) - Method in class com.couchbase.client.core.env.AggregatingMeterConfig.Builder
-
Allows to customize the emit interval
- emitInterval(Duration) - Static method in class com.couchbase.client.core.env.AggregatingMeterConfig
-
Allows to customize the emit interval
- emitInterval() - Method in class com.couchbase.client.core.env.AggregatingMeterConfig
-
- emitInterval(Duration) - Method in class com.couchbase.client.core.env.OrphanReporterConfig.Builder
-
Allows to customize the event emit interval
- emitInterval(Duration) - Static method in class com.couchbase.client.core.env.OrphanReporterConfig
-
Allows to customize the event emit interval.
- emitInterval() - Method in class com.couchbase.client.core.env.OrphanReporterConfig
-
Returns the configured emit interval.
- emitInterval(Duration) - Method in class com.couchbase.client.core.env.ThresholdRequestTracerConfig.Builder
-
Allows to customize the emit interval
- emitInterval(Duration) - Static method in class com.couchbase.client.core.env.ThresholdRequestTracerConfig
-
Allows to customize the emit interval
- emitInterval() - Method in class com.couchbase.client.core.env.ThresholdRequestTracerConfig
-
- emitRow(ROW) - Method in class com.couchbase.client.core.io.netty.chunk.BaseChunkResponseParser
-
Emits a single row into the rows flux.
- EMPTY_BYTE_ARRAY - Static variable in class com.couchbase.client.core.util.Bytes
-
Holds an empty byte array, so we do not need to create one every time.
- emptyToNull(String) - Static method in class com.couchbase.client.core.util.CbStrings
-
- enable(boolean) - Method in class com.couchbase.client.core.env.CompressionConfig.Builder
-
If set to false, disabled compression.
- enable(boolean) - Static method in class com.couchbase.client.core.env.CompressionConfig
-
If set to false, disabled compression.
- enabled(boolean) - Method in class com.couchbase.client.core.endpoint.CircuitBreakerConfig.Builder
-
Enables or disables this circuit breaker.
- enabled(boolean) - Static method in class com.couchbase.client.core.endpoint.CircuitBreakerConfig
-
- enabled() - Method in class com.couchbase.client.core.endpoint.CircuitBreakerConfig
-
Returns true if this circuit breaker is enabled.
- enabled(boolean) - Method in class com.couchbase.client.core.env.AggregatingMeterConfig.Builder
-
- enabled(boolean) - Static method in class com.couchbase.client.core.env.AggregatingMeterConfig
-
- enabled() - Method in class com.couchbase.client.core.env.AggregatingMeterConfig
-
- enabled() - Method in class com.couchbase.client.core.env.CompressionConfig
-
True if compression should be enabled, false otherwise.
- enabled(boolean) - Method in class com.couchbase.client.core.env.OrphanReporterConfig.Builder
-
Allows to configure if this reporter is enabled.
- enabled(boolean) - Static method in class com.couchbase.client.core.env.OrphanReporterConfig
-
Allows to configure the status (enabled/disabled) of this reporter.
- enabled() - Method in class com.couchbase.client.core.env.OrphanReporterConfig
-
Returns the status (enabled/disabled).
- enableDiagnosticContext(boolean) - Method in class com.couchbase.client.core.env.LoggerConfig.Builder
-
- enableDiagnosticContext(boolean) - Static method in class com.couchbase.client.core.env.LoggerConfig
-
- enableDnsSrv(boolean) - Method in class com.couchbase.client.core.env.IoConfig.Builder
-
- enableDnsSrv(boolean) - Static method in class com.couchbase.client.core.env.IoConfig
-
- enableHostnameVerification(boolean) - Method in class com.couchbase.client.core.env.SecurityConfig.Builder
-
Allows to enable or disable hostname verification (enabled by default).
- enableHostnameVerification(boolean) - Static method in class com.couchbase.client.core.env.SecurityConfig
-
Allows to enable or disable hostname verification (enabled by default).
- enableMutationTokens(boolean) - Method in class com.couchbase.client.core.env.IoConfig.Builder
-
Configures whether mutation tokens will be returned from the server for all mutation operations.
- enableMutationTokens(boolean) - Static method in class com.couchbase.client.core.env.IoConfig
-
- enableNativeIo(boolean) - Method in class com.couchbase.client.core.env.IoEnvironment.Builder
-
If set to false (enabled by default) will force using the java NIO based IO transport.
- enableNativeIo(boolean) - Static method in class com.couchbase.client.core.env.IoEnvironment
-
If set to false (enabled by default) will force using the java NIO based IO transport.
- enableNativeTls(boolean) - Method in class com.couchbase.client.core.env.SecurityConfig.Builder
-
Enables/disables native TLS (enabled by default).
- enableNativeTls(boolean) - Static method in class com.couchbase.client.core.env.SecurityConfig
-
Enables/disables native TLS (enabled by default).
- enablePlainSaslMechanism() - Method in class com.couchbase.client.core.env.PasswordAuthenticator.Builder
-
- enableTcpKeepAlives(boolean) - Method in class com.couchbase.client.core.env.IoConfig.Builder
-
- enableTcpKeepAlives(boolean) - Static method in class com.couchbase.client.core.env.IoConfig
-
- enableTls(boolean) - Method in class com.couchbase.client.core.env.SecurityConfig.Builder
-
Enables TLS for all client/server communication (disabled by default).
- enableTls(boolean) - Static method in class com.couchbase.client.core.env.SecurityConfig
-
Enables TLS for all client/server communication (disabled by default).
- Encodable<T> - Interface in com.couchbase.client.core.msg
-
- encode() - Method in class com.couchbase.client.core.msg.analytics.AnalyticsPingRequest
-
- encode() - Method in class com.couchbase.client.core.msg.analytics.AnalyticsRequest
-
- encode() - Method in class com.couchbase.client.core.msg.analytics.GenericAnalyticsRequest
-
- encode() - Method in interface com.couchbase.client.core.msg.Encodable
-
- encode(ByteBufAllocator, int, KeyValueChannelContext) - Method in class com.couchbase.client.core.msg.kv.AppendRequest
-
- encode(ByteBufAllocator, int, KeyValueChannelContext) - Method in class com.couchbase.client.core.msg.kv.CarrierBucketConfigRequest
-
- encode(ByteBufAllocator, int, KeyValueChannelContext) - Method in class com.couchbase.client.core.msg.kv.CarrierGlobalConfigRequest
-
- encode(ByteBufAllocator, int, KeyValueChannelContext) - Method in class com.couchbase.client.core.msg.kv.DecrementRequest
-
- encode(ByteBufAllocator, int, KeyValueChannelContext) - Method in class com.couchbase.client.core.msg.kv.GetAndLockRequest
-
- encode(ByteBufAllocator, int, KeyValueChannelContext) - Method in class com.couchbase.client.core.msg.kv.GetAndTouchRequest
-
- encode(ByteBufAllocator, int, KeyValueChannelContext) - Method in class com.couchbase.client.core.msg.kv.GetCollectionIdRequest
-
- encode(ByteBufAllocator, int, KeyValueChannelContext) - Method in class com.couchbase.client.core.msg.kv.GetCollectionManifestRequest
-
- encode(ByteBufAllocator, int, KeyValueChannelContext) - Method in class com.couchbase.client.core.msg.kv.GetMetaRequest
-
- encode(ByteBufAllocator, int, KeyValueChannelContext) - Method in class com.couchbase.client.core.msg.kv.GetRequest
-
- encode(ByteBufAllocator, int, KeyValueChannelContext) - Method in class com.couchbase.client.core.msg.kv.IncrementRequest
-
- encode(ByteBufAllocator, int, KeyValueChannelContext) - Method in class com.couchbase.client.core.msg.kv.InsertRequest
-
- encode(ByteBufAllocator, int, KeyValueChannelContext) - Method in interface com.couchbase.client.core.msg.kv.KeyValueRequest
-
Encode this request with the given allocator and opaque.
- encode(ByteBufAllocator, int, KeyValueChannelContext) - Method in class com.couchbase.client.core.msg.kv.MultiObserveViaCasRequest
-
- encode(ByteBufAllocator, int, KeyValueChannelContext) - Method in class com.couchbase.client.core.msg.kv.NoopRequest
-
- encode(ByteBufAllocator, int, KeyValueChannelContext) - Method in class com.couchbase.client.core.msg.kv.ObserveViaCasRequest
-
- encode(ByteBufAllocator, int, KeyValueChannelContext) - Method in class com.couchbase.client.core.msg.kv.ObserveViaSeqnoRequest
-
- encode(ByteBufAllocator, int, KeyValueChannelContext) - Method in class com.couchbase.client.core.msg.kv.PrependRequest
-
- encode(ByteBufAllocator, int, KeyValueChannelContext) - Method in class com.couchbase.client.core.msg.kv.RemoveRequest
-
- encode(ByteBufAllocator, int, KeyValueChannelContext) - Method in class com.couchbase.client.core.msg.kv.ReplaceRequest
-
- encode(ByteBufAllocator, int, KeyValueChannelContext) - Method in class com.couchbase.client.core.msg.kv.ReplicaGetRequest
-
- encode(ByteBufAllocator) - Method in class com.couchbase.client.core.msg.kv.SubdocGetRequest.Command
-
- encode(ByteBufAllocator, int, KeyValueChannelContext) - Method in class com.couchbase.client.core.msg.kv.SubdocGetRequest
-
- encode(ByteBufAllocator) - Method in class com.couchbase.client.core.msg.kv.SubdocMutateRequest.Command
-
- encode(ByteBufAllocator, int, KeyValueChannelContext) - Method in class com.couchbase.client.core.msg.kv.SubdocMutateRequest
-
- encode(ByteBufAllocator, int, KeyValueChannelContext) - Method in class com.couchbase.client.core.msg.kv.TouchRequest
-
- encode(ByteBufAllocator, int, KeyValueChannelContext) - Method in class com.couchbase.client.core.msg.kv.UnlockRequest
-
- encode(ByteBufAllocator, int, KeyValueChannelContext) - Method in class com.couchbase.client.core.msg.kv.UpsertRequest
-
- encode() - Method in class com.couchbase.client.core.msg.manager.BucketConfigRequest
-
- encode() - Method in class com.couchbase.client.core.msg.manager.BucketConfigStreamingRequest
-
- encode() - Method in class com.couchbase.client.core.msg.manager.GenericManagerRequest
-
- encode() - Method in class com.couchbase.client.core.msg.query.QueryPingRequest
-
- encode() - Method in class com.couchbase.client.core.msg.query.QueryRequest
-
- encode() - Method in class com.couchbase.client.core.msg.search.GenericSearchRequest
-
- encode() - Method in class com.couchbase.client.core.msg.search.SearchPingRequest
-
- encode() - Method in class com.couchbase.client.core.msg.search.SearchRequest
-
- encode() - Method in class com.couchbase.client.core.msg.view.GenericViewRequest
-
- encode() - Method in class com.couchbase.client.core.msg.view.ViewPingRequest
-
- encode() - Method in class com.couchbase.client.core.msg.view.ViewRequest
-
- encode(long) - Static method in class com.couchbase.client.core.util.UnsignedLEB128
-
Returns a byte array containing the unsigned LEB128 representation of the given value.
- encodeAsBytes(Object) - Static method in class com.couchbase.client.core.json.Mapper
-
Encodes the given input into a byte array, formatted non-pretty.
- encodeAsBytesPretty(Object) - Static method in class com.couchbase.client.core.json.Mapper
-
Encodes the given input into a byte array, formatted pretty.
- encodeAsString(Object) - Static method in class com.couchbase.client.core.json.Mapper
-
Encodes the given input into a String, formatted non-pretty.
- encodeAsStringPretty(Object) - Static method in class com.couchbase.client.core.json.Mapper
-
Encodes the given input into a String, formatted pretty.
- encodedExternalKeyWithCollection(ByteBufAllocator, KeyValueChannelContext, byte[]) - Method in class com.couchbase.client.core.msg.kv.BaseKeyValueRequest
-
Encodes a given key with the collection prefix if needed.
- encodedKeyWithCollection(ByteBufAllocator, KeyValueChannelContext) - Method in class com.couchbase.client.core.msg.kv.BaseKeyValueRequest
-
This method returns an encoded key with or without the collection prefix, depending on the
context provided.
- encodeDurationToMs(Duration) - Static method in class com.couchbase.client.core.util.Golang
-
Encodes a Java duration into the encoded golang format.
- encodeForManagementApi() - Method in enum com.couchbase.client.core.msg.kv.DurabilityLevel
-
- encodeLatency() - Method in class com.couchbase.client.core.msg.RequestContext
-
- encodeLatency(long) - Method in class com.couchbase.client.core.msg.RequestContext
-
- EncodingFailureException - Exception in com.couchbase.client.core.error
-
Raised when provided content could not be successfully encoded.
- EncodingFailureException() - Constructor for exception com.couchbase.client.core.error.EncodingFailureException
-
- EncodingFailureException(String) - Constructor for exception com.couchbase.client.core.error.EncodingFailureException
-
- EncodingFailureException(String, Throwable) - Constructor for exception com.couchbase.client.core.error.EncodingFailureException
-
- EncodingFailureException(Throwable) - Constructor for exception com.couchbase.client.core.error.EncodingFailureException
-
- encrypt(byte[], String) - Method in interface com.couchbase.client.core.encryption.CryptoManager
-
Encrypts the given data using the named encrypter.
- end() - Method in interface com.couchbase.client.core.cnc.RequestSpan
-
Completes this span.
- end() - Method in class com.couchbase.client.core.cnc.tracing.NoopRequestSpan
-
- end() - Method in class com.couchbase.client.core.cnc.tracing.ThresholdRequestSpan
-
- endOfInput() - Method in class com.couchbase.client.core.io.netty.chunk.BaseChunkResponseParser
-
- endOfInput() - Method in interface com.couchbase.client.core.io.netty.chunk.ChunkResponseParser
-
Indicates the complete JSON document has been fed to the parser.
- endOfInput() - Method in class com.couchbase.client.core.json.stream.JsonStreamParser
-
Should be called after last chunk of data to parse has been fed.
- Endpoint - Interface in com.couchbase.client.core.endpoint
-
The parent interface for all endpoints.
- EndpointConnectedEvent - Class in com.couchbase.client.core.cnc.events.endpoint
-
This event is published when an endpoint is connected properly.
- EndpointConnectedEvent(Duration, EndpointContext, SortedMap<String, Duration>) - Constructor for class com.couchbase.client.core.cnc.events.endpoint.EndpointConnectedEvent
-
- EndpointConnectionAbortedEvent - Class in com.couchbase.client.core.cnc.events.endpoint
-
This event is published when an endpoint is in the phase of reconnecting because
of an error, but disconnect was called in the meantime and as a result any
further reconnect attempts are aborted.
- EndpointConnectionAbortedEvent(Duration, EndpointContext, SortedMap<String, Duration>) - Constructor for class com.couchbase.client.core.cnc.events.endpoint.EndpointConnectionAbortedEvent
-
- EndpointConnectionFailedEvent - Class in com.couchbase.client.core.cnc.events.endpoint
-
This event is published when an endpoint connect attempt failed.
- EndpointConnectionFailedEvent(Event.Severity, Duration, EndpointContext, long, Throwable) - Constructor for class com.couchbase.client.core.cnc.events.endpoint.EndpointConnectionFailedEvent
-
- EndpointConnectionIgnoredEvent - Class in com.couchbase.client.core.cnc.events.endpoint
-
This event is published when an endpoint is connected properly but
a disconnect signal came before so it is ignored.
- EndpointConnectionIgnoredEvent(Duration, EndpointContext, SortedMap<String, Duration>) - Constructor for class com.couchbase.client.core.cnc.events.endpoint.EndpointConnectionIgnoredEvent
-
- EndpointContext - Class in com.couchbase.client.core.endpoint
-
- EndpointContext(EndpointContext) - Constructor for class com.couchbase.client.core.endpoint.EndpointContext
-
Helper method to duplicate the endpoint context (useful for extension).
- EndpointContext(CoreContext, HostAndPort, CircuitBreaker, ServiceType, Optional<HostAndPort>, Optional<String>, Optional<String>) - Constructor for class com.couchbase.client.core.endpoint.EndpointContext
-
- EndpointDiagnostics - Class in com.couchbase.client.core.diagnostics
-
A diagnostic report for an individual endpoint.
- EndpointDiagnostics(ServiceType, EndpointState, String, String, Optional<String>, Optional<Long>, Optional<String>) - Constructor for class com.couchbase.client.core.diagnostics.EndpointDiagnostics
-
- EndpointDisconnectedEvent - Class in com.couchbase.client.core.cnc.events.endpoint
-
This event is generated when an endpoint is correctly disconnected.
- EndpointDisconnectedEvent(Duration, EndpointContext) - Constructor for class com.couchbase.client.core.cnc.events.endpoint.EndpointDisconnectedEvent
-
Creates a new endpoint disconnected event.
- EndpointDisconnectionFailedEvent - Class in com.couchbase.client.core.cnc.events.endpoint
-
This event is raised if an endpoint disconnect attempt failed for some reason.
- EndpointDisconnectionFailedEvent(Duration, EndpointContext, Throwable) - Constructor for class com.couchbase.client.core.cnc.events.endpoint.EndpointDisconnectionFailedEvent
-
Creates a new endpoint disconnection failed event.
- EndpointPingReport - Class in com.couchbase.client.core.diagnostics
-
- EndpointPingReport(ServiceType, String, String, String, PingState, Optional<String>, Duration, Optional<String>) - Constructor for class com.couchbase.client.core.diagnostics.EndpointPingReport
-
- endpoints() - Method in class com.couchbase.client.core.diagnostics.DiagnosticsResult
-
Returns the diagnostic reports of each individual endpoint.
- endpoints() - Method in class com.couchbase.client.core.diagnostics.PingResult
-
Returns the diagnostic reports of each individual endpoint.
- endpoints(int) - Method in class com.couchbase.client.core.service.KeyValueServiceConfig.Builder
-
- endpoints(int) - Static method in class com.couchbase.client.core.service.KeyValueServiceConfig
-
- EndpointSelectionStrategy - Interface in com.couchbase.client.core.service
-
- EndpointState - Enum in com.couchbase.client.core.endpoint
-
Represents all states an
Endpoint
can be in.
- EndpointStateChangedEvent - Class in com.couchbase.client.core.cnc.events.endpoint
-
This event is raised when an endpoint changes its underlying state.
- EndpointStateChangedEvent(EndpointContext, EndpointState, EndpointState) - Constructor for class com.couchbase.client.core.cnc.events.endpoint.EndpointStateChangedEvent
-
- EndpointWriteFailedEvent - Class in com.couchbase.client.core.cnc.events.endpoint
-
This event is raised if the actual IO write and flush (into netty) failed.
- EndpointWriteFailedEvent(Event.Severity, EndpointContext, Throwable) - Constructor for class com.couchbase.client.core.cnc.events.endpoint.EndpointWriteFailedEvent
-
- ensureServiceAt(NodeIdentifier, ServiceType, int, Optional<String>, Optional<String>) - Method in class com.couchbase.client.core.Core
-
This method can be used by a caller to make sure a certain service is enabled at the given
target node.
- environment() - Method in class com.couchbase.client.core.CoreContext
-
The attached environment for this core.
- ephemeral() - Method in class com.couchbase.client.core.config.CouchbaseBucketConfig
-
- equals(Object) - Method in class com.couchbase.client.core.cnc.metrics.AggregatingValueRecorder
-
- equals(Object) - Method in class com.couchbase.client.core.cnc.metrics.NameAndTags
-
- equals(Object) - Method in class com.couchbase.client.core.config.AlternateAddress
-
- equals(Object) - Method in class com.couchbase.client.core.config.MemcachedBucketConfig
-
- equals(Object) - Method in class com.couchbase.client.core.config.PortInfo
-
- equals(Object) - Method in class com.couchbase.client.core.config.ProposedBucketConfigContext
-
- equals(Object) - Method in class com.couchbase.client.core.config.ProposedGlobalConfigContext
-
- equals(Object) - Method in class com.couchbase.client.core.diagnostics.DiagnosticsResult
-
- equals(Object) - Method in class com.couchbase.client.core.diagnostics.EndpointDiagnostics
-
- equals(Object) - Method in class com.couchbase.client.core.diagnostics.EndpointPingReport
-
- equals(Object) - Method in class com.couchbase.client.core.diagnostics.HealthPinger.PingTarget
-
- equals(Object) - Method in class com.couchbase.client.core.diagnostics.PingResult
-
- equals(Object) - Method in class com.couchbase.client.core.env.NetworkResolution
-
- equals(Object) - Method in class com.couchbase.client.core.env.SeedNode
-
- equals(Object) - Method in class com.couchbase.client.core.io.CollectionIdentifier
-
- equals(Object) - Method in class com.couchbase.client.core.msg.CancellationReason
-
- equals(Object) - Method in class com.couchbase.client.core.msg.kv.MutationToken
-
- equals(Object) - Method in class com.couchbase.client.core.msg.kv.ResponseStatusDetails
-
- equals(Object) - Method in class com.couchbase.client.core.node.Node
-
- equals(Object) - Method in class com.couchbase.client.core.node.NodeIdentifier
-
- equals(Object) - Method in class com.couchbase.client.core.projections.PathArray
-
- equals(Object) - Method in class com.couchbase.client.core.projections.PathObjectOrField
-
- equals(Object) - Method in class com.couchbase.client.core.scheduler.SchedulerClock
-
- equals(Object) - Method in class com.couchbase.client.core.util.HostAndPort
-
- errIfNoCommands(ErrorContext) - Static method in class com.couchbase.client.core.msg.kv.SubdocMutateRequest
-
- errIfTooManyCommands(ErrorContext) - Static method in class com.couchbase.client.core.msg.kv.SubdocMutateRequest
-
- error(String) - Method in interface com.couchbase.client.core.cnc.LoggingEventConsumer.Logger
-
Log a message at the ERROR level.
- error(String, Object...) - Method in interface com.couchbase.client.core.cnc.LoggingEventConsumer.Logger
-
Log a message at the ERROR level according to the specified format
and arguments.
- error(String, Throwable) - Method in interface com.couchbase.client.core.cnc.LoggingEventConsumer.Logger
-
Log an exception (throwable) at the ERROR level with an
accompanying message.
- error() - Method in class com.couchbase.client.core.diagnostics.EndpointPingReport
-
The reason this ping did not succeed.
- error() - Method in class com.couchbase.client.core.error.context.ViewErrorContext
-
- error() - Method in class com.couchbase.client.core.io.netty.analytics.AnalyticsChunkResponseParser
-
- error() - Method in interface com.couchbase.client.core.io.netty.chunk.ChunkResponseParser
-
If the parser sees an error, it should fill this optional so that if the IO
layer needs to fail the topmost future it will be passed in.
- error() - Method in class com.couchbase.client.core.io.netty.query.QueryChunkResponseParser
-
- error() - Method in class com.couchbase.client.core.io.netty.search.SearchChunkResponseParser
-
- error() - Method in class com.couchbase.client.core.io.netty.view.ViewChunkResponseParser
-
- error() - Method in class com.couchbase.client.core.msg.kv.SubdocGetResponse
-
Error will be set, and should be checked and handled, when status==SUBDOC_FAILURE
- error() - Method in class com.couchbase.client.core.msg.kv.SubdocMutateResponse
-
Error will be set, and should be checked and handled, when status==SUBDOC_FAILURE
- error() - Method in class com.couchbase.client.core.msg.kv.SubDocumentField
-
- error() - Method in class com.couchbase.client.core.msg.view.ViewChunkTrailer
-
- error() - Method in class com.couchbase.client.core.msg.view.ViewError
-
- errorCode() - Method in class com.couchbase.client.core.cnc.events.io.KeyValueErrorMapCodeHandledEvent
-
- ErrorCode(String, String, Set<ErrorMap.ErrorAttribute>, ErrorMap.RetrySpecification) - Constructor for class com.couchbase.client.core.io.netty.kv.ErrorMap.ErrorCode
-
Creates a new error code, usually called from jackson.
- ErrorCodeAndMessage - Class in com.couchbase.client.core.error
-
A numeric error code and associated human-readable error message.
- ErrorCodeAndMessage(int, String) - Constructor for class com.couchbase.client.core.error.ErrorCodeAndMessage
-
- ErrorContext - Class in com.couchbase.client.core.error.context
-
The ErrorContext is the parent interface for all service-specific error contexts that are thrown as part of
the
CouchbaseException
.
- ErrorContext(ResponseStatus) - Constructor for class com.couchbase.client.core.error.context.ErrorContext
-
- errorIncompleteResponse() - Static method in class com.couchbase.client.core.msg.analytics.AnalyticsResponse
-
- errorIncompleteResponse() - Static method in class com.couchbase.client.core.msg.query.QueryResponse
-
- errorLogging(Optional<PrintStream>) - Method in class com.couchbase.client.core.cnc.DefaultEventBus.Builder
-
- errorMap() - Method in class com.couchbase.client.core.cnc.events.io.ErrorMapLoadedEvent
-
Returns the error map if present.
- ErrorMap - Class in com.couchbase.client.core.io.netty.kv
-
The
ErrorMap
contains mappings from errors to their attributes, negotiated
between the client and the server.
- ErrorMap(int, int, Map<String, ErrorMap.ErrorCode>) - Constructor for class com.couchbase.client.core.io.netty.kv.ErrorMap
-
Creates a new Error Map, usually called from jackson.
- ErrorMap.ErrorAttribute - Enum in com.couchbase.client.core.io.netty.kv
-
- ErrorMap.ErrorCode - Class in com.couchbase.client.core.io.netty.kv
-
- ErrorMap.RetrySpecification - Class in com.couchbase.client.core.io.netty.kv
-
- ErrorMap.RetryStrategy - Enum in com.couchbase.client.core.io.netty.kv
-
- ErrorMapLoadedEvent - Class in com.couchbase.client.core.cnc.events.io
-
The KV error map got negotiated loaded from the server.
- ErrorMapLoadedEvent(IoContext, Duration, Optional<ErrorMap>) - Constructor for class com.couchbase.client.core.cnc.events.io.ErrorMapLoadedEvent
-
- ErrorMapLoadingFailedEvent - Class in com.couchbase.client.core.cnc.events.io
-
If loading the KV error map for some reason fails, this event will capture
the KV status code.
- ErrorMapLoadingFailedEvent(IoContext, Duration, short) - Constructor for class com.couchbase.client.core.cnc.events.io.ErrorMapLoadingFailedEvent
-
- ErrorMapLoadingHandler - Class in com.couchbase.client.core.io.netty.kv
-
This handler tries to load the KV Error Map in a best effort manner.
- ErrorMapLoadingHandler(EndpointContext) - Constructor for class com.couchbase.client.core.io.netty.kv.ErrorMapLoadingHandler
-
- ErrorMapUndecodableEvent - Class in com.couchbase.client.core.cnc.events.io
-
If the KV error map could be loaded, but the decoding of the
buffer from JSON failed, this event will be raised.
- ErrorMapUndecodableEvent(IoContext, String, String) - Constructor for class com.couchbase.client.core.cnc.events.io.ErrorMapUndecodableEvent
-
- errorProfileNotPresent() - Static method in class com.couchbase.client.core.msg.analytics.AnalyticsResponse
-
- errorProfileNotPresent() - Static method in class com.couchbase.client.core.msg.query.QueryResponse
-
- errors() - Method in exception com.couchbase.client.core.error.AnalyticsException
-
Returns the full list of errors and warnings associated with the exception.
- errors() - Method in class com.couchbase.client.core.error.context.AnalyticsErrorContext
-
- errors() - Method in class com.couchbase.client.core.error.context.QueryErrorContext
-
- errors() - Method in exception com.couchbase.client.core.error.QueryException
-
Returns the full list of errors and warnings associated with the exception.
- errors() - Method in class com.couchbase.client.core.io.netty.kv.ErrorMap
-
- errors() - Method in class com.couchbase.client.core.msg.analytics.AnalyticsChunkTrailer
-
- errors() - Method in class com.couchbase.client.core.msg.query.QueryChunkTrailer
-
- errorSignatureNotPresent() - Static method in class com.couchbase.client.core.msg.analytics.AnalyticsResponse
-
- errorSignatureNotPresent() - Static method in class com.couchbase.client.core.msg.query.QueryResponse
-
- errorThresholdPercentage(int) - Method in class com.couchbase.client.core.endpoint.CircuitBreakerConfig.Builder
-
The percentage of operations that need to fail in a window until the circuit is opened.
- errorThresholdPercentage(int) - Static method in class com.couchbase.client.core.endpoint.CircuitBreakerConfig
-
- errorThresholdPercentage() - Method in class com.couchbase.client.core.endpoint.CircuitBreakerConfig
-
Returns the configured error threshold percentage after which the circuit possibly opens.
- errorWarningsNotPresent() - Static method in class com.couchbase.client.core.msg.query.QueryResponse
-
- Event - Interface in com.couchbase.client.core.cnc
-
The parent interface for all events pushed through the command and
control system.
- Event.Category - Enum in com.couchbase.client.core.cnc
-
Describes the category of any given event.
- Event.Severity - Enum in com.couchbase.client.core.cnc
-
Describes the severity of any given event.
- EventBus - Interface in com.couchbase.client.core.cnc
-
The
EventBus
is the main demarcation line between internal behavior and external
visibility.
- eventBus(EventBus) - Method in class com.couchbase.client.core.env.CoreEnvironment.Builder
-
Customizes the event bus for the SDK.
- eventBus() - Method in class com.couchbase.client.core.env.CoreEnvironment
-
The central event bus which manages all kinds of messages flowing
throughout the client.
- EventBus.PublishResult - Enum in com.couchbase.client.core.cnc
-
Signals if a publish call was successful and if not why.
- eventLoopThreadCount(int) - Method in class com.couchbase.client.core.env.IoEnvironment.Builder
-
Overrides the number of threads used per event loop.
- eventLoopThreadCount(int) - Static method in class com.couchbase.client.core.env.IoEnvironment
-
Overrides the number of threads used per event loop.
- EventSubscription - Class in com.couchbase.client.core.cnc
-
Subscription for a consumer on a
EventBus
that can be used
to unsubscribe once done.
- exception() - Method in class com.couchbase.client.core.retry.reactor.DefaultContext
-
- exception() - Method in interface com.couchbase.client.core.retry.reactor.RetryContext
-
Returns the exception from the last iteration.
- exceptionCaught(ChannelHandlerContext, Throwable) - Method in class com.couchbase.client.core.io.netty.kv.FeatureNegotiatingHandler
-
If there is an exception raised while we are waiting for our connect phase to complete, the error
should be propagated as a cause up the pipeline.
- exceptionCaught(ChannelHandlerContext, Throwable) - Method in class com.couchbase.client.core.io.netty.kv.SaslListMechanismsHandler
-
If there is an exception raised while we are waiting for our connect phase to complete, the error
should be propagated as a cause up the pipeline.
- exceptionCaught(ChannelHandlerContext, Throwable) - Method in class com.couchbase.client.core.io.netty.PipelineErrorHandler
-
- exponential(Duration, Duration, int, boolean) - Static method in interface com.couchbase.client.core.retry.reactor.Backoff
-
Backoff function with exponential backoff delay.
- exponentialBackoff(Duration, Duration) - Method in interface com.couchbase.client.core.retry.reactor.Repeat
-
Returns a repeat function with exponential backoff delay.
- exponentialBackoff(Duration, Duration) - Method in interface com.couchbase.client.core.retry.reactor.Retry
-
Returns a retry function with exponential backoff delay.
- exponentialBackoffWithJitter(Duration, Duration) - Method in interface com.couchbase.client.core.retry.reactor.Repeat
-
Returns a repeat function with full jitter backoff strategy.
- exponentialBackoffWithJitter(Duration, Duration) - Method in interface com.couchbase.client.core.retry.reactor.Retry
-
Returns a retry function with full jitter backoff strategy.
- exportAsMap() - Method in class com.couchbase.client.core.endpoint.CircuitBreakerConfig
-
- exportAsMap() - Method in interface com.couchbase.client.core.service.ServiceConfig
-
- exportAsString(Context.ExportFormat) - Method in class com.couchbase.client.core.cnc.AbstractContext
-
- exportAsString(Context.ExportFormat) - Method in interface com.couchbase.client.core.cnc.Context
-
Export this context into the specified format.
- exportAsString(Context.ExportFormat) - Method in class com.couchbase.client.core.env.CoreEnvironment
-
Export this environment into the specified format.
- exportToJson() - Method in class com.couchbase.client.core.diagnostics.DiagnosticsResult
-
Exports this report into the standard JSON format which is consistent across different SDKs.
- exportToJson() - Method in class com.couchbase.client.core.diagnostics.PingResult
-
Exports this report into the standard JSON format which is consistent across different SDKs.
- EXTERNAL - Static variable in class com.couchbase.client.core.env.NetworkResolution
-
Pins it to external resolution.
- ExternalSupplier<T> - Class in com.couchbase.client.core.env
-
This supplier signals the entity passed in is not owned.
- ExternalSupplier(T) - Constructor for class com.couchbase.client.core.env.ExternalSupplier
-
- extractAlternateAddressInfos(ClusterConfig) - Static method in class com.couchbase.client.core.config.DefaultConfigurationProvider
-
Helper method to turn either the port info or the node info into a list of hosts to use for the
alternate address resolution.
- extractCommonFlags(int) - Static method in enum com.couchbase.client.core.msg.kv.CodecFlags
-
Returns only the common flags from the full flags.
- extractToken(boolean, short, ByteBuf, String) - Static method in enum com.couchbase.client.core.io.netty.kv.MemcacheProtocol
-
Tries to extract the mutation token if the surround msg and environment allows for it.
- extras(ByteBuf) - Static method in enum com.couchbase.client.core.io.netty.kv.MemcacheProtocol
-
- extrasAsInt(ByteBuf, int, int) - Static method in enum com.couchbase.client.core.io.netty.kv.MemcacheProtocol
-
Tries to extract the extras as an integer value and if not possible returns the default value.
- id() - Method in class com.couchbase.client.core.CoreContext
-
A (app local) unique ID per core instance.
- id() - Method in class com.couchbase.client.core.diagnostics.DiagnosticsResult
-
The ID of this report.
- id() - Method in class com.couchbase.client.core.diagnostics.EndpointDiagnostics
-
The ID for this endpoint.
- id() - Method in class com.couchbase.client.core.diagnostics.EndpointPingReport
-
The ID for this endpoint.
- id() - Method in class com.couchbase.client.core.diagnostics.PingResult
-
The ID of this report.
- id() - Method in class com.couchbase.client.core.msg.BaseRequest
-
- id() - Method in interface com.couchbase.client.core.msg.Request
-
Holds a unique ID for each request that is assigned automatically.
- idempotent() - Method in class com.couchbase.client.core.msg.analytics.AnalyticsPingRequest
-
- idempotent() - Method in class com.couchbase.client.core.msg.analytics.AnalyticsRequest
-
- idempotent() - Method in class com.couchbase.client.core.msg.analytics.GenericAnalyticsRequest
-
- idempotent() - Method in class com.couchbase.client.core.msg.kv.CarrierBucketConfigRequest
-
- idempotent() - Method in class com.couchbase.client.core.msg.kv.CarrierGlobalConfigRequest
-
- idempotent() - Method in class com.couchbase.client.core.msg.kv.GetCollectionIdRequest
-
- idempotent() - Method in class com.couchbase.client.core.msg.kv.GetCollectionManifestRequest
-
- idempotent() - Method in class com.couchbase.client.core.msg.kv.GetMetaRequest
-
- idempotent() - Method in class com.couchbase.client.core.msg.kv.GetRequest
-
- idempotent() - Method in class com.couchbase.client.core.msg.kv.MultiObserveViaCasRequest
-
- idempotent() - Method in class com.couchbase.client.core.msg.kv.NoopRequest
-
- idempotent() - Method in class com.couchbase.client.core.msg.kv.ObserveViaCasRequest
-
- idempotent() - Method in class com.couchbase.client.core.msg.kv.ObserveViaSeqnoRequest
-
- idempotent() - Method in class com.couchbase.client.core.msg.kv.SubdocGetRequest
-
- idempotent() - Method in class com.couchbase.client.core.msg.manager.BucketConfigRequest
-
- idempotent() - Method in class com.couchbase.client.core.msg.manager.BucketConfigStreamingRequest
-
- idempotent() - Method in class com.couchbase.client.core.msg.manager.GenericManagerRequest
-
- idempotent() - Method in class com.couchbase.client.core.msg.query.QueryPingRequest
-
- idempotent() - Method in class com.couchbase.client.core.msg.query.QueryRequest
-
- idempotent() - Method in interface com.couchbase.client.core.msg.Request
-
Returns if the given request is idempotent or not.
- idempotent() - Method in class com.couchbase.client.core.msg.search.GenericSearchRequest
-
- idempotent() - Method in class com.couchbase.client.core.msg.search.SearchPingRequest
-
- idempotent() - Method in class com.couchbase.client.core.msg.search.SearchRequest
-
- idempotent() - Method in class com.couchbase.client.core.msg.view.GenericViewRequest
-
- idempotent() - Method in class com.couchbase.client.core.msg.view.ViewPingRequest
-
- idempotent() - Method in class com.couchbase.client.core.msg.view.ViewRequest
-
- ident() - Method in enum com.couchbase.client.core.service.ServiceType
-
- identifier() - Method in enum com.couchbase.client.core.cnc.events.core.DnsSrvLookupFailedEvent.Reason
-
- identifier() - Method in class com.couchbase.client.core.config.NodeInfo
-
- identifier() - Method in class com.couchbase.client.core.config.PortInfo
-
- identifier() - Method in class com.couchbase.client.core.msg.CancellationReason
-
Returns the identifier for this reason.
- identifier() - Method in class com.couchbase.client.core.node.Node
-
Returns the node identifier.
- IdleEndpointRemovedEvent - Class in com.couchbase.client.core.cnc.events.service
-
- IdleEndpointRemovedEvent(EndpointContext) - Constructor for class com.couchbase.client.core.cnc.events.service.IdleEndpointRemovedEvent
-
- idleHttpConnectionTimeout(Duration) - Method in class com.couchbase.client.core.env.IoConfig.Builder
-
- idleHttpConnectionTimeout(Duration) - Static method in class com.couchbase.client.core.env.IoConfig
-
- idleHttpConnectionTimeout() - Method in class com.couchbase.client.core.env.IoConfig
-
- idleSleepDuration(Duration) - Method in class com.couchbase.client.core.cnc.DefaultEventBus.Builder
-
- IdleStreamingEndpointClosedEvent - Class in com.couchbase.client.core.cnc.events.io
-
Raised when a http config streaming connection is closed because of the configured configIdleRedialTimeout.
- IdleStreamingEndpointClosedEvent(IoContext) - Constructor for class com.couchbase.client.core.cnc.events.io.IdleStreamingEndpointClosedEvent
-
- idleTime(Duration) - Method in class com.couchbase.client.core.service.AbstractPooledEndpointServiceConfig.Builder
-
- idleTime() - Method in class com.couchbase.client.core.service.AbstractPooledEndpointServiceConfig
-
- idleTime(Duration) - Static method in class com.couchbase.client.core.service.AnalyticsServiceConfig
-
- idleTime() - Method in class com.couchbase.client.core.service.KeyValueServiceConfig
-
- idleTime(Duration) - Static method in class com.couchbase.client.core.service.QueryServiceConfig
-
- idleTime(Duration) - Static method in class com.couchbase.client.core.service.SearchServiceConfig
-
- idleTime() - Method in interface com.couchbase.client.core.service.ServiceConfig
-
- idleTime(Duration) - Static method in class com.couchbase.client.core.service.ViewServiceConfig
-
- idx() - Method in class com.couchbase.client.core.projections.PathArray
-
- incompleteRequest(KeyValueRequest<?>) - Static method in class com.couchbase.client.core.error.context.KeyValueErrorContext
-
- incrementBy(long) - Method in interface com.couchbase.client.core.cnc.Counter
-
Increments the counter by the given number.
- incrementBy(long) - Method in class com.couchbase.client.core.cnc.metrics.AggregatingCounter
-
- incrementBy(long) - Method in class com.couchbase.client.core.cnc.metrics.NoopCounter
-
- IncrementRequest - Class in com.couchbase.client.core.msg.kv
-
- IncrementRequest(Duration, CoreContext, CollectionIdentifier, RetryStrategy, String, long, Optional<Long>, long, Optional<DurabilityLevel>, RequestSpan) - Constructor for class com.couchbase.client.core.msg.kv.IncrementRequest
-
- IncrementResponse - Class in com.couchbase.client.core.msg.kv
-
- IncrementResponse(ResponseStatus, long, long, Optional<MutationToken>) - Constructor for class com.couchbase.client.core.msg.kv.IncrementResponse
-
- incrementRetryAttempts(Duration, RetryReason) - Method in class com.couchbase.client.core.msg.RequestContext
-
- index() - Method in class com.couchbase.client.core.error.context.SubDocumentErrorContext
-
Returns the index of the spec which triggered the error.
- IndexesNotReadyException - Exception in com.couchbase.client.core.error
-
- IndexesNotReadyException(Map<String, String>) - Constructor for exception com.couchbase.client.core.error.IndexesNotReadyException
-
- IndexExistsException - Exception in com.couchbase.client.core.error
-
- IndexExistsException(ErrorContext) - Constructor for exception com.couchbase.client.core.error.IndexExistsException
-
- IndexFailureException - Exception in com.couchbase.client.core.error
-
Indicates an operation failed because there has been an issue with the query planner or similar.
- IndexFailureException(ErrorContext) - Constructor for exception com.couchbase.client.core.error.IndexFailureException
-
- indexNameToState() - Method in exception com.couchbase.client.core.error.IndexesNotReadyException
-
- IndexNotFoundException - Exception in com.couchbase.client.core.error
-
- IndexNotFoundException(String) - Constructor for exception com.couchbase.client.core.error.IndexNotFoundException
-
- IndexNotFoundException(ErrorContext) - Constructor for exception com.couchbase.client.core.error.IndexNotFoundException
-
- IndividualGlobalConfigLoadFailedEvent - Class in com.couchbase.client.core.cnc.events.config
-
Raised if an individual global config load event failed but it is not raised as a warning because progress
has been made from another host so it can be ignored (but is still relevant for debugging purposes).
- IndividualGlobalConfigLoadFailedEvent(Duration, CoreContext, Throwable, String) - Constructor for class com.couchbase.client.core.cnc.events.config.IndividualGlobalConfigLoadFailedEvent
-
- IndividualReplicaGetFailedEvent - Class in com.couchbase.client.core.cnc.events.request
-
When a replica get fetches more than one in one shot and an individual item fails it
will be ignored, but this event is logged to aid with debugging.
- IndividualReplicaGetFailedEvent(RequestContext) - Constructor for class com.couchbase.client.core.cnc.events.request.IndividualReplicaGetFailedEvent
-
- info(String) - Method in interface com.couchbase.client.core.cnc.LoggingEventConsumer.Logger
-
Log a message at the INFO level.
- info(String, Object...) - Method in interface com.couchbase.client.core.cnc.LoggingEventConsumer.Logger
-
Log a message at the INFO level according to the specified format
and arguments.
- info(String, Throwable) - Method in interface com.couchbase.client.core.cnc.LoggingEventConsumer.Logger
-
Log an exception (throwable) at the INFO level with an
accompanying message.
- init(BaseEndpoint, ChannelPipeline) - Method in class com.couchbase.client.core.endpoint.AnalyticsEndpoint.AnalyticsPipelineInitializer
-
- init(BaseEndpoint, ChannelPipeline) - Method in class com.couchbase.client.core.endpoint.KeyValueEndpoint.KeyValuePipelineInitializer
-
- init(BaseEndpoint, ChannelPipeline) - Method in class com.couchbase.client.core.endpoint.ManagerEndpoint.ManagerPipelineInitializer
-
- init(BaseEndpoint, ChannelPipeline) - Method in interface com.couchbase.client.core.endpoint.PipelineInitializer
-
Initializes the pipeline with the handlers that are part of the implementation.
- init(BaseEndpoint, ChannelPipeline) - Method in class com.couchbase.client.core.endpoint.QueryEndpoint.QueryPipelineInitializer
-
- init(BaseEndpoint, ChannelPipeline) - Method in class com.couchbase.client.core.endpoint.SearchEndpoint.SearchPipelineInitializer
-
- init(BaseEndpoint, ChannelPipeline) - Method in class com.couchbase.client.core.endpoint.ViewEndpoint.ViewPipelineInitializer
-
- initGlobalConfig() - Method in class com.couchbase.client.core.Core
-
Instructs the client to, if possible, load and initialize the global config.
- InitGlobalConfigFailedEvent - Class in com.couchbase.client.core.cnc.events.core
-
Raised when a global config could not be loaded.
- InitGlobalConfigFailedEvent(Event.Severity, Duration, CoreContext, InitGlobalConfigFailedEvent.Reason, Throwable) - Constructor for class com.couchbase.client.core.cnc.events.core.InitGlobalConfigFailedEvent
-
- InitGlobalConfigFailedEvent.Reason - Enum in com.couchbase.client.core.cnc.events.core
-
The reasons why the global config init failed.
- initialize(ChannelConfig) - Method in class com.couchbase.client.core.io.netty.chunk.BaseChunkResponseParser
-
Initializes the parser to a fresh state.
- initialize(ChannelConfig) - Method in interface com.couchbase.client.core.io.netty.chunk.ChunkResponseParser
-
Begins a new parsing session.
- injectExportableParams(Map<String, Object>) - Method in class com.couchbase.client.core.cnc.AbstractContext
-
This method needs to be implemented by the actual context implementations to
inject the params they need for exporting.
- injectExportableParams(Map<String, Object>) - Method in class com.couchbase.client.core.CoreContext
-
- injectExportableParams(Map<String, Object>) - Method in class com.couchbase.client.core.endpoint.EndpointContext
-
- injectExportableParams(Map<String, Object>) - Method in class com.couchbase.client.core.error.context.AggregateErrorContext
-
- injectExportableParams(Map<String, Object>) - Method in class com.couchbase.client.core.error.context.AnalyticsErrorContext
-
- injectExportableParams(Map<String, Object>) - Method in class com.couchbase.client.core.error.context.CancellationErrorContext
-
- injectExportableParams(Map<String, Object>) - Method in class com.couchbase.client.core.error.context.ErrorContext
-
- injectExportableParams(Map<String, Object>) - Method in class com.couchbase.client.core.error.context.GenericRequestErrorContext
-
- injectExportableParams(Map<String, Object>) - Method in class com.couchbase.client.core.error.context.KeyValueErrorContext
-
- injectExportableParams(Map<String, Object>) - Method in class com.couchbase.client.core.error.context.KeyValueIoErrorContext
-
- injectExportableParams(Map<String, Object>) - Method in class com.couchbase.client.core.error.context.QueryErrorContext
-
- injectExportableParams(Map<String, Object>) - Method in class com.couchbase.client.core.error.context.ReducedAnalyticsErrorContext
-
- injectExportableParams(Map<String, Object>) - Method in class com.couchbase.client.core.error.context.ReducedKeyValueErrorContext
-
- injectExportableParams(Map<String, Object>) - Method in class com.couchbase.client.core.error.context.ReducedQueryErrorContext
-
- injectExportableParams(Map<String, Object>) - Method in class com.couchbase.client.core.error.context.ReducedSearchErrorContext
-
- injectExportableParams(Map<String, Object>) - Method in class com.couchbase.client.core.error.context.ReducedViewErrorContext
-
- injectExportableParams(Map<String, Object>) - Method in class com.couchbase.client.core.error.context.SearchErrorContext
-
- injectExportableParams(Map<String, Object>) - Method in class com.couchbase.client.core.error.context.SubDocumentErrorContext
-
- injectExportableParams(Map<String, Object>) - Method in class com.couchbase.client.core.error.context.ViewErrorContext
-
- injectExportableParams(Map<String, Object>) - Method in class com.couchbase.client.core.io.IoContext
-
- injectExportableParams(Map<String, Object>) - Method in class com.couchbase.client.core.msg.RequestContext
-
- injectExportableParams(Map<String, Object>) - Method in class com.couchbase.client.core.node.NodeContext
-
- injectExportableParams(Map<String, Object>) - Method in class com.couchbase.client.core.service.ServiceContext
-
- innerReason() - Method in class com.couchbase.client.core.msg.CancellationReason
-
If applicable, returns an inner reason for the cancellation for additional context.
- InsecureSecurityConfigDetectedEvent - Class in com.couchbase.client.core.cnc.events.config
-
This event is raised if the SDK sees a potentially insecurely configured security config.
- InsecureSecurityConfigDetectedEvent(boolean, boolean) - Constructor for class com.couchbase.client.core.cnc.events.config.InsecureSecurityConfigDetectedEvent
-
- InsertRequest - Class in com.couchbase.client.core.msg.kv
-
Uses the KV "add" command to insert documents if they do not already exist.
- InsertRequest(String, byte[], long, int, Duration, CoreContext, CollectionIdentifier, RetryStrategy, Optional<DurabilityLevel>, RequestSpan) - Constructor for class com.couchbase.client.core.msg.kv.InsertRequest
-
- InsertResponse - Class in com.couchbase.client.core.msg.kv
-
- INSTANCE - Static variable in class com.couchbase.client.core.cnc.tracing.NoopRequestSpan
-
Holds a single, static representation of this span.
- INSTANCE - Static variable in class com.couchbase.client.core.cnc.tracing.NoopRequestTracer
-
Returns the static instance of this tracer.
- INSTANCE - Static variable in class com.couchbase.client.core.endpoint.NoopCircuitBreaker
-
- INSTANCE - Static variable in class com.couchbase.client.core.node.StandardMemcachedHashingStrategy
-
- INSTANCE - Static variable in class com.couchbase.client.core.retry.BestEffortRetryStrategy
-
- INSTANCE - Static variable in class com.couchbase.client.core.retry.FailFastRetryStrategy
-
- instant() - Method in class com.couchbase.client.core.scheduler.SchedulerClock
-
Gets the current instant of the clock.
- InternalServerFailureException - Exception in com.couchbase.client.core.error
-
Indicates an operation failed because there has been an internal error in the server.
- InternalServerFailureException(ErrorContext) - Constructor for exception com.couchbase.client.core.error.InternalServerFailureException
-
- interval() - Method in class com.couchbase.client.core.io.netty.kv.ErrorMap.RetrySpecification
-
- InvalidArgumentException - Exception in com.couchbase.client.core.error
-
- InvalidArgumentException(String, Throwable, ErrorContext) - Constructor for exception com.couchbase.client.core.error.InvalidArgumentException
-
- InvalidPacketDetectedEvent - Class in com.couchbase.client.core.cnc.events.io
-
This event is created if somewhere in the IO layer an invalid packet
was detected.
- InvalidPacketDetectedEvent(IoContext, byte[]) - Constructor for class com.couchbase.client.core.cnc.events.io.InvalidPacketDetectedEvent
-
- InvalidRequestDetectedEvent - Class in com.couchbase.client.core.cnc.events.io
-
If this event is raised, it indicates a serious bug in the system.
- InvalidRequestDetectedEvent(IoContext, ServiceType, Object) - Constructor for class com.couchbase.client.core.cnc.events.io.InvalidRequestDetectedEvent
-
- ioConfig(IoConfig.Builder) - Method in class com.couchbase.client.core.env.CoreEnvironment.Builder
-
Allows to customize various I/O-related configuration properties.
- ioConfig() - Method in class com.couchbase.client.core.env.CoreEnvironment.Builder
-
Returns the currently stored config builder.
- ioConfig() - Method in class com.couchbase.client.core.env.CoreEnvironment
-
Returns the current configuration for all I/O-related settings.
- IoConfig - Class in com.couchbase.client.core.env
-
- IoConfig.Builder - Class in com.couchbase.client.core.env
-
- IoContext - Class in com.couchbase.client.core.io
-
The
IoContext
is used to extend the core context with IO related metadata
that is useful during event generation.
- IoContext(CoreContext, SocketAddress, SocketAddress, Optional<String>) - Constructor for class com.couchbase.client.core.io.IoContext
-
Creates a new IO Context.
- ioEnvironment(IoEnvironment.Builder) - Method in class com.couchbase.client.core.env.CoreEnvironment.Builder
-
Allows to customize I/O thread pools.
- ioEnvironment() - Method in class com.couchbase.client.core.env.CoreEnvironment
-
Holds the environmental configuration/state that is tied to the IO layer.
- IoEnvironment - Class in com.couchbase.client.core.env
-
- IoEnvironment.Builder - Class in com.couchbase.client.core.env
-
- isDebugEnabled() - Method in interface com.couchbase.client.core.cnc.LoggingEventConsumer.Logger
-
Is the logger instance enabled for the DEBUG level.
- isDefault() - Method in class com.couchbase.client.core.io.CollectionIdentifier
-
- isDeleted() - Method in class com.couchbase.client.core.msg.kv.SubdocGetResponse
-
- isErrorEnabled() - Method in interface com.couchbase.client.core.cnc.LoggingEventConsumer.Logger
-
Is the logger instance enabled for the ERROR level.
- isFlexible() - Method in enum com.couchbase.client.core.io.netty.kv.MemcacheProtocol.Magic
-
- isHeaderComplete() - Method in class com.couchbase.client.core.io.netty.chunk.BaseChunkResponseParser
-
Only for use by subclasses.
- isInfoEnabled() - Method in interface com.couchbase.client.core.cnc.LoggingEventConsumer.Logger
-
Is the logger instance enabled for the INFO level.
- isMangled(String) - Method in interface com.couchbase.client.core.encryption.CryptoManager
-
- isNull() - Method in class com.couchbase.client.core.json.stream.MatchedValue
-
- isNullOrEmpty(Collection<?>) - Static method in class com.couchbase.client.core.util.CbCollections
-
- isNullOrEmpty(Map<?, ?>) - Static method in class com.couchbase.client.core.util.CbCollections
-
- isNullOrEmpty(String) - Static method in class com.couchbase.client.core.util.CbCollections
-
- isNullOrEmpty(String) - Static method in class com.couchbase.client.core.util.CbStrings
-
- isRequest() - Method in enum com.couchbase.client.core.io.netty.kv.MemcacheProtocol.Magic
-
- isTraceEnabled() - Method in interface com.couchbase.client.core.cnc.LoggingEventConsumer.Logger
-
Is the logger instance enabled for the TRACE level.
- isValidDnsSrv() - Method in class com.couchbase.client.core.util.ConnectionString
-
Returns true if this connection string qualifies for DNS SRV resolving per spec.
- isWarnEnabled() - Method in interface com.couchbase.client.core.cnc.LoggingEventConsumer.Logger
-
Is the logger instance enabled for the WARN level.
- iteration() - Method in class com.couchbase.client.core.retry.reactor.DefaultContext
-
- iteration() - Method in interface com.couchbase.client.core.retry.reactor.IterationContext
-
The next iteration number.
- IterationContext<T> - Interface in com.couchbase.client.core.retry.reactor
-
Context provided to retry or repeat callbacks.
- magic() - Method in enum com.couchbase.client.core.io.netty.kv.MemcacheProtocol.Magic
-
Returns the magic for the given command.
- managementTimeout(Duration) - Method in class com.couchbase.client.core.env.TimeoutConfig.Builder
-
Sets the timeout to use for manager operations.
- managementTimeout(Duration) - Static method in class com.couchbase.client.core.env.TimeoutConfig
-
- managementTimeout() - Method in class com.couchbase.client.core.env.TimeoutConfig
-
- managerCircuitBreakerConfig(CircuitBreakerConfig.Builder) - Method in class com.couchbase.client.core.env.IoConfig.Builder
-
- managerCircuitBreakerConfig() - Method in class com.couchbase.client.core.env.IoConfig.Builder
-
- managerCircuitBreakerConfig(CircuitBreakerConfig.Builder) - Static method in class com.couchbase.client.core.env.IoConfig
-
- managerCircuitBreakerConfig() - Method in class com.couchbase.client.core.env.IoConfig
-
- ManagerEndpoint - Class in com.couchbase.client.core.endpoint
-
- ManagerEndpoint(ServiceContext, String, int) - Constructor for class com.couchbase.client.core.endpoint.ManagerEndpoint
-
- ManagerEndpoint.ManagerPipelineInitializer - Class in com.couchbase.client.core.endpoint
-
- managerEventLoopGroup(EventLoopGroup) - Method in class com.couchbase.client.core.env.IoEnvironment.Builder
-
Allows to specify a custom event loop group (I/O event loop thread pool) for the management service.
- managerEventLoopGroup(EventLoopGroup) - Static method in class com.couchbase.client.core.env.IoEnvironment
-
Allows to specify a custom event loop group (I/O event loop thread pool) for the management service.
- managerEventLoopGroup() - Method in class com.couchbase.client.core.env.IoEnvironment
-
Returns the EventLoopGroup
to be used for config traffic.
- ManagerMessageHandler - Class in com.couchbase.client.core.io.netty.manager
-
This handler dispatches requests and responses against the cluster manager service.
- ManagerMessageHandler(BaseEndpoint, CoreContext) - Constructor for class com.couchbase.client.core.io.netty.manager.ManagerMessageHandler
-
- ManagerPipelineInitializer(EndpointContext) - Constructor for class com.couchbase.client.core.endpoint.ManagerEndpoint.ManagerPipelineInitializer
-
- managerPort() - Method in class com.couchbase.client.core.node.NodeIdentifier
-
- ManagerRequest<R extends Response> - Interface in com.couchbase.client.core.msg.manager
-
Parent interface for all requests going to the cluster manager.
- ManagerService - Class in com.couchbase.client.core.service
-
- ManagerService(CoreContext, String, int) - Constructor for class com.couchbase.client.core.service.ManagerService
-
- mangle(String) - Method in interface com.couchbase.client.core.encryption.CryptoManager
-
Transforms the given field name to indicate its value is encrypted.
- manifest() - Method in class com.couchbase.client.core.msg.kv.GetCollectionManifestResponse
-
- mapOf() - Static method in class com.couchbase.client.core.util.CbCollections
-
Returns an unmodifiable empty map.
- mapOf(K, V) - Static method in class com.couchbase.client.core.util.CbCollections
-
Returns an unmodifiable map containing the given key/value pairs.
- mapOf(K, V, K, V) - Static method in class com.couchbase.client.core.util.CbCollections
-
Returns an unmodifiable map containing the given key/value pairs.
- mapOf(K, V, K, V, K, V) - Static method in class com.couchbase.client.core.util.CbCollections
-
Returns an unmodifiable map containing the given key/value pairs.
- mapOf(K, V, K, V, K, V, K, V) - Static method in class com.couchbase.client.core.util.CbCollections
-
Returns an unmodifiable map containing the given key/value pairs.
- mapOf(K, V, K, V, K, V, K, V, K, V) - Static method in class com.couchbase.client.core.util.CbCollections
-
Returns an unmodifiable map containing the given key/value pairs.
- Mapper - Class in com.couchbase.client.core.json
-
Provides utilities for encoding and decoding JSON data.
- MapperException - Exception in com.couchbase.client.core.json
-
This exception is usually raised when a JSON encoding or decoding was not successful.
- mapSubDocumentError(KeyValueRequest<?>, SubDocumentOpResponseStatus, String, int) - Static method in enum com.couchbase.client.core.io.netty.kv.MemcacheProtocol
-
For any response that can be returned by a SubDocument command - path, document, or execution-based - map it to
an appropriate SubDocumentException.
- markFailure() - Method in interface com.couchbase.client.core.endpoint.CircuitBreaker
-
The tracked request is marked failure.
- markFailure() - Method in class com.couchbase.client.core.endpoint.NoopCircuitBreaker
-
- markHeaderComplete() - Method in class com.couchbase.client.core.io.netty.chunk.BaseChunkResponseParser
-
- markRequestCompletion() - Method in class com.couchbase.client.core.endpoint.BaseEndpoint
-
Called from the event loop handlers to mark a request as being completed.
- markSuccess() - Method in interface com.couchbase.client.core.endpoint.CircuitBreaker
-
The tracked request is marked succeeded.
- markSuccess() - Method in class com.couchbase.client.core.endpoint.NoopCircuitBreaker
-
- markTainted(String) - Method in interface com.couchbase.client.core.config.refresher.BucketRefresher
-
Marks the bucket as tainted, which will change the behavior of the refresher.
- markTainted(String) - Method in class com.couchbase.client.core.config.refresher.ClusterManagerBucketRefresher
-
No action needed when a config is marked as tainted for the cluster manager
refresher, since the server pushes new configs anyways during rebalance.
- markTainted(String) - Method in class com.couchbase.client.core.config.refresher.KeyValueBucketRefresher
-
- markUntainted(String) - Method in interface com.couchbase.client.core.config.refresher.BucketRefresher
-
Marks the bucket as untainted, which will change the behavior of the refresher.
- markUntainted(String) - Method in class com.couchbase.client.core.config.refresher.ClusterManagerBucketRefresher
-
No action needed when a config is marked as untainted for the cluster manager
refresher, since the server pushes new configs anyways during rebalance.
- markUntainted(String) - Method in class com.couchbase.client.core.config.refresher.KeyValueBucketRefresher
-
- MatchedValue - Class in com.couchbase.client.core.json.stream
-
- maxDelay() - Method in class com.couchbase.client.core.retry.reactor.BackoffDelay
-
- maxDuration() - Method in class com.couchbase.client.core.io.netty.kv.ErrorMap.RetrySpecification
-
- maxEndpoints(int) - Method in class com.couchbase.client.core.service.AbstractPooledEndpointServiceConfig.Builder
-
- maxEndpoints() - Method in class com.couchbase.client.core.service.AbstractPooledEndpointServiceConfig
-
- maxEndpoints(int) - Static method in class com.couchbase.client.core.service.AnalyticsServiceConfig
-
- maxEndpoints() - Method in class com.couchbase.client.core.service.KeyValueServiceConfig
-
- maxEndpoints(int) - Static method in class com.couchbase.client.core.service.QueryServiceConfig
-
- maxEndpoints(int) - Static method in class com.couchbase.client.core.service.SearchServiceConfig
-
- maxEndpoints() - Method in interface com.couchbase.client.core.service.ServiceConfig
-
- maxEndpoints(int) - Static method in class com.couchbase.client.core.service.ViewServiceConfig
-
- maxExpiry() - Method in class com.couchbase.client.core.config.CollectionsManifestCollection
-
- maxHttpConnections(int) - Method in class com.couchbase.client.core.env.IoConfig.Builder
-
- maxHttpConnections(int) - Static method in class com.couchbase.client.core.env.IoConfig
-
- maxHttpConnections() - Method in class com.couchbase.client.core.env.IoConfig
-
- maxNumRequestsInRetry(long) - Method in class com.couchbase.client.core.env.CoreEnvironment.Builder
-
Allows to customize the maximum number of requests allowed in the retry timer.
- maxScore() - Method in class com.couchbase.client.core.msg.search.SearchChunkTrailer
-
- maybeRetry(CoreContext, Request<? extends Response>, RetryReason) - Static method in class com.couchbase.client.core.retry.RetryOrchestrator
-
Retry or cancel the given request, depending on its state and the configured
RetryStrategy
.
- mech() - Method in enum com.couchbase.client.core.env.SaslMechanism
-
Returns the "raw" string representation of the mechanism on the wire.
- mechanism() - Method in class com.couchbase.client.core.cnc.events.io.UnknownSaslMechanismDetectedEvent
-
Returns the unknown mechanism.
- MemcachedBucketConfig - Class in com.couchbase.client.core.config
-
- MemcachedBucketConfig(CoreEnvironment, long, String, String, String, String, List<NodeInfo>, List<PortInfo>, List<BucketCapabilities>, Map<String, Set<ClusterCapabilities>>, String) - Constructor for class com.couchbase.client.core.config.MemcachedBucketConfig
-
- MemcachedHashingStrategy - Interface in com.couchbase.client.core.node
-
This interface defines different hashing strategies used for ketama hashing in memcached buckets.
- MemcacheProtocol - Enum in com.couchbase.client.core.io.netty.kv
-
The
MemcacheProtocol
class holds static helpers that deal with the encoding
and decoding as well as access of the memcache binary protocol.
- MemcacheProtocol.Datatype - Enum in com.couchbase.client.core.io.netty.kv
-
- MemcacheProtocol.Magic - Enum in com.couchbase.client.core.io.netty.kv
-
- MemcacheProtocol.Opcode - Enum in com.couchbase.client.core.io.netty.kv
-
Contains all known/used kv protocol opcodes.
- MemcacheProtocol.Status - Enum in com.couchbase.client.core.io.netty.kv
-
- MemcacheProtocolDecodeHandler - Class in com.couchbase.client.core.io.netty.kv
-
The
MemcacheProtocolDecodeHandler
is a lightweight decoder that understands the
KV header and aggregates header and value into one buffer before passing it on.
- MemcacheProtocolDecodeHandler() - Constructor for class com.couchbase.client.core.io.netty.kv.MemcacheProtocolDecodeHandler
-
- MemcacheProtocolVerificationHandler - Class in com.couchbase.client.core.io.netty.kv
-
This handler makes sure that the KV protocol packets passed around
are not malformed.
- MemcacheProtocolVerificationHandler(EndpointContext) - Constructor for class com.couchbase.client.core.io.netty.kv.MemcacheProtocolVerificationHandler
-
- message() - Method in class com.couchbase.client.core.cnc.events.io.ErrorMapUndecodableEvent
-
Returns the error message in string form.
- message() - Method in class com.couchbase.client.core.cnc.events.io.InvalidRequestDetectedEvent
-
- message() - Method in class com.couchbase.client.core.error.ErrorCodeAndMessage
-
- message() - Method in class com.couchbase.client.core.logging.RedactableArgument
-
The message of this redactable argument.
- messageToString(ByteBuf) - Static method in enum com.couchbase.client.core.io.netty.kv.MemcacheProtocol
-
Helper method during development and debugging to dump the raw message as a
verbose string.
- Meter - Interface in com.couchbase.client.core.cnc
-
The generic interface for all metric implementations in the client.
- meter(Meter) - Method in class com.couchbase.client.core.env.CoreEnvironment.Builder
-
Allows to configure a custom metrics implementation.
- meter() - Method in class com.couchbase.client.core.env.CoreEnvironment
-
- metrics() - Method in class com.couchbase.client.core.msg.analytics.AnalyticsChunkTrailer
-
- metrics() - Method in class com.couchbase.client.core.msg.query.QueryChunkTrailer
-
- millis() - Method in class com.couchbase.client.core.scheduler.SchedulerClock
-
- minDelay() - Method in class com.couchbase.client.core.retry.reactor.BackoffDelay
-
- minEndpoints(int) - Method in class com.couchbase.client.core.service.AbstractPooledEndpointServiceConfig.Builder
-
- minEndpoints() - Method in class com.couchbase.client.core.service.AbstractPooledEndpointServiceConfig
-
- minEndpoints(int) - Static method in class com.couchbase.client.core.service.AnalyticsServiceConfig
-
- minEndpoints() - Method in class com.couchbase.client.core.service.KeyValueServiceConfig
-
- minEndpoints(int) - Static method in class com.couchbase.client.core.service.QueryServiceConfig
-
- minEndpoints(int) - Static method in class com.couchbase.client.core.service.SearchServiceConfig
-
- minEndpoints() - Method in interface com.couchbase.client.core.service.ServiceConfig
-
- minEndpoints(int) - Static method in class com.couchbase.client.core.service.ViewServiceConfig
-
- minimumEndpoints() - Method in class com.couchbase.client.core.cnc.events.service.ServiceConnectInitiatedEvent
-
- minRatio(double) - Method in class com.couchbase.client.core.env.CompressionConfig.Builder
-
The minimum ratio after which a compressed doc is sent compressed
versus the uncompressed version is sent for efficiency.
- minRatio(double) - Static method in class com.couchbase.client.core.env.CompressionConfig
-
The minimum ratio after which a compressed doc is sent compressed
versus the uncompressed version is sent for efficiency.
- minRatio() - Method in class com.couchbase.client.core.env.CompressionConfig
-
Returns the minimum effective ratio to send when compressed.
- minSize(int) - Method in class com.couchbase.client.core.env.CompressionConfig.Builder
-
The minimum size after which compression is performed.
- minSize(int) - Static method in class com.couchbase.client.core.env.CompressionConfig
-
The minimum size after which compression is performed.
- minSize() - Method in class com.couchbase.client.core.env.CompressionConfig
-
Returns the minimum configured compression size.
- msg() - Method in exception com.couchbase.client.core.error.QueryException
-
Returns a human-readable description of the error, as reported by the query service.
- MultiObserveViaCasRequest - Class in com.couchbase.client.core.msg.kv
-
Special observe request implementation to handle more than one key at the same time.
- MultiObserveViaCasRequest(Duration, CoreContext, RetryStrategy, CollectionIdentifier, NodeIdentifier, Map<byte[], Short>, Predicate<ObserveViaCasResponse.ObserveStatus>) - Constructor for class com.couchbase.client.core.msg.kv.MultiObserveViaCasRequest
-
- MultiObserveViaCasResponse - Class in com.couchbase.client.core.msg.kv
-
- MultiObserveViaCasResponse(ResponseStatus, Map<byte[], ObserveViaCasResponse.ObserveStatus>) - Constructor for class com.couchbase.client.core.msg.kv.MultiObserveViaCasResponse
-
- mutationToken() - Method in class com.couchbase.client.core.msg.kv.AppendResponse
-
- mutationToken() - Method in class com.couchbase.client.core.msg.kv.DecrementResponse
-
- mutationToken() - Method in class com.couchbase.client.core.msg.kv.IncrementResponse
-
- mutationToken() - Method in class com.couchbase.client.core.msg.kv.InsertResponse
-
- MutationToken - Class in com.couchbase.client.core.msg.kv
-
Value object to contain partition details and sequence number.
- MutationToken(short, long, long, String) - Constructor for class com.couchbase.client.core.msg.kv.MutationToken
-
- mutationToken() - Method in class com.couchbase.client.core.msg.kv.PrependResponse
-
- mutationToken() - Method in class com.couchbase.client.core.msg.kv.RemoveResponse
-
- mutationToken() - Method in class com.couchbase.client.core.msg.kv.ReplaceResponse
-
- mutationToken() - Method in class com.couchbase.client.core.msg.kv.SubdocMutateResponse
-
- mutationToken() - Method in class com.couchbase.client.core.msg.kv.TouchResponse
-
- mutationToken() - Method in class com.couchbase.client.core.msg.kv.UnlockResponse
-
- mutationToken() - Method in class com.couchbase.client.core.msg.kv.UpsertResponse
-
- mutationToken() - Method in class com.couchbase.client.core.service.kv.ObserveContext
-
- mutationTokensEnabled() - Method in class com.couchbase.client.core.env.IoConfig
-
- mutationTokensEnabled() - Method in class com.couchbase.client.core.io.netty.kv.KeyValueChannelContext
-
- name() - Method in class com.couchbase.client.core.cnc.events.core.BucketClosedEvent
-
- name() - Method in class com.couchbase.client.core.cnc.events.core.BucketOpenedEvent
-
- name() - Method in class com.couchbase.client.core.cnc.events.core.BucketOpenInitiatedEvent
-
- name() - Method in class com.couchbase.client.core.config.AbstractBucketConfig
-
- name() - Method in interface com.couchbase.client.core.config.BucketConfig
-
The name of the bucket.
- name() - Method in class com.couchbase.client.core.config.CollectionsManifestCollection
-
- name() - Method in class com.couchbase.client.core.config.CollectionsManifestScope
-
- name() - Method in class com.couchbase.client.core.env.NetworkResolution
-
Returns the wire representation of the network resolution setting.
- name() - Method in class com.couchbase.client.core.env.UserAgent
-
- name() - Method in exception com.couchbase.client.core.error.DesignDocumentNotFoundException
-
- name() - Method in class com.couchbase.client.core.io.netty.kv.ErrorMap.ErrorCode
-
- name() - Method in class com.couchbase.client.core.msg.kv.GetAndLockRequest
-
- name() - Method in class com.couchbase.client.core.msg.kv.GetAndTouchRequest
-
- name() - Method in class com.couchbase.client.core.msg.kv.GetMetaRequest
-
- name() - Method in class com.couchbase.client.core.msg.kv.ObserveViaSeqnoRequest
-
- name() - Method in class com.couchbase.client.core.msg.kv.ReplicaGetRequest
-
- name() - Method in class com.couchbase.client.core.msg.kv.SubdocGetRequest
-
- name() - Method in class com.couchbase.client.core.msg.kv.SubdocMutateRequest
-
- name() - Method in interface com.couchbase.client.core.msg.Request
-
The unique name of the request, usually related to the type but not necessarily.
- name() - Method in class com.couchbase.client.core.msg.view.ViewRequest
-
- NameAndTags - Class in com.couchbase.client.core.cnc.metrics
-
Helper class which consolidates names and tags for caching purposes.
- NameAndTags(String, Map<String, String>) - Constructor for class com.couchbase.client.core.cnc.metrics.NameAndTags
-
- namespace() - Method in class com.couchbase.client.core.diagnostics.EndpointDiagnostics
-
The namespace of this endpoint (likely the bucket name if present).
- namespace() - Method in class com.couchbase.client.core.diagnostics.EndpointPingReport
-
The namespace of this endpoint (likely the bucket name if present).
- namespace() - Method in exception com.couchbase.client.core.error.DesignDocumentNotFoundException
-
- nativeIoEnabled() - Method in class com.couchbase.client.core.env.IoEnvironment
-
Returns true if native IO is enabled and can be used if supported.
- nativeTlsEnabled() - Method in class com.couchbase.client.core.env.SecurityConfig
-
Returns whether native TLS is enabled.
- negotiated() - Method in class com.couchbase.client.core.cnc.events.io.FeaturesNegotiatedEvent
-
Returns the negotiated server features for this connection.
- networkResolution(NetworkResolution) - Method in class com.couchbase.client.core.env.IoConfig.Builder
-
- networkResolution(NetworkResolution) - Static method in class com.couchbase.client.core.env.IoConfig
-
- networkResolution() - Method in class com.couchbase.client.core.env.IoConfig
-
- NetworkResolution - Class in com.couchbase.client.core.env
-
Configuration options for the network resolution setting.
- newState() - Method in class com.couchbase.client.core.cnc.events.endpoint.EndpointStateChangedEvent
-
- newState() - Method in class com.couchbase.client.core.cnc.events.node.NodeStateChangedEvent
-
- newState() - Method in class com.couchbase.client.core.cnc.events.service.ServiceStateChangedEvent
-
- nextOpaque() - Static method in class com.couchbase.client.core.msg.kv.BaseKeyValueRequest
-
- NO_JITTER - Static variable in interface com.couchbase.client.core.retry.reactor.Jitter
-
- NO_PRIORITY - Static variable in class com.couchbase.client.core.msg.analytics.AnalyticsRequest
-
- noBackoff() - Method in interface com.couchbase.client.core.retry.reactor.Repeat
-
Returns a repeat function with no backoff delay.
- noBackoff() - Method in interface com.couchbase.client.core.retry.reactor.Retry
-
Returns a retry function with no backoff delay.
- noBody() - Static method in enum com.couchbase.client.core.io.netty.kv.MemcacheProtocol
-
Helper to express no body is used for this message.
- noCas() - Static method in enum com.couchbase.client.core.io.netty.kv.MemcacheProtocol
-
Helper to express no cas is used for this message.
- noDatatype() - Static method in enum com.couchbase.client.core.io.netty.kv.MemcacheProtocol
-
Helper to express no datatype is used for this message.
- Node - Class in com.couchbase.client.core.node
-
- Node(CoreContext, NodeIdentifier, Optional<String>) - Constructor for class com.couchbase.client.core.node.Node
-
- nodeAtIndex(int) - Method in class com.couchbase.client.core.config.CouchbaseBucketConfig
-
- nodeCanBeUsed(Node, Request<? extends Response>, ClusterConfig) - Method in class com.couchbase.client.core.node.RoundRobinLocator
-
- nodeCanBeUsed(Node, Request<? extends Response>, ClusterConfig) - Method in class com.couchbase.client.core.node.ViewLocator
-
In addition to checking that the view service is enabled, for view dispatching it is vital that
a request is only ever sent to a node which has active primary KV partitions.
- NodeConnectedEvent - Class in com.couchbase.client.core.cnc.events.node
-
This event is generated when a node is correctly connected.
- NodeConnectedEvent(Duration, NodeContext) - Constructor for class com.couchbase.client.core.cnc.events.node.NodeConnectedEvent
-
Creates a new node connected event.
- NodeContext - Class in com.couchbase.client.core.node
-
- NodeContext(CoreContext, NodeIdentifier, Optional<String>) - Constructor for class com.couchbase.client.core.node.NodeContext
-
- NodeDisconnectedEvent - Class in com.couchbase.client.core.cnc.events.node
-
This event is generated when a node is correctly disconnected.
- NodeDisconnectedEvent(Duration, NodeContext) - Constructor for class com.couchbase.client.core.cnc.events.node.NodeDisconnectedEvent
-
Creates a new node disconnected event.
- NodeDisconnectIgnoredEvent - Class in com.couchbase.client.core.cnc.events.node
-
- NodeDisconnectIgnoredEvent(Event.Severity, NodeDisconnectIgnoredEvent.Reason, Context) - Constructor for class com.couchbase.client.core.cnc.events.node.NodeDisconnectIgnoredEvent
-
- NodeDisconnectIgnoredEvent.Reason - Enum in com.couchbase.client.core.cnc.events.node
-
Enumerates the reasons why a disconnect nod event could be ignored by the system.
- nodeForId(byte[]) - Method in class com.couchbase.client.core.config.MemcachedBucketConfig
-
- nodeIdentifier() - Method in class com.couchbase.client.core.diagnostics.HealthPinger.PingTarget
-
- NodeIdentifier - Class in com.couchbase.client.core.node
-
Identifies a node uniquely in the cluster.
- NodeIdentifier(String, int) - Constructor for class com.couchbase.client.core.node.NodeIdentifier
-
- nodeIndexForActive(int, boolean) - Method in class com.couchbase.client.core.config.CouchbaseBucketConfig
-
- nodeIndexForReplica(int, int, boolean) - Method in class com.couchbase.client.core.config.CouchbaseBucketConfig
-
- NodeInfo - Class in com.couchbase.client.core.config
-
- NodeInfo(String, String, Map<String, Integer>, Map<String, AlternateAddress>) - Constructor for class com.couchbase.client.core.config.NodeInfo
-
Creates a new
NodeInfo
with no SSL services.
- NodeInfo(String, Map<ServiceType, Integer>, Map<ServiceType, Integer>, Map<String, AlternateAddress>) - Constructor for class com.couchbase.client.core.config.NodeInfo
-
Creates a new
NodeInfo
with SSL services.
- NodeLocatorBugIdentifiedEvent - Class in com.couchbase.client.core.cnc.events.node
-
- NodeLocatorBugIdentifiedEvent(Context) - Constructor for class com.couchbase.client.core.cnc.events.node.NodeLocatorBugIdentifiedEvent
-
- NodePartitionLengthNotEqualEvent - Class in com.couchbase.client.core.cnc.events.node
-
- NodePartitionLengthNotEqualEvent(CoreContext, int, int) - Constructor for class com.couchbase.client.core.cnc.events.node.NodePartitionLengthNotEqualEvent
-
- nodes() - Method in class com.couchbase.client.core.config.AbstractBucketConfig
-
- nodes() - Method in interface com.couchbase.client.core.config.BucketConfig
-
The list of nodes associated with this bucket.
- NodeState - Enum in com.couchbase.client.core.node
-
Holds all the different states a
Node
can be in.
- NodeStateChangedEvent - Class in com.couchbase.client.core.cnc.events.node
-
- NodeStateChangedEvent(NodeContext, NodeState, NodeState) - Constructor for class com.couchbase.client.core.cnc.events.node.NodeStateChangedEvent
-
- noExtras() - Static method in enum com.couchbase.client.core.io.netty.kv.MemcacheProtocol
-
Helper to express no extras are used for this message.
- noFramingExtras() - Static method in enum com.couchbase.client.core.io.netty.kv.MemcacheProtocol
-
Helper to express no framing extras are used for this message.
- noJitter() - Static method in interface com.couchbase.client.core.retry.reactor.Jitter
-
Jitter function that is a no-op.
- noKey() - Static method in enum com.couchbase.client.core.io.netty.kv.MemcacheProtocol
-
Helper to express no key is used for this message.
- noMoreRetries(RetryReason) - Static method in class com.couchbase.client.core.msg.CancellationReason
-
This cancellation reason indicates that no more retries were allowed based on the retry strategy.
- NonChunkedHttpMessageHandler - Class in com.couchbase.client.core.io.netty
-
- NonChunkedHttpMessageHandler(BaseEndpoint, ServiceType) - Constructor for class com.couchbase.client.core.io.netty.NonChunkedHttpMessageHandler
-
- NonChunkedHttpRequest<R extends Response> - Interface in com.couchbase.client.core.msg
-
- noOpaque() - Static method in enum com.couchbase.client.core.io.netty.kv.MemcacheProtocol
-
Helper to express no opaque is used for this message.
- NoopCircuitBreaker - Class in com.couchbase.client.core.endpoint
-
A simple noop implementation of the
CircuitBreaker
if disabled by the user.
- NoopCounter - Class in com.couchbase.client.core.cnc.metrics
-
- NoopCounter() - Constructor for class com.couchbase.client.core.cnc.metrics.NoopCounter
-
- NoopMeter - Class in com.couchbase.client.core.cnc.metrics
-
- NoopMeter() - Constructor for class com.couchbase.client.core.cnc.metrics.NoopMeter
-
- NoopRequest - Class in com.couchbase.client.core.msg.kv
-
Represents a NOOP KV Request, doing nothing.
- NoopRequest(Duration, CoreContext, RetryStrategy, CollectionIdentifier) - Constructor for class com.couchbase.client.core.msg.kv.NoopRequest
-
- NoopRequestSpan - Class in com.couchbase.client.core.cnc.tracing
-
- NoopRequestTracer - Class in com.couchbase.client.core.cnc.tracing
-
A simple NOOP implementation of the tracer, useful if tracing needs to be disabled completely.
- NoopResponse - Class in com.couchbase.client.core.msg.kv
-
- NoopValueRecorder - Class in com.couchbase.client.core.cnc.metrics
-
- NoopValueRecorder() - Constructor for class com.couchbase.client.core.cnc.metrics.NoopValueRecorder
-
- noPartition() - Static method in enum com.couchbase.client.core.io.netty.kv.MemcacheProtocol
-
Helper to express no partition is used for this message.
- noRetry() - Static method in class com.couchbase.client.core.retry.RetryAction
-
Constructs a new
RetryAction
indicating that the request should not be retried.
- notifyChannelInactive() - Method in class com.couchbase.client.core.endpoint.BaseEndpoint
-
This method is called from inside the channel to tell the endpoint hat it got inactive.
- notNull(T, String) - Static method in class com.couchbase.client.core.util.Validators
-
Check if the given input is not null.
- notNull(T, String, Supplier<ErrorContext>) - Static method in class com.couchbase.client.core.util.Validators
-
- notNullOrEmpty(String, String) - Static method in class com.couchbase.client.core.util.Validators
-
Check if the given string is not null or empty.
- notNullOrEmpty(String, String, Supplier<ErrorContext>) - Static method in class com.couchbase.client.core.util.Validators
-
- notNullOrEmpty(List<T>, String) - Static method in class com.couchbase.client.core.util.Validators
-
- notNullOrEmpty(List<T>, String, Supplier<ErrorContext>) - Static method in class com.couchbase.client.core.util.Validators
-
- notNullOrEmpty(Set<T>, String) - Static method in class com.couchbase.client.core.util.Validators
-
- notNullOrEmpty(Set<T>, String, Supplier<ErrorContext>) - Static method in class com.couchbase.client.core.util.Validators
-
- nullToEmpty(String) - Static method in class com.couchbase.client.core.util.CbStrings
-
- numberOfPartitions() - Method in class com.couchbase.client.core.config.CouchbaseBucketConfig
-
- numberOfReplicas() - Method in class com.couchbase.client.core.config.CouchbaseBucketConfig
-
- numberOfReplicas() - Method in class com.couchbase.client.core.config.PartitionInfo
-
- NumberTooBigException - Exception in com.couchbase.client.core.error.subdoc
-
Subdocument exception thrown when existing number value in document is too big.
- NumberTooBigException(SubDocumentErrorContext) - Constructor for exception com.couchbase.client.core.error.subdoc.NumberTooBigException
-
- numKvConnections(int) - Method in class com.couchbase.client.core.env.IoConfig.Builder
-
- numKvConnections(int) - Static method in class com.couchbase.client.core.env.IoConfig
-
- numKvConnections() - Method in class com.couchbase.client.core.env.IoConfig
-
- random() - Static method in interface com.couchbase.client.core.retry.reactor.Jitter
-
- random(double) - Static method in interface com.couchbase.client.core.retry.reactor.Jitter
-
Jitter function that applies a random jitter with a provided [0; 1] factor (default 0.5),
generating a backoff between
[d - d*factor; d + d*factor]
(but still within
the limits of [
BackoffDelay.minDelay()
;
BackoffDelay.maxDelay()
].
- RANDOM_JITTER - Static variable in interface com.couchbase.client.core.retry.reactor.Jitter
-
- randomBackoff(Duration, Duration) - Method in interface com.couchbase.client.core.retry.reactor.Repeat
-
Returns a repeat function with random de-correlated jitter backoff strategy.
- randomBackoff(Duration, Duration) - Method in interface com.couchbase.client.core.retry.reactor.Retry
-
Returns a retry function with random de-correlated jitter backoff strategy.
- raw() - Method in enum com.couchbase.client.core.io.netty.kv.ErrorMap.ErrorAttribute
-
- Reactor - Class in com.couchbase.client.core
-
This class provides utility methods when working with reactor.
- read(ByteBuf) - Static method in class com.couchbase.client.core.util.UnsignedLEB128
-
Reads an unsigned LEB128 value from the buffer.
- readBoolean() - Method in class com.couchbase.client.core.json.stream.MatchedValue
-
- readBytes() - Method in class com.couchbase.client.core.json.stream.MatchedValue
-
- readDouble() - Method in class com.couchbase.client.core.json.stream.MatchedValue
-
- reader() - Static method in class com.couchbase.client.core.json.Mapper
-
Returns an ObjectReader for advanced use cases.
- readLong() - Method in class com.couchbase.client.core.json.stream.MatchedValue
-
- readString() - Method in class com.couchbase.client.core.json.stream.MatchedValue
-
- ReadTrafficCapturedEvent - Class in com.couchbase.client.core.cnc.events.io
-
- ReadTrafficCapturedEvent(IoContext, String) - Constructor for class com.couchbase.client.core.cnc.events.io.ReadTrafficCapturedEvent
-
- readTree() - Method in class com.couchbase.client.core.json.stream.MatchedValue
-
- reason() - Method in class com.couchbase.client.core.cnc.events.config.ConfigIgnoredEvent
-
- reason() - Method in class com.couchbase.client.core.cnc.events.core.DnsSrvLookupFailedEvent
-
- reason() - Method in class com.couchbase.client.core.cnc.events.io.ChannelClosedProactivelyEvent
-
- reason() - Method in class com.couchbase.client.core.cnc.events.node.NodeDisconnectIgnoredEvent
-
- reason() - Method in class com.couchbase.client.core.cnc.events.service.ServiceAddIgnoredEvent
-
- reason() - Method in class com.couchbase.client.core.cnc.events.service.ServiceRemoveIgnoredEvent
-
- reason() - Method in exception com.couchbase.client.core.error.RequestCanceledException
-
- reason() - Method in class com.couchbase.client.core.msg.view.ViewError
-
- receivedDisconnectSignal() - Method in class com.couchbase.client.core.endpoint.BaseEndpoint
-
- receivedDisconnectSignal() - Method in interface com.couchbase.client.core.endpoint.Endpoint
-
- ReconfigurationCompletedEvent - Class in com.couchbase.client.core.cnc.events.core
-
Client got a new config and completed the reconfiguration properly without issue.
- ReconfigurationCompletedEvent(Duration, Context) - Constructor for class com.couchbase.client.core.cnc.events.core.ReconfigurationCompletedEvent
-
- ReconfigurationErrorDetectedEvent - Class in com.couchbase.client.core.cnc.events.core
-
The client ran into an error during a config reconfiguration event.
- ReconfigurationErrorDetectedEvent(Context, Throwable) - Constructor for class com.couchbase.client.core.cnc.events.core.ReconfigurationErrorDetectedEvent
-
- ReconfigurationIgnoredEvent - Class in com.couchbase.client.core.cnc.events.core
-
Client got a new config, but for some valid reason the event is ignored.
- ReconfigurationIgnoredEvent(Context) - Constructor for class com.couchbase.client.core.cnc.events.core.ReconfigurationIgnoredEvent
-
- record(Channel, Class<?>) - Static method in class com.couchbase.client.core.io.netty.kv.ConnectTimings
-
Convenience method to record a single timing right away.
- recordValue(long) - Method in class com.couchbase.client.core.cnc.metrics.AggregatingValueRecorder
-
- recordValue(long) - Method in class com.couchbase.client.core.cnc.metrics.NoopValueRecorder
-
- recordValue(long) - Method in interface com.couchbase.client.core.cnc.ValueRecorder
-
Records a specific value.
- RedactableArgument - Class in com.couchbase.client.core.logging
-
Wraps a piece of information that is subject to log redaction.
- RedactionLevel - Enum in com.couchbase.client.core.logging
-
Allows to specify the level of log redaction.
- redactMeta(Object) - Static method in class com.couchbase.client.core.logging.RedactableArgument
-
A redactable argument of meta data.
- redactSystem(Object) - Static method in class com.couchbase.client.core.logging.RedactableArgument
-
A redactable argument of system data.
- redactUser(Object) - Static method in class com.couchbase.client.core.logging.RedactableArgument
-
A redactable argument of user data.
- ReducedAnalyticsErrorContext - Class in com.couchbase.client.core.error.context
-
- ReducedAnalyticsErrorContext(String) - Constructor for class com.couchbase.client.core.error.context.ReducedAnalyticsErrorContext
-
- ReducedKeyValueErrorContext - Class in com.couchbase.client.core.error.context
-
- ReducedQueryErrorContext - Class in com.couchbase.client.core.error.context
-
- ReducedQueryErrorContext(String) - Constructor for class com.couchbase.client.core.error.context.ReducedQueryErrorContext
-
- ReducedSearchErrorContext - Class in com.couchbase.client.core.error.context
-
- ReducedSearchErrorContext(String, Map<String, Object>) - Constructor for class com.couchbase.client.core.error.context.ReducedSearchErrorContext
-
- ReducedViewErrorContext - Class in com.couchbase.client.core.error.context
-
- ReducedViewErrorContext(String, String, String) - Constructor for class com.couchbase.client.core.error.context.ReducedViewErrorContext
-
- reference() - Method in class com.couchbase.client.core.msg.kv.ResponseStatusDetails
-
- refreshCollectionMap(String, boolean) - Method in interface com.couchbase.client.core.config.ConfigurationProvider
-
Helper method to refresh the collection map for the given bucket.
- refreshCollectionMap(String, boolean) - Method in class com.couchbase.client.core.config.DefaultConfigurationProvider
-
- register(String) - Method in interface com.couchbase.client.core.config.refresher.BucketRefresher
-
Registers a bucket for refreshing.
- register(String) - Method in class com.couchbase.client.core.config.refresher.ClusterManagerBucketRefresher
-
Registers a given bucket for http-based config refresh if not already registered.
- register(String) - Method in class com.couchbase.client.core.config.refresher.KeyValueBucketRefresher
-
- register(Request<Response>) - Method in class com.couchbase.client.core.Timer
-
Registers the given request to be tracked with its timeout value.
- register(T, Stateful<IN>) - Method in class com.couchbase.client.core.util.CompositeStateful
-
Registers a stateful element with the composite.
- registerRefresher(String) - Method in class com.couchbase.client.core.config.DefaultConfigurationProvider
-
Registers the given bucket for refreshing.
- releaseBefore(long) - Method in class com.couchbase.client.core.json.stream.CopyingStreamWindow
-
- releaseBefore(long) - Method in interface com.couchbase.client.core.json.stream.StreamWindow
-
Forgets any bytes with stream offsets lower then the given offset.
- remote() - Method in class com.couchbase.client.core.diagnostics.EndpointDiagnostics
-
The remote socket address for this endpoint.
- remote() - Method in class com.couchbase.client.core.diagnostics.EndpointPingReport
-
The remote socket address for this endpoint.
- remoteAddress() - Method in class com.couchbase.client.core.endpoint.BaseEndpoint
-
Helper method to create the remote address this endpoint will (re)connect to.
- remoteHostname() - Method in class com.couchbase.client.core.node.NodeContext
-
- remoteHostname() - Method in class com.couchbase.client.core.service.ServiceContext
-
- remoteHttpHost(SocketAddress) - Static method in class com.couchbase.client.core.io.netty.HttpProtocol
-
Calculates the remote host for caching so that it is set on each query request.
- remotePort() - Method in class com.couchbase.client.core.service.ServiceContext
-
- remoteSocket() - Method in class com.couchbase.client.core.endpoint.EndpointContext
-
- remoteSocket() - Method in class com.couchbase.client.core.io.IoContext
-
Returns the remote socket.
- remove() - Method in class com.couchbase.client.core.service.kv.ObserveContext
-
- removeEldestEntry(Map.Entry<K, V>) - Method in class com.couchbase.client.core.util.LRUCache
-
- removeEnd(String, String) - Static method in class com.couchbase.client.core.util.CbStrings
-
- RemoveRequest - Class in com.couchbase.client.core.msg.kv
-
Represents a KV delete operation.
- RemoveRequest(String, long, Duration, CoreContext, CollectionIdentifier, RetryStrategy, Optional<DurabilityLevel>, RequestSpan) - Constructor for class com.couchbase.client.core.msg.kv.RemoveRequest
-
- RemoveResponse - Class in com.couchbase.client.core.msg.kv
-
- removeService(ServiceType, Optional<String>) - Method in class com.couchbase.client.core.node.Node
-
- removeStart(String, String) - Static method in class com.couchbase.client.core.util.CbStrings
-
- Repeat<T> - Interface in com.couchbase.client.core.retry.reactor
-
- RepeatContext<T> - Interface in com.couchbase.client.core.retry.reactor
-
- repeatMax(long) - Method in class com.couchbase.client.core.retry.reactor.DefaultRepeat
-
- repeatMax(long) - Method in interface com.couchbase.client.core.retry.reactor.Repeat
-
Returns a repeat function that repeats at most n times.
- ReplaceRequest - Class in com.couchbase.client.core.msg.kv
-
Uses the KV replace command to replace a document if it exists.
- ReplaceRequest(String, byte[], long, int, Duration, long, CoreContext, CollectionIdentifier, RetryStrategy, Optional<DurabilityLevel>, RequestSpan) - Constructor for class com.couchbase.client.core.msg.kv.ReplaceRequest
-
- ReplaceResponse - Class in com.couchbase.client.core.msg.kv
-
- replica(int) - Method in class com.couchbase.client.core.config.Partition
-
- replica() - Method in class com.couchbase.client.core.msg.kv.ObserveViaCasRequest
-
- replica() - Method in class com.couchbase.client.core.msg.kv.ObserveViaSeqnoRequest
-
- replica() - Method in class com.couchbase.client.core.msg.kv.ReplicaGetRequest
-
- ReplicaGetRequest - Class in com.couchbase.client.core.msg.kv
-
- ReplicaGetRequest(String, Duration, CoreContext, CollectionIdentifier, RetryStrategy, short, RequestSpan) - Constructor for class com.couchbase.client.core.msg.kv.ReplicaGetRequest
-
- ReplicaNotAvailableException - Exception in com.couchbase.client.core.error
-
- ReplicaNotAvailableException() - Constructor for exception com.couchbase.client.core.error.ReplicaNotAvailableException
-
- ReplicaNotAvailableException(String) - Constructor for exception com.couchbase.client.core.error.ReplicaNotAvailableException
-
- ReplicaNotAvailableException(String, Throwable) - Constructor for exception com.couchbase.client.core.error.ReplicaNotAvailableException
-
- ReplicaNotAvailableException(Throwable) - Constructor for exception com.couchbase.client.core.error.ReplicaNotAvailableException
-
- ReplicaNotConfiguredException - Exception in com.couchbase.client.core.error
-
- ReplicaNotConfiguredException() - Constructor for exception com.couchbase.client.core.error.ReplicaNotConfiguredException
-
- ReplicaNotConfiguredException(String) - Constructor for exception com.couchbase.client.core.error.ReplicaNotConfiguredException
-
- ReplicaNotConfiguredException(String, Throwable) - Constructor for exception com.couchbase.client.core.error.ReplicaNotConfiguredException
-
- ReplicaNotConfiguredException(Throwable) - Constructor for exception com.couchbase.client.core.error.ReplicaNotConfiguredException
-
- replicateTo() - Method in class com.couchbase.client.core.service.kv.ObserveContext
-
- report(Request<?>) - Method in class com.couchbase.client.core.cnc.OrphanReporter
-
- request(ByteBufAllocator, MemcacheProtocol.Opcode, byte, short, int, long, ByteBuf, ByteBuf, ByteBuf) - Static method in enum com.couchbase.client.core.io.netty.kv.MemcacheProtocol
-
Create a regular, non-flexible memcached protocol request with all fields necessary.
- Request<R extends Response> - Interface in com.couchbase.client.core.msg
-
Represents a
Request
flowing through the client.
- request() - Method in class com.couchbase.client.core.msg.RequestContext
-
- RequestCanceledException - Exception in com.couchbase.client.core.error
-
- RequestCanceledException(String, CancellationReason, CancellationErrorContext) - Constructor for exception com.couchbase.client.core.error.RequestCanceledException
-
- requestClass() - Method in class com.couchbase.client.core.cnc.events.request.RequestRetryScheduledEvent
-
- requestContext(RequestContext) - Method in interface com.couchbase.client.core.cnc.RequestSpan
-
Allows to set a request context to the request span.
- requestContext(RequestContext) - Method in class com.couchbase.client.core.cnc.tracing.NoopRequestSpan
-
- requestContext(RequestContext) - Method in class com.couchbase.client.core.cnc.tracing.ThresholdRequestSpan
-
- requestContext() - Method in class com.couchbase.client.core.error.context.AnalyticsErrorContext
-
- requestContext() - Method in class com.couchbase.client.core.error.context.CancellationErrorContext
-
Returns the underlying request context for debug reasons.
- requestContext() - Method in class com.couchbase.client.core.error.context.QueryErrorContext
-
- requestContext() - Method in class com.couchbase.client.core.error.context.SearchErrorContext
-
- requestContext() - Method in class com.couchbase.client.core.error.context.ViewErrorContext
-
- requestContext() - Method in class com.couchbase.client.core.io.netty.chunk.BaseChunkResponseParser
-
- RequestContext - Class in com.couchbase.client.core.msg
-
Additional context which might be attached to an individual
Request
.
- RequestContext(CoreContext, Request<? extends Response>) - Constructor for class com.couchbase.client.core.msg.RequestContext
-
- requestId() - Method in class com.couchbase.client.core.msg.analytics.AnalyticsChunkHeader
-
- requestId() - Method in class com.couchbase.client.core.msg.query.QueryChunkHeader
-
- RequestNotRetriedEvent - Class in com.couchbase.client.core.cnc.events.request
-
This event is raised if a request is not retried anymore.
- RequestNotRetriedEvent(Event.Severity, Class<? extends Request>, RequestContext, RetryReason, Throwable) - Constructor for class com.couchbase.client.core.cnc.events.request.RequestNotRetriedEvent
-
- RequestRetryScheduledEvent - Class in com.couchbase.client.core.cnc.events.request
-
- RequestRetryScheduledEvent(Duration, RequestContext, Class<?>, RetryReason) - Constructor for class com.couchbase.client.core.cnc.events.request.RequestRetryScheduledEvent
-
- RequestSpan - Interface in com.couchbase.client.core.cnc
-
Wrapper interface for all spans flowing through the SDK.
- requestSpan(String, RequestSpan) - Method in interface com.couchbase.client.core.cnc.RequestTracer
-
Creates a new request span with or without a parent.
- requestSpan(String, RequestSpan) - Method in class com.couchbase.client.core.cnc.tracing.NoopRequestTracer
-
- requestSpan(String, RequestSpan) - Method in class com.couchbase.client.core.cnc.tracing.ThresholdRequestTracer
-
- requestSpan() - Method in class com.couchbase.client.core.msg.BaseRequest
-
- requestSpan() - Method in interface com.couchbase.client.core.msg.Request
-
Holds the internal span for this request.
- RequestTracer - Interface in com.couchbase.client.core.cnc
-
- requestTracer(RequestTracer) - Method in class com.couchbase.client.core.env.CoreEnvironment.Builder
-
Allows to configure a custom tracer implementation.
- requestTracer() - Method in class com.couchbase.client.core.env.CoreEnvironment
-
Returns the request tracer for response time observability.
- reset() - Method in interface com.couchbase.client.core.endpoint.CircuitBreaker
-
Resets this circuit breaker to its initial state.
- reset() - Method in class com.couchbase.client.core.endpoint.NoopCircuitBreaker
-
- response() - Method in class com.couchbase.client.core.cnc.events.io.UnknownResponseReceivedEvent
-
- response() - Method in class com.couchbase.client.core.cnc.events.io.UnsupportedResponseTypeReceivedEvent
-
- response(ByteBufAllocator, MemcacheProtocol.Opcode, byte, short, int, long, ByteBuf, ByteBuf, ByteBuf) - Static method in enum com.couchbase.client.core.io.netty.kv.MemcacheProtocol
-
Create a regular, non-flexible memcached protocol response with all fields necessary.
- response() - Method in class com.couchbase.client.core.msg.BaseRequest
-
- response() - Method in interface com.couchbase.client.core.msg.Request
-
Holds the response which eventually completes.
- Response - Interface in com.couchbase.client.core.msg
-
This interface is the base entity for all Responses flowing through the client.
- responseHeader() - Method in class com.couchbase.client.core.io.netty.chunk.BaseChunkResponseParser
-
- responseMetric(Request<?>) - Method in class com.couchbase.client.core.Core
-
- responseStatus() - Method in class com.couchbase.client.core.error.context.ErrorContext
-
- ResponseStatus - Enum in com.couchbase.client.core.msg
-
The
ResponseStatus
describes what kind of response came back for a specific
request.
- ResponseStatusDetails - Class in com.couchbase.client.core.msg.kv
-
Container for extended response status information.
- Retry<T> - Interface in com.couchbase.client.core.retry.reactor
-
Retry function that may be used with retryWhen in Flux and Mono.
- retryable() - Method in exception com.couchbase.client.core.error.PreparedStatementFailureException
-
- RetryAction - Class in com.couchbase.client.core.retry
-
The
RetryAction
describes how and when a request should be retried.
- retryAttempts() - Method in exception com.couchbase.client.core.error.TimeoutException
-
Returns the number of retry attempts for this request.
- retryAttempts() - Method in class com.couchbase.client.core.msg.RequestContext
-
- RetryContext<T> - Interface in com.couchbase.client.core.retry.reactor
-
- RetryExhaustedException - Exception in com.couchbase.client.core.retry.reactor
-
- RetryExhaustedException(String) - Constructor for exception com.couchbase.client.core.retry.reactor.RetryExhaustedException
-
- RetryExhaustedException(Throwable) - Constructor for exception com.couchbase.client.core.retry.reactor.RetryExhaustedException
-
- retryMax(long) - Method in class com.couchbase.client.core.retry.reactor.DefaultRetry
-
- retryMax(long) - Method in interface com.couchbase.client.core.retry.reactor.Retry
-
Retry function that retries n times.
- retryOnce() - Method in interface com.couchbase.client.core.retry.reactor.Retry
-
Retry function that retries once.
- RetryOrchestrator - Class in com.couchbase.client.core.retry
-
The
RetryOrchestrator
is responsible for checking if a request is eligible for retry
and if so dispatch it properly and update state.
- RetryOrchestrator() - Constructor for class com.couchbase.client.core.retry.RetryOrchestrator
-
- retryReason() - Method in class com.couchbase.client.core.cnc.events.request.RequestNotRetriedEvent
-
- retryReason() - Method in class com.couchbase.client.core.cnc.events.request.RequestRetryScheduledEvent
-
- RetryReason - Enum in com.couchbase.client.core.retry
-
Provides more insight into why an operation has been retried.
- retryReasons() - Method in exception com.couchbase.client.core.error.TimeoutException
-
Returns the set of retry reasons for request.
- retryReasons() - Method in class com.couchbase.client.core.msg.RequestContext
-
- retrySpec() - Method in class com.couchbase.client.core.io.netty.kv.ErrorMap.ErrorCode
-
- RetrySpecification(ErrorMap.RetryStrategy, int, int, int, int) - Constructor for class com.couchbase.client.core.io.netty.kv.ErrorMap.RetrySpecification
-
Creates a new retry specification, usually called from jackson.
- retryStrategy(RetryStrategy) - Method in class com.couchbase.client.core.env.CoreEnvironment.Builder
-
Allows to customize the default retry strategy.
- retryStrategy() - Method in class com.couchbase.client.core.env.CoreEnvironment
-
Returns the retry strategy on this environment.
- retryStrategy() - Method in class com.couchbase.client.core.msg.BaseRequest
-
- retryStrategy() - Method in interface com.couchbase.client.core.msg.Request
-
The retry strategy for this particular request.
- RetryStrategy - Interface in com.couchbase.client.core.retry
-
- retryStrategy() - Method in class com.couchbase.client.core.service.kv.ObserveContext
-
- rev() - Method in interface com.couchbase.client.core.config.BucketConfig
-
Revision number (optional) for that configuration.
- rev() - Method in class com.couchbase.client.core.config.CouchbaseBucketConfig
-
- rev() - Method in class com.couchbase.client.core.config.GlobalConfig
-
The revision id of this global config.
- rev() - Method in class com.couchbase.client.core.config.MemcachedBucketConfig
-
- revision() - Method in class com.couchbase.client.core.io.netty.kv.ErrorMap
-
- rollingWindow(Duration) - Method in class com.couchbase.client.core.endpoint.CircuitBreakerConfig.Builder
-
How long the window is in which the number of failed ops are tracked in a rolling fashion.
- rollingWindow(Duration) - Static method in class com.couchbase.client.core.endpoint.CircuitBreakerConfig
-
- rollingWindow() - Method in class com.couchbase.client.core.endpoint.CircuitBreakerConfig
-
Returns the configured rolling window duration which is considered to track the failed ops.
- RoundRobinLocator - Class in com.couchbase.client.core.node
-
A
Locator
which implements node selection on a round-robin basis.
- RoundRobinLocator(ServiceType) - Constructor for class com.couchbase.client.core.node.RoundRobinLocator
-
- RoundRobinSelectionStrategy - Class in com.couchbase.client.core.service.strategy
-
- RoundRobinSelectionStrategy() - Constructor for class com.couchbase.client.core.service.strategy.RoundRobinSelectionStrategy
-
- roundtrips() - Method in enum com.couchbase.client.core.env.SaslMechanism
-
Returns the number of roundtrips this algorithm has with the server.
- rows() - Method in class com.couchbase.client.core.io.netty.chunk.BaseChunkResponseParser
-
- rows() - Method in interface com.couchbase.client.core.io.netty.chunk.ChunkResponseParser
-
Returns the currently assigned flux for the rows.
- rows() - Method in class com.couchbase.client.core.msg.analytics.AnalyticsResponse
-
- rows() - Method in interface com.couchbase.client.core.msg.chunk.ChunkedResponse
-
Returns the rows for this response, available pushed as they come streaming in.
- rows() - Method in class com.couchbase.client.core.msg.query.QueryResponse
-
- rows() - Method in class com.couchbase.client.core.msg.search.SearchResponse
-
- rows() - Method in class com.couchbase.client.core.msg.view.ViewResponse
-
- sampleSize(int) - Method in class com.couchbase.client.core.cnc.tracing.ThresholdRequestTracer.Builder
-
Allows to customize the sample size per service.
- sampleSize(int) - Method in class com.couchbase.client.core.env.OrphanReporterConfig.Builder
-
Allows to customize the sample size per service.
- sampleSize(int) - Static method in class com.couchbase.client.core.env.OrphanReporterConfig
-
Allows to customize the sample size per service.
- sampleSize() - Method in class com.couchbase.client.core.env.OrphanReporterConfig
-
Returns the configured sample size.
- sampleSize(int) - Method in class com.couchbase.client.core.env.ThresholdRequestTracerConfig.Builder
-
Allows to customize the sample size per service.
- sampleSize(int) - Static method in class com.couchbase.client.core.env.ThresholdRequestTracerConfig
-
Allows to customize the sample size per service.
- sampleSize() - Method in class com.couchbase.client.core.env.ThresholdRequestTracerConfig
-
- SASL_MECHS_KEY - Static variable in class com.couchbase.client.core.io.netty.kv.ChannelAttributes
-
Holds the SASL mechanisms the server supports.
- SaslAuthenticationCompletedEvent - Class in com.couchbase.client.core.cnc.events.io
-
- SaslAuthenticationCompletedEvent(Duration, IoContext) - Constructor for class com.couchbase.client.core.cnc.events.io.SaslAuthenticationCompletedEvent
-
- SaslAuthenticationFailedEvent - Class in com.couchbase.client.core.cnc.events.io
-
If something goes wrong during the SASL authentication process, this event is raised.
- SaslAuthenticationFailedEvent(Duration, KeyValueIoErrorContext, String, byte[]) - Constructor for class com.couchbase.client.core.cnc.events.io.SaslAuthenticationFailedEvent
-
- SaslAuthenticationHandler - Class in com.couchbase.client.core.io.netty.kv
-
This handler is responsible for perform SASL authentication against the KV engine.
- SaslAuthenticationHandler(EndpointContext, String, String, Set<SaslMechanism>) - Constructor for class com.couchbase.client.core.io.netty.kv.SaslAuthenticationHandler
-
- SaslAuthenticationRestartedEvent - Class in com.couchbase.client.core.cnc.events.io
-
This event is raised if we need to re-do the SASL auth for a connection because the mechanisms did not match up
with the best-effort first try.
- SaslAuthenticationRestartedEvent(IoContext) - Constructor for class com.couchbase.client.core.cnc.events.io.SaslAuthenticationRestartedEvent
-
- SaslListMechanismsHandler - Class in com.couchbase.client.core.io.netty.kv
-
- SaslListMechanismsHandler(EndpointContext) - Constructor for class com.couchbase.client.core.io.netty.kv.SaslListMechanismsHandler
-
- SaslMechanism - Enum in com.couchbase.client.core.env
-
Describes the support SASL authentication mechanisms.
- SaslMechanismsListedEvent - Class in com.couchbase.client.core.cnc.events.io
-
This debug event signals that SASL auth mechanisms have been listed from the server.
- SaslMechanismsListedEvent(IoContext, Set<SaslMechanism>, Duration) - Constructor for class com.couchbase.client.core.cnc.events.io.SaslMechanismsListedEvent
-
- SaslMechanismsListingFailedEvent - Class in com.couchbase.client.core.cnc.events.io
-
- SaslMechanismsListingFailedEvent(Duration, Context, String) - Constructor for class com.couchbase.client.core.cnc.events.io.SaslMechanismsListingFailedEvent
-
- SaslMechanismsSelectedEvent - Class in com.couchbase.client.core.cnc.events.io
-
This debug event signals that a SASL auth mechanism has been negotiated
between the client and the server.
- SaslMechanismsSelectedEvent(IoContext, Set<SaslMechanism>, SaslMechanism) - Constructor for class com.couchbase.client.core.cnc.events.io.SaslMechanismsSelectedEvent
-
- schedule(Runnable, Duration) - Method in class com.couchbase.client.core.Timer
-
Schedule an arbitrary task for this timer.
- scheduleForRetry(Core, Request<? extends Response>, Duration) - Method in class com.couchbase.client.core.Timer
-
Schedules a request to be retried after the given duration.
- scheduler(Scheduler) - Method in class com.couchbase.client.core.env.CoreEnvironment.Builder
-
Customizes the default Reactor scheduler used for parallel operations.
- scheduler() - Method in class com.couchbase.client.core.env.CoreEnvironment
-
Returns the scheduler used to schedule reactive, async tasks across the SDK.
- SchedulerClock - Class in com.couchbase.client.core.scheduler
-
- scheme() - Method in class com.couchbase.client.core.util.ConnectionString
-
- scope() - Method in class com.couchbase.client.core.io.CollectionIdentifier
-
- scope() - Method in enum com.couchbase.client.core.service.ServiceType
-
- ScopedRequest - Interface in com.couchbase.client.core.msg
-
- ScopeExistsException - Exception in com.couchbase.client.core.error
-
- ScopeExistsException(String) - Constructor for exception com.couchbase.client.core.error.ScopeExistsException
-
- scopeName() - Method in exception com.couchbase.client.core.error.ScopeExistsException
-
- scopeName() - Method in exception com.couchbase.client.core.error.ScopeNotFoundException
-
- ScopeNotFoundException - Exception in com.couchbase.client.core.error
-
- ScopeNotFoundException(String) - Constructor for exception com.couchbase.client.core.error.ScopeNotFoundException
-
- scopes() - Method in class com.couchbase.client.core.config.CollectionsManifest
-
- ScramSaslClientFactory - Class in com.couchbase.client.core.io.netty.kv.sasl
-
- ScramSaslClientFactory() - Constructor for class com.couchbase.client.core.io.netty.kv.sasl.ScramSaslClientFactory
-
- sdk() - Method in class com.couchbase.client.core.diagnostics.DiagnosticsResult
-
The identifier of this SDK (useful when exporting to JSON).
- sdk() - Method in class com.couchbase.client.core.diagnostics.PingResult
-
The identifier of this SDK (useful when exporting to JSON).
- SearchChunkHeader - Class in com.couchbase.client.core.msg.search
-
- SearchChunkHeader(byte[]) - Constructor for class com.couchbase.client.core.msg.search.SearchChunkHeader
-
- SearchChunkResponseParser - Class in com.couchbase.client.core.io.netty.search
-
- SearchChunkResponseParser() - Constructor for class com.couchbase.client.core.io.netty.search.SearchChunkResponseParser
-
- SearchChunkRow - Class in com.couchbase.client.core.msg.search
-
- SearchChunkRow(byte[]) - Constructor for class com.couchbase.client.core.msg.search.SearchChunkRow
-
- SearchChunkTrailer - Class in com.couchbase.client.core.msg.search
-
- SearchChunkTrailer(long, double, long, byte[]) - Constructor for class com.couchbase.client.core.msg.search.SearchChunkTrailer
-
- searchCircuitBreakerConfig(CircuitBreakerConfig.Builder) - Method in class com.couchbase.client.core.env.IoConfig.Builder
-
- searchCircuitBreakerConfig() - Method in class com.couchbase.client.core.env.IoConfig.Builder
-
- searchCircuitBreakerConfig(CircuitBreakerConfig.Builder) - Static method in class com.couchbase.client.core.env.IoConfig
-
- searchCircuitBreakerConfig() - Method in class com.couchbase.client.core.env.IoConfig
-
- SearchEndpoint - Class in com.couchbase.client.core.endpoint
-
- SearchEndpoint(ServiceContext, String, int) - Constructor for class com.couchbase.client.core.endpoint.SearchEndpoint
-
- SearchEndpoint.SearchPipelineInitializer - Class in com.couchbase.client.core.endpoint
-
- SearchErrorContext - Class in com.couchbase.client.core.error.context
-
- SearchErrorContext(ResponseStatus, RequestContext, int) - Constructor for class com.couchbase.client.core.error.context.SearchErrorContext
-
- searchEventLoopGroup(EventLoopGroup) - Method in class com.couchbase.client.core.env.IoEnvironment.Builder
-
Allows to specify a custom event loop group (I/O event loop thread pool) for the search service.
- searchEventLoopGroup(EventLoopGroup) - Static method in class com.couchbase.client.core.env.IoEnvironment
-
Allows to specify a custom event loop group (I/O event loop thread pool) for the search service.
- searchEventLoopGroup() - Method in class com.couchbase.client.core.env.IoEnvironment
-
Returns the EventLoopGroup
to be used for search traffic.
- SearchHandlerSwitcher - Class in com.couchbase.client.core.io.netty.search
-
- SearchHandlerSwitcher(BaseEndpoint, EndpointContext) - Constructor for class com.couchbase.client.core.io.netty.search.SearchHandlerSwitcher
-
- SearchPingRequest - Class in com.couchbase.client.core.msg.search
-
- SearchPingRequest(Duration, CoreContext, RetryStrategy, NodeIdentifier) - Constructor for class com.couchbase.client.core.msg.search.SearchPingRequest
-
- SearchPingResponse - Class in com.couchbase.client.core.msg.search
-
- SearchRequest - Class in com.couchbase.client.core.msg.search
-
- SearchRequest(Duration, CoreContext, RetryStrategy, Authenticator, String, byte[], RequestSpan) - Constructor for class com.couchbase.client.core.msg.search.SearchRequest
-
- SearchResponse - Class in com.couchbase.client.core.msg.search
-
- SearchService - Class in com.couchbase.client.core.service
-
- SearchService(SearchServiceConfig, CoreContext, String, int) - Constructor for class com.couchbase.client.core.service.SearchService
-
- SearchServiceConfig - Class in com.couchbase.client.core.service
-
- SearchServiceConfig.Builder - Class in com.couchbase.client.core.service
-
- searchThreshold(Duration) - Method in class com.couchbase.client.core.cnc.tracing.ThresholdRequestTracer.Builder
-
Allows to customize the ftsThreshold.
- searchThreshold(Duration) - Method in class com.couchbase.client.core.env.ThresholdRequestTracerConfig.Builder
-
Allows to customize the ftsThreshold.
- searchThreshold(Duration) - Static method in class com.couchbase.client.core.env.ThresholdRequestTracerConfig
-
Allows to customize the ftsThreshold.
- searchThreshold() - Method in class com.couchbase.client.core.env.ThresholdRequestTracerConfig
-
- searchTimeout(Duration) - Method in class com.couchbase.client.core.env.TimeoutConfig.Builder
-
Sets the timeout to use for search operations.
- searchTimeout(Duration) - Static method in class com.couchbase.client.core.env.TimeoutConfig
-
- searchTimeout() - Method in class com.couchbase.client.core.env.TimeoutConfig
-
- SecureConnectionFailedEvent - Class in com.couchbase.client.core.cnc.events.io
-
- SecureConnectionFailedEvent(Context, SSLException) - Constructor for class com.couchbase.client.core.cnc.events.io.SecureConnectionFailedEvent
-
- securityConfig(SecurityConfig.Builder) - Method in class com.couchbase.client.core.env.CoreEnvironment.Builder
-
Allows to configure everything related to TLS/encrypted connections.
- securityConfig() - Method in class com.couchbase.client.core.env.CoreEnvironment.Builder
-
Returns the currently stored config builder.
- securityConfig() - Method in class com.couchbase.client.core.env.CoreEnvironment
-
Returns the current security configuration (TLS etc.).
- SecurityConfig - Class in com.couchbase.client.core.env
-
The
SecurityConfig
allows to enable transport encryption between the client and the servers.
- SecurityConfig.Builder - Class in com.couchbase.client.core.env
-
This builder allows to customize the default security configuration.
- SecurityException - Exception in com.couchbase.client.core.error
-
- SecurityException() - Constructor for exception com.couchbase.client.core.error.SecurityException
-
- SecurityException(String) - Constructor for exception com.couchbase.client.core.error.SecurityException
-
- SecurityException(String, Throwable) - Constructor for exception com.couchbase.client.core.error.SecurityException
-
- SecurityException(Throwable) - Constructor for exception com.couchbase.client.core.error.SecurityException
-
- SeedNode - Class in com.couchbase.client.core.env
-
The
SeedNode
represents a combination of hostname/ip and port that is used during the SDK bootstrap.
- SeedNodeOutdatedException - Exception in com.couchbase.client.core.error
-
Used to signal that the seed node used for an operation is outdated and might need to be refreshed.
- SeedNodeOutdatedException(String) - Constructor for exception com.couchbase.client.core.error.SeedNodeOutdatedException
-
- seedNodes() - Method in interface com.couchbase.client.core.config.ConfigurationProvider
-
Returns a stream of seed node sets sourced from the server's global config or bucket config.
- seedNodes() - Method in class com.couchbase.client.core.config.DefaultConfigurationProvider
-
- seedNodesFromConnectionString(String, boolean, boolean, EventBus) - Static method in class com.couchbase.client.core.util.ConnectionStringUtil
-
Populates a list of seed nodes from the connection string.
- SeedNodesUpdatedEvent - Class in com.couchbase.client.core.cnc.events.config
-
This event is emitted when seed nodes are updated in the configuration provider.
- SeedNodesUpdatedEvent(Context, Set<SeedNode>, Set<SeedNode>) - Constructor for class com.couchbase.client.core.cnc.events.config.SeedNodesUpdatedEvent
-
- seeds() - Method in class com.couchbase.client.core.cnc.events.core.DnsSrvRecordsLoadedEvent
-
- select(R, List<Endpoint>) - Method in interface com.couchbase.client.core.service.EndpointSelectionStrategy
-
- select(R, List<Endpoint>) - Method in class com.couchbase.client.core.service.strategy.PartitionSelectionStrategy
-
- select(R, List<Endpoint>) - Method in class com.couchbase.client.core.service.strategy.RoundRobinSelectionStrategy
-
- SelectBucketCompletedEvent - Class in com.couchbase.client.core.cnc.events.io
-
This event gets created as soon as a bucket has been selected during the
KV bootstrap process for each socket/node.
- SelectBucketCompletedEvent(Duration, IoContext, String) - Constructor for class com.couchbase.client.core.cnc.events.io.SelectBucketCompletedEvent
-
- SelectBucketFailedEvent - Class in com.couchbase.client.core.cnc.events.io
-
If selecting a bucket during KV bootstrap fails, this is a really problematic
issue and needs to be looked at.
- SelectBucketFailedEvent(Event.Severity, IoContext, short) - Constructor for class com.couchbase.client.core.cnc.events.io.SelectBucketFailedEvent
-
- SelectBucketHandler - Class in com.couchbase.client.core.io.netty.kv
-
- SelectBucketHandler(EndpointContext, String) - Constructor for class com.couchbase.client.core.io.netty.kv.SelectBucketHandler
-
- selectedMechanism() - Method in class com.couchbase.client.core.cnc.events.io.SaslMechanismsSelectedEvent
-
- selectionStrategy() - Method in class com.couchbase.client.core.service.AnalyticsService
-
- selectionStrategy() - Method in class com.couchbase.client.core.service.KeyValueService
-
- selectionStrategy() - Method in class com.couchbase.client.core.service.ManagerService
-
- selectionStrategy() - Method in class com.couchbase.client.core.service.QueryService
-
- selectionStrategy() - Method in class com.couchbase.client.core.service.SearchService
-
- selectionStrategy() - Method in class com.couchbase.client.core.service.ViewService
-
- self() - Method in class com.couchbase.client.core.env.CoreEnvironment.Builder
-
- send(Request<R>) - Method in class com.couchbase.client.core.Core
-
Sends a command into the core layer and registers the request with the timeout timer.
- send(Request<R>, boolean) - Method in class com.couchbase.client.core.Core
-
Sends a command into the core layer and allows to avoid timeout registration.
- send(R) - Method in class com.couchbase.client.core.endpoint.BaseEndpoint
-
- send(R) - Method in interface com.couchbase.client.core.endpoint.Endpoint
-
- send(R) - Method in class com.couchbase.client.core.node.Node
-
Sends the request into this
Node
.
- send(R) - Method in interface com.couchbase.client.core.service.Service
-
Sends the request into this
Service
.
- sendIntoRetry(R) - Method in class com.couchbase.client.core.node.Node
-
Retries the request.
- sequenceNumber() - Method in class com.couchbase.client.core.msg.kv.MutationToken
-
- SERIALIZED_COMPAT_FLAGS - Static variable in enum com.couchbase.client.core.msg.kv.CodecFlags
-
- SERIALIZED_LEGACY_FLAGS - Static variable in enum com.couchbase.client.core.msg.kv.CodecFlags
-
- ServerFeature - Enum in com.couchbase.client.core.io.netty.kv
-
The
ServerFeature
enum describes all the different negotiation modes
between the server and the SDK.
- serverLatency() - Method in class com.couchbase.client.core.msg.RequestContext
-
- serverLatency(long) - Method in class com.couchbase.client.core.msg.RequestContext
-
- serverMechanisms() - Method in class com.couchbase.client.core.cnc.events.io.SaslMechanismsListedEvent
-
- ServerOutOfMemoryException - Exception in com.couchbase.client.core.error
-
Thrown when Couchbase Server returns with an Out of Memory error.
- ServerOutOfMemoryException(KeyValueErrorContext) - Constructor for exception com.couchbase.client.core.error.ServerOutOfMemoryException
-
- Service - Interface in com.couchbase.client.core.service
-
The parent interface for all service implementations.
- SERVICE_ANALYTICS - Static variable in class com.couchbase.client.core.cnc.TracingIdentifiers
-
The identifier commonly used to identify the analytics service.
- SERVICE_KV - Static variable in class com.couchbase.client.core.cnc.TracingIdentifiers
-
The identifier commonly used to identify the kv service.
- SERVICE_QUERY - Static variable in class com.couchbase.client.core.cnc.TracingIdentifiers
-
The identifier commonly used to identify the query service.
- SERVICE_SEARCH - Static variable in class com.couchbase.client.core.cnc.TracingIdentifiers
-
The identifier commonly used to identify the search service.
- SERVICE_VIEWS - Static variable in class com.couchbase.client.core.cnc.TracingIdentifiers
-
The identifier commonly used to identify the view service.
- ServiceAddedEvent - Class in com.couchbase.client.core.cnc.events.service
-
- ServiceAddedEvent(Duration, ServiceContext) - Constructor for class com.couchbase.client.core.cnc.events.service.ServiceAddedEvent
-
- ServiceAddIgnoredEvent - Class in com.couchbase.client.core.cnc.events.service
-
- ServiceAddIgnoredEvent(Event.Severity, ServiceAddIgnoredEvent.Reason, Context) - Constructor for class com.couchbase.client.core.cnc.events.service.ServiceAddIgnoredEvent
-
- ServiceAddIgnoredEvent.Reason - Enum in com.couchbase.client.core.cnc.events.service
-
Enumerates the reasons why a add service event could be ignored by the system.
- ServiceConfig - Interface in com.couchbase.client.core.service
-
- ServiceConnectInitiatedEvent - Class in com.couchbase.client.core.cnc.events.service
-
- ServiceConnectInitiatedEvent(ServiceContext, int) - Constructor for class com.couchbase.client.core.cnc.events.service.ServiceConnectInitiatedEvent
-
- serviceContext() - Method in class com.couchbase.client.core.msg.analytics.AnalyticsPingRequest
-
- serviceContext() - Method in class com.couchbase.client.core.msg.analytics.AnalyticsRequest
-
- serviceContext() - Method in class com.couchbase.client.core.msg.BaseRequest
-
- serviceContext() - Method in class com.couchbase.client.core.msg.kv.BaseKeyValueRequest
-
- serviceContext() - Method in class com.couchbase.client.core.msg.kv.CarrierBucketConfigRequest
-
- serviceContext() - Method in class com.couchbase.client.core.msg.kv.CarrierGlobalConfigRequest
-
- serviceContext() - Method in class com.couchbase.client.core.msg.kv.KvPingRequest
-
- serviceContext() - Method in class com.couchbase.client.core.msg.kv.ReplicaGetRequest
-
- serviceContext() - Method in class com.couchbase.client.core.msg.manager.BucketConfigRequest
-
- serviceContext() - Method in class com.couchbase.client.core.msg.query.QueryPingRequest
-
- serviceContext() - Method in class com.couchbase.client.core.msg.query.QueryRequest
-
- serviceContext() - Method in interface com.couchbase.client.core.msg.Request
-
Returns contextual information for each individual service.
- serviceContext() - Method in class com.couchbase.client.core.msg.search.SearchPingRequest
-
- serviceContext() - Method in class com.couchbase.client.core.msg.search.SearchRequest
-
- serviceContext() - Method in class com.couchbase.client.core.msg.view.ViewPingRequest
-
- serviceContext() - Method in class com.couchbase.client.core.msg.view.ViewRequest
-
- ServiceContext - Class in com.couchbase.client.core.service
-
- ServiceContext(CoreContext, String, int, ServiceType, Optional<String>) - Constructor for class com.couchbase.client.core.service.ServiceContext
-
- ServiceDisconnectInitiatedEvent - Class in com.couchbase.client.core.cnc.events.service
-
- ServiceDisconnectInitiatedEvent(ServiceContext, int) - Constructor for class com.couchbase.client.core.cnc.events.service.ServiceDisconnectInitiatedEvent
-
- serviceEnabled(ServiceType) - Method in class com.couchbase.client.core.config.AbstractBucketConfig
-
- serviceEnabled(ServiceType) - Method in interface com.couchbase.client.core.config.BucketConfig
-
Check if the service is enabled on the bucket.
- serviceEnabled(ServiceType) - Method in class com.couchbase.client.core.node.Node
-
- ServiceNotAvailableException - Exception in com.couchbase.client.core.error
-
Exception which states that the service is not available for the bucket.
- ServiceNotAvailableException(String, ErrorContext) - Constructor for exception com.couchbase.client.core.error.ServiceNotAvailableException
-
- ServiceReconfigurationFailedEvent - Class in com.couchbase.client.core.cnc.events.core
-
- ServiceReconfigurationFailedEvent(Context, String, ServiceType, Throwable) - Constructor for class com.couchbase.client.core.cnc.events.core.ServiceReconfigurationFailedEvent
-
- ServiceRemovedEvent - Class in com.couchbase.client.core.cnc.events.service
-
- ServiceRemovedEvent(Duration, ServiceContext) - Constructor for class com.couchbase.client.core.cnc.events.service.ServiceRemovedEvent
-
- ServiceRemoveIgnoredEvent - Class in com.couchbase.client.core.cnc.events.service
-
- ServiceRemoveIgnoredEvent(Event.Severity, ServiceRemoveIgnoredEvent.Reason, Context) - Constructor for class com.couchbase.client.core.cnc.events.service.ServiceRemoveIgnoredEvent
-
- ServiceRemoveIgnoredEvent.Reason - Enum in com.couchbase.client.core.cnc.events.service
-
Enumerates the reasons why a remove service event could be ignored by the system.
- services() - Method in class com.couchbase.client.core.config.AlternateAddress
-
- services() - Method in class com.couchbase.client.core.config.NodeInfo
-
- ServiceScope - Enum in com.couchbase.client.core.service
-
- serviceState(NodeIdentifier, ServiceType, Optional<String>) - Method in class com.couchbase.client.core.Core
-
If present, returns a flux that allows to monitor the state changes of a specific service.
- serviceState(ServiceType, Optional<String>) - Method in class com.couchbase.client.core.node.Node
-
If present, returns a flux that allows to monitor the state changes of a specific service.
- ServiceState - Enum in com.couchbase.client.core.service
-
Holds all states a
Service
can be in.
- ServiceStateChangedEvent - Class in com.couchbase.client.core.cnc.events.service
-
This event is raised every time a
Service
changes its state.
- ServiceStateChangedEvent(ServiceContext, ServiceState, ServiceState) - Constructor for class com.couchbase.client.core.cnc.events.service.ServiceStateChangedEvent
-
- servicesToCapture() - Method in class com.couchbase.client.core.env.IoConfig
-
Lists the services on which traffic should be captured.
- serviceType() - Method in class com.couchbase.client.core.cnc.events.core.ServiceReconfigurationFailedEvent
-
- serviceType() - Method in class com.couchbase.client.core.cnc.events.io.InvalidRequestDetectedEvent
-
- serviceType() - Method in class com.couchbase.client.core.diagnostics.HealthPinger.PingTarget
-
- serviceType() - Method in class com.couchbase.client.core.endpoint.EndpointContext
-
- serviceType() - Method in class com.couchbase.client.core.msg.analytics.AnalyticsPingRequest
-
- serviceType() - Method in class com.couchbase.client.core.msg.analytics.AnalyticsRequest
-
- serviceType() - Method in class com.couchbase.client.core.msg.analytics.GenericAnalyticsRequest
-
- serviceType() - Method in class com.couchbase.client.core.msg.kv.BaseKeyValueRequest
-
- serviceType() - Method in class com.couchbase.client.core.msg.manager.BaseManagerRequest
-
- serviceType() - Method in class com.couchbase.client.core.msg.query.QueryPingRequest
-
- serviceType() - Method in class com.couchbase.client.core.msg.query.QueryRequest
-
- serviceType() - Method in interface com.couchbase.client.core.msg.Request
-
The service type of this request.
- serviceType() - Method in class com.couchbase.client.core.msg.search.GenericSearchRequest
-
- serviceType() - Method in class com.couchbase.client.core.msg.search.SearchPingRequest
-
- serviceType() - Method in class com.couchbase.client.core.msg.search.SearchRequest
-
- serviceType() - Method in class com.couchbase.client.core.msg.view.GenericViewRequest
-
- serviceType() - Method in class com.couchbase.client.core.msg.view.ViewPingRequest
-
- serviceType() - Method in class com.couchbase.client.core.msg.view.ViewRequest
-
- serviceType() - Method in class com.couchbase.client.core.service.ServiceContext
-
- ServiceType - Enum in com.couchbase.client.core.service
-
Describes the types of services available in a couchbase cluster.
- set(String, String) - Method in class com.couchbase.client.core.util.UrlQueryStringBuilder
-
- set(String, int) - Method in class com.couchbase.client.core.util.UrlQueryStringBuilder
-
- set(String, long) - Method in class com.couchbase.client.core.util.UrlQueryStringBuilder
-
- set(String, boolean) - Method in class com.couchbase.client.core.util.UrlQueryStringBuilder
-
- setAttribute(String, String) - Method in interface com.couchbase.client.core.cnc.RequestSpan
-
Sets an attribute on the span, which is translated to the corresponding implementation specific tag.
- setAttribute(String, String) - Method in class com.couchbase.client.core.cnc.tracing.NoopRequestSpan
-
- setAttribute(String, String) - Method in class com.couchbase.client.core.cnc.tracing.ThresholdRequestSpan
-
- setBucketConfig(BucketConfig) - Method in class com.couchbase.client.core.config.ClusterConfig
-
- setDnsEnvParameter(String, String) - Static method in class com.couchbase.client.core.util.DnsSrv
-
- setGlobalConfig(GlobalConfig) - Method in class com.couchbase.client.core.config.ClusterConfig
-
- setOf(T...) - Static method in class com.couchbase.client.core.util.CbCollections
-
Returns an unmodifiable set containing the given items.
- setRedactionLevel(RedactionLevel) - Static method in class com.couchbase.client.core.logging.LogRedaction
-
Changes the redaction level.
- severity() - Method in class com.couchbase.client.core.cnc.AbstractEvent
-
- severity() - Method in interface com.couchbase.client.core.cnc.Event
-
The Severity of this event.
- severity() - Method in enum com.couchbase.client.core.cnc.events.config.ConfigIgnoredEvent.Reason
-
- severity() - Method in enum com.couchbase.client.core.cnc.events.core.InitGlobalConfigFailedEvent.Reason
-
- shouldRetry(Request<? extends Response>, RetryReason) - Method in class com.couchbase.client.core.retry.BestEffortRetryStrategy
-
Determines if a request should be retried or not (and if so, after which duration).
- shouldRetry(Request<? extends Response>, RetryReason) - Method in class com.couchbase.client.core.retry.FailFastRetryStrategy
-
- shouldRetry(Request<? extends Response>, RetryReason) - Method in interface com.couchbase.client.core.retry.RetryStrategy
-
Checks if the given request should be retried and how long the
retry delay should be.
- shutdown() - Method in interface com.couchbase.client.core.config.ConfigurationProvider
-
Shuts down the configuration provider and all its associated resources and timers.
- shutdown() - Method in class com.couchbase.client.core.config.DefaultConfigurationProvider
-
- shutdown() - Method in interface com.couchbase.client.core.config.refresher.BucketRefresher
-
Permanently shuts down the refresher.
- shutdown() - Method in class com.couchbase.client.core.config.refresher.ClusterManagerBucketRefresher
-
- shutdown() - Method in class com.couchbase.client.core.config.refresher.GlobalRefresher
-
- shutdown() - Method in class com.couchbase.client.core.config.refresher.KeyValueBucketRefresher
-
- shutdown() - Method in class com.couchbase.client.core.Core
-
- shutdown(Duration) - Method in class com.couchbase.client.core.Core
-
Shuts down this core and all associated, owned resources.
- shutdown(Duration) - Method in class com.couchbase.client.core.env.CoreEnvironment
-
Shuts down this Environment with a custom timeout.
- shutdown() - Method in class com.couchbase.client.core.env.CoreEnvironment
-
Shuts down this Environment with the default disconnect timeout.
- shutdown(Duration) - Method in class com.couchbase.client.core.env.IoEnvironment
-
Instructs all the owned event loops to shut down.
- SHUTDOWN - Static variable in class com.couchbase.client.core.msg.CancellationReason
-
The SDK has been shut down already when this request is dispatched.
- shutdownAsync() - Method in class com.couchbase.client.core.env.CoreEnvironment
-
Shuts down this Environment with the default disconnect timeout.
- shutdownAsync(Duration) - Method in class com.couchbase.client.core.env.CoreEnvironment
-
Shuts down this Environment with a custom timeout.
- ShutdownCompletedEvent - Class in com.couchbase.client.core.cnc.events.core
-
Raised when a core is successfully shut down.
- ShutdownCompletedEvent(Duration, Context) - Constructor for class com.couchbase.client.core.cnc.events.core.ShutdownCompletedEvent
-
- ShutdownInitiatedEvent - Class in com.couchbase.client.core.cnc.events.core
-
This event is raised when the core is beginning to shut down.
- ShutdownInitiatedEvent(Context) - Constructor for class com.couchbase.client.core.cnc.events.core.ShutdownInitiatedEvent
-
- shutdownReactive() - Method in class com.couchbase.client.core.env.CoreEnvironment
-
Shuts down this Environment with the default disconnect timeout.
- shutdownReactive(Duration) - Method in class com.couchbase.client.core.env.CoreEnvironment
-
Shuts down this Environment with a custom timeout.
- signalComplete() - Method in class com.couchbase.client.core.io.netty.analytics.AnalyticsChunkResponseParser
-
- signalComplete() - Method in class com.couchbase.client.core.io.netty.chunk.BaseChunkResponseParser
-
Called when the JSON stream has been parsed completely and successfully.
- signalComplete() - Method in class com.couchbase.client.core.io.netty.query.QueryChunkResponseParser
-
- signalComplete() - Method in class com.couchbase.client.core.io.netty.search.SearchChunkResponseParser
-
- signalComplete() - Method in class com.couchbase.client.core.io.netty.view.ViewChunkResponseParser
-
- signature() - Method in class com.couchbase.client.core.msg.analytics.AnalyticsChunkHeader
-
- signature() - Method in class com.couchbase.client.core.msg.query.QueryChunkHeader
-
- SimpleEventBus - Class in com.couchbase.client.core.cnc
-
This super simple event bus should be used in testing only to assert certain
events got pushed through.
- SimpleEventBus(boolean) - Constructor for class com.couchbase.client.core.cnc.SimpleEventBus
-
- SimpleEventBus(boolean, List<Class<? extends Event>>) - Constructor for class com.couchbase.client.core.cnc.SimpleEventBus
-
- SingleStateful<S> - Class in com.couchbase.client.core.util
-
Represents a single stateful component.
- skip(ByteBuf) - Static method in class com.couchbase.client.core.util.UnsignedLEB128
-
Advances the buffer's reader index past the unsigned LEB128 value at the reader index.
- sleepWindow(Duration) - Method in class com.couchbase.client.core.endpoint.CircuitBreakerConfig.Builder
-
The sleep window that is waited from when the circuit opens to when the canary is tried.
- sleepWindow(Duration) - Static method in class com.couchbase.client.core.endpoint.CircuitBreakerConfig
-
- sleepWindow() - Method in class com.couchbase.client.core.endpoint.CircuitBreakerConfig
-
Returns the configured sleep window after which a canary is allowed to go through.
- SPAN_DISPATCH - Static variable in class com.couchbase.client.core.cnc.TracingIdentifiers
-
A common name for the dispatch span that implementations should use.
- SPAN_REQUEST_ANALYTICS - Static variable in class com.couchbase.client.core.cnc.TracingIdentifiers
-
- SPAN_REQUEST_ENCODING - Static variable in class com.couchbase.client.core.cnc.TracingIdentifiers
-
A common name for the value encode span that implementations should use.
- SPAN_REQUEST_KV_APPEND - Static variable in class com.couchbase.client.core.cnc.TracingIdentifiers
-
- SPAN_REQUEST_KV_DECREMENT - Static variable in class com.couchbase.client.core.cnc.TracingIdentifiers
-
- SPAN_REQUEST_KV_EXISTS - Static variable in class com.couchbase.client.core.cnc.TracingIdentifiers
-
- SPAN_REQUEST_KV_GAL - Static variable in class com.couchbase.client.core.cnc.TracingIdentifiers
-
- SPAN_REQUEST_KV_GAT - Static variable in class com.couchbase.client.core.cnc.TracingIdentifiers
-
- SPAN_REQUEST_KV_GET - Static variable in class com.couchbase.client.core.cnc.TracingIdentifiers
-
- SPAN_REQUEST_KV_GET_REPLICA - Static variable in class com.couchbase.client.core.cnc.TracingIdentifiers
-
- SPAN_REQUEST_KV_INCREMENT - Static variable in class com.couchbase.client.core.cnc.TracingIdentifiers
-
- SPAN_REQUEST_KV_INSERT - Static variable in class com.couchbase.client.core.cnc.TracingIdentifiers
-
- SPAN_REQUEST_KV_LOOKUP_IN - Static variable in class com.couchbase.client.core.cnc.TracingIdentifiers
-
- SPAN_REQUEST_KV_MUTATE_IN - Static variable in class com.couchbase.client.core.cnc.TracingIdentifiers
-
- SPAN_REQUEST_KV_OBSERVE - Static variable in class com.couchbase.client.core.cnc.TracingIdentifiers
-
- SPAN_REQUEST_KV_PREPEND - Static variable in class com.couchbase.client.core.cnc.TracingIdentifiers
-
- SPAN_REQUEST_KV_REMOVE - Static variable in class com.couchbase.client.core.cnc.TracingIdentifiers
-
- SPAN_REQUEST_KV_REPLACE - Static variable in class com.couchbase.client.core.cnc.TracingIdentifiers
-
- SPAN_REQUEST_KV_TOUCH - Static variable in class com.couchbase.client.core.cnc.TracingIdentifiers
-
- SPAN_REQUEST_KV_UNLOCK - Static variable in class com.couchbase.client.core.cnc.TracingIdentifiers
-
- SPAN_REQUEST_KV_UPSERT - Static variable in class com.couchbase.client.core.cnc.TracingIdentifiers
-
- SPAN_REQUEST_MANAGER_ANALYTICS - Static variable in class com.couchbase.client.core.cnc.TracingIdentifiers
-
- SPAN_REQUEST_MANAGER_BUCKETS - Static variable in class com.couchbase.client.core.cnc.TracingIdentifiers
-
- SPAN_REQUEST_MANAGER_COLLECTIONS - Static variable in class com.couchbase.client.core.cnc.TracingIdentifiers
-
- SPAN_REQUEST_MANAGER_QUERY - Static variable in class com.couchbase.client.core.cnc.TracingIdentifiers
-
- SPAN_REQUEST_MANAGER_SEARCH - Static variable in class com.couchbase.client.core.cnc.TracingIdentifiers
-
- SPAN_REQUEST_MANAGER_USERS - Static variable in class com.couchbase.client.core.cnc.TracingIdentifiers
-
- SPAN_REQUEST_MANAGER_VIEWS - Static variable in class com.couchbase.client.core.cnc.TracingIdentifiers
-
- SPAN_REQUEST_QUERY - Static variable in class com.couchbase.client.core.cnc.TracingIdentifiers
-
- SPAN_REQUEST_SEARCH - Static variable in class com.couchbase.client.core.cnc.TracingIdentifiers
-
- SPAN_REQUEST_VIEWS - Static variable in class com.couchbase.client.core.cnc.TracingIdentifiers
-
- sslException() - Method in class com.couchbase.client.core.cnc.events.io.SecureConnectionFailedEvent
-
- SslHandlerFactory - Class in com.couchbase.client.core.io.netty
-
This factory creates SslHandler
based on a given configuration.
- SslHandlerFactory() - Constructor for class com.couchbase.client.core.io.netty.SslHandlerFactory
-
- sslPorts() - Method in class com.couchbase.client.core.config.PortInfo
-
- sslServices() - Method in class com.couchbase.client.core.config.AlternateAddress
-
- sslServices() - Method in class com.couchbase.client.core.config.NodeInfo
-
- Stability - Annotation Type in com.couchbase.client.core.annotation
-
This annotation describes the stability guarantees of the annotated
interface, class or method.
- Stability.Committed - Annotation Type in com.couchbase.client.core.annotation
-
A committed interface is the highest grade of stability, and is the preferred attribute
level for consumers of the library.
- Stability.Internal - Annotation Type in com.couchbase.client.core.annotation
-
This is internal API and may not be relied on at all.
- Stability.Uncommitted - Annotation Type in com.couchbase.client.core.annotation
-
No commitment is made about the interface.
- Stability.Volatile - Annotation Type in com.couchbase.client.core.annotation
-
Types/Methods/Interfaces marked as volatile can change any time and
for any reason.
- StandardMemcachedHashingStrategy - Class in com.couchbase.client.core.node
-
- start() - Method in class com.couchbase.client.core.cnc.DefaultEventBus
-
- start() - Method in interface com.couchbase.client.core.cnc.EventBus
-
Starts the event bus if it hasn't been started yet.
- start() - Method in interface com.couchbase.client.core.cnc.Meter
-
Starts the meter if it hasn't been started, might be a noop depending on the implementation.
- start() - Method in class com.couchbase.client.core.cnc.metrics.AggregatingMeter
-
- start() - Method in class com.couchbase.client.core.cnc.OrphanReporter
-
Starts the orphan reporter.
- start() - Method in interface com.couchbase.client.core.cnc.RequestTracer
-
Starts the tracer if it hasn't been started, might be a noop depending on the implementation.
- start() - Method in class com.couchbase.client.core.cnc.SimpleEventBus
-
- start() - Method in class com.couchbase.client.core.cnc.tracing.NoopRequestTracer
-
- start() - Method in class com.couchbase.client.core.cnc.tracing.ThresholdRequestTracer
-
- start() - Method in class com.couchbase.client.core.config.refresher.GlobalRefresher
-
- start(Channel, Class<?>) - Static method in class com.couchbase.client.core.io.netty.kv.ConnectTimings
-
Start the connect timings for a given class and channel.
- start() - Method in class com.couchbase.client.core.Timer
-
Starts this timer.
- state() - Method in class com.couchbase.client.core.diagnostics.DiagnosticsResult
-
Returns the aggregated and simplified cluster state.
- state() - Method in class com.couchbase.client.core.diagnostics.EndpointDiagnostics
-
The current state of the endpoint.
- state() - Method in class com.couchbase.client.core.diagnostics.EndpointPingReport
-
The state of this ping when assembling the report.
- state() - Method in class com.couchbase.client.core.endpoint.BaseEndpoint
-
- state() - Method in interface com.couchbase.client.core.endpoint.CircuitBreaker
-
Returns the current state of the circuit breaker.
- state() - Method in class com.couchbase.client.core.endpoint.NoopCircuitBreaker
-
- state() - Method in class com.couchbase.client.core.node.Node
-
- state() - Method in class com.couchbase.client.core.util.CompositeStateful
-
- state() - Method in class com.couchbase.client.core.util.SingleStateful
-
- state() - Method in interface com.couchbase.client.core.util.Stateful
-
Returns the current state of the stateful component.
- Stateful<S> - Interface in com.couchbase.client.core.util
-
Common interface for stateful components.
- statement() - Method in class com.couchbase.client.core.msg.analytics.AnalyticsRequest
-
- statement() - Method in class com.couchbase.client.core.msg.query.QueryRequest
-
- states() - Method in class com.couchbase.client.core.endpoint.BaseEndpoint
-
- states() - Method in class com.couchbase.client.core.node.Node
-
- states() - Method in class com.couchbase.client.core.util.CompositeStateful
-
- states() - Method in class com.couchbase.client.core.util.SingleStateful
-
- states() - Method in interface com.couchbase.client.core.util.Stateful
-
Returns a stream of states for this component as they change.
- status() - Method in class com.couchbase.client.core.cnc.events.io.ErrorMapLoadingFailedEvent
-
Returns the KV status which was not successful, useful for debugging.
- status() - Method in class com.couchbase.client.core.cnc.events.io.FeaturesNegotiationFailedEvent
-
Returns the KV status which was not successful, useful for debugging.
- status() - Method in class com.couchbase.client.core.cnc.events.io.SelectBucketFailedEvent
-
- status() - Method in class com.couchbase.client.core.cnc.events.io.UnknownResponseStatusReceivedEvent
-
- status(ByteBuf) - Static method in enum com.couchbase.client.core.io.netty.kv.MemcacheProtocol
-
Returns the status of that response.
- status() - Method in enum com.couchbase.client.core.io.netty.kv.MemcacheProtocol.Status
-
Returns the status code for the status enum.
- status() - Method in class com.couchbase.client.core.msg.analytics.AnalyticsChunkTrailer
-
- status() - Method in class com.couchbase.client.core.msg.BaseResponse
-
- status() - Method in class com.couchbase.client.core.msg.kv.SubDocumentField
-
- status() - Method in class com.couchbase.client.core.msg.query.QueryChunkTrailer
-
- status() - Method in interface com.couchbase.client.core.msg.Response
-
Holds the status of the response.
- statusDetails() - Method in class com.couchbase.client.core.msg.kv.ObserveViaCasResponse
-
- stop(Duration) - Method in class com.couchbase.client.core.cnc.DefaultEventBus
-
- stop(Duration) - Method in interface com.couchbase.client.core.cnc.EventBus
-
Stops the event bus if it hasn't been stopped already.
- stop(Duration) - Method in interface com.couchbase.client.core.cnc.Meter
-
Stops the metrics if it has been started previously, might be a noop depending on the implementation.
- stop(Duration) - Method in class com.couchbase.client.core.cnc.metrics.AggregatingMeter
-
- stop() - Method in class com.couchbase.client.core.cnc.OrphanReporter
-
Stops the orphan reporter.
- stop(Duration) - Method in interface com.couchbase.client.core.cnc.RequestTracer
-
Stops the tracer if it has been started previously, might be a noop depending on the implementation.
- stop(Duration) - Method in class com.couchbase.client.core.cnc.SimpleEventBus
-
- stop(Duration) - Method in class com.couchbase.client.core.cnc.tracing.NoopRequestTracer
-
- stop(Duration) - Method in class com.couchbase.client.core.cnc.tracing.ThresholdRequestTracer
-
- stop() - Method in class com.couchbase.client.core.config.refresher.GlobalRefresher
-
- stop(Channel, Class<?>, boolean) - Static method in class com.couchbase.client.core.io.netty.kv.ConnectTimings
-
Stops the timing.
- stop() - Method in class com.couchbase.client.core.Timer
-
Stops this timer.
- STOPPED_LISTENING - Static variable in class com.couchbase.client.core.msg.CancellationReason
-
The downstream consumer stopped listening for a result and therefore any further
processing is a waste of resources.
- str() - Method in class com.couchbase.client.core.projections.PathArray
-
- str() - Method in class com.couchbase.client.core.projections.PathObjectOrField
-
- strategy() - Method in class com.couchbase.client.core.io.netty.kv.ErrorMap.RetrySpecification
-
- strategy() - Method in enum com.couchbase.client.core.io.netty.kv.ErrorMap.RetryStrategy
-
- streamingUri() - Method in class com.couchbase.client.core.config.AbstractBucketConfig
-
- streamingUri() - Method in interface com.couchbase.client.core.config.BucketConfig
-
The HTTP Streaming URI for this bucket.
- StreamWindow - Interface in com.couchbase.client.core.json.stream
-
A sliding window over the contents of a byte stream.
- STRING - Static variable in interface com.couchbase.client.core.cnc.Context.ExportFormat
-
Java "toString" basically.
- STRING_COMMON_FLAGS - Static variable in enum com.couchbase.client.core.msg.kv.CodecFlags
-
- STRING_COMPAT_FLAGS - Static variable in enum com.couchbase.client.core.msg.kv.CodecFlags
-
- STRING_LEGACY_FLAGS - Static variable in enum com.couchbase.client.core.msg.kv.CodecFlags
-
- stringify(ResponseStatus, ResponseStatusDetails) - Static method in class com.couchbase.client.core.msg.kv.ResponseStatusDetails
-
Stringify the status details and the status in a best effort manner.
- SUBDOC_DOC_FLAG_ACCESS_DELETED - Static variable in class com.couchbase.client.core.msg.kv.SubdocMutateRequest
-
- SUBDOC_DOC_FLAG_CREATE_AS_DELETED - Static variable in class com.couchbase.client.core.msg.kv.SubdocMutateRequest
-
- SUBDOC_MAX_FIELDS - Static variable in class com.couchbase.client.core.msg.kv.SubdocMutateRequest
-
- SubdocCommandType - Enum in com.couchbase.client.core.msg.kv
-
- SubdocGetRequest - Class in com.couchbase.client.core.msg.kv
-
- SubdocGetRequest(Duration, CoreContext, CollectionIdentifier, RetryStrategy, String, byte, List<SubdocGetRequest.Command>, RequestSpan) - Constructor for class com.couchbase.client.core.msg.kv.SubdocGetRequest
-
- SubdocGetRequest.Command - Class in com.couchbase.client.core.msg.kv
-
- SubdocGetResponse - Class in com.couchbase.client.core.msg.kv
-
- SubdocGetResponse(ResponseStatus, Optional<CouchbaseException>, SubDocumentField[], long, boolean) - Constructor for class com.couchbase.client.core.msg.kv.SubdocGetResponse
-
- SubdocMutateRequest - Class in com.couchbase.client.core.msg.kv
-
- SubdocMutateRequest(Duration, CoreContext, CollectionIdentifier, BucketConfig, RetryStrategy, String, boolean, boolean, boolean, boolean, List<SubdocMutateRequest.Command>, long, long, Optional<DurabilityLevel>, RequestSpan) - Constructor for class com.couchbase.client.core.msg.kv.SubdocMutateRequest
-
- SubdocMutateRequest.Command - Class in com.couchbase.client.core.msg.kv
-
- SubdocMutateResponse - Class in com.couchbase.client.core.msg.kv
-
- SubdocMutateResponse(ResponseStatus, Optional<CouchbaseException>, SubDocumentField[], long, Optional<MutationToken>) - Constructor for class com.couchbase.client.core.msg.kv.SubdocMutateResponse
-
- SubDocumentErrorContext - Class in com.couchbase.client.core.error.context
-
- SubDocumentErrorContext(KeyValueErrorContext, int, String, SubDocumentOpResponseStatus) - Constructor for class com.couchbase.client.core.error.context.SubDocumentErrorContext
-
- SubDocumentField - Class in com.couchbase.client.core.msg.kv
-
- SubDocumentField(SubDocumentOpResponseStatus, Optional<CouchbaseException>, byte[], String, SubdocCommandType) - Constructor for class com.couchbase.client.core.msg.kv.SubDocumentField
-
- SubDocumentOpResponseStatus - Enum in com.couchbase.client.core.msg.kv
-
- subscribe(Consumer<Event>) - Method in class com.couchbase.client.core.cnc.DefaultEventBus
-
- subscribe(Consumer<Event>) - Method in interface com.couchbase.client.core.cnc.EventBus
-
- subscribe(Consumer<Event>) - Method in class com.couchbase.client.core.cnc.SimpleEventBus
-
- succeed(R) - Method in class com.couchbase.client.core.msg.BaseRequest
-
- succeed(R) - Method in interface com.couchbase.client.core.msg.Request
-
Completes this request successfully.
- succeeded() - Method in class com.couchbase.client.core.msg.BaseRequest
-
- succeeded() - Method in interface com.couchbase.client.core.msg.Request
-
Allows to check if this request has been successfully completed.
- success() - Method in enum com.couchbase.client.core.msg.kv.SubDocumentOpResponseStatus
-
- success() - Method in enum com.couchbase.client.core.msg.ResponseStatus
-
- successful(ByteBuf) - Static method in enum com.couchbase.client.core.io.netty.kv.MemcacheProtocol
-
Helper method to check if the given response has a successful status.
- supportsNonTls() - Method in interface com.couchbase.client.core.env.Authenticator
-
If this authenticator supports non-encrypted connections.
- supportsNonTls() - Method in class com.couchbase.client.core.env.CertificateAuthenticator
-
- supportsTls() - Method in interface com.couchbase.client.core.env.Authenticator
-
If this authenticator supports encrypted connections.
- SuspiciousExpiryDurationEvent - Class in com.couchbase.client.core.cnc.events.request
-
- SuspiciousExpiryDurationEvent(Duration) - Constructor for class com.couchbase.client.core.cnc.events.request.SuspiciousExpiryDurationEvent
-
Deprecated.
- SWITCHER_IDENTIFIER - Static variable in class com.couchbase.client.core.io.netty.ChunkedHandlerSwitcher
-
- SYNC_REPLICATION_FLEXIBLE_IDENT - Static variable in enum com.couchbase.client.core.io.netty.kv.MemcacheProtocol
-
Flag which indicates that this flexible extra frame is for syc replication.
- SYNC_REPLICATION_TIMEOUT_FLOOR_MS - Static variable in enum com.couchbase.client.core.io.netty.kv.MemcacheProtocol
-
Minimum sync durability timeout that can be set and which will override any lower
user-provided value.
- SyncDurabilityRequest - Interface in com.couchbase.client.core.msg.kv
-
Marker interface to signal that the given request supports synchronous durability.
- syncReplicationEnabled() - Method in class com.couchbase.client.core.io.netty.kv.KeyValueChannelContext
-
- SystemPropertyPropertyLoader - Class in com.couchbase.client.core.env
-
- SystemPropertyPropertyLoader() - Constructor for class com.couchbase.client.core.env.SystemPropertyPropertyLoader
-
- SystemPropertyPropertyLoader(Properties) - Constructor for class com.couchbase.client.core.env.SystemPropertyPropertyLoader
-
- tainted() - Method in interface com.couchbase.client.core.config.BucketConfig
-
Returns true if the config indicates the cluster is undergoing
a transition (such as a rebalance operation).
- tainted() - Method in class com.couchbase.client.core.config.CouchbaseBucketConfig
-
- tainted() - Method in class com.couchbase.client.core.config.MemcachedBucketConfig
-
- tainted() - Method in class com.couchbase.client.core.config.PartitionInfo
-
- target() - Method in class com.couchbase.client.core.msg.analytics.AnalyticsPingRequest
-
- target() - Method in class com.couchbase.client.core.msg.kv.CarrierBucketConfigRequest
-
- target() - Method in class com.couchbase.client.core.msg.kv.CarrierGlobalConfigRequest
-
- target() - Method in class com.couchbase.client.core.msg.kv.KvPingRequest
-
- target() - Method in class com.couchbase.client.core.msg.kv.MultiObserveViaCasRequest
-
- target() - Method in class com.couchbase.client.core.msg.manager.BucketConfigRequest
-
- target() - Method in class com.couchbase.client.core.msg.query.QueryPingRequest
-
- target() - Method in class com.couchbase.client.core.msg.query.TargetedQueryRequest
-
- target() - Method in class com.couchbase.client.core.msg.search.SearchPingRequest
-
- target() - Method in interface com.couchbase.client.core.msg.TargetedRequest
-
The target where this request must be dispatched to.
- target() - Method in class com.couchbase.client.core.msg.view.ViewPingRequest
-
- TARGET_NODE_REMOVED - Static variable in class com.couchbase.client.core.msg.CancellationReason
-
When a
TargetedRequest
is dispatched but the list of nodes does not contain the target at all,
there is good chance that this request will not be able to make progress anymore so it will be cancelled.
- TargetedQueryRequest - Class in com.couchbase.client.core.msg.query
-
- TargetedQueryRequest(Duration, CoreContext, RetryStrategy, Authenticator, String, byte[], boolean, String, RequestSpan, String, NodeIdentifier) - Constructor for class com.couchbase.client.core.msg.query.TargetedQueryRequest
-
- TargetedRequest - Interface in com.couchbase.client.core.msg
-
Marker interface to signal a request that can only be sent to the specified target node.
- tcpKeepAlivesEnabled() - Method in class com.couchbase.client.core.env.IoConfig
-
- tcpKeepAliveTime(Duration) - Method in class com.couchbase.client.core.env.IoConfig.Builder
-
Allows to customize the idle time after which a tcp keepalive gets fired.
- tcpKeepAliveTime(Duration) - Static method in class com.couchbase.client.core.env.IoConfig
-
- tcpKeepAliveTime() - Method in class com.couchbase.client.core.env.IoConfig
-
- TemporaryFailureException - Exception in com.couchbase.client.core.error
-
Thrown when the server reports a temporary failure.
- TemporaryFailureException(ErrorContext) - Constructor for exception com.couchbase.client.core.error.TemporaryFailureException
-
- threadName(String) - Method in class com.couchbase.client.core.cnc.DefaultEventBus.Builder
-
- ThresholdRequestSpan - Class in com.couchbase.client.core.cnc.tracing
-
- ThresholdRequestTracer - Class in com.couchbase.client.core.cnc.tracing
-
The default tracing implementation, which tracks the top N slowest requests per service and dumps them at
configurable intervals.
- ThresholdRequestTracer.Builder - Class in com.couchbase.client.core.cnc.tracing
-
- thresholdRequestTracerConfig(ThresholdRequestTracerConfig.Builder) - Method in class com.couchbase.client.core.env.CoreEnvironment.Builder
-
Allows to customize the threshold request tracer configuration.
- thresholdRequestTracerConfig() - Method in class com.couchbase.client.core.env.CoreEnvironment.Builder
-
- ThresholdRequestTracerConfig - Class in com.couchbase.client.core.env
-
- ThresholdRequestTracerConfig.Builder - Class in com.couchbase.client.core.env
-
- throwIfInstanceOf(Throwable, Class<T>) - Static method in class com.couchbase.client.core.util.CbThrowables
-
If the given Throwable is an instance of the given class, throw it.
- throwIfUnchecked(Throwable) - Static method in class com.couchbase.client.core.util.CbThrowables
-
If the given Throwable is an instance of RuntimeException or Error, throw it.
- timeout() - Method in class com.couchbase.client.core.msg.BaseRequest
-
- TIMEOUT - Static variable in class com.couchbase.client.core.msg.CancellationReason
-
The request ran into a timeout and is therefore cancelled before it got a chance
to complete.
- timeout() - Method in interface com.couchbase.client.core.msg.Request
-
Returns the timeout for this request.
- timeout(Duration) - Method in class com.couchbase.client.core.retry.reactor.DefaultRepeat
-
- timeout(Duration) - Method in class com.couchbase.client.core.retry.reactor.DefaultRetry
-
- timeout(Duration) - Method in interface com.couchbase.client.core.retry.reactor.Repeat
-
Returns a repeat function with timeout.
- timeout(Duration) - Method in interface com.couchbase.client.core.retry.reactor.Retry
-
Returns a retry function with timeout.
- timeout() - Method in class com.couchbase.client.core.service.kv.ObserveContext
-
- timeoutConfig(TimeoutConfig.Builder) - Method in class com.couchbase.client.core.env.CoreEnvironment.Builder
-
Allows to customize the default timeouts for all operations.
- timeoutConfig() - Method in class com.couchbase.client.core.env.CoreEnvironment.Builder
-
Returns the currently stored config builder.
- timeoutConfig() - Method in class com.couchbase.client.core.env.CoreEnvironment
-
Returns the configuration for all default timeouts.
- TimeoutConfig - Class in com.couchbase.client.core.env
-
- TimeoutConfig.Builder - Class in com.couchbase.client.core.env
-
- timeoutElapsed() - Method in class com.couchbase.client.core.msg.BaseRequest
-
- timeoutElapsed() - Method in interface com.couchbase.client.core.msg.Request
-
Returns true if the timeout elapsed.
- TimeoutException - Exception in com.couchbase.client.core.error
-
The
TimeoutException
signals that an operation timed out before it could be completed.
- TimeoutException(String, CancellationErrorContext) - Constructor for exception com.couchbase.client.core.error.TimeoutException
-
- timer() - Method in class com.couchbase.client.core.env.CoreEnvironment
-
Returns the timer used to schedule timeouts and retries amongst other tasks.
- Timer - Class in com.couchbase.client.core
-
The
Timer
acts as the main timing facility for various operations, for
example to track and time out requests if they run for too long or for rescheduling needs.
- times(long) - Static method in interface com.couchbase.client.core.retry.reactor.Repeat
-
Repeat function that repeats n times.
- timings() - Method in class com.couchbase.client.core.cnc.events.endpoint.EndpointConnectedEvent
-
Returns the timings captured as part of the endpoint connection process.
- timings() - Method in class com.couchbase.client.core.cnc.events.endpoint.EndpointConnectionAbortedEvent
-
Returns the timings captured as part of the endpoint connection process.
- timings() - Method in class com.couchbase.client.core.cnc.events.endpoint.EndpointConnectionIgnoredEvent
-
Returns the timings captured as part of the endpoint connection process.
- tlsEnabled() - Method in class com.couchbase.client.core.env.SecurityConfig
-
True if TLS is enabled, false otherwise.
- toFlux(Supplier<CompletableFuture<C>>) - Static method in class com.couchbase.client.core.Reactor
-
Helper method to wrap an async call into a reactive one and translate
exceptions appropriately.
- toMap(Channel) - Static method in class com.couchbase.client.core.io.netty.kv.ConnectTimings
-
- toMono(Supplier<CompletableFuture<T>>) - Static method in class com.couchbase.client.core.Reactor
-
Helper method to wrap an async call into a reactive one and translate
exceptions appropriately.
- TOO_MANY_REQUESTS_IN_RETRY - Static variable in class com.couchbase.client.core.msg.CancellationReason
-
If too many outstanding requests are waiting to be completed.
- took() - Method in class com.couchbase.client.core.msg.search.SearchChunkTrailer
-
- toReactorRetry() - Method in interface com.couchbase.client.core.retry.reactor.Retry
-
Converts this retry function to a reactor retry function for compatibility.
- toString() - Method in class com.couchbase.client.core.cnc.AbstractContext
-
- toString() - Method in class com.couchbase.client.core.cnc.AbstractEvent
-
- toString() - Method in class com.couchbase.client.core.cnc.metrics.AggregatingValueRecorder
-
- toString() - Method in class com.couchbase.client.core.cnc.metrics.NoopMeter
-
- toString() - Method in class com.couchbase.client.core.config.AlternateAddress
-
- toString() - Method in class com.couchbase.client.core.config.ClusterConfig
-
- toString() - Method in class com.couchbase.client.core.config.CollectionsManifest
-
- toString() - Method in class com.couchbase.client.core.config.CollectionsManifestCollection
-
- toString() - Method in class com.couchbase.client.core.config.CollectionsManifestScope
-
- toString() - Method in class com.couchbase.client.core.config.CouchbaseBucketConfig
-
- toString() - Method in class com.couchbase.client.core.config.GlobalConfig
-
- toString() - Method in class com.couchbase.client.core.config.MemcachedBucketConfig
-
Note that dumping the whole ring is pretty much useless, so here we focus on just dumping all the nodes
that participate in the cluster instead.
- toString() - Method in class com.couchbase.client.core.config.NodeInfo
-
- toString() - Method in class com.couchbase.client.core.config.Partition
-
- toString() - Method in class com.couchbase.client.core.config.PartitionInfo
-
- toString() - Method in class com.couchbase.client.core.config.PortInfo
-
- toString() - Method in class com.couchbase.client.core.config.ProposedGlobalConfigContext
-
- toString() - Method in class com.couchbase.client.core.diagnostics.DiagnosticsResult
-
- toString() - Method in class com.couchbase.client.core.diagnostics.EndpointDiagnostics
-
- toString() - Method in class com.couchbase.client.core.diagnostics.EndpointPingReport
-
- toString() - Method in class com.couchbase.client.core.diagnostics.HealthPinger.PingTarget
-
- toString() - Method in class com.couchbase.client.core.diagnostics.PingResult
-
- toString() - Method in class com.couchbase.client.core.env.CertificateAuthenticator
-
- toString() - Method in class com.couchbase.client.core.env.CoreEnvironment
-
- toString() - Method in class com.couchbase.client.core.env.ExternalSupplier
-
- toString() - Method in class com.couchbase.client.core.env.NetworkResolution
-
- toString() - Method in class com.couchbase.client.core.env.OwnedSupplier
-
- toString() - Method in class com.couchbase.client.core.env.SeedNode
-
- toString() - Method in class com.couchbase.client.core.env.UserAgent
-
- toString() - Method in exception com.couchbase.client.core.error.CouchbaseException
-
- toString() - Method in class com.couchbase.client.core.error.ErrorCodeAndMessage
-
- toString() - Method in class com.couchbase.client.core.io.CollectionIdentifier
-
- toString(Channel) - Static method in class com.couchbase.client.core.io.netty.kv.ConnectTimings
-
Exports the timings into a string.
- toString() - Method in class com.couchbase.client.core.io.netty.kv.ErrorMap.ErrorCode
-
- toString() - Method in class com.couchbase.client.core.io.netty.kv.ErrorMap.RetrySpecification
-
- toString() - Method in class com.couchbase.client.core.io.netty.kv.ErrorMap
-
- toString() - Method in class com.couchbase.client.core.json.stream.CopyingStreamWindow
-
- toString() - Method in class com.couchbase.client.core.json.stream.MatchedValue
-
- toString() - Method in class com.couchbase.client.core.logging.RedactableArgument
-
- toString() - Method in class com.couchbase.client.core.msg.analytics.AnalyticsChunkHeader
-
- toString() - Method in class com.couchbase.client.core.msg.analytics.AnalyticsChunkRow
-
- toString() - Method in class com.couchbase.client.core.msg.analytics.AnalyticsChunkTrailer
-
- toString() - Method in class com.couchbase.client.core.msg.analytics.AnalyticsResponse
-
- toString() - Method in class com.couchbase.client.core.msg.analytics.GenericAnalyticsResponse
-
- toString() - Method in class com.couchbase.client.core.msg.CancellationReason
-
- toString() - Method in class com.couchbase.client.core.msg.kv.CarrierBucketConfigResponse
-
- toString() - Method in class com.couchbase.client.core.msg.kv.CarrierGlobalConfigResponse
-
- toString() - Method in class com.couchbase.client.core.msg.kv.GetCollectionManifestResponse
-
- toString() - Method in class com.couchbase.client.core.msg.kv.GetMetaResponse
-
- toString() - Method in class com.couchbase.client.core.msg.kv.MultiObserveViaCasResponse
-
- toString() - Method in class com.couchbase.client.core.msg.kv.MutationToken
-
- toString() - Method in class com.couchbase.client.core.msg.kv.ObserveViaCasResponse
-
- toString() - Method in class com.couchbase.client.core.msg.kv.ObserveViaSeqnoResponse
-
- toString() - Method in class com.couchbase.client.core.msg.kv.ResponseStatusDetails
-
- toString() - Method in class com.couchbase.client.core.msg.kv.SubdocGetResponse
-
- toString() - Method in class com.couchbase.client.core.msg.kv.SubdocMutateResponse
-
- toString() - Method in class com.couchbase.client.core.msg.kv.SubDocumentField
-
- toString() - Method in class com.couchbase.client.core.msg.kv.UpsertResponse
-
- toString() - Method in class com.couchbase.client.core.msg.manager.BucketConfigResponse
-
- toString() - Method in class com.couchbase.client.core.msg.manager.GenericManagerResponse
-
- toString() - Method in class com.couchbase.client.core.msg.query.QueryChunkHeader
-
- toString() - Method in class com.couchbase.client.core.msg.query.QueryChunkRow
-
- toString() - Method in class com.couchbase.client.core.msg.query.QueryChunkTrailer
-
- toString() - Method in class com.couchbase.client.core.msg.query.QueryRequest
-
- toString() - Method in class com.couchbase.client.core.msg.query.QueryResponse
-
- toString() - Method in class com.couchbase.client.core.msg.search.GenericSearchResponse
-
- toString() - Method in class com.couchbase.client.core.msg.search.SearchChunkHeader
-
- toString() - Method in class com.couchbase.client.core.msg.search.SearchChunkRow
-
- toString() - Method in class com.couchbase.client.core.msg.search.SearchChunkTrailer
-
- toString() - Method in class com.couchbase.client.core.msg.view.GenericViewResponse
-
- toString() - Method in class com.couchbase.client.core.msg.view.ViewChunkHeader
-
- toString() - Method in class com.couchbase.client.core.msg.view.ViewChunkRow
-
- toString() - Method in class com.couchbase.client.core.msg.view.ViewChunkTrailer
-
- toString() - Method in class com.couchbase.client.core.msg.view.ViewError
-
- toString() - Method in class com.couchbase.client.core.msg.view.ViewResponse
-
- toString() - Method in class com.couchbase.client.core.node.Node
-
- toString() - Method in class com.couchbase.client.core.node.NodeIdentifier
-
- toString() - Method in class com.couchbase.client.core.projections.PathArray
-
- toString() - Method in class com.couchbase.client.core.projections.PathObjectOrField
-
- toString() - Method in class com.couchbase.client.core.retry.BestEffortRetryStrategy
-
- toString() - Method in class com.couchbase.client.core.retry.FailFastRetryStrategy
-
- toString() - Method in class com.couchbase.client.core.retry.reactor.BackoffDelay
-
- toString() - Method in class com.couchbase.client.core.retry.reactor.DefaultContext
-
- toString() - Method in class com.couchbase.client.core.retry.reactor.DefaultRepeat
-
- toString() - Method in class com.couchbase.client.core.retry.reactor.DefaultRetry
-
- toString() - Method in class com.couchbase.client.core.scheduler.SchedulerClock
-
- toString() - Method in class com.couchbase.client.core.service.AbstractPooledEndpointServiceConfig
-
- toString() - Method in class com.couchbase.client.core.service.KeyValueServiceConfig
-
- toString() - Method in class com.couchbase.client.core.Timer
-
- toString() - Method in class com.couchbase.client.core.util.ConnectionString
-
- toString() - Method in class com.couchbase.client.core.util.ConnectionString.UnresolvedSocket
-
- toString() - Method in class com.couchbase.client.core.util.HostAndPort
-
- toString() - Method in class com.couchbase.client.core.util.UrlQueryStringBuilder
-
- totalRows() - Method in class com.couchbase.client.core.msg.search.SearchChunkTrailer
-
- totalRows() - Method in class com.couchbase.client.core.msg.view.ViewChunkHeader
-
- touchesReplica() - Method in enum com.couchbase.client.core.service.kv.Observe.ObservePersistTo
-
Identifies if this enum property will touch a replica or just the active.
- touchesReplica() - Method in enum com.couchbase.client.core.service.kv.Observe.ObserveReplicateTo
-
Identifies if this enum property will touch a replica or just the active.
- TouchRequest - Class in com.couchbase.client.core.msg.kv
-
- TouchRequest(Duration, CoreContext, CollectionIdentifier, RetryStrategy, String, long, RequestSpan) - Constructor for class com.couchbase.client.core.msg.kv.TouchRequest
-
- TouchResponse - Class in com.couchbase.client.core.msg.kv
-
- TouchResponse(ResponseStatus, long, Optional<MutationToken>) - Constructor for class com.couchbase.client.core.msg.kv.TouchResponse
-
- trace(String) - Method in interface com.couchbase.client.core.cnc.LoggingEventConsumer.Logger
-
Log a message at the TRACE level.
- trace(String, Object...) - Method in interface com.couchbase.client.core.cnc.LoggingEventConsumer.Logger
-
Log a message at the TRACE level according to the specified format
and arguments.
- trace(String, Throwable) - Method in interface com.couchbase.client.core.cnc.LoggingEventConsumer.Logger
-
Log an exception (throwable) at the TRACE level with an
accompanying message.
- TracingIdentifiers - Class in com.couchbase.client.core.cnc
-
Holds static tracing identifiers throughout the SDK.
- track() - Method in interface com.couchbase.client.core.endpoint.CircuitBreaker
-
Marks that a circuit breaker should start tracking.
- track() - Method in class com.couchbase.client.core.endpoint.NoopCircuitBreaker
-
- TrafficCaptureHandler - Class in com.couchbase.client.core.io.netty
-
Similar to the netty LoggingHandler, but it dumps the traffic into the event bus for later
consumption instead of logging it right away.
- TrafficCaptureHandler(EndpointContext) - Constructor for class com.couchbase.client.core.io.netty.TrafficCaptureHandler
-
- trailer() - Method in class com.couchbase.client.core.io.netty.chunk.BaseChunkResponseParser
-
- trailer() - Method in interface com.couchbase.client.core.io.netty.chunk.ChunkResponseParser
-
Returns the currently assigned mono for the trailer bits.
- trailer() - Method in class com.couchbase.client.core.msg.analytics.AnalyticsResponse
-
- trailer() - Method in interface com.couchbase.client.core.msg.chunk.ChunkedResponse
-
Returns the trailer for this response, available at the end of the response eventually.
- trailer() - Method in class com.couchbase.client.core.msg.query.QueryResponse
-
- trailer() - Method in class com.couchbase.client.core.msg.search.SearchResponse
-
- trailer() - Method in class com.couchbase.client.core.msg.view.ViewResponse
-
- transition(S) - Method in class com.couchbase.client.core.util.SingleStateful
-
Transition into a new state, notifying consumers.
- trustCertificate(Path) - Method in class com.couchbase.client.core.env.SecurityConfig.Builder
-
Loads a X.509 trust certificate from the given path and uses it.
- trustCertificate(Path) - Static method in class com.couchbase.client.core.env.SecurityConfig
-
Loads a X.509 trust certificate from the given path and uses it.
- trustCertificates(List<X509Certificate>) - Method in class com.couchbase.client.core.env.SecurityConfig.Builder
-
Loads the given list of X.509 certificates into the trust store.
- trustCertificates(List<X509Certificate>) - Static method in class com.couchbase.client.core.env.SecurityConfig
-
Loads the given list of X.509 certificates into the trust store.
- trustCertificates() - Method in class com.couchbase.client.core.env.SecurityConfig
-
The list of trust certificates that should be used, if present.
- trustManagerFactory(TrustManagerFactory) - Method in class com.couchbase.client.core.env.SecurityConfig.Builder
-
Allows to provide a trust manager factory directly for maximum flexibility.
- trustManagerFactory(TrustManagerFactory) - Static method in class com.couchbase.client.core.env.SecurityConfig
-
Allows to provide a trust manager factory directly for maximum flexibility.
- trustManagerFactory() - Method in class com.couchbase.client.core.env.SecurityConfig
-
The currently configured trust manager factory, if present.
- trustStore(KeyStore) - Method in class com.couchbase.client.core.env.SecurityConfig.Builder
-
- trustStore(Path, String, Optional<String>) - Method in class com.couchbase.client.core.env.SecurityConfig.Builder
-
- trustStore(KeyStore) - Static method in class com.couchbase.client.core.env.SecurityConfig
-
- trustStore(Path, String, Optional<String>) - Static method in class com.couchbase.client.core.env.SecurityConfig
-
- tryCompression(byte[], double) - Static method in enum com.couchbase.client.core.io.netty.kv.MemcacheProtocol
-
Try to compress the input, but if it is below the min ratio then it will return null.
- tryDecompression(byte[], byte) - Static method in enum com.couchbase.client.core.io.netty.kv.MemcacheProtocol
-
Try to decompress the input if the datatype has the snappy flag enabled.
- type() - Method in interface com.couchbase.client.core.config.BucketConfig
-
The bucket type.
- type() - Method in class com.couchbase.client.core.config.CouchbaseBucketConfig
-
- type() - Method in class com.couchbase.client.core.config.MemcachedBucketConfig
-
- type() - Method in class com.couchbase.client.core.diagnostics.EndpointDiagnostics
-
The service type for this endpoint.
- type() - Method in class com.couchbase.client.core.diagnostics.EndpointPingReport
-
The service type for this endpoint.
- type() - Method in class com.couchbase.client.core.logging.RedactableArgument
-
The type of this redactable argument.
- type() - Method in class com.couchbase.client.core.msg.kv.SubDocumentField
-
- type() - Method in class com.couchbase.client.core.service.AnalyticsService
-
- type() - Method in class com.couchbase.client.core.service.KeyValueService
-
- type() - Method in class com.couchbase.client.core.service.ManagerService
-
- type() - Method in class com.couchbase.client.core.service.QueryService
-
- type() - Method in class com.couchbase.client.core.service.SearchService
-
- type() - Method in interface com.couchbase.client.core.service.Service
-
Represents the service type for this service.
- type() - Method in class com.couchbase.client.core.service.ViewService
-
- Validators - Class in com.couchbase.client.core.util
-
Common validators used throughout the client.
- value() - Method in enum com.couchbase.client.core.io.netty.kv.ServerFeature
-
Returns the actual byte value for the wire protocol.
- value() - Method in class com.couchbase.client.core.msg.kv.DecrementResponse
-
- value() - Method in class com.couchbase.client.core.msg.kv.IncrementResponse
-
- value() - Method in enum com.couchbase.client.core.msg.kv.ObserveViaCasResponse.ObserveStatus
-
- value() - Method in class com.couchbase.client.core.msg.kv.SubDocumentField
-
- value() - Method in enum com.couchbase.client.core.service.kv.Observe.ObservePersistTo
-
Returns the actual internal persistence representation for the enum.
- value() - Method in enum com.couchbase.client.core.service.kv.Observe.ObserveReplicateTo
-
Returns the actual internal replication representation for the enum.
- ValueInvalidException - Exception in com.couchbase.client.core.error.subdoc
-
Subdocument exception thrown when the provided value cannot be inserted at the given path.
- ValueInvalidException(SubDocumentErrorContext) - Constructor for exception com.couchbase.client.core.error.subdoc.ValueInvalidException
-
- valueOf(String) - Static method in enum com.couchbase.client.core.cnc.Event.Category
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.couchbase.client.core.cnc.Event.Severity
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.couchbase.client.core.cnc.EventBus.PublishResult
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.couchbase.client.core.cnc.events.config.BucketConfigRefreshFailedEvent.Reason
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.couchbase.client.core.cnc.events.config.BucketConfigRefreshFailedEvent.RefresherType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.couchbase.client.core.cnc.events.config.CollectionMapRefreshFailedEvent.Reason
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.couchbase.client.core.cnc.events.config.ConfigIgnoredEvent.Reason
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.couchbase.client.core.cnc.events.core.DnsSrvLookupFailedEvent.Reason
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.couchbase.client.core.cnc.events.core.InitGlobalConfigFailedEvent.Reason
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.couchbase.client.core.cnc.events.io.ChannelClosedProactivelyEvent.Reason
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.couchbase.client.core.cnc.events.node.NodeDisconnectIgnoredEvent.Reason
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.couchbase.client.core.cnc.events.service.ServiceAddIgnoredEvent.Reason
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.couchbase.client.core.cnc.events.service.ServiceRemoveIgnoredEvent.Reason
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.couchbase.client.core.config.BucketCapabilities
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.couchbase.client.core.config.BucketNodeLocator
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.couchbase.client.core.config.BucketType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.couchbase.client.core.config.ClusterCapabilities
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.couchbase.client.core.diagnostics.ClusterState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.couchbase.client.core.diagnostics.PingState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.couchbase.client.core.endpoint.CircuitBreaker.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.couchbase.client.core.endpoint.EndpointState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in class com.couchbase.client.core.env.NetworkResolution
-
Returns a network resolution option with the given name.
- valueOf(String) - Static method in enum com.couchbase.client.core.env.SaslMechanism
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.couchbase.client.core.io.netty.kv.ErrorMap.ErrorAttribute
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.couchbase.client.core.io.netty.kv.ErrorMap.RetryStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.couchbase.client.core.io.netty.kv.MemcacheProtocol.Datatype
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.couchbase.client.core.io.netty.kv.MemcacheProtocol.Magic
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.couchbase.client.core.io.netty.kv.MemcacheProtocol.Opcode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.couchbase.client.core.io.netty.kv.MemcacheProtocol.Status
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.couchbase.client.core.io.netty.kv.MemcacheProtocol
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.couchbase.client.core.io.netty.kv.ServerFeature
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.couchbase.client.core.logging.RedactionLevel
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.couchbase.client.core.msg.kv.CodecFlags.CommonFlags
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.couchbase.client.core.msg.kv.CodecFlags
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.couchbase.client.core.msg.kv.DurabilityLevel
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.couchbase.client.core.msg.kv.ObserveViaCasResponse.ObserveStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(byte) - Static method in enum com.couchbase.client.core.msg.kv.ObserveViaCasResponse.ObserveStatus
-
- valueOf(String) - Static method in enum com.couchbase.client.core.msg.kv.SubdocCommandType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.couchbase.client.core.msg.kv.SubDocumentOpResponseStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.couchbase.client.core.msg.ResponseStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.couchbase.client.core.node.NodeState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.couchbase.client.core.retry.RetryReason
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.couchbase.client.core.service.kv.Observe.ObservePersistTo
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.couchbase.client.core.service.kv.Observe.ObserveReplicateTo
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.couchbase.client.core.service.ServiceScope
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.couchbase.client.core.service.ServiceState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.couchbase.client.core.service.ServiceType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.couchbase.client.core.util.ConnectionString.PortType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.couchbase.client.core.util.ConnectionString.Scheme
-
Returns the enum constant of this type with the specified name.
- valueRecorder(String, Map<String, String>) - Method in interface com.couchbase.client.core.cnc.Meter
-
Creates a new value recorder.
- valueRecorder(String, Map<String, String>) - Method in class com.couchbase.client.core.cnc.metrics.AggregatingMeter
-
- valueRecorder(String, Map<String, String>) - Method in class com.couchbase.client.core.cnc.metrics.NoopMeter
-
- ValueRecorder - Interface in com.couchbase.client.core.cnc
-
Represents a generic value recorder for the metrics interface.
- values() - Static method in enum com.couchbase.client.core.cnc.Event.Category
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.couchbase.client.core.cnc.Event.Severity
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.couchbase.client.core.cnc.EventBus.PublishResult
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.couchbase.client.core.cnc.events.config.BucketConfigRefreshFailedEvent.Reason
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.couchbase.client.core.cnc.events.config.BucketConfigRefreshFailedEvent.RefresherType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.couchbase.client.core.cnc.events.config.CollectionMapRefreshFailedEvent.Reason
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.couchbase.client.core.cnc.events.config.ConfigIgnoredEvent.Reason
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.couchbase.client.core.cnc.events.core.DnsSrvLookupFailedEvent.Reason
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.couchbase.client.core.cnc.events.core.InitGlobalConfigFailedEvent.Reason
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.couchbase.client.core.cnc.events.io.ChannelClosedProactivelyEvent.Reason
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.couchbase.client.core.cnc.events.node.NodeDisconnectIgnoredEvent.Reason
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.couchbase.client.core.cnc.events.service.ServiceAddIgnoredEvent.Reason
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.couchbase.client.core.cnc.events.service.ServiceRemoveIgnoredEvent.Reason
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.couchbase.client.core.config.BucketCapabilities
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.couchbase.client.core.config.BucketNodeLocator
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.couchbase.client.core.config.BucketType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.couchbase.client.core.config.ClusterCapabilities
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.couchbase.client.core.diagnostics.ClusterState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.couchbase.client.core.diagnostics.PingState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.couchbase.client.core.endpoint.CircuitBreaker.State
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.couchbase.client.core.endpoint.EndpointState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.couchbase.client.core.env.SaslMechanism
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.couchbase.client.core.io.netty.kv.ErrorMap.ErrorAttribute
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.couchbase.client.core.io.netty.kv.ErrorMap.RetryStrategy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.couchbase.client.core.io.netty.kv.MemcacheProtocol.Datatype
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.couchbase.client.core.io.netty.kv.MemcacheProtocol.Magic
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.couchbase.client.core.io.netty.kv.MemcacheProtocol.Opcode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.couchbase.client.core.io.netty.kv.MemcacheProtocol.Status
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.couchbase.client.core.io.netty.kv.MemcacheProtocol
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.couchbase.client.core.io.netty.kv.ServerFeature
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.couchbase.client.core.logging.RedactionLevel
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.couchbase.client.core.msg.kv.CodecFlags.CommonFlags
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.couchbase.client.core.msg.kv.CodecFlags
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.couchbase.client.core.msg.kv.DurabilityLevel
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.couchbase.client.core.msg.kv.ObserveViaCasResponse.ObserveStatus
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.couchbase.client.core.msg.kv.SubdocCommandType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class com.couchbase.client.core.msg.kv.SubdocGetResponse
-
- values() - Method in class com.couchbase.client.core.msg.kv.SubdocMutateResponse
-
- values() - Static method in enum com.couchbase.client.core.msg.kv.SubDocumentOpResponseStatus
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.couchbase.client.core.msg.ResponseStatus
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.couchbase.client.core.node.NodeState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.couchbase.client.core.retry.RetryReason
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.couchbase.client.core.service.kv.Observe.ObservePersistTo
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.couchbase.client.core.service.kv.Observe.ObserveReplicateTo
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.couchbase.client.core.service.ServiceScope
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.couchbase.client.core.service.ServiceState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.couchbase.client.core.service.ServiceType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.couchbase.client.core.util.ConnectionString.PortType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.couchbase.client.core.util.ConnectionString.Scheme
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- ValueTooDeepException - Exception in com.couchbase.client.core.error.subdoc
-
Subdocument exception thrown when proposed value would make the document too deep to parse.
- ValueTooDeepException(SubDocumentErrorContext) - Constructor for exception com.couchbase.client.core.error.subdoc.ValueTooDeepException
-
- ValueTooLargeException - Exception in com.couchbase.client.core.error
-
Thrown when the request is too big for some reason.
- ValueTooLargeException(ErrorContext) - Constructor for exception com.couchbase.client.core.error.ValueTooLargeException
-
- vattrEnabled() - Method in class com.couchbase.client.core.io.netty.kv.KeyValueChannelContext
-
- vbucketID() - Method in class com.couchbase.client.core.msg.kv.ObserveViaSeqnoResponse
-
- vbucketUUID() - Method in class com.couchbase.client.core.msg.kv.ObserveViaSeqnoResponse
-
- version() - Method in class com.couchbase.client.core.diagnostics.DiagnosticsResult
-
The version of this report (useful when exporting to JSON).
- version() - Method in class com.couchbase.client.core.diagnostics.PingResult
-
The version of this report (useful when exporting to JSON).
- version() - Method in class com.couchbase.client.core.env.UserAgent
-
- version() - Method in class com.couchbase.client.core.io.netty.kv.ErrorMap
-
- ViewChunkHeader - Class in com.couchbase.client.core.msg.view
-
- ViewChunkHeader(long, Optional<byte[]>) - Constructor for class com.couchbase.client.core.msg.view.ViewChunkHeader
-
- ViewChunkResponseParser - Class in com.couchbase.client.core.io.netty.view
-
Parses the individual response http chunks for a view request.
- ViewChunkResponseParser() - Constructor for class com.couchbase.client.core.io.netty.view.ViewChunkResponseParser
-
- ViewChunkRow - Class in com.couchbase.client.core.msg.view
-
- ViewChunkRow(byte[]) - Constructor for class com.couchbase.client.core.msg.view.ViewChunkRow
-
- ViewChunkTrailer - Class in com.couchbase.client.core.msg.view
-
- ViewChunkTrailer(Optional<ViewError>) - Constructor for class com.couchbase.client.core.msg.view.ViewChunkTrailer
-
- viewCircuitBreakerConfig(CircuitBreakerConfig.Builder) - Method in class com.couchbase.client.core.env.IoConfig.Builder
-
- viewCircuitBreakerConfig() - Method in class com.couchbase.client.core.env.IoConfig.Builder
-
- viewCircuitBreakerConfig(CircuitBreakerConfig.Builder) - Static method in class com.couchbase.client.core.env.IoConfig
-
- viewCircuitBreakerConfig() - Method in class com.couchbase.client.core.env.IoConfig
-
- ViewEndpoint - Class in com.couchbase.client.core.endpoint
-
- ViewEndpoint(ServiceContext, String, int) - Constructor for class com.couchbase.client.core.endpoint.ViewEndpoint
-
- ViewEndpoint.ViewPipelineInitializer - Class in com.couchbase.client.core.endpoint
-
- ViewError - Class in com.couchbase.client.core.msg.view
-
- ViewError(String, String) - Constructor for class com.couchbase.client.core.msg.view.ViewError
-
- ViewErrorContext - Class in com.couchbase.client.core.error.context
-
- ViewErrorContext(ResponseStatus, RequestContext, ViewError, int) - Constructor for class com.couchbase.client.core.error.context.ViewErrorContext
-
- viewEventLoopGroup(EventLoopGroup) - Method in class com.couchbase.client.core.env.IoEnvironment.Builder
-
Allows to specify a custom event loop group (I/O event loop thread pool) for the view service.
- viewEventLoopGroup(EventLoopGroup) - Static method in class com.couchbase.client.core.env.IoEnvironment
-
Allows to specify a custom event loop group (I/O event loop thread pool) for the view service.
- viewEventLoopGroup() - Method in class com.couchbase.client.core.env.IoEnvironment
-
Returns the EventLoopGroup
to be used for view traffic.
- ViewHandlerSwitcher - Class in com.couchbase.client.core.io.netty.view
-
- ViewHandlerSwitcher(BaseEndpoint, EndpointContext) - Constructor for class com.couchbase.client.core.io.netty.view.ViewHandlerSwitcher
-
- ViewLocator - Class in com.couchbase.client.core.node
-
The
ViewLocator
extends the round-robin locator with some custom checks.
- ViewLocator() - Constructor for class com.couchbase.client.core.node.ViewLocator
-
- ViewNotFoundException - Exception in com.couchbase.client.core.error
-
- ViewNotFoundException(ErrorContext) - Constructor for exception com.couchbase.client.core.error.ViewNotFoundException
-
- ViewPingRequest - Class in com.couchbase.client.core.msg.view
-
- ViewPingRequest(Duration, CoreContext, RetryStrategy, String, NodeIdentifier) - Constructor for class com.couchbase.client.core.msg.view.ViewPingRequest
-
- ViewPingResponse - Class in com.couchbase.client.core.msg.view
-
- ViewRequest - Class in com.couchbase.client.core.msg.view
-
- ViewRequest(Duration, CoreContext, RetryStrategy, Authenticator, String, String, String, String, Optional<byte[]>, boolean, RequestSpan) - Constructor for class com.couchbase.client.core.msg.view.ViewRequest
-
- ViewResponse - Class in com.couchbase.client.core.msg.view
-
- ViewService - Class in com.couchbase.client.core.service
-
- ViewService(ViewServiceConfig, CoreContext, String, int) - Constructor for class com.couchbase.client.core.service.ViewService
-
- ViewServiceConfig - Class in com.couchbase.client.core.service
-
- ViewServiceConfig.Builder - Class in com.couchbase.client.core.service
-
- ViewServiceException - Exception in com.couchbase.client.core.error
-
There was a problem fulfilling the view request.
- ViewServiceException(String) - Constructor for exception com.couchbase.client.core.error.ViewServiceException
-
- ViewServiceException(String, Throwable) - Constructor for exception com.couchbase.client.core.error.ViewServiceException
-
- viewThreshold(Duration) - Method in class com.couchbase.client.core.cnc.tracing.ThresholdRequestTracer.Builder
-
Allows to customize the viewThreshold.
- viewThreshold(Duration) - Method in class com.couchbase.client.core.env.ThresholdRequestTracerConfig.Builder
-
Allows to customize the viewThreshold.
- viewThreshold(Duration) - Static method in class com.couchbase.client.core.env.ThresholdRequestTracerConfig
-
Allows to customize the viewThreshold.
- viewThreshold() - Method in class com.couchbase.client.core.env.ThresholdRequestTracerConfig
-
- viewTimeout(Duration) - Method in class com.couchbase.client.core.env.TimeoutConfig.Builder
-
Sets the timeout to use for view operations.
- viewTimeout(Duration) - Static method in class com.couchbase.client.core.env.TimeoutConfig
-
- viewTimeout() - Method in class com.couchbase.client.core.env.TimeoutConfig
-
- volumeThreshold(int) - Method in class com.couchbase.client.core.endpoint.CircuitBreakerConfig.Builder
-
The volume threshold defines how many operations need to be in the window at least so that
the threshold percentage can be meaningfully calculated.
- volumeThreshold(int) - Static method in class com.couchbase.client.core.endpoint.CircuitBreakerConfig
-
- volumeThreshold() - Method in class com.couchbase.client.core.endpoint.CircuitBreakerConfig
-
Returns the volume threshold at which point the circuit will decide if it opens.