Uses of Class
com.couchbase.client.core.Core
-
-
Uses of Core in com.couchbase.client.core
Methods in com.couchbase.client.core that return Core Modifier and Type Method Description CoreCoreContext. core()Returns the core to which this context belongs.static CoreCore. create(CoreEnvironment environment, Authenticator authenticator, Set<SeedNode> seedNodes)Creates a newCorewith the given environment with no connection string.static CoreCore. create(CoreEnvironment environment, Authenticator authenticator, Set<SeedNode> seedNodes, ConnectionString connectionString)Creates a newCorewith the given environment with no connection string.Methods in com.couchbase.client.core with parameters of type Core Modifier and Type Method Description voidTimer. scheduleForRetry(Core core, Request<? extends Response> request, Duration runAfter)Schedules a request to be retried after the given duration.Constructors in com.couchbase.client.core with parameters of type Core Constructor Description CoreContext(Core core, long id, CoreEnvironment env, Authenticator authenticator)Creates a newCoreContext.CoreProtostellar(Core core, Authenticator authenticator, Set<SeedNode> seedNodes) -
Uses of Core in com.couchbase.client.core.api.kv
Methods in com.couchbase.client.core.api.kv with parameters of type Core Modifier and Type Method Description static voidCoreKvBinaryParamValidators. validateAppendPrependArgs(Core core, String key, CoreKeyspace keyspace, CoreCommonOptions options, byte[] content, long cas, CoreDurability durability)static voidCoreKvBinaryParamValidators. validateCore(Core core)static voidCoreKvBinaryParamValidators. validateIncrementDecrementArgs(Core core, String key, CoreKeyspace keyspace, CoreCommonOptions options, long expiry, long delta, Optional<Long> initial, CoreDurability durability) -
Uses of Core in com.couchbase.client.core.classic
Methods in com.couchbase.client.core.classic with parameters of type Core Modifier and Type Method Description static <T extends CoreMutationResult>
CompletableFuture<T>ClassicHelper. maybeWrapWithLegacyDurability(CompletableFuture<T> input, String key, CoreDurability durability, Core core, KeyValueRequest<?> request)Helper method to wrap a mutation result to perform legacy durability requirements if needed. -
Uses of Core in com.couchbase.client.core.classic.kv
Methods in com.couchbase.client.core.classic.kv with parameters of type Core Modifier and Type Method Description static CompletableFuture<CoreMutationResult>BinaryAccessor. append(Core core, AppendRequest request, String key, CoreKeyspace keyspace, CoreDurability durability)static CompletableFuture<CoreCounterResult>BinaryAccessor. decrement(Core core, DecrementRequest request, String id, CoreKeyspace keyspace, CoreDurability durability)static CompletableFuture<CoreCounterResult>BinaryAccessor. increment(Core core, IncrementRequest request, String id, CoreKeyspace keyspace, CoreDurability durability)static CompletableFuture<CoreMutationResult>BinaryAccessor. prepend(Core core, PrependRequest request, String key, CoreKeyspace keyspace, CoreDurability durability)Constructors in com.couchbase.client.core.classic.kv with parameters of type Core Constructor Description ClassicCoreKvBinaryOps(Core core, CoreKeyspace keyspace)ClassicCoreKvOps(Core core, CoreKeyspace keyspace) -
Uses of Core in com.couchbase.client.core.classic.manager
Constructors in com.couchbase.client.core.classic.manager with parameters of type Core Constructor Description ClassicCoreCollectionManagerOps(Core core, String bucketName) -
Uses of Core in com.couchbase.client.core.classic.query
Constructors in com.couchbase.client.core.classic.query with parameters of type Core Constructor Description ClassicCoreQueryOps(Core core)EnhancedPreparedStatementStrategy(Core core, int cacheSize)LegacyPreparedStatementStrategy(Core core, int cacheSize)PreparedStatementStrategy(Core core, int cacheSize) -
Uses of Core in com.couchbase.client.core.config
Constructors in com.couchbase.client.core.config with parameters of type Core Constructor Description DefaultConfigurationProvider(Core core, Set<SeedNode> seedNodes)DefaultConfigurationProvider(Core core, Set<SeedNode> seedNodes, ConnectionString connectionString)Creates a new configuration provider. -
Uses of Core in com.couchbase.client.core.config.loader
Methods in com.couchbase.client.core.config.loader that return Core Modifier and Type Method Description protected CoreBaseBucketLoader. core()Returns the attachedCoreto be used by implementations.Constructors in com.couchbase.client.core.config.loader with parameters of type Core Constructor Description ClusterManagerBucketLoader(Core core)GlobalLoader(Core core)KeyValueBucketLoader(Core core) -
Uses of Core in com.couchbase.client.core.config.refresher
Constructors in com.couchbase.client.core.config.refresher with parameters of type Core Constructor Description ClusterManagerBucketRefresher(ConfigurationProvider provider, Core core)GlobalRefresher(ConfigurationProvider provider, Core core)Creates a new global refresher.KeyValueBucketRefresher(ConfigurationProvider provider, Core core) -
Uses of Core in com.couchbase.client.core.diagnostics
Methods in com.couchbase.client.core.diagnostics with parameters of type Core Modifier and Type Method Description static Mono<PingResult>HealthPinger. ping(Core core, Optional<Duration> timeout, RetryStrategy retryStrategy, Set<ServiceType> serviceTypes, Optional<String> reportId, Optional<String> bucketName)Performs a service ping against all or (if given) the services provided.static CompletableFuture<Void>WaitUntilReadyHelper. waitUntilReady(Core core, Set<ServiceType> serviceTypes, Duration timeout, ClusterState desiredState, Optional<String> bucketName)static CompletableFuture<Void>WaitUntilReadyHelper. waitUntilReadyProtostellar(Core core, Duration timeout, ClusterState desiredState) -
Uses of Core in com.couchbase.client.core.endpoint
Constructors in com.couchbase.client.core.endpoint with parameters of type Core Constructor Description ProtostellarEndpoint(Core core, String hostname, int port)ProtostellarPool(Core core, String hostname, int port) -
Uses of Core in com.couchbase.client.core.endpoint.http
Methods in com.couchbase.client.core.endpoint.http with parameters of type Core Modifier and Type Method Description CompletableFuture<CoreHttpResponse>CoreHttpRequest.Builder. exec(Core core)CompletableFuture<CoreHttpResponse>CoreHttpRequest. exec(Core core)Constructors in com.couchbase.client.core.endpoint.http with parameters of type Core Constructor Description CoreHttpClient(Core core, RequestTarget target) -
Uses of Core in com.couchbase.client.core.kv
Constructors in com.couchbase.client.core.kv with parameters of type Core Constructor Description RangeScanOrchestrator(Core core, CollectionIdentifier collectionIdentifier)Creates a newRangeScanOrchestratorwhich can be shared across calls. -
Uses of Core in com.couchbase.client.core.manager
Fields in com.couchbase.client.core.manager declared as Core Modifier and Type Field Description protected CoreCoreViewIndexManager. coreConstructors in com.couchbase.client.core.manager with parameters of type Core Constructor Description CoreAnalyticsLinkManager(Core core)CoreBucketManager(Core core)CoreCollectionQueryIndexManager(Core core, CoreKeyspace collection)CoreEventingFunctionManager(Core core)CoreQueryIndexManager(Core core)CoreViewIndexManager(Core core, String bucket) -
Uses of Core in com.couchbase.client.core.msg.query
Constructors in com.couchbase.client.core.msg.query with parameters of type Core Constructor Description CoreQueryAccessor(Core core)Deprecated. -
Uses of Core in com.couchbase.client.core.protostellar
Methods in com.couchbase.client.core.protostellar with parameters of type Core Modifier and Type Method Description static <TSdkResult,TGrpcRequest,TGrpcResponse>
CoreAsyncResponse<TSdkResult>CoreProtostellarAccessors. async(Core core, ProtostellarRequest<TGrpcRequest> request, Function<ProtostellarEndpoint,com.couchbase.client.core.deps.com.google.common.util.concurrent.ListenableFuture<TGrpcResponse>> executeFutureGrpcCall, Function<TGrpcResponse,TSdkResult> convertResponse)Convenience overload that uses the default exception handling.static <TSdkResult,TGrpcRequest,TGrpcResponse>
CoreAsyncResponse<TSdkResult>CoreProtostellarAccessors. async(Core core, ProtostellarRequest<TGrpcRequest> request, Function<ProtostellarEndpoint,com.couchbase.client.core.deps.com.google.common.util.concurrent.ListenableFuture<TGrpcResponse>> executeFutureGrpcCall, Function<TGrpcResponse,TSdkResult> convertResponse, Function<Throwable,ProtostellarRequestBehaviour> convertException)static <TSdkResult,TGrpcRequest,TGrpcResponse>
voidCoreProtostellarAccessors. asyncInternal(CompletableFuture<TSdkResult> ret, Core core, ProtostellarRequest<TGrpcRequest> request, Function<ProtostellarEndpoint,com.couchbase.client.core.deps.com.google.common.util.concurrent.ListenableFuture<TGrpcResponse>> executeFutureGrpcCall, Function<TGrpcResponse,TSdkResult> convertResponse, Function<Throwable,ProtostellarRequestBehaviour> convertException)static <TSdkResult,TGrpcRequest,TGrpcResponse>
TSdkResultCoreProtostellarAccessors. blocking(Core core, ProtostellarRequest<TGrpcRequest> request, Function<ProtostellarEndpoint,TGrpcResponse> executeBlockingGrpcCall, Function<TGrpcResponse,TSdkResult> convertResponse)Convenience overload that uses the default exception handling.static <TSdkResult,TGrpcRequest,TGrpcResponse>
TSdkResultCoreProtostellarAccessors. blocking(Core core, ProtostellarRequest<TGrpcRequest> request, Function<ProtostellarEndpoint,TGrpcResponse> executeBlockingGrpcCall, Function<TGrpcResponse,TSdkResult> convertResponse, Function<Throwable,ProtostellarRequestBehaviour> convertException)static ProtostellarRequestBehaviourCoreProtostellarErrorHandlingUtil. convertKeyValueException(Core core, ProtostellarRequest<?> request, Throwable t)static <TResponse>
ProtostellarRequestBehaviourCoreProtostellarUtil. convertKeyValueException(Core core, ProtostellarRequest<TResponse> request, Throwable t)static RequestSpanCoreProtostellarUtil. createSpan(Core core, String spanName, CoreDurability durability, RequestSpan parent)static <T> booleanCoreProtostellarUtil. handleShutdownAsync(Core core, CompletableFuture<T> ret, ProtostellarRequest<?> request)static voidCoreProtostellarUtil. handleShutdownBlocking(Core core, ProtostellarRequest<?> request)static <T> Mono<T>CoreProtostellarUtil. handleShutdownReactive(Core core, ProtostellarRequest<?> request)static <TSdkResult>
booleanCoreProtostellarUtil. handleShutdownReactive(Sinks.One<TSdkResult> ret, Core core, ProtostellarRequest<?> request)static DurationCoreProtostellarUtil. kvDurableTimeout(Optional<Duration> customTimeout, CoreDurability dl, Core core)static DurationCoreProtostellarUtil. kvDurableTimeout(Optional<Duration> customTimeout, Optional<DurabilityLevel> dl, Core core)static DurationCoreProtostellarUtil. kvTimeout(Optional<Duration> customTimeout, Core core)static DurationCoreProtostellarUtil. managementTimeout(Optional<Duration> customTimeout, Core core)static <TSdkResult,TGrpcRequest,TGrpcResponse>
Mono<TSdkResult>CoreProtostellarAccessors. reactive(Core core, ProtostellarRequest<TGrpcRequest> request, Function<ProtostellarEndpoint,com.couchbase.client.core.deps.com.google.common.util.concurrent.ListenableFuture<TGrpcResponse>> executeFutureGrpcCall, Function<TGrpcResponse,TSdkResult> convertResponse)Convenience overload that uses the default exception handling.static <TSdkResult,TGrpcRequest,TGrpcResponse>
Mono<TSdkResult>CoreProtostellarAccessors. reactive(Core core, ProtostellarRequest<TGrpcRequest> request, Function<ProtostellarEndpoint,com.couchbase.client.core.deps.com.google.common.util.concurrent.ListenableFuture<TGrpcResponse>> executeFutureGrpcCall, Function<TGrpcResponse,TSdkResult> convertResponse, Function<Throwable,ProtostellarRequestBehaviour> convertException)static <TSdkResult,TGrpcRequest,TGrpcResponse>
voidCoreProtostellarAccessors. reactiveInternal(Sinks.One<TSdkResult> ret, Core core, ProtostellarRequest<TGrpcRequest> request, Function<ProtostellarEndpoint,com.couchbase.client.core.deps.com.google.common.util.concurrent.ListenableFuture<TGrpcResponse>> executeFutureGrpcCall, Function<TGrpcResponse,TSdkResult> convertResponse, Function<Throwable,ProtostellarRequestBehaviour> convertException)Constructors in com.couchbase.client.core.protostellar with parameters of type Core Constructor Description ProtostellarBaseRequest(Core core, ProtostellarRequest<?> request)ProtostellarCollectionManagerRequest(Core core, String bucketName, String scopeName, String collectionName, String requestName, RequestSpan span, Duration timeout, boolean idempotent, RetryStrategy retryStrategy, Map<String,Object> clientContext)ProtostellarKeyValueRequest(Core core, CoreKeyspace keyspace, String key, CoreDurability durability, String requestName, RequestSpan span, Duration timeout, boolean idempotent, RetryStrategy retryStrategy, Map<String,Object> clientContext)ProtostellarRequest(Core core, ServiceType serviceType, String requestName, RequestSpan span, Duration timeout, boolean idempotent, RetryStrategy retryStrategy, Map<String,Object> clientContext) -
Uses of Core in com.couchbase.client.core.protostellar.kv
Methods in com.couchbase.client.core.protostellar.kv with parameters of type Core Modifier and Type Method Description static ProtostellarRequest<com.couchbase.client.protostellar.kv.v1.AppendRequest>CoreProtoStellarKvBinaryRequests. appendRequest(Core core, String key, CoreKeyspace keyspace, CoreCommonOptions opts, byte[] content, long cas, CoreDurability durability)For creating Protostellar GRPC requests.static ProtostellarRequest<com.couchbase.client.protostellar.kv.v1.DecrementRequest>CoreProtoStellarKvBinaryRequests. decrementRequest(Core core, String key, CoreKeyspace keyspace, CoreCommonOptions opts, long expiry, long delta, Optional<Long> initial, CoreDurability durability)static ProtostellarRequest<com.couchbase.client.protostellar.kv.v1.ExistsRequest>CoreProtostellarKeyValueRequests. existsRequest(Core core, CoreKeyspace keyspace, CoreCommonOptions opts, String key)static ProtostellarRequest<com.couchbase.client.protostellar.kv.v1.GetAndLockRequest>CoreProtostellarKeyValueRequests. getAndLockRequest(Core core, CoreCommonOptions opts, CoreKeyspace keyspace, String key, Duration lockTime)static ProtostellarRequest<com.couchbase.client.protostellar.kv.v1.GetAndTouchRequest>CoreProtostellarKeyValueRequests. getAndTouchRequest(Core core, CoreCommonOptions opts, CoreKeyspace keyspace, String key, long expiration)static ProtostellarRequest<com.couchbase.client.protostellar.kv.v1.GetRequest>CoreProtostellarKeyValueRequests. getRequest(Core core, CoreCommonOptions opts, CoreKeyspace keyspace, String key, List<String> projections, boolean withExpiry)static ProtostellarRequest<com.couchbase.client.protostellar.kv.v1.IncrementRequest>CoreProtoStellarKvBinaryRequests. incrementRequest(Core core, String key, CoreKeyspace keyspace, CoreCommonOptions opts, long expiry, long delta, Optional<Long> initial, CoreDurability durability)static ProtostellarRequest<com.couchbase.client.protostellar.kv.v1.InsertRequest>CoreProtostellarKeyValueRequests. insertRequest(Core core, CoreKeyspace keyspace, CoreCommonOptions opts, String key, Supplier<CoreEncodedContent> content, CoreDurability durability, long expiry)static ProtostellarRequest<com.couchbase.client.protostellar.kv.v1.MutateInRequest>CoreProtostellarKeyValueRequests. mutateInRequest(Core core, CoreKeyspace keyspace, CoreCommonOptions opts, String key, List<CoreSubdocMutateCommand> commands, CoreStoreSemantics storeSemantics, long cas, CoreDurability durability, long expiry, boolean preserveExpiry, boolean accessDeleted, boolean createAsDeleted)static ProtostellarRequest<com.couchbase.client.protostellar.kv.v1.PrependRequest>CoreProtoStellarKvBinaryRequests. prependRequest(Core core, String key, CoreKeyspace keyspace, CoreCommonOptions opts, byte[] content, long cas, CoreDurability durability)static ProtostellarRequest<com.couchbase.client.protostellar.kv.v1.RemoveRequest>CoreProtostellarKeyValueRequests. removeRequest(Core core, CoreKeyspace keyspace, CoreCommonOptions opts, String key, long cas, CoreDurability durability)static ProtostellarRequest<com.couchbase.client.protostellar.kv.v1.ReplaceRequest>CoreProtostellarKeyValueRequests. replaceRequest(Core core, CoreKeyspace keyspace, CoreCommonOptions opts, String key, Supplier<CoreEncodedContent> content, long cas, CoreDurability durability, long expiry, boolean preserveExpiry)static ProtostellarRequest<com.couchbase.client.protostellar.kv.v1.TouchRequest>CoreProtostellarKeyValueRequests. touchRequest(Core core, CoreKeyspace keyspace, CoreCommonOptions opts, String key, long expiry)static ProtostellarRequest<com.couchbase.client.protostellar.kv.v1.UnlockRequest>CoreProtostellarKeyValueRequests. unlockRequest(Core core, CoreKeyspace keyspace, CoreCommonOptions opts, String key, long cas)static ProtostellarRequest<com.couchbase.client.protostellar.kv.v1.UpsertRequest>CoreProtostellarKeyValueRequests. upsertRequest(Core core, CoreKeyspace keyspace, CoreCommonOptions opts, String key, Supplier<CoreEncodedContent> content, CoreDurability durability, long expiry, boolean preserveExpiry)Constructors in com.couchbase.client.core.protostellar.kv with parameters of type Core Constructor Description ProtostellarCoreKvBinaryOps(Core core, CoreKeyspace keyspace)ProtostellarCoreKvOps(Core core, CoreKeyspace keyspace) -
Uses of Core in com.couchbase.client.core.protostellar.manager
Methods in com.couchbase.client.core.protostellar.manager with parameters of type Core Modifier and Type Method Description static ProtostellarRequest<com.couchbase.client.protostellar.admin.collection.v1.CreateCollectionRequest>CoreProtostellarCollectionManagerRequests. createCollectionRequest(Core core, String bucketName, String scopeName, String collectionName, Duration maxTTL, CoreCommonOptions opts)static ProtostellarRequest<com.couchbase.client.protostellar.admin.collection.v1.CreateScopeRequest>CoreProtostellarCollectionManagerRequests. createScopeRequest(Core core, String bucketName, String scopeName, CoreCommonOptions opts)static ProtostellarRequest<com.couchbase.client.protostellar.admin.collection.v1.DeleteCollectionRequest>CoreProtostellarCollectionManagerRequests. deleteCollectionRequest(Core core, String bucketName, String scopeName, String collectionName, CoreCommonOptions opts)static ProtostellarRequest<com.couchbase.client.protostellar.admin.collection.v1.DeleteScopeRequest>CoreProtostellarCollectionManagerRequests. deleteScopeRequest(Core core, String bucketName, String scopeName, CoreCommonOptions opts)static ProtostellarRequest<com.couchbase.client.protostellar.admin.collection.v1.ListCollectionsRequest>CoreProtostellarCollectionManagerRequests. listCollectionsRequest(Core core, String bucketName, CoreCommonOptions opts)Constructors in com.couchbase.client.core.protostellar.manager with parameters of type Core Constructor Description ProtostellarCoreCollectionManagerOps(Core core, String bucketName) -
Uses of Core in com.couchbase.client.core.protostellar.query
Constructors in com.couchbase.client.core.protostellar.query with parameters of type Core Constructor Description ProtostellarCoreQueryOps(Core core) -
Uses of Core in com.couchbase.client.core.retry
Methods in com.couchbase.client.core.retry with parameters of type Core Modifier and Type Method Description static ProtostellarRequestBehaviourRetryOrchestratorProtostellar. shouldRetry(Core core, ProtostellarRequest<?> request, RetryReason reason) -
Uses of Core in com.couchbase.client.core.service.kv
Methods in com.couchbase.client.core.service.kv with parameters of type Core 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) -
Uses of Core in com.couchbase.client.core.transaction
Methods in com.couchbase.client.core.transaction that return Core Modifier and Type Method Description CoreCoreTransactionAttemptContext. core()CoreCoreTransactionsReactive. core()Constructors in com.couchbase.client.core.transaction with parameters of type Core Constructor Description CoreTransactionAttemptContext(Core core, CoreTransactionContext overall, CoreMergedTransactionConfig config, String attemptId, CoreTransactionsReactive parent, Optional<SpanWrapper> parentSpan, CoreTransactionAttemptContextHooks hooks)CoreTransactionsReactive(Core core, CoreTransactionsConfig config) -
Uses of Core in com.couchbase.client.core.transaction.cleanup
Methods in com.couchbase.client.core.transaction.cleanup with parameters of type Core Modifier and Type Method Description TransactionsCleanerCleanerFactory. create(Core core)TransactionsCleanerCleanerMockFactory. create(Core core)ClientRecordClientRecordFactory. create(Core core)ClientRecordClientRecordFactoryMock. create(Core core)Constructors in com.couchbase.client.core.transaction.cleanup with parameters of type Core Constructor Description ClientRecord(Core core)CoreTransactionsCleanup(Core core, CoreTransactionsConfig config)LostCleanupDistributed(Core core, CoreTransactionsConfig config, Supplier<TransactionsCleaner> cleanerSupplier)TransactionsCleaner(Core core, CleanerHooks hooks) -
Uses of Core in com.couchbase.client.core.transaction.components
-
Uses of Core in com.couchbase.client.core.transaction.forwards
Methods in com.couchbase.client.core.transaction.forwards with parameters of type Core Modifier and Type Method Description static Mono<Void>ForwardCompatibility. check(Core core, ForwardCompatibilityStage fc, Optional<ForwardCompatibility> forwardCompatibility, CoreTransactionLogger logger, Supported supported)Returns empty if it's ok to continue, otherwise an error: -
Uses of Core in com.couchbase.client.core.transaction.support
Methods in com.couchbase.client.core.transaction.support with parameters of type Core Modifier and Type Method Description CoreTransactionAttemptContextTransactionAttemptContextFactory. create(Core core, CoreTransactionContext overall, CoreMergedTransactionConfig config, String attemptId, CoreTransactionsReactive parent, Optional<SpanWrapper> parentSpan)static DurationOptionsUtil. kvTimeoutMutating(Core core)The timeout to use for important mutating KV operations.static DurationOptionsUtil. kvTimeoutNonMutating(Core core)The timeout to use for non-mutating KV operations (or mutating operations that aren't important enough to justify durability.) -
Uses of Core in com.couchbase.client.core.transaction.util
Methods in com.couchbase.client.core.transaction.util with parameters of type Core Modifier and Type Method Description CoreTransactionAttemptContextTestTransactionAttemptContextFactory. create(Core core, CoreTransactionContext overall, CoreMergedTransactionConfig config, String attemptId, CoreTransactionsReactive parent, Optional<SpanWrapper> parentSpan)static Mono<InsertResponse>TransactionKVHandler. insert(Core core, CollectionIdentifier collectionIdentifier, String id, byte[] transcodedContent, 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, 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 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) -
Uses of Core in com.couchbase.client.core.util
Methods in com.couchbase.client.core.util with parameters of type Core Modifier and Type Method Description static Mono<BucketConfig>BucketConfigUtil. waitForBucketConfig(Core core, String bucketName, Duration timeout)A bucket config can be null while the bucket has not been opened.static voidConsistencyUtil. waitUntilBucketDropped(Core core, String name)static voidConsistencyUtil. waitUntilBucketPresent(Core core, String name)static voidConsistencyUtil. waitUntilCollectionDropped(Core core, String bucketName, String scopeName, String collectionName)static voidConsistencyUtil. waitUntilCollectionPresent(Core core, String bucketName, String scopeName, String collectionName)static voidConsistencyUtil. waitUntilDesignDocumentDropped(Core core, String bucketName, String designDocument)static voidConsistencyUtil. waitUntilDesignDocumentPresent(Core core, String bucketName, String designDocument)static voidConsistencyUtil. waitUntilGroupDropped(Core core, String name)static voidConsistencyUtil. waitUntilGroupPresent(Core core, String name)static voidConsistencyUtil. waitUntilScopeDropped(Core core, String bucketName, String scopeName)static voidConsistencyUtil. waitUntilScopePresent(Core core, String bucketName, String scopeName)static voidConsistencyUtil. waitUntilSearchIndexDropped(Core core, String indexName)static voidConsistencyUtil. waitUntilSearchIndexPresent(Core core, String indexName)static voidConsistencyUtil. waitUntilUserDropped(Core core, String domain, String name)static voidConsistencyUtil. waitUntilUserPresent(Core core, String domain, String name)static voidConsistencyUtil. waitUntilViewDropped(Core core, String bucketName, String designDocument, String viewName)static voidConsistencyUtil. waitUntilViewPresent(Core core, String bucketName, String designDocument, String viewName)
-