1. RPC
对于微服务开发者,对于 RPC (Remote Procedure Call Protocol 远程过程调用协议)并不会陌生吧, RESTful API 、Dubbo 、WebService 等都是RPC的实现调用
在RabbitMQ 中也提供了 RPC 功能,并且使用起来很简单,下面就来学习一下
2. 实现原理
再来熟悉下原理图
上图把RPC 的过程描述的很清楚:
Client 先发送一条消息,和普通的消息相比,消息多了两个关键内容:一个是 correlation_id ,表示这条消息的唯一 id ,一个是 reply_to ,表示回复队列的名字Server 从消息发送队列获取消息并处理相应的业务逻辑,处理完成后,将处理结果发送到 reply_to 指定的回调队列中Client 从回调队列中读取消息,就可知道执行结果
3. 代码实现
3.1 客户端实现
客户端配置文件:application.properties
server.port=8889
spring.rabbitmq.host=192.168.3.157
spring.rabbitmq.port=5672
spring.rabbitmq.username=guest
spring.rabbitmq.password=guest
spring.rabbitmq.virtual-host=/
# 开启消息确认
spring.rabbitmq.publisher-confirm-type=correlated
# 开启发送失败退回
spring.rabbitmq.publisher-returns=true
spring.rabbitmq.publisher-confirm-type=correlated 这项配置作用是:通过 correlated 来确认消息。
只有开启了这个配置,将来的消息中才会带 correlation_id ,只有通过 correlation_id 才能将发送的消息和返回值之间关联起来
客户端配置类:
package com.scorpios.rabbitmq.config;
import org.springframework.amqp.core.Binding;
import org.springframework.amqp.core.BindingBuilder;
import org.springframework.amqp.core.Queue;
import org.springframework.amqp.core.TopicExchange;
import org.springframework.amqp.rabbit.connection.ConnectionFactory;
import org.springframework.amqp.rabbit.core.RabbitTemplate;
import org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer;
import org.springframework.context.annotation.Bean;
import org.springframework.context.annotation.Configuration;
@Configuration
public class RPCRabbitMQConfig {
public static final String SCORPIOS_RPC_EXCHANGE_NAME = "scorpios_rpc_exchange_name";
public static final String SCORPIOS_RPC_MSG_QUEUE = "scorpios_rpc_msg_queue";
public static final String SCORPIOS_RPC_REPLY_QUEUE = "scorpios_rpc_reply_queue";
@Bean
TopicExchange topicExchange(){
return new TopicExchange(RPCRabbitMQConfig.SCORPIOS_RPC_EXCHANGE_NAME,true,false);
}
@Bean
Queue queueOne() {
return new Queue(RPCRabbitMQConfig.SCORPIOS_RPC_MSG_QUEUE,true,false,false);
}
@Bean
Queue queueTwo() {
return new Queue(RPCRabbitMQConfig.SCORPIOS_RPC_REPLY_QUEUE,true,false,false);
}
@Bean
Binding bindingMsg(){
return BindingBuilder.bind(queueOne()).to(topicExchange()).with(RPCRabbitMQConfig.SCORPIOS_RPC_MSG_QUEUE);
}
@Bean
Binding bindingReply(){
return BindingBuilder.bind(queueTwo()).to(topicExchange()).with(RPCRabbitMQConfig.SCORPIOS_RPC_REPLY_QUEUE);
}
@Bean
RabbitTemplate rabbitTemplate(ConnectionFactory connectionFactory){
RabbitTemplate rabbitTemplate = new RabbitTemplate(connectionFactory);
rabbitTemplate.setReplyAddress(RPCRabbitMQConfig.SCORPIOS_RPC_REPLY_QUEUE);
rabbitTemplate.setReplyTimeout(5000);
return rabbitTemplate;
}
@Bean
SimpleMessageListenerContainer replyContainer(ConnectionFactory connectionFactory) {
SimpleMessageListenerContainer container = new SimpleMessageListenerContainer();
container.setConnectionFactory(connectionFactory);
container.setQueueNames(RPCRabbitMQConfig.SCORPIOS_RPC_REPLY_QUEUE);
container.setMessageListener(rabbitTemplate(connectionFactory));
return container;
}
}
上面代码解释说明:
- 定义一个
TopicExchange 交换机,一个MsgQueue 队列,一个ReplyQueue ,并与交换机进行绑定 - 自定义一个
RabbitTemplate 用户发送消息,虽然在 SpringBoot 中,默认情况下系统自动提供RabbitTemplate ,但是这里需要对该RabbitTemplate 重新进行定制,因为要给RabbitTemplate 添加返回队列,最后还需要给返回队列设置一个监听器
下面来编写消息发送代码:
@Slf4j
@RestController
public class RabbitMQController {
@Autowired
private RabbitTemplate rabbitTemplate;
@GetMapping("/send/message")
public String send(String message) {
Message newMessage = MessageBuilder.withBody(message.getBytes()).build();
log.info("Client 发送的消息为:{}", newMessage);
Message result = rabbitTemplate.sendAndReceive(RPCRabbitMQConfig.SCORPIOS_RPC_EXCHANGE_NAME, RPCRabbitMQConfig.SCORPIOS_RPC_MSG_QUEUE, newMessage);
String response = "";
if (result != null) {
String correlationId = newMessage.getMessageProperties().getCorrelationId();
log.info("发送消息的correlationId为:{}", correlationId);
HashMap<String, Object> headers = (HashMap<String, Object>) result.getMessageProperties().getHeaders();
String msgId = (String) headers.get("spring_returned_message_correlation");
if (msgId.equals(correlationId)) {
response = new String(result.getBody());
log.info("client 收到的响应结果为:{}", response);
}
}
return response;
}
}
解释说明:
- 消息发送调用
sendAndReceive 方法,该方法自带返回值,返回值就是服务端返回的消息 - 服务端返回的消息中,头信息中包含了
spring_returned_message_correlation 字段,这就是消息发送时的 correlation_id ,通过消息发送时的 correlation_id 以及返回消息头中的 spring_returned_message_correlation 字段值,就可以将返回的消息内容和发送的消息绑定到一起,确认出这个返回的内容就是针对这个发送的消息的
注意:如果没有在 application.properties 中配置 correlated,发送的消息中就没有 correlation_id,这样就无法将返回的消息内容和发送的消息内容关联起来
3.2 服务端实现
服务端配置文件 application.properties 与客户端中的配置文件一致
服务端配置类:
@Configuration
public class RPCServerRabbitMQConfig {
public static final String SCORPIOS_RPC_EXCHANGE_NAME = "scorpios_rpc_exchange_name";
public static final String SCORPIOS_RPC_MSG_QUEUE = "scorpios_rpc_msg_queue";
public static final String SCORPIOS_RPC_REPLY_QUEUE = "scorpios_rpc_reply_queue";
@Bean
TopicExchange topicExchange(){
return new TopicExchange(RPCServerRabbitMQConfig.SCORPIOS_RPC_EXCHANGE_NAME,true,false);
}
@Bean
Queue queueOne() {
return new Queue(RPCServerRabbitMQConfig.SCORPIOS_RPC_MSG_QUEUE,true,false,false);
}
@Bean
Queue queueTwo() {
return new Queue(RPCServerRabbitMQConfig.SCORPIOS_RPC_REPLY_QUEUE,true,false,false);
}
@Bean
Binding bindingMsg(){
return BindingBuilder.bind(queueOne()).to(topicExchange()).with(RPCServerRabbitMQConfig.SCORPIOS_RPC_MSG_QUEUE);
}
@Bean
Binding bindingReply(){
return BindingBuilder.bind(queueTwo()).to(topicExchange()).with(RPCServerRabbitMQConfig.SCORPIOS_RPC_REPLY_QUEUE);
}
}
最后我们再来看下消息的消费:
@Slf4j
@Component
public class RpcServerConsumer {
@Autowired
private RabbitTemplate rabbitTemplate;
@RabbitListener(queues = RPCServerRabbitMQConfig.SCORPIOS_RPC_MSG_QUEUE)
public void process(Message msg) {
log.info("server 收到msgQueue队列中的消息为 : {}",msg.toString());
Message response = MessageBuilder.withBody(("我是服务端Server,收到的消息为:"+new String(msg.getBody())).getBytes()).build();
CorrelationData correlationData = new CorrelationData(msg.getMessageProperties().getCorrelationId());
rabbitTemplate.sendAndReceive(RPCServerRabbitMQConfig.SCORPIOS_RPC_EXCHANGE_NAME, RPCServerRabbitMQConfig.SCORPIOS_RPC_REPLY_QUEUE, response, correlationData);
}
}
解释说明:
- 服务端首先收到消息并打印出来
- 服务端提取出原消息中的
correlation_id - 服务端调用
sendAndReceive 方法,将消息发送给 replyQueue 队列,同时带上 correlation_id 参数
3.3 测试
启动Client 与Server 服务,并在浏览器中输入:http://localhost:8889/send/scorpios
Client 服务日志:
Server 服务日志:
浏览器响应结果:
4. 小结
再来看一下这个原理图:
- 定义一个
Exchange 交换机,两个队列:MsgQueue 、ReplyQueue Client 调用 sendAndReceive 方法向MsgQueue 队列中发送消息,该方法自带返回值,返回值就是服务端返回的消息- 在
Server 端消费MsgQueue 队列消息后,往ReplayQueue 中发送消息
代码地址:https://github.com/Hofanking/springboot-rabbitmq-example
springboot-rabbitmq-rpc-client
springboot-rabbitmq-rpc-server
|