iis服务器助手广告广告
返回顶部
首页 > 资讯 > 后端开发 > Python >java开发分布式服务框架Dubbo调用过程
  • 445
分享到

java开发分布式服务框架Dubbo调用过程

2024-04-02 19:04:59 445人浏览 八月长安

Python 官方文档:入门教程 => 点击学习

摘要

目录大致流程调用请求的具体信息协议dubbo协议序列化器调用流程图调用流程源码分析——客户端模板方法模式路由和负载均衡调用的三种方式调用流程源码分析——服务端总结大致流程 客户端根据

大致流程

客户端根据远程服务的地址,客户端发送请求至服务端,服务端解析信息并找到对应的实现类,进行方法调用,之后将调用结果原路返回,客户端解析响应之后再返回。

在这里插入图片描述

调用请求的具体信息

客户端发送给服务端的请求中应该包含哪些具体信息呢?

首先肯定要说明调用的是服务端的哪个接口、方法名、方法参数类型、以及版本号等,将上述信息封装进请求,服务端就可以根据请求进行方法调用,之后再组装响应返回即可。

在这里插入图片描述

以上就是一个实际调用请求所包含的信息。

协议

远程调用必不可少协议的约定,否则客户端与服务端无法解析彼此传来的信息,因此需要提前约定好协议,方便远程调用的信息解析。

Dubbo使用的协议属于Header+Body,协议头固定长度,并且头部中会填写Body的长度,因此Body是不固定长度的,方便拓展,伸缩性较好。

Dubbo协议

在这里插入图片描述

协议分为协议头和协议体,16字节的协议头主要携带了魔法数、一些请求的设置,消息体数据长度。

16字节之后包含的就是协议体,包含版本信息,接口名称,接口版本,以及方法名参数类型等。

在这里插入图片描述

序列化器

网络是以字节流传输的,传输之前,我们需要将数据序列化为字节流然后再传输至服务端,服务端再反序列化这些字节流得到原来的数据。

从上图中可得知,Dubbo支持多种序列化,大致分为两种,一种是字符型,一种是二进制流。

字符型的代表就是JSON,优点是易懂,方便调试,缺点也很明显,传输效率低,对于计算机来说有很多冗余的东西,例如jsON中的括号等等都会使得网络传输时长边长,占用带宽变大。

二进制流类型的数据紧凑,占用字节数小,传输更快,但是调试困难。

Dubbo默认使用的是Hessian2Serialization,即Hessian2序列化协议。

调用流程图

在这里插入图片描述

这个流程图比较简略,大致就是客户端发起调用,实际调用的是代理类,代理类调用Client(默认使用NettyClient),之后构造好协议头以及将Java对象序列化生成协议体,之后进行网络传输。

服务端的NettyServer接收到请求之后,会分发给业务线程池,由线程池来调用具体的方法。

但这远远不够,实际场景比这复杂得多,并且Dubbo是生产级别的,通常会比上述流程更加安全稳定。

在这里插入图片描述

在实际生产环境中,服务端往往会集群分布,多个服务端的服务会有多个Invoker,最终需要通过路由Router过滤,以及负载均衡LoadBalance选出一个Invoker进行调用。

请求会到达Netty的IO线程池进行序列化,再将请求发送给服务端,反序列化后丢入线程池处理,找到对应的Invoker进行调用。

调用流程源码分析——客户端

客户端调用方法并发送请求。

首先会调用生成的代理类,而代理类会生成一个rpcInvocation对象调用MockClusterInvoker.invoke()

生成的RpcInvocation如下:

在这里插入图片描述

进入MockClusterInvoker.invoke()看看:


