Search in sources :

Example 6 with Metrics

use of io.mantisrx.common.metrics.Metrics in project mantis by Netflix.

the class PushServerSse method createServer.

@Override
public RxServer<?, ?> createServer() {
    RxServer<HttpServerRequest<String>, HttpServerResponse<ServerSentEvent>> server = RxNetty.newHttpServerBuilder(port, new RequestHandler<String, ServerSentEvent>() {

        @Override
        public Observable<Void> handle(HttpServerRequest<String> request, final HttpServerResponse<ServerSentEvent> response) {
            final Map<String, List<String>> queryParameters = request.getQueryParameters();
            final Counter sseProcessedCounter;
            final Counter sseDroppedCounter;
            // heartbeat state
            boolean enableHeartbeats = false;
            boolean enableBinaryOutput = false;
            final AtomicLong heartBeatReadIdleSec = new AtomicLong(2);
            SerializedSubject<String, String> metaMsgSubject = PublishSubject.<String>create().toSerialized();
            final AtomicLong metaMessagesFreqMSec = new AtomicLong(1000);
            boolean enableMetaMessages = false;
            final AtomicLong lastWriteTime = new AtomicLong();
            Subscription heartbeatSubscription = null;
            Subscription metaMsgSubscription = null;
            // sample state
            boolean enableSampling = false;
            long samplingTimeMsec = 0;
            // client state
            String groupId = null;
            String slotId = null;
            String id = null;
            Func1<T, Boolean> predicateFunction = null;
            if (predicate != null) {
                predicateFunction = predicate.call(queryParameters);
            }
            byte[] delimiter = CompressionUtils.MANTIS_SSE_DELIMITER_BINARY;
            if (queryParameters != null && !queryParameters.isEmpty()) {
                if (queryParameters.containsKey(MantisSSEConstants.ID)) {
                    id = queryParameters.get(MantisSSEConstants.ID).get(0);
                }
                if (queryParameters.containsKey(MantisSSEConstants.SLOT_ID)) {
                    slotId = queryParameters.get(MantisSSEConstants.SLOT_ID).get(0);
                }
                // support groupId and clientId for grouping
                if (queryParameters.containsKey(MantisSSEConstants.GROUP_ID)) {
                    groupId = queryParameters.get(MantisSSEConstants.GROUP_ID).get(0);
                }
                if (queryParameters.containsKey(MantisSSEConstants.CLIENT_ID)) {
                    groupId = queryParameters.get(MantisSSEConstants.CLIENT_ID).get(0);
                }
                if (queryParameters.containsKey(MantisSSEConstants.HEARTBEAT_SEC)) {
                    heartBeatReadIdleSec.set(Long.parseLong(queryParameters.get(MantisSSEConstants.HEARTBEAT_SEC).get(0)));
                    if (heartBeatReadIdleSec.get() < 1) {
                        throw new IllegalArgumentException("Sampling rate too low: " + samplingTimeMsec);
                    }
                    enableHeartbeats = true;
                }
                if (queryParameters != null && queryParameters.containsKey(MantisSSEConstants.MANTIS_ENABLE_COMPRESSION)) {
                    String enableBinaryOutputStr = queryParameters.get(MantisSSEConstants.MANTIS_ENABLE_COMPRESSION).get(0);
                    if ("true".equalsIgnoreCase(enableBinaryOutputStr)) {
                        logger.info("Binary compression requested");
                        enableBinaryOutput = true;
                    }
                }
                if (queryParameters.containsKey(MantisSSEConstants.ENABLE_PINGS)) {
                    String enablePings = queryParameters.get(MantisSSEConstants.ENABLE_PINGS).get(0);
                    if ("true".equalsIgnoreCase(enablePings)) {
                        enableHeartbeats = true;
                    }
                }
                if (queryParameters.containsKey(MantisSSEConstants.ENABLE_META_MESSAGES)) {
                    String enableMetaMessagesStr = queryParameters.get(MantisSSEConstants.ENABLE_META_MESSAGES).get(0);
                    if ("true".equalsIgnoreCase(enableMetaMessagesStr)) {
                        enableMetaMessages = true;
                    }
                }
                if (queryParameters.containsKey(MantisSSEConstants.META_MESSAGES_SEC)) {
                    metaMessagesFreqMSec.set(Long.parseLong(queryParameters.get(MantisSSEConstants.META_MESSAGES_SEC).get(0)));
                    if (metaMessagesFreqMSec.get() < 250) {
                        throw new IllegalArgumentException("Meta message frequence rate too low: " + metaMessagesFreqMSec.get());
                    }
                    enableMetaMessages = true;
                }
                if (queryParameters.containsKey(MantisSSEConstants.SAMPLE)) {
                    samplingTimeMsec = Long.parseLong(queryParameters.get(MantisSSEConstants.SAMPLE).get(0)) * 1000;
                    if (samplingTimeMsec < 50) {
                        throw new IllegalArgumentException("Sampling rate too low: " + samplingTimeMsec);
                    }
                    enableSampling = true;
                }
                if (queryParameters.containsKey(MantisSSEConstants.SAMPLE_M_SEC)) {
                    samplingTimeMsec = Long.parseLong(queryParameters.get(MantisSSEConstants.SAMPLE_M_SEC).get(0));
                    if (samplingTimeMsec < 50) {
                        throw new IllegalArgumentException("Sampling rate too low: " + samplingTimeMsec);
                    }
                    enableSampling = true;
                }
                if (queryParameters.containsKey(MantisSSEConstants.MANTIS_COMPRESSION_DELIMITER)) {
                    String rawDelimiter = queryParameters.get(MantisSSEConstants.MANTIS_COMPRESSION_DELIMITER).get(0);
                    if (rawDelimiter != null && !rawDelimiter.isEmpty()) {
                        delimiter = rawDelimiter.getBytes();
                    }
                }
                if (queryParameters.containsKey(MantisSSEConstants.MQL)) {
                    String query = queryParameters.get(MantisSSEConstants.MQL).get(0);
                    if ((Boolean) mqlParses.invoke(query)) {
                        Query q = (Query) mqlMakeQuery.invoke(groupId, query);
                        predicateFunction = (T datum) -> datum instanceof Map ? q.matches((Map) datum) : true;
                    }
                }
            }
            InetSocketAddress socketAddress = (InetSocketAddress) response.getChannel().remoteAddress();
            Metrics metrics;
            if (groupId == null) {
                String address = socketAddress.getAddress().toString();
                metrics = registerSseMetrics(address, address);
            } else {
                metrics = registerSseMetrics(groupId, socketAddress.getAddress().toString());
            }
            sseProcessedCounter = metrics.getCounter(PROCESSED_COUNTER_METRIC_NAME);
            sseDroppedCounter = metrics.getCounter(DROPPED_COUNTER_METRIC_NAME);
            response.getHeaders().set("Access-Control-Allow-Origin", "*");
            response.getHeaders().set("content-type", "text/event-stream");
            response.getHeaders().set("Cache-Control", "no-cache, no-store, max-age=0, must-revalidate");
            response.getHeaders().set("Pragma", "no-cache");
            response.flush();
            if (queryParameters != null && requestPreprocessor != null) {
                requestPreprocessor.call(queryParameters, processorState);
            }
            if (enableMetaMessages && metaMessagesFreqMSec.get() > 0) {
                logger.info("Enabling Meta messages, interval : " + metaMessagesFreqMSec.get() + " ms");
                metaMsgSubscription = metaMsgSubject.throttleLast(metaMessagesFreqMSec.get(), TimeUnit.MILLISECONDS).doOnNext((String t) -> {
                    if (t != null && !t.isEmpty()) {
                        long currentTime = System.currentTimeMillis();
                        ByteBuf data = response.getAllocator().buffer().writeBytes(t.getBytes());
                        response.writeAndFlush(new ServerSentEvent(data));
                        lastWriteTime.set(currentTime);
                    }
                }).subscribe();
            }
            if (enableHeartbeats && heartBeatReadIdleSec.get() > 0) {
                logger.info("Enabling hearts, interval: " + heartBeatReadIdleSec);
                heartbeatSubscription = Observable.interval(2, heartBeatReadIdleSec.get(), TimeUnit.SECONDS).doOnNext((Long t1) -> {
                    long currentTime = System.currentTimeMillis();
                    long diff = (currentTime - lastWriteTime.get()) / 1000;
                    if (diff > heartBeatReadIdleSec.get()) {
                        ByteBuf data = response.getAllocator().buffer().writeBytes("ping".getBytes());
                        response.writeAndFlush(new ServerSentEvent(data));
                        lastWriteTime.set(currentTime);
                    }
                }).subscribe();
            }
            Action0 connectionClosedCallback = null;
            if (queryParameters != null && requestPostprocessor != null) {
                connectionClosedCallback = new Action0() {

                    @Override
                    public void call() {
                        requestPostprocessor.call(queryParameters, processorState);
                    }
                };
            }
            class SubscribeCallback implements Action0 {

                @Override
                public void call() {
                    if (queryParameters != null && subscribeProcessor != null) {
                        subscribeProcessor.call(queryParameters, processorState);
                    }
                }
            }
            return manageConnectionWithCompression(response, socketAddress.getHostString(), socketAddress.getPort(), groupId, slotId, id, lastWriteTime, enableHeartbeats, heartbeatSubscription, enableSampling, samplingTimeMsec, metaMsgSubject, metaMsgSubscription, predicateFunction, connectionClosedCallback, sseProcessedCounter, sseDroppedCounter, new SubscribeCallback(), enableBinaryOutput, true, delimiter);
        }
    }).pipelineConfigurator(PipelineConfigurators.serveSseConfigurator()).channelOption(ChannelOption.WRITE_BUFFER_WATER_MARK, new WriteBufferWaterMark(1024 * 1024, 5 * 1024 * 1024)).build();
    return server;
}
Also used : Query(io.mantisrx.mql.jvm.core.Query) InetSocketAddress(java.net.InetSocketAddress) ServerSentEvent(mantis.io.reactivex.netty.protocol.http.sse.ServerSentEvent) ByteBuf(io.netty.buffer.ByteBuf) Metrics(io.mantisrx.common.metrics.Metrics) Counter(io.mantisrx.common.metrics.Counter) HttpServerResponse(mantis.io.reactivex.netty.protocol.http.server.HttpServerResponse) List(java.util.List) WriteBufferWaterMark(io.netty.channel.WriteBufferWaterMark) Subscription(rx.Subscription) Action0(rx.functions.Action0) HttpServerRequest(mantis.io.reactivex.netty.protocol.http.server.HttpServerRequest) AtomicLong(java.util.concurrent.atomic.AtomicLong) RequestHandler(mantis.io.reactivex.netty.protocol.http.server.RequestHandler) AtomicLong(java.util.concurrent.atomic.AtomicLong) Map(java.util.Map)

