Search in sources :

Example 11 with Response

use of org.apache.servicecomb.swagger.invocation.Response in project incubator-servicecomb-java-chassis by apache.

the class TestAbstractRestInvocation method doInvoke.

@Test
public void doInvoke(@Mocked Endpoint endpoint, @Mocked OperationMeta operationMeta, @Mocked Object[] swaggerArguments, @Mocked SchemaMeta schemaMeta) throws Throwable {
    Response response = Response.ok("ok");
    Handler handler = new Handler() {

        @Override
        public void handle(Invocation invocation, AsyncResponse asyncResp) {
            asyncResp.complete(response);
        }
    };
    List<Handler> handlerChain = Arrays.asList(handler);
    Deencapsulation.setField(invocation, "handlerList", handlerChain);
    Holder<Response> result = new Holder<>();
    restInvocation = new AbstractRestInvocationForTest() {

        @Override
        protected void sendResponseQuietly(Response response) {
            result.value = response;
        }
    };
    restInvocation.invocation = invocation;
    restInvocation.doInvoke();
    Assert.assertSame(response, result.value);
}
Also used : AsyncResponse(org.apache.servicecomb.swagger.invocation.AsyncResponse) Response(org.apache.servicecomb.swagger.invocation.Response) Invocation(org.apache.servicecomb.core.Invocation) Holder(javax.xml.ws.Holder) Handler(org.apache.servicecomb.core.Handler) AsyncResponse(org.apache.servicecomb.swagger.invocation.AsyncResponse) Test(org.junit.Test)

Example 12 with Response

use of org.apache.servicecomb.swagger.invocation.Response in project incubator-servicecomb-java-chassis by apache.

the class TestAbstractRestInvocation method invokeFilterHaveResponse.

@Test
public void invokeFilterHaveResponse(@Mocked HttpServerFilter filter) {
    Response response = Response.ok("");
    new Expectations() {

        {
            filter.afterReceiveRequest(invocation, requestEx);
            result = response;
        }
    };
    Holder<Response> result = new Holder<>();
    restInvocation = new AbstractRestInvocationForTest() {

        @Override
        protected void doInvoke() {
            result.value = Response.ok("not run to here");
        }

        @Override
        protected void sendResponseQuietly(Response response) {
            result.value = response;
        }
    };
    initRestInvocation();
    restInvocation.httpServerFilters = Arrays.asList(filter);
    restInvocation.invoke();
    Assert.assertSame(response, result.value);
}
Also used : AsyncResponse(org.apache.servicecomb.swagger.invocation.AsyncResponse) Response(org.apache.servicecomb.swagger.invocation.Response) Expectations(mockit.Expectations) Holder(javax.xml.ws.Holder) Test(org.junit.Test)

Example 13 with Response

use of org.apache.servicecomb.swagger.invocation.Response in project incubator-servicecomb-java-chassis by apache.

the class AbstractRestInvocation method sendFailResponse.

public void sendFailResponse(Throwable throwable) {
    if (produceProcessor == null) {
        produceProcessor = ProduceProcessorManager.DEFAULT_PROCESSOR;
    }
    Response response = Response.createProducerFail(throwable);
    sendResponseQuietly(response);
}
Also used : Response(org.apache.servicecomb.swagger.invocation.Response)

Example 14 with Response

use of org.apache.servicecomb.swagger.invocation.Response in project incubator-servicecomb-java-chassis by apache.

the class AbstractRestInvocation method invoke.

public void invoke() {
    try {
        Response response = prepareInvoke();
        if (response != null) {
            sendResponseQuietly(response);
            return;
        }
        doInvoke();
    } catch (Throwable e) {
        LOGGER.error("unknown rest exception.", e);
        sendFailResponse(e);
    }
}
Also used : Response(org.apache.servicecomb.swagger.invocation.Response)

Example 15 with Response

use of org.apache.servicecomb.swagger.invocation.Response in project incubator-servicecomb-java-chassis by apache.

the class LoadbalanceHandler method sendWithRetry.