public Result invoke(Invocation invocation) throws RpcException {
    Result result = null;
    //获取mock参数配置
    String value = this.directory.getUrl().getMethodParameter(invocation.getMethodName(), "mock", Boolean.FALSE.toString()).trim();
    //如果配置了并且配置值为true
    if (value.length() != 0 && !value.equalsIgnoreCase("false")) {
        //强制走mock流程
        if (value.startsWith("force")) {
            result = this.doMockInvoke(invocation, (RpcException)null);
        } else {
            //不走mock流程
            try {
                result = this.invoker.invoke(invocation);
            } catch (RpcException var5) {
                ....
            }
            ....
                result = this.doMockInvoke(invocation, var5);
        }
    }
} else {
    result = this.invoker.invoke(invocation);
}
	return result;
}

总的来说就是检查配置是否配置了mock,如果没有就直接进入this.invoker.invoke(invocation),实际上会调用到AbstractClusterInvoker.invoke()


public Result invoke(Invocation invocation) throws RpcException {
    //检查是否被销毁
    this.checkWhetherDestroyed();
    LoadBalance loadbalance = null;
    //从上下文中获取attachments,如果获取得到的话绑定到invocation中
    Map<String, String> contextAttachments = RpcContext.getContext().getAttachments();
    if (contextAttachments != null && contextAttachments.size() != 0) {
        ((RpcInvocation)invocation).addAttachments(contextAttachments);
    }
	//调用的是directory.list,其中会做路由过滤
    List<Invoker<T>> invokers = this.list(invocation);
    //如果过滤完之后还有Invoker,就通过SPI获取对应的LoadBalance实现类
    if (invokers != null && !invokers.isEmpty()) {
        loadbalance = (LoadBalance)ExtensionLoader.getExtensionLoader(LoadBalance.class).getExtension(((Invoker)invokers.get(0)).getUrl().getMethodParameter(RpcUtils.getMethodName(invocation), "loadbalance", "random"));
    }
    RpcUtils.attachInvocationIdIfAsync(this.getUrl(), invocation);
    return this.doInvoke(invocation, invokers, loadbalance);	//调用子类方法
}
protected List<Invoker<T>> list(Invocation invocation) throws RpcException {
    //获取invokers目录,实际调用的是AbstractDirectory.list()
    List<Invoker<T>> invokers = this.directory.list(invocation);
    return invokers;
}

模板方法模式

这是很常见的设计模式之一,就是再抽象类中定好代码的整体架构,然后将具体的实现留到子类中,由子类自定义实现,由此可以再不改变整体执行步骤的情况下,实现多样化的实现,减少代码重复,利于扩展,符合开闭原则。

在上述代码中this.doInvoke()是抽象方法,具体实现在FailoverClusterInvoker.doInvoke()中,上述所有步骤是每个子类都需要执行的,所以抽取出来放在抽象类中。

路由和负载均衡

上述this.directory.list(invocation),其实就是通过方法名找到对应的Invoker,然后由路由进行过滤。


public List<Invoker<T>> list(Invocation invocation) throws RpcException {
    if (this.destroyed) {
        throw new RpcException("Directory already destroyed .url: " + this.getUrl());
    } else {
        //抽象方法doList,同样由子类实现
        List<Invoker<T>> invokers = this.doList(invocation);
        List<Router> localRouters = this.routers;
        if (localRouters != null && !localRouters.isEmpty()) {
            Iterator i$ = localRouters.iterator();
            while(i$.hasNext()) {
                Router router = (Router)i$.next();
                try {	//遍历router,并判断是否进行路由过滤
                    if (router.getUrl() == null || router.getUrl().getParameter("runtime", false)) {
                        invokers = router.route(invokers, this.getConsumerUrl(), invocation);
                    }
                } catch (Throwable var7) {
                    logger.error("Failed to execute router: " + this.getUrl() + ", cause: " + var7.getMessage(), var7);
                }
            }
        }
        return invokers;
    }
}

返回Invokers之后,还会在进行负载均衡的筛选,得到最终调用的Invoke,Dubbo默认使用的是FailoverClusterInvoker,即失败调用后自动切换的容错方式。

进入FailoverClusterInvoker.doInvoke()