Example 7 with Metrics

use of io.mantisrx.common.metrics.Metrics in project mantis by Netflix.

the class PushServerSse method registerSseMetrics.

private Metrics registerSseMetrics(String uniqueClientId, String socketAddrStr) {
    final BasicTag clientIdTag = new BasicTag(CLIENT_ID_TAG_NAME, Optional.ofNullable(uniqueClientId).orElse("none"));
    final BasicTag sockAddrTag = new BasicTag(SOCK_ADDR_TAG_NAME, Optional.ofNullable(socketAddrStr).orElse("none"));
    final String metricGroup = supportLegacyMetrics ? PUSH_SERVER_LEGACY_METRIC_GROUP_NAME : PUSH_SERVER_METRIC_GROUP_NAME;
    Metrics sseSinkMetrics = new Metrics.Builder().id(metricGroup, clientIdTag, sockAddrTag).addCounter(PROCESSED_COUNTER_METRIC_NAME).addCounter(DROPPED_COUNTER_METRIC_NAME).build();
    sseSinkMetrics = metricsRegistry.registerAndGet(sseSinkMetrics);
    return sseSinkMetrics;
}
Also used : BasicTag(com.netflix.spectator.api.BasicTag) Metrics(io.mantisrx.common.metrics.Metrics)

Example 8 with Metrics

