Search in sources :

Example 1 with ArrayNode

use of com.couchbase.client.core.deps.com.fasterxml.jackson.databind.node.ArrayNode in project couchbase-jvm-clients by couchbase.

the class ProjectionsApplier method insertRecursive.

/**
 * Will follow `path`, constructing JSON as it does into `out`, and inserting `content` at the leaf
 *
 * @param out must be either a ObjectNode or ArrayNode, and the JSON will be constructed into it
 */
private static void insertRecursive(final ContainerNode<?> out, final List<PathElement> path, final JsonNode content) {
    if (path.isEmpty()) {
        // Recursion is done
        return;
    }
    if (path.size() == 1) {
        // At leaf of path
        PathElement leaf = path.get(0);
        if (leaf instanceof PathArray) {
            PathArray v = (PathArray) leaf;
            ArrayNode toInsert = out.arrayNode().add(content);
            if (out.isObject()) {
                ((ObjectNode) out).set(v.str(), toInsert);
            } else {
                ((ArrayNode) out).add(toInsert);
            }
        } else {
            PathObjectOrField v = (PathObjectOrField) leaf;
            if (out.isObject()) {
                ((ObjectNode) out).set(v.str(), content);
            } else {
                ObjectNode toInsert = out.objectNode();
                toInsert.set(v.str(), content);
                ((ArrayNode) out).add(toInsert);
            }
        }
    } else {
        // Non-leaf
        PathElement next = path.get(0);
        List<PathElement> remaining = path.subList(1, path.size());
        if (next instanceof PathArray) {
            PathArray v = (PathArray) next;
            ArrayNode toInsert = out.arrayNode();
            if (out.isObject()) {
                ((ObjectNode) out).set(v.str(), toInsert);
                insertRecursive(toInsert, remaining, content);
            } else {
                ((ArrayNode) out).add(toInsert);
                insertRecursive(out, remaining, content);
            }
        } else {
            PathObjectOrField v = (PathObjectOrField) next;
            if (out.isObject()) {
                ObjectNode createIn = (ObjectNode) out.get(v.str());
                if (createIn == null) {
                    createIn = out.objectNode();
                }
                ((ObjectNode) out).set(v.str(), createIn);
                insertRecursive(createIn, remaining, content);
            } else {
                ObjectNode toCreate = out.objectNode();
                ObjectNode nextToCreate = out.objectNode();
                toCreate.set(v.str(), nextToCreate);
                ((ArrayNode) out).add(toCreate);
                insertRecursive(nextToCreate, remaining, content);
            }
        }
    }
}
Also used : ObjectNode(com.couchbase.client.core.deps.com.fasterxml.jackson.databind.node.ObjectNode) ArrayNode(com.couchbase.client.core.deps.com.fasterxml.jackson.databind.node.ArrayNode)

Example 2 with ArrayNode

use of com.couchbase.client.core.deps.com.fasterxml.jackson.databind.node.ArrayNode in project couchbase-jvm-clients by couchbase.

the class WaitUntilReadyHelper method waitUntilReady.

