org.apache.spark.network.netty.NettyTransportContext.java Source code

Java tutorial

Introduction

Here is the source code for org.apache.spark.network.netty.NettyTransportContext.java

Source

/*
 * Licensed to the Apache Software Foundation (ASF) under one or more
 * contributor license agreements.  See the NOTICE file distributed with
 * this work for additional information regarding copyright ownership.
 * The ASF licenses this file to You under the Apache License, Version 2.0
 * (the "License"); you may not use this file except in compliance with
 * the License.  You may obtain a copy of the License at
 *
 *    http://www.apache.org/licenses/LICENSE-2.0
 *
 * Unless required by applicable law or agreed to in writing, software
 * distributed under the License is distributed on an "AS IS" BASIS,
 * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */

package org.apache.spark.network.netty;

import java.util.List;

import com.google.common.collect.Lists;
import io.netty.channel.Channel;
import io.netty.channel.socket.SocketChannel;
import io.netty.handler.timeout.IdleStateHandler;
import io.netty.util.ResourceLeakDetector;
import io.netty.util.ResourceLeakDetector.Level;
import org.slf4j.Logger;
import org.slf4j.LoggerFactory;

import org.apache.spark.network.client.TransportClient;
import org.apache.spark.network.client.TransportClientBootstrap;
import org.apache.spark.network.client.TransportClientFactory;
import org.apache.spark.network.client.TransportResponseHandler;
import org.apache.spark.network.protocol.MessageDecoder;
import org.apache.spark.network.protocol.MessageEncoder;
import org.apache.spark.network.server.RpcHandler;
import org.apache.spark.network.server.TransportChannelHandler;
import org.apache.spark.network.server.TransportRequestHandler;
import org.apache.spark.network.server.TransportServer;
import org.apache.spark.network.server.TransportServerBootstrap;
import org.apache.spark.network.util.NettyUtils;
import org.apache.spark.network.util.TransportConf;
import org.apache.spark.network.util.TransportFrameDecoder;
import org.apache.spark.network.TransportContext;

/**
 * Contains the context to create a {@link TransportServer}, {@link TransportClientFactory}, and to
 * setup Netty Channel pipelines with a {@link org.apache.spark.network.server.TransportChannelHandler}.
 *
 * There are two communication protocols that the TransportClient provides, control-plane RPCs and
 * data-plane "chunk fetching". The handling of the RPCs is performed outside of the scope of the
 * TransportContext (i.e., by a user-provided handler), and it is responsible for setting up streams
 * which can be streamed through the data plane in chunks using zero-copy IO.
 *
 * The TransportServer and TransportClientFactory both create a TransportChannelHandler for each
 * channel. As each TransportChannelHandler contains a TransportClient, this enables server
 * processes to send messages back to the client on an existing channel.
 */
public class NettyTransportContext implements TransportContext {
    private final Logger logger = LoggerFactory.getLogger(NettyTransportContext.class);

    private final TransportConf conf;
    private final RpcHandler rpcHandler;
    private final boolean closeIdleConnections;

    private final MessageEncoder encoder;
    private final MessageDecoder decoder;

    public NettyTransportContext(TransportConf conf, RpcHandler rpcHandler) {
        this(conf, rpcHandler, false);
    }

    public NettyTransportContext(TransportConf conf, RpcHandler rpcHandler, boolean closeIdleConnections) {
        ResourceLeakDetector.setLevel(Level.DISABLED);
        this.conf = conf;
        this.rpcHandler = rpcHandler;
        this.encoder = new MessageEncoder();
        this.decoder = new MessageDecoder();
        this.closeIdleConnections = closeIdleConnections;
    }

    /**
     * Initializes a ClientFactory which runs the given TransportClientBootstraps prior to returning
     * a new Client. Bootstraps will be executed synchronously, and must run successfully in order
     * to create a Client.
     */
    public NettyTransportClientFactory createClientFactory(List<TransportClientBootstrap> bootstraps) {
        return new NettyTransportClientFactory(this, bootstraps);
    }

    @Override
    public TransportClientFactory createClientFactory() {
        return createClientFactory(Lists.<TransportClientBootstrap>newArrayList());
    }

    /** Create a server which will attempt to bind to a specific port. */
    @Override
    public NettyTransportServer createServer(int port) {
        return createServer(port, Lists.<TransportServerBootstrap>newArrayList());
    }

    /** Create a server which will attempt to bind to a specific port. */
    public NettyTransportServer createServer(int port, List<TransportServerBootstrap> bootstraps) {
        return new NettyTransportServer(this, null, port, rpcHandler, bootstraps);
    }

    /** Create a server which will attempt to bind to a specific host and port. */
    public NettyTransportServer createServer(String host, int port, List<TransportServerBootstrap> bootstraps) {
        return new NettyTransportServer(this, host, port, rpcHandler, bootstraps);
    }

    /** Creates a new server, binding to any available ephemeral port. */
    public NettyTransportServer createServer(List<TransportServerBootstrap> bootstraps) {
        return createServer(0, bootstraps);
    }

    @Override
    public NettyTransportServer createServer() {
        return createServer(0, Lists.<TransportServerBootstrap>newArrayList());
    }

    public TransportChannelHandler initializePipeline(SocketChannel channel) {
        return initializePipeline(channel, rpcHandler);
    }

    /**
     * Initializes a client or server Netty Channel Pipeline which encodes/decodes messages and
     * has a {@link org.apache.spark.network.server.TransportChannelHandler} to handle request or
     * response messages.
     *
     * @param channel The channel to initialize.
     * @param channelRpcHandler The RPC handler to use for the channel.
     *
     * @return Returns the created TransportChannelHandler, which includes a TransportClient that can
     * be used to communicate on this channel. The TransportClient is directly associated with a
     * ChannelHandler to ensure all users of the same channel get the same TransportClient object.
     */
    public TransportChannelHandler initializePipeline(SocketChannel channel, RpcHandler channelRpcHandler) {
        try {
            TransportChannelHandler channelHandler = createChannelHandler(channel, channelRpcHandler);
            channel.pipeline().addLast("encoder", encoder)
                    .addLast(TransportFrameDecoder.HANDLER_NAME, NettyUtils.createFrameDecoder())
                    .addLast("decoder", decoder)
                    .addLast("idleStateHandler", new IdleStateHandler(0, 0, conf.connectionTimeoutMs() / 1000))
                    // NOTE: Chunks are currently guaranteed to be returned in the order of request, but this
                    // would require more logic to guarantee if this were not part of the same event loop.
                    .addLast("handler", channelHandler);
            return channelHandler;
        } catch (RuntimeException e) {
            logger.error("Error while initializing Netty pipeline", e);
            throw e;
        }
    }

    /**
     * Creates the server- and client-side handler which is used to handle both RequestMessages and
     * ResponseMessages. The channel is expected to have been successfully created, though certain
     * properties (such as the remoteAddress()) may not be available yet.
     */
    private TransportChannelHandler createChannelHandler(Channel channel, RpcHandler rpcHandler) {
        TransportResponseHandler responseHandler = new TransportResponseHandler(channel);
        NettyTransportClient client = new NettyTransportClient(channel, responseHandler);
        NettyTransportRequestHandler requestHandler = new NettyTransportRequestHandler(channel, client, rpcHandler);
        return new TransportChannelHandler(client, responseHandler, requestHandler, conf.connectionTimeoutMs(),
                closeIdleConnections);
    }

    @Override
    public TransportConf getConf() {
        return conf;
    }

    @Override
    public RpcHandler getRpcHandler() {
        return rpcHandler;
    }
}