6.自定义RPC框架

6.1 分布式架构网络通信

在分布式服务框架中,一个最基础的问题就是远程服务是怎么通讯的,在Java领域中有很多可实现远程通讯的技术,例如:RMI、Hessian、SOAP、ESB和JMS等,它们背后到底是基于什么原理实现的呢

6.1.1 基本原理

要实现网络机器间的通讯,首先得来看看计算机系统网络通信的基本原理,在底层层面去看,网络通信需要做的就是将流从一台计算机传输到另外一台计算机,基于传输协议和网络IO来实现,其中传输协议比较出名的有tcp、udp等等,tcp、udp都是在基于Socket概念上为某类应用场景而扩展出的传输协议,网络IO,主要有bio、nio、aio三种方式,所有的分布式应用通讯都基于这个原理而实现.

6.1.2 什么是RPC

RPC全称为remote procedure call,即远程过程调用。借助RPC可以做到像本地调用一样调用远程服务,是一种进程间的通信方式.
比如两台服务器A和B,A服务器上部署一个应用,B服务器上部署一个应用,A服务器上的应用想调用B服务器上的应用提供的方法,由于两个应用不在一个内存空间,不能直接调用,所以需要通过网络来表达调用的语义和传达调用的数据。需要注意的是RPC并不是一个具体的技术,而是指整个网络远程调用过程。
image.png
RPC架构
一个完整的RPC架构里面包含了四个核心的组件,分别是Client,Client Stub,Server以及Server
Stub,这个Stub可以理解为存根。

  • 客户端(Client),服务的调用方。
  • 客户端存根(Client Stub),存放服务端的地址消息,再将客户端的请求参数打包成网络消息,然后通过网络远程发送给服务方。
  • 服务端(Server),真正的服务提供者。
  • 服务端存根(Server Stub),接收客户端发送过来的消息,将消息解包,并调用本地的方法。

image.png
1. 客户端(client)以本地调用方式(即以接口的方式)调用服务;
2. 客户端存根(client stub)接收到调用后,负责将方法、参数等组装成能够进行网络传输的消息体(将消息体对象序列化为二进制);
3. 客户端通过socket将消息发送到服务端;
4. 服务端存根( server stub)收到消息后进行解码(将消息对象反序列化);
5. 服务端存根( server stub)根据解码结果调用本地的服务;
6. 服务处理
7. 本地服务执行并将结果返回给服务端存根( server stub);
8. 服务端存根( server stub)将返回结果打包成消息(将结果消息对象序列化);
9. 服务端(server)通过socket将消息发送到客户端;
10. 客户端存根(client stub)接收到结果消息,并进行解码(将结果消息发序列化);
11. 客户端(client)得到最终结果。

RPC的目标是要把2、3、4、5、7、8、9、10这些步骤都封装起来。只剩下1、6、11

注意:无论是何种类型的数据,最终都需要转换成二进制流在网络上进行传输,数据的发送方需要将对象转换为二进制流,而数据的接收方则需要把二进制流再恢复为对象。

在java中RPC框架比较多,常见的有Hessian、gRPC、Dubbo 等,其实对 于RPC框架而言,核心模块
就是通讯和序列化

6.1.3 RMI