@Stability.Internal
public static CompletableFuture<Void> waitUntilReady(final Core core, final Set<ServiceType> serviceTypes, final Duration timeout, final ClusterState desiredState, final Optional<String> bucketName) {
    final WaitUntilReadyState state = new WaitUntilReadyState();
    state.transition(WaitUntilReadyStage.CONFIG_LOAD);
    return Flux.interval(Duration.ofMillis(10), core.context().environment().scheduler()).onBackpressureDrop().filter(i -> !(core.configurationProvider().bucketConfigLoadInProgress() || core.configurationProvider().globalConfigLoadInProgress() || (bucketName.isPresent() && core.configurationProvider().collectionRefreshInProgress()) || (bucketName.isPresent() && core.clusterConfig().bucketConfig(bucketName.get()) == null))).filter(i -> {
        // created.
        if (bucketName.isPresent()) {
            state.transition(WaitUntilReadyStage.BUCKET_CONFIG_READY);
            BucketConfig bucketConfig = core.clusterConfig().bucketConfig(bucketName.get());
            long extNodes = bucketConfig.portInfos().stream().filter(p -> p.ports().containsKey(ServiceType.KV)).count();
            long visibleNodes = bucketConfig.nodes().stream().filter(n -> n.services().containsKey(ServiceType.KV)).count();
            return extNodes > 0 && extNodes == visibleNodes;
        } else {
            return true;
        }
    }).flatMap(i -> {
        if (bucketName.isPresent()) {
            state.transition(WaitUntilReadyStage.BUCKET_NODES_HEALTHY);
            // To avoid tmpfails on the bucket, we double check that all nodes from the nodes list are
            // in a healthy status - but for this we need to actually fetch the verbose config, since
            // the terse one doesn't have that status in it.
            GenericManagerRequest request = new GenericManagerRequest(core.context(), () -> new DefaultFullHttpRequest(HttpVersion.HTTP_1_1, HttpMethod.GET, "/pools/default/buckets/" + bucketName.get()), true, null);
            core.send(request);
            return Reactor.wrap(request, request.response(), true).filter(response -> {
                if (response.status() != ResponseStatus.SUCCESS) {
                    return false;
                }
                ObjectNode root = (ObjectNode) Mapper.decodeIntoTree(response.content());
                ArrayNode nodes = (ArrayNode) root.get("nodes");
                long healthy = StreamSupport.stream(nodes.spliterator(), false).filter(node -> node.get("status").asText().equals("healthy")).count();
                return nodes.size() == healthy;
            }).map(ignored -> i);
        } else {
            return Flux.just(i);
        }
    }).take(1).flatMap(aLong -> {
        // to being ready at this point. Bucket level wait until ready is the way to go there.
        if (!bucketName.isPresent() && !core.clusterConfig().hasClusterOrBucketConfig()) {
            state.transition(WaitUntilReadyStage.COMPLETE);
            WaitUntilReadyContext waitUntilReadyContext = new WaitUntilReadyContext(servicesToCheck(core, serviceTypes, bucketName), timeout, desiredState, bucketName, core.diagnostics().collect(Collectors.groupingBy(EndpointDiagnostics::type)), state);
            core.context().environment().eventBus().publish(new WaitUntilReadyCompletedEvent(waitUntilReadyContext, WaitUntilReadyCompletedEvent.Reason.CLUSTER_LEVEL_NOT_SUPPORTED));
            return Flux.empty();
        }
        state.transition(WaitUntilReadyStage.PING);
        final Flux<ClusterState> diagnostics = Flux.interval(Duration.ofMillis(10), core.context().environment().scheduler()).onBackpressureDrop().map(i -> diagnosticsCurrentState(core)).takeUntil(s -> s == desiredState);
        return Flux.concat(ping(core, servicesToCheck(core, serviceTypes, bucketName), timeout, bucketName), diagnostics);
    }).then().timeout(timeout, Mono.defer(() -> {
        WaitUntilReadyContext waitUntilReadyContext = new WaitUntilReadyContext(servicesToCheck(core, serviceTypes, bucketName), timeout, desiredState, bucketName, core.diagnostics().collect(Collectors.groupingBy(EndpointDiagnostics::type)), state);
        CancellationErrorContext errorContext = new CancellationErrorContext(waitUntilReadyContext);
        return Mono.error(new UnambiguousTimeoutException("WaitUntilReady timed out", errorContext));
    }), core.context().environment().scheduler()).doOnSuccess(unused -> {
        state.transition(WaitUntilReadyStage.COMPLETE);
        WaitUntilReadyContext waitUntilReadyContext = new WaitUntilReadyContext(servicesToCheck(core, serviceTypes, bucketName), timeout, desiredState, bucketName, core.diagnostics().collect(Collectors.groupingBy(EndpointDiagnostics::type)), state);
        core.context().environment().eventBus().publish(new WaitUntilReadyCompletedEvent(waitUntilReadyContext, WaitUntilReadyCompletedEvent.Reason.SUCCESS));
    }).toFuture();
}
Also used : CbCollections.isNullOrEmpty(com.couchbase.client.core.util.CbCollections.isNullOrEmpty) UnambiguousTimeoutException(com.couchbase.client.core.error.UnambiguousTimeoutException) HttpVersion(com.couchbase.client.core.deps.io.netty.handler.codec.http.HttpVersion) RequestTarget(com.couchbase.client.core.msg.RequestTarget) CompletableFuture(java.util.concurrent.CompletableFuture) Function(java.util.function.Function) ServiceType(com.couchbase.client.core.service.ServiceType) Duration(java.time.Duration) Map(java.util.Map) Stability(com.couchbase.client.core.annotation.Stability) GenericManagerRequest(com.couchbase.client.core.msg.manager.GenericManagerRequest) StreamSupport(java.util.stream.StreamSupport) BucketConfig(com.couchbase.client.core.config.BucketConfig) ObjectNode(com.couchbase.client.core.deps.com.fasterxml.jackson.databind.node.ObjectNode) CancellationErrorContext(com.couchbase.client.core.error.context.CancellationErrorContext) ArrayNode(com.couchbase.client.core.deps.com.fasterxml.jackson.databind.node.ArrayNode) Reactor(com.couchbase.client.core.Reactor) HttpMethod(com.couchbase.client.core.deps.io.netty.handler.codec.http.HttpMethod) Mapper(com.couchbase.client.core.json.Mapper) ConcurrentHashMap(java.util.concurrent.ConcurrentHashMap) Set(java.util.Set) DefaultFullHttpRequest(com.couchbase.client.core.deps.io.netty.handler.codec.http.DefaultFullHttpRequest) Mono(reactor.core.publisher.Mono) Collectors(java.util.stream.Collectors) ResponseStatus(com.couchbase.client.core.msg.ResponseStatus) TimeUnit(java.util.concurrent.TimeUnit) Flux(reactor.core.publisher.Flux) AtomicLong(java.util.concurrent.atomic.AtomicLong) WaitUntilReadyCompletedEvent(com.couchbase.client.core.cnc.events.core.WaitUntilReadyCompletedEvent) TreeMap(java.util.TreeMap) Optional(java.util.Optional) Core(com.couchbase.client.core.Core) DefaultFullHttpRequest(com.couchbase.client.core.deps.io.netty.handler.codec.http.DefaultFullHttpRequest) ObjectNode(com.couchbase.client.core.deps.com.fasterxml.jackson.databind.node.ObjectNode) UnambiguousTimeoutException(com.couchbase.client.core.error.UnambiguousTimeoutException) BucketConfig(com.couchbase.client.core.config.BucketConfig) GenericManagerRequest(com.couchbase.client.core.msg.manager.GenericManagerRequest) WaitUntilReadyCompletedEvent(com.couchbase.client.core.cnc.events.core.WaitUntilReadyCompletedEvent) ArrayNode(com.couchbase.client.core.deps.com.fasterxml.jackson.databind.node.ArrayNode) CancellationErrorContext(com.couchbase.client.core.error.context.CancellationErrorContext)