use of io.mantisrx.common.metrics.Metrics in project mantis by Netflix.

the class DataDroppedPayloadSetterTest method testAggregateDropOperatorMetrics.

@Test
public void testAggregateDropOperatorMetrics() throws Exception {
    SpectatorRegistryFactory.setRegistry(new DefaultRegistry());
    Heartbeat heartbeat = new Heartbeat("job-1", 1, 1, 1);
    DataDroppedPayloadSetter payloadSetter = new DataDroppedPayloadSetter(heartbeat);
    Metrics m = new Metrics.Builder().id(METRIC_GROUP + "_" + INCOMING + "_metric1").addCounter(DropOperator.Counters.dropped.toString()).addCounter(DropOperator.Counters.onNext.toString()).build();
    m = MetricsRegistry.getInstance().registerAndGet(m);
    m.getCounter(DropOperator.Counters.dropped.toString()).increment(1);
    m.getCounter(DropOperator.Counters.onNext.toString()).increment(10);
    m = new Metrics.Builder().id(METRIC_GROUP + "_" + INCOMING + "_metric2").addCounter(DropOperator.Counters.dropped.toString()).addCounter(DropOperator.Counters.onNext.toString()).build();
    m = MetricsRegistry.getInstance().registerAndGet(m);
    m.getCounter(DropOperator.Counters.dropped.toString()).increment(100);
    m.getCounter(DropOperator.Counters.onNext.toString()).increment(1000);
    payloadSetter.setPayload(30);
    m = MetricsRegistry.getInstance().getMetric(new MetricGroupId(DATA_DROP_METRIC_GROUP));
    assertEquals(101L, m.getGauge(DROP_COUNT).value());
    assertEquals(1010, m.getGauge(ON_NEXT_COUNT).value());
}
Also used : Metrics(io.mantisrx.common.metrics.Metrics) DefaultRegistry(com.netflix.spectator.api.DefaultRegistry) MetricGroupId(io.mantisrx.common.metrics.spectator.MetricGroupId) Test(org.junit.Test)

