zoukankan      html  css  js  c++  java
  • hadoop IPC 源代码分析

          

    如图所示, 在hadoop中客户端需要和服务端通信 。 首先我们看一下需求是啥。

    举一个例子,在客户端想要往hadoop集群中写数据的时候,它需要先和namenode通信,以便获得 诸一个blockID。

    这时 ,我们希望在客户端可以做到 诸如 调用一个方法 如 getBlockID() 则就获得了服务端的发过来的ID ,如果调用本地方法一样。

    需求搞定,我们看现实有的条件 服务端通信我们有的能力为socket,这个是已经封装在linux内核之中, JAVA对linux内核通信又进行了封装,有了自己的

    Socket ServerSocket 通信, 同时在JAVA Nio中又提出了 异步方式的IO。

    好,我们有的资源和需要达到的目标都已经有了,下面是实现中间件来弥补两者之间的鸿沟。

    首先从客户端来看。 客户端调用服务端的服务,肯定需要底层通信处理,而且这些通信处理需要集中处理,不能每次远程调用,都需重新处理一遍底层连接。

    有什么方法可以达到这个目的么 ? 动态代理。

    1. public Object invoke(Object proxy, Method method, Object[] args)
    2.   throws Throwable {
    3.      
    4.   ObjectWritable value = (ObjectWritable)
    5.     client.call(new Invocation(method, args), remoteId);
    6.     
    7.   return value.get();
    8. }

    一般我们看到的动态代理的invoke()方法中总会有 method.invoke(ac, arg);  这句代码。而上面代码中却没有,这是为什么呢?其实使用 method.invoke(ac, arg); 是在本地JVM中调用;

    在客户端这边并没有Proxy对象,我们需要到服务找到对应的对象然后调用相应的方法。在hadoop中,是将数据发送给服务端,服务端将处理的结果再返回给客户端,所以这里的invoke()方法必然需要进行网络通信。

    到这里我们可以再一次从图形来表示一下我们需要达到的目标。

        

                 

                     

        

        

        

    下面这句代码就是服务端真正的调用相应方法的语句, 其中的instance对象,是运行在服务端的对象,call是客户端传递过来的参数。 通过反射机制,进行方法调用。

    1. Object value = method.invoke(instance, call.getParameters());

        

    上面我们把大体的框架搭建起来了,下面一步步进行细节分析。

        

    在上面所示的invok()方法中,最终调用的方法为

    1. client.call(new Invocation(method, args), remoteId);
    2. value.get();

    我们需求分析 Client端是如何通过 这两个方法 调用了远程服务器的方法,并且获取返回值得。

    需要解决的三个问题是

    1. 客户端和服务端的连接是怎样建立的?
    2. . 客户端是怎样给服务端发送数据的?
    3. 客户端是怎样获取服务端的返回数据的?
    4. public Writable call(Writable param, ConnectionId remoteId)
    5.                        throws InterruptedException, IOException {
    6.     Call call = new Call(param); //将传入的数据封装成call对象
    7.     Connection connection = getConnection(remoteId, call); //获得一个连接
    8.     connection.sendParam(call); // 向服务端发送call对象
    9.     boolean interrupted = false;
    10.     synchronized (call) {
    11.       while (!call.done) {
    12.         try {
    13.           call.wait(); // 等待结果的返回,在Call类的callComplete()方法里有notify()方法用于唤醒线程
    14.         } catch (InterruptedException ie) {
    15.           // 因中断异常而终止,设置标志interrupted为true
    16.           interrupted = true;
    17.         }
    18.       }
    19.       if (interrupted) {
    20.         Thread.currentThread().interrupt();
    21.       }
    22.     
    23.       if (call.error != null) {
    24.         if (call.error instanceof RemoteException) {
    25.           call.error.fillInStackTrace();
    26.           throw call.error;
    27.         } else { // 本地异常
    28.           throw wrapException(remoteId.getAddress(), call.error);
    29.         }
    30.       } else {
    31.         return call.value; //返回结果数据
    32.       }
    33.     }
    34.   }

    网络通信有关的代码只会是下面的两句了:

    1. Connection connection = getConnection(remoteId, call); //获得一个连接
    2. connection.sendParam(call); // 向服务端发送call对象

    先看看是怎么获得一个到服务端的连接吧,下面贴出ipc.Client类中的getConnection()方法。

    1. private Connection getConnection(ConnectionId remoteId,
    2.                                    Call call)
    3.                                    throws IOException, InterruptedException {
    4.     if (!running.get()) {
    5.       // 如果client关闭了
    6.       throw new IOException("The client is stopped");
    7.     }
    8.     Connection connection;
    9. //如果connections连接池中有对应的连接对象,就不需重新创建了;如果没有就需重新创建一个连接对象。
    10. //但请注意,该//连接对象只是存储了remoteId的信息,其实还并没有和服务端建立连接。
    11.     do {
    12.       synchronized (connections) {
    13.         connection = connections.get(remoteId);
    14.         if (connection == null) {
    15.           connection = new Connection(remoteId);
    16.           connections.put(remoteId, connection);
    17.         }
    18.       }
    19.     } while (!connection.addCall(call)); //将call对象放入对应连接中的calls池,就不贴出源码了
    20.    //这句代码才是真正的完成了和服务端建立连接哦~
    21.     connection.setupIOstreams();
    22.     return connection;
    23.   }

    下面贴出Client.Connection类中的setupIOstreams()方法:

    1. private synchronized void setupIOstreams() throws InterruptedException {
    2. ???
    3.     try {
    4.      ???
    5.       while (true) {
    6.         setupConnection(); //建立连接
    7.         InputStream inStream = NetUtils.getInputStream(socket); //获得输入流
    8.         OutputStream outStream = NetUtils.getOutputStream(socket); //获得输出流
    9.         writeRpcHeader(outStream);
    10.         ???
    11.         this.in = new DataInputStream(new BufferedInputStream
    12.             (new PingInputStream(inStream))); //将输入流装饰成DataInputStream
    13.         this.out = new DataOutputStream
    14.         (new BufferedOutputStream(outStream)); //将输出流装饰成DataOutputStream
    15.         writeHeader();
    16.         // 跟新活动时间
    17.         touch();
    18.         //当连接建立时,启动接受线程等待服务端传回数据,注意:Connection继承了Tread
    19.         start();
    20.         return;
    21.       }
    22.     } catch (IOException e) {
    23.       markClosed(e);
    24.       close();
    25.     }
    26.   }

    再有一步我们就知道客户端的连接是怎么建立的啦,下面贴出Client.Connection类中的setupConnection()方法:

    1. private synchronized void setupConnection() throws IOException {
    2.     short ioFailures = 0;
    3.     short timeoutFailures = 0;
    4.     while (true) {
    5.       try {
    6.         this.socket = socketFactory.createSocket(); //终于看到创建socket的方法了
    7.         this.socket.setTcpNoDelay(tcpNoDelay);
    8.        ???
    9.         // 设置连接超时为20s
    10.         NetUtils.connect(this.socket, remoteId.getAddress(), 20000);
    11.         this.socket.setSoTimeout(pingInterval);
    12.         return;
    13.       } catch (SocketTimeoutException toe) {
    14.         /* 设置最多连接重试为45次。
    15.          * 总共有20s*45 = 15 分钟的重试时间。
    16.          */
    17.         handleConnectionFailure(timeoutFailures++, 45, toe);
    18.       } catch (IOException ie) {
    19.         handleConnectionFailure(ioFailures++, maxRetries, ie);
    20.       }
    21.     }
    22.   }

    终于,我们知道了客户端的连接是怎样建立的了,其实就是创建一个普通的socket进行通信。

    问题2:客户端是怎样给服务端发送数据的? 

    第一句为了完成连接的建立,我们已经分析完毕;而第二句是为了发送数据,呵呵,分析下去,看能不能解决我们的问题呢。下面贴出Client.Connection类的sendParam()方法吧:

    1. public void sendParam(Call call) {
    2.       if (shouldCloseConnection.get()) {
    3.         return;
    4.       }
    5.       DataOutputBuffer d=null;
    6.       try {
    7.         synchronized (this.out) {
    8.           if (LOG.isDebugEnabled())
    9.             LOG.debug(getName() + " sending #" + call.id);
    10.           //创建一个缓冲区
    11.           d = new DataOutputBuffer();
    12.           d.writeInt(call.id);
    13.           call.param.write(d);
    14.           byte[] data = d.getData();
    15.           int dataLength = d.getLength();
    16.           out.writeInt(dataLength); //首先写出数据的长度
    17.           out.write(data, 0, dataLength); //向服务端写数据
    18.           out.flush();
    19.         }
    20.       } catch(IOException e) {
    21.         markClosed(e);
    22.       } finally {
    23.         IOUtils.closeStream(d);
    24.       }
    25.     }

    问题3:客户端是怎样获取服务端的返回数据的? 

    ,当连接建立时会启动一个线程用于处理服务端返回的数据,我们看看这个处理线程是怎么实现的吧,下面贴出Client.Connection类和Client.Call类中的相关方法吧:

    1. 方法一:
    2.   public void run() {
    3.       ???
    4.       while (waitForWork()) {
    5.         receiveResponse(); //具体的处理方法
    6.       }
    7.       close();
    8.      ???
    9. }
    10.     
    11. 方法二:
    12. private void receiveResponse() {
    13.       if (shouldCloseConnection.get()) {
    14.         return;
    15.       }
    16.       touch();
    17.       try {
    18.         int id = in.readInt(); // 阻塞读取id
    19.         if (LOG.isDebugEnabled())
    20.           LOG.debug(getName() + " got value #" + id);
    21.           Call call = calls.get(id); //在calls池中找到发送时的那个对象
    22.         int state = in.readInt(); // 阻塞读取call对象的状态
    23.         if (state == Status.SUCCESS.state) {
    24.           Writable value = ReflectionUtils.newInstance(valueClass, conf);
    25.           value.readFields(in); // 读取数据
    26.         //将读取到的值赋给call对象,同时唤醒Client等待线程,贴出setValue()代码方法三
    27.           call.setValue(value);
    28.           calls.remove(id); //删除已处理的call
    29.         } else if (state == Status.ERROR.state) {
    30.         ???
    31.         } else if (state == Status.FATAL.state) {
    32.         ???
    33.         }
    34.       } catch (IOException e) {
    35.         markClosed(e);
    36.       }
    37. }
    38.     
    39. 方法三:
    40. public synchronized void setValue(Writable value) {
    41.       this.value = value;
    42.       callComplete(); //具体实现
    43. }
    44. protected synchronized void callComplete() {
    45.       this.done = true;
    46.       notify(); // 唤醒client等待线程
    47.     }

        

    客户端的代码分析就到这里,我们可以发现 ,客户端使用 普通的socket 连接把客户端的方法调用 名称 参数 (形参 和实参) 传递到服务端了。

    下面分析服务端的代码。

    对于ipc.Server,我们先分析一下它的几个内部类吧:

         

    Call :用于存储客户端发来的请求
    Listener 
    监听类,用于监听客户端发来的请求,同时Listener内部还有一个静态类,Listener.Reader,当监听器监听到用户请求,便让Reader读取用户请求。
    Responder 
    :响应RPC请求类,请求处理完毕,由Responder发送给请求客户端。
    Connection 
    :连接类,真正的客户端请求读取逻辑在这个类中。
    Handler 
    :请求处理类,会循环阻塞读取callQueue中的call对象,并对其进行操作。

         

    你会发现其实ipc.Server是一个abstract修饰的抽象类。那随之而来的问题就是:hadoop是怎样初始化RPCServer端的呢?Namenode初始化时一定初始化了RPCSever端,那我们去看看Namenode的初始化源码吧:

    1. private void initialize(Configuration conf) throws IOException {
    2.    ???
    3.     // 创建 rpc server
    4.     InetSocketAddress dnSocketAddr = getServiceRpcServerAddress(conf);
    5.     if (dnSocketAddr != null) {
    6.       int serviceHandlerCount =
    7.         conf.getInt(DFSConfigKeys.DFS_NAMENODE_SERVICE_HANDLER_COUNT_KEY,
    8.                     DFSConfigKeys.DFS_NAMENODE_SERVICE_HANDLER_COUNT_DEFAULT);
    9.       //获得serviceRpcServer
    10.       this.serviceRpcServer = RPC.getServer(this, dnSocketAddr.getHostName(),
    11.           dnSocketAddr.getPort(), serviceHandlerCount,
    12.           false, conf, namesystem.getDelegationTokenSecretManager());
    13.       this.serviceRPCAddress = this.serviceRpcServer.getListenerAddress();
    14.       setRpcServiceServerAddress(conf);
    15. }
    16. //获得server
    17.     this.server = RPC.getServer(this, socAddr.getHostName(),
    18.         socAddr.getPort(), handlerCount, false, conf, namesystem
    19.         .getDelegationTokenSecretManager());
    20.     
    21.    ???
    22.     this.server.start(); //启动 RPC server Clients只允许连接该server
    23.     if (serviceRpcServer != null) {
    24.       serviceRpcServer.start(); //启动 RPC serviceRpcServer 为HDFS服务的server
    25.     }
    26.     startTrashEmptier(conf);
    27.   }
      1.     this.serviceRpcServer = RPC.getServer(this, dnSocketAddr.getHostName(),
    28.           dnSocketAddr.getPort(), serviceHandlerCount,

        

    这里面我们需要重点关注的是这个上面这个方法, 可以看到这里面传递过去的第一个参数是this .我们在前面说服务端最终是需要调用在服务端的某个对象来实际运行方法的。

    现在这个this对象,及namenode对象就是服务端的相应对象。我们就有疑问,那么客户端有那么多接口 ,namenode都实现了相应的对象么?是的都实现了。这也好理解,客户端

    会调用什么方法,肯定都是服务端和客户端事先约定好的,服务端肯定把相应的对象创建好了来等待客户端的调用。我们可以看一下namenode实现的端口,就很明晰了。

    1. public class NameNode implements ClientProtocol, DatanodeProtocol,
    2.                                  NamenodeProtocol, FSConstants,
    3.                                  RefreshAuthorizationPolicyProtocol,
    4.                                  RefreshUserMappingsProtocol {

        

    下面我们来分析服务端是如何处理请求的。

    分析过ipc.Client源码后,我们知道Client端的底层通信直接采用了阻塞式IO编程。但hadoop是单中心结构,所以服务端不可以这么做,而是采用了java  NIO来实现Server端,那Server端采用java NIO是怎么建立连接的呢?分析源码得知,Server端采用Listener监听客户端的连接,下面先分析一下Listener的构造函数吧:

    1. public Listener() throws IOException {
    2.   address = new InetSocketAddress(bindAddress, port);
    3.   // 创建ServerSocketChannel,并设置成非阻塞式
    4.   acceptChannel = ServerSocketChannel.open();
    5.   acceptChannel.configureBlocking(false);
    6.     
    7.   // 将server socket绑定到本地端口
    8.   bind(acceptChannel.socket(), address, backlogLength);
    9.   port = acceptChannel.socket().getLocalPort();
    10.   // 获得一个selector
    11.   selector= Selector.open();
    12.   readers = new Reader[readThreads];
    13.   readPool = Executors.newFixedThreadPool(readThreads);
    14.   //启动多个reader线程,为了防止请求多时服务端响应延时的问题
    15.   for (int i = 0; i < readThreads; i++) {
    16.     Selector readSelector = Selector.open();
    17.     Reader reader = new Reader(readSelector);
    18.     readers[i] = reader;
    19.     readPool.execute(reader);
    20.   }
    21.   // 注册连接事件
    22.   acceptChannel.register(selector, SelectionKey.OP_ACCEPT);
    23.   this.setName("IPC Server listener on " + port);
    24.   this.setDaemon(true);
    25. }

    在启动Listener线程时,服务端会一直等待客户端的连接,下面贴出Server.Listener类的run()方法:

    1. public void run() {
    2.    ???
    3.     while (running) {
    4.       SelectionKey key = null;
    5.       try {
    6.         selector.select();
    7.         Iterator<SelectionKey> iter = selector.selectedKeys().iterator();
    8.         while (iter.hasNext()) {
    9.           key = iter.next();
    10.           iter.remove();
    11.           try {
    12.             if (key.isValid()) {
    13.               if (key.isAcceptable())
    14.                 doAccept(key); //具体的连接方法
    15.             }
    16.           } catch (IOException e) {
    17.           }
    18.           key = null;
    19.         }
    20.       } catch (OutOfMemoryError e) {
    21.      ???
    22.   }

    下面贴出Server.Listener类中doAccept ()方法中的关键源码吧:

    1.     void doAccept(SelectionKey key) throws IOException, OutOfMemoryError {
    2.       Connection c = null;
    3.       ServerSocketChannel server = (ServerSocketChannel) key.channel();
    4.       SocketChannel channel;
    5.       while ((channel = server.accept()) != null) { //建立连接
    6.         channel.configureBlocking(false);
    7.         channel.socket().setTcpNoDelay(tcpNoDelay);
    8.         Reader reader = getReader(); //从readers池中获得一个reader
    9.         try {
    10.           reader.startAdd(); // 激活readSelector,设置adding为true
    11.           SelectionKey readKey = reader.registerChannel(channel);//将读事件设置成兴趣事件
    12.           c = new Connection(readKey, channel, System.currentTimeMillis());//创建一个连接对象
    13.           readKey.attach(c); //将connection对象注入readKey
    14.           synchronized (connectionList) {
    15.             connectionList.add(numConnections, c);
    16.             numConnections++;
    17.           }
    18.         ???
    19.         } finally {
    20. //设置adding为false,采用notify()唤醒一个reader,其实代码十三中启动的每个reader都使
    21. //用了wait()方法等待。因篇幅有限,就不贴出源码了。
    22.           reader.finishAdd();
    23.         }
    24.       }
    25.     }

    reader被唤醒,reader接着执行doRead()方法。

    下面贴出Server.Listener.Reader类中的doRead()方法和Server.Connection类中的readAndProcess()方法源码:

        

    1. 方法一:
    2.  void doRead(SelectionKey key) throws InterruptedException {
    3.       int count = 0;
    4.       Connection c = (Connection)key.attachment(); //获得connection对象
    5.       if (c == null) {
    6.         return;
    7.       }
    8.       c.setLastContact(System.currentTimeMillis());
    9.       try {
    10.         count = c.readAndProcess(); // 接受并处理请求
    11.       } catch (InterruptedException ieo) {
    12.        ???
    13.       }
    14.      ???
    15. }
    16.     
    17. 方法二:
    18. public int readAndProcess() throws IOException, InterruptedException {
    19.       while (true) {
    20.         ???
    21.         if (!rpcHeaderRead) {
    22.           if (rpcHeaderBuffer == null) {
    23.             rpcHeaderBuffer = ByteBuffer.allocate(2);
    24.           }
    25.          //读取请求头
    26.           count = channelRead(channel, rpcHeaderBuffer);
    27.           if (count < 0 || rpcHeaderBuffer.remaining() > 0) {
    28.             return count;
    29.           }
    30.         // 读取请求版本号
    31.           int version = rpcHeaderBuffer.get(0);
    32.           byte[] method = new byte[] {rpcHeaderBuffer.get(1)};
    33.         ???
    34.     
    35.           data = ByteBuffer.allocate(dataLength);
    36.         }
    37.         // 读取请求
    38.         count = channelRead(channel, data);
    39.     
    40.         if (data.remaining() == 0) {
    41.          ???
    42.           if (useSasl) {
    43.          ???
    44.           } else {
    45.             processOneRpc(data.array());//处理请求
    46.           }
    47.         ???
    48.           }
    49.         }
    50.         return count;
    51.       }
    52.     }

    获得call对象 
    下面贴出Server.Connection类中的processOneRpc()方法和processData()方法的源码

    1. 方法一:
    2.  private void processOneRpc(byte[] buf) throws IOException,
    3.         InterruptedException {
    4.       if (headerRead) {
    5.         processData(buf);
    6.       } else {
    7.         processHeader(buf);
    8.         headerRead = true;
    9.         if (!authorizeConnection()) {
    10.           throw new AccessControlException("Connection from " + this
    11.               + " for protocol " + header.getProtocol()
    12.               + " is unauthorized for user " + user);
    13.         }
    14.       }
    15. }
    16. 方法二:
    17.     private void processData(byte[] buf) throws IOException, InterruptedException {
    18.       DataInputStream dis =
    19.         new DataInputStream(new ByteArrayInputStream(buf));
    20.       int id = dis.readInt(); // 尝试读取id
    21.       Writable param = ReflectionUtils.newInstance(paramClass, conf);//读取参数
    22.       param.readFields(dis);
    23.     
    24.       Call call = new Call(id, param, this); //封装成call
    25.       callQueue.put(call); // 将call存入callQueue
    26.       incRpcCount(); // 增加rpc请求的计数
    27.     }

    处理call对象 
    你还记得Server类中还有个Handler内部类吗?呵呵,对call对象的处理就是它干的。下面贴出Server.Handler类中run()方法中的关键代码:

    1. while (running) {
    2.       try {
    3.         final Call call = callQueue.take(); //弹出call,可能会阻塞
    4.         ???
    5.         //调用ipc.Server类中的call()方法,但该call()方法是抽象方法,具体实现在RPC.Server类中
    6.         value = call(call.connection.protocol, call.param, call.timestamp);
    7.         synchronized (call.connection.responseQueue) {
    8.           setupResponse(buf, call,
    9.                       (error == null) ? Status.SUCCESS : Status.ERROR,
    10.                       value, errorClass, error);
    11.            ???
    12.           //给客户端响应请求
    13.           responder.doRespond(call);
    14.         }
    15. }

    终于看到了call 方法 我们下面看看服务端实际的call方法是怎么执行的吧

    1. public Writable call(Class<?> protocol, Writable param, long receivedTime)
    2.     throws IOException {
    3.       try {
    4.         Invocation call = (Invocation)param;
    5.         if (verbose) log("Call: " + call);
    6.     
    7.         Method method =
    8.           protocol.getMethod(call.getMethodName(),
    9.                                    call.getParameterClasses());
    10.         method.setAccessible(true);
    11.     
    12.         long startTime = System.currentTimeMillis();
    13.         Object value = method.invoke(instance, call.getParameters());

    最后一句我们发现实际上是用了反射。 反射中的那个实际对象 instance 就是在namenode起来的时候创建的namenode对象。

  • 相关阅读:
    二,redis常用的数据类型--list
    一,redis常用的数据类型--String
    redis连接超时--Exception in thread "main" redis.clients.jedis.exceptions.JedisConnectionException: Failed connecting to host xxxxx:6379
    Contos 7.5下搭建elasticsearch-7.6.2
    java List中相同的数据合并到一起
    booststrap select2的应用总结
    jquery和bootstrap获取checkbox选中的多行数据
    哈利法克斯(Halifax),布里格斯(Briggs)计算对数的方法-1620年
    Opencv实现频域理想滤波器
    CIELab颜色模型概述
  • 原文地址:https://www.cnblogs.com/echomyecho/p/3272238.html
Copyright © 2011-2022 走看看