private void sendWithRetry(Invocation invocation, AsyncResponse asyncResp, final LoadBalancer chosenLB) throws Exception {
    long time = System.currentTimeMillis();
    // retry in loadbalance, 2.0 feature
    final int currentHandler = invocation.getHandlerIndex();
    final SyncResponseExecutor orginExecutor;
    final Executor newExecutor;
    if (invocation.getResponseExecutor() instanceof SyncResponseExecutor) {
        orginExecutor = (SyncResponseExecutor) invocation.getResponseExecutor();
        newExecutor = new Executor() {

            @Override
            public void execute(Runnable command) {
                // retry的场景,对于同步调用, 同步调用的主线程已经被挂起,无法再主线程中进行重试;
                // 重试也不能在网络线程(event-loop)中进行,未被保护的阻塞操作会导致网络线程挂起
                RETRY_POOL.submit(command);
            }
        };
        invocation.setResponseExecutor(newExecutor);
    } else {
        orginExecutor = null;
        newExecutor = null;
    }
    ExecutionListener<Invocation, Response> listener = new ExecutionListener<Invocation, Response>() {

        @Override
        public void onExecutionStart(ExecutionContext<Invocation> context) throws AbortExecutionException {
        }

        @Override
        public void onStartWithServer(ExecutionContext<Invocation> context, ExecutionInfo info) throws AbortExecutionException {
        }

        @Override
        public void onExceptionWithServer(ExecutionContext<Invocation> context, Throwable exception, ExecutionInfo info) {
            LOGGER.error("onExceptionWithServer msg {}; server {}", exception.getMessage(), context.getRequest().getEndpoint());
        }

        @Override
        public void onExecutionSuccess(ExecutionContext<Invocation> context, Response response, ExecutionInfo info) {
            if (orginExecutor != null) {
                orginExecutor.execute(() -> {
                    asyncResp.complete(response);
                });
            } else {
                asyncResp.complete(response);
            }
        }

        @Override
        public void onExecutionFailed(ExecutionContext<Invocation> context, Throwable finalException, ExecutionInfo info) {
            if (orginExecutor != null) {
                orginExecutor.execute(() -> {
                    asyncResp.consumerFail(finalException);
                });
            } else {
                asyncResp.consumerFail(finalException);
            }
        }
    };
    List<ExecutionListener<Invocation, Response>> listeners = new ArrayList<>(0);
    listeners.add(listener);
    ExecutionContext<Invocation> context = new ExecutionContext<>(invocation, null, null, null);
    LoadBalancerCommand<Response> command = LoadBalancerCommand.<Response>builder().withLoadBalancer(chosenLB).withServerLocator(invocation).withRetryHandler(ExtensionsManager.createRetryHandler(invocation.getMicroserviceName())).withListeners(listeners).withExecutionContext(context).build();
    Observable<Response> observable = command.submit(new ServerOperation<Response>() {

        public Observable<Response> call(Server s) {
            return Observable.create(f -> {
                try {
                    ((CseServer) s).setLastVisitTime(time);
                    chosenLB.getLoadBalancerStats().incrementNumRequests(s);
                    // for retry
                    invocation.setHandlerIndex(currentHandler);
                    invocation.setEndpoint(((CseServer) s).getEndpoint());
                    invocation.next(resp -> {
                        if (resp.isFailed()) {
                            LOGGER.error("service call error, msg is {}, server is {} ", ((Throwable) resp.getResult()).getMessage(), s);
                            chosenLB.getLoadBalancerStats().incrementSuccessiveConnectionFailureCount(s);
                            ((CseServer) s).incrementContinuousFailureCount();
                            f.onError(resp.getResult());
                        } else {
                            chosenLB.getLoadBalancerStats().incrementActiveRequestsCount(s);
                            ((CseServer) s).clearContinuousFailure();
                            chosenLB.getLoadBalancerStats().noteResponseTime(s, (System.currentTimeMillis() - time));
                            f.onNext(resp);
                            f.onCompleted();
                        }
                    });
                } catch (Exception e) {
                    LOGGER.error("execution error, msg is " + e.getMessage());
                    f.onError(e);
                }
            });
        }
    });
    observable.subscribe(response -> {
    }, error -> {
    }, () -> {
    });
}
Also used : LoggerFactory(org.slf4j.LoggerFactory) DiscoveryTree(org.apache.servicecomb.serviceregistry.discovery.DiscoveryTree) AsyncResponse(org.apache.servicecomb.swagger.invocation.AsyncResponse) StringUtils(org.apache.commons.lang3.StringUtils) ArrayList(java.util.ArrayList) Observable(rx.Observable) AtomicInteger(java.util.concurrent.atomic.AtomicInteger) TransactionControlFilter(org.apache.servicecomb.loadbalance.filter.TransactionControlFilter) CseServerDiscoveryFilter(org.apache.servicecomb.loadbalance.filter.CseServerDiscoveryFilter) Map(java.util.Map) LoadBalancerCommand(com.netflix.loadbalancer.reactive.LoadBalancerCommand) ConcurrentHashMapEx(org.apache.servicecomb.foundation.common.concurrent.ConcurrentHashMapEx) ThreadFactory(java.util.concurrent.ThreadFactory) Response(org.apache.servicecomb.swagger.invocation.Response) ExecutorService(java.util.concurrent.ExecutorService) DiscoveryFilter(org.apache.servicecomb.serviceregistry.discovery.DiscoveryFilter) SyncResponseExecutor(org.apache.servicecomb.core.provider.consumer.SyncResponseExecutor) Logger(org.slf4j.Logger) ExecutionListener(com.netflix.loadbalancer.reactive.ExecutionListener) Executor(java.util.concurrent.Executor) Handler(org.apache.servicecomb.core.Handler) ExceptionUtils(org.apache.servicecomb.core.exception.ExceptionUtils) Server(com.netflix.loadbalancer.Server) VersionedCache(org.apache.servicecomb.foundation.common.cache.VersionedCache) Executors(java.util.concurrent.Executors) Invocation(org.apache.servicecomb.core.Invocation) ExecutionContext(com.netflix.loadbalancer.reactive.ExecutionContext) List(java.util.List) IsolationServerListFilter(org.apache.servicecomb.loadbalance.filter.IsolationServerListFilter) DiscoveryContext(org.apache.servicecomb.serviceregistry.discovery.DiscoveryContext) IRule(com.netflix.loadbalancer.IRule) ExecutionInfo(com.netflix.loadbalancer.reactive.ExecutionInfo) ServerOperation(com.netflix.loadbalancer.reactive.ServerOperation) Invocation(org.apache.servicecomb.core.Invocation) Server(com.netflix.loadbalancer.Server) SyncResponseExecutor(org.apache.servicecomb.core.provider.consumer.SyncResponseExecutor) ArrayList(java.util.ArrayList) ExecutionInfo(com.netflix.loadbalancer.reactive.ExecutionInfo) Observable(rx.Observable) ExecutionListener(com.netflix.loadbalancer.reactive.ExecutionListener) AsyncResponse(org.apache.servicecomb.swagger.invocation.AsyncResponse) Response(org.apache.servicecomb.swagger.invocation.Response) SyncResponseExecutor(org.apache.servicecomb.core.provider.consumer.SyncResponseExecutor) Executor(java.util.concurrent.Executor) ExecutionContext(com.netflix.loadbalancer.reactive.ExecutionContext)