Example 9 with Metrics

use of io.mantisrx.common.metrics.Metrics in project mantis by Netflix.

the class AbstractAckableTaggingStage method tagData.

@SuppressWarnings("unchecked")
protected List<TaggedData> tagData(Map<String, Object> d, Context context) {
    List<TaggedData> taggedDataList = new ArrayList<>();
    boolean metaEvent = isMetaEvent(d);
    Metrics metrics = context.getMetricsRegistry().getMetric("mql");
    Collection<Query> queries = MQLQueryManager.getInstance().getRegisteredQueries();
    Iterator<Query> it = queries.iterator();
    while (it.hasNext()) {
        Query query = it.next();
        try {
            if (metaEvent) {
                TaggedData tg = new TaggedData(d);
                tg.addMatchedClient(query.getSubscriptionId());
                taggedDataList.add(tg);
            } else if (query.matches(d)) {
                Map<String, Object> projected = query.project(d);
                projected.put(MANTIS_META_SOURCE_NAME, d.get(MANTIS_META_SOURCE_NAME));
                projected.put(MANTIS_META_SOURCE_TIMESTAMP, d.get(MANTIS_META_SOURCE_TIMESTAMP));
                TaggedData tg = new TaggedData(projected);
                tg.addMatchedClient(query.getSubscriptionId());
                taggedDataList.add(tg);
            }
        } catch (Exception ex) {
            if (ex instanceof ClassNotFoundException) {
                logger.error("Error loading MQL: " + ex.getMessage());
                ex.printStackTrace();
                metrics.getCounter(MQL_CLASSLOADER_ERROR).increment();
            } else {
                ex.printStackTrace();
                metrics.getCounter(MQL_FAILURE).increment();
                logger.error("MQL Error: " + ex.getMessage());
                logger.error("MQL Query: " + query.getRawQuery());
                logger.error("MQL Datum: " + d);
            }
        } catch (Error e) {
            metrics.getCounter(MQL_FAILURE).increment();
            if (!errorLogged.get()) {
                logger.error("caught Error when processing MQL {} on {}", query.getRawQuery(), d.toString(), e);
                errorLogged.set(true);
            }
        }
    }
    return taggedDataList;
}
Also used : Metrics(io.mantisrx.common.metrics.Metrics) Query(io.mantisrx.mql.jvm.core.Query) ArrayList(java.util.ArrayList) TaggedData(io.mantisrx.sourcejob.kafka.core.TaggedData) HashMap(java.util.HashMap) Map(java.util.Map)

