Uses of Class
com.couchbase.client.core.io.CollectionIdentifier
-
-
Uses of CollectionIdentifier in com.couchbase.client.core.cnc.events.config
Methods in com.couchbase.client.core.cnc.events.config that return CollectionIdentifier Modifier and Type Method Description CollectionIdentifier
CollectionMapRefreshFailedEvent. collectionIdentifier()
CollectionIdentifier
CollectionMapRefreshIgnoredEvent. collectionIdentifier()
Constructors in com.couchbase.client.core.cnc.events.config with parameters of type CollectionIdentifier Constructor Description CollectionMapRefreshFailedEvent(Duration duration, Context context, CollectionIdentifier collectionIdentifier, Throwable cause, CollectionMapRefreshFailedEvent.Reason reason)
CollectionMapRefreshIgnoredEvent(Context context, CollectionIdentifier collectionIdentifier)
CollectionMapRefreshSucceededEvent(Duration duration, Context context, CollectionIdentifier collectionIdentifier, long cid)
-
Uses of CollectionIdentifier in com.couchbase.client.core.cnc.events.io
Constructors in com.couchbase.client.core.cnc.events.io with parameters of type CollectionIdentifier Constructor Description CollectionOutdatedHandledEvent(CollectionIdentifier collectionIdentifier, RetryReason retryReason, IoContext context)
-
Uses of CollectionIdentifier in com.couchbase.client.core.cnc.events.transaction
Methods in com.couchbase.client.core.cnc.events.transaction that return CollectionIdentifier Modifier and Type Method Description CollectionIdentifier
TransactionCleanupAttemptEvent. atrCollection()
Constructors in com.couchbase.client.core.cnc.events.transaction with parameters of type CollectionIdentifier Constructor Description TransactionCleanupAttemptEvent(Event.Severity severity, boolean success, boolean isRegular, List<TransactionLogEvent> logs, String attemptId, String atrId, CollectionIdentifier atrCollection, CleanupRequest req, String addlDebug)
-
Uses of CollectionIdentifier in com.couchbase.client.core.config
Methods in com.couchbase.client.core.config with parameters of type CollectionIdentifier Modifier and Type Method Description boolean
ConfigurationProvider. collectionRefreshInProgress(CollectionIdentifier identifier)
Returns true if a collection refresh is in progress for the given identifier.boolean
DefaultConfigurationProvider. collectionRefreshInProgress(CollectionIdentifier identifier)
void
ConfigurationProvider. refreshCollectionId(CollectionIdentifier identifier)
Helper method to refresh the collection map for the given collection.void
DefaultConfigurationProvider. refreshCollectionId(CollectionIdentifier identifier)
-
Uses of CollectionIdentifier in com.couchbase.client.core.error.context
Methods in com.couchbase.client.core.error.context with parameters of type CollectionIdentifier Modifier and Type Method Description static ReducedKeyValueErrorContext
ReducedKeyValueErrorContext. create(String id, CollectionIdentifier collectionIdentifier)
-
Uses of CollectionIdentifier in com.couchbase.client.core.io
Methods in com.couchbase.client.core.io that return CollectionIdentifier Modifier and Type Method Description static CollectionIdentifier
CollectionIdentifier. fromDefault(String bucket)
Methods in com.couchbase.client.core.io that return types with arguments of type CollectionIdentifier Modifier and Type Method Description Map<CollectionIdentifier,byte[]>
CollectionMap. inner()
Returns the inner map, mainly for print/debug purposes.Methods in com.couchbase.client.core.io with parameters of type CollectionIdentifier Modifier and Type Method Description byte[]
CollectionMap. get(CollectionIdentifier key)
Retrieves the collection id for the given identifier.void
CollectionMap. put(CollectionIdentifier key, byte[] value)
Stores a new collection ID with the given identifier. -
Uses of CollectionIdentifier in com.couchbase.client.core.msg.kv
Methods in com.couchbase.client.core.msg.kv that return CollectionIdentifier Modifier and Type Method Description CollectionIdentifier
BaseKeyValueRequest. collectionIdentifier()
CollectionIdentifier
KeyValueRequest. collectionIdentifier()
Constructors in com.couchbase.client.core.msg.kv with parameters of type CollectionIdentifier Constructor Description AppendRequest(Duration timeout, CoreContext ctx, CollectionIdentifier collectionIdentifier, RetryStrategy retryStrategy, String key, byte[] content, long cas, Optional<DurabilityLevel> syncReplicationType, RequestSpan span)
BaseKeyValueRequest(Duration timeout, CoreContext ctx, RetryStrategy retryStrategy, String key, CollectionIdentifier collectionIdentifier)
BaseKeyValueRequest(Duration timeout, CoreContext ctx, RetryStrategy retryStrategy, String key, CollectionIdentifier collectionIdentifier, RequestSpan span)
CarrierBucketConfigRequest(Duration timeout, CoreContext ctx, CollectionIdentifier collectionIdentifier, RetryStrategy retryStrategy, NodeIdentifier target)
DecrementRequest(Duration timeout, CoreContext ctx, CollectionIdentifier collectionIdentifier, RetryStrategy retryStrategy, String key, long delta, Optional<Long> initial, long expiry, Optional<DurabilityLevel> syncReplicationType, RequestSpan span)
GetAndLockRequest(String key, Duration timeout, CoreContext ctx, CollectionIdentifier collectionIdentifier, RetryStrategy retryStrategy, Duration lockFor, RequestSpan span)
GetAndTouchRequest(String key, Duration timeout, CoreContext ctx, CollectionIdentifier collectionIdentifier, RetryStrategy retryStrategy, long expiration, RequestSpan span)
GetCollectionIdRequest(Duration timeout, CoreContext ctx, RetryStrategy retryStrategy, CollectionIdentifier collectionIdentifier)
GetCollectionManifestRequest(Duration timeout, CoreContext ctx, RetryStrategy retryStrategy, CollectionIdentifier collectionIdentifier)
GetMetaRequest(String key, Duration timeout, CoreContext ctx, CollectionIdentifier collectionIdentifier, RetryStrategy retryStrategy, RequestSpan span)
GetRequest(String key, Duration timeout, CoreContext ctx, CollectionIdentifier collectionIdentifier, RetryStrategy retryStrategy, RequestSpan span)
IncrementRequest(Duration timeout, CoreContext ctx, CollectionIdentifier collectionIdentifier, RetryStrategy retryStrategy, String key, long delta, Optional<Long> initial, long expiration, Optional<DurabilityLevel> syncReplicationType, RequestSpan span)
InsertRequest(String key, byte[] content, long expiration, int flags, Duration timeout, CoreContext ctx, CollectionIdentifier collectionIdentifier, RetryStrategy retryStrategy, Optional<DurabilityLevel> syncReplicationType, RequestSpan span)
KvPingRequest(Duration timeout, CoreContext ctx, RetryStrategy retryStrategy, CollectionIdentifier identifier, NodeIdentifier target)
MultiObserveViaCasRequest(Duration timeout, CoreContext ctx, RetryStrategy retryStrategy, CollectionIdentifier collectionIdentifier, NodeIdentifier target, Map<byte[],Short> keys, Predicate<ObserveViaCasResponse.ObserveStatus> responsePredicate)
NoopRequest(Duration timeout, CoreContext ctx, RetryStrategy retryStrategy, CollectionIdentifier collectionIdentifier)
ObserveViaCasRequest(Duration timeout, CoreContext ctx, CollectionIdentifier collectionIdentifier, RetryStrategy retryStrategy, String key, boolean active, int replica)
ObserveViaSeqnoRequest(Duration timeout, CoreContext ctx, CollectionIdentifier collectionIdentifier, RetryStrategy retryStrategy, int replica, boolean active, long vbucketUUID, String key, RequestSpan span)
PrependRequest(Duration timeout, CoreContext ctx, CollectionIdentifier collectionIdentifier, RetryStrategy retryStrategy, String key, byte[] content, long cas, Optional<DurabilityLevel> syncReplicationType, RequestSpan span)
RemoveRequest(String key, long cas, Duration timeout, CoreContext ctx, CollectionIdentifier collectionIdentifier, RetryStrategy retryStrategy, Optional<DurabilityLevel> syncReplicationType, RequestSpan span)
ReplaceRequest(String key, byte[] content, long expiration, boolean preserveExpiry, int flags, Duration timeout, long cas, CoreContext ctx, CollectionIdentifier collectionIdentifier, RetryStrategy retryStrategy, Optional<DurabilityLevel> syncReplicationType, RequestSpan span)
ReplicaGetRequest(String key, Duration timeout, CoreContext ctx, CollectionIdentifier collectionIdentifier, RetryStrategy retryStrategy, short replica, RequestSpan span)
SubdocGetRequest(Duration timeout, CoreContext ctx, CollectionIdentifier collectionIdentifier, RetryStrategy retryStrategy, String key, byte flags, List<SubdocGetRequest.Command> commands, RequestSpan span)
SubdocMutateRequest(Duration timeout, CoreContext ctx, CollectionIdentifier collectionIdentifier, BucketConfig bucketConfig, RetryStrategy retryStrategy, String key, boolean insertDocument, boolean upsertDocument, boolean reviveDocument, boolean accessDeleted, boolean createAsDeleted, List<SubdocMutateRequest.Command> commands, long expiration, boolean preserveExpiry, long cas, Optional<DurabilityLevel> syncReplicationType, RequestSpan span)
TouchRequest(Duration timeout, CoreContext ctx, CollectionIdentifier collectionIdentifier, RetryStrategy retryStrategy, String key, long expiry, RequestSpan span)
UnlockRequest(Duration timeout, CoreContext ctx, CollectionIdentifier collectionIdentifier, RetryStrategy retryStrategy, String key, long cas, RequestSpan span)
UpsertRequest(String key, byte[] content, long expiration, boolean preserveExpiry, int flags, Duration timeout, CoreContext ctx, CollectionIdentifier collectionIdentifier, RetryStrategy retryStrategy, Optional<DurabilityLevel> syncReplicationType, RequestSpan span)
-
Uses of CollectionIdentifier in com.couchbase.client.core.service.kv
Methods in com.couchbase.client.core.service.kv that return CollectionIdentifier Modifier and Type Method Description CollectionIdentifier
ObserveContext. collectionIdentifier()
Methods in com.couchbase.client.core.service.kv with parameters of type CollectionIdentifier Modifier and Type Method Description static <R> CompletableFuture<List<CompletableFuture<R>>>
ReplicaHelper. getAllReplicasAsync(Core core, CollectionIdentifier collectionIdentifier, String documentId, Duration timeout, RetryStrategy retryStrategy, Map<String,Object> clientContext, RequestSpan parentSpan, Function<ReplicaHelper.GetReplicaResponse,R> responseMapper)
Reads from replicas or the active node based on the options and returns the results as a list of futures that might complete or fail.static Flux<ReplicaHelper.GetReplicaResponse>
ReplicaHelper. getAllReplicasReactive(Core core, CollectionIdentifier collectionIdentifier, String documentId, Duration timeout, RetryStrategy retryStrategy, Map<String,Object> clientContext, RequestSpan parentSpan)
static CompletableFuture<Stream<GetRequest>>
ReplicaHelper. getAllReplicasRequests(Core core, CollectionIdentifier collectionIdentifier, String documentId, Map<String,Object> clientContext, RetryStrategy retryStrategy, Duration timeout, RequestSpan parent)
Helper method to assemble a stream of requests to the active and all replicasstatic <R> CompletableFuture<R>
ReplicaHelper. getAnyReplicaAsync(Core core, CollectionIdentifier collectionIdentifier, String documentId, Duration timeout, RetryStrategy retryStrategy, Map<String,Object> clientContext, RequestSpan parentSpan, Function<ReplicaHelper.GetReplicaResponse,R> responseMapper)
static Mono<ReplicaHelper.GetReplicaResponse>
ReplicaHelper. getAnyReplicaReactive(Core core, CollectionIdentifier collectionIdentifier, String documentId, Duration timeout, RetryStrategy retryStrategy, Map<String,Object> clientContext, RequestSpan parentSpan)
Constructors in com.couchbase.client.core.service.kv with parameters of type CollectionIdentifier Constructor Description ObserveContext(CoreContext ctx, Observe.ObservePersistTo persistTo, Observe.ObserveReplicateTo replicateTo, Optional<MutationToken> mutationToken, long cas, CollectionIdentifier collectionIdentifier, String key, boolean remove, Duration timeout, RequestSpan parentSpan)
-
Uses of CollectionIdentifier in com.couchbase.client.core.transaction
Methods in com.couchbase.client.core.transaction that return CollectionIdentifier Modifier and Type Method Description CollectionIdentifier
CoreTransactionGetResult. collection()
Methods in com.couchbase.client.core.transaction that return types with arguments of type CollectionIdentifier Modifier and Type Method Description Optional<CollectionIdentifier>
CoreTransactionAttemptContext. atrCollection()
Methods in com.couchbase.client.core.transaction with parameters of type CollectionIdentifier Modifier and Type Method Description static CoreTransactionGetResult
CoreTransactionGetResult. createFrom(CollectionIdentifier collection, String documentId, SubdocGetResponse doc)
Mono<CoreTransactionGetResult>
CoreTransactionAttemptContext. get(CollectionIdentifier collection, String id)
Gets a document with the specifiedid
and from the specified Couchbasebucket
.Mono<CoreTransactionGetResult>
CoreTransactionAttemptContext. insert(CollectionIdentifier collection, String id, byte[] content)
Inserts a new document into the specified Couchbasecollection
.Constructors in com.couchbase.client.core.transaction with parameters of type CollectionIdentifier Constructor Description CoreTransactionGetResult(String id, byte[] content, long cas, CollectionIdentifier collection, TransactionLinks links, Optional<DocumentMetadata> documentMetadata, Optional<com.couchbase.client.core.deps.com.fasterxml.jackson.databind.JsonNode> txnMeta, Optional<String> crc32OfGet)
-
Uses of CollectionIdentifier in com.couchbase.client.core.transaction.cleanup
Methods in com.couchbase.client.core.transaction.cleanup that return CollectionIdentifier Modifier and Type Method Description CollectionIdentifier
CleanupRequest. atrCollection()
Methods in com.couchbase.client.core.transaction.cleanup that return types with arguments of type CollectionIdentifier Modifier and Type Method Description Set<CollectionIdentifier>
CoreTransactionsCleanup. cleanupSet()
Set<CollectionIdentifier>
LostCleanupDistributed. cleanupSet()
Methods in com.couchbase.client.core.transaction.cleanup with parameters of type CollectionIdentifier Modifier and Type Method Description void
CoreTransactionsCleanup. addToCleanupSet(CollectionIdentifier coll)
void
LostCleanupDistributed. addToCleanupSet(CollectionIdentifier coll)
Mono<TransactionCleanupAttemptEvent>
TransactionsCleaner. cleanupATREntry(CollectionIdentifier atrCollection, String atrId, String attemptId, ActiveTransactionRecordEntry atrEntry, boolean isRegularCleanup)
Kept purely for backwards compatibility with FIT performer.static CleanupRequest
CleanupRequest. fromAtrEntry(CollectionIdentifier atrCollection, ActiveTransactionRecordEntry atrEntry)
Mono<SubdocGetResponse>
ClientRecord. getClientRecord(CollectionIdentifier collection, SpanWrapper span)
Flux<TransactionCleanupAttemptEvent>
LostCleanupDistributed. handleATRCleanup(String bp, CollectionIdentifier atrCollection, String atrId, ActiveTransactionRecordStats stats, Duration safetyMargin, SpanWrapper pspan)
Looks at an ATR, finds any expired entries, and cleans them up.Mono<ClientRecordDetails>
ClientRecord. processClient(String clientUuid, CollectionIdentifier collection, CoreTransactionsConfig config, SpanWrapper pspan)
Method parameters in com.couchbase.client.core.transaction.cleanup with type arguments of type CollectionIdentifier Modifier and Type Method Description Flux<Void>
ClientRecord. removeClientFromClientRecord(String clientUuid, Duration timeout, Set<CollectionIdentifier> collections)
Called on shutdown to cleanly remove a client from the client-record.Flux<Void>
ClientRecord. removeClientFromClientRecord(String clientUuid, Set<CollectionIdentifier> cleanupSet)
Constructors in com.couchbase.client.core.transaction.cleanup with parameters of type CollectionIdentifier Constructor Description CleanupRequest(String attemptId, String atrId, CollectionIdentifier atrCollection, AttemptState state, List<DocRecord> stagedReplaces, List<DocRecord> stagedRemoves, List<DocRecord> stagedInserts, Duration delay, Optional<ForwardCompatibility> forwardCompatibility, long ageMillis, Optional<DurabilityLevel> durabilityLevel)
-
Uses of CollectionIdentifier in com.couchbase.client.core.transaction.components
Methods in com.couchbase.client.core.transaction.components that return CollectionIdentifier Modifier and Type Method Description CollectionIdentifier
ActiveTransactionRecords. collection()
CollectionIdentifier
TransactionLinks. collection()
Method parameters in com.couchbase.client.core.transaction.components with type arguments of type CollectionIdentifier Modifier and Type Method Description static RedactableArgument
ActiveTransactionRecordUtil. getAtrDebug(Optional<CollectionIdentifier> collection, Optional<String> atrId)
Constructors in com.couchbase.client.core.transaction.components with parameters of type CollectionIdentifier Constructor Description ActiveTransactionRecords(String id, CollectionIdentifier collection, long casInNanos, List<ActiveTransactionRecordEntry> entries, CasMode casMode)
-
Uses of CollectionIdentifier in com.couchbase.client.core.transaction.config
Methods in com.couchbase.client.core.transaction.config that return types with arguments of type CollectionIdentifier Modifier and Type Method Description Set<CollectionIdentifier>
CoreTransactionsCleanupConfig. cleanupSet()
Optional<CollectionIdentifier>
CoreMergedTransactionConfig. metadataCollection()
Optional<CollectionIdentifier>
CoreSingleQueryTransactionOptions. metadataCollection()
Optional<CollectionIdentifier>
CoreTransactionOptions. metadataCollection()
Optional<CollectionIdentifier>
CoreTransactionsConfig. metadataCollection()
Method parameters in com.couchbase.client.core.transaction.config with type arguments of type CollectionIdentifier Modifier and Type Method Description static CoreTransactionsConfig
CoreTransactionsConfig. createForSingleQueryTransactions(DurabilityLevel durabilityLevel, Duration timeout, TransactionAttemptContextFactory transactionAttemptContextFactory, Optional<CollectionIdentifier> metadataCollection)
Constructor parameters in com.couchbase.client.core.transaction.config with type arguments of type CollectionIdentifier Constructor Description CoreTransactionsCleanupConfig(boolean runLostAttemptsCleanupThread, boolean runRegularAttemptsCleanupThread, Duration cleanupWindow, Set<CollectionIdentifier> cleanupSet)
CoreTransactionsConfig(DurabilityLevel durabilityLevel, Duration timeout, CoreTransactionsCleanupConfig cleanupConfig, TransactionAttemptContextFactory attemptContextFactory, CleanerFactory cleanerFactory, ClientRecordFactory clientRecordFactory, int numAtrs, Optional<CollectionIdentifier> metadataCollection, Optional<String> scanConsistency)
-
Uses of CollectionIdentifier in com.couchbase.client.core.transaction.support
Fields in com.couchbase.client.core.transaction.support declared as CollectionIdentifier Modifier and Type Field Description CollectionIdentifier
StagedMutation. collection
Methods in com.couchbase.client.core.transaction.support with parameters of type CollectionIdentifier Modifier and Type Method Description static SpanWrapper
SpanWrapperUtil. createOp(CoreTransactionAttemptContext ctx, RequestTracer tracer, CollectionIdentifier collection, String id, String op, SpanWrapper attemptSpan)
Constructors in com.couchbase.client.core.transaction.support with parameters of type CollectionIdentifier Constructor Description StagedMutation(String operationId, String id, CollectionIdentifier collection, long cas, Optional<DocumentMetadata> documentMetadata, Optional<String> crc32, byte[] content, StagedMutationType type)
-
Uses of CollectionIdentifier in com.couchbase.client.core.transaction.util
Methods in com.couchbase.client.core.transaction.util with parameters of type CollectionIdentifier Modifier and Type Method Description static LogDeferDocId
DebugUtil. docId(CollectionIdentifier collection, String docId)
static Mono<InsertResponse>
TransactionKVHandler. insert(Core core, CollectionIdentifier collectionIdentifier, String id, byte[] transcodedContent, Duration timeout, Optional<DurabilityLevel> durabilityLevel, Map<String,Object> clientContext, SpanWrapper span)
static Mono<SubdocGetResponse>
TransactionKVHandler. lookupIn(Core core, CollectionIdentifier collectionIdentifier, String id, Duration timeout, boolean accessDeleted, Map<String,Object> clientContext, SpanWrapper span, List<SubdocGetRequest.Command> commands)
static Mono<SubdocMutateResponse>
TransactionKVHandler. mutateIn(Core core, CollectionIdentifier collectionIdentifier, String id, Duration timeout, boolean insertDocument, boolean upsertDocument, boolean reviveDocument, boolean accessDeleted, boolean createAsDeleted, long cas, Optional<DurabilityLevel> durabilityLevel, Map<String,Object> clientContext, SpanWrapper span, List<SubdocMutateRequest.Command> commands)
static Mono<SubdocMutateResponse>
TransactionKVHandler. mutateIn(Core core, CollectionIdentifier collectionIdentifier, String id, Duration timeout, boolean insertDocument, boolean upsertDocument, boolean reviveDocument, boolean accessDeleted, boolean createAsDeleted, long cas, Optional<DurabilityLevel> durabilityLevel, Map<String,Object> clientContext, SpanWrapper span, List<SubdocMutateRequest.Command> commands, CoreTransactionLogger logger)
static Mono<RemoveResponse>
TransactionKVHandler. remove(Core core, CollectionIdentifier collectionIdentifier, String id, Duration timeout, long cas, Optional<DurabilityLevel> durabilityLevel, Map<String,Object> clientContext, SpanWrapper span)
Constructors in com.couchbase.client.core.transaction.util with parameters of type CollectionIdentifier Constructor Description LogDeferDocId(CollectionIdentifier collection, String docId)
-