| Modifier and Type | Method and Description |
|---|---|
CollectionIdentifier |
CoreKeyspace.toCollectionIdentifier() |
| Modifier and Type | Method and Description |
|---|---|
static CoreKeyspace |
CoreKeyspace.from(CollectionIdentifier id) |
| Modifier and Type | Method and Description |
|---|---|
static void |
CoreKvParamValidators.validateUnlockParams(CoreCommonOptions common,
String key,
long cas,
CollectionIdentifier collectionIdentifier) |
| Modifier and Type | Method and Description |
|---|---|
CollectionIdentifier |
CollectionMapRefreshFailedEvent.collectionIdentifier() |
CollectionIdentifier |
CollectionMapRefreshIgnoredEvent.collectionIdentifier() |
| Constructor and 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) |
| Constructor and Description |
|---|
CollectionOutdatedHandledEvent(CollectionIdentifier collectionIdentifier,
RetryReason retryReason,
IoContext context) |
| Modifier and Type | Method and Description |
|---|---|
CollectionIdentifier |
TransactionCleanupAttemptEvent.atrCollection() |
| Constructor and Description |
|---|
TransactionCleanupAttemptEvent(Event.Severity severity,
boolean success,
boolean isRegular,
List<TransactionLogEvent> logs,
String attemptId,
String atrId,
CollectionIdentifier atrCollection,
CleanupRequest req,
String addlDebug) |
| Modifier and Type | Method and Description |
|---|---|
boolean |
DefaultConfigurationProvider.collectionRefreshInProgress(CollectionIdentifier identifier) |
boolean |
ConfigurationProvider.collectionRefreshInProgress(CollectionIdentifier identifier)
Returns true if a collection refresh is in progress for the given identifier.
|
void |
DefaultConfigurationProvider.refreshCollectionId(CollectionIdentifier identifier) |
void |
ConfigurationProvider.refreshCollectionId(CollectionIdentifier identifier)
Helper method to refresh the collection map for the given collection.
|
| Modifier and Type | Method and Description |
|---|---|
static ReducedKeyValueErrorContext |
ReducedKeyValueErrorContext.create(String id,
CollectionIdentifier collectionIdentifier) |
| Constructor and Description |
|---|
ReducedKeyValueErrorContext(String id,
CollectionIdentifier collectionIdentifier) |
| Modifier and Type | Method and Description |
|---|---|
static CollectionIdentifier |
CollectionIdentifier.fromDefault(String bucket) |
| Modifier and Type | Method and Description |
|---|---|
Map<CollectionIdentifier,byte[]> |
CollectionMap.inner()
Returns the inner map, mainly for print/debug purposes.
|
| Modifier and Type | Method and 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.
|
| Constructor and Description |
|---|
RangeScanOrchestrator(Core core,
CollectionIdentifier collectionIdentifier)
Creates a new
RangeScanOrchestrator which can be shared across calls. |
| Modifier and Type | Method and Description |
|---|---|
CollectionIdentifier |
KeyValueRequest.collectionIdentifier() |
CollectionIdentifier |
BaseKeyValueRequest.collectionIdentifier() |
| Modifier and Type | Method and Description |
|---|---|
static SubdocGetRequest |
SubdocGetRequest.create(Duration timeout,
CoreContext ctx,
CollectionIdentifier collectionIdentifier,
RetryStrategy retryStrategy,
String key,
byte flags,
List<CoreSubdocGetCommand> commands,
RequestSpan span) |
static ReplicaSubdocGetRequest |
ReplicaSubdocGetRequest.create(Duration timeout,
CoreContext ctx,
CollectionIdentifier collectionIdentifier,
RetryStrategy retryStrategy,
String key,
byte flags,
List<CoreSubdocGetCommand> commands,
short replica,
RequestSpan span) |
static RangeScanCreateRequest |
RangeScanCreateRequest.forRangeScan(byte[] startTerm,
CoreRangeScan rangeScan,
CoreScanOptions options,
short partition,
CoreContext ctx,
CollectionIdentifier collectionIdentifier,
Map<Short,MutationToken> consistencyMap) |
static RangeScanCreateRequest |
RangeScanCreateRequest.forSamplingScan(CoreSamplingScan samplingScan,
CoreScanOptions options,
short partition,
CoreContext ctx,
CollectionIdentifier collectionIdentifier,
Map<Short,MutationToken> consistencyMap) |
| Constructor and 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,
ConfigVersion ifNewerThan) |
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) |
PredeterminedPartitionRequest(short partition,
Duration timeout,
CoreContext ctx,
RetryStrategy retryStrategy,
String key,
CollectionIdentifier collectionIdentifier,
RequestSpan span) |
PrependRequest(Duration timeout,
CoreContext ctx,
CollectionIdentifier collectionIdentifier,
RetryStrategy retryStrategy,
String key,
byte[] content,
long cas,
Optional<DurabilityLevel> syncReplicationType,
RequestSpan span) |
RangeScanCancelRequest(CoreRangeScanId id,
CoreScanOptions options,
short partition,
CoreContext ctx,
CollectionIdentifier collectionIdentifier) |
RangeScanContinueRequest(CoreRangeScanId id,
Sinks.Many<CoreRangeScanItem> sink,
String key,
CoreScanOptions options,
short partition,
CoreContext ctx,
CollectionIdentifier collectionIdentifier) |
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,
int userFlags,
Optional<DurabilityLevel> syncReplicationType,
RequestSpan span)
Deprecated.
Please use the other constructor instead.
|
SubdocMutateRequest(Duration timeout,
CoreContext ctx,
CollectionIdentifier collectionIdentifier,
BucketConfig bucketConfig,
RetryStrategy retryStrategy,
String key,
CoreStoreSemantics storeSemantics,
boolean accessDeleted,
boolean createAsDeleted,
List<CoreSubdocMutateCommand> 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) |
| Modifier and Type | Method and Description |
|---|---|
CollectionIdentifier |
ObserveContext.collectionIdentifier() |
| Modifier and Type | Method and 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 replicas
|
static <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 <R> CompletableFuture<List<CompletableFuture<R>>> |
ReplicaHelper.lookupInAllReplicasAsync(Core core,
CollectionIdentifier collectionIdentifier,
String documentId,
List<CoreSubdocGetCommand> commands,
Duration timeout,
RetryStrategy retryStrategy,
Map<String,Object> clientContext,
RequestSpan parentSpan,
Function<CoreSubdocGetResult,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<CoreSubdocGetResult> |
ReplicaHelper.lookupInAllReplicasReactive(Core core,
CollectionIdentifier collectionIdentifier,
String documentId,
List<CoreSubdocGetCommand> commands,
Duration timeout,
RetryStrategy retryStrategy,
Map<String,Object> clientContext,
RequestSpan parentSpan) |
static CompletableFuture<Stream<SubdocGetRequest>> |
ReplicaHelper.lookupInAllReplicasRequests(Core core,
CollectionIdentifier collectionIdentifier,
String documentId,
List<CoreSubdocGetCommand> commands,
Map<String,Object> clientContext,
RetryStrategy retryStrategy,
Duration timeout,
RequestSpan parent)
Helper method to assemble a stream of requests to the active and all replicas
|
static <R> CompletableFuture<R> |
ReplicaHelper.lookupInAnyReplicaAsync(Core core,
CollectionIdentifier collectionIdentifier,
String documentId,
List<CoreSubdocGetCommand> commands,
Duration timeout,
RetryStrategy retryStrategy,
Map<String,Object> clientContext,
RequestSpan parentSpan,
Function<CoreSubdocGetResult,R> responseMapper) |
| Constructor and 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) |
| Modifier and Type | Method and Description |
|---|---|
CollectionIdentifier |
CoreTransactionGetResult.collection() |
| Modifier and Type | Method and Description |
|---|---|
Optional<CollectionIdentifier> |
CoreTransactionAttemptContext.atrCollection() |
| Modifier and Type | Method and Description |
|---|---|
static CoreTransactionGetResult |
CoreTransactionGetResult.createFrom(CollectionIdentifier collection,
String documentId,
SubdocGetResponse doc) |
Mono<CoreTransactionGetResult> |
CoreTransactionAttemptContext.get(CollectionIdentifier collection,
String id)
Gets a document with the specified
id and from the specified Couchbase bucket. |
Mono<CoreTransactionGetResult> |
CoreTransactionAttemptContext.insert(CollectionIdentifier collection,
String id,
byte[] content,
int flagsToStage,
SpanWrapper pspan)
Inserts a new document into the specified Couchbase
collection. |
| Constructor and Description |
|---|
CoreTransactionGetResult(String id,
byte[] content,
int userFlags,
long cas,
CollectionIdentifier collection,
TransactionLinks links,
Optional<DocumentMetadata> documentMetadata,
Optional<com.couchbase.client.core.deps.com.fasterxml.jackson.databind.JsonNode> txnMeta,
Optional<String> crc32OfGet)
Note that it's intentionally obfuscated here as to whether both content and userFlags come from the document's current body, or staged in the transactional metadata.
|
| Modifier and Type | Method and Description |
|---|---|
CollectionIdentifier |
CleanupRequest.atrCollection() |
| Modifier and Type | Method and Description |
|---|---|
Set<CollectionIdentifier> |
LostCleanupDistributed.cleanupSet() |
Set<CollectionIdentifier> |
CoreTransactionsCleanup.cleanupSet() |
| Modifier and Type | Method and 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) |
| Constructor and 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) |
| Modifier and Type | Method and Description |
|---|---|
CollectionIdentifier |
TransactionLinks.collection() |
CollectionIdentifier |
ActiveTransactionRecords.collection() |
| Modifier and Type | Method and Description |
|---|---|
static RedactableArgument |
ActiveTransactionRecordUtil.getAtrDebug(Optional<CollectionIdentifier> collection,
Optional<String> atrId) |
| Constructor and Description |
|---|
ActiveTransactionRecords(String id,
CollectionIdentifier collection,
long casInNanos,
List<ActiveTransactionRecordEntry> entries,
CasMode casMode) |
| Modifier and Type | Method and Description |
|---|---|
Set<CollectionIdentifier> |
CoreTransactionsCleanupConfig.cleanupSet() |
Optional<CollectionIdentifier> |
CoreTransactionOptions.metadataCollection() |
Optional<CollectionIdentifier> |
CoreSingleQueryTransactionOptions.metadataCollection() |
Optional<CollectionIdentifier> |
CoreMergedTransactionConfig.metadataCollection() |
Optional<CollectionIdentifier> |
CoreTransactionsConfig.metadataCollection() |
| Modifier and Type | Method and Description |
|---|---|
static CoreTransactionsConfig |
CoreTransactionsConfig.createForSingleQueryTransactions(DurabilityLevel durabilityLevel,
Duration timeout,
TransactionAttemptContextFactory transactionAttemptContextFactory,
Optional<CollectionIdentifier> metadataCollection) |
| Modifier and Type | Field and Description |
|---|---|
CollectionIdentifier |
StagedMutation.collection |
| Modifier and Type | Method and Description |
|---|---|
static SpanWrapper |
SpanWrapperUtil.createOp(CoreTransactionAttemptContext ctx,
RequestTracer tracer,
CollectionIdentifier collection,
String id,
String op,
SpanWrapper attemptSpan) |
static SpanWrapper |
SpanWrapperUtil.setAttributes(SpanWrapper out,
CoreTransactionAttemptContext ctx,
CollectionIdentifier collection,
String id) |
| Constructor and Description |
|---|
StagedMutation(String operationId,
String id,
CollectionIdentifier collection,
long cas,
Optional<DocumentMetadata> documentMetadata,
Optional<String> crc32,
int currentUserFlags,
byte[] content,
int stagedUserFlags,
StagedMutationType type) |
| Modifier and Type | Method and Description |
|---|---|
static LogDeferDocId |
DebugUtil.docId(CollectionIdentifier collection,
String docId) |
static Mono<InsertResponse> |
TransactionKVHandler.insert(Core core,
CollectionIdentifier collectionIdentifier,
String id,
byte[] transcodedContent,
int flags,
Duration timeout,
Optional<DurabilityLevel> durabilityLevel,
Map<String,Object> clientContext,
SpanWrapper pspan) |
static Mono<SubdocGetResponse> |
TransactionKVHandler.lookupIn(Core core,
CollectionIdentifier collectionIdentifier,
String id,
Duration timeout,
boolean accessDeleted,
Map<String,Object> clientContext,
SpanWrapper pspan,
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,
int userFlags,
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,
int userFlags,
Optional<DurabilityLevel> durabilityLevel,
Map<String,Object> clientContext,
SpanWrapper pspan,
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 pspan) |
| Constructor and Description |
|---|
LogDeferDocId(CollectionIdentifier collection,
String docId) |
Copyright © 2024 Couchbase, Inc.. All rights reserved.