use of io.netty.handler.logging.LoggingHandler in project riposte by Nike-Inc.
the class HttpChannelInitializer method initChannel.
@Override
public void initChannel(SocketChannel ch) {
ChannelPipeline p = ch.pipeline();
// request/response payloads, etc.
if (debugChannelLifecycleLoggingEnabled) {
p.addLast(SERVER_WORKER_CHANNEL_DEBUG_LOGGING_HANDLER_NAME, new LoggingHandler(SERVER_WORKER_CHANNEL_DEBUG_SLF4J_LOGGER_NAME, LogLevel.DEBUG));
}
// order).
if (sslCtx != null)
p.addLast(SSL_HANDLER_NAME, sslCtx.newHandler(ch.alloc()));
// OUTBOUND - Add HttpResponseEncoder to encode our responses appropriately.
// This MUST be the earliest "outbound" handler after the SSL handler since outbound handlers are
// processed in reverse order.
p.addLast(HTTP_RESPONSE_ENCODER_HANDLER_NAME, new HttpResponseEncoder());
// OUTBOUND - Add ProcessFinalResponseOutputHandler to get the final response headers, calculate the final
// content length (after compression/gzip and/or any other modifications), etc, and set those values
// on the channel's HttpProcessingState.
p.addLast(PROCESS_FINAL_RESPONSE_OUTPUT_HANDLER_NAME, new ProcessFinalResponseOutputHandler());
// INBOUND - Add HttpRequestDecoder so that incoming messages are translated into the appropriate HttpMessage
// objects.
p.addLast(HTTP_REQUEST_DECODER_HANDLER_NAME, new HttpRequestDecoder());
// INBOUND - Now that the message is translated into HttpMessages we can add RequestStateCleanerHandler to
// setup/clean state for the rest of the pipeline.
p.addLast(REQUEST_STATE_CLEANER_HANDLER_NAME, new RequestStateCleanerHandler(metricsListener, incompleteHttpCallTimeoutMillis));
// INBOUND - Add DTraceStartHandler to start the distributed tracing for this request
p.addLast(DTRACE_START_HANDLER_NAME, new DTraceStartHandler(userIdHeaderKeys));
// INBOUND - Access log start
p.addLast(ACCESS_LOG_START_HANDLER_NAME, new AccessLogStartHandler());
// IN/OUT - Add SmartHttpContentCompressor for automatic content compression (if appropriate for the
// request/response/size threshold). This must be after HttpRequestDecoder on the incoming pipeline and
// before HttpResponseEncoder on the outbound pipeline (keep in mind that "before" on outbound means
// later in the list since outbound is processed in reverse order).
// TODO: Make the threshold configurable
p.addLast(SMART_HTTP_CONTENT_COMPRESSOR_HANDLER_NAME, new SmartHttpContentCompressor(500));
// INBOUND - Add RequestInfoSetterHandler to populate our request state with a RequestInfo object
p.addLast(REQUEST_INFO_SETTER_HANDLER_NAME, new RequestInfoSetterHandler(maxRequestSizeInBytes));
// maxOpenChannelsThreshold is not -1.
if (maxOpenChannelsThreshold != -1) {
p.addLast(OPEN_CHANNEL_LIMIT_HANDLER_NAME, new OpenChannelLimitHandler(openChannelsGroup, maxOpenChannelsThreshold));
}
// INBOUND - Add the RequestFilterHandler for before security (if we have any filters to apply).
if (beforeSecurityRequestFilterHandler != null)
p.addLast(REQUEST_FILTER_BEFORE_SECURITY_HANDLER_NAME, beforeSecurityRequestFilterHandler);
// INBOUND - Add RoutingHandler to figure out which endpoint should handle the request and set it on our request
// state for later execution
p.addLast(ROUTING_HANDLER_NAME, new RoutingHandler(endpoints, maxRequestSizeInBytes));
// INBOUND - Add SecurityValidationHandler to validate the RequestInfo object for the matching endpoint
p.addLast(SECURITY_VALIDATION_HANDLER_NAME, new SecurityValidationHandler(requestSecurityValidator));
// INBOUND - Add the RequestFilterHandler for after security (if we have any filters to apply).
if (afterSecurityRequestFilterHandler != null)
p.addLast(REQUEST_FILTER_AFTER_SECURITY_HANDLER_NAME, afterSecurityRequestFilterHandler);
// INBOUND - Now that the request state knows which endpoint will be called we can try to deserialize the
// request content (if desired by the endpoint)
p.addLast(REQUEST_CONTENT_DESERIALIZER_HANDLER_NAME, new RequestContentDeserializerHandler(requestContentDeserializer));
// deserialized content (if desired by the endpoint and if we have a non-null validator)
if (validationService != null)
p.addLast(REQUEST_CONTENT_VALIDATION_HANDLER_NAME, new RequestContentValidationHandler(validationService));
// INBOUND - Add NonblockingEndpointExecutionHandler to perform execution of async/nonblocking endpoints
p.addLast(NONBLOCKING_ENDPOINT_EXECUTION_HANDLER_NAME, new NonblockingEndpointExecutionHandler(longRunningTaskExecutor, defaultCompletableFutureTimeoutMillis));
// INBOUND - Add ProxyRouterEndpointExecutionHandler to perform execution of proxy routing endpoints
p.addLast(PROXY_ROUTER_ENDPOINT_EXECUTION_HANDLER_NAME, new ProxyRouterEndpointExecutionHandler(longRunningTaskExecutor, streamingAsyncHttpClientForProxyRouterEndpoints, defaultCompletableFutureTimeoutMillis));
// INBOUND - Add RequestHasBeenHandledVerificationHandler to verify that one of the endpoint handlers took care
// of the request. This makes sure that the messages coming into channelRead are correctly typed for
// the rest of the pipeline.
p.addLast(REQUEST_HAS_BEEN_HANDLED_VERIFICATION_HANDLER_NAME, new RequestHasBeenHandledVerificationHandler());
// INBOUND - Add ExceptionHandlingHandler to catch and deal with any exceptions or requests that fell through
// the cracks.
ExceptionHandlingHandler exceptionHandlingHandler = new ExceptionHandlingHandler(riposteErrorHandler, riposteUnhandledErrorHandler);
p.addLast(EXCEPTION_HANDLING_HANDLER_NAME, exceptionHandlingHandler);
// INBOUND - Add the ResponseFilterHandler (if we have any filters to apply).
if (cachedResponseFilterHandler != null)
p.addLast(RESPONSE_FILTER_HANDLER_NAME, cachedResponseFilterHandler);
// INBOUND - Add ResponseSenderHandler to send the response that got put into the request state
p.addLast(RESPONSE_SENDER_HANDLER_NAME, new ResponseSenderHandler(responseSender));
// INBOUND - Access log end
p.addLast(ACCESS_LOG_END_HANDLER_NAME, new AccessLogEndHandler(accessLogger));
// INBOUND - Add DTraceEndHandler to finish up our distributed trace for this request.
p.addLast(DTRACE_END_HANDLER_NAME, new DTraceEndHandler());
// INBOUND - Add ChannelPipelineFinalizerHandler to stop the request processing.
p.addLast(CHANNEL_PIPELINE_FINALIZER_HANDLER_NAME, new ChannelPipelineFinalizerHandler(exceptionHandlingHandler, responseSender, metricsListener, workerChannelIdleTimeoutMillis));
// pipeline create hooks
if (pipelineCreateHooks != null) {
for (PipelineCreateHook hook : pipelineCreateHooks) {
hook.executePipelineCreateHook(p);
}
}
}
use of io.netty.handler.logging.LoggingHandler in project async-http-client by AsyncHttpClient.
the class HttpStaticFileServer method start.
public static void start(int port) throws Exception {
bossGroup = new NioEventLoopGroup(1);
workerGroup = new NioEventLoopGroup();
ServerBootstrap b = new ServerBootstrap();
//
b.group(bossGroup, workerGroup).channel(//
NioServerSocketChannel.class).handler(//
new LoggingHandler(LogLevel.INFO)).childHandler(new HttpStaticFileServerInitializer());
b.bind(port).sync().channel();
LOGGER.info("Open your web browser and navigate to " + ("http") + "://localhost:" + port + '/');
}
use of io.netty.handler.logging.LoggingHandler in project async-http-client by AsyncHttpClient.
the class ChannelManager method configureBootstraps.
public void configureBootstraps(NettyRequestSender requestSender) {
final AsyncHttpClientHandler httpHandler = new HttpHandler(config, this, requestSender);
wsHandler = new WebSocketHandler(config, this, requestSender);
final NoopHandler pinnedEntry = new NoopHandler();
final LoggingHandler loggingHandler = new LoggingHandler(LogLevel.TRACE);
httpBootstrap.handler(new ChannelInitializer<Channel>() {
@Override
protected void initChannel(Channel ch) throws Exception {
ChannelPipeline pipeline = //
ch.pipeline().addLast(PINNED_ENTRY, //
pinnedEntry).addLast(HTTP_CLIENT_CODEC, //
newHttpClientCodec()).addLast(INFLATER_HANDLER, //
newHttpContentDecompressor()).addLast(CHUNKED_WRITER_HANDLER, //
new ChunkedWriteHandler()).addLast(AHC_HTTP_HANDLER, httpHandler);
if (LOGGER.isTraceEnabled()) {
pipeline.addAfter(PINNED_ENTRY, LOGGING_HANDLER, loggingHandler);
}
if (config.getHttpAdditionalChannelInitializer() != null)
config.getHttpAdditionalChannelInitializer().initChannel(ch);
}
});
wsBootstrap.handler(new ChannelInitializer<Channel>() {
@Override
protected void initChannel(Channel ch) throws Exception {
ChannelPipeline pipeline = //
ch.pipeline().addLast(PINNED_ENTRY, //
pinnedEntry).addLast(HTTP_CLIENT_CODEC, //
newHttpClientCodec()).addLast(AHC_WS_HANDLER, wsHandler);
if (LOGGER.isDebugEnabled()) {
pipeline.addAfter(PINNED_ENTRY, LOGGING_HANDLER, loggingHandler);
}
if (config.getWsAdditionalChannelInitializer() != null)
config.getWsAdditionalChannelInitializer().initChannel(ch);
}
});
}
use of io.netty.handler.logging.LoggingHandler in project cloudstack by apache.
the class NfsSecondaryStorageResource method startPostUploadServer.
private void startPostUploadServer() {
final int PORT = 8210;
final int NO_OF_WORKERS = 15;
final EventLoopGroup bossGroup = new NioEventLoopGroup(1);
final EventLoopGroup workerGroup = new NioEventLoopGroup(NO_OF_WORKERS);
final ServerBootstrap b = new ServerBootstrap();
final NfsSecondaryStorageResource storageResource = this;
b.group(bossGroup, workerGroup);
b.channel(NioServerSocketChannel.class);
b.handler(new LoggingHandler(LogLevel.INFO));
b.childHandler(new ChannelInitializer<SocketChannel>() {
@Override
protected void initChannel(SocketChannel ch) throws Exception {
ChannelPipeline pipeline = ch.pipeline();
pipeline.addLast(new HttpRequestDecoder());
pipeline.addLast(new HttpResponseEncoder());
pipeline.addLast(new HttpContentCompressor());
pipeline.addLast(new HttpUploadServerHandler(storageResource));
}
});
new Thread() {
@Override
public void run() {
try {
Channel ch = b.bind(PORT).sync().channel();
s_logger.info(String.format("Started post upload server on port %d with %d workers", PORT, NO_OF_WORKERS));
ch.closeFuture().sync();
} catch (InterruptedException e) {
s_logger.info("Failed to start post upload server");
s_logger.debug("Exception while starting post upload server", e);
} finally {
bossGroup.shutdownGracefully();
workerGroup.shutdownGracefully();
s_logger.info("shutting down post upload server");
}
}
}.start();
s_logger.info("created a thread to start post upload server");
}
Aggregations