Aggregations

ArrayNode (com.couchbase.client.core.deps.com.fasterxml.jackson.databind.node.ArrayNode)2 ObjectNode (com.couchbase.client.core.deps.com.fasterxml.jackson.databind.node.ObjectNode)2 Core (com.couchbase.client.core.Core)1 Reactor (com.couchbase.client.core.Reactor)1 Stability (com.couchbase.client.core.annotation.Stability)1 WaitUntilReadyCompletedEvent (com.couchbase.client.core.cnc.events.core.WaitUntilReadyCompletedEvent)1 BucketConfig (com.couchbase.client.core.config.BucketConfig)1 DefaultFullHttpRequest (com.couchbase.client.core.deps.io.netty.handler.codec.http.DefaultFullHttpRequest)1 HttpMethod (com.couchbase.client.core.deps.io.netty.handler.codec.http.HttpMethod)1 HttpVersion (com.couchbase.client.core.deps.io.netty.handler.codec.http.HttpVersion)1 UnambiguousTimeoutException (com.couchbase.client.core.error.UnambiguousTimeoutException)1 CancellationErrorContext (com.couchbase.client.core.error.context.CancellationErrorContext)1 Mapper (com.couchbase.client.core.json.Mapper)1 RequestTarget (com.couchbase.client.core.msg.RequestTarget)1 ResponseStatus (com.couchbase.client.core.msg.ResponseStatus)1 GenericManagerRequest (com.couchbase.client.core.msg.manager.GenericManagerRequest)1 ServiceType (com.couchbase.client.core.service.ServiceType)1 CbCollections.isNullOrEmpty (com.couchbase.client.core.util.CbCollections.isNullOrEmpty)1 Duration (java.time.Duration)1 Map (java.util.Map)1