use of com.couchbase.client.core.env.CoreEnvironment in project couchbase-jvm-clients by couchbase.
the class ReplicaHelper method getAllReplicasReactive.
/**
* @param clientContext (nullable)
* @param parentSpan (nullable)
*/
public static Flux<GetReplicaResponse> getAllReplicasReactive(final Core core, final CollectionIdentifier collectionIdentifier, final String documentId, final Duration timeout, final RetryStrategy retryStrategy, Map<String, Object> clientContext, RequestSpan parentSpan) {
notNullOrEmpty(documentId, "Id", () -> ReducedKeyValueErrorContext.create(documentId, collectionIdentifier));
CoreEnvironment env = core.context().environment();
RequestSpan getAllSpan = env.requestTracer().requestSpan(TracingIdentifiers.SPAN_GET_ALL_REPLICAS, parentSpan);
getAllSpan.attribute(TracingIdentifiers.ATTR_SYSTEM, TracingIdentifiers.ATTR_SYSTEM_COUCHBASE);
return Reactor.toMono(() -> getAllReplicasRequests(core, collectionIdentifier, documentId, clientContext, retryStrategy, timeout, getAllSpan)).flux().flatMap(Flux::fromStream).flatMap(request -> Reactor.wrap(request, get(core, request), true).onErrorResume(t -> {
env.eventBus().publish(new IndividualReplicaGetFailedEvent(request.context()));
// Swallow any errors from individual replicas
return Mono.empty();
}).map(response -> new GetReplicaResponse(response, request instanceof ReplicaGetRequest))).doFinally(signalType -> getAllSpan.end());
}
use of com.couchbase.client.core.env.CoreEnvironment in project couchbase-jvm-clients by couchbase.
the class ReplicaHelper method getAllReplicasAsync.
/**
* 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.
*
* @param clientContext (nullable)
* @param parentSpan (nullable)
* @param responseMapper converts the GetReplicaResponse to the client's native result type
* @return a list of results from the active and the replica.
*/
public static <R> CompletableFuture<List<CompletableFuture<R>>> getAllReplicasAsync(final Core core, final CollectionIdentifier collectionIdentifier, final String documentId, final Duration timeout, final RetryStrategy retryStrategy, final Map<String, Object> clientContext, final RequestSpan parentSpan, final Function<GetReplicaResponse, R> responseMapper) {
CoreEnvironment env = core.context().environment();
RequestSpan getAllSpan = env.requestTracer().requestSpan(TracingIdentifiers.SPAN_GET_ALL_REPLICAS, parentSpan);
getAllSpan.attribute(TracingIdentifiers.ATTR_SYSTEM, TracingIdentifiers.ATTR_SYSTEM_COUCHBASE);
return getAllReplicasRequests(core, collectionIdentifier, documentId, clientContext, retryStrategy, timeout, getAllSpan).thenApply(stream -> stream.map(request -> get(core, request).thenApply(response -> new GetReplicaResponse(response, request instanceof ReplicaGetRequest)).thenApply(responseMapper)).collect(Collectors.toList())).whenComplete((completableFutures, throwable) -> {
final AtomicInteger toComplete = new AtomicInteger(completableFutures.size());
for (CompletableFuture<R> cf : completableFutures) {
cf.whenComplete((a, b) -> {
if (toComplete.decrementAndGet() == 0) {
getAllSpan.end();
}
});
}
});
}
use of com.couchbase.client.core.env.CoreEnvironment in project couchbase-jvm-clients by couchbase.
the class RetryOrchestratorTest method cancelIfNoMoreRetriesAllowed.
@Test
@SuppressWarnings({ "unchecked" })
void cancelIfNoMoreRetriesAllowed() {
RetryStrategy retryStrategy = mock(RetryStrategy.class);
when(retryStrategy.shouldRetry(any(Request.class), any(RetryReason.class))).thenReturn(CompletableFuture.completedFuture(RetryAction.noRetry()));
Request<?> request = mock(Request.class);
when(request.completed()).thenReturn(false);
when(request.retryStrategy()).thenReturn(retryStrategy);
RequestContext requestContext = mock(RequestContext.class);
when(request.context()).thenReturn(requestContext);
CoreEnvironment env = mock(CoreEnvironment.class);
SimpleEventBus eventBus = new SimpleEventBus(true);
when(env.eventBus()).thenReturn(eventBus);
CoreContext context = new CoreContext(mock(Core.class), 1, env, mock(Authenticator.class));
RetryOrchestrator.maybeRetry(context, request, RetryReason.UNKNOWN);
verify(request, times(1)).cancel(CancellationReason.noMoreRetries(RetryReason.UNKNOWN), Function.identity());
assertEquals(1, eventBus.publishedEvents().size());
RequestNotRetriedEvent retryEvent = (RequestNotRetriedEvent) eventBus.publishedEvents().get(0);
assertEquals(Event.Severity.INFO, retryEvent.severity());
assertEquals(Event.Category.REQUEST.path(), retryEvent.category());
assertEquals(requestContext, retryEvent.context());
}
use of com.couchbase.client.core.env.CoreEnvironment in project couchbase-jvm-clients by couchbase.
the class SearchMock method loadSearchTestCase.
/**
* Given JSON in the form expected, e.g. those from https://github.com/chvck/sdk-testcases which contains the
* returned JSON from the search service in a field "data", returns the completed SearchResult that the API
* would return.
*/
public static SearchResult loadSearchTestCase(InputStream json) throws ExecutionException, InterruptedException, IOException {
// The idea is to fake packets that have come from the search service.
// Start by preparing the packets.
JsonObject jo = JsonObject.fromJson(toByteArray(json));
JsonObject data = jo.getObject("data");
byte[] b = data.toString().getBytes(StandardCharsets.UTF_8);
ByteBuf bytes = Unpooled.wrappedBuffer(b);
HttpContent content = new DefaultLastHttpContent(bytes);
HttpResponse resp = new DefaultHttpResponse(HttpVersion.HTTP_1_1, HttpResponseStatus.OK);
// Fake some core stuff
Core mockedCore = mock(Core.class);
CoreEnvironment env = CoreEnvironment.create();
CoreContext ctx = new CoreContext(mockedCore, 0, env, PasswordAuthenticator.create("Administrator", "password"));
// Our ChunkedSearchMessageHandler needs to be initialised by pretending we've sent an outbound SearchRequest
// through it
SearchRequest req = new SearchRequest(Duration.ofSeconds(10), ctx, BestEffortRetryStrategy.INSTANCE, null, null, null, null);
// ChunkedSearchMessageHandler will try to encode() the SearchRequest. Rather than mocking everything required
// to get that working, just mock the encode method.
SearchRequest spiedReq = spy(req);
doReturn(new DefaultFullHttpRequest(HttpVersion.HTTP_1_1, HttpMethod.GET, "localhost")).when(spiedReq).encode();
doAnswer(v -> {
EndpointContext endpointContext = new EndpointContext(ctx, new HostAndPort(null, 0), null, null, null, Optional.of("bucket"), null);
BaseEndpoint endpoint = mock(BaseEndpoint.class);
when(endpoint.context()).thenReturn(endpointContext);
when(endpoint.pipelined()).thenReturn(false);
// ChunkedSearchMessageHandler does most of the work in handling responses from the service
ChunkedSearchMessageHandler handler = new ChunkedSearchMessageHandler(endpoint, endpointContext);
// Netty's EmbeddedChannel lets us test ChannelHandlers like ChunkedSearchMessageHandler. It's a Netty Channel
// that doesn't touch the network at all.
final EmbeddedChannel channel = new EmbeddedChannel(handler);
// Writing the request is necessary to estabish some initial state inChunkedSearchMessageHandler
channel.writeAndFlush(spiedReq);
// Finally we can do the interesting bit of passing our fake FTS service response into
// ChunkedSearchMessageHandler
channel.writeInbound(resp);
channel.writeInbound(content);
return null;
}).when(mockedCore).send(any());
CompletableFuture<SearchResult> future = SearchAccessor.searchQueryAsync(mockedCore, req, DefaultJsonSerializer.create());
SearchResult result = future.get();
return result;
}
use of com.couchbase.client.core.env.CoreEnvironment in project couchbase-jvm-clients by couchbase.
the class ErrorMapLoadingHandlerTest method failConnectIfPromiseTimesOut.
/**
* This test makes sure that the timer fires if the connect future is not completed
* otherwise.
*/
@Test
void failConnectIfPromiseTimesOut() throws Exception {
channel = new EmbeddedChannel();
eventBus = new SimpleEventBus(true);
CoreEnvironment env = mock(CoreEnvironment.class);
TimeoutConfig timeoutConfig = mock(TimeoutConfig.class);
when(env.eventBus()).thenReturn(eventBus);
when(env.timeoutConfig()).thenReturn(timeoutConfig);
when(timeoutConfig.connectTimeout()).thenReturn(Duration.ofMillis(100));
CoreContext coreContext = new CoreContext(mock(Core.class), 1, env, mock(Authenticator.class));
EndpointContext endpointContext = new EndpointContext(coreContext, new HostAndPort("127.0.0.1", 1234), null, ServiceType.KV, Optional.empty(), Optional.empty(), Optional.empty());
ErrorMapLoadingHandler handler = new ErrorMapLoadingHandler(endpointContext);
channel.pipeline().addLast(handler);
final ChannelFuture connect = channel.connect(new InetSocketAddress("1.2.3.4", 1234));
channel.pipeline().fireChannelActive();
Thread.sleep(Duration.ofMillis(100).toMillis() + 5);
channel.runScheduledPendingTasks();
assertTrue(connect.isDone());
assertTrue(connect.cause() instanceof TimeoutException);
assertEquals("KV Error Map loading timed out after 100ms", connect.cause().getMessage());
}
Aggregations