Example 10 with Metrics

use of io.mantisrx.common.metrics.Metrics in project mantis by Netflix.

the class ServerSentEventRequestHandler method handle.

@Override
public Observable<Void> handle(HttpServerRequest<ByteBuf> request, final HttpServerResponse<ServerSentEvent> response) {
    InetSocketAddress socketAddress = (InetSocketAddress) response.getChannel().remoteAddress();
    LOG.info("HTTP SSE connection received from " + socketAddress.getAddress() + ":" + socketAddress.getPort() + "  queryParams: " + request.getQueryParameters());
    final String socketAddrStr = socketAddress.getAddress().toString();
    final WritableEndpoint<String> sn = new WritableEndpoint<>(socketAddress.getHostString(), socketAddress.getPort(), Endpoint.uniqueHost(socketAddress.getHostString(), socketAddress.getPort(), null));
    final Map<String, List<String>> queryParameters = request.getQueryParameters();
    final SlotAssignmentManager<String> slotMgr = ssm.registerServer(sn, queryParameters);
    final AtomicLong lastResponseFlush = new AtomicLong();
    lastResponseFlush.set(-1);
    final AtomicLong lastResponseSent = new AtomicLong(-1);
    // copy reference, then apply request specific filters, sampling
    Observable<T> requestObservable = observableToServe;
    // decouple the observable on a separate thread and add backpressure handling
    // ServiceRegistry.INSTANCE.getPropertiesService().getStringValue("sse.decouple", "false");
    String decoupleSSE = "false";
    if ("true".equals(decoupleSSE)) {
        final BasicTag sockAddrTag = new BasicTag("sockAddr", Optional.ofNullable(socketAddrStr).orElse("none"));
        requestObservable = requestObservable.lift(new DropOperator<T>("outgoing_ServerSentEventRequestHandler", sockAddrTag)).observeOn(Schedulers.io());
    }
    response.getHeaders().set("Access-Control-Allow-Origin", "*");
    response.getHeaders().set("content-type", "text/event-stream");
    response.getHeaders().set("Cache-Control", "no-cache, no-store, max-age=0, must-revalidate");
    response.getHeaders().set("Pragma", "no-cache");
    response.flush();
    String uniqueClientId = socketAddrStr;
    if (queryParameters != null && queryParameters.containsKey(CLIENT_ID_PARAM)) {
        // enablePings
        uniqueClientId = queryParameters.get(CLIENT_ID_PARAM).get(0);
    }
    if (queryParameters != null && queryParameters.containsKey(FORMAT_PARAM)) {
        format = queryParameters.get(FORMAT_PARAM).get(0);
    }
    if (queryParameters != null && requestPreprocessor != null) {
        requestPreprocessor.call(queryParameters, context);
    }
    // apply sampling, milli, then seconds
    if (queryParameters != null && queryParameters.containsKey(SAMPLE_PARAM_MSEC)) {
        // apply sampling rate
        int samplingRate = Integer.parseInt(queryParameters.get(SAMPLE_PARAM_MSEC).get(0));
        requestObservable = requestObservable.sample(samplingRate, TimeUnit.MILLISECONDS);
    }
    if (queryParameters != null && queryParameters.containsKey(SAMPLE_PARAM)) {
        // apply sampling rate
        int samplingRate = Integer.parseInt(queryParameters.get(SAMPLE_PARAM).get(0));
        requestObservable = requestObservable.sample(samplingRate, TimeUnit.SECONDS);
    }
    if (queryParameters != null && queryParameters.containsKey(ENABLE_PINGS_PARAM)) {
        // enablePings
        String enablePings = queryParameters.get(ENABLE_PINGS_PARAM).get(0);
        if ("true".equalsIgnoreCase(enablePings)) {
            pingsEnabled = true;
        } else {
            pingsEnabled = false;
        }
    }
    if (queryParameters != null && queryParameters.containsKey("delay")) {
        // apply flush
        try {
            int flushInterval = Integer.parseInt(queryParameters.get("delay").get(0));
            if (flushInterval >= 50) {
                flushIntervalMillis = flushInterval;
            } else {
                LOG.warn("delay parameter too small " + flushInterval + " min. is 100");
            }
        } catch (Exception e) {
            e.printStackTrace();
        }
    }
    final byte[] delimiter = queryParameters != null && queryParameters.containsKey(MantisSSEConstants.MANTIS_COMPRESSION_DELIMITER) && queryParameters.get(MantisSSEConstants.MANTIS_COMPRESSION_DELIMITER).get(0) != null ? queryParameters.get(MantisSSEConstants.MANTIS_COMPRESSION_DELIMITER).get(0).getBytes() : null;
    Tag[] tags = new Tag[2];
    final String clientId = Optional.ofNullable(uniqueClientId).orElse("none");
    final String sockAddr = Optional.ofNullable(socketAddrStr).orElse("none");
    tags[0] = new BasicTag("clientId", clientId);
    tags[1] = new BasicTag("sockAddr", sockAddr);
    Metrics sseSinkMetrics = new Metrics.Builder().id("ServerSentEventRequestHandler", tags).addCounter("processedCounter").addCounter("pingCounter").addCounter("errorCounter").addCounter("droppedCounter").addCounter("flushCounter").build();
    final Counter msgProcessedCounter = sseSinkMetrics.getCounter("processedCounter");
    final Counter pingCounter = sseSinkMetrics.getCounter("pingCounter");
    final Counter errorCounter = sseSinkMetrics.getCounter("errorCounter");
    final Counter droppedWrites = sseSinkMetrics.getCounter("droppedCounter");
    final Counter flushCounter = sseSinkMetrics.getCounter("flushCounter");
    // get predicate, defaults to return true for all T
    Func1<T, Boolean> filterFunction = new Func1<T, Boolean>() {

        @Override
        public Boolean call(T t1) {
            return true;
        }
    };
    if (queryParameters != null && predicate != null) {
        filterFunction = predicate.getPredicate().call(queryParameters);
    }
    final Subscription timerSubscription = Observable.interval(1, TimeUnit.SECONDS).doOnNext(new Action1<Long>() {

        @Override
        public void call(Long t1) {
            long currentTime = System.currentTimeMillis();
            if (pingsEnabled && (lastResponseSent.get() == -1 || currentTime > lastResponseSent.get() + PING_INTERVAL)) {
                pingCounter.increment();
                response.writeStringAndFlush(PING);
                lastResponseSent.set(currentTime);
            }
        }
    }).subscribe();
    return requestObservable.filter(filterFunction).map(encoder).lift(new DisableBackPressureOperator<String>()).buffer(flushIntervalMillis, TimeUnit.MILLISECONDS).flatMap(new Func1<List<String>, Observable<Void>>() {

        @Override
        public Observable<Void> call(List<String> valueList) {
            if (response.isCloseIssued() || !response.getChannel().isActive()) {
                LOG.info("Client closed detected, throwing closed channel exception");
                return Observable.error(new ClosedChannelException());
            }
            List<String> filteredList = valueList.stream().filter(e -> {
                return slotMgr.filter(sn, e.getBytes());
            }).collect(Collectors.toList());
            if (response.getChannel().isWritable()) {
                flushCounter.increment();
                if (format.equals(BINARY_FORMAT)) {
                    boolean useSnappy = true;
                    try {
                        String compressedList = delimiter == null ? CompressionUtils.compressAndBase64Encode(filteredList, useSnappy) : CompressionUtils.compressAndBase64Encode(filteredList, useSnappy, delimiter);
                        StringBuilder sb = new StringBuilder(3);
                        sb.append(SSE_DATA_PREFIX);
                        sb.append(compressedList);
                        sb.append(TWO_NEWLINES);
                        msgProcessedCounter.increment(valueList.size());
                        lastResponseSent.set(System.currentTimeMillis());
                        return response.writeStringAndFlush(sb.toString());
                    } catch (Exception e) {
                        LOG.warn("Could not compress data" + e.getMessage());
                        droppedWrites.increment(valueList.size());
                        return Observable.empty();
                    }
                } else {
                    int noOfMsgs = 0;
                    StringBuilder sb = new StringBuilder(valueList.size() * 3);
                    for (String s : filteredList) {
                        sb.append(SSE_DATA_PREFIX);
                        sb.append(s);
                        sb.append(TWO_NEWLINES);
                        noOfMsgs++;
                    }
                    msgProcessedCounter.increment(noOfMsgs);
                    lastResponseSent.set(System.currentTimeMillis());
                    return response.writeStringAndFlush(sb.toString());
                }
            } else {
                // 
                droppedWrites.increment(filteredList.size());
            }
            return Observable.empty();
        }
    }).onErrorResumeNext(new Func1<Throwable, Observable<? extends Void>>() {

        @Override
        public Observable<? extends Void> call(Throwable throwable) {
            Throwable cause = throwable.getCause();
            // ignore closed channel exceptions, this is
            // when the connection was closed on the client
            // side without informing the server
            errorCounter.increment();
            if (cause != null && !(cause instanceof ClosedChannelException)) {
                LOG.warn("Error detected in SSE sink", cause);
                if (errorEncoder != null) {
                    // write error out on connection
                    // response.writeAndFlush(errorEncoder.call(throwable));
                    ByteBuf errType = response.getAllocator().buffer().writeBytes("error: ".getBytes());
                    ByteBuf errRes = response.getAllocator().buffer().writeBytes((errorEncoder.call(throwable)).getBytes());
                    response.writeAndFlush(ServerSentEvent.withEventType(errType, errRes));
                }
                throwable.printStackTrace();
            }
            if (requestPostprocessor != null && queryParameters != null) {
                requestPostprocessor.call(queryParameters, context);
            }
            ssm.deregisterServer(sn, queryParameters);
            timerSubscription.unsubscribe();
            return Observable.error(throwable);
        }
    });
}
Also used : Predicate(io.mantisrx.runtime.sink.predicate.Predicate) DisableBackPressureOperator(io.reactivx.mantis.operators.DisableBackPressureOperator) ServerSentEvent(mantis.io.reactivex.netty.protocol.http.sse.ServerSentEvent) LoggerFactory(org.slf4j.LoggerFactory) Action1(rx.functions.Action1) DropOperator(io.reactivx.mantis.operators.DropOperator) HttpServerResponse(mantis.io.reactivex.netty.protocol.http.server.HttpServerResponse) Observable(rx.Observable) Func1(rx.functions.Func1) Func2(rx.functions.Func2) ByteBuf(io.netty.buffer.ByteBuf) Map(java.util.Map) Schedulers(rx.schedulers.Schedulers) RequestHandler(mantis.io.reactivex.netty.protocol.http.server.RequestHandler) BasicTag(com.netflix.spectator.api.BasicTag) Metrics(io.mantisrx.common.metrics.Metrics) Counter(io.mantisrx.common.metrics.Counter) Logger(org.slf4j.Logger) Tag(com.netflix.spectator.api.Tag) HashFunctions(io.mantisrx.common.network.HashFunctions) Endpoint(io.mantisrx.common.network.Endpoint) ClosedChannelException(java.nio.channels.ClosedChannelException) WritableEndpoint(io.mantisrx.common.network.WritableEndpoint) Context(io.mantisrx.runtime.Context) InetSocketAddress(java.net.InetSocketAddress) Collectors(java.util.stream.Collectors) TimeUnit(java.util.concurrent.TimeUnit) AtomicLong(java.util.concurrent.atomic.AtomicLong) List(java.util.List) CompressionUtils(io.mantisrx.common.compression.CompressionUtils) SlotAssignmentManager(io.mantisrx.common.network.ServerSlotManager.SlotAssignmentManager) Optional(java.util.Optional) ServerSlotManager(io.mantisrx.common.network.ServerSlotManager) MantisSSEConstants(com.mantisrx.common.utils.MantisSSEConstants) HttpServerRequest(mantis.io.reactivex.netty.protocol.http.server.HttpServerRequest) Subscription(rx.Subscription) InetSocketAddress(java.net.InetSocketAddress) ByteBuf(io.netty.buffer.ByteBuf) BasicTag(com.netflix.spectator.api.BasicTag) Metrics(io.mantisrx.common.metrics.Metrics) Counter(io.mantisrx.common.metrics.Counter) List(java.util.List) Func1(rx.functions.Func1) Subscription(rx.Subscription) ClosedChannelException(java.nio.channels.ClosedChannelException) WritableEndpoint(io.mantisrx.common.network.WritableEndpoint) DisableBackPressureOperator(io.reactivx.mantis.operators.DisableBackPressureOperator) Action1(rx.functions.Action1) Endpoint(io.mantisrx.common.network.Endpoint) WritableEndpoint(io.mantisrx.common.network.WritableEndpoint) ClosedChannelException(java.nio.channels.ClosedChannelException) Observable(rx.Observable) AtomicLong(java.util.concurrent.atomic.AtomicLong) AtomicLong(java.util.concurrent.atomic.AtomicLong) BasicTag(com.netflix.spectator.api.BasicTag) Tag(com.netflix.spectator.api.Tag)

Aggregations

Metrics (io.mantisrx.common.metrics.Metrics)15 Counter (io.mantisrx.common.metrics.Counter)6 Subscription (rx.Subscription)6 Action1 (rx.functions.Action1)5 Gauge (io.mantisrx.common.metrics.Gauge)4 List (java.util.List)4 Map (java.util.Map)4 MetricGroupId (io.mantisrx.common.metrics.spectator.MetricGroupId)3 Query (io.mantisrx.mql.jvm.core.Query)3 InetSocketAddress (java.net.InetSocketAddress)3 ArrayList (java.util.ArrayList)3 AtomicReference (java.util.concurrent.atomic.AtomicReference)3 BasicTag (com.netflix.spectator.api.BasicTag)2 DefaultRegistry (com.netflix.spectator.api.DefaultRegistry)2 ByteBuf (io.netty.buffer.ByteBuf)2 WriteBufferWaterMark (io.netty.channel.WriteBufferWaterMark)2 DisableBackPressureOperator (io.reactivx.mantis.operators.DisableBackPressureOperator)2 HashMap (java.util.HashMap)2 ServerSentEvent (mantis.io.reactivex.netty.protocol.http.sse.ServerSentEvent)2 Test (org.junit.Test)2