Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
A
- AbstractStateMachine<S extends Enum> - Class in com.couchbase.client.dcp.core.state
-
Abstract
Stateful
implementation which acts like a simple state machine. - AbstractStateMachine(S) - Constructor for class com.couchbase.client.dcp.core.state.AbstractStateMachine
-
Creates a new state machine.
- accept(HostAndPort, String) - Method in class com.couchbase.client.dcp.conductor.BucketConfigArbiter
- accept(HostAndPort, String) - Method in interface com.couchbase.client.dcp.conductor.BucketConfigSink
- accept(HostAndPort, String, ConfigRevision) - Method in class com.couchbase.client.dcp.conductor.BucketConfigArbiter
- accept(HostAndPort, String, ConfigRevision) - Method in interface com.couchbase.client.dcp.conductor.BucketConfigSink
- ack(int) - Method in interface com.couchbase.client.dcp.transport.netty.ChannelFlowController
- ack(int) - Method in class com.couchbase.client.dcp.transport.netty.ChannelFlowControllerImpl
- ack(ByteBuf) - Method in interface com.couchbase.client.dcp.transport.netty.ChannelFlowController
-
Acknowledge bytes read if DcpControl.Names.CONNECTION_BUFFER_SIZE is set on bootstrap.
- ack(ByteBuf) - Method in class com.couchbase.client.dcp.transport.netty.ChannelFlowControllerImpl
- ACK - Enum constant in enum class com.couchbase.client.dcp.message.SnapshotMarkerFlag
-
Specifies that this snapshot marker should return a response once the entire snapshot is received.
- ackBytes(ByteBuf, int) - Static method in enum class com.couchbase.client.dcp.message.DcpBufferAckRequest
- acknowledge() - Method in class com.couchbase.client.dcp.highlevel.internal.FlowControlReceipt
- ActionCounter - Class in com.couchbase.client.dcp.metrics
-
Tracks the results of an action that can succeed or fail.
- ActionCounter.Builder - Class in com.couchbase.client.dcp.metrics
- ActionTimer - Class in com.couchbase.client.dcp.metrics
-
Tracks the results and of an action that can succeed or fail, along with elapsed time.
- ActionTimer.Builder - Class in com.couchbase.client.dcp.metrics
- active() - Method in class com.couchbase.client.dcp.core.config.PartitionInfo
- active(int) - Method in class com.couchbase.client.dcp.core.config.PartitionMap
-
Returns info about the node hosting the active instance of the given partition (vBucket), or empty if the active is not currently available or there is no such partition.
- active(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpSetVbucketStateMessage
- ACTIVE - Enum constant in enum class com.couchbase.client.dcp.message.DcpSetVbucketStateMessage.State
- ACTIVE - Enum constant in enum class com.couchbase.client.dcp.message.VbucketState
-
Actively servicing a partition.
- ACTIVE_EXTERNAL_USERS_OPCODE - Static variable in enum class com.couchbase.client.dcp.message.MessageUtil
- ACTIVE_VB_ONLY - Enum constant in enum class com.couchbase.client.dcp.message.StreamFlag
-
Indicate the server to add stream only if the VBucket is active.
- AdaptiveDelay - Class in com.couchbase.client.dcp.util
-
A stateful wrapper around a
Delay
. - AdaptiveDelay(Delay, Duration) - Constructor for class com.couchbase.client.dcp.util.AdaptiveDelay
- address() - Method in class com.couchbase.client.dcp.conductor.DcpChannel
- address() - Method in class com.couchbase.client.dcp.core.env.SeedNode
-
The ip address or hostname of this seed node.
- addToFailoverLog(long, long) - Method in class com.couchbase.client.dcp.state.PartitionState
-
Deprecated.
- allPartitions(int) - Static method in class com.couchbase.client.dcp.util.PartitionSet
- ALT_REQUEST - Enum constant in enum class com.couchbase.client.dcp.message.HelloFeature
- ANALYTICS - Enum constant in enum class com.couchbase.client.dcp.core.service.ServiceType
-
Analytics operations.
- ANY - Enum constant in enum class com.couchbase.client.dcp.message.VbucketState
-
Any live state (except DEAD).
- append(String, String, String...) - Method in class com.couchbase.client.dcp.util.UserAgentBuilder
- appendJava() - Method in class com.couchbase.client.dcp.util.UserAgentBuilder
- appendOs() - Method in class com.couchbase.client.dcp.util.UserAgentBuilder
- apply(CollectionsManifest) - Method in class com.couchbase.client.dcp.highlevel.CollectionCreated
- apply(CollectionsManifest) - Method in class com.couchbase.client.dcp.highlevel.CollectionDropped
- apply(CollectionsManifest) - Method in class com.couchbase.client.dcp.highlevel.CollectionFlushed
- apply(CollectionsManifest) - Method in class com.couchbase.client.dcp.highlevel.ScopeCreated
- apply(CollectionsManifest) - Method in class com.couchbase.client.dcp.highlevel.ScopeDropped
- apply(CollectionsManifest) - Method in interface com.couchbase.client.dcp.message.DcpSystemEvent.CollectionsManifestEvent
- applyTlsProperties(SslContextBuilder) - Method in interface com.couchbase.client.dcp.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.dcp.CertificateAuthenticator
- AsyncEventDispatcher - Class in com.couchbase.client.dcp.highlevel.internal
-
Dispatches events in a separate dedicated thread.
- AsyncEventDispatcher(FlowControlMode, DatabaseChangeListener) - Constructor for class com.couchbase.client.dcp.highlevel.internal.AsyncEventDispatcher
- AtomicBooleanArray - Class in com.couchbase.client.dcp.util
-
A
boolean
array in which elements may be updated atomically. - AtomicBooleanArray(int) - Constructor for class com.couchbase.client.dcp.util.AtomicBooleanArray
-
Creates a new AtomicBooleanArray of the given length, with all elements initially false.
- AUTH_CONTINUE - Static variable in class com.couchbase.client.dcp.message.ResponseStatus
- AUTH_ERROR - Static variable in class com.couchbase.client.dcp.message.ResponseStatus
- AUTHENTICATE_OPCODE - Static variable in enum class com.couchbase.client.dcp.message.MessageUtil
- AuthenticationException - Exception in com.couchbase.client.dcp.core.endpoint.kv
- AuthenticationException() - Constructor for exception com.couchbase.client.dcp.core.endpoint.kv.AuthenticationException
- AuthenticationException(String) - Constructor for exception com.couchbase.client.dcp.core.endpoint.kv.AuthenticationException
- AuthenticationException(String, Throwable) - Constructor for exception com.couchbase.client.dcp.core.endpoint.kv.AuthenticationException
- AuthenticationException(Throwable) - Constructor for exception com.couchbase.client.dcp.core.endpoint.kv.AuthenticationException
- authenticator() - Method in class com.couchbase.client.dcp.Client.Environment
-
The authenticator for the connection
- authenticator(Authenticator) - Method in class com.couchbase.client.dcp.Client.Builder
- Authenticator - Interface in com.couchbase.client.dcp
- AuthHandler - Class in com.couchbase.client.dcp.transport.netty
-
Performs SASL authentication against the socket and once complete removes itself.
- AuthHandler(Credentials) - Constructor for class com.couchbase.client.dcp.transport.netty.AuthHandler
- authKeyValueConnection(ChannelPipeline) - Method in interface com.couchbase.client.dcp.Authenticator
-
Allows the authenticator to add KV handlers during connection bootstrap to perform authentication.
- authKeyValueConnection(ChannelPipeline) - Method in class com.couchbase.client.dcp.PasswordAuthenticator
- AUTO - Static variable in class com.couchbase.client.dcp.core.env.NetworkResolution
-
Based on heuristics discovers if internal or external resolution will be used.
- autoDetect(Set<SeedNode>) - Static method in interface com.couchbase.client.dcp.core.config.NetworkSelector
- AUTOMATIC - Enum constant in enum class com.couchbase.client.dcp.highlevel.FlowControlMode
-
In this mode,
Mutation
andDeletion
events are automatically acknowledged prior to dispatch to theDatabaseChangeListener
. - AutoNetworkSelector(Set<SeedNode>) - Constructor for class com.couchbase.client.dcp.core.config.NetworkSelector.AutoNetworkSelector
- availableReplicas() - Method in class com.couchbase.client.dcp.core.config.PartitionInfo
- availableReplicas(int) - Method in class com.couchbase.client.dcp.core.config.PartitionMap
-
Returns info about the nodes hosting replica instances of the given partition (vBucket), or empty if no replicas are currently available or there is no such partition.
- awaitTermination(Duration) - Method in class com.couchbase.client.dcp.highlevel.internal.AsyncEventDispatcher
-
Blocks until the dispatch thread terminates or the timeout expires.
- awaitTermination(Duration) - Method in interface com.couchbase.client.dcp.highlevel.internal.EventDispatcher
- awaitTermination(Duration) - Method in class com.couchbase.client.dcp.highlevel.internal.ImmediateEventDispatcher
B
- BACKFILL_FAILED - Static variable in class com.couchbase.client.dcp.message.StreamEndReason
- BACKUP - Enum constant in enum class com.couchbase.client.dcp.core.service.ServiceType
-
The Backup service
- BadResponseStatusException(ResponseStatus) - Constructor for exception com.couchbase.client.dcp.buffer.DcpOps.BadResponseStatusException
- BadResponseStatusException(ResponseStatus, String) - Constructor for exception com.couchbase.client.dcp.buffer.DcpOps.BadResponseStatusException
- BEGINNING - Enum constant in enum class com.couchbase.client.dcp.StreamFrom
-
Start at the very beginning - will stream all docs in the bucket.
- bind(ChannelHandlerContext, SocketAddress, ChannelPromise) - Method in class com.couchbase.client.dcp.transport.netty.AuthHandler
- bitmask() - Method in enum class com.couchbase.client.dcp.message.DataType
- BlockingQueueConsumerOps<T> - Interface in com.couchbase.client.dcp.highlevel.internal
-
Subset of the BlockingQueue interface that should be exposed to consumers.
- BODY_LENGTH_OFFSET - Static variable in enum class com.couchbase.client.dcp.message.MessageUtil
- BootstrapException - Exception in com.couchbase.client.dcp.error
-
This exception indicates an error during bootstrap.
- BootstrapException() - Constructor for exception com.couchbase.client.dcp.error.BootstrapException
- BootstrapException(String) - Constructor for exception com.couchbase.client.dcp.error.BootstrapException
- BootstrapException(String, Throwable) - Constructor for exception com.couchbase.client.dcp.error.BootstrapException
- BootstrapException(Throwable) - Constructor for exception com.couchbase.client.dcp.error.BootstrapException
- bootstrapTimeout() - Method in class com.couchbase.client.dcp.Client.Environment
-
Time in milliseconds to wait for first configuration during bootstrap.
- bootstrapTimeout(Duration) - Method in class com.couchbase.client.dcp.Client.Builder
-
Time to wait for first configuration during bootstrap.
- bucket() - Method in class com.couchbase.client.dcp.Client.Environment
-
Name of the bucket used.
- bucket(String) - Method in class com.couchbase.client.dcp.Client.Builder
-
The name of the bucket to use.
- BUCKET - Enum constant in enum class com.couchbase.client.dcp.core.service.ServiceScope
-
The service can only handle one bucket at a time.
- BucketCapability - Enum Class in com.couchbase.client.dcp.core.config
- BucketConfigArbiter - Class in com.couchbase.client.dcp.conductor
-
Manages the bucket config stream.
- BucketConfigArbiter(Client.Environment) - Constructor for class com.couchbase.client.dcp.conductor.BucketConfigArbiter
- BucketConfigHandler - Class in com.couchbase.client.dcp.transport.netty
- BucketConfigSink - Interface in com.couchbase.client.dcp.conductor
- BucketConfigSource - Interface in com.couchbase.client.dcp.conductor
- BucketSelectRequest - Enum Class in com.couchbase.client.dcp.message
- buffer() - Method in class com.couchbase.client.dcp.transport.netty.DcpResponse
- bufferAckEnabled() - Method in class com.couchbase.client.dcp.config.DcpControl
-
Shorthand getter to check if buffer acknowledgements are enabled.
- bufferAckWatermark() - Method in class com.couchbase.client.dcp.Client.Environment
-
The watermark in percent for buffer acknowledgements.
- bufferAckWatermark(int) - Method in class com.couchbase.client.dcp.Client.Builder
-
The buffer acknowledge watermark in percent.
- build() - Method in class com.couchbase.client.dcp.Client.Builder
-
Create the client instance ready to use.
- build() - Method in class com.couchbase.client.dcp.metrics.ActionCounter.Builder
- build() - Method in class com.couchbase.client.dcp.metrics.ActionTimer.Builder
- build() - Method in class com.couchbase.client.dcp.metrics.EventCounter.Builder
- build() - Method in class com.couchbase.client.dcp.SecurityConfig.Builder
-
Builds the
SecurityConfig
out of this builder. - build() - Method in class com.couchbase.client.dcp.util.UserAgentBuilder
- builder() - Static method in class com.couchbase.client.dcp.Client
- builder() - Static method in class com.couchbase.client.dcp.SecurityConfig
-
Creates a builder to customize the
SecurityConfig
configuration. - builder(MeterRegistry, String) - Static method in class com.couchbase.client.dcp.metrics.ActionCounter
- builder(MeterRegistry, String) - Static method in class com.couchbase.client.dcp.metrics.ActionTimer
- builder(MeterRegistry, String) - Static method in class com.couchbase.client.dcp.metrics.EventCounter
- Builder() - Constructor for class com.couchbase.client.dcp.Client.Builder
- Builder() - Constructor for class com.couchbase.client.dcp.SecurityConfig.Builder
- BUSY - Static variable in class com.couchbase.client.dcp.message.ResponseStatus
- bySeqno(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpDeletionMessage
- bySeqno(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpExpirationMessage
- bySeqno(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpMutationMessage
C
- calculate() - Method in class com.couchbase.client.dcp.util.AdaptiveDelay
-
Returns the next delay in the backoff sequence.
- calculate(long) - Method in class com.couchbase.client.dcp.core.time.Delay
-
Calculate a specific delay based on the attempt passed in.
- calculate(long) - Method in class com.couchbase.client.dcp.core.time.ExponentialDelay
- calculate(long) - Method in class com.couchbase.client.dcp.core.time.FixedDelay
- calculate(long) - Method in class com.couchbase.client.dcp.core.time.LinearDelay
- calculateAlternatePower(long) - Method in class com.couchbase.client.dcp.core.time.ExponentialDelay
- calculatePowerOfTwo(long) - Method in class com.couchbase.client.dcp.core.time.ExponentialDelay
- call(Callable<T>) - Method in class com.couchbase.client.dcp.metrics.ActionCounter
- capabilities() - Method in class com.couchbase.client.dcp.core.config.ClusterConfig
- capabilities() - Method in class com.couchbase.client.dcp.core.config.CouchbaseBucketConfig
- cas(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpDeletionMessage
- cas(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpExpirationMessage
- cas(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpMutationMessage
- CAS_OFFSET - Static variable in enum class com.couchbase.client.dcp.message.MessageUtil
- CbCollections - Class in com.couchbase.client.dcp.core.utils
- CBHELLO - Enum constant in enum class com.couchbase.client.dcp.core.config.BucketCapability
- CbStrings - Class in com.couchbase.client.dcp.core.utils
- CCCP - Enum constant in enum class com.couchbase.client.dcp.core.config.BucketCapability
- CertificateAuthenticator - Class in com.couchbase.client.dcp
-
Performs authentication through a client certificate instead of supplying username and password.
- challenge(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.SaslAuthResponse
-
Returns the server challenge.
- challengeResponse(byte[], ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.SaslAuthRequest
-
Sets the challenge response payload.
- challengeResponse(byte[], ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.SaslStepRequest
-
Sets the challenge response payload.
- channelActive(ChannelHandlerContext) - Method in class com.couchbase.client.dcp.buffer.PersistencePollingHandler
- channelActive(ChannelHandlerContext) - Method in class com.couchbase.client.dcp.transport.netty.AuthHandler
-
Once the channel is active, start the SASL auth negotiation.
- channelActive(ChannelHandlerContext) - Method in class com.couchbase.client.dcp.transport.netty.DcpConnectHandler
-
Assigns a name to the connection and starts the first connection step.
- channelActive(ChannelHandlerContext) - Method in class com.couchbase.client.dcp.transport.netty.DcpControlHandler
-
Once the channel becomes active, start negotiating the dcp control params.
- channelActive(ChannelHandlerContext) - Method in class com.couchbase.client.dcp.transport.netty.DcpMessageHandler
- ChannelFlowController - Interface in com.couchbase.client.dcp.transport.netty
- ChannelFlowControllerImpl - Class in com.couchbase.client.dcp.transport.netty
- ChannelFlowControllerImpl(Channel, Client.Environment) - Constructor for class com.couchbase.client.dcp.transport.netty.ChannelFlowControllerImpl
- channelForEventLoopGroup(EventLoopGroup) - Static method in enum class com.couchbase.client.dcp.transport.netty.ChannelUtils
-
Helper method to detect the right channel for the given event loop group.
- channelIdle(ChannelHandlerContext, IdleStateEvent) - Method in class com.couchbase.client.dcp.transport.netty.ClientNoopHandler
- channelInactive(ChannelHandlerContext) - Method in class com.couchbase.client.dcp.buffer.PersistencePollingHandler
- channelInactive(ChannelHandlerContext) - Method in class com.couchbase.client.dcp.transport.netty.AuthHandler
- channelInactive(ChannelHandlerContext) - Method in class com.couchbase.client.dcp.transport.netty.DcpMessageHandler
-
Fails all the promises in the
DcpMessageHandler.outstandingRequests
queue when the channel becomes inactive. - channelMetrics(HostAndPort) - Method in class com.couchbase.client.dcp.metrics.DcpClientMetrics
- channelRead(ChannelHandlerContext, Object) - Method in class com.couchbase.client.dcp.transport.netty.DcpMessageHandler
-
Reads server responses and uses them to fulfill promises returned by
DcpMessageHandler.sendRequest(com.couchbase.client.core.deps.io.netty.buffer.ByteBuf)
. - channelRead0(ChannelHandlerContext, ByteBuf) - Method in class com.couchbase.client.dcp.transport.netty.AuthHandler
-
Every time we receive a message as part of the negotiation process, handle it according to the req/res process.
- channelRead0(ChannelHandlerContext, ByteBuf) - Method in class com.couchbase.client.dcp.transport.netty.BucketConfigHandler
- channelRead0(ChannelHandlerContext, ByteBuf) - Method in class com.couchbase.client.dcp.transport.netty.DcpConnectHandler
-
Once we get a response from the connect request, check if it is successful and complete/fail the connect phase accordingly.
- channelRead0(ChannelHandlerContext, ByteBuf) - Method in class com.couchbase.client.dcp.transport.netty.DcpControlHandler
-
Since only one feature per req/res can be negotiated, repeat the process once a response comes back until the iterator is complete or a non-success response status is received.
- ChannelUtils - Enum Class in com.couchbase.client.dcp.transport.netty
-
Various netty channel related utility methods.
- CHECKPOINT - Enum constant in enum class com.couchbase.client.dcp.message.SnapshotMarkerFlag
-
An internally used flag for intra-cluster replication to help to keep in-memory datastructures look similar.
- clear(int) - Method in class com.couchbase.client.dcp.buffer.StreamEventBuffer
-
Discard all buffered events in the given vbucket.
- Client - Class in com.couchbase.client.dcp
-
This
Client
provides the main API to configure and use the DCP client. - CLIENT_COLLECTIONS_MANIFEST_AHEAD - Static variable in class com.couchbase.client.dcp.message.ResponseStatus
- Client.Builder - Class in com.couchbase.client.dcp
-
Builder object to customize the
Client
creation. - Client.Environment - Class in com.couchbase.client.dcp
-
The
Client.Environment
is responsible to carry various configuration and state information throughout the lifecycle. - ClientNoopHandler - Class in com.couchbase.client.dcp.transport.netty
-
Issues ordinary NOOP requests to the server when the DCP channel is idle.
- ClientNoopHandler(long, TimeUnit) - Constructor for class com.couchbase.client.dcp.transport.netty.ClientNoopHandler
- clientVersion() - Static method in class com.couchbase.client.dcp.ClientVersion
- ClientVersion - Class in com.couchbase.client.dcp
- ClientVersion() - Constructor for class com.couchbase.client.dcp.ClientVersion
- clock(Clock) - Method in class com.couchbase.client.dcp.metrics.ActionTimer.Builder
- close() - Method in class com.couchbase.client.dcp.Client
-
Disconnects the client.
- close(ChannelHandlerContext, ChannelPromise) - Method in class com.couchbase.client.dcp.transport.netty.AuthHandler
- CLOSED - Static variable in class com.couchbase.client.dcp.message.StreamEndReason
- closeStream(int) - Method in class com.couchbase.client.dcp.conductor.DcpChannel
- CLUSTER - Enum constant in enum class com.couchbase.client.dcp.core.service.ServiceScope
-
The service is able to handle all buckets at the same time.
- clusterAt() - Method in class com.couchbase.client.dcp.Client.Environment
-
Returns the node addresses to use for bootstrapping.
- clusterCapabilities() - Method in class com.couchbase.client.dcp.core.config.CouchbaseBucketConfig
- ClusterCapability - Enum Class in com.couchbase.client.dcp.core.config
- ClusterConfig - Class in com.couchbase.client.dcp.core.config
- ClusterConfig(ConfigRevision, List<NodeInfo>, Set<ClusterCapability>, NetworkResolution) - Constructor for class com.couchbase.client.dcp.core.config.ClusterConfig
- ClusterConfigParser - Class in com.couchbase.client.dcp.core.config
- clusterManagerPort() - Method in class com.couchbase.client.dcp.core.env.SeedNode
-
If present, the cluster manager port.
- CLUSTERMAP_CHANGE_NOTIFICATION - Enum constant in enum class com.couchbase.client.dcp.message.HelloFeature
- CLUSTERMAP_CHANGE_NOTIFICATION_OPCODE - Static variable in enum class com.couchbase.client.dcp.message.MessageUtil
- code() - Method in enum class com.couchbase.client.dcp.message.DcpSystemEvent.Type
- code() - Method in enum class com.couchbase.client.dcp.message.HelloFeature
- code() - Method in class com.couchbase.client.dcp.message.ResponseStatus
- COLLECTION_CREATED - Enum constant in enum class com.couchbase.client.dcp.message.DcpSystemEvent.Type
- COLLECTION_DROPPED - Enum constant in enum class com.couchbase.client.dcp.message.DcpSystemEvent.Type
- COLLECTION_FLUSHED - Enum constant in enum class com.couchbase.client.dcp.message.DcpSystemEvent.Type
- CollectionCreated - Class in com.couchbase.client.dcp.highlevel
- CollectionCreated(int, long, int, ByteBuf) - Constructor for class com.couchbase.client.dcp.highlevel.CollectionCreated
- CollectionDropped - Class in com.couchbase.client.dcp.highlevel
- CollectionDropped(int, long, int, ByteBuf) - Constructor for class com.couchbase.client.dcp.highlevel.CollectionDropped
- CollectionFlushed - Class in com.couchbase.client.dcp.highlevel
- CollectionFlushed(int, long, int, ByteBuf) - Constructor for class com.couchbase.client.dcp.highlevel.CollectionFlushed
- collectionId() - Method in class com.couchbase.client.dcp.highlevel.internal.CollectionIdAndKey
- CollectionIdAndKey - Class in com.couchbase.client.dcp.highlevel.internal
- CollectionIdAndKey(long, String) - Constructor for class com.couchbase.client.dcp.highlevel.internal.CollectionIdAndKey
- collectionIds() - Method in class com.couchbase.client.dcp.Client.Environment
-
Collection IDs to filter on, or empty for all collections.
- collectionIds(long...) - Method in class com.couchbase.client.dcp.Client.Builder
-
Configures the client to stream only from the collections identified by the given IDs.
- collectionIds(Collection<Long>) - Method in class com.couchbase.client.dcp.Client.Builder
-
Configures the client to stream only from the collections identified by the given IDs.
- CollectionInfo(CollectionsManifest.ScopeInfo, long, String, Long) - Constructor for class com.couchbase.client.dcp.highlevel.internal.CollectionsManifest.CollectionInfo
- collectionNames() - Method in class com.couchbase.client.dcp.Client.Environment
-
Collection names to filter on, or empty for all collections.
- collectionNames(String...) - Method in class com.couchbase.client.dcp.Client.Builder
- collectionNames(Collection<String>) - Method in class com.couchbase.client.dcp.Client.Builder
- COLLECTIONS - Enum constant in enum class com.couchbase.client.dcp.core.config.BucketCapability
- COLLECTIONS - Enum constant in enum class com.couchbase.client.dcp.message.HelloFeature
- COLLECTIONS - Static variable in interface com.couchbase.client.dcp.highlevel.internal.KeyExtractor
- COLLECTIONS_MANIFEST_NOT_APPLIED - Static variable in class com.couchbase.client.dcp.message.ResponseStatus
- collectionsAware() - Method in class com.couchbase.client.dcp.Client.Environment
-
Whether the client should operate in collections-aware mode
- collectionsAware(boolean) - Method in class com.couchbase.client.dcp.Client.Builder
-
Controls whether the client operates in collections-aware mode (defaults to false).
- CollectionsManifest - Class in com.couchbase.client.dcp.highlevel.internal
-
A collections manifest optimized for lookups by collection ID, and for evolution via DCP system events.
- CollectionsManifest.CollectionInfo - Class in com.couchbase.client.dcp.highlevel.internal
- CollectionsManifest.ScopeInfo - Class in com.couchbase.client.dcp.highlevel.internal
- com.couchbase.client.dcp - package com.couchbase.client.dcp
- com.couchbase.client.dcp.buffer - package com.couchbase.client.dcp.buffer
- com.couchbase.client.dcp.conductor - package com.couchbase.client.dcp.conductor
- com.couchbase.client.dcp.config - package com.couchbase.client.dcp.config
- com.couchbase.client.dcp.core - package com.couchbase.client.dcp.core
-
These are the bits of core-io 1.x that the DCP client depends on.
- com.couchbase.client.dcp.core.config - package com.couchbase.client.dcp.core.config
- com.couchbase.client.dcp.core.endpoint - package com.couchbase.client.dcp.core.endpoint
- com.couchbase.client.dcp.core.endpoint.kv - package com.couchbase.client.dcp.core.endpoint.kv
- com.couchbase.client.dcp.core.env - package com.couchbase.client.dcp.core.env
- com.couchbase.client.dcp.core.env.resources - package com.couchbase.client.dcp.core.env.resources
- com.couchbase.client.dcp.core.event - package com.couchbase.client.dcp.core.event
- com.couchbase.client.dcp.core.lang - package com.couchbase.client.dcp.core.lang
- com.couchbase.client.dcp.core.logging - package com.couchbase.client.dcp.core.logging
- com.couchbase.client.dcp.core.service - package com.couchbase.client.dcp.core.service
- com.couchbase.client.dcp.core.state - package com.couchbase.client.dcp.core.state
- com.couchbase.client.dcp.core.time - package com.couchbase.client.dcp.core.time
- com.couchbase.client.dcp.core.utils - package com.couchbase.client.dcp.core.utils
- com.couchbase.client.dcp.error - package com.couchbase.client.dcp.error
- com.couchbase.client.dcp.events - package com.couchbase.client.dcp.events
- com.couchbase.client.dcp.highlevel - package com.couchbase.client.dcp.highlevel
- com.couchbase.client.dcp.highlevel.internal - package com.couchbase.client.dcp.highlevel.internal
- com.couchbase.client.dcp.message - package com.couchbase.client.dcp.message
- com.couchbase.client.dcp.metrics - package com.couchbase.client.dcp.metrics
- com.couchbase.client.dcp.state - package com.couchbase.client.dcp.state
- com.couchbase.client.dcp.state.json - package com.couchbase.client.dcp.state.json
- com.couchbase.client.dcp.transport.netty - package com.couchbase.client.dcp.transport.netty
- com.couchbase.client.dcp.util - package com.couchbase.client.dcp.util
- compareLong(long, long) - Static method in class com.couchbase.client.dcp.util.MathUtils
-
Deprecated.In favor of
Long.compare(long, long)
- compareTo(ConfigRevision) - Method in class com.couchbase.client.dcp.core.config.ConfigRevision
- compareTo(Version) - Method in class com.couchbase.client.dcp.util.Version
- compareUnsignedLong(long, long) - Static method in class com.couchbase.client.dcp.util.MathUtils
-
Deprecated.In favor of
Long.compareUnsigned(long, long)
- compression(CompressionMode) - Method in class com.couchbase.client.dcp.Client.Builder
-
Sets the compression mode for message values sent by Couchbase Server.
- compression(CompressionMode) - Method in class com.couchbase.client.dcp.config.DcpControl
-
Set the compression mode to use.
- compression(Version) - Method in class com.couchbase.client.dcp.config.DcpControl
-
Returns the requested compression mode, or the fallback mode if the server does not support the requested mode.
- CompressionMode - Enum Class in com.couchbase.client.dcp.config
- Conductor - Class in com.couchbase.client.dcp.conductor
- Conductor(Client.Environment, DcpClientMetrics) - Constructor for class com.couchbase.client.dcp.conductor.Conductor
- ConfigException - Exception in com.couchbase.client.dcp.core.config
- ConfigException() - Constructor for exception com.couchbase.client.dcp.core.config.ConfigException
- ConfigException(String) - Constructor for exception com.couchbase.client.dcp.core.config.ConfigException
- ConfigException(String, Throwable) - Constructor for exception com.couchbase.client.dcp.core.config.ConfigException
- ConfigException(Throwable) - Constructor for exception com.couchbase.client.dcp.core.config.ConfigException
- configRefreshInterval() - Method in class com.couchbase.client.dcp.Client.Environment
-
Polling interval when server does not support clustermap change notifications.
- configRefreshInterval(Duration) - Method in class com.couchbase.client.dcp.Client.Builder
-
When connecting to versions of Couchbase Server older than 5.5, the DCP client polls the server for cluster topology config changes at the specified interval.
- ConfigRevision - Class in com.couchbase.client.dcp.core.config
- ConfigRevision(long, long) - Constructor for class com.couchbase.client.dcp.core.config.ConfigRevision
- configs() - Method in class com.couchbase.client.dcp.conductor.BucketConfigArbiter
- configs() - Method in interface com.couchbase.client.dcp.conductor.BucketConfigSource
- configure() - Static method in class com.couchbase.client.dcp.Client
-
Deprecated.in favor of
Client.builder()
- connect() - Method in class com.couchbase.client.dcp.Client
-
Initializes the underlying connections (not the streams) and sets up everything as needed.
- connect() - Method in class com.couchbase.client.dcp.conductor.Conductor
- connect() - Method in class com.couchbase.client.dcp.conductor.DcpChannel
- connect(ChannelHandlerContext, SocketAddress, SocketAddress, ChannelPromise) - Method in class com.couchbase.client.dcp.transport.netty.AuthHandler
-
Intercept the connect phase and store the original promise.
- connect(ChannelHandlerContext, SocketAddress, SocketAddress, ChannelPromise) - Method in class com.couchbase.client.dcp.transport.netty.HandshakeTimeoutHandler
- CONNECTED - Enum constant in enum class com.couchbase.client.dcp.core.state.LifecycleState
-
The component is connected without degradation.
- CONNECTING - Enum constant in enum class com.couchbase.client.dcp.core.state.LifecycleState
-
The component is currently connecting or reconnecting.
- CONNECTION_BUFFER_SIZE - Enum constant in enum class com.couchbase.client.dcp.config.DcpControl.Names
-
Used to tell the Producer the size of the Consumer side buffer in bytes which the Consumer is using for flow control.
- CONNECTION_NAME_MAX_UTF8_BYTES - Static variable in interface com.couchbase.client.dcp.ConnectionNameGenerator
- connectionFlags() - Method in class com.couchbase.client.dcp.Client.Environment
-
Returns the flags to use when opening a DCP connection.
- connectionName(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpOpenConnectionRequest
-
Returns the connection name (a slice out of the original buffer).
- connectionName(ByteBuf, String) - Static method in enum class com.couchbase.client.dcp.message.DcpOpenConnectionRequest
-
Set the connection name on the buffer.
- connectionNameGenerator() - Method in class com.couchbase.client.dcp.Client.Environment
-
Returns the name generator used to identify DCP sockets.
- connectionNameGenerator(ConnectionNameGenerator) - Method in class com.couchbase.client.dcp.Client.Builder
-
If specific names for DCP connections should be generated, a custom one can be provided.
- ConnectionNameGenerator - Interface in com.couchbase.client.dcp
-
A generic interface which determines the name for a DCP connection.
- connectionString() - Method in class com.couchbase.client.dcp.Client.Environment
- connectionString(ConnectionString) - Method in class com.couchbase.client.dcp.Client.Builder
- connectionString(String) - Method in class com.couchbase.client.dcp.Client.Builder
-
Connection string to bootstrap with.
- contains(int, DataType) - Static method in enum class com.couchbase.client.dcp.message.DataType
- content() - Method in class com.couchbase.client.dcp.message.ContentAndXattrs
- content(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpMutationMessage
- ContentAndXattrs - Class in com.couchbase.client.dcp.message
- ContentAndXattrs(byte[], Map<String, String>) - Constructor for class com.couchbase.client.dcp.message.ContentAndXattrs
- contentBytes(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpMutationMessage
- Control - Class in com.couchbase.client.dcp.config
- Control(String, String, boolean) - Constructor for class com.couchbase.client.dcp.config.Control
- controlEventHandler() - Method in class com.couchbase.client.dcp.Client.Environment
-
Returns the current attached control event handler.
- controlEventHandler(ControlEventHandler) - Method in class com.couchbase.client.dcp.Client
-
Stores a
ControlEventHandler
to be called when control events happen. - ControlEventHandler - Interface in com.couchbase.client.dcp
-
This interface acts as a callback on the
Client.controlEventHandler(ControlEventHandler)
API that allows one to react to control events. - controlParam(DcpControl.Names, Object) - Method in class com.couchbase.client.dcp.Client.Builder
-
Sets a DCP control parameter.
- controlParam(String, Object) - Method in class com.couchbase.client.dcp.Client.Builder
-
Sets an arbitrary DCP control parameter.
- convertValue(Object, TypeReference<T>) - Static method in class com.couchbase.client.dcp.core.utils.JacksonHelper
- copyToUnmodifiableList(Collection<T>) - Static method in class com.couchbase.client.dcp.core.utils.CbCollections
-
Returns a new unmodifiable list with the same contents as the given collection.
- copyToUnmodifiableSet(Collection<T>) - Static method in class com.couchbase.client.dcp.core.utils.CbCollections
-
Returns a new unmodifiable set with the same contents as the given collection.
- COUCHAPI - Enum constant in enum class com.couchbase.client.dcp.core.config.BucketCapability
- CouchbaseBucketConfig - Class in com.couchbase.client.dcp.core.config
- CouchbaseBucketConfig(ClusterConfig, String, String, Set<BucketCapability>, boolean, int, PartitionMap, PartitionMap) - Constructor for class com.couchbase.client.dcp.core.config.CouchbaseBucketConfig
- CouchbaseBucketConfigParser - Class in com.couchbase.client.dcp.core.config
- CouchbaseBucketConfigParser() - Constructor for class com.couchbase.client.dcp.core.config.CouchbaseBucketConfigParser
- CouchbaseEvent - Interface in com.couchbase.client.dcp.core.event
-
Defines the generic couchbase event pushed through the event bus.
- CouchbaseException - Exception in com.couchbase.client.dcp.core
-
Common parent exception to build a proper exception hierarchy inside the driver.
- CouchbaseException() - Constructor for exception com.couchbase.client.dcp.core.CouchbaseException
- CouchbaseException(String) - Constructor for exception com.couchbase.client.dcp.core.CouchbaseException
- CouchbaseException(String, Throwable) - Constructor for exception com.couchbase.client.dcp.core.CouchbaseException
- CouchbaseException(Throwable) - Constructor for exception com.couchbase.client.dcp.core.CouchbaseException
- create(NetworkResolution, Set<SeedNode>) - Static method in interface com.couchbase.client.dcp.core.config.NetworkSelector
- create(String) - Static method in class com.couchbase.client.dcp.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.dcp.core.env.SeedNode
-
Creates a seed node from a hostname and custom ports.
- create(T1, T2) - Static method in class com.couchbase.client.dcp.core.lang.Tuple
-
Creates a tuple with two values.
- CREATE_AS_DELETED - Enum constant in enum class com.couchbase.client.dcp.core.config.BucketCapability
- credentials(String, String) - Method in class com.couchbase.client.dcp.Client.Builder
- Credentials - Class in com.couchbase.client.dcp
- Credentials(String, String) - Constructor for class com.couchbase.client.dcp.Credentials
- credentialsProvider(CredentialsProvider) - Method in class com.couchbase.client.dcp.Client.Builder
- CredentialsProvider - Interface in com.couchbase.client.dcp
- CURRENT_VERSION - Static variable in class com.couchbase.client.dcp.state.SessionState
-
The current version format used on export, respected on import to aid backwards compatibility.
D
- DATA_TYPE_OFFSET - Static variable in enum class com.couchbase.client.dcp.message.MessageUtil
- DatabaseChangeConsumerOps - Class in com.couchbase.client.dcp.highlevel.internal
-
Optionally auto-acknowledges events as they are consumed.
- DatabaseChangeConsumerOps(BlockingQueue<DatabaseChangeEvent>, FlowControlMode) - Constructor for class com.couchbase.client.dcp.highlevel.internal.DatabaseChangeConsumerOps
- DatabaseChangeEvent - Interface in com.couchbase.client.dcp.highlevel.internal
- DatabaseChangeListener - Interface in com.couchbase.client.dcp.highlevel
- dataEventHandler() - Method in class com.couchbase.client.dcp.Client.Environment
-
Returns the currently attached data event handler.
- dataEventHandler(DataEventHandler) - Method in class com.couchbase.client.dcp.Client
-
Stores a
DataEventHandler
to be called when data events happen. - DataEventHandler - Interface in com.couchbase.client.dcp
-
This interface acts as a callback on the
Client.dataEventHandler(DataEventHandler)
API that allows one to react to data events. - DataType - Enum Class in com.couchbase.client.dcp.message
-
https://github.com/couchbase/kv_engine/blob/master/docs/BinaryProtocol.md#data-types
- DATATYPE - Enum constant in enum class com.couchbase.client.dcp.message.HelloFeature
- DCP - Enum constant in enum class com.couchbase.client.dcp.core.config.BucketCapability
- DCP_ADD_STREAM_OPCODE - Static variable in enum class com.couchbase.client.dcp.message.MessageUtil
- DCP_BUFFER_ACK_OPCODE - Static variable in enum class com.couchbase.client.dcp.message.MessageUtil
- DCP_CONTROL_OPCODE - Static variable in enum class com.couchbase.client.dcp.message.MessageUtil
- DCP_DELETION_OPCODE - Static variable in enum class com.couchbase.client.dcp.message.MessageUtil
- DCP_EXPIRATION_OPCODE - Static variable in enum class com.couchbase.client.dcp.message.MessageUtil
- DCP_FAILOVER_LOG_OPCODE - Static variable in enum class com.couchbase.client.dcp.message.MessageUtil
- DCP_FLUSH_OPCODE - Static variable in enum class com.couchbase.client.dcp.message.MessageUtil
- DCP_MUTATION_OPCODE - Static variable in enum class com.couchbase.client.dcp.message.MessageUtil
- DCP_NOOP_OPCODE - Static variable in enum class com.couchbase.client.dcp.message.MessageUtil
- DCP_OSO_SNAPSHOT_MARKER_OPCODE - Static variable in enum class com.couchbase.client.dcp.message.MessageUtil
- DCP_SEQNO_ADVANCED_OPCODE - Static variable in enum class com.couchbase.client.dcp.message.MessageUtil
- DCP_SET_VBUCKET_STATE_OPCODE - Static variable in enum class com.couchbase.client.dcp.message.MessageUtil
- DCP_SNAPSHOT_MARKER_OPCODE - Static variable in enum class com.couchbase.client.dcp.message.MessageUtil
- DCP_STREAM_CLOSE_OPCODE - Static variable in enum class com.couchbase.client.dcp.message.MessageUtil
- DCP_STREAM_END_OPCODE - Static variable in enum class com.couchbase.client.dcp.message.MessageUtil
- DCP_STREAM_REQUEST_OPCODE - Static variable in enum class com.couchbase.client.dcp.message.MessageUtil
- DCP_SYSTEM_EVENT_OPCODE - Static variable in enum class com.couchbase.client.dcp.message.MessageUtil
- DcpAddStreamRequest - Enum Class in com.couchbase.client.dcp.message
-
Sent to the consumer to tell the consumer to initiate a stream request with the producer
- DcpAddStreamResponse - Enum Class in com.couchbase.client.dcp.message
- DcpBucketConfig - Class in com.couchbase.client.dcp.buffer
-
A wrapper around a
CouchbaseBucketConfig
that automatically resolves alternate addresses and analyzes the partition map to support persistence polling. - DcpBucketConfig(CouchbaseBucketConfig) - Constructor for class com.couchbase.client.dcp.buffer.DcpBucketConfig
- DcpBufferAckRequest - Enum Class in com.couchbase.client.dcp.message
- DcpChannel - Class in com.couchbase.client.dcp.conductor
-
Logical representation of a DCP cluster connection.
- DcpChannel(HostAndPort, Client.Environment, Conductor, DcpClientMetrics) - Constructor for class com.couchbase.client.dcp.conductor.DcpChannel
- DcpChannelControlHandler - Class in com.couchbase.client.dcp.conductor
- DcpChannelControlHandler(DcpChannel) - Constructor for class com.couchbase.client.dcp.conductor.DcpChannelControlHandler
- DcpChannelMetrics - Class in com.couchbase.client.dcp.metrics
- DcpChannelMetrics(MetricsContext) - Constructor for class com.couchbase.client.dcp.metrics.DcpChannelMetrics
- dcpChannelsReconnectDelay(Delay) - Method in class com.couchbase.client.dcp.Client.Builder
-
Deprecated.Doesn't do anything.
- dcpChannelsReconnectMaxAttempts() - Method in class com.couchbase.client.dcp.Client.Environment
- dcpChannelsReconnectMaxAttempts(int) - Method in class com.couchbase.client.dcp.Client.Builder
-
The maximum number of reconnect attempts for DCP channels
- DcpClientMetrics - Class in com.couchbase.client.dcp.metrics
- DcpClientMetrics(MetricsContext) - Constructor for class com.couchbase.client.dcp.metrics.DcpClientMetrics
- DcpCloseStreamRequest - Enum Class in com.couchbase.client.dcp.message
- DcpCloseStreamResponse - Enum Class in com.couchbase.client.dcp.message
- DcpConnectHandler - Class in com.couchbase.client.dcp.transport.netty
-
Opens the DCP connection on the channel and once established removes itself.
- dcpControl() - Method in class com.couchbase.client.dcp.Client.Environment
-
Returns all DCP control params set, may be empty.
- DcpControl - Class in com.couchbase.client.dcp.config
-
This class is used during bootstrap to configure all the possible DCP negotiation parameters.
- DcpControl() - Constructor for class com.couchbase.client.dcp.config.DcpControl
- DcpControl.Names - Enum Class in com.couchbase.client.dcp.config
-
All the possible control options available.
- DcpControlHandler - Class in com.couchbase.client.dcp.transport.netty
-
Negotiates DCP controls once connected and removes itself afterwards.
- DcpControlRequest - Enum Class in com.couchbase.client.dcp.message
- DcpControlResponse - Enum Class in com.couchbase.client.dcp.message
- DcpDeletionMessage - Enum Class in com.couchbase.client.dcp.message
- DcpExpirationMessage - Enum Class in com.couchbase.client.dcp.message
- DcpFailoverLogRequest - Enum Class in com.couchbase.client.dcp.message
- DcpFailoverLogResponse - Enum Class in com.couchbase.client.dcp.message
- DcpFailureEvent - Interface in com.couchbase.client.dcp.events
- DcpFlushRequest - Enum Class in com.couchbase.client.dcp.message
- DcpGetPartitionSeqnosRequest - Enum Class in com.couchbase.client.dcp.message
- DcpGetPartitionSeqnosResponse - Enum Class in com.couchbase.client.dcp.message
- DcpLoggingHandler - Class in com.couchbase.client.dcp.transport.netty
-
A
ChannelHandler
that logs all events using a logging framework. - DcpLoggingHandler() - Constructor for class com.couchbase.client.dcp.transport.netty.DcpLoggingHandler
-
Creates a new instance whose logger name is the fully qualified class name of the instance with hex dump enabled.
- DcpLoggingHandler(LogLevel) - Constructor for class com.couchbase.client.dcp.transport.netty.DcpLoggingHandler
-
Creates a new instance whose logger name is the fully qualified class name of the instance.
- DcpLoggingHandler(Class<?>) - Constructor for class com.couchbase.client.dcp.transport.netty.DcpLoggingHandler
-
Creates a new instance with the specified logger name and with hex dump enabled.
- DcpLoggingHandler(Class<?>, LogLevel) - Constructor for class com.couchbase.client.dcp.transport.netty.DcpLoggingHandler
-
Creates a new instance with the specified logger name.
- DcpLoggingHandler(String) - Constructor for class com.couchbase.client.dcp.transport.netty.DcpLoggingHandler
-
Creates a new instance with the specified logger name.
- DcpLoggingHandler(String, LogLevel) - Constructor for class com.couchbase.client.dcp.transport.netty.DcpLoggingHandler
-
Creates a new instance with the specified logger name.
- DcpMessageHandler - Class in com.couchbase.client.dcp.transport.netty
-
Handles the "business logic" of incoming DCP mutation and control messages.
- DcpMutationMessage - Enum Class in com.couchbase.client.dcp.message
- DcpNoopRequest - Enum Class in com.couchbase.client.dcp.message
- DcpNoopResponse - Enum Class in com.couchbase.client.dcp.message
- DcpOpenConnectionRequest - Enum Class in com.couchbase.client.dcp.message
- DcpOpenConnectionResponse - Enum Class in com.couchbase.client.dcp.message
- DcpOpenStreamRequest - Enum Class in com.couchbase.client.dcp.message
- DcpOpenStreamResponse - Enum Class in com.couchbase.client.dcp.message
- DcpOps - Interface in com.couchbase.client.dcp.buffer
- DcpOps.BadResponseStatusException - Exception in com.couchbase.client.dcp.buffer
-
Thrown when response status field is non-zero.
- DcpOpsImpl - Class in com.couchbase.client.dcp.buffer
- DcpOpsImpl(DcpRequestDispatcher) - Constructor for class com.couchbase.client.dcp.buffer.DcpOpsImpl
- DcpPipeline - Class in com.couchbase.client.dcp.transport.netty
-
Sets up the pipeline for the actual DCP communication channels.
- DcpPipeline(Client.Environment, DcpChannelControlHandler, BucketConfigArbiter, DcpChannelMetrics, DcpClientMetrics) - Constructor for class com.couchbase.client.dcp.transport.netty.DcpPipeline
-
Creates the pipeline.
- DcpRequestDispatcher - Interface in com.couchbase.client.dcp.buffer
-
Sends DCP requests to the server.
- DcpResponse - Class in com.couchbase.client.dcp.transport.netty
- DcpResponse(ByteBuf) - Constructor for class com.couchbase.client.dcp.transport.netty.DcpResponse
- DcpResponseListener - Interface in com.couchbase.client.dcp.transport.netty
-
Type alias.
- DcpSeqnoAdvancedRequest - Class in com.couchbase.client.dcp.message
- DcpSetVbucketStateMessage - Enum Class in com.couchbase.client.dcp.message
-
This message is used during the VBucket takeover process to hand off ownership of a VBucket between two nodes.
- DcpSetVbucketStateMessage.State - Enum Class in com.couchbase.client.dcp.message
- DcpSnapshotMarkerRequest - Enum Class in com.couchbase.client.dcp.message
- DcpSnapshotMarkerResponse - Enum Class in com.couchbase.client.dcp.message
- DcpStreamEndMessage - Enum Class in com.couchbase.client.dcp.message
- DcpSystemEvent - Class in com.couchbase.client.dcp.message
- DcpSystemEvent(DcpSystemEvent.Type, int, long, int) - Constructor for class com.couchbase.client.dcp.message.DcpSystemEvent
- DcpSystemEvent.CollectionsManifestEvent - Interface in com.couchbase.client.dcp.message
- DcpSystemEvent.Type - Enum Class in com.couchbase.client.dcp.message
- DcpSystemEventRequest - Class in com.couchbase.client.dcp.message
- DcpSystemEventRequest() - Constructor for class com.couchbase.client.dcp.message.DcpSystemEventRequest
- dead(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpSetVbucketStateMessage
- DEAD - Enum constant in enum class com.couchbase.client.dcp.message.DcpSetVbucketStateMessage.State
- DEAD - Enum constant in enum class com.couchbase.client.dcp.message.VbucketState
-
Not in use, pending deletion.
- DEBUG - Enum constant in enum class com.couchbase.client.dcp.metrics.LogLevel
- decode(byte[]) - Static method in class com.couchbase.client.dcp.core.utils.UnsignedLEB128
-
Given a byte array starting with an unsigned LEB128 value, returns the decoded form of that value.
- decode(int) - Static method in enum class com.couchbase.client.dcp.message.SnapshotMarkerFlag
- decode(int) - Static method in enum class com.couchbase.client.dcp.message.StreamFlag
- decodeCertificates(List<String>) - Static method in class com.couchbase.client.dcp.SecurityConfig
-
Helper method to decode string-encoded certificates into their x.509 format.
- DEFAULT - Static variable in interface com.couchbase.client.dcp.core.config.NetworkSelector
- DEFAULT - Static variable in class com.couchbase.client.dcp.core.env.NetworkResolution
-
Pick whatever the server returns in the config, this is the old and backwards compatible mode (server default).
- DEFAULT - Static variable in class com.couchbase.client.dcp.highlevel.internal.CollectionsManifest
-
A manifest with just the default scope and default collection.
- DEFAULT - Static variable in class com.couchbase.client.dcp.highlevel.internal.CollectionsManifest.ScopeInfo
- DEFAULT_BOOTSTRAP_TIMEOUT - Static variable in class com.couchbase.client.dcp.Client.Environment
- DEFAULT_CONFIG_REFRESH_INTERVAL - Static variable in class com.couchbase.client.dcp.Client.Environment
- DEFAULT_DCP_CHANNELS_RECONNECT_DELAY - Static variable in class com.couchbase.client.dcp.Client.Environment
- DEFAULT_DCP_CHANNELS_RECONNECT_MAX_ATTEMPTS - Static variable in class com.couchbase.client.dcp.Client.Environment
- DEFAULT_SOCKET_CONNECT_TIMEOUT - Static variable in class com.couchbase.client.dcp.Client.Environment
- DefaultConnectionNameGenerator - Class in com.couchbase.client.dcp
-
The default implementation for the
ConnectionNameGenerator
. - DefaultDcpEventBus - Class in com.couchbase.client.dcp.events
- DefaultDcpEventBus(Scheduler) - Constructor for class com.couchbase.client.dcp.events.DefaultDcpEventBus
- DefaultDropwizardConfig - Class in com.couchbase.client.dcp.metrics
- DefaultDropwizardConfig() - Constructor for class com.couchbase.client.dcp.metrics.DefaultDropwizardConfig
- DefaultDropwizardConfig(String, Function<String, String>) - Constructor for class com.couchbase.client.dcp.metrics.DefaultDropwizardConfig
- DefaultDropwizardConfig(String, Map<String, String>) - Constructor for class com.couchbase.client.dcp.metrics.DefaultDropwizardConfig
- DefaultDropwizardConfig(String, Properties) - Constructor for class com.couchbase.client.dcp.metrics.DefaultDropwizardConfig
- defaultIfEmpty(String, String) - Static method in class com.couchbase.client.dcp.core.utils.CbStrings
- DefaultObjectMapper - Class in com.couchbase.client.dcp.core.utils
-
Provides global access to the services of a Jackson
ObjectMapper
with default configuration. - DEGRADED - Enum constant in enum class com.couchbase.client.dcp.core.state.LifecycleState
-
The component is connected, but with service degradation.
- Delay - Class in com.couchbase.client.dcp.core.time
-
Parent class of
Delay
s and provides factory methods to create them. - Deletion - Class in com.couchbase.client.dcp.highlevel
- Deletion(ByteBuf, CollectionsManifest.CollectionInfo, String, FlowControlReceipt, StreamOffset, boolean) - Constructor for class com.couchbase.client.dcp.highlevel.Deletion
- deregister(ChannelHandlerContext, ChannelPromise) - Method in class com.couchbase.client.dcp.transport.netty.AuthHandler
- describe(StreamOffset) - Static method in class com.couchbase.client.dcp.highlevel.StreamOffset
-
Returns the same info as toString(), but in a format readable by humans without special knowledge.
- description() - Method in class com.couchbase.client.dcp.message.StreamEndReason
- deserialize(JsonParser, DeserializationContext) - Method in class com.couchbase.client.dcp.state.json.SessionStateDeserializer
- DISABLED - Enum constant in enum class com.couchbase.client.dcp.config.CompressionMode
-
Couchbase Server will never send compressed values.
- disconnect() - Method in class com.couchbase.client.dcp.Client
-
Disconnect the
Client
and shut down all its owned resources. - disconnect() - Method in class com.couchbase.client.dcp.conductor.DcpChannel
- disconnect(ChannelHandlerContext, ChannelPromise) - Method in class com.couchbase.client.dcp.transport.netty.AuthHandler
- disconnected() - Method in class com.couchbase.client.dcp.conductor.Conductor
-
Returns true if all channels and the config provider are in a disconnected state.
- DISCONNECTED - Enum constant in enum class com.couchbase.client.dcp.core.state.LifecycleState
-
The component is currently disconnected.
- DISCONNECTED - Static variable in class com.couchbase.client.dcp.message.StreamEndReason
- DISCONNECTING - Enum constant in enum class com.couchbase.client.dcp.core.state.LifecycleState
-
The component is disconnecting.
- DISK - Enum constant in enum class com.couchbase.client.dcp.message.SnapshotMarkerFlag
-
Specifies that the snapshot contains on-disk items only.
- DISK_ONLY - Enum constant in enum class com.couchbase.client.dcp.message.StreamFlag
-
Specifies that the stream should only send items only if they are on disk.
- dispatch(DatabaseChangeListener) - Method in class com.couchbase.client.dcp.highlevel.CollectionCreated
- dispatch(DatabaseChangeListener) - Method in class com.couchbase.client.dcp.highlevel.CollectionDropped
- dispatch(DatabaseChangeListener) - Method in class com.couchbase.client.dcp.highlevel.CollectionFlushed
- dispatch(DatabaseChangeListener) - Method in class com.couchbase.client.dcp.highlevel.Deletion
- dispatch(DatabaseChangeListener) - Method in class com.couchbase.client.dcp.highlevel.FailoverLog
- dispatch(DatabaseChangeListener) - Method in interface com.couchbase.client.dcp.highlevel.internal.DatabaseChangeEvent
-
Pass this event to the appropriate method of the given listener.
- dispatch(DatabaseChangeListener) - Method in class com.couchbase.client.dcp.highlevel.Mutation
- dispatch(DatabaseChangeListener) - Method in class com.couchbase.client.dcp.highlevel.Rollback
- dispatch(DatabaseChangeListener) - Method in class com.couchbase.client.dcp.highlevel.ScopeCreated
- dispatch(DatabaseChangeListener) - Method in class com.couchbase.client.dcp.highlevel.ScopeDropped
- dispatch(DatabaseChangeListener) - Method in class com.couchbase.client.dcp.highlevel.SeqnoAdvanced
- dispatch(DatabaseChangeListener) - Method in class com.couchbase.client.dcp.highlevel.SnapshotDetails
- dispatch(DatabaseChangeListener) - Method in class com.couchbase.client.dcp.highlevel.StreamEnd
- dispatch(DatabaseChangeListener) - Method in class com.couchbase.client.dcp.highlevel.StreamFailure
- dispatch(DatabaseChangeEvent) - Method in class com.couchbase.client.dcp.highlevel.internal.AsyncEventDispatcher
- dispatch(DatabaseChangeEvent) - Method in interface com.couchbase.client.dcp.highlevel.internal.EventDispatcher
- dispatch(DatabaseChangeEvent) - Method in class com.couchbase.client.dcp.highlevel.internal.ImmediateEventDispatcher
- DocumentChange - Class in com.couchbase.client.dcp.highlevel
- DocumentChange(ByteBuf, CollectionsManifest.CollectionInfo, String, FlowControlReceipt, StreamOffset) - Constructor for class com.couchbase.client.dcp.highlevel.DocumentChange
- dummy - Static variable in interface com.couchbase.client.dcp.transport.netty.ChannelFlowController
-
A flow controller that doesn't do anything.
- DUPLEX - Enum constant in enum class com.couchbase.client.dcp.message.HelloFeature
- DURABILITY_IMPOSSIBLE - Static variable in class com.couchbase.client.dcp.message.ResponseStatus
- DURABILITY_LEVEL_INVALID - Static variable in class com.couchbase.client.dcp.message.ResponseStatus
- DURABLE_WRITE - Enum constant in enum class com.couchbase.client.dcp.core.config.BucketCapability
E
- effectiveMode(Version) - Method in enum class com.couchbase.client.dcp.config.CompressionMode
- ENABLE_EXPIRY_OPCODE - Enum constant in enum class com.couchbase.client.dcp.config.DcpControl.Names
-
Tells the server that the client would like to receive expiry opcodes when an item is expired.
- ENABLE_EXT_METADATA - Enum constant in enum class com.couchbase.client.dcp.config.DcpControl.Names
-
Enables sending extended meta data.
- ENABLE_NOOP - Enum constant in enum class com.couchbase.client.dcp.config.DcpControl.Names
-
Used to enable to tell the Producer that the Consumer supports detecting dead connections through the use of a noop.
- ENABLE_VALUE_COMPRESSION - Enum constant in enum class com.couchbase.client.dcp.config.DcpControl.Names
-
Deprecated.in favor of specifying compression settings by calling
DcpControl.compression(CompressionMode)
. Scheduled for removal in next major version. - ENABLED - Enum constant in enum class com.couchbase.client.dcp.config.CompressionMode
-
Default mode.
- enableHostnameVerification(boolean) - Method in class com.couchbase.client.dcp.SecurityConfig.Builder
-
Allows to enable or disable hostname verification (enabled by default).
- enableNativeTls(boolean) - Method in class com.couchbase.client.dcp.SecurityConfig.Builder
-
Enables/disables native TLS (enabled by default).
- enableTls(boolean) - Method in class com.couchbase.client.dcp.SecurityConfig.Builder
-
Enables TLS for all client/server communication (disabled by default).
- encode(long) - Static method in class com.couchbase.client.dcp.core.utils.UnsignedLEB128
-
Returns a byte array containing the unsigned LEB128 representation of the given value.
- encode(Set<OpenConnectionFlag>) - Static method in enum class com.couchbase.client.dcp.message.OpenConnectionFlag
- encode(Set<StreamFlag>) - Static method in enum class com.couchbase.client.dcp.message.StreamFlag
- endSeqno(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpSnapshotMarkerRequest
- endSeqno(ByteBuf, long) - Static method in enum class com.couchbase.client.dcp.message.DcpOpenStreamRequest
- entries(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpFailoverLogResponse
- ephemeral() - Method in class com.couchbase.client.dcp.core.config.CouchbaseBucketConfig
- epoch() - Method in class com.couchbase.client.dcp.core.config.ConfigRevision
- equals(Object) - Method in class com.couchbase.client.dcp.conductor.DcpChannel
- equals(Object) - Method in class com.couchbase.client.dcp.config.HostAndPort
- equals(Object) - Method in class com.couchbase.client.dcp.core.config.ConfigRevision
- equals(Object) - Method in class com.couchbase.client.dcp.core.config.NodeIdentifier
- equals(Object) - Method in class com.couchbase.client.dcp.core.config.NodeInfo
- equals(Object) - Method in class com.couchbase.client.dcp.core.env.NetworkResolution
- equals(Object) - Method in class com.couchbase.client.dcp.core.env.SeedNode
- equals(Object) - Method in class com.couchbase.client.dcp.highlevel.SnapshotMarker
- equals(Object) - Method in class com.couchbase.client.dcp.highlevel.StreamOffset
- equals(Object) - Method in class com.couchbase.client.dcp.message.PartitionAndSeqno
- equals(Object) - Method in class com.couchbase.client.dcp.message.ResponseStatus
- equals(Object) - Method in class com.couchbase.client.dcp.message.StreamEndReason
- equals(Object) - Method in class com.couchbase.client.dcp.state.FailoverLogEntry
- equals(Object) - Method in class com.couchbase.client.dcp.util.PartitionSet
- equals(Object) - Method in class com.couchbase.client.dcp.util.Version
- error() - Method in interface com.couchbase.client.dcp.events.DcpFailureEvent
- error() - Method in class com.couchbase.client.dcp.events.FailedToAddNodeEvent
-
Error object, describing the issue
- error() - Method in class com.couchbase.client.dcp.events.FailedToMovePartitionEvent
-
Error object, describing the issue
- error() - Method in class com.couchbase.client.dcp.events.FailedToRemoveNodeEvent
-
Error object, describing the issue
- ERROR - Enum constant in enum class com.couchbase.client.dcp.metrics.LogLevel
- eventBus() - Method in class com.couchbase.client.dcp.Client.Environment
-
Returns the event bus where events are broadcasted on and can be published to.
- eventBus(EventBus) - Method in class com.couchbase.client.dcp.Client.Builder
-
Sets the event bus to an alternative implementation.
- EventBus - Interface in com.couchbase.client.dcp.core.event
- EventCounter - Class in com.couchbase.client.dcp.metrics
-
Tracks occurrences of an event.
- EventCounter.Builder - Class in com.couchbase.client.dcp.metrics
- EventDispatcher - Interface in com.couchbase.client.dcp.highlevel.internal
- EventHandlerAdapter - Class in com.couchbase.client.dcp.highlevel.internal
-
Bridges the gap between the various low-level callback handlers and the high-level
DatabaseChangeListener
. - EVENTING - Enum constant in enum class com.couchbase.client.dcp.core.service.ServiceType
-
The Eventing (function) service.
- eventLoopGroup() - Method in class com.couchbase.client.dcp.Client.Environment
-
Returns the currently attached event loop group for IO process.ing.
- eventLoopGroup(EventLoopGroup) - Method in class com.couchbase.client.dcp.Client.Builder
-
Sets a custom event loop group.
- Events - Class in com.couchbase.client.dcp.core.utils
-
Utility methods for event handling.
- Events() - Constructor for class com.couchbase.client.dcp.core.utils.Events
- EventType - Enum Class in com.couchbase.client.dcp.core.event
- exceptionCaught(ChannelHandlerContext, Throwable) - Method in class com.couchbase.client.dcp.transport.netty.AuthHandler
- expiry(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpMutationMessage
- exponential(TimeUnit) - Static method in class com.couchbase.client.dcp.core.time.Delay
-
Creates a new
ExponentialDelay
with default boundaries and factor (1, 2, 4, 8, 16, 32...). - exponential(TimeUnit, long) - Static method in class com.couchbase.client.dcp.core.time.Delay
-
Creates a new
ExponentialDelay
with custom upper boundary and default factor (eg. - exponential(TimeUnit, long, long) - Static method in class com.couchbase.client.dcp.core.time.Delay
-
Creates a new
ExponentialDelay
with custom boundaries and default factor (eg. - exponential(TimeUnit, long, long, long) - Static method in class com.couchbase.client.dcp.core.time.Delay
-
Creates a new
ExponentialDelay
with custom boundaries and factor (eg. - exponential(TimeUnit, long, long, long, int) - Static method in class com.couchbase.client.dcp.core.time.Delay
-
Creates a new
ExponentialDelay
on a base different from powers of two, with custom boundaries and factor (eg. - ExponentialDelay - Class in com.couchbase.client.dcp.core.time
-
Delay which increases exponentially on every attempt.
- export(StateFormat) - Method in class com.couchbase.client.dcp.state.SessionState
-
Export the
PartitionState
into the desired format. - EXTERNAL - Static variable in interface com.couchbase.client.dcp.core.config.NetworkSelector
- EXTERNAL - Static variable in class com.couchbase.client.dcp.core.env.NetworkResolution
-
Pins it to external resolution.
- EXTRAS_LENGTH_OFFSET - Static variable in enum class com.couchbase.client.dcp.message.MessageUtil
F
- FailedToAddNodeEvent - Class in com.couchbase.client.dcp.events
-
Event published when the connector has failed to add new node during failover/rebalance.
- FailedToAddNodeEvent(HostAndPort, Throwable) - Constructor for class com.couchbase.client.dcp.events.FailedToAddNodeEvent
- FailedToMovePartitionEvent - Class in com.couchbase.client.dcp.events
-
Event published when the connector has failed to move partition to new node during failover/rebalance.
- FailedToMovePartitionEvent(int, Throwable) - Constructor for class com.couchbase.client.dcp.events.FailedToMovePartitionEvent
- FailedToRemoveNodeEvent - Class in com.couchbase.client.dcp.events
-
Event published when the connector has failed to remove node during failover/rebalance.
- FailedToRemoveNodeEvent(HostAndPort, Throwable) - Constructor for class com.couchbase.client.dcp.events.FailedToRemoveNodeEvent
- failoverLog(int) - Method in class com.couchbase.client.dcp.Client
- FailoverLog - Class in com.couchbase.client.dcp.highlevel
- FailoverLog(int, List<FailoverLogEntry>) - Constructor for class com.couchbase.client.dcp.highlevel.FailoverLog
- FailoverLogEntry - Class in com.couchbase.client.dcp.state
-
Represents a single entry in a failover log per partition state.
- FailoverLogEntry(long, long) - Constructor for class com.couchbase.client.dcp.state.FailoverLogEntry
- failoverLogs(Short...) - Method in class com.couchbase.client.dcp.Client
-
Deprecated.Please use
Client.failoverLogs(Collection)
instead. - failoverLogs(Collection<Integer>) - Method in class com.couchbase.client.dcp.Client
-
Helper method to return the failover logs for the given partitions (vbids).
- failure(long, TimeUnit, String) - Method in class com.couchbase.client.dcp.metrics.ActionTimer
- failure(long, TimeUnit, Throwable) - Method in class com.couchbase.client.dcp.metrics.ActionTimer
-
Increments the "failure" count.
- failure(String) - Method in class com.couchbase.client.dcp.metrics.ActionCounter
- failure(Throwable) - Method in class com.couchbase.client.dcp.metrics.ActionCounter
-
Increments the "failure" count.
- failureLogLevel(LogLevel) - Method in class com.couchbase.client.dcp.metrics.ActionCounter.Builder
- failureLogLevel(LogLevel) - Method in class com.couchbase.client.dcp.metrics.ActionTimer.Builder
- filter(Iterable<T>, Predicate<? super T>) - Static method in class com.couchbase.client.dcp.core.utils.CbCollections
-
Convenience method equivalent to:
- filter(T[], Predicate<? super T>) - Static method in class com.couchbase.client.dcp.core.utils.CbCollections
-
Convenience method equivalent to:
- FILTER_EMPTY - Static variable in class com.couchbase.client.dcp.message.StreamEndReason
- fixed(long, TimeUnit) - Static method in class com.couchbase.client.dcp.core.time.Delay
-
Creates a new
FixedDelay
. - FixedDelay - Class in com.couchbase.client.dcp.core.time
-
Delay which is fixed for every attempt.
- flags(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpAddStreamRequest
- flags(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpMutationMessage
- flags(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpOpenStreamRequest
- flags(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpSetVbucketStateMessage
- flags(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpSnapshotMarkerRequest
- flags(ByteBuf, int) - Static method in enum class com.couchbase.client.dcp.message.DcpAddStreamRequest
- flags(ByteBuf, int) - Static method in enum class com.couchbase.client.dcp.message.DcpOpenStreamRequest
- flagsAsInt(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpAddStreamRequest
- flagsAsInt(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpOpenStreamRequest
- flagsAsInt(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpSnapshotMarkerRequest
- flowControl(int) - Method in class com.couchbase.client.dcp.Client.Builder
-
Enables flow control with the specified buffer size (in bytes) and a reasonable default buffer ACK threshold.
- flowControlAck() - Method in class com.couchbase.client.dcp.highlevel.DocumentChange
-
Removes the backpressure generated by this event, allowing the server to send more data.
- flowControlAck() - Method in interface com.couchbase.client.dcp.highlevel.internal.FlowControllable
-
Must be idempotent.
- FlowControllable - Interface in com.couchbase.client.dcp.highlevel.internal
- FlowControlMode - Enum Class in com.couchbase.client.dcp.highlevel
- FlowControlReceipt - Class in com.couchbase.client.dcp.highlevel.internal
- FlowControlReceipt(ChannelFlowController, int) - Constructor for class com.couchbase.client.dcp.highlevel.internal.FlowControlReceipt
- flush(ChannelHandlerContext) - Method in class com.couchbase.client.dcp.transport.netty.AuthHandler
- FORCED - Enum constant in enum class com.couchbase.client.dcp.config.CompressionMode
-
Couchbase Server will always send compressed values, regardless of how the values are stored on the server, unless the compressed form is larger than the uncompressed form.
- forCode(int) - Static method in enum class com.couchbase.client.dcp.message.HelloFeature
- forDefaultCollection(String) - Static method in class com.couchbase.client.dcp.highlevel.internal.CollectionIdAndKey
- forEach(BiConsumer<Integer, PartitionInfo>) - Method in class com.couchbase.client.dcp.core.config.PartitionMap
-
Passes each map entry to the given consumer.
- foreachPartition(BiConsumer<Integer, PartitionState>) - Method in class com.couchbase.client.dcp.state.SessionState
- foreachPartition(Consumer<PartitionState>) - Method in class com.couchbase.client.dcp.state.SessionState
-
Provides an iterator over all partitions, calling the callback for each one.
- format() - Method in class com.couchbase.client.dcp.config.HostAndPort
- format() - Method in class com.couchbase.client.dcp.util.PartitionSet
- format(ChannelHandlerContext, String, Object) - Method in class com.couchbase.client.dcp.transport.netty.DcpLoggingHandler
- formatted() - Method in class com.couchbase.client.dcp.message.ResponseStatus
- forMessage(ChannelFlowController, ByteBuf) - Static method in class com.couchbase.client.dcp.highlevel.internal.FlowControlReceipt
- forProduct(String, String, String...) - Static method in class com.couchbase.client.dcp.DefaultConnectionNameGenerator
-
Returns a new connection name generator that includes the given product information in the User Agent string.
- from(Collection<Integer>) - Static method in class com.couchbase.client.dcp.util.PartitionSet
- fromJson(byte[]) - Static method in class com.couchbase.client.dcp.highlevel.internal.CollectionsManifest
- fromKey(PrivateKey, String, List<X509Certificate>) - Static method in class com.couchbase.client.dcp.CertificateAuthenticator
-
Creates a new
CertificateAuthenticator
directly from a key and certificate chain. - fromKeyManagerFactory(Supplier<KeyManagerFactory>) - Static method in class com.couchbase.client.dcp.CertificateAuthenticator
-
Creates a new
CertificateAuthenticator
from aKeyManagerFactory
. - fromKeyStore(Path, String) - Static method in class com.couchbase.client.dcp.CertificateAuthenticator
-
Creates a new
CertificateAuthenticator
from a key store path. - fromKeyStore(Path, String, String) - Static method in class com.couchbase.client.dcp.CertificateAuthenticator
-
Creates a new
CertificateAuthenticator
from a key store path. - fromKeyStore(KeyStore, String) - Static method in class com.couchbase.client.dcp.CertificateAuthenticator
-
Creates a new
CertificateAuthenticator
from a key store. - fromOffset(StreamOffset) - Static method in class com.couchbase.client.dcp.state.PartitionState
- FULL - Enum constant in enum class com.couchbase.client.dcp.core.logging.RedactionLevel
-
User, System and Metadata are all redacted.
G
- get() - Method in interface com.couchbase.client.dcp.core.event.EventBus
-
Subscribe to the event bus to retrieve
CouchbaseEvent
s. - get() - Static method in enum class com.couchbase.client.dcp.core.logging.RedactionLevel
- get() - Method in class com.couchbase.client.dcp.events.DefaultDcpEventBus
- get(int) - Method in class com.couchbase.client.dcp.core.config.PartitionMap
- get(int) - Method in class com.couchbase.client.dcp.state.SessionState
-
Accessor into the partition state, only use this if really needed.
- get(int) - Method in class com.couchbase.client.dcp.util.AtomicBooleanArray
- get(ByteBufAllocator, SecurityConfig, HostAndPort, Authenticator) - Static method in class com.couchbase.client.dcp.transport.netty.SslHandlerFactory
- get(DcpControl.Names) - Method in class com.couchbase.client.dcp.config.DcpControl
-
Returns a param if set, otherwise null is returned.
- get(HostAndPort) - Method in interface com.couchbase.client.dcp.CredentialsProvider
-
Get the username/password pair to use for authentication/authorization
- get(HostAndPort) - Method in class com.couchbase.client.dcp.StaticCredentialsProvider
- get(String) - Method in class com.couchbase.client.dcp.metrics.DefaultDropwizardConfig
- GET_CLUSTER_CONFIG_OPCODE - Static variable in enum class com.couchbase.client.dcp.message.MessageUtil
- GET_COLLECTIONS_MANIFEST_OPCODE - Static variable in enum class com.couchbase.client.dcp.message.MessageUtil
- GET_SEQNOS_OPCODE - Static variable in enum class com.couchbase.client.dcp.message.MessageUtil
- getAbsentPartitionInstances() - Method in class com.couchbase.client.dcp.buffer.DcpBucketConfig
- getActiveNodeKvAddress(int) - Method in class com.couchbase.client.dcp.buffer.DcpBucketConfig
- getAddress(NodeInfo) - Method in class com.couchbase.client.dcp.buffer.DcpBucketConfig
- getCas() - Method in class com.couchbase.client.dcp.highlevel.DocumentChange
- getCas(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.MessageUtil
- getCause() - Method in class com.couchbase.client.dcp.highlevel.StreamFailure
- getCollection() - Method in class com.couchbase.client.dcp.highlevel.DocumentChange
- getCollection(long) - Method in class com.couchbase.client.dcp.highlevel.internal.CollectionsManifest
- getCollection(String) - Method in class com.couchbase.client.dcp.highlevel.internal.CollectionsManifest
- getCollectionId() - Method in class com.couchbase.client.dcp.highlevel.CollectionCreated
- getCollectionId() - Method in class com.couchbase.client.dcp.highlevel.CollectionDropped
- getCollectionId() - Method in class com.couchbase.client.dcp.highlevel.CollectionFlushed
- getCollectionIdAndKey(ByteBuf) - Method in interface com.couchbase.client.dcp.highlevel.internal.KeyExtractor
- getCollectionIdAndKey(ByteBuf, boolean) - Static method in enum class com.couchbase.client.dcp.message.MessageUtil
- getCollectionName() - Method in class com.couchbase.client.dcp.highlevel.CollectionCreated
- getCollectionsManifest() - Method in class com.couchbase.client.dcp.conductor.DcpChannel
-
Returns empty optional if collections are not enabled for this channel, otherwise the current collections manifest.
- getCollectionsManifest() - Method in class com.couchbase.client.dcp.state.PartitionState
- getCollectionsManifestUid() - Method in class com.couchbase.client.dcp.highlevel.StreamOffset
- getCollectionsManifestUid() - Method in class com.couchbase.client.dcp.state.PartitionState
- getContent() - Method in class com.couchbase.client.dcp.highlevel.DocumentChange
- getContent(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.MessageUtil
-
Returns the message content, uncompressed.
- getContentAndXattrs(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.MessageUtil
- getContentAsByteArray(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.MessageUtil
-
Returns a new array containing the uncompressed content of the given message.
- getContentAsString(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.MessageUtil
- getControls(Version) - Method in class com.couchbase.client.dcp.config.DcpControl
-
Returns the control settings, adjusted for the actual Couchbase Server version.
- getDataType(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.MessageUtil
- getDcpControls(Version) - Method in enum class com.couchbase.client.dcp.config.CompressionMode
- getEndSeqno() - Method in class com.couchbase.client.dcp.highlevel.SnapshotMarker
-
NOTE: Sequence numbers are unsigned, and must be compared using
Long.compareUnsigned(long, long)
- getEndSeqno() - Method in class com.couchbase.client.dcp.state.PartitionState
-
Returns the current end sequence number.
- getEntries() - Method in class com.couchbase.client.dcp.highlevel.FailoverLog
- getExpiry() - Method in class com.couchbase.client.dcp.highlevel.Mutation
- getExtras(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.MessageUtil
- getFailedStartOffset() - Method in class com.couchbase.client.dcp.highlevel.Rollback
-
Returns the requested start offset that lead to this rollback.
- getFailoverLog() - Method in class com.couchbase.client.dcp.state.PartitionState
-
Returns the full failover log stored, in sorted order.
- getFailoverLog(int) - Method in interface com.couchbase.client.dcp.buffer.DcpOps
- getFailoverLog(int) - Method in class com.couchbase.client.dcp.buffer.DcpOpsImpl
- getFailoverLog(int) - Method in class com.couchbase.client.dcp.conductor.Conductor
- getFailoverLog(int) - Method in class com.couchbase.client.dcp.conductor.DcpChannel
- getFeatures(Channel) - Static method in class com.couchbase.client.dcp.transport.netty.DcpConnectHandler
-
Returns the features from the HELO response (the intersection of the features we advertised and the features supported by the server).
- getFlags() - Method in class com.couchbase.client.dcp.highlevel.SnapshotDetails
- getFlagsAsInt() - Method in class com.couchbase.client.dcp.highlevel.Mutation
- getFlagsAsInt() - Method in class com.couchbase.client.dcp.highlevel.SnapshotDetails
- getHelloFeatures(Version) - Method in enum class com.couchbase.client.dcp.config.CompressionMode
- getHostAndPort(Channel) - Static method in class com.couchbase.client.dcp.conductor.DcpChannel
- getHostedPartitions(HostAndPort) - Method in class com.couchbase.client.dcp.buffer.DcpBucketConfig
- getId() - Method in class com.couchbase.client.dcp.highlevel.internal.CollectionsManifest
- getId(ByteBuf) - Static method in class com.couchbase.client.dcp.message.DcpSystemEventRequest
- getKey() - Method in class com.couchbase.client.dcp.highlevel.DocumentChange
- getKey(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.MessageUtil
- getKeyAsString(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.MessageUtil
- getKeyExtractor() - Method in class com.couchbase.client.dcp.state.PartitionState
- getKvNodes() - Method in class com.couchbase.client.dcp.buffer.DcpBucketConfig
-
Returns an unmodifiable list containing only those nodes that are running the KV service.
- getLastUuid() - Method in class com.couchbase.client.dcp.state.PartitionState
-
Convenience method to get the last UUID returned on the failover log.
- getLockTime() - Method in class com.couchbase.client.dcp.highlevel.Mutation
- getManifestId() - Method in class com.couchbase.client.dcp.highlevel.CollectionCreated
- getManifestId() - Method in class com.couchbase.client.dcp.highlevel.CollectionDropped
- getManifestId() - Method in class com.couchbase.client.dcp.highlevel.CollectionFlushed
- getManifestId() - Method in class com.couchbase.client.dcp.highlevel.ScopeCreated
- getManifestId() - Method in class com.couchbase.client.dcp.highlevel.ScopeDropped
- getManifestId() - Method in interface com.couchbase.client.dcp.message.DcpSystemEvent.CollectionsManifestEvent
- getMarker() - Method in class com.couchbase.client.dcp.highlevel.SnapshotDetails
- getMaxTtl() - Method in class com.couchbase.client.dcp.highlevel.CollectionCreated
- getMostRecentOpenStreamOffset() - Method in class com.couchbase.client.dcp.state.PartitionState
- getNodeIndex(HostAndPort) - Method in class com.couchbase.client.dcp.buffer.DcpBucketConfig
- getOffset() - Method in class com.couchbase.client.dcp.highlevel.DocumentChange
- getOffset() - Method in class com.couchbase.client.dcp.highlevel.SeqnoAdvanced
- getOffset() - Method in class com.couchbase.client.dcp.state.PartitionState
- getOpaque(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.MessageUtil
- getOpcode(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.MessageUtil
- getPassword() - Method in class com.couchbase.client.dcp.Credentials
- getQualifiedKey() - Method in class com.couchbase.client.dcp.highlevel.DocumentChange
-
Returns the document key prefixed by the names of the containing scope and collection.
- getRawContent(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.MessageUtil
-
Returns the message content in its original form (possibly compressed).
- getReason() - Method in class com.couchbase.client.dcp.highlevel.StreamEnd
- getReasonAsString(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpStreamEndMessage
- getResponseStatus(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.MessageUtil
- getRevision() - Method in class com.couchbase.client.dcp.highlevel.DocumentChange
- getScope(String) - Method in class com.couchbase.client.dcp.highlevel.internal.CollectionsManifest
- getScopeId() - Method in class com.couchbase.client.dcp.highlevel.CollectionCreated
- getScopeId() - Method in class com.couchbase.client.dcp.highlevel.CollectionDropped
- getScopeId() - Method in class com.couchbase.client.dcp.highlevel.CollectionFlushed
- getScopeId() - Method in class com.couchbase.client.dcp.highlevel.ScopeCreated
- getScopeId() - Method in class com.couchbase.client.dcp.highlevel.ScopeDropped
- getScopeName() - Method in class com.couchbase.client.dcp.highlevel.ScopeCreated
- getSeqno() - Method in class com.couchbase.client.dcp.highlevel.Rollback
-
NOTE: Sequence numbers are unsigned, and must be compared using
Long.compareUnsigned(long, long)
- getSeqno() - Method in class com.couchbase.client.dcp.highlevel.StreamOffset
-
NOTE: Sequence numbers are unsigned, and must be compared using
Long.compareUnsigned(long, long)
- getSeqno() - Method in class com.couchbase.client.dcp.message.DcpSystemEvent
- getSeqno() - Method in class com.couchbase.client.dcp.state.FailoverLogEntry
- getSeqno(ByteBuf) - Static method in class com.couchbase.client.dcp.message.DcpSeqnoAdvancedRequest
- getSeqno(ByteBuf) - Static method in class com.couchbase.client.dcp.message.DcpSystemEventRequest
- getSeqnos() - Method in class com.couchbase.client.dcp.Client
-
Get the current sequence numbers from all partitions.
- getSeqnos() - Method in class com.couchbase.client.dcp.conductor.Conductor
- getSeqnos() - Method in class com.couchbase.client.dcp.conductor.DcpChannel
-
Returns all seqnos for all vbuckets on that channel.
- getServerVersion(Channel) - Static method in class com.couchbase.client.dcp.transport.netty.DcpConnectHandler
-
Returns the Couchbase Server version associated with the given channel.
- getServiceForName(String) - Method in enum class com.couchbase.client.dcp.core.config.PortSelector
-
Given the name of a Couchbase service as it appears in the global/bucket config JSON, return the associated ServiceType, or empty if the name is unrecognized or refers to an irrelevant transport.
- getShortOpcodeName(int) - Static method in enum class com.couchbase.client.dcp.message.MessageUtil
- getShortOpcodeName(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.MessageUtil
- getSnapshot() - Method in class com.couchbase.client.dcp.highlevel.StreamOffset
- getSnapshot() - Method in class com.couchbase.client.dcp.state.PartitionState
- getSnapshotEndSeqno() - Method in class com.couchbase.client.dcp.state.PartitionState
-
Returns the current snapshot end sequence number.
- getSnapshotStartSeqno() - Method in class com.couchbase.client.dcp.state.PartitionState
-
Returns the current snapshot start sequence number.
- getStartSeqno() - Method in class com.couchbase.client.dcp.highlevel.SnapshotMarker
-
NOTE: Sequence numbers are unsigned, and must be compared using
Long.compareUnsigned(long, long)
- getStartSeqno() - Method in class com.couchbase.client.dcp.state.PartitionState
-
Returns the current start sequence number.
- getStatus(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.MessageUtil
-
Deprecated.in favor of
MessageUtil.getResponseStatus(ByteBuf)
- getTimestamp() - Method in class com.couchbase.client.dcp.highlevel.DocumentChange
-
Returns the time the change occurred.
- getTracingToken() - Method in class com.couchbase.client.dcp.highlevel.DocumentChange
-
Returns an opaque tracing token that uniquely identifies this change within the current run of the JVM.
- getType() - Method in class com.couchbase.client.dcp.message.DcpSystemEvent
- getUsername() - Method in class com.couchbase.client.dcp.Credentials
- getUuid() - Method in class com.couchbase.client.dcp.state.FailoverLogEntry
- getVbucket() - Method in class com.couchbase.client.dcp.highlevel.DocumentChange
- getVbucket() - Method in class com.couchbase.client.dcp.highlevel.FailoverLog
- getVbucket() - Method in interface com.couchbase.client.dcp.highlevel.internal.DatabaseChangeEvent
-
Returns the id of the virtual bucket associated with this event, or -1 if the event is not associated with a specific virtual bucket.
- getVbucket() - Method in class com.couchbase.client.dcp.highlevel.Rollback
- getVbucket() - Method in class com.couchbase.client.dcp.highlevel.SeqnoAdvanced
- getVbucket() - Method in class com.couchbase.client.dcp.highlevel.SnapshotDetails
- getVbucket() - Method in class com.couchbase.client.dcp.highlevel.StreamEnd
- getVbucket() - Method in class com.couchbase.client.dcp.highlevel.StreamFailure
-
Returns the partition that experience the failure, or -1 if the failure is not specific to a partition.
- getVbucket() - Method in class com.couchbase.client.dcp.message.DcpSystemEvent
- getVbucket(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.MessageUtil
- getVbuuid() - Method in class com.couchbase.client.dcp.highlevel.StreamOffset
- getVersion() - Method in class com.couchbase.client.dcp.message.DcpSystemEvent
- getVersion(ByteBuf) - Static method in class com.couchbase.client.dcp.message.DcpSystemEventRequest
- getXattrs() - Method in class com.couchbase.client.dcp.highlevel.DocumentChange
-
Returns the document's extended attributes (XATTRS) as a map.
- globalConfig() - Method in class com.couchbase.client.dcp.core.config.CouchbaseBucketConfig
- gracefulShutdown() - Method in class com.couchbase.client.dcp.highlevel.internal.AsyncEventDispatcher
-
Allows the listener to finish processing the current event and then starts terminating the dispatch thread.
- gracefulShutdown() - Method in interface com.couchbase.client.dcp.highlevel.internal.EventDispatcher
- gracefulShutdown() - Method in class com.couchbase.client.dcp.highlevel.internal.ImmediateEventDispatcher
H
- handle(Callback[]) - Method in class com.couchbase.client.dcp.transport.netty.AuthHandler
-
Handles the SASL defined callbacks to set user and password (the
CallbackHandler
interface). - handleServerRequest(ChannelHandlerContext, ByteBuf, BucketConfigSink) - Static method in class com.couchbase.client.dcp.message.ServerRequest
- HandshakeDeadlineEvent - Class in com.couchbase.client.dcp.transport.netty
-
A user event indicating the connection should be failed if the handshake is not yet complete.
- HandshakeDeadlineEvent() - Constructor for class com.couchbase.client.dcp.transport.netty.HandshakeDeadlineEvent
- HandshakeTimeoutHandler - Class in com.couchbase.client.dcp.transport.netty
-
Collaborates with
ConnectInterceptingHandler
to fail the connection if the handshake takes too long. - HandshakeTimeoutHandler(long, TimeUnit) - Constructor for class com.couchbase.client.dcp.transport.netty.HandshakeTimeoutHandler
- has(ServiceType) - Method in class com.couchbase.client.dcp.core.config.NodeInfo
- hasCapability(BucketCapability) - Method in class com.couchbase.client.dcp.core.config.CouchbaseBucketConfig
- hasCapability(ClusterCapability) - Method in class com.couchbase.client.dcp.core.config.ClusterConfig
- hasCapability(ClusterCapability) - Method in class com.couchbase.client.dcp.core.config.CouchbaseBucketConfig
- hashCode() - Method in class com.couchbase.client.dcp.conductor.DcpChannel
- hashCode() - Method in class com.couchbase.client.dcp.config.HostAndPort
- hashCode() - Method in class com.couchbase.client.dcp.core.config.ConfigRevision
- hashCode() - Method in class com.couchbase.client.dcp.core.config.NodeIdentifier
- hashCode() - Method in class com.couchbase.client.dcp.core.config.NodeInfo
- hashCode() - Method in class com.couchbase.client.dcp.core.env.NetworkResolution
- hashCode() - Method in class com.couchbase.client.dcp.core.env.SeedNode
- hashCode() - Method in class com.couchbase.client.dcp.highlevel.SnapshotMarker
- hashCode() - Method in class com.couchbase.client.dcp.highlevel.StreamOffset
- hashCode() - Method in class com.couchbase.client.dcp.message.PartitionAndSeqno
- hashCode() - Method in class com.couchbase.client.dcp.message.ResponseStatus
- hashCode() - Method in class com.couchbase.client.dcp.message.StreamEndReason
- hashCode() - Method in class com.couchbase.client.dcp.state.FailoverLogEntry
- hashCode() - Method in class com.couchbase.client.dcp.util.PartitionSet
- hashCode() - Method in class com.couchbase.client.dcp.util.Version
- hasPrimaryPartitionsOnNode(String) - Method in class com.couchbase.client.dcp.core.config.CouchbaseBucketConfig
-
Deprecated.This check is not robust in a world where multiple nodes can share the same host. A safer approach would be to consider the KV port as well.
- HEADER_SIZE - Static variable in enum class com.couchbase.client.dcp.message.MessageUtil
- HELLO_OPCODE - Static variable in enum class com.couchbase.client.dcp.message.MessageUtil
- HelloFeature - Enum Class in com.couchbase.client.dcp.message
- HelloRequest - Enum Class in com.couchbase.client.dcp.message
- HISTORY - Enum constant in enum class com.couchbase.client.dcp.message.SnapshotMarkerFlag
- host() - Method in class com.couchbase.client.dcp.config.HostAndPort
- host() - Method in class com.couchbase.client.dcp.core.config.NodeInfo
- HostAndPort - Class in com.couchbase.client.dcp.config
-
A host (hostname or IP address) and a port number.
- HostAndPort(String, int) - Constructor for class com.couchbase.client.dcp.config.HostAndPort
- hostname() - Method in class com.couchbase.client.dcp.config.HostAndPort
-
Deprecated.Please use
HostAndPort.host()
instead. - hostname() - Method in class com.couchbase.client.dcp.core.config.NodeInfo
-
Deprecated.Please use
NodeInfo.host()
instead. - hostnames(String...) - Method in class com.couchbase.client.dcp.Client.Builder
-
Deprecated.use
Client.Builder.seedNodes(String...)
instead. - hostnames(List<String>) - Method in class com.couchbase.client.dcp.Client.Builder
-
Deprecated.use
Client.Builder.seedNodes(Collection)
instead. - hostnameVerificationEnabled() - Method in class com.couchbase.client.dcp.SecurityConfig
-
True if TLS hostname verification is enabled, false otherwise.
- humanize(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.MessageUtil
-
Dumps the given ByteBuf in the "wire format".
I
- id() - Method in class com.couchbase.client.dcp.core.config.NodeInfo
- id() - Method in class com.couchbase.client.dcp.highlevel.internal.CollectionsManifest.CollectionInfo
- id() - Method in class com.couchbase.client.dcp.highlevel.internal.CollectionsManifest.ScopeInfo
- identityMap(CouchbaseEvent) - Static method in class com.couchbase.client.dcp.core.utils.Events
-
Takes a
CouchbaseEvent
and returns a map with event information. - IGNORE_PURGED_TOMBSTONES - Enum constant in enum class com.couchbase.client.dcp.message.StreamFlag
-
Specifies that the server should skip rollback if the client is behind the purge seqno, but the request is otherwise satisfiable (i.e.
- ILLEGAL_RANGE - Static variable in class com.couchbase.client.dcp.message.ResponseStatus
- ImmediateEventDispatcher - Class in com.couchbase.client.dcp.highlevel.internal
-
Dispatches events in the same thread that calls the dispatch method.
- ImmediateEventDispatcher(DatabaseChangeListener) - Constructor for class com.couchbase.client.dcp.highlevel.internal.ImmediateEventDispatcher
- inaccessible() - Method in class com.couchbase.client.dcp.core.config.NodeInfo
- INACCESSIBLE - Static variable in class com.couchbase.client.dcp.core.config.NodeInfo
- INCLUDE_DELETE_TIMES - Enum constant in enum class com.couchbase.client.dcp.message.OpenConnectionFlag
-
Requests that DCP_DELETION messages include metadata regarding when a document was deleted.
- INCLUDE_XATTRS - Enum constant in enum class com.couchbase.client.dcp.message.OpenConnectionFlag
-
Requests that DCP_MUTATION, DCP_DELETION and DCP_EXPIRATION (if enabled) messages should include any XATTRs associated with the Document.
- increment() - Method in class com.couchbase.client.dcp.metrics.EventCounter
-
Increments the event count.
- increment(long) - Method in class com.couchbase.client.dcp.metrics.EventCounter
-
Increases the event count by the given amount
- incrementAddChannel() - Method in class com.couchbase.client.dcp.metrics.DcpClientMetrics
- incrementBytesRead(long) - Method in class com.couchbase.client.dcp.metrics.DcpChannelMetrics
- incrementDeadConnections() - Method in class com.couchbase.client.dcp.metrics.DcpChannelMetrics
- incrementReconfigure() - Method in class com.couchbase.client.dcp.metrics.DcpClientMetrics
- incrementRemoveChannel() - Method in class com.couchbase.client.dcp.metrics.DcpClientMetrics
- INFINITY - Enum constant in enum class com.couchbase.client.dcp.StreamTo
-
Never stop streaming automatically, but manual stream stop is of course possible.
- INFO - Enum constant in enum class com.couchbase.client.dcp.metrics.LogLevel
- init(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpAddStreamRequest
- init(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpBufferAckRequest
- init(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpCloseStreamRequest
- init(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpControlRequest
-
Initialize the buffer with all the values needed.
- init(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpControlResponse
-
Initialize the buffer with all the values needed.
- init(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpFailoverLogRequest
- init(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpFailoverLogResponse
- init(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpGetPartitionSeqnosRequest
- init(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpNoopResponse
- init(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpSnapshotMarkerResponse
- init(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.SaslAuthRequest
-
Initialize the buffer with all the values needed.
- init(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.SaslListMechsRequest
-
Initialize the buffer with all the values needed.
- init(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.SaslStepRequest
-
Initialize the buffer with all the values needed.
- init(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.VersionRequest
- init(ByteBuf, int) - Static method in enum class com.couchbase.client.dcp.message.DcpAddStreamResponse
- init(ByteBuf, int, long) - Static method in enum class com.couchbase.client.dcp.message.RollbackMessage
- init(ByteBuf, DcpSetVbucketStateMessage.State) - Static method in enum class com.couchbase.client.dcp.message.DcpSetVbucketStateMessage
- init(ByteBuf, String) - Static method in enum class com.couchbase.client.dcp.message.BucketSelectRequest
- init(ByteBuf, String, Set<HelloFeature>) - Static method in enum class com.couchbase.client.dcp.message.HelloRequest
- init(ByteBuf, Set<OpenConnectionFlag>) - Static method in enum class com.couchbase.client.dcp.message.DcpOpenConnectionRequest
-
Initialize the buffer with all the values needed.
- init(ByteBuf, Set<StreamFlag>, int) - Static method in enum class com.couchbase.client.dcp.message.DcpOpenStreamRequest
-
Initialize the buffer with all the values needed.
- initChannel(Channel) - Method in class com.couchbase.client.dcp.transport.netty.DcpPipeline
-
Initializes the full pipeline with all handlers needed (some of them may remove themselves during steady state, like auth and feature negotiation).
- initializeState(StreamFrom, StreamTo) - Method in class com.couchbase.client.dcp.Client
-
Initialize the
SessionState
based on arbitrary time points. - INITIALIZING_NODE - Static variable in class com.couchbase.client.dcp.message.ResponseStatus
- initRequest(byte, ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.MessageUtil
-
Helper method to initialize a request with an opcode.
- initResponse(byte, ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.MessageUtil
-
Helper method to initialize a response with an opcode.
- INSTANCE - Static variable in class com.couchbase.client.dcp.core.utils.MinimalEventBus
- INSTANCE - Static variable in class com.couchbase.client.dcp.DefaultConnectionNameGenerator
-
A connection name generator with a default User Agent string.
- INTERNAL_ERROR - Static variable in class com.couchbase.client.dcp.message.ResponseStatus
- INTERNAL_ROLLBACK_OPCODE - Static variable in enum class com.couchbase.client.dcp.message.MessageUtil
- INVALID_ARGUMENTS - Static variable in class com.couchbase.client.dcp.message.ResponseStatus
- is(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpAddStreamRequest
- is(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpAddStreamResponse
- is(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpBufferAckRequest
- is(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpCloseStreamRequest
- is(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpCloseStreamResponse
- is(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpControlRequest
-
If the given buffer is a
DcpControlRequest
message. - is(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpControlResponse
-
If the given buffer is a
DcpControlResponse
message. - is(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpDeletionMessage
- is(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpExpirationMessage
- is(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpFailoverLogRequest
- is(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpFailoverLogResponse
- is(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpFlushRequest
- is(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpGetPartitionSeqnosRequest
- is(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpGetPartitionSeqnosResponse
- is(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpMutationMessage
- is(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpNoopRequest
- is(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpNoopResponse
- is(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpOpenConnectionRequest
-
If the given buffer is a
DcpOpenConnectionRequest
message. - is(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpOpenConnectionResponse
-
If the given buffer is a
DcpOpenConnectionResponse
message. - is(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpOpenStreamRequest
-
If the given buffer is a
DcpOpenStreamRequest
message. - is(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpOpenStreamResponse
- is(ByteBuf) - Static method in class com.couchbase.client.dcp.message.DcpSeqnoAdvancedRequest
- is(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpSetVbucketStateMessage
- is(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpSnapshotMarkerRequest
- is(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpSnapshotMarkerResponse
- is(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpStreamEndMessage
- is(ByteBuf) - Static method in class com.couchbase.client.dcp.message.DcpSystemEventRequest
- is(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.RollbackMessage
- is(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.SaslAuthRequest
-
If the given buffer is a
SaslAuthRequest
message. - is(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.SaslAuthResponse
-
If the given buffer is a
SaslAuthResponse
message. - is(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.SaslListMechsRequest
-
If the given buffer is a
SaslListMechsRequest
message. - is(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.SaslListMechsResponse
-
If the given buffer is a
SaslListMechsResponse
message. - is(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.SaslStepRequest
-
If the given buffer is a
SaslStepRequest
message. - is(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.SaslStepResponse
-
If the given buffer is a
SaslStepResponse
message. - isAtEnd() - Method in class com.couchbase.client.dcp.state.PartitionState
-
Check if the current partition is at the end (start >= end seqno).
- isAtEnd() - Method in class com.couchbase.client.dcp.state.SessionState
-
Check if the current sequence numbers for all partitions are >= the ones set as end.
- isAtLeast(Version) - Method in class com.couchbase.client.dcp.util.Version
- isComplete(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.MessageUtil
-
Returns true if message can be processed and false if more data is needed.
- isDueToExpiration() - Method in class com.couchbase.client.dcp.highlevel.Deletion
- isEnabled(Channel) - Method in enum class com.couchbase.client.dcp.message.HelloFeature
- isEnabled(ChannelHandlerContext) - Method in enum class com.couchbase.client.dcp.message.HelloFeature
- isEnabled(Logger) - Method in enum class com.couchbase.client.dcp.metrics.LogLevel
- isEnabled(Marker, Logger) - Method in enum class com.couchbase.client.dcp.metrics.LogLevel
- isJson() - Method in class com.couchbase.client.dcp.highlevel.Mutation
- isMutation() - Method in class com.couchbase.client.dcp.highlevel.DocumentChange
- isNullOrEmpty(String) - Static method in class com.couchbase.client.dcp.core.utils.CbCollections
- isNullOrEmpty(Collection<?>) - Static method in class com.couchbase.client.dcp.core.utils.CbCollections
- isNullOrEmpty(Map<?, ?>) - Static method in class com.couchbase.client.dcp.core.utils.CbCollections
- isOptional() - Method in class com.couchbase.client.dcp.config.Control
- isServerRequest(ByteBuf) - Static method in class com.couchbase.client.dcp.message.ServerRequest
- isSet(int) - Method in enum class com.couchbase.client.dcp.message.OpenConnectionFlag
- isSet(int) - Method in enum class com.couchbase.client.dcp.message.SnapshotMarkerFlag
- isSet(int) - Method in enum class com.couchbase.client.dcp.message.StreamFlag
- isShutdown() - Method in class com.couchbase.client.dcp.conductor.DcpChannel
- isShutdown() - Method in class com.couchbase.client.dcp.core.env.resources.NoOpShutdownHook
- isShutdown() - Method in interface com.couchbase.client.dcp.core.env.resources.ShutdownHook
- isSnappyCompressed(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.MessageUtil
- isState(S) - Method in class com.couchbase.client.dcp.core.state.AbstractStateMachine
- isState(S) - Method in interface com.couchbase.client.dcp.core.state.Stateful
-
Check if the given state is the same as the current one.
- isSuccess() - Method in class com.couchbase.client.dcp.message.ResponseStatus
- isTemporary() - Method in class com.couchbase.client.dcp.message.ResponseStatus
- ITEM_NOT_STORED - Static variable in class com.couchbase.client.dcp.message.ResponseStatus
J
- JacksonHelper - Class in com.couchbase.client.dcp.core.utils
- JacksonHelper() - Constructor for class com.couchbase.client.dcp.core.utils.JacksonHelper
- JSON - Enum constant in enum class com.couchbase.client.dcp.message.DataType
- JSON - Enum constant in enum class com.couchbase.client.dcp.message.HelloFeature
- JSON - Enum constant in enum class com.couchbase.client.dcp.state.StateFormat
K
- key() - Method in class com.couchbase.client.dcp.highlevel.internal.CollectionIdAndKey
- key(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpDeletionMessage
-
Deprecated.This method parses the key incorrectly if collections are enabled. Please use
MessageUtil.getCollectionIdAndKey(ByteBuf, boolean)
instead. - key(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpExpirationMessage
-
Deprecated.This method parses the key incorrectly if collections are enabled. Please use
MessageUtil.getCollectionIdAndKey(ByteBuf, boolean)
instead. - key(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpMutationMessage
-
Deprecated.This method parses the key incorrectly if collections are enabled. Please use
MessageUtil.getCollectionIdAndKey(ByteBuf, boolean)
instead. - key(String, ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpControlRequest
- key(String, ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpControlResponse
- KEY_EXISTS - Static variable in class com.couchbase.client.dcp.message.ResponseStatus
- KEY_LENGTH_OFFSET - Static variable in enum class com.couchbase.client.dcp.message.MessageUtil
- KEY_NOT_FOUND - Static variable in class com.couchbase.client.dcp.message.ResponseStatus
- KeyExtractor - Interface in com.couchbase.client.dcp.highlevel.internal
-
Knows how to parse the collection ID out of a message's key field.
- keyString(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpDeletionMessage
-
Deprecated.This method parses the key incorrectly if collections are enabled. Please use
MessageUtil.getCollectionIdAndKey(ByteBuf, boolean)
instead. - keyString(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpExpirationMessage
-
Deprecated.This method parses the key incorrectly if collections are enabled. Please use
MessageUtil.getCollectionIdAndKey(ByteBuf, boolean)
instead. - keyString(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpMutationMessage
-
Deprecated.This method parses the key incorrectly if collections are enabled. Please use
MessageUtil.getCollectionIdAndKey(ByteBuf, boolean)
instead. - keyString(ByteBuf, Charset) - Static method in enum class com.couchbase.client.dcp.message.DcpDeletionMessage
-
Deprecated.This method parses the key incorrectly if collections are enabled. Please use
MessageUtil.getCollectionIdAndKey(ByteBuf, boolean)
instead. - keyString(ByteBuf, Charset) - Static method in enum class com.couchbase.client.dcp.message.DcpExpirationMessage
-
Deprecated.This method parses the key incorrectly if collections are enabled. Please use
MessageUtil.getCollectionIdAndKey(ByteBuf, boolean)
instead. - keyString(ByteBuf, Charset) - Static method in enum class com.couchbase.client.dcp.message.DcpMutationMessage
-
Deprecated.This method parses the key incorrectly if collections are enabled. Please use
MessageUtil.getCollectionIdAndKey(ByteBuf, boolean)
instead. - KV - Enum constant in enum class com.couchbase.client.dcp.core.service.ServiceType
-
Key/Value type operations.
- kvPort() - Method in class com.couchbase.client.dcp.core.env.SeedNode
-
If present, the kv port.
L
- LATEST - Enum constant in enum class com.couchbase.client.dcp.message.StreamFlag
-
Specifies that the server should stream all mutations up to the current sequence number for that VBucket.
- length() - Method in class com.couchbase.client.dcp.util.AtomicBooleanArray
- lessThanUnsigned(long, long) - Static method in class com.couchbase.client.dcp.util.MathUtils
-
Compares two numbers as unsigned 64-bit integers.
- LifecycleState - Enum Class in com.couchbase.client.dcp.core.state
-
**Represents common lifecycle states of components.**
- linear(TimeUnit) - Static method in class com.couchbase.client.dcp.core.time.Delay
-
Creates a new
LinearDelay
with no bounds and default factor. - linear(TimeUnit, long) - Static method in class com.couchbase.client.dcp.core.time.Delay
-
Creates a new
LinearDelay
with a custom upper boundary and the default factor. - linear(TimeUnit, long, long) - Static method in class com.couchbase.client.dcp.core.time.Delay
-
Creates a new
LinearDelay
with a custom boundaries and the default factor. - linear(TimeUnit, long, long, long) - Static method in class com.couchbase.client.dcp.core.time.Delay
-
Creates a new
LinearDelay
with a custom boundaries and factor. - LinearDelay - Class in com.couchbase.client.dcp.core.time
-
Delay which increases linearly for every attempt.
- listCopyOf(Collection<? extends E>) - Static method in class com.couchbase.client.dcp.core.utils.CbCollections
-
Backport of
List.copyOf
. - listener(DatabaseChangeListener, FlowControlMode) - Method in class com.couchbase.client.dcp.Client
-
Registers an event listener that will be invoked in a dedicated thread.
- listOf(T...) - Static method in class com.couchbase.client.dcp.core.utils.CbCollections
-
Returns an unmodifiable list containing the given items.
- LOCALHOST - Static variable in class com.couchbase.client.dcp.core.env.SeedNode
-
Seed node set pointing to localhost with default ports.
- lockTime(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpMutationMessage
- log(Logger, String) - Method in enum class com.couchbase.client.dcp.metrics.LogLevel
- log(Logger, String, Object) - Method in enum class com.couchbase.client.dcp.metrics.LogLevel
- log(Logger, String, Object...) - Method in enum class com.couchbase.client.dcp.metrics.LogLevel
- log(Logger, String, Object, Object) - Method in enum class com.couchbase.client.dcp.metrics.LogLevel
- log(Logger, String, Throwable) - Method in enum class com.couchbase.client.dcp.metrics.LogLevel
- log(Marker, Logger, String) - Method in enum class com.couchbase.client.dcp.metrics.LogLevel
- log(Marker, Logger, String, Object) - Method in enum class com.couchbase.client.dcp.metrics.LogLevel
- log(Marker, Logger, String, Object...) - Method in enum class com.couchbase.client.dcp.metrics.LogLevel
- log(Marker, Logger, String, Object, Object) - Method in enum class com.couchbase.client.dcp.metrics.LogLevel
- log(Marker, Logger, String, Throwable) - Method in enum class com.couchbase.client.dcp.metrics.LogLevel
- LoggingTracer - Class in com.couchbase.client.dcp.events
- LoggingTracer(LogLevel, Predicate<String>) - Constructor for class com.couchbase.client.dcp.events.LoggingTracer
- logLevel(LogLevel) - Method in class com.couchbase.client.dcp.metrics.ActionCounter.Builder
- logLevel(LogLevel) - Method in class com.couchbase.client.dcp.metrics.ActionTimer.Builder
- logLevel(LogLevel) - Method in class com.couchbase.client.dcp.metrics.EventCounter.Builder
- LogLevel - Enum Class in com.couchbase.client.dcp.metrics
- LOST_PRIVILEGES - Static variable in class com.couchbase.client.dcp.message.StreamEndReason
M
- MAGIC_INT - Static variable in enum class com.couchbase.client.dcp.message.MessageUtil
- MAGIC_REQ - Static variable in enum class com.couchbase.client.dcp.message.MessageUtil
- MAGIC_RES - Static variable in enum class com.couchbase.client.dcp.message.MessageUtil
- MAGIC_SERVER_REQ - Static variable in enum class com.couchbase.client.dcp.message.MessageUtil
- MAGIC_SERVER_RES - Static variable in enum class com.couchbase.client.dcp.message.MessageUtil
- major() - Method in class com.couchbase.client.dcp.util.Version
- MALFORMED_RESPONSE - Static variable in class com.couchbase.client.dcp.message.ResponseStatus
- MANAGER - Enum constant in enum class com.couchbase.client.dcp.core.service.ServiceType
-
The Cluster Manager service ("ns server")
- MANUAL - Enum constant in enum class com.couchbase.client.dcp.highlevel.FlowControlMode
-
In this mode, the listener is responsible for calling
DocumentChange.flowControlAck()
after eachMutation
andDeletion
event is processed. - mapCopyOf(Map<? extends K, ? extends V>) - Static method in class com.couchbase.client.dcp.core.utils.CbCollections
-
Backport of
Map.copyOf
. - mapOf() - Static method in class com.couchbase.client.dcp.core.utils.CbCollections
-
Returns an unmodifiable empty map.
- mapOf(K, V) - Static method in class com.couchbase.client.dcp.core.utils.CbCollections
-
Returns an unmodifiable map containing the given key/value pairs.
- mapOf(K, V, K, V) - Static method in class com.couchbase.client.dcp.core.utils.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.dcp.core.utils.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.dcp.core.utils.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.dcp.core.utils.CbCollections
-
Returns an unmodifiable map containing the given key/value pairs.
- markAsAbsent(PartitionInstance) - Method in class com.couchbase.client.dcp.buffer.PersistedSeqnos
- matches(SeedNode) - Method in class com.couchbase.client.dcp.core.config.NodeInfo
- MathUtils - Class in com.couchbase.client.dcp.util
-
Various math utility methods, also backports from later JDK versions.
- MathUtils() - Constructor for class com.couchbase.client.dcp.util.MathUtils
- maxTtl() - Method in class com.couchbase.client.dcp.highlevel.internal.CollectionsManifest.CollectionInfo
- MAY_CONTAIN_DUPLICATE_KEYS - Enum constant in enum class com.couchbase.client.dcp.message.SnapshotMarkerFlag
- mechanism(String, ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.SaslAuthRequest
-
Sets the selected mechanism.
- mechanism(String, ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.SaslStepRequest
-
Sets the selected mechanism.
- MEMORY - Enum constant in enum class com.couchbase.client.dcp.message.SnapshotMarkerFlag
-
Specifies that the snapshot contains in-memory items only.
- message() - Method in class com.couchbase.client.dcp.core.logging.RedactableArgument
-
The message of this redactable argument.
- MessageUtil - Enum Class in com.couchbase.client.dcp.message
- meta(Object) - Static method in class com.couchbase.client.dcp.core.logging.RedactableArgument
-
Deprecated.Please use
RedactableArgument.redactMeta(Object)
instead. - META - Enum constant in enum class com.couchbase.client.dcp.core.logging.RedactableArgument.ArgumentType
-
Metadata is logical data needed by Couchbase to store and process user data.
- meterRegistry(MeterRegistry) - Method in class com.couchbase.client.dcp.Client.Builder
-
Specifies the registry the client should use when tracking metrics.
- METRIC - Enum constant in enum class com.couchbase.client.dcp.core.event.EventType
-
The event contains some kind of metric.
- MetricsContext - Class in com.couchbase.client.dcp.metrics
- MetricsContext(MeterRegistry, String) - Constructor for class com.couchbase.client.dcp.metrics.MetricsContext
- MetricsContext(MeterRegistry, String, Tags) - Constructor for class com.couchbase.client.dcp.metrics.MetricsContext
- MinimalEventBus - Class in com.couchbase.client.dcp.core.utils
-
Simple implementation that synchronously logs events.
- MinimalEventBus() - Constructor for class com.couchbase.client.dcp.core.utils.MinimalEventBus
- minor() - Method in class com.couchbase.client.dcp.util.Version
- mitigateRollbacks(long, TimeUnit) - Method in class com.couchbase.client.dcp.Client.Builder
-
Enables rollback mitigation with the specified persistence polling interval.
- Mutation - Class in com.couchbase.client.dcp.highlevel
- Mutation(ByteBuf, CollectionsManifest.CollectionInfo, String, FlowControlReceipt, StreamOffset) - Constructor for class com.couchbase.client.dcp.highlevel.Mutation
- MUTATION_SEQNO - Enum constant in enum class com.couchbase.client.dcp.message.HelloFeature
N
- N1QL_ENHANCED_PREPARED_STATEMENTS - Enum constant in enum class com.couchbase.client.dcp.core.config.ClusterCapability
- name() - Method in class com.couchbase.client.dcp.config.Control
- name() - Method in interface com.couchbase.client.dcp.ConnectionNameGenerator
-
Generates the name for a DCP Connection.
- name() - Method in class com.couchbase.client.dcp.core.config.CouchbaseBucketConfig
- name() - Method in class com.couchbase.client.dcp.core.env.NetworkResolution
-
Returns the wire representation of the network resolution setting.
- name() - Method in class com.couchbase.client.dcp.DefaultConnectionNameGenerator
- name() - Method in class com.couchbase.client.dcp.highlevel.internal.CollectionsManifest.CollectionInfo
- name() - Method in class com.couchbase.client.dcp.highlevel.internal.CollectionsManifest.ScopeInfo
- name() - Method in class com.couchbase.client.dcp.message.StreamEndReason
- namespace() - Method in enum class com.couchbase.client.dcp.core.config.ClusterCapability
- nativeTlsEnabled() - Method in class com.couchbase.client.dcp.SecurityConfig
-
Returns whether native TLS is enabled.
- network() - Method in class com.couchbase.client.dcp.core.config.ClusterConfig
- networkResolution() - Method in class com.couchbase.client.dcp.Client.Environment
-
Returns the configured hostname selection strategy.
- networkResolution(NetworkResolution) - Method in class com.couchbase.client.dcp.Client.Builder
-
Network selection strategy for connecting to clusters whose nodes have alternate hostnames.
- NetworkResolution - Class in com.couchbase.client.dcp.core.env
- networkSelector() - Method in class com.couchbase.client.dcp.Client.Environment
- NetworkSelector - Interface in com.couchbase.client.dcp.core.config
-
Helps the config parser select the correct alternate addresses.
- NetworkSelector.AutoNetworkSelector - Class in com.couchbase.client.dcp.core.config
- newActionCounter(String) - Method in class com.couchbase.client.dcp.metrics.MetricsContext
- newActionTimer(String) - Method in class com.couchbase.client.dcp.metrics.MetricsContext
- newEnumMap(Class<K>, Map<K, V>) - Static method in class com.couchbase.client.dcp.core.utils.CbCollections
- newEnumSet(Class<T>, Iterable<T>) - Static method in class com.couchbase.client.dcp.core.utils.CbCollections
-
Like
EnumSet.copyOf(java.util.EnumSet<E>)
, but does not explode when given an empty collection. - newerThan(ConfigRevision) - Method in class com.couchbase.client.dcp.core.config.ConfigRevision
- newEventCounter(String) - Method in class com.couchbase.client.dcp.metrics.MetricsContext
- newThread(Runnable) - Method in class com.couchbase.client.dcp.highlevel.internal.SimpleThreadFactory
- NO_ACCESS - Static variable in class com.couchbase.client.dcp.message.ResponseStatus
- NO_COLLECTIONS - Static variable in interface com.couchbase.client.dcp.highlevel.internal.KeyExtractor
- NO_COLLECTIONS_MANIFEST - Static variable in class com.couchbase.client.dcp.message.ResponseStatus
- NO_END_SEQNO - Static variable in class com.couchbase.client.dcp.state.SessionState
-
The highest possible sequence number,
(2^64)-1
. - NO_ERROR - Static variable in class com.couchbase.client.dcp.message.ResponseStatus
- NO_VALUE - Enum constant in enum class com.couchbase.client.dcp.message.OpenConnectionFlag
-
Requests that DCP_MUTATION, DCP_DELETION and DCP_EXPIRATION (if enabled) messages do not include the Document.
- NO_VALUE - Enum constant in enum class com.couchbase.client.dcp.message.StreamFlag
-
Deprecated.(Removed in 5.0, use OpenConnectionFlag.NO_VALUE when opening the connection instead)
- node() - Method in class com.couchbase.client.dcp.events.FailedToAddNodeEvent
-
The address of the node
- node() - Method in class com.couchbase.client.dcp.events.FailedToRemoveNodeEvent
-
The address of the node
- nodeAtIndex(int) - Method in class com.couchbase.client.dcp.core.config.CouchbaseBucketConfig
-
Deprecated.
- NodeIdentifier - Class in com.couchbase.client.dcp.core.config
- NodeIdentifier(String, int) - Constructor for class com.couchbase.client.dcp.core.config.NodeIdentifier
- nodeIndexForActive() - Method in class com.couchbase.client.dcp.core.config.PartitionInfo
- nodeIndexForActive(int, boolean) - Method in class com.couchbase.client.dcp.core.config.CouchbaseBucketConfig
-
Deprecated.
- nodeIndexForReplica(int) - Method in class com.couchbase.client.dcp.core.config.PartitionInfo
- nodeIndexForReplica(int, int, boolean) - Method in class com.couchbase.client.dcp.core.config.CouchbaseBucketConfig
-
Deprecated.
- NodeInfo - Class in com.couchbase.client.dcp.core.config
-
Used for locating the services running on a node.
- NodeInfo(String, Map<ServiceType, Integer>) - Constructor for class com.couchbase.client.dcp.core.config.NodeInfo
- NodeInfoParser - Class in com.couchbase.client.dcp.core.config
- nodes() - Method in class com.couchbase.client.dcp.buffer.DcpBucketConfig
- nodes() - Method in class com.couchbase.client.dcp.core.config.ClusterConfig
- nodes() - Method in class com.couchbase.client.dcp.core.config.CouchbaseBucketConfig
- NODES_EXT - Enum constant in enum class com.couchbase.client.dcp.core.config.BucketCapability
- NON_NUMERIC - Static variable in class com.couchbase.client.dcp.message.ResponseStatus
- NON_TLS - Enum constant in enum class com.couchbase.client.dcp.core.config.PortSelector
- nonBlockingListener(DatabaseChangeListener) - Method in class com.couchbase.client.dcp.Client
-
Registers an event listener to be invoked in the Netty I/O event loop thread.
- NONE - Enum constant in enum class com.couchbase.client.dcp.core.logging.RedactionLevel
-
No redaction is performed, this is the default
- NONE - Enum constant in enum class com.couchbase.client.dcp.metrics.LogLevel
- NONE - Static variable in class com.couchbase.client.dcp.highlevel.SnapshotMarker
- NOOP - Static variable in interface com.couchbase.client.dcp.events.Tracer
-
An instance that ignores all events.
- NOOP_OPCODE - Static variable in enum class com.couchbase.client.dcp.message.MessageUtil
- noopEnabled() - Method in class com.couchbase.client.dcp.config.DcpControl
-
Shorthand getter to check if noops are enabled.
- noopIntervalSeconds() - Method in class com.couchbase.client.dcp.config.DcpControl
-
Shorthand getter for the NOOP interval.
- NoOpShutdownHook - Class in com.couchbase.client.dcp.core.env.resources
-
ShutdownHook
hook that does nothing and returns true. - NoOpShutdownHook() - Constructor for class com.couchbase.client.dcp.core.env.resources.NoOpShutdownHook
- NOT_CONNECTED_TO_BUCKET - Static variable in class com.couchbase.client.dcp.message.ResponseStatus
- NOT_MY_VBUCKET - Static variable in class com.couchbase.client.dcp.message.ResponseStatus
- NOT_SUPPORTED - Static variable in class com.couchbase.client.dcp.message.ResponseStatus
- NotConnectedException - Exception in com.couchbase.client.dcp.core.state
-
Thrown if the stateful component is not connected.
- NotConnectedException() - Constructor for exception com.couchbase.client.dcp.core.state.NotConnectedException
- NotConnectedException(String) - Constructor for exception com.couchbase.client.dcp.core.state.NotConnectedException
- NotConnectedException(String, Throwable) - Constructor for exception com.couchbase.client.dcp.core.state.NotConnectedException
- NotConnectedException(Throwable) - Constructor for exception com.couchbase.client.dcp.core.state.NotConnectedException
- NOTIFIER - Enum constant in enum class com.couchbase.client.dcp.message.OpenConnectionFlag
-
Deprecated.Notifier connections are deprecated with no replacement.
- NotMyVbucketException - Exception in com.couchbase.client.dcp.conductor
-
Created by daschl on 01/09/16.
- NotMyVbucketException() - Constructor for exception com.couchbase.client.dcp.conductor.NotMyVbucketException
- NotMyVbucketException(String) - Constructor for exception com.couchbase.client.dcp.conductor.NotMyVbucketException
- NotMyVbucketException(String, Throwable) - Constructor for exception com.couchbase.client.dcp.conductor.NotMyVbucketException
- NotMyVbucketException(Throwable) - Constructor for exception com.couchbase.client.dcp.conductor.NotMyVbucketException
- noValue(boolean) - Method in class com.couchbase.client.dcp.Client.Builder
-
If the argument is true, configures the client to receive only document keys and metadata (no contents).
- NOW - Enum constant in enum class com.couchbase.client.dcp.StreamFrom
-
Start "now", where now is a time point of execution in the running program where the state is gathered from each partition.
- NOW - Enum constant in enum class com.couchbase.client.dcp.StreamTo
-
Stop "now", where now is the time when the state is initialized that way.
- numberOfPartitions() - Method in class com.couchbase.client.dcp.buffer.DcpBucketConfig
- numberOfPartitions() - Method in class com.couchbase.client.dcp.conductor.Conductor
-
Returns the total number of partitions.
- numberOfPartitions() - Method in class com.couchbase.client.dcp.core.config.CouchbaseBucketConfig
- numberOfReplicas() - Method in class com.couchbase.client.dcp.buffer.DcpBucketConfig
- numberOfReplicas() - Method in class com.couchbase.client.dcp.core.config.CouchbaseBucketConfig
- numLogEntries(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpFailoverLogResponse
-
Deprecated.in favor of
DcpFailoverLogResponse.entries(ByteBuf)
- numPairs(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpGetPartitionSeqnosResponse
-
Deprecated.Please use
instead
- numPartitions() - Method in class com.couchbase.client.dcp.Client
-
Returns the number of partitions on the remote cluster.
O
- OBSERVE_SEQNO_OPCODE - Static variable in enum class com.couchbase.client.dcp.message.MessageUtil
- observeSeqno(int, long) - Method in interface com.couchbase.client.dcp.buffer.DcpOps
- observeSeqno(int, long) - Method in class com.couchbase.client.dcp.buffer.DcpOpsImpl
- OK - Static variable in class com.couchbase.client.dcp.message.StreamEndReason
- onCollectionCreated(CollectionCreated) - Method in interface com.couchbase.client.dcp.highlevel.DatabaseChangeListener
-
Called when a collection is created.
- onCollectionDropped(CollectionDropped) - Method in interface com.couchbase.client.dcp.highlevel.DatabaseChangeListener
-
Called when a collection is dropped.
- onCollectionFlushed(CollectionFlushed) - Method in interface com.couchbase.client.dcp.highlevel.DatabaseChangeListener
-
Called when a collection is flushed.
- onConnectionClose(String) - Method in class com.couchbase.client.dcp.events.LoggingTracer
- onConnectionClose(String) - Method in interface com.couchbase.client.dcp.events.Tracer
- onConnectionOpen(String) - Method in class com.couchbase.client.dcp.events.LoggingTracer
- onConnectionOpen(String) - Method in interface com.couchbase.client.dcp.events.Tracer
- onControlEvent(ByteBuf, Channel) - Method in class com.couchbase.client.dcp.events.LoggingTracer
- onControlEvent(ByteBuf, Channel) - Method in interface com.couchbase.client.dcp.events.Tracer
- onDataEvent(ByteBuf, Channel) - Method in class com.couchbase.client.dcp.events.LoggingTracer
- onDataEvent(ByteBuf, Channel) - Method in interface com.couchbase.client.dcp.events.Tracer
- onDeletion(Deletion) - Method in interface com.couchbase.client.dcp.highlevel.DatabaseChangeListener
-
Called when a Couchbase document is deleted or expired.
- onEvent(CouchbaseEvent) - Method in class com.couchbase.client.dcp.highlevel.internal.EventHandlerAdapter
- onEvent(CouchbaseEvent) - Method in interface com.couchbase.client.dcp.SystemEventHandler
-
Called every time when a system event happens that should be handled by consumers of the
Client
. - onEvent(ChannelFlowController, ByteBuf) - Method in class com.couchbase.client.dcp.buffer.StreamEventBuffer
- onEvent(ChannelFlowController, ByteBuf) - Method in class com.couchbase.client.dcp.conductor.DcpChannelControlHandler
- onEvent(ChannelFlowController, ByteBuf) - Method in interface com.couchbase.client.dcp.ControlEventHandler
-
Called every time when a control event happens that should be handled by consumers of the
Client
. - onEvent(ChannelFlowController, ByteBuf) - Method in interface com.couchbase.client.dcp.DataEventHandler
-
Called when a data event happens.
- onEvent(ChannelFlowController, ByteBuf) - Method in class com.couchbase.client.dcp.highlevel.internal.EventHandlerAdapter
- onFailoverLog(FailoverLog) - Method in interface com.couchbase.client.dcp.highlevel.DatabaseChangeListener
- onFailure(StreamFailure) - Method in interface com.couchbase.client.dcp.highlevel.DatabaseChangeListener
-
Something bad and probably unrecoverable happened.
- onMutation(Mutation) - Method in interface com.couchbase.client.dcp.highlevel.DatabaseChangeListener
-
Called when a Couchbase document is created or updated.
- onRollback(Rollback) - Method in interface com.couchbase.client.dcp.highlevel.DatabaseChangeListener
- onScopeCreated(ScopeCreated) - Method in interface com.couchbase.client.dcp.highlevel.DatabaseChangeListener
-
Called when a new scope is created.
- onScopeDropped(ScopeDropped) - Method in interface com.couchbase.client.dcp.highlevel.DatabaseChangeListener
-
Called when a scope is dropped.
- onSeqnoAdvanced(SeqnoAdvanced) - Method in interface com.couchbase.client.dcp.highlevel.DatabaseChangeListener
-
Called when a vbucket sequence number has advanced due to an event other than a document change, or for events the consumer is not subscribed to.
- onSnapshot(SnapshotDetails) - Method in interface com.couchbase.client.dcp.highlevel.DatabaseChangeListener
- onStreamEnd(StreamEndEvent) - Method in class com.couchbase.client.dcp.buffer.StreamEventBuffer
- onStreamEnd(StreamEnd) - Method in interface com.couchbase.client.dcp.highlevel.DatabaseChangeListener
-
NOTE: The DCP client will automatically attempt to reopen the stream if the reason is not
StreamEndReason.OK
. - onStreamStart(HostAndPort, int, long, long, long, long, long, Map<String, Object>) - Method in class com.couchbase.client.dcp.events.LoggingTracer
- onStreamStart(HostAndPort, int, long, long, long, long, long, Map<String, Object>) - Method in interface com.couchbase.client.dcp.events.Tracer
- onStreamStartFailed(HostAndPort, int, String) - Method in class com.couchbase.client.dcp.events.LoggingTracer
- onStreamStartFailed(HostAndPort, int, String) - Method in interface com.couchbase.client.dcp.events.Tracer
- opaque(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpAddStreamResponse
-
The opaque field contains the opaque value used by messages passing for that VBucket.
- opaque(ByteBuf, int) - Static method in enum class com.couchbase.client.dcp.message.DcpAddStreamResponse
- opaque(ByteBuf, int) - Static method in enum class com.couchbase.client.dcp.message.DcpBufferAckRequest
- opaque(ByteBuf, int) - Static method in enum class com.couchbase.client.dcp.message.DcpCloseStreamRequest
- opaque(ByteBuf, int) - Static method in enum class com.couchbase.client.dcp.message.DcpFailoverLogRequest
- opaque(ByteBuf, int) - Static method in enum class com.couchbase.client.dcp.message.DcpGetPartitionSeqnosRequest
- opaque(ByteBuf, int) - Static method in enum class com.couchbase.client.dcp.message.DcpOpenStreamRequest
- OPAQUE_OFFSET - Static variable in enum class com.couchbase.client.dcp.message.MessageUtil
- OPEN_CONNECTION_OPCODE - Static variable in enum class com.couchbase.client.dcp.message.MessageUtil
- OPEN_TRACING - Enum constant in enum class com.couchbase.client.dcp.message.HelloFeature
- OpenConnectionFlag - Enum Class in com.couchbase.client.dcp.message
- openStream(int, StreamOffset, long, CollectionsManifest, Set<StreamFlag>) - Method in class com.couchbase.client.dcp.conductor.DcpChannel
- optionalControlParam(String, Object) - Method in class com.couchbase.client.dcp.Client.Builder
-
Sets an arbitrary DCP control parameter.
- OUT_OF_MEMORY - Static variable in class com.couchbase.client.dcp.message.ResponseStatus
P
- parse(byte[], String, PortSelector, NetworkSelector) - Static method in class com.couchbase.client.dcp.core.config.CouchbaseBucketConfigParser
- parse(byte, byte[]) - Static method in class com.couchbase.client.dcp.message.ContentAndXattrs
- parse(int) - Static method in enum class com.couchbase.client.dcp.message.DataType
- parse(ObjectNode) - Static method in class com.couchbase.client.dcp.core.config.ConfigRevision
- parse(ObjectNode, PortSelector) - Static method in class com.couchbase.client.dcp.core.config.NodeInfoParser
-
Parses one element of the "nodesExt" array.
- parse(ObjectNode, String, PortSelector, NetworkSelector) - Static method in class com.couchbase.client.dcp.core.config.ClusterConfigParser
- parse(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpGetPartitionSeqnosResponse
- parse(ByteBuf) - Static method in class com.couchbase.client.dcp.message.DcpSystemEvent
- parse(String) - Static method in class com.couchbase.client.dcp.config.HostAndPort
- parse(String) - Static method in class com.couchbase.client.dcp.util.PartitionSet
- parse(String, int) - Static method in class com.couchbase.client.dcp.config.HostAndPort
- parse(List<NodeInfo>, List<Integer>) - Static method in class com.couchbase.client.dcp.core.config.PartitionInfo
- parseResponse(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.HelloRequest
- parseVersion(String) - Static method in class com.couchbase.client.dcp.util.Version
- PARTIAL - Enum constant in enum class com.couchbase.client.dcp.core.logging.RedactionLevel
-
Only user data is redacted, system and metadata are not.
- partition() - Method in interface com.couchbase.client.dcp.events.DcpFailureEvent
-
The partition (vbucket) which has caused issue, or empty if not specific to a vbucket
- partition() - Method in class com.couchbase.client.dcp.events.FailedToAddNodeEvent
- partition() - Method in class com.couchbase.client.dcp.events.FailedToMovePartitionEvent
-
The partition ID which has caused issue
- partition() - Method in class com.couchbase.client.dcp.events.FailedToRemoveNodeEvent
- partition() - Method in class com.couchbase.client.dcp.events.StreamEndEvent
- partition() - Method in class com.couchbase.client.dcp.message.PartitionAndSeqno
- partition(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpDeletionMessage
- partition(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpExpirationMessage
- partition(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpMutationMessage
- partition(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpSnapshotMarkerRequest
- PartitionAndSeqno - Class in com.couchbase.client.dcp.message
-
An immutable pair consisting of a partition and an associated sequence number.
- PartitionAndSeqno(int, long) - Constructor for class com.couchbase.client.dcp.message.PartitionAndSeqno
- PartitionInfo - Class in com.couchbase.client.dcp.core.config
-
Knows which nodes host the active and replicas for one partition.
- PartitionInfo(NodeInfo, List<NodeInfo>, List<Integer>) - Constructor for class com.couchbase.client.dcp.core.config.PartitionInfo
- PartitionMap - Class in com.couchbase.client.dcp.core.config
-
A map from partition index to info about the partition.
- PartitionMap(List<PartitionInfo>) - Constructor for class com.couchbase.client.dcp.core.config.PartitionMap
- partitions() - Method in class com.couchbase.client.dcp.core.config.CouchbaseBucketConfig
- PartitionSet - Class in com.couchbase.client.dcp.util
-
A set of partition IDs, printable in a compact human-readable form suitable for logging.
- partitionsForward() - Method in class com.couchbase.client.dcp.core.config.CouchbaseBucketConfig
- PartitionState - Class in com.couchbase.client.dcp.state
-
Represents the individual current session state for a given partition.
- PartitionState() - Constructor for class com.couchbase.client.dcp.state.PartitionState
- PasswordAuthenticator - Class in com.couchbase.client.dcp
- PasswordAuthenticator(CredentialsProvider) - Constructor for class com.couchbase.client.dcp.PasswordAuthenticator
- patch() - Method in class com.couchbase.client.dcp.util.Version
- pending(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpSetVbucketStateMessage
- PENDING - Enum constant in enum class com.couchbase.client.dcp.message.DcpSetVbucketStateMessage.State
- PENDING - Enum constant in enum class com.couchbase.client.dcp.message.VbucketState
-
Pending active.
- persistedSeqnos() - Method in class com.couchbase.client.dcp.Client.Environment
-
Returns the bookkeeper for observed seqno persistence.
- PersistedSeqnos - Class in com.couchbase.client.dcp.buffer
-
For each partition, holds the persisted sequence number and vbucket UUID for the active and replicas.
- persistencePollingEnabled() - Method in class com.couchbase.client.dcp.Client.Environment
-
Returns true if and only if rollback mitigation / persistence polling is enabled.
- PersistencePollingHandler - Class in com.couchbase.client.dcp.buffer
- PersistencePollingHandler(Client.Environment, BucketConfigSource, DcpRequestDispatcher, DcpClientMetrics) - Constructor for class com.couchbase.client.dcp.buffer.PersistencePollingHandler
- persistencePollingIntervalMillis() - Method in class com.couchbase.client.dcp.Client.Environment
-
Returns the interval between observeSeqno requests.
- poll(long, TimeUnit) - Method in interface com.couchbase.client.dcp.highlevel.internal.BlockingQueueConsumerOps
-
Retrieves and removes the head of this queue, waiting up to the specified wait time if necessary for an element to become available.
- poll(long, TimeUnit) - Method in class com.couchbase.client.dcp.highlevel.internal.DatabaseChangeConsumerOps
- poolBuffers() - Method in class com.couchbase.client.dcp.Client.Environment
-
If buffer pooling is enabled.
- poolBuffers(boolean) - Method in class com.couchbase.client.dcp.Client.Builder
-
If buffer pooling should be enabled (yes by default).
- port() - Method in class com.couchbase.client.dcp.config.HostAndPort
- port(ServiceType) - Method in class com.couchbase.client.dcp.core.config.NodeInfo
- ports() - Method in class com.couchbase.client.dcp.core.config.NodeInfo
- portSelector() - Method in class com.couchbase.client.dcp.Client.Environment
- PortSelector - Enum Class in com.couchbase.client.dcp.core.config
-
Helps the config parser select only the service ports relevant to the client's transport security mode (TLS or non-TLS).
- prefix() - Method in class com.couchbase.client.dcp.metrics.DefaultDropwizardConfig
- PRESERVE_TTL - Enum constant in enum class com.couchbase.client.dcp.message.HelloFeature
- PRETTY_TAGS - Static variable in class com.couchbase.client.dcp.metrics.DefaultDropwizardConfig
- prettyWriter() - Static method in class com.couchbase.client.dcp.core.utils.DefaultObjectMapper
- PRODUCER - Enum constant in enum class com.couchbase.client.dcp.message.OpenConnectionFlag
-
Tells the remote peer to act as a DCP producer.
- publish(Event) - Method in class com.couchbase.client.dcp.core.utils.MinimalEventBus
- publish(CouchbaseEvent) - Method in interface com.couchbase.client.dcp.core.event.EventBus
-
Publish a
CouchbaseEvent
into the bus. - publish(CouchbaseEvent) - Method in class com.couchbase.client.dcp.events.DefaultDcpEventBus
- put(DcpControl.Names, String) - Method in class com.couchbase.client.dcp.config.DcpControl
-
Sets a control parameter.
- put(String, String) - Method in class com.couchbase.client.dcp.config.DcpControl
- putOptional(String, String) - Method in class com.couchbase.client.dcp.config.DcpControl
Q
- QUERY - Enum constant in enum class com.couchbase.client.dcp.core.service.ServiceType
-
Query (N1QL) operations.
R
- read(ByteBuf) - Static method in class com.couchbase.client.dcp.core.utils.UnsignedLEB128
-
Reads an unsigned LEB128 value from the buffer.
- read(ChannelHandlerContext) - Method in class com.couchbase.client.dcp.transport.netty.AuthHandler
- reader() - Static method in class com.couchbase.client.dcp.core.utils.DefaultObjectMapper
- reader() - Static method in class com.couchbase.client.dcp.core.utils.JacksonHelper
- readObject(byte[]) - Static method in class com.couchbase.client.dcp.core.utils.JacksonHelper
- readObject(String) - Static method in class com.couchbase.client.dcp.core.utils.JacksonHelper
- readTree(byte[]) - Static method in class com.couchbase.client.dcp.core.utils.DefaultObjectMapper
- readTree(InputStream) - Static method in class com.couchbase.client.dcp.core.utils.DefaultObjectMapper
- readTree(Reader) - Static method in class com.couchbase.client.dcp.core.utils.DefaultObjectMapper
- readTree(String) - Static method in class com.couchbase.client.dcp.core.utils.DefaultObjectMapper
- readValue(byte[], int, int, TypeReference<T>) - Static method in class com.couchbase.client.dcp.core.utils.DefaultObjectMapper
- readValue(byte[], int, int, Class<T>) - Static method in class com.couchbase.client.dcp.core.utils.DefaultObjectMapper
- readValue(byte[], TypeReference<T>) - Static method in class com.couchbase.client.dcp.core.utils.DefaultObjectMapper
- readValue(byte[], Class<T>) - Static method in class com.couchbase.client.dcp.core.utils.DefaultObjectMapper
- readValue(InputStream, TypeReference<T>) - Static method in class com.couchbase.client.dcp.core.utils.DefaultObjectMapper
- readValue(InputStream, Class<T>) - Static method in class com.couchbase.client.dcp.core.utils.DefaultObjectMapper
- readValue(Reader, TypeReference<T>) - Static method in class com.couchbase.client.dcp.core.utils.DefaultObjectMapper
- readValue(Reader, Class<T>) - Static method in class com.couchbase.client.dcp.core.utils.DefaultObjectMapper
- readValue(String, TypeReference<T>) - Static method in class com.couchbase.client.dcp.core.utils.DefaultObjectMapper
- readValue(String, Class<T>) - Static method in class com.couchbase.client.dcp.core.utils.DefaultObjectMapper
- readValueAsMap(byte[]) - Static method in class com.couchbase.client.dcp.core.utils.DefaultObjectMapper
- readValueAsMap(InputStream) - Static method in class com.couchbase.client.dcp.core.utils.DefaultObjectMapper
- readValueAsMap(Reader) - Static method in class com.couchbase.client.dcp.core.utils.DefaultObjectMapper
- readValueAsMap(String) - Static method in class com.couchbase.client.dcp.core.utils.DefaultObjectMapper
- reason() - Method in class com.couchbase.client.dcp.events.StreamEndEvent
- reason(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpStreamEndMessage
- recordServerRequest(ByteBuf) - Method in class com.couchbase.client.dcp.metrics.DcpChannelMetrics
- recoverOrInitializeState(StateFormat, byte[], StreamFrom, StreamTo) - Method in class com.couchbase.client.dcp.Client
-
Recovers or initializes the
SessionState
. - recoverState(StateFormat, byte[]) - Method in class com.couchbase.client.dcp.Client
-
Initializes the
SessionState
from a previous snapshot with specific state information. - RedactableArgument - Class in com.couchbase.client.dcp.core.logging
-
Represents a logging argument which is subject to redaction.
- RedactableArgument.ArgumentType - Enum Class in com.couchbase.client.dcp.core.logging
-
The type of the redactable argument.
- RedactionLevel - Enum Class in com.couchbase.client.dcp.core.logging
-
Allows to specify the level of log redaction.
- redactMeta(Object) - Static method in class com.couchbase.client.dcp.core.logging.RedactableArgument
-
A redactable argument of meta data.
- redactSystem(Object) - Static method in class com.couchbase.client.dcp.core.logging.RedactableArgument
-
A redactable argument of system data.
- redactUser(Object) - Static method in class com.couchbase.client.dcp.core.logging.RedactableArgument
-
A redactable argument of user data.
- register(Client, EventDispatcher) - Static method in class com.couchbase.client.dcp.highlevel.internal.EventHandlerAdapter
- registerConnectionStatusGauges(Collection<DcpChannel>) - Method in class com.couchbase.client.dcp.metrics.DcpClientMetrics
-
Updates the "connection status" gauge for all channels.
- registry() - Method in class com.couchbase.client.dcp.metrics.MetricsContext
- replica(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpSetVbucketStateMessage
- REPLICA - Enum constant in enum class com.couchbase.client.dcp.message.DcpSetVbucketStateMessage.State
- REPLICA - Enum constant in enum class com.couchbase.client.dcp.message.VbucketState
-
Servicing a partition as a replica only.
- requiresFlowControlAck(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.MessageUtil
- requiresTls() - Method in interface com.couchbase.client.dcp.Authenticator
-
If this authenticator only works with encrypted connections.
- requiresTls() - Method in class com.couchbase.client.dcp.CertificateAuthenticator
- reset(int, int) - Method in class com.couchbase.client.dcp.buffer.PersistedSeqnos
- reset(DcpBucketConfig) - Method in class com.couchbase.client.dcp.buffer.PersistedSeqnos
- ResponseStatus - Class in com.couchbase.client.dcp.message
-
Response status codes and messages, as defined in the Response Status section of the Couchbase Binary Protocol specification.
- resume() - Method in class com.couchbase.client.dcp.highlevel.Rollback
-
Reopens the stream starting from the rollback point, without any snapshot information.
- resumeStreaming(Map<Integer, StreamOffset>) - Method in class com.couchbase.client.dcp.Client
- rev() - Method in class com.couchbase.client.dcp.buffer.DcpBucketConfig
- rev() - Method in class com.couchbase.client.dcp.core.config.ConfigRevision
- revision() - Method in class com.couchbase.client.dcp.core.config.ClusterConfig
- revision() - Method in class com.couchbase.client.dcp.core.config.CouchbaseBucketConfig
- revisionSeqno(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpDeletionMessage
- revisionSeqno(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpExpirationMessage
- revisionSeqno(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpMutationMessage
- Rollback - Class in com.couchbase.client.dcp.highlevel
- Rollback(Client, int, long, Consumer<Throwable>) - Constructor for class com.couchbase.client.dcp.highlevel.Rollback
- ROLLBACK - Static variable in class com.couchbase.client.dcp.message.StreamEndReason
- ROLLBACK_REQUIRED - Static variable in class com.couchbase.client.dcp.message.ResponseStatus
- rollbackAndRestartStream(int, long) - Method in class com.couchbase.client.dcp.Client
-
Helper method to rollback the partition state and stop/restart the stream.
- RollbackException - Exception in com.couchbase.client.dcp.error
-
Indicates a rollback happened, used as an internal messaging event.
- RollbackException() - Constructor for exception com.couchbase.client.dcp.error.RollbackException
- RollbackException(String) - Constructor for exception com.couchbase.client.dcp.error.RollbackException
- RollbackException(String, Throwable) - Constructor for exception com.couchbase.client.dcp.error.RollbackException
- RollbackException(Throwable) - Constructor for exception com.couchbase.client.dcp.error.RollbackException
- RollbackMessage - Enum Class in com.couchbase.client.dcp.message
- rollbackSeqno(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpOpenStreamResponse
- rollbackToPosition(int, long) - Method in class com.couchbase.client.dcp.state.SessionState
-
Helper method to rollback the given partition to the given sequence number.
- run(Runnable) - Method in class com.couchbase.client.dcp.metrics.ActionCounter
S
- SASL_AUTH_OPCODE - Static variable in enum class com.couchbase.client.dcp.message.MessageUtil
- SASL_LIST_MECHS_OPCODE - Static variable in enum class com.couchbase.client.dcp.message.MessageUtil
- SASL_STEP_OPCODE - Static variable in enum class com.couchbase.client.dcp.message.MessageUtil
- SaslAuthRequest - Enum Class in com.couchbase.client.dcp.message
- SaslAuthResponse - Enum Class in com.couchbase.client.dcp.message
- SaslListMechsRequest - Enum Class in com.couchbase.client.dcp.message
- SaslListMechsResponse - Enum Class in com.couchbase.client.dcp.message
- SaslStepRequest - Enum Class in com.couchbase.client.dcp.message
- SaslStepResponse - Enum Class in com.couchbase.client.dcp.message
- scheduledPollingTasks() - Method in class com.couchbase.client.dcp.metrics.DcpClientMetrics
- scope() - Method in enum class com.couchbase.client.dcp.core.service.ServiceType
- scope() - Method in class com.couchbase.client.dcp.highlevel.internal.CollectionsManifest.CollectionInfo
- SCOPE_CREATED - Enum constant in enum class com.couchbase.client.dcp.message.DcpSystemEvent.Type
- SCOPE_DROPPED - Enum constant in enum class com.couchbase.client.dcp.message.DcpSystemEvent.Type
- ScopeCreated - Class in com.couchbase.client.dcp.highlevel
- ScopeCreated(int, long, int, ByteBuf) - Constructor for class com.couchbase.client.dcp.highlevel.ScopeCreated
- ScopeDropped - Class in com.couchbase.client.dcp.highlevel
- ScopeDropped(int, long, int, ByteBuf) - Constructor for class com.couchbase.client.dcp.highlevel.ScopeDropped
- scopeId() - Method in class com.couchbase.client.dcp.Client.Environment
-
Scope to filter on, or empty to filter by collection IDs.
- scopeId(long) - Method in class com.couchbase.client.dcp.Client.Builder
-
Configures the client to stream only from the scope identified by the given ID.
- ScopeInfo(long, String) - Constructor for class com.couchbase.client.dcp.highlevel.internal.CollectionsManifest.ScopeInfo
- scopeName() - Method in class com.couchbase.client.dcp.Client.Environment
-
Scope to filter on, or empty to filter by collection IDs.
- scopeName(String) - Method in class com.couchbase.client.dcp.Client.Builder
-
Configures the client to stream only from the scope identified by the given ID.
- SEARCH - Enum constant in enum class com.couchbase.client.dcp.core.service.ServiceType
-
Search (CBFT) operations.
- securityConfig() - Method in class com.couchbase.client.dcp.Client.Environment
-
Returns the TLS configuration
- securityConfig(SecurityConfig) - Method in class com.couchbase.client.dcp.Client.Builder
-
Deprecated.Please use
Client.Builder.securityConfig(Consumer)
instead. - securityConfig(SecurityConfig.Builder) - Method in class com.couchbase.client.dcp.Client.Builder
-
Deprecated.Please use
Client.Builder.securityConfig(Consumer)
instead. - securityConfig(Consumer<SecurityConfig.Builder>) - Method in class com.couchbase.client.dcp.Client.Builder
- SecurityConfig - Class in com.couchbase.client.dcp
-
TLS options.
- SecurityConfig.Builder - Class in com.couchbase.client.dcp
-
This builder allows to customize the default security configuration.
- SeedNode - Class in com.couchbase.client.dcp.core.env
-
The
SeedNode
represents a combination of hostname/ip and port that is used during the SDK bootstrap. - seedNodes(String...) - Method in class com.couchbase.client.dcp.Client.Builder
-
Sets the addresses of the Couchbase Server nodes to bootstrap against.
- seedNodes(Collection<String>) - Method in class com.couchbase.client.dcp.Client.Builder
-
Sets the addresses of the Couchbase Server nodes to bootstrap against.
- SELECT_BUCKET - Enum constant in enum class com.couchbase.client.dcp.message.HelloFeature
- SELECT_BUCKET_OPCODE - Static variable in enum class com.couchbase.client.dcp.message.MessageUtil
- selectNetwork(List<Map<NetworkResolution, NodeInfo>>) - Method in class com.couchbase.client.dcp.core.config.NetworkSelector.AutoNetworkSelector
- selectNetwork(List<Map<NetworkResolution, NodeInfo>>) - Method in interface com.couchbase.client.dcp.core.config.NetworkSelector
- sendRequest(ByteBuf) - Method in interface com.couchbase.client.dcp.buffer.DcpRequestDispatcher
-
Assigns a value to the request's
opaque
field and writes the message to the channel. - sendRequest(ByteBuf) - Method in class com.couchbase.client.dcp.conductor.DcpChannel
- sendRequest(ByteBuf) - Method in class com.couchbase.client.dcp.transport.netty.DcpMessageHandler
- seqno() - Method in class com.couchbase.client.dcp.message.PartitionAndSeqno
- seqno(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.RollbackMessage
- SeqnoAdvanced - Class in com.couchbase.client.dcp.highlevel
-
Think of this as a document change event without a document.
- SeqnoAdvanced(int, StreamOffset) - Constructor for class com.couchbase.client.dcp.highlevel.SeqnoAdvanced
- seqnoEntry(ByteBuf, int) - Static method in enum class com.couchbase.client.dcp.message.DcpFailoverLogResponse
-
Deprecated.in favor of
DcpFailoverLogResponse.entries(ByteBuf)
- serialize(SessionState, JsonGenerator, SerializerProvider) - Method in class com.couchbase.client.dcp.state.json.SessionStateSerializer
- ServerRequest - Class in com.couchbase.client.dcp.message
-
Utils for handling server-initiated requests when DUPLEX mode is active
- services() - Method in class com.couchbase.client.dcp.core.config.NodeInfo
-
Deprecated.Please use
NodeInfo.ports()
instead. - ServiceScope - Enum Class in com.couchbase.client.dcp.core.service
- ServiceType - Enum Class in com.couchbase.client.dcp.core.service
-
Represents the different
ServiceType
s and how they map onto buckets. - sessionState() - Method in class com.couchbase.client.dcp.Client
-
Returns the current
SessionState
, useful for persistence and inspection. - sessionState() - Method in class com.couchbase.client.dcp.conductor.Conductor
- SessionState - Class in com.couchbase.client.dcp.state
-
Holds the state information for the current session (all partitions involved).
- SessionState() - Constructor for class com.couchbase.client.dcp.state.SessionState
-
Initializes with an empty partition state for 1024 partitions.
- SessionStateDeserializer - Class in com.couchbase.client.dcp.state.json
-
Jackson JSON deserializer for
SessionState
andPartitionState
. - SessionStateDeserializer() - Constructor for class com.couchbase.client.dcp.state.json.SessionStateDeserializer
- SessionStateSerializer - Class in com.couchbase.client.dcp.state.json
-
Jackson JSON serializer for
SessionState
andPartitionState
. - SessionStateSerializer() - Constructor for class com.couchbase.client.dcp.state.json.SessionStateSerializer
- set(int, boolean) - Method in class com.couchbase.client.dcp.util.AtomicBooleanArray
- set(int, PartitionState) - Method in class com.couchbase.client.dcp.state.SessionState
-
Accessor to set/override the current partition state, only use this if really needed.
- set(RedactionLevel) - Static method in enum class com.couchbase.client.dcp.core.logging.RedactionLevel
- SET_NOOP_INTERVAL - Enum constant in enum class com.couchbase.client.dcp.config.DcpControl.Names
-
Sets the noop interval on the Producer.
- SET_PRIORITY - Enum constant in enum class com.couchbase.client.dcp.config.DcpControl.Names
-
Sets the priority that the connection should have when sending data.
- setCollectionsManifest(CollectionsManifest) - Method in class com.couchbase.client.dcp.state.PartitionState
- setCollectionsManifestUid(long) - Method in class com.couchbase.client.dcp.state.PartitionState
- setContent(byte[], ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.MessageUtil
- setContent(ByteBuf, ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.MessageUtil
-
Sets the content payload of the buffer, updating the content length as well.
- setControlEventHandler(ControlEventHandler) - Method in class com.couchbase.client.dcp.buffer.StreamEventBuffer
- setControlEventHandler(ControlEventHandler) - Method in class com.couchbase.client.dcp.Client.Environment
-
Set/Override the control event handler.
- setCopyOf(Collection<? extends E>) - Static method in class com.couchbase.client.dcp.core.utils.CbCollections
-
Backport of
Set.copyOf
. - setDataEventHandler(DataEventHandler) - Method in class com.couchbase.client.dcp.buffer.StreamEventBuffer
- setDataEventHandler(DataEventHandler) - Method in class com.couchbase.client.dcp.Client.Environment
-
Set/Override the data event handler.
- setDataType(byte, ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.MessageUtil
- setEndSeqno(long) - Method in class com.couchbase.client.dcp.state.PartitionState
-
Allows to set the current end sequence number.
- setExtras(ByteBuf, ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.MessageUtil
- setFailoverLog(List<FailoverLogEntry>) - Method in class com.couchbase.client.dcp.state.PartitionState
-
Sets the failover log.
- setFromJson(byte[]) - Method in class com.couchbase.client.dcp.state.SessionState
-
Recovers the session state from persisted JSON.
- setKey(String, ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.MessageUtil
-
Helper method to set the key, update the key length and the content length.
- setKeyExtractor(KeyExtractor) - Method in class com.couchbase.client.dcp.state.PartitionState
- setMostRecentOpenStreamOffset(StreamOffset) - Method in class com.couchbase.client.dcp.state.PartitionState
- setOf(T...) - Static method in class com.couchbase.client.dcp.core.utils.CbCollections
-
Returns an unmodifiable set containing the given items.
- setOpaque(int, ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.MessageUtil
- setSnapshot(SnapshotMarker) - Method in class com.couchbase.client.dcp.state.PartitionState
- setSnapshotEndSeqno(long) - Method in class com.couchbase.client.dcp.state.PartitionState
-
Deprecated.in favor of
PartitionState.setSnapshot(SnapshotMarker)
- setSnapshotStartSeqno(long) - Method in class com.couchbase.client.dcp.state.PartitionState
-
Deprecated.in favor of
PartitionState.setSnapshot(SnapshotMarker)
- setStartSeqno(long) - Method in class com.couchbase.client.dcp.state.PartitionState
-
Allows to set the current start sequence number.
- setSystemEventHandler(SystemEventHandler) - Method in class com.couchbase.client.dcp.Client.Environment
-
Set/Override the control event handler.
- setToBeginningWithNoEnd(int) - Method in class com.couchbase.client.dcp.state.SessionState
-
Initializes all partition states to start at the beginning (0) with no end.
- setVbucket(int, ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.MessageUtil
- shutdown() - Method in class com.couchbase.client.dcp.Client.Environment
-
Shut down this stateful environment.
- shutdown() - Method in class com.couchbase.client.dcp.core.env.resources.NoOpShutdownHook
- shutdown() - Method in interface com.couchbase.client.dcp.core.env.resources.ShutdownHook
- ShutdownHook - Interface in com.couchbase.client.dcp.core.env.resources
-
Interface to describe shutdown behavior for a resource that can be asynchronously shut down.
- shutdownNow() - Method in class com.couchbase.client.dcp.highlevel.internal.AsyncEventDispatcher
-
Interrupts the listener and starts terminating the dispatch thread.
- shutdownNow() - Method in interface com.couchbase.client.dcp.highlevel.internal.EventDispatcher
- shutdownNow() - Method in class com.couchbase.client.dcp.highlevel.internal.ImmediateEventDispatcher
- SimpleThreadFactory - Class in com.couchbase.client.dcp.highlevel.internal
- SimpleThreadFactory(String, Consumer<Thread>) - Constructor for class com.couchbase.client.dcp.highlevel.internal.SimpleThreadFactory
- size() - Method in class com.couchbase.client.dcp.core.config.PartitionMap
-
Returns the number of partitions.
- skip(ByteBuf) - Static method in class com.couchbase.client.dcp.core.utils.UnsignedLEB128
-
Advances the buffer's reader index past the unsigned LEB128 value at the reader index.
- SNAPPY - Enum constant in enum class com.couchbase.client.dcp.core.config.BucketCapability
- SNAPPY - Enum constant in enum class com.couchbase.client.dcp.message.DataType
- SNAPPY - Enum constant in enum class com.couchbase.client.dcp.message.HelloFeature
- SnapshotDetails - Class in com.couchbase.client.dcp.highlevel
- SnapshotDetails(int, int, SnapshotMarker) - Constructor for class com.couchbase.client.dcp.highlevel.SnapshotDetails
- snapshotEndSeqno(ByteBuf, long) - Static method in enum class com.couchbase.client.dcp.message.DcpOpenStreamRequest
- SnapshotMarker - Class in com.couchbase.client.dcp.highlevel
- SnapshotMarker(long, long) - Constructor for class com.couchbase.client.dcp.highlevel.SnapshotMarker
- SnapshotMarkerFlag - Enum Class in com.couchbase.client.dcp.message
-
Flags, used in snapshot messages.
- snapshotStartSeqno(ByteBuf, long) - Static method in enum class com.couchbase.client.dcp.message.DcpOpenStreamRequest
- socketConnectTimeout() - Method in class com.couchbase.client.dcp.Client.Environment
-
Socket connect timeout in milliseconds.
- socketConnectTimeout(long) - Method in class com.couchbase.client.dcp.Client.Builder
-
Sets a custom socket connect timeout.
- SSLException - Exception in com.couchbase.client.dcp.core.endpoint
- SSLException() - Constructor for exception com.couchbase.client.dcp.core.endpoint.SSLException
- SSLException(String) - Constructor for exception com.couchbase.client.dcp.core.endpoint.SSLException
- SSLException(String, Throwable) - Constructor for exception com.couchbase.client.dcp.core.endpoint.SSLException
- SSLException(Throwable) - Constructor for exception com.couchbase.client.dcp.core.endpoint.SSLException
- SslHandlerFactory - Class in com.couchbase.client.dcp.transport.netty
-
This factory creates
SslHandler
based on a given configuration. - sslServices() - Method in class com.couchbase.client.dcp.core.config.NodeInfo
-
Deprecated.Please use
NodeInfo.ports()
instead. - STALE_AUTH_CONTEXT - Static variable in class com.couchbase.client.dcp.message.ResponseStatus
- start() - Method in class com.couchbase.client.dcp.core.utils.MinimalEventBus
- startSeqno(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpSnapshotMarkerRequest
- startSeqno(ByteBuf, long) - Static method in enum class com.couchbase.client.dcp.message.DcpOpenStreamRequest
- startStreamForPartition(int, StreamOffset, long) - Method in class com.couchbase.client.dcp.conductor.Conductor
- startStreaming() - Method in class com.couchbase.client.dcp.Client
-
Start streaming for all partitions.
- startStreaming(Short...) - Method in class com.couchbase.client.dcp.Client
-
Deprecated.Please use
Client.startStreaming(Collection)
instead. - startStreaming(Collection<Integer>) - Method in class com.couchbase.client.dcp.Client
-
Start DCP streams based on the initialized state for the given partition IDs (vbids).
- state() - Method in class com.couchbase.client.dcp.core.state.AbstractStateMachine
- state() - Method in interface com.couchbase.client.dcp.core.state.Stateful
-
Returns the current state.
- state(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpSetVbucketStateMessage
- state(ByteBuf, DcpSetVbucketStateMessage.State) - Static method in enum class com.couchbase.client.dcp.message.DcpSetVbucketStateMessage
- STATE_CHANGED - Static variable in class com.couchbase.client.dcp.message.StreamEndReason
- StateFormat - Enum Class in com.couchbase.client.dcp.state
-
Defines the support import/export formats for a
SessionState
. - Stateful<S extends Enum> - Interface in com.couchbase.client.dcp.core.state
-
A stateful component that changes its state and notifies subscribed parties.
- StaticCredentialsProvider - Class in com.couchbase.client.dcp
- StaticCredentialsProvider(String, String) - Constructor for class com.couchbase.client.dcp.StaticCredentialsProvider
- status() - Method in class com.couchbase.client.dcp.transport.netty.DcpResponse
- stop() - Method in class com.couchbase.client.dcp.conductor.Conductor
- stop(Duration) - Method in class com.couchbase.client.dcp.core.utils.MinimalEventBus
- stopStreamForPartition(int) - Method in class com.couchbase.client.dcp.conductor.Conductor
- stopStreaming(Short...) - Method in class com.couchbase.client.dcp.Client
-
Deprecated.Please use
Client.stopStreaming(Collection)
instead. - stopStreaming(Collection<Integer>) - Method in class com.couchbase.client.dcp.Client
-
Stop DCP streams for the given partition IDs (vbids).
- StreamEnd - Class in com.couchbase.client.dcp.highlevel
- StreamEnd(int, StreamEndReason) - Constructor for class com.couchbase.client.dcp.highlevel.StreamEnd
- StreamEndEvent - Class in com.couchbase.client.dcp.events
-
Event published when stream has stopped activity.
- StreamEndEvent(int, StreamEndReason) - Constructor for class com.couchbase.client.dcp.events.StreamEndEvent
- StreamEndReason - Class in com.couchbase.client.dcp.message
-
Code describing why producer decided to close the stream.
- streamEventBuffer() - Method in class com.couchbase.client.dcp.Client.Environment
-
Returns the stream event buffer used for rollback mitigation.
- StreamEventBuffer - Class in com.couchbase.client.dcp.buffer
-
When rollback mitigation / persistence polling is enabled, the stream event buffer intercepts stream events and stores them until being notified that persistence is observed.
- StreamEventBuffer(EventBus) - Constructor for class com.couchbase.client.dcp.buffer.StreamEventBuffer
- StreamFailure - Class in com.couchbase.client.dcp.highlevel
- StreamFailure(int, Throwable) - Constructor for class com.couchbase.client.dcp.highlevel.StreamFailure
- StreamFlag - Enum Class in com.couchbase.client.dcp.message
-
Flags for "open stream" and "add stream" requests.
- streamFlags() - Method in class com.couchbase.client.dcp.Client.Environment
-
Returns the flags to use when opening or adding a DCP stream.
- streamFlags(Set<StreamFlag>) - Method in class com.couchbase.client.dcp.Client.Builder
-
Sets the flags to use for all "open stream" and "add stream" requests.
- StreamFrom - Enum Class in com.couchbase.client.dcp
-
From which point in time to start the DCP stream.
- streamIsOpen(int) - Method in class com.couchbase.client.dcp.Client
-
Returns true if the stream for the given partition id is currently open.
- streamIsOpen(int) - Method in class com.couchbase.client.dcp.conductor.Conductor
- streamIsOpen(int) - Method in class com.couchbase.client.dcp.conductor.DcpChannel
- StreamOffset - Class in com.couchbase.client.dcp.highlevel
-
Position in a DCP stream for a particular vbucket.
- StreamOffset(long, long, SnapshotMarker, long) - Constructor for class com.couchbase.client.dcp.highlevel.StreamOffset
- StreamTo - Enum Class in com.couchbase.client.dcp
-
Up to which point the DCP stream should run.
- STRICT_VB_UUID - Enum constant in enum class com.couchbase.client.dcp.message.StreamFlag
-
Indicate the server to check for vb_uuid match even at start_seqno 0 before adding the stream successfully.
- SUBDOC_REPLACE_BODY_WITH_XATTR - Enum constant in enum class com.couchbase.client.dcp.core.config.BucketCapability
- SUBDOC_REVIVE_DOCUMENT - Enum constant in enum class com.couchbase.client.dcp.core.config.BucketCapability
- subscribe(Consumer<Event>) - Method in class com.couchbase.client.dcp.core.utils.MinimalEventBus
- success() - Method in class com.couchbase.client.dcp.metrics.ActionCounter
-
Increments the "success" count.
- success(long, TimeUnit) - Method in class com.couchbase.client.dcp.metrics.ActionTimer
-
Increments the "success" count.
- successLogLevel(LogLevel) - Method in class com.couchbase.client.dcp.metrics.ActionCounter.Builder
- successLogLevel(LogLevel) - Method in class com.couchbase.client.dcp.metrics.ActionTimer.Builder
- supportedMechs(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.SaslListMechsResponse
-
Extracts the supported SASL mechanisms as a string array.
- SUPPORTS_CURSOR_DROPPING - Enum constant in enum class com.couchbase.client.dcp.config.DcpControl.Names
-
Tells the server that the client can tolerate the server dropping the connection.
- swap() - Method in class com.couchbase.client.dcp.core.lang.Tuple2
-
Create a new
Tuple2
where the two values are swapped. - symbolicName() - Method in class com.couchbase.client.dcp.message.ResponseStatus
- SYNC_REPLICATION - Enum constant in enum class com.couchbase.client.dcp.message.HelloFeature
- SYNCHRONOUS_WRITE_AMBIGUOUS - Static variable in class com.couchbase.client.dcp.message.ResponseStatus
- SYNCHRONOUS_WRITE_IN_PROGRESS - Static variable in class com.couchbase.client.dcp.message.ResponseStatus
- system(Object) - Static method in class com.couchbase.client.dcp.core.logging.RedactableArgument
-
Deprecated.Please use
RedactableArgument.redactSystem(Object)
instead. - SYSTEM - Enum constant in enum class com.couchbase.client.dcp.core.event.EventType
-
The event is system state related.
- SYSTEM - Enum constant in enum class com.couchbase.client.dcp.core.logging.RedactableArgument.ArgumentType
-
System data is data from other parts of the system Couchbase interacts with over the network.
- systemEventHandler(SystemEventHandler) - Method in class com.couchbase.client.dcp.Client
-
Stores a
SystemEventHandler
to be called when control events happen. - SystemEventHandler - Interface in com.couchbase.client.dcp
-
This interface acts as a callback on the
Client.systemEventHandler(SystemEventHandler)
API that allows one to react to system events.
T
- tag(Tag) - Method in class com.couchbase.client.dcp.metrics.ActionCounter.Builder
- tag(Tag) - Method in class com.couchbase.client.dcp.metrics.ActionTimer.Builder
- tag(Tag) - Method in class com.couchbase.client.dcp.metrics.EventCounter.Builder
- tag(String, String) - Method in class com.couchbase.client.dcp.metrics.ActionCounter.Builder
- tag(String, String) - Method in class com.couchbase.client.dcp.metrics.ActionTimer.Builder
- tag(String, String) - Method in class com.couchbase.client.dcp.metrics.EventCounter.Builder
- tags(Iterable<Tag>) - Method in class com.couchbase.client.dcp.metrics.ActionCounter.Builder
- tags(Iterable<Tag>) - Method in class com.couchbase.client.dcp.metrics.ActionTimer.Builder
- tags(Iterable<Tag>) - Method in class com.couchbase.client.dcp.metrics.EventCounter.Builder
- take() - Method in interface com.couchbase.client.dcp.highlevel.internal.BlockingQueueConsumerOps
-
Retrieves and removes the head of this queue, waiting if necessary until an element becomes available.
- take() - Method in class com.couchbase.client.dcp.highlevel.internal.DatabaseChangeConsumerOps
- TAKEOVER - Enum constant in enum class com.couchbase.client.dcp.message.StreamFlag
-
Specifies that the stream should send over all remaining data to the remote node and then set the remote nodes VBucket to active state and the source nodes VBucket to dead.
- TCP_DELAY - Enum constant in enum class com.couchbase.client.dcp.message.HelloFeature
- TCP_NODELAY - Enum constant in enum class com.couchbase.client.dcp.message.HelloFeature
- TEMPORARY_FAILURE - Static variable in class com.couchbase.client.dcp.message.ResponseStatus
- TLS - Enum constant in enum class com.couchbase.client.dcp.core.config.PortSelector
- TLS - Enum constant in enum class com.couchbase.client.dcp.message.HelloFeature
- tlsEnabled() - Method in class com.couchbase.client.dcp.SecurityConfig
-
True if TLS is enabled, false otherwise.
- toList() - Method in class com.couchbase.client.dcp.util.PartitionSet
- toMap() - Method in interface com.couchbase.client.dcp.core.event.CouchbaseEvent
-
Converts the event into a map representation of simple types.
- toMap() - Method in class com.couchbase.client.dcp.events.FailedToAddNodeEvent
- toMap() - Method in class com.couchbase.client.dcp.events.FailedToMovePartitionEvent
- toMap() - Method in class com.couchbase.client.dcp.events.FailedToRemoveNodeEvent
- toMap() - Method in class com.couchbase.client.dcp.events.StreamEndEvent
- TOO_SLOW - Static variable in class com.couchbase.client.dcp.message.StreamEndReason
- toString() - Method in class com.couchbase.client.dcp.buffer.PersistedSeqnos
- toString() - Method in class com.couchbase.client.dcp.CertificateAuthenticator
- toString() - Method in class com.couchbase.client.dcp.Client.Environment
- toString() - Method in class com.couchbase.client.dcp.conductor.DcpChannel
- toString() - Method in class com.couchbase.client.dcp.config.Control
- toString() - Method in class com.couchbase.client.dcp.config.DcpControl
- toString() - Method in class com.couchbase.client.dcp.config.HostAndPort
- toString() - Method in class com.couchbase.client.dcp.core.config.ClusterConfig
- toString() - Method in class com.couchbase.client.dcp.core.config.ConfigRevision
- toString() - Method in class com.couchbase.client.dcp.core.config.CouchbaseBucketConfig
- toString() - Method in class com.couchbase.client.dcp.core.config.NodeIdentifier
- toString() - Method in class com.couchbase.client.dcp.core.config.NodeInfo
- toString() - Method in class com.couchbase.client.dcp.core.config.PartitionInfo
- toString() - Method in class com.couchbase.client.dcp.core.config.PartitionMap
- toString() - Method in class com.couchbase.client.dcp.core.env.NetworkResolution
- toString() - Method in class com.couchbase.client.dcp.core.env.SeedNode
- toString() - Method in class com.couchbase.client.dcp.core.lang.Tuple2
- toString() - Method in class com.couchbase.client.dcp.core.logging.RedactableArgument
- toString() - Method in class com.couchbase.client.dcp.core.time.ExponentialDelay
- toString() - Method in class com.couchbase.client.dcp.core.time.FixedDelay
- toString() - Method in class com.couchbase.client.dcp.core.time.LinearDelay
- toString() - Method in class com.couchbase.client.dcp.DefaultConnectionNameGenerator
- toString() - Method in class com.couchbase.client.dcp.events.FailedToAddNodeEvent
- toString() - Method in class com.couchbase.client.dcp.events.FailedToMovePartitionEvent
- toString() - Method in class com.couchbase.client.dcp.events.FailedToRemoveNodeEvent
- toString() - Method in class com.couchbase.client.dcp.events.StreamEndEvent
- toString() - Method in class com.couchbase.client.dcp.highlevel.CollectionCreated
- toString() - Method in class com.couchbase.client.dcp.highlevel.CollectionDropped
- toString() - Method in class com.couchbase.client.dcp.highlevel.CollectionFlushed
- toString() - Method in class com.couchbase.client.dcp.highlevel.DocumentChange
- toString() - Method in class com.couchbase.client.dcp.highlevel.internal.CollectionIdAndKey
- toString() - Method in class com.couchbase.client.dcp.highlevel.internal.CollectionsManifest.CollectionInfo
- toString() - Method in class com.couchbase.client.dcp.highlevel.internal.CollectionsManifest.ScopeInfo
- toString() - Method in class com.couchbase.client.dcp.highlevel.internal.CollectionsManifest
- toString() - Method in class com.couchbase.client.dcp.highlevel.ScopeCreated
- toString() - Method in class com.couchbase.client.dcp.highlevel.ScopeDropped
- toString() - Method in class com.couchbase.client.dcp.highlevel.SnapshotMarker
- toString() - Method in class com.couchbase.client.dcp.highlevel.StreamEnd
- toString() - Method in class com.couchbase.client.dcp.highlevel.StreamOffset
- toString() - Method in enum class com.couchbase.client.dcp.message.HelloFeature
- toString() - Method in class com.couchbase.client.dcp.message.PartitionAndSeqno
- toString() - Method in class com.couchbase.client.dcp.message.ResponseStatus
- toString() - Method in class com.couchbase.client.dcp.message.StreamEndReason
- toString() - Method in class com.couchbase.client.dcp.SecurityConfig
- toString() - Method in class com.couchbase.client.dcp.state.FailoverLogEntry
- toString() - Method in class com.couchbase.client.dcp.state.PartitionState
- toString() - Method in class com.couchbase.client.dcp.state.SessionState
- toString() - Method in class com.couchbase.client.dcp.util.PartitionSet
- toString() - Method in class com.couchbase.client.dcp.util.UserAgentBuilder
- toString() - Method in class com.couchbase.client.dcp.util.Version
- toString(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpDeletionMessage
- toString(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpExpirationMessage
- toString(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpFailoverLogResponse
- toString(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpMutationMessage
- toString(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpSnapshotMarkerRequest
- toString(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.RollbackMessage
- TOUCH - Enum constant in enum class com.couchbase.client.dcp.core.config.BucketCapability
- trace(LogLevel, Predicate<String>) - Method in class com.couchbase.client.dcp.Client.Builder
-
Enables fine-grained trace logging to the "com.couchbase.client.dcp.trace" category.
- TRACE - Enum constant in enum class com.couchbase.client.dcp.metrics.LogLevel
- tracer() - Method in class com.couchbase.client.dcp.Client.Environment
- Tracer - Interface in com.couchbase.client.dcp.events
-
Callback handler for various events that might occur while the DCP client is running.
- TRACING - Enum constant in enum class com.couchbase.client.dcp.message.HelloFeature
- track(Future<?>) - Method in class com.couchbase.client.dcp.metrics.ActionTimer
- track(F) - Method in class com.couchbase.client.dcp.metrics.ActionCounter
- track(F, Function<V, String>) - Method in class com.couchbase.client.dcp.metrics.ActionCounter
- trackConnect(F) - Method in class com.couchbase.client.dcp.metrics.DcpChannelMetrics
- trackDcpRequest(Promise<DcpResponse>, ByteBuf) - Method in class com.couchbase.client.dcp.metrics.DcpChannelMetrics
- trackDisconnect(F) - Method in class com.couchbase.client.dcp.metrics.DcpChannelMetrics
- transform(ArrayNode, Function<JsonNode, ? extends T>) - Static method in class com.couchbase.client.dcp.core.utils.JacksonHelper
-
Returns a list where each element is the result of applying the given transform to the corresponding element of the ArrayNode.
- transform(Iterable<T1>, Function<? super T1, ? extends T2>) - Static method in class com.couchbase.client.dcp.core.utils.CbCollections
-
Convenience method equivalent to:
- transform(Iterator<T1>, Function<? super T1, ? extends T2>) - Static method in class com.couchbase.client.dcp.core.utils.CbCollections
-
Convenience method equivalent to:
- transform(T1[], Function<? super T1, ? extends T2>) - Static method in class com.couchbase.client.dcp.core.utils.CbCollections
-
Convenience method equivalent to:
- transformValues(Map<K, V1>, Function<V1, V2>) - Static method in class com.couchbase.client.dcp.core.utils.CbCollections
- transitionState(S) - Method in class com.couchbase.client.dcp.core.state.AbstractStateMachine
-
Transition into a new state.
- trustCertificate(Path) - Method in class com.couchbase.client.dcp.SecurityConfig.Builder
-
Loads a X.509 trust certificate from the given path and uses it.
- trustCertificates() - Method in class com.couchbase.client.dcp.SecurityConfig
-
The list of trust certificates that should be used, if present.
- trustCertificates(List<X509Certificate>) - Method in class com.couchbase.client.dcp.SecurityConfig.Builder
-
Loads the given list of X.509 certificates into the trust store.
- trustManagerFactory() - Method in class com.couchbase.client.dcp.SecurityConfig
-
The currently configured trust manager factory, if present.
- trustManagerFactory(TrustManagerFactory) - Method in class com.couchbase.client.dcp.SecurityConfig.Builder
-
Allows to provide a trust manager factory directly for maximum flexibility.
- trustStore(Path, String) - Method in class com.couchbase.client.dcp.SecurityConfig.Builder
-
Loads a trust store from a file path and password and initializes the
TrustManagerFactory
. - trustStore(Path, String, String) - Method in class com.couchbase.client.dcp.SecurityConfig.Builder
-
Loads a trust store from a file path and password and initializes the
TrustManagerFactory
. - trustStore(KeyStore) - Method in class com.couchbase.client.dcp.SecurityConfig.Builder
-
Initializes the
TrustManagerFactory
with the given trust store. - Tuple - Class in com.couchbase.client.dcp.core.lang
-
Static factory class for various Tuples.
- Tuple2<T1,
T2> - Class in com.couchbase.client.dcp.core.lang -
A container for two values.
- type() - Method in interface com.couchbase.client.dcp.core.event.CouchbaseEvent
-
The type of the event.
- type() - Method in class com.couchbase.client.dcp.core.logging.RedactableArgument
-
The type of this redactable argument.
- type() - Method in class com.couchbase.client.dcp.events.FailedToAddNodeEvent
- type() - Method in class com.couchbase.client.dcp.events.FailedToMovePartitionEvent
- type() - Method in class com.couchbase.client.dcp.events.FailedToRemoveNodeEvent
- type() - Method in class com.couchbase.client.dcp.events.StreamEndEvent
U
- uninitialized() - Static method in class com.couchbase.client.dcp.buffer.PersistedSeqnos
-
Returns a new empty instance that will not be usable until it is reset.
- unit() - Method in class com.couchbase.client.dcp.core.time.Delay
- UNKNOWN_COLLECTION - Static variable in class com.couchbase.client.dcp.message.ResponseStatus
- UNKNOWN_COMMAND - Static variable in class com.couchbase.client.dcp.message.ResponseStatus
- UNKNOWN_SCOPE - Static variable in class com.couchbase.client.dcp.message.ResponseStatus
- UNORDERED_EXECUTION - Enum constant in enum class com.couchbase.client.dcp.message.HelloFeature
- UnsignedLEB128 - Class in com.couchbase.client.dcp.core.utils
-
Encodes and decodes the unsigned LEB128 (Little Endian Base 128) format.
- unsubscribe(EventSubscription) - Method in class com.couchbase.client.dcp.core.utils.MinimalEventBus
- update(int, int, long, long) - Method in class com.couchbase.client.dcp.buffer.PersistedSeqnos
- update(PartitionInstance, long, long) - Method in class com.couchbase.client.dcp.buffer.PersistedSeqnos
-
Updates the dataset with information about the given partition instance
- user(Object) - Static method in class com.couchbase.client.dcp.core.logging.RedactableArgument
-
Deprecated.Please use
RedactableArgument.redactUser(Object)
instead. - USER - Enum constant in enum class com.couchbase.client.dcp.core.logging.RedactableArgument.ArgumentType
-
User data is data that is stored into Couchbase by the application user account.
- userAgent(String, String, String...) - Method in class com.couchbase.client.dcp.Client.Builder
-
Sets the product information to include in the DCP client's User Agent string.
- UserAgentBuilder - Class in com.couchbase.client.dcp.util
-
Generates a User Agent string in accordance with https://tools.ietf.org/html/rfc7231#section-5.5.3
- UserAgentBuilder() - Constructor for class com.couchbase.client.dcp.util.UserAgentBuilder
- userEventTriggered(ChannelHandlerContext, Object) - Method in class com.couchbase.client.dcp.transport.netty.AuthHandler
- userEventTriggered(ChannelHandlerContext, Object) - Method in class com.couchbase.client.dcp.transport.netty.DcpMessageHandler
-
Close dead connection in response to idle event from IdleStateHandler.
- uuid() - Method in class com.couchbase.client.dcp.core.config.CouchbaseBucketConfig
V
- value() - Method in class com.couchbase.client.dcp.config.Control
- value() - Method in enum class com.couchbase.client.dcp.config.DcpControl.Names
- value() - Method in enum class com.couchbase.client.dcp.message.OpenConnectionFlag
- value() - Method in enum class com.couchbase.client.dcp.message.SnapshotMarkerFlag
- value() - Method in class com.couchbase.client.dcp.message.StreamEndReason
- value() - Method in enum class com.couchbase.client.dcp.message.StreamFlag
- value() - Method in enum class com.couchbase.client.dcp.message.VbucketState
- value(ByteBuf, ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpControlRequest
- value(ByteBuf, ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpControlResponse
- VALUE_TOO_LARGE - Static variable in class com.couchbase.client.dcp.message.ResponseStatus
- value1() - Method in class com.couchbase.client.dcp.core.lang.Tuple2
-
Get the first value.
- value2() - Method in class com.couchbase.client.dcp.core.lang.Tuple2
-
Get the second value.
- valueOf(int) - Static method in class com.couchbase.client.dcp.message.ResponseStatus
-
Returns the ResponseStatus with the given status code.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.config.CompressionMode
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.config.DcpControl.Names
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.core.config.BucketCapability
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.core.config.ClusterCapability
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.core.config.PortSelector
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in class com.couchbase.client.dcp.core.env.NetworkResolution
-
Provide a network resolution option which is not covered by the statics defined in this class.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.core.event.EventType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.core.logging.RedactableArgument.ArgumentType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.core.logging.RedactionLevel
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.core.service.ServiceScope
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.core.service.ServiceType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.core.state.LifecycleState
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.highlevel.FlowControlMode
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.message.BucketSelectRequest
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.message.DataType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.message.DcpAddStreamRequest
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.message.DcpAddStreamResponse
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.message.DcpBufferAckRequest
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.message.DcpCloseStreamRequest
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.message.DcpCloseStreamResponse
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.message.DcpControlRequest
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.message.DcpControlResponse
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.message.DcpDeletionMessage
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.message.DcpExpirationMessage
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.message.DcpFailoverLogRequest
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.message.DcpFailoverLogResponse
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.message.DcpFlushRequest
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.message.DcpGetPartitionSeqnosRequest
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.message.DcpGetPartitionSeqnosResponse
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.message.DcpMutationMessage
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.message.DcpNoopRequest
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.message.DcpNoopResponse
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.message.DcpOpenConnectionRequest
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.message.DcpOpenConnectionResponse
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.message.DcpOpenStreamRequest
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.message.DcpOpenStreamResponse
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.message.DcpSetVbucketStateMessage.State
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.message.DcpSetVbucketStateMessage
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.message.DcpSnapshotMarkerRequest
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.message.DcpSnapshotMarkerResponse
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.message.DcpStreamEndMessage
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.message.DcpSystemEvent.Type
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.message.HelloFeature
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.message.HelloRequest
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.message.MessageUtil
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.message.OpenConnectionFlag
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.message.RollbackMessage
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.message.SaslAuthRequest
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.message.SaslAuthResponse
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.message.SaslListMechsRequest
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.message.SaslListMechsResponse
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.message.SaslStepRequest
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.message.SaslStepResponse
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.message.SnapshotMarkerFlag
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.message.StreamFlag
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.message.VbucketState
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.message.VersionRequest
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.metrics.LogLevel
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.state.StateFormat
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.StreamFrom
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.StreamTo
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class com.couchbase.client.dcp.transport.netty.ChannelUtils
-
Returns the enum constant of this class with the specified name.
- values() - Static method in enum class com.couchbase.client.dcp.config.CompressionMode
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.config.DcpControl.Names
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.core.config.BucketCapability
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.core.config.ClusterCapability
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Method in class com.couchbase.client.dcp.core.config.PartitionMap
- values() - Static method in enum class com.couchbase.client.dcp.core.config.PortSelector
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.core.event.EventType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.core.logging.RedactableArgument.ArgumentType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.core.logging.RedactionLevel
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.core.service.ServiceScope
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.core.service.ServiceType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.core.state.LifecycleState
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.highlevel.FlowControlMode
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.message.BucketSelectRequest
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.message.DataType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.message.DcpAddStreamRequest
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.message.DcpAddStreamResponse
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.message.DcpBufferAckRequest
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.message.DcpCloseStreamRequest
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.message.DcpCloseStreamResponse
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.message.DcpControlRequest
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.message.DcpControlResponse
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.message.DcpDeletionMessage
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.message.DcpExpirationMessage
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.message.DcpFailoverLogRequest
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.message.DcpFailoverLogResponse
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.message.DcpFlushRequest
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.message.DcpGetPartitionSeqnosRequest
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.message.DcpGetPartitionSeqnosResponse
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.message.DcpMutationMessage
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.message.DcpNoopRequest
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.message.DcpNoopResponse
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.message.DcpOpenConnectionRequest
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.message.DcpOpenConnectionResponse
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.message.DcpOpenStreamRequest
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.message.DcpOpenStreamResponse
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.message.DcpSetVbucketStateMessage.State
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.message.DcpSetVbucketStateMessage
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.message.DcpSnapshotMarkerRequest
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.message.DcpSnapshotMarkerResponse
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.message.DcpStreamEndMessage
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.message.DcpSystemEvent.Type
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.message.HelloFeature
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.message.HelloRequest
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.message.MessageUtil
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.message.OpenConnectionFlag
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.message.RollbackMessage
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.message.SaslAuthRequest
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.message.SaslAuthResponse
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.message.SaslListMechsRequest
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.message.SaslListMechsResponse
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.message.SaslStepRequest
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.message.SaslStepResponse
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.message.SnapshotMarkerFlag
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.message.StreamFlag
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.message.VbucketState
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.message.VersionRequest
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.metrics.LogLevel
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.state.StateFormat
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.StreamFrom
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.StreamTo
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class com.couchbase.client.dcp.transport.netty.ChannelUtils
-
Returns an array containing the constants of this enum class, in the order they are declared.
- VALUES - Static variable in enum class com.couchbase.client.dcp.core.config.ClusterCapability
- VATTR - Enum constant in enum class com.couchbase.client.dcp.message.HelloFeature
- vbucket(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpFailoverLogResponse
- vbucket(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpOpenStreamResponse
- vbucket(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.DcpStreamEndMessage
- vbucket(ByteBuf) - Static method in enum class com.couchbase.client.dcp.message.RollbackMessage
- vbucket(ByteBuf, int) - Static method in enum class com.couchbase.client.dcp.message.DcpCloseStreamRequest
- vbucket(ByteBuf, int) - Static method in enum class com.couchbase.client.dcp.message.DcpFailoverLogRequest
- vbucket(ByteBuf, int) - Static method in enum class com.couchbase.client.dcp.message.DcpFailoverLogResponse
- VBUCKET_OFFSET - Static variable in enum class com.couchbase.client.dcp.message.MessageUtil
- vbucketState(ByteBuf, VbucketState) - Static method in enum class com.couchbase.client.dcp.message.DcpGetPartitionSeqnosRequest
- VbucketState - Enum Class in com.couchbase.client.dcp.message
- vbuuid(ByteBuf, long) - Static method in enum class com.couchbase.client.dcp.message.DcpOpenStreamRequest
- vbuuidEntry(ByteBuf, int) - Static method in enum class com.couchbase.client.dcp.message.DcpFailoverLogResponse
-
Deprecated.in favor of
DcpFailoverLogResponse.entries(ByteBuf)
- Version - Class in com.couchbase.client.dcp.util
-
Representation of a software version, up to major.minor.patch granularity.
- Version(int, int, int) - Constructor for class com.couchbase.client.dcp.util.Version
- VERSION_OPCODE - Static variable in enum class com.couchbase.client.dcp.message.MessageUtil
- VersionRequest - Enum Class in com.couchbase.client.dcp.message
- VIEWS - Enum constant in enum class com.couchbase.client.dcp.core.service.ServiceType
-
Views and Design Documents.
W
- WARN - Enum constant in enum class com.couchbase.client.dcp.metrics.LogLevel
- wireName() - Method in enum class com.couchbase.client.dcp.core.config.BucketCapability
- wireName() - Method in enum class com.couchbase.client.dcp.core.config.ClusterCapability
- withCollection(long, long, long, String, Long) - Method in class com.couchbase.client.dcp.highlevel.internal.CollectionsManifest
- withDefaultPortsIfNoneSpecified(boolean) - Method in class com.couchbase.client.dcp.core.env.SeedNode
- withKvPort(int) - Method in class com.couchbase.client.dcp.core.env.SeedNode
- withManagerPort(int) - Method in class com.couchbase.client.dcp.core.env.SeedNode
- withManifestId(long) - Method in class com.couchbase.client.dcp.highlevel.internal.CollectionsManifest
- withMissingInfoFrom(NodeInfo) - Method in class com.couchbase.client.dcp.core.config.NodeInfo
- withoutCollection(long, long) - Method in class com.couchbase.client.dcp.highlevel.internal.CollectionsManifest
- withoutScope(long, long) - Method in class com.couchbase.client.dcp.highlevel.internal.CollectionsManifest
- withPort(int) - Method in class com.couchbase.client.dcp.config.HostAndPort
- withScope(long, long, String) - Method in class com.couchbase.client.dcp.highlevel.internal.CollectionsManifest
- withTags(Tags) - Method in class com.couchbase.client.dcp.metrics.MetricsContext
- wrap(Runnable) - Method in class com.couchbase.client.dcp.metrics.ActionCounter
- wrap(Callable<T>) - Method in class com.couchbase.client.dcp.metrics.ActionCounter
- write(ByteBuf, long) - Static method in class com.couchbase.client.dcp.core.utils.UnsignedLEB128
-
Writes the unsigned LEB128 representation of the value to the buffer.
- write(ChannelHandlerContext, Object, ChannelPromise) - Method in class com.couchbase.client.dcp.transport.netty.AuthHandler
- writer() - Static method in class com.couchbase.client.dcp.core.utils.DefaultObjectMapper
- writeValue(OutputStream, Object) - Static method in class com.couchbase.client.dcp.core.utils.DefaultObjectMapper
- writeValue(Writer, Object) - Static method in class com.couchbase.client.dcp.core.utils.DefaultObjectMapper
- writeValueAsBytes(Object) - Static method in class com.couchbase.client.dcp.core.utils.DefaultObjectMapper
- writeValueAsString(Object) - Static method in class com.couchbase.client.dcp.core.utils.DefaultObjectMapper
X
- XATTR - Enum constant in enum class com.couchbase.client.dcp.core.config.BucketCapability
- XATTR - Enum constant in enum class com.couchbase.client.dcp.message.DataType
- XATTR - Enum constant in enum class com.couchbase.client.dcp.message.HelloFeature
- XATTR_INVALID_SYNTAX - Static variable in class com.couchbase.client.dcp.message.ResponseStatus
- xattrs() - Method in class com.couchbase.client.dcp.message.ContentAndXattrs
- xattrs(boolean) - Method in class com.couchbase.client.dcp.Client.Builder
-
If the argument is true, configures the client to receive extended attributes (XATTRS).
- XDCR_CHECKPOINTING - Enum constant in enum class com.couchbase.client.dcp.core.config.BucketCapability
- XERROR - Enum constant in enum class com.couchbase.client.dcp.message.HelloFeature
Z
- ZERO - Static variable in class com.couchbase.client.dcp.highlevel.StreamOffset
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
PartitionState.setFailoverLog(List)