Class AbstractHandler<T extends RestfulGateway,​R extends RequestBody,​M extends MessageParameters>

    • Field Detail

      • log

        protected final org.slf4j.Logger log
      • MAPPER

        protected static final org.apache.flink.shaded.jackson2.com.fasterxml.jackson.databind.ObjectMapper MAPPER
    • Method Detail

      • respondToRequest

        protected abstract CompletableFuture<Void> respondToRequest​(org.apache.flink.shaded.netty4.io.netty.channel.ChannelHandlerContext ctx,
                                                                    org.apache.flink.shaded.netty4.io.netty.handler.codec.http.HttpRequest httpRequest,
                                                                    HandlerRequest<R> handlerRequest,
                                                                    T gateway)
                                                             throws RestHandlerException
        Respond to the given HandlerRequest.
        Parameters:
        ctx - channel handler context to write the response
        httpRequest - original http request
        handlerRequest - typed handler request
        gateway - leader gateway
        Returns:
        Future which is completed once the request has been processed
        Throws:
        RestHandlerException - if an exception occurred while responding