Java RMI,即远程方法调用(Remote Method Invocation),一种用于实现远程过程调用(RPCRemote procedure call)的Java API, 能直接传输序列化后的Java对象。它的实现依赖于Java虚拟机,因此它仅支持从一个JVM到另一个JVM的调用。
image.png
1.客户端从远程服务器的注册表中查询并获取远程对象引用。
2.桩对象与远程对象具有相同的接口和方法列表,当客户端调用远程对象时,实际上是由相应的桩
对象代理完成的。
3.远程引用层在将桩的本地引用转换为服务器上对象的远程引用后,再将调用传递给传输层(Transport),由传输层通过TCP协议发送调用;
4.在服务器端,传输层监听入站连接,它一旦接收到客户端远程调用后,就将这个引用转发给其上
层的远程引用层; 5)服务器端的远程引用层将客户端发送的远程应用转换为本地虚拟机的引用
后,再将请求传递给骨架(Skeleton); 6)骨架读取参数,又将请求传递给服务器,最后由服务
器进行实际的方法调用。
5.如果远程方法调用后有返回值,则服务器将这些结果又沿着“骨架->远程引用层->传输层”向下传
递;
6.客户端的传输层接收到返回值后,又沿着“传输层->远程引用层->桩”向上传递,然后由桩来反序
列化这些返回值,并将最终的结果传递给客户端程序。
需求分析:
1. 服务端提供根据ID查询用户的方法
2. 客户端调用服务端方法, 并返回用户对象
3. 要求使用RMI进行远程通信
代码实现:
1. 服务端

  1. package com.lagou.rmi.server;
  2. import com.lagou.rmi.service.IUserService;
  3. import com.lagou.rmi.service.UserServiceImpl;
  4. import java.rmi.RemoteException;
  5. import java.rmi.registry.LocateRegistry;
  6. import java.rmi.registry.Registry;
  7. /**
  8. * 服务端
  9. */
  10. public class RMIServer {
  11. public static void main(String[] args) {
  12. try {
  13. //1.注册Registry实例. 绑定端口
  14. Registry registry = LocateRegistry.createRegistry(9998);
  15. //2.创建远程对象
  16. IUserService userService = new UserServiceImpl();
  17. //3.将远程对象注册到RMI服务器上即(服务端注册表上)
  18. registry.rebind("userService", userService);
  19. System.out.println("---RMI服务端启动成功----");
  20. } catch (RemoteException e) {
  21. e.printStackTrace();
  22. }
  23. }
  24. }
  1. 客户端 ```java package com.lagou.rmi.client; import com.lagou.rmi.pojo.User; import com.lagou.rmi.service.IUserService; import java.rmi.NotBoundException; import java.rmi.RemoteException; import java.rmi.registry.LocateRegistry; import java.rmi.registry.Registry; /**
  • 客户端 */ public class RMIClient { public static void main(String[] args) throws RemoteException, NotBoundException {
    1. //1.获取Registry实例
    2. Registry registry = LocateRegistry.getRegistry("127.0.0.1", 9998);
    3. //2.通过Registry实例查找远程对象
    4. IUserService userService = (IUserService) registry.lookup("userService");
    5. User user = userService.getByUserId(2);
    6. System.out.println(user.getId() + "----" + user.getName());
    } } ```
  1. 接口与实现类
    1. package com.lagou.rmi;
    2. import java.rmi.Remote;
    3. import java.rmi.RemoteException;
    4. public interface IUserService extends Remote {
    5. User getById(int id) throws RemoteException;
    6. }
    1. package com.lagou.rmi;
    2. import java.rmi.RemoteException;
    3. import java.rmi.server.UnicastRemoteObject;
    4. import java.util.HashMap;
    5. import java.util.Map;
    6. public class UserServiceImpl extends UnicastRemoteObject implements IUserService {
    7. Map<Object, User> userMap = new HashMap();
    8. protected UserServiceImpl() throws RemoteException {
    9. super();
    10. User user1 = new User();
    11. user1.setId(1);
    12. user1.setName("张三");
    13. User user2 = new User();
    14. user2.setId(2);
    15. user2.setName("李四");
    16. userMap.put(user1.getId(), user1);
    17. userMap.put(user2.getId(), user2);
    18. }
    19. @Override
    20. public User getById(int id) throws RemoteException {
    21. return userMap.get(id);
    22. }
    23. }

    6.2 基于Netty实现RPC框架

    6.2.1 需求介绍

    dubbo 底层使用了 Netty 作为网络通讯框架,要求用 Netty 实现一个简单的 RPC 框架,消费者和提供者约定接口和协议,消费者远程调用提供者的服务,
    1. 创建一个接口,定义抽象方法。用于消费者和提供者之间的约定,
    2. 创建一个提供者,该类需要监听消费者的请求,并按照约定返回数据
    3. 创建一个消费者,该类需要透明的调用自己不存在的方法,内部需要使用 Netty 进行数据通信
    4. 提供者与消费者数据传输使用json字符串数据格式
    5. 提供者使用netty集成spring boot 环境实现
    案例: 客户端远程调用服务端提供根据ID查询user对象的方法.
    image.png

    6.2.2 代码实现

    6.2.2.1 服务端代码

  • 注解RpcService ```java package com.lagou.rpc.provider.anno; import java.lang.annotation.ElementType; import java.lang.annotation.Retention; import java.lang.annotation.RetentionPolicy; import java.lang.annotation.Target; /**
  • 对外暴露服务接口 */ @Target(ElementType.TYPE) // 用于接口和类上 @Retention(RetentionPolicy.RUNTIME)// 在运行时可以获取到 public @interface RpcService { } ```
  • 实现类UserServiceImpl

    1. package com.lagou.rpc.provider.service;
    2. import com.lagou.rpc.api.IUserService;
    3. import com.lagou.rpc.pojo.User;
    4. import com.lagou.rpc.provider.anno.RpcService;
    5. import org.springframework.stereotype.Service;
    6. import java.util.HashMap;
    7. import java.util.Map;
    8. @RpcService
    9. @Service
    10. public class UserServiceImpl implements IUserService {
    11. Map<Object, User> userMap = new HashMap();
    12. @Override
    13. public User getById(int id) {
    14. if (userMap.size() == 0) {
    15. User user1 = new User();
    16. user1.setId(1);
    17. user1.setName("张三");
    18. User user2 = new User();
    19. user2.setId(2);
    20. user2.setName("李四");
    21. userMap.put(user1.getId(), user1);
    22. userMap.put(user2.getId(), user2);
    23. }
    24. return userMap.get(id);
    25. }
    26. }
  • 服务Netty启动类RpcServer ```java package com.lagou.rpc.provider.server; import com.lagou.rpc.provider.handler.RpcServerHandler; import io.netty.bootstrap.ServerBootstrap; import io.netty.channel.ChannelFuture; import io.netty.channel.ChannelInitializer; import io.netty.channel.ChannelPipeline; import io.netty.channel.nio.NioEventLoopGroup; import io.netty.channel.socket.SocketChannel; import io.netty.channel.socket.nio.NioServerSocketChannel; import io.netty.handler.codec.string.StringDecoder; import io.netty.handler.codec.string.StringEncoder; import org.springframework.beans.factory.DisposableBean; import org.springframework.beans.factory.annotation.Autowired; import org.springframework.stereotype.Service; /**

  • 启动类 */ @Service public class RpcServer implements DisposableBean { private NioEventLoopGroup bossGroup; private NioEventLoopGroup workerGroup; @Autowired RpcServerHandler rpcServerHandler; public void startServer(String ip, int port) {
    1. try {
    2. //1. 创建线程组
    3. bossGroup = new NioEventLoopGroup(1);
    4. workerGroup = new NioEventLoopGroup();
    5. //2. 创建服务端启动助手
    6. ServerBootstrap serverBootstrap = new ServerBootstrap();
    7. //3. 设置参数
    8. serverBootstrap.group(bossGroup, workerGroup)
    9. .channel(NioServerSocketChannel.class)
    10. .childHandler(new ChannelInitializer<SocketChannel>() {
    11. @Override
    12. protected void initChannel(SocketChannel channel) throws Exception {
    13. ChannelPipeline pipeline = channel.pipeline();
    14. //添加String的编解码器
    15. pipeline.addLast(new StringDecoder());
    16. pipeline.addLast(new StringEncoder());
    17. //业务处理类
    18. pipeline.addLast(rpcServerHandler);
    19. }
    20. });
    21. //4.绑定端口
    22. ChannelFuture sync = serverBootstrap.bind(ip, port).sync();
    23. System.out.println("==========服务端启动成功==========");
    24. sync.channel().closeFuture().sync();
    25. } catch (InterruptedException e) {
    26. e.printStackTrace();
    27. } finally {
    28. if (bossGroup != null) {
    29. bossGroup.shutdownGracefully();
    30. }
    31. if (workerGroup != null) {
    32. workerGroup.shutdownGracefully();
    33. }
    34. }
    } @Override public void destroy() throws Exception {
    1. if (bossGroup != null) {
    2. bossGroup.shutdownGracefully();
    3. }
    4. if (workerGroup != null) {
    5. workerGroup.shutdownGracefully();
    6. }
    } } ```
  • 服务业务处理类RpcServerHandler ```java package com.lagou.rpc.provider.handler; import com.alibaba.fastjson.JSON; import com.lagou.rpc.common.RpcRequest; import com.lagou.rpc.common.RpcResponse; import com.lagou.rpc.provider.anno.RpcService; import io.netty.channel.ChannelHandler; import io.netty.channel.ChannelHandlerContext; import io.netty.channel.SimpleChannelInboundHandler; import org.springframework.beans.BeansException; import org.springframework.cglib.reflect.FastClass; import org.springframework.cglib.reflect.FastMethod; import org.springframework.context.ApplicationContext; import org.springframework.context.ApplicationContextAware; import org.springframework.stereotype.Component; import java.lang.reflect.InvocationTargetException; import java.util.Map; import java.util.Set; import java.util.concurrent.ConcurrentHashMap; /**
  • 服务端业务处理类
  • 1.将标有@RpcService注解的bean缓存
  • 2.接收客户端请求
  • 3.根据传递过来的beanName从缓存中查找到对应的bean
  • 4.解析请求中的方法名称. 参数类型 参数信息
  • 5.反射调用bean的方法
  • 6.给客户端进行响应 / @Component @ChannelHandler.Sharable public class RpcServerHandler extends SimpleChannelInboundHandler implements ApplicationContextAware { private static final Map SERVICE_INSTANCE_MAP = new ConcurrentHashMap(); /*
    • 1.将标有@RpcService注解的bean缓存 *
    • @param applicationContext
    • @throws BeansException */ @Override public void setApplicationContext(ApplicationContext applicationContext) throws BeansException { Map serviceMap = applicationContext.getBeansWithAnnotation(RpcService.class); if (serviceMap != null && serviceMap.size() > 0) {
      1. Set<Map.Entry<String, Object>> entries = serviceMap.entrySet();
      2. for (Map.Entry<String, Object> item : entries) {
      3. Object serviceBean = item.getValue();
      4. if (serviceBean.getClass().getInterfaces().length == 0) {
      5. throw new RuntimeException("服务必须实现接口");
      6. }
      7. //默认取第一个接口作为缓存bean的名称
      8. String name = serviceBean.getClass().getInterfaces()[0].getName();
      9. SERVICE_INSTANCE_MAP.put(name, serviceBean);
      10. }
      } } /**
    • 通道读取就绪事件 *
    • @param channelHandlerContext
    • @param msg
    • @throws Exception */ @Override protected void channelRead0(ChannelHandlerContext channelHandlerContext, String msg) throws Exception { //1.接收客户端请求- 将msg转化RpcRequest对象 RpcRequest rpcRequest = JSON.parseObject(msg, RpcRequest.class); RpcResponse rpcResponse = new RpcResponse(); rpcResponse.setRequestId(rpcRequest.getRequestId()); try {
      1. //业务处理
      2. rpcResponse.setResult(handler(rpcRequest));
      } catch (Exception exception) {
      1. exception.printStackTrace();
      2. rpcResponse.setError(exception.getMessage());
      } //6.给客户端进行响应 channelHandlerContext.writeAndFlush(JSON.toJSONString(rpcResponse)); } /**
    • 业务处理逻辑 *
    • @return */ public Object handler(RpcRequest rpcRequest) throws InvocationTargetException { // 3.根据传递过来的beanName从缓存中查找到对应的bean Object serviceBean = SERVICE_INSTANCE_MAP.get(rpcRequest.getClassName()); if (serviceBean == null) {
      1. throw new RuntimeException("根据beanName找不到服务,beanName:" + rpcRequest.getClassName());
      } //4.解析请求中的方法名称. 参数类型 参数信息 Class<?> serviceBeanClass = serviceBean.getClass(); String methodName = rpcRequest.getMethodName(); Class<?>[] parameterTypes = rpcRequest.getParameterTypes(); Object[] parameters = rpcRequest.getParameters(); //5.反射调用bean的方法- CGLIB反射调用 FastClass fastClass = FastClass.create(serviceBeanClass); FastMethod method = fastClass.getMethod(methodName, parameterTypes); return method.invoke(serviceBean, parameters); } } ```
  • 启动类ServerBootstrap

    1. package com.lagou.rpc.provider;
    2. import com.lagou.rpc.provider.server.RpcServer;
    3. import org.springframework.beans.factory.annotation.Autowired;
    4. import org.springframework.boot.CommandLineRunner;
    5. import org.springframework.boot.SpringApplication;
    6. import org.springframework.boot.autoconfigure.SpringBootApplication;
    7. @SpringBootApplication
    8. public class ServerBootstrapApplication implements CommandLineRunner {
    9. @Autowired
    10. RpcServer rpcServer;
    11. public static void main(String[] args) {
    12. SpringApplication.run(ServerBootstrapApplication.class, args);
    13. }
    14. @Override
    15. public void run(String... args) throws Exception {
    16. new Thread(new Runnable() {
    17. @Override
    18. public void run() {
    19. rpcServer.startServer("127.0.0.1", 8899);
    20. }
    21. }).start();
    22. }
    23. }

    6.2.2.2 客户端代码实现

  • 客户端Netty启动类 ```java package com.lagou.rpc.consumer.client; import com.lagou.rpc.consumer.handler.RpcClientHandler; import io.netty.bootstrap.Bootstrap; import io.netty.channel.; import io.netty.channel.nio.NioEventLoopGroup; import io.netty.channel.socket.SocketChannel; import io.netty.channel.socket.nio.NioSocketChannel; import io.netty.handler.codec.string.StringDecoder; import io.netty.handler.codec.string.StringEncoder; import java.util.concurrent.ExecutionException; import java.util.concurrent.ExecutorService; import java.util.concurrent.Executors; import java.util.concurrent.Future; /*

  • 客户端
  • 1.连接Netty服务端
  • 2.提供给调用者主动关闭资源的方法
  • 3.提供消息发送的方法 */ public class RpcClient { private EventLoopGroup group; private Channel channel; private String ip; private int port; private RpcClientHandler rpcClientHandler = new RpcClientHandler(); private ExecutorService executorService = Executors.newCachedThreadPool(); public RpcClient(String ip, int port) {
    1. this.ip = ip;
    2. this.port = port;
    3. initClient();
    } /**
    • 初始化方法-连接Netty服务端 */ public void initClient() { try {
      1. //1.创建线程组
      2. group = new NioEventLoopGroup();
      3. //2.创建启动助手
      4. Bootstrap bootstrap = new Bootstrap();
      5. //3.设置参数
      6. bootstrap.group(group)
      7. .channel(NioSocketChannel.class)
      8. .option(ChannelOption.SO_KEEPALIVE, Boolean.TRUE)
      9. .option(ChannelOption.CONNECT_TIMEOUT_MILLIS, 3000)
      10. .handler(new ChannelInitializer<SocketChannel>() {
      11. @Override
      12. protected void initChannel(SocketChannel channel) throws Exception {
      13. ChannelPipeline pipeline = channel.pipeline();
      14. //String类型编解码器
      15. pipeline.addLast(new StringDecoder());
      16. pipeline.addLast(new StringEncoder());
      17. //添加客户端处理类
      18. pipeline.addLast(rpcClientHandler);
      19. }
      20. });
      21. //4.连接Netty服务端
      22. channel = bootstrap.connect(ip, port).sync().channel();
      } catch (Exception exception) {
      1. exception.printStackTrace();
      2. if (channel != null) {
      3. channel.close();
      4. }
      5. if (group != null) {
      6. group.shutdownGracefully();
      7. }
      } } /**
    • 提供给调用者主动关闭资源的方法 */ public void close() { if (channel != null) {
      1. channel.close();
      } if (group != null) {
      1. group.shutdownGracefully();
      } } /**
    • 提供消息发送的方法 */ public Object send(String msg) throws ExecutionException, InterruptedException { rpcClientHandler.setRequestMsg(msg); Future submit = executorService.submit(rpcClientHandler); return submit.get(); } } ```
  • 客户端业务处理类RpcClientHandler ```java package com.lagou.rpc.consumer.handler; import io.netty.channel.ChannelHandlerContext; import io.netty.channel.SimpleChannelInboundHandler; import java.util.concurrent.Callable; /**
  • 客户端处理类
  • 1.发送消息
  • 2.接收消息 */ public class RpcClientHandler extends SimpleChannelInboundHandler implements Callable { ChannelHandlerContext context; //发送的消息 String requestMsg; //服务端的消息 String responseMsg; public void setRequestMsg(String requestMsg) {
    1. this.requestMsg = requestMsg;
    } /**
    • 通道连接就绪事件 *
    • @param ctx
    • @throws Exception / @Override public void channelActive(ChannelHandlerContext ctx) throws Exception { context = ctx; } /*
    • 通道读取就绪事件 *
    • @param channelHandlerContext
    • @param msg
    • @throws Exception / @Override protected synchronized void channelRead0(ChannelHandlerContext channelHandlerContext, String msg) throws Exception { responseMsg = msg; //唤醒等待的线程 notify(); } /*
    • 发送消息到服务端 *
    • @return
    • @throws Exception */ @Override public synchronized Object call() throws Exception { //消息发送 context.writeAndFlush(requestMsg); //线程等待 wait(); return responseMsg; } } ```
  • RPC代理类 ```java package com.lagou.rpc.consumer.proxy; import com.alibaba.fastjson.JSON; import com.lagou.rpc.common.RpcRequest; import com.lagou.rpc.common.RpcResponse; import com.lagou.rpc.consumer.client.RpcClient; import java.lang.reflect.InvocationHandler; import java.lang.reflect.Method; import java.lang.reflect.Proxy; import java.util.UUID; /**
  • 客户端代理类-创建代理对象
  • 1.封装request请求对象
  • 2.创建RpcClient对象
  • 3.发送消息
  • 4.返回结果 */ public class RpcClientProxy { public static Object createProxy(Class serviceClass) {
    1. return Proxy.newProxyInstance(
    2. Thread.currentThread().getContextClassLoader(),
    3. new Class[]{
    4. serviceClass},
    5. new InvocationHandler() {
    6. @Override
    7. public Object invoke(Object proxy, Method method, Object[] args) throws Throwable {
    8. //1.封装request请求对象
    9. RpcRequest rpcRequest = new RpcRequest();
    10. rpcRequest.setRequestId(UUID.randomUUID().toString());
    11. rpcRequest.setClassName(method.getDeclaringClass().getName());
    12. rpcRequest.setMethodName(method.getName());
    13. rpcRequest.setParameterTypes(method.getParameterTypes());
    14. rpcRequest.setParameters(args);
    15. //2.创建RpcClient对象
    16. RpcClient rpcClient = new RpcClient("127.0.0.1", 8899);
    17. try {
    18. //3.发送消息
    19. Object responseMsg = rpcClient.send(JSON.toJSONString(rpcRequest));
    20. RpcResponse rpcResponse = JSON.parseObject(responseMsg.toString(), RpcResponse.class);
    21. if (rpcResponse.getError() != null) {
    22. throw new RuntimeException(rpcResponse.getError());
    23. }
    24. //4.返回结果
    25. Object result = rpcResponse.getResult();
    26. return JSON.parseObject(result.toString(), method.getReturnType());
    27. } catch (Exception e) {
    28. throw e;
    29. } finally {
    30. rpcClient.close();
    31. }
    32. }
    33. }
    34. );
    } } ```
  • 客户端启动类ClientBootStrap ```java package com.lagou.rpc.consumer; import com.lagou.rpc.api.IUserService; import com.lagou.rpc.consumer.proxy.RpcClientProxy; import com.lagou.rpc.pojo.User; /**
  • 测试类 */ public class ClientBootStrap { public static void main(String[] args) {
    1. IUserService userService = (IUserService) RpcClientProxy.createProxy(IUserService.class);
    2. User user = userService.getById(1);
    3. System.out.println(user);
    } } ```