use of com.couchbase.client.core.error.UnambiguousTimeoutException in project couchbase-jvm-clients by couchbase.
the class QueryChunkResponseParser method errorsToThrowable.
static CouchbaseException errorsToThrowable(final byte[] bytes, HttpResponse header, RequestContext ctx) {
int httpStatus = header != null ? header.status().code() : 0;
final List<ErrorCodeAndMessage> errors = bytes.length == 0 ? Collections.emptyList() : ErrorCodeAndMessage.fromJsonArray(bytes);
QueryErrorContext errorContext = new QueryErrorContext(ctx, errors, httpStatus);
if (errors.size() >= 1) {
ErrorCodeAndMessage codeAndMessage = errors.get(0);
int code = codeAndMessage.code();
String message = codeAndMessage.message();
int reasonCode = codeAndMessage.reason() != null ? (int) codeAndMessage.reason().getOrDefault("code", 0) : 0;
if (code == 3000) {
return new ParsingFailureException(errorContext);
} else if (PREPARED_ERROR_CODES.contains(code)) {
return new PreparedStatementFailureException(errorContext, RETRYABLE_PREPARED_ERROR_CODES.contains(code));
} else if (code == 4300 && message.matches("^.*index .*already exist.*")) {
return new IndexExistsException(errorContext);
} else if (code >= 4000 && code < 5000) {
return new PlanningFailureException(errorContext);
} else if (code == 12004 || code == 12016 || (code == 5000 && message.matches("^.*index .+ not found.*"))) {
return new IndexNotFoundException(errorContext);
} else if (code == 5000 && message.matches("^.*Index .*already exist.*")) {
return new IndexExistsException(errorContext);
} else if (code == 5000 && message.contains("limit for number of indexes that can be created per scope has been reached")) {
return new QuotaLimitedException(errorContext);
} else if (code >= 5000 && code < 6000) {
return new InternalServerFailureException(errorContext);
} else if (code == 12009) {
if (message.contains("CAS mismatch") || reasonCode == 12033) {
return new CasMismatchException(errorContext);
} else if (reasonCode == 17014) {
return new DocumentNotFoundException(errorContext);
} else if (reasonCode == 17012) {
return new DocumentExistsException(errorContext);
} else {
return new DmlFailureException(errorContext);
}
} else if ((code >= 10000 && code < 11000) || code == 13014) {
return new AuthenticationFailureException("Could not authenticate query", errorContext, null);
} else if ((code >= 12000 && code < 13000) || (code >= 14000 && code < 15000)) {
return new IndexFailureException(errorContext);
} else if (code == 1065) {
if (message.contains("query_context")) {
return FeatureNotAvailableException.scopeLevelQuery(ServiceType.QUERY);
}
if (message.contains("preserve_expiry")) {
return FeatureNotAvailableException.queryPreserveExpiry();
}
} else if (code == 1080) {
// engine will proactively send us a timeout and we need to convert it.
return new UnambiguousTimeoutException("Query timed out while streaming/receiving rows", new CancellationErrorContext(errorContext));
} else if (code == 1191 || code == 1192 || code == 1193 || code == 1194) {
return new RateLimitedException(errorContext);
} else if (code == 3230) {
String feature = null;
if (message.contains("Advisor") || message.contains("Advise")) {
feature = "Query Index Advisor";
} else if (message.contains("Window")) {
feature = "Query Window Functions";
}
return FeatureNotAvailableException.communityEdition(feature);
}
}
return new CouchbaseException("Unknown query error", errorContext);
}
use of com.couchbase.client.core.error.UnambiguousTimeoutException 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();
}
use of com.couchbase.client.core.error.UnambiguousTimeoutException in project connectors-se by Talend.
the class CouchbaseService method openConnection.
public Cluster openConnection(CouchbaseDataStore dataStore) {
String bootStrapNodes = dataStore.getBootstrapNodes();
String username = dataStore.getUsername();
String password = dataStore.getPassword();
String urls = Arrays.stream(resolveAddresses(bootStrapNodes)).collect(Collectors.joining(","));
ClusterHolder holder = clustersPool.computeIfAbsent(dataStore, ds -> {
ClusterEnvironment.Builder envBuilder = ClusterEnvironment.builder();
if (dataStore.isUseConnectionParameters()) {
Builder timeoutBuilder = TimeoutConfig.builder();
dataStore.getConnectionParametersList().forEach(conf -> setTimeout(timeoutBuilder, envBuilder, conf.getParameterName(), parseValue(conf.getParameterValue())));
envBuilder.timeoutConfig(timeoutBuilder);
}
ClusterEnvironment environment = envBuilder.build();
Cluster cluster = Cluster.connect(urls, ClusterOptions.clusterOptions(username, password).environment(environment));
try {
cluster.waitUntilReady(Duration.ofSeconds(3), WaitUntilReadyOptions.waitUntilReadyOptions().desiredState(ClusterState.ONLINE));
} catch (UnambiguousTimeoutException e) {
LOG.error(i18n.connectionKO());
throw new ComponentException(e);
}
return new ClusterHolder(environment, cluster);
});
holder.use();
Cluster cluster = holder.getCluster();
// connection is lazily initialized; need to send actual request to test it
cluster.buckets().getAllBuckets();
PingResult pingResult = cluster.ping();
LOG.debug(i18n.connectedToCluster(pingResult.id()));
return cluster;
}
use of com.couchbase.client.core.error.UnambiguousTimeoutException in project couchbase-jvm-clients by couchbase.
the class BaseRequest method cancel.
@Override
public void cancel(final CancellationReason reason, Function<Throwable, Throwable> exceptionTranslator) {
if (STATE_UPDATER.compareAndSet(this, State.INCOMPLETE, State.CANCELLED)) {
cancelTimeoutRegistration();
cancellationReason = reason;
final Throwable exception;
final String msg = this.getClass().getSimpleName() + ", Reason: " + reason;
final CancellationErrorContext ctx = new CancellationErrorContext(context());
if (reason == CancellationReason.TIMEOUT) {
exception = idempotent() ? new UnambiguousTimeoutException(msg, ctx) : new AmbiguousTimeoutException(msg, ctx);
} else {
exception = new RequestCanceledException(msg, reason, ctx);
}
response.completeExceptionally(exceptionTranslator.apply(exception));
}
}
Aggregations