zoukankan      html  css  js  c++  java
  • Springboot整合二 集成 rabbitmq

    1、在application.yml文件中进行RabbitMQ的相关配置
    先上代码

    spring:
      rabbitmq:
        host: 192168.21.11
        port: 5672
        username: guest
        password: password
        publisher-confirms: true    #  消息发送到交换机确认机制,是否确认回调
      virtual-host: / #默认主机

    #自定义参数
    defineProps:
     rabbitmq:
      wechat:
       template:
        topic: wxmsg.topic
        queue: wxmsg.queue
        # *表号匹配一个word,#匹配多个word和路径,路径之间通过.隔开
        queue1_pattern: wxmsg.message.exchange.queue.#
        # *表号匹配一个word,#匹配多个word和路径,路径之间通过.隔开
        queue2_pattern: wxmsg.message.exchange.queue.#

    2. 项目启动配置


           大家可以看到上图中的config包,这里就是相关配置类

    下面,就这三个配置类,做下说明:(这里需要大家对RabbitMQ有一定的了解,知道生产者、消费者、消息交换机、队列等)

    ExchangeConfig    消息交换机配置

    package com.space.rabbitmq.config;
     
    import org.springframework.amqp.core.DirectExchange;
    import org.springframework.context.annotation.Bean;
    import org.springframework.context.annotation.Configuration;
     
    /**
     * 消息交换机配置  可以配置多个
     */
    @Configuration
    public class ExchangeConfig {
        @Value("${defineProps.rabbitmq.wechat.template.topic}")
        private String templateTopic;

        /**
         *   1.定义topic exchange,绑定路由
         *   2.direct交换器相对来说比较简单,匹配规则为:如果路由键匹配,消息就被投送到相关的队列
         *     fanout交换器中没有路由键的概念,他会把消息发送到所有绑定在此交换器上面的队列中。
         *     topic交换器你采用模糊匹配路由键的原则进行转发消息到队列中
         *   3.durable="true" rabbitmq重启的时候不需要创建新的交换机
         *   4.autoDelete:false ,默认不自动删除
         *   5.key: queue在该topic exchange中的key值,当消息符合topic exchange中routing_key规则,
         *   消息将会转发给queue参数指定的消息队列
         */
        public TopicExchange topicExchange(){
            return new TopicExchange(templateTopic, true, false);
        } }

    QueueConfig 队列配置
    package com.space.rabbitmq.config;
     
    import org.springframework.amqp.core.Queue;
    import org.springframework.context.annotation.Bean;
    import org.springframework.context.annotation.Configuration;
     
    /**
     * 队列配置  可以配置多个队列
     */
    @Configuration
    public class QueueConfig {
     
        @Bean
        public Queue firstQueue() {
            /**
             durable="true" 持久化 rabbitmq重启的时候不需要创建新的队列
             auto-delete 表示消息队列没有在使用时将被自动删除 默认是false
             exclusive  表示该消息队列是否只在当前connection生效,默认是false
             */
            return new Queue("queue1",true,false,false);
        }
     
        @Bean
        public Queue secondQueue() {
            return new Queue("queue2",true,false,false);
        }
    }

    RabbitMqConfig RabbitMq配置
    package com.space.rabbitmq.config;
     
    import com.space.rabbitmq.mqcallback.MsgSendConfirmCallBack;
    import org.springframework.amqp.core.AcknowledgeMode;
    import org.springframework.amqp.core.Binding;
    import org.springframework.amqp.core.BindingBuilder;
    import org.springframework.amqp.rabbit.connection.ConnectionFactory;
    import org.springframework.amqp.rabbit.core.RabbitTemplate;
    import org.springframework.amqp.rabbit.listener.SimpleMessageListenerContainer;
    import org.springframework.beans.factory.annotation.Autowired;
    import org.springframework.context.annotation.Bean;
    import org.springframework.context.annotation.Configuration;
     
    /**
     * RabbitMq配置
     */
    @Configuration
    public class RabbitMqConfig {
     
        @Value("${spring.rabbitmq.host}")
        private String host;
        @Value("${spring.rabbitmq.port}")
        private int port;
        @Value("${spring.rabbitmq.username}")
        private String username;
        @Value("${spring.rabbitmq.password}")
        private String password;
        @Value("${spring.rabbitmq.virtual-host}")
        private String vhost;
        
        @Value("${defineProps.rabbitmq.wechat.template.
    queue1_pattern}")
        private String
    queue1_pattern;
        @Value("${defineProps.rabbitmq.wechat.template.
    queue2_pattern}")
        private String
    queue2_pattern; @Autowired
    private QueueConfig queueConfig; @Autowired private ExchangeConfig exchangeConfig;
    /**
    * 连接工厂
    */
    @Bean
    public ConnectionFactory connectionFactory() {
    CachingConnectionFactory connectionFactory = new CachingConnectionFactory(host, port);
    connectionFactory.setUsername(username);
    connectionFactory.setPassword(password);
    connectionFactory.setVirtualHost(vhost);
    return connectionFactory;
    }

    @Bean
    public RabbitTemplate rabbitTemplate(){
    return new RabbitTemplate(connectionFactory());
    }
    /** 将消息队列1和交换机进行绑定 */ @Bean public Binding binding_one() { return BindingBuilder.bind(queueConfig.firstQueue()).to(exchangeConfig.topicExchange()).with(queue1_pattern); } /** * 将消息队列2和交换机进行绑定 */ @Bean public Binding binding_two() { return BindingBuilder.bind(queueConfig.secondQueue()).to(exchangeConfig.topicExchange()).with(queue2_pattern); } /** * queue listener 观察 监听模式 * 当有消息到达时会通知监听在对应的队列上的监听对象 * @return */ @Bean public SimpleMessageListenerContainer simpleMessageListenerContainer_one(){ SimpleMessageListenerContainer simpleMessageListenerContainer = new SimpleMessageListenerContainer(connectionFactory); simpleMessageListenerContainer.addQueues(queueConfig.firstQueue()); simpleMessageListenerContainer.setExposeListenerChannel(true); simpleMessageListenerContainer.setMaxConcurrentConsumers(5); simpleMessageListenerContainer.setConcurrentConsumers(1); simpleMessageListenerContainer.setAcknowledgeMode(AcknowledgeMode.MANUAL); //设置确认模式手工确认 simpleMessageListenerContainer.setMessageListener(wechatPushMessageListener());
    return simpleMessageListenerContainer; }

    /**
    * 配置消费者bean
    * @return
    */
    @Bean
    public WechatPushMessageConsumer wechatPushMessageListener(){
    return new WechatPushMessageConsumer(redisUtil, mqMsgExceptionRemote, wechatAppID, wechatAppSecret);
    }
    /** * 定义rabbit template用于数据的接收和发送 * @return */ @Bean public RabbitTemplate rabbitTemplate() { RabbitTemplate template = new RabbitTemplate(connectionFactory); /**若使用confirm-callback或return-callback, * 必须要配置publisherConfirms或publisherReturns为true * 每个rabbitTemplate只能有一个confirm-callback和return-callback */ template.setConfirmCallback(msgSendConfirmCallBack()); //template.setReturnCallback(msgSendReturnCallback()); /** * 使用return-callback时必须设置mandatory为true,或者在配置中设置mandatory-expression的值为true, * 可针对每次请求的消息去确定’mandatory’的boolean值, * 只能在提供’return -callback’时使用,与mandatory互斥 */ // template.setMandatory(true); return template; } /** * 消息确认机制 * Confirms给客户端一种轻量级的方式,能够跟踪哪些消息被broker处理, * 哪些可能因为broker宕掉或者网络失败的情况而重新发布。 * 确认并且保证消息被送达,提供了两种方式:发布确认和事务。(两者不可同时使用) * 在channel为事务时,不可引入确认模式;同样channel为确认模式下,不可使用事务。 * @return */ @Bean public MsgSendConfirmCallBack msgSendConfirmCallBack(){ return new MsgSendConfirmCallBack(); } }

    消息回调

    package com.space.rabbitmq.mqcallback;
     
    import org.springframework.amqp.rabbit.core.RabbitTemplate;
    import org.springframework.amqp.rabbit.support.CorrelationData;
     
    /**
     * 消息发送到交换机确认机制
     * @author zhuzhe
     * @date 2018/5/25 15:53
     * @email 1529949535@qq.com
     */
    public class MsgSendConfirmCallBack implements RabbitTemplate.ConfirmCallback {
     
        @Override
        public void confirm(CorrelationData correlationData, boolean ack, String cause) {
            System.out.println("MsgSendConfirmCallBack  , 回调id:" + correlationData);
            if (ack) {
                System.out.println("消息消费成功");
            } else {
                System.out.println("消息消费失败:" + cause+"
    重新发送");
            }
        }
    }

     

    生产者/消息发送者

    package com.space.rabbitmq.sender;
     
    import com.space.rabbitmq.config.RabbitMqConfig;
    import lombok.extern.slf4j.Slf4j;
    import org.springframework.amqp.rabbit.core.RabbitTemplate;
    import org.springframework.amqp.rabbit.support.CorrelationData;
    import org.springframework.beans.factory.annotation.Autowired;
    import org.springframework.stereotype.Component;
     
    import java.util.UUID;
     
    /**
     * 消息发送  生产者1
     * @author zhuzhe
     * @date 2018/5/25 14:28
     * @email 1529949535@qq.com
     */
    @Slf4j
    @Component
    public class FirstSender {
     
        @Autowired
        private RabbitTemplate rabbitTemplate;
     
        /**
         * 发送消息
         * @param uuid
         * @param message  消息
         */
        public void send(String uuid,Object message) {
            CorrelationData correlationId = new CorrelationData(uuid);
            rabbitTemplate.convertAndSend(RabbitMqConfig.EXCHANGE, RabbitMqConfig.ROUTINGKEY2,
                    message, correlationId);
        }
    }

    消费者

    方式一(使用注解): 

    package com.space.rabbitmq.receiver; import org.springframework.amqp.rabbit.annotation.RabbitListener; import org.springframework.stereotype.Component;
    /** * 消息消费者1 * @author zhuzhe * @date 2018/5/25 17:32 * @email 1529949535@qq.com */ @Component public class FirstConsumer { @RabbitListener(queues = {"first-queue","second-queue"}, containerFactory = "rabbitListenerContainerFactory") public void handleMessage(String message) throws Exception { // 处理消息 System.out.println("FirstConsumer {} handleMessage :"+message); } }
    方式二(利用配置):
    package com.space.rabbitmq.receiver; import org.springframework.amqp.rabbit.annotation.RabbitListener; import org.springframework.stereotype.Component;
    /** * 消息消费者1 */public class WechatPushMessageConsumer extends BaseMessageConsumer implements ChannelAwareMessageListener
    @Override
    public void onMessage(Message message, Channel channel) throws Exception {
          System.out.println("接收到的消息:" + message.getBody());
        }
    }

    消息接收两种方式:

    @RabbitListener @RabbitHandler 及 消息序列化
    参看资料: https://www.jianshu.com/p/911d987b5f11

    测试

    package com.space.rabbitmq.controller;
     
    import com.space.rabbitmq.sender.FirstSender;
    import org.springframework.beans.factory.annotation.Autowired;
    import org.springframework.web.bind.annotation.GetMapping;
    import org.springframework.web.bind.annotation.RestController;
     
    import java.util.UUID;
     
    /**
     * @author zhuzhe
     * @date 2018/5/25 16:00
     * @email 1529949535@qq.com
     */
    @RestController
    public class SendController {
     
        @Autowired
        private FirstSender firstSender;
     
        @GetMapping("/send")
        public String send(String message){
            String uuid = UUID.randomUUID().toString();
            firstSender.send(uuid,message);
            return uuid;
        }
    }

    package com.space.rabbitmq.controller;
     
    import com.space.rabbitmq.sender.FirstSender;
    import org.springframework.beans.factory.annotation.Autowired;
    import org.springframework.web.bind.annotation.GetMapping;
    import org.springframework.web.bind.annotation.RestController;
     
    import java.util.UUID;
     
    /**
     * @author zhuzhe
     * @date 2018/5/25 16:00
     * @email 1529949535@qq.com
     */
    @RestController
    public class SendController {
     
        @Autowired
        private FirstSender firstSender;
     
        @GetMapping("/send")
        public String send(String message){
            String uuid = UUID.randomUUID().toString();
            firstSender.send(uuid,message);
            return uuid;
        }
    }

    topicExchange
  • 相关阅读:
    数据结构八树和森林
    数据结构 七 二叉树的遍历
    python 的 encode 、decode、字节串、字符串
    TCP/IP
    pg 数据库操作
    nginx + lua 的 跳转命令
    lua string 下的函数
    lua 的匹配规则
    nginx的 ngx.var ngx.ctx ngx.req
    docker 网络模式 和 端口映射
  • 原文地址:https://www.cnblogs.com/yingsong/p/9791159.html
Copyright © 2011-2022 走看看