Aggregations

Response (org.apache.servicecomb.swagger.invocation.Response)65 Test (org.junit.Test)44 Invocation (org.apache.servicecomb.core.Invocation)17 AsyncResponse (org.apache.servicecomb.swagger.invocation.AsyncResponse)14 OperationMeta (org.apache.servicecomb.core.definition.OperationMeta)11 InvocationException (org.apache.servicecomb.swagger.invocation.exception.InvocationException)8 Expectations (mockit.Expectations)7 ResponseEntity (org.springframework.http.ResponseEntity)7 HystrixCommandProperties (com.netflix.hystrix.HystrixCommandProperties)6 MockUp (mockit.MockUp)6 Method (java.lang.reflect.Method)5 Headers (org.apache.servicecomb.swagger.invocation.response.Headers)5 Holder (javax.xml.ws.Holder)4 User (org.apache.servicecomb.demo.server.User)4 InvocationContext (org.apache.servicecomb.swagger.invocation.context.InvocationContext)4 CommonExceptionData (org.apache.servicecomb.swagger.invocation.exception.CommonExceptionData)4 HttpHeaders (org.springframework.http.HttpHeaders)4 ApiResponse (io.swagger.annotations.ApiResponse)3 List (java.util.List)3 ResponseHeaders (org.apache.servicecomb.swagger.extend.annotations.ResponseHeaders)3