public Result doInvoke(Invocation invocation, List<Invoker<T>> invokers, LoadBalance loadbalance) throws RpcException {
    //重试次数
    int len = this.getUrl().getMethodParameter(invocation.getMethodName(), "retries", 2) + 1;
    if (len <= 0) {
        len = 1;
    }
    ....
	//重试
    for(int i = 0; i < len; ++i) {
		//负载均衡筛选出一个Invoker
        Invoker<T> invoker = this.select(loadbalance, invocation, copyinvokers, invoked);
        invoked.add(invoker);
        //在上下文中保存调用过的invoker
        RpcContext.getContext().setInvokers(invoked);
        try {
            Result result = invoker.invoke(invocation);
            ....
            return result;
        } catch (RpcException e) {
		   ....
        } finally {
            providers.add(invoker.getUrl().getAddress());
        }
    }
    throw new RpcException();
}

发起这次调用的invoker.invoke又是调用抽象类的中的invoke,然后再调用子类的doInvoke,我们直接进入子类DubboInvoker.doInvoke看看:


protected Result doInvoke(Invocation invocation) throws Throwable {
    RpcInvocation inv = (RpcInvocation)invocation;
    String methodName = RpcUtils.getMethodName(invocation);
    inv.setAttachment("path", this.getUrl().getPath());	//设置path到attachment中
    inv.setAttachment("version", this.version);	//设置版本号
    ExchangeClient currentClient;
    if (this.clients.length == 1) {	//选择client
        currentClient = this.clients[0];
    } else {
        currentClient = this.clients[this.index.getAndIncrement() % this.clients.length];
    }
    try {
        boolean isAsync = RpcUtils.isAsync(this.getUrl(), invocation);	//是否异步调用
        boolean isOneway = RpcUtils.isOneway(this.getUrl(), invocation); //是否oneway调用
        int timeout = this.getUrl().getMethodParameter(methodName, "timeout", 1000); //获取超时限制
        if (isOneway) {	//oneway 
            boolean isSent = this.getUrl().getMethodParameter(methodName, "sent", false);
            currentClient.send(inv, isSent);	//发送
            RpcContext.getContext().setFuture((Future)null); //返回空的future
            return new RpcResult(); //返回空结果
        } else if (isAsync) { //异步调用
            ResponseFuture future = currentClient.request(inv, timeout);	
            RpcContext.getContext().setFuture(new FutureAdapter(future)); //上下文中设置future
            return new RpcResult(); //返回空结果
        } else { //同步调用
            RpcContext.getContext().setFuture((Future)null); 
            return (Result)currentClient.request(inv, timeout).get(); //直接调用future.get() 进行等待,完成get操作之后再返回结果
        }
    } catch (TimeoutException var9) {
        throw new RpcException();
    }
}

调用的三种方式

从上述代码中,可以看到调用一共分为三种,分别是oneway异步同步

  • oneway:不需要关心请求是否发送成功的情况下,直接使用oneway,无需关心是否能完成发送并返回结果。
  • 异步调用:client发送请求之后会得到一个ResponseFuture,然后将这个future塞入上下文中,让用户从上下文拿到这个future,用户可以继续执行操作在调用future.get()返回结果。
  • 同步调用:从Dubbo源码中,我们可以看到,先使用了future.get(),让用户进行等待之后,再用client发送请求,给用户的感觉就是调用接口后要进行等待才能返回结果,这个过程是阻塞的。

currentClient.request()就是由如下所示,组装request,然后构造一个future调用NettyClient发送请求。


public ResponseFuture request(Object request, int timeout) throws RemotingException {
    if (this.closed) {
        throw new RemotingException(this.getLocalAddress(), (InetSocketAddress)null, "Failed to send request " + request + ", cause: The channel " + this + " is closed!");
    } else {
        Request req = new Request();	//构建request
        req.setVersion(Version.getProtocolVersion());
        req.setTwoWay(true);
        req.setData(request);
        DefaultFuture future = new DefaultFuture(this.channel, req, timeout);
        try {
            this.channel.send(req);		//调用NettyServer.sent()进行发送请求
            return future;
        } catch (RemotingException var6) {
            future.cancel();
            throw var6;
        }
    }
}

Dubbo默认的调用方式是异步调用,那么这个future保存至上下文之后,等响应回来之后怎么找到对应的future呢?

进入DefaultFuture看看:


public class Request {
    private final long mId;
    public Request() {
        this.mId = newId();
    }
    //静态变量递增,依次构造唯一ID
    private static long newId() {
        return INVOKE_ID.getAndIncrement();
    }
}
public class DefaultFuture implements ResponseFuture {
 	private static final Map<Long, DefaultFuture> FUTURES = new ConcurrentHashMap();
        public DefaultFuture(Channel channel, Request request, int timeout) {
        this.done = this.lock.newCondition();
        this.start = System.currentTimeMillis();
        this.channel = channel;
        this.request = request;
        this.id = request.getId();		//唯一ID
        this.timeout = timeout > 0 ? timeout : channel.getUrl().getPositiveParameter("timeout", 1000);
        FUTURES.put(this.id, this);		//将唯一ID和future的关系保存到这个ConcurrentHashMap中
        CHANNELS.put(this.id, channel);
    }
}

Request构造对象的时候会生成一个唯一ID,future内部也会将自己与请求ID存储到一个ConcurrentHashMap中,这个ID发送至服务端之后,服务端也会把这个ID返回,通过ID再去ConcurrentHashMap中找到对应的future,由此完成一次完整的调用。

最终相应返回之后会调用DefaultFuture.received()


public static void received(Channel channel, Response response) {
    try {
        //获取响应的ID去FUTURES中获取对应的future,获取之后将future移除
        DefaultFuture future = (DefaultFuture)FUTURES.remove(response.getId());
        if (future != null) {
            //确认接收响应
            future.doReceived(response);
        } else {
            logger.warn("....");
        }
    } finally {
        CHANNELS.remove(response.getId());
    }
}
private void doReceived(Response res) {
    this.lock.lock();
    try {
        this.response = res;	//响应赋值
        if (this.done != null) {
            this.done.signal();	//通知响应返回
        }
    } finally {
        this.lock.unlock();
    }
    if (this.callback != null) {
        this.invokeCallback(this.callback);
    }
}

在这里插入图片描述

调用流程源码分析——服务端

服务端接受请求之后会解析请求得到消息,消息总共有五种派发策略:

在这里插入图片描述

Dubbo默认使用的是all,所有消息都派发到业务线程池中,在AllChannelHandler中实现:


public void received(Channel channel, Object message) throws RemotingException {
    ExecutorService cexecutor = this.getExecutorService();
    try {
        cexecutor.execute(new ChannelEventRunnable(channel, this.handler, ChannelState.RECEIVED, message));
    } catch (Throwable var8) {
        if (message instanceof Request && var8 instanceof RejectedExecutionException) {
            Request request = (Request)message;
            if (request.isTwoWay()) {		//如果需要返回响应,将错误封装起来之后返回
                String msg = "Server side(" + this.url.getIp() + "," + this.url.getPort() + ") threadpool is exhausted ,detail msg:" + var8.getMessage();
                Response response = new Response(request.getId(), request.getVersion());
                response.setStatus((byte)100);
                response.setErrORMessage(msg);
                channel.send(response);
                return;
            }
        }
        throw new ExecutionException(message, channel, this.getClass() + " error when process received event .", var8);
    }
}

上述代码就是将消息封装成一个ChannelEventRunnable然后放入业务线程池中执行,ChannelEventRunnable会根据ChannelState参数调用对应的处理方法,此处是ChannelState.RECEIVED,因此调用的是handler.received,最终调用的是HeaderExchangeHandler.handleRequest()方法:


Response handleRequest(ExchangeChannel channel, Request req) throws RemotingException {
    Response res = new Response(req.getId(), req.getVersion());		//通过requestId构造响应
    Object data;
    if (req.isBroken()) {
        data = req.getData();
        String msg;
        if (data == null) {
            msg = null;
        } else if (data instanceof Throwable) {
            msg = StringUtils.toString((Throwable)data);
        } else {
            msg = data.toString();
        }
        res.setErrorMessage("Fail to decode request due to: " + msg);
        res.setStatus((byte)40);
        return res;
    } else {
        data = req.getData();

        try {
            Object result = this.handler.reply(channel, data);	//最终调用DubboProtocol.reply()
            res.setStatus((byte)20);
            res.setResult(result);
        } catch (Throwable var6) {
            res.setStatus((byte)70);
            res.setErrorMessage(StringUtils.toString(var6));
        }
        return res;
    }
}

进入DubboProtocol.reply()看看:


public Object reply(ExchangeChannel channel, Object message) throws RemotingException {
    if (!(message instanceof Invocation)) {
        throw new RemotingException();
    } else {
        Invocation inv = (Invocation)message;
        Invoker<?> invoker = DubboProtocol.this.getInvoker(channel, inv);	 //根据inv得到对应的Invoker
        if (Boolean.TRUE.toString().equals(inv.getAttachments().get("_isCallBackServiceInvoke"))) {
				//一些回调逻辑
            } else {
                hasMethod = inv.getMethodName().equals(methodsStr);
            }
        }
        RpcContext.getContext().setRemoteAddress(channel.getRemoteAddress());	
        return invoker.invoke(inv);		//调用选择的Invoker.invoke()
    }
}

最后的调用我们已经了解过,就是调用一个Javassist生成的代理类,其中包含了真正的实现类;再进入this.getInvoker()看看是怎么根据请求信息获取到Invoker的:


Invoker<?> getInvoker(Channel channel, Invocation inv) throws RemotingException {
    //....
    int port = channel.getLocalAddress().getPort();
    String path = (String)inv.getAttachments().get("path");	
    //根据port、path以及其他信息获取serviceKey
    String serviceKey = serviceKey(port, path, (String)inv.getAttachments().get("version"), (String)inv.getAttachments().get("group"));
    //根据serviceKey在之前提到的exportMap中获取exporter
    DubboExporter<?> exporter = (DubboExporter)this.exporterMap.get(serviceKey);
    if (exporter == null) {
        throw new RemotingException(....);
    } else {
        return exporter.getInvoker();	//返回Invoker
    }
}

关键点在于serviceKey,在之前服务暴露提到的将Invoker封装成exporter之后再构建一个exporterMap,将serviceKey和对应的exporter存入,在服务调用时这个map就起到作用了。

找到所需要的Invoker最终调用实现类具体方法再返回响应整个服务调用流程就结束了,再对上述的流程图进行一下补充:

在这里插入图片描述

总结

首先客户端调用接口中的某个方法,但实际调用的是代理类,代理类通过Cluster从获取Invokers,之后通过Router进行路由过滤,再通过所配置的负载均衡机制进行筛选得到本次远程调用所需要的Invoker,此时根据具体的协议构造请求头,再将参数根据具体的序列化协议进行序列化之后构造好塞入协议体,最后通过NettyClient发起远程调用。

服务端NettyServer收到请求后,根据协议将得到的信息进行反序列化得到对象,根据消息派发策略(默认是All)将消息丢入线程池。

业务现场会根据消息类型得到serviceKey,用这个key从之前服务暴露生成的exportMap中得到对应的Invoker,然后调用真正的实现类中的具体方法。

最终将结果返回,因为请求和响应的都有一个对应且唯一的ID,客户端会根据响应的ID找到存储起来的Future,塞入响应中等待唤醒Future的线程,这就完成了一次完整的调用过程。

如有错误或不足欢迎评论指正。

以上就是java开发分布式服务框架Dubbo调用过程的详细内容,更多关于Dubbo服务调用过程的资料请关注编程网其它相关文章!

--结束END--

本文标题: java开发分布式服务框架Dubbo调用过程

本文链接: https://www.lsjlt.com/news/157359.html(转载时请注明来源链接)

有问题或投稿请发送至: 邮箱/279061341@qq.com    QQ/279061341

本篇文章演示代码以及资料文档资料下载

下载Word文档到电脑,方便收藏和打印~

下载Word文档
猜你喜欢
  • java开发分布式服务框架Dubbo调用过程
    目录大致流程调用请求的具体信息协议Dubbo协议序列化器调用流程图调用流程源码分析——客户端模板方法模式路由和负载均衡调用的三种方式调用流程源码分析——服务端总结大致流程 客户端根据...
    99+
    2022-11-12
  • java开发分布式服务框架Dubbo服务引用过程详解
    目录大致流程服务引用策略服务引用的三种方式服务引入流程解析总结大致流程 Provider将服务暴露出来并且注册到注册中心,而Consumer通过注册中心获取Provider的信息,之...
    99+
    2022-11-12
  • java开发分布式服务框架Dubbo暴露服务过程详解
    目录Dubbo服务暴露机制前言服务暴露流程源码解析本地暴露远程暴露Dubbo服务暴露机制 前言 在进行服务暴露机制的分析之前,必须谈谈什么是URL,在Dubbo服务暴露过程中URL是...
    99+
    2022-11-12
  • Java分布式服务框架Dubbo介绍
    目录1、什么是Dubbo?2、Dubbo核心组件是?3、Dubbo的工作原理是?4、介绍一下Dubbo框架分层?5、Dubbo支持哪些协议?1.dubbo默认协议:2.rmi协议:3...
    99+
    2022-11-13
  • java开发分布式服务框架Dubbo原理机制详解
    目录前言Dubbo框架有以下部件ConsumerProviderRegistryMonitorContainer架构高可用性框架设计服务暴露过程服务消费过程前言 在介绍Dubbo之前...
    99+
    2022-11-12
  • java开发分布式服务框架Dubbo暴露服务的示例分析
    小编给大家分享一下java开发分布式服务框架Dubbo暴露服务的示例分析,希望大家阅读完这篇文章之后都有所收获,下面让我们一起去探讨吧!Dubbo服务暴露机制前言在进行服务暴露机制的分析之前,必须谈谈什么是URL,在Dubbo服务暴露过程中...
    99+
    2023-06-25
  • java开发分布式服务框架Dubbo原理机制的示例分析
    这篇文章给大家分享的是有关java开发分布式服务框架Dubbo原理机制的示例分析的内容。小编觉得挺实用的,因此分享给大家做个参考,一起跟随小编过来看看吧。前言在介绍Dubbo之前先了解一下基本概念:Dubbo是一个RPC框架,RPC,即Re...
    99+
    2023-06-25
  • 如何使用Java分布式框架中的Shell进行快速开发?
    Java分布式框架中的Shell是一个非常强大的工具,可以帮助开发者快速开发出分布式应用程序。本文将介绍如何使用Java分布式框架中的Shell进行快速开发。 一、什么是Java分布式框架中的Shell? Java分布式框架中的Shell是...
    99+
    2023-08-18
    分布式 框架 shell
  • 阿里架构师细谈:微服务+分布式+性能优化+JVM调优+团队开发
    ”文末有资料放送一:分布式架构高并发,高可用,海量数据,没有分布式的架构知识肯定是玩不转的所以分布式的知识需要掌握:分布式架构思维大型互联网架构演进过程架构师应具备的分布式知识主流分布式架构设计详解架构开发基础多线程开发高性能NIO框架架构...
    99+
    2023-06-02
软考高级职称资格查询
编程网,编程工程师的家园,是目前国内优秀的开源技术社区之一,形成了由开源软件库、代码分享、资讯、协作翻译、讨论区和博客等几大频道内容,为IT开发者提供了一个发现、使用、并交流开源技术的平台。
  • 官方手机版

  • 微信公众号

  • 商务合作