欧美bbbwbbbw肥妇,免费乱码人妻系列日韩,一级黄片

SpringBoot整合RabbitMQ消息隊(duì)列的完整步驟

 更新時(shí)間:2021年05月06日 11:03:52   作者:JackHorse  
這篇文章主要給大家介紹了關(guān)于SpringBoot整合RabbitMQ消息隊(duì)列的相關(guān)資料,文中通過(guò)示例代碼介紹的非常詳細(xì),對(duì)大家的學(xué)習(xí)或者工作具有一定的參考學(xué)習(xí)價(jià)值,需要的朋友們下面隨著小編來(lái)一起學(xué)習(xí)學(xué)習(xí)吧

SpringBoot整合RabbitMQ

主要實(shí)現(xiàn)RabbitMQ以下三種消息隊(duì)列:

  • 簡(jiǎn)單消息隊(duì)列(演示direct模式)
  • 基于RabbitMQ特性的延時(shí)消息隊(duì)列
  • 基于RabbitMQ相關(guān)插件的延時(shí)消息隊(duì)列

公共資源

1. 引入pom依賴

 <dependency>
     <groupId>org.springframework.boot</groupId>
     <artifactId>spring-boot-starter-amqp</artifactId>
</dependency>

2. 配置yml文件

基于上篇《RabbitMQ安裝與配置》實(shí)現(xiàn)的情況下,進(jìn)行基礎(chǔ)配置。

spring:
  rabbitmq:
    host: 121.5.168.31
    port: 5672    # 默認(rèn)可省略
    virtual-host: /*** # 虛擬主機(jī)
    username: *** # 用戶名
    password: *** # 用戶密碼
    # 開啟投遞成功回調(diào) P -> Exchange
    publisher-confirm-type: correlated
    # 開啟投遞消息到隊(duì)列失敗回調(diào) Exchange -> Queue
    publisher-returns: true
    # 開啟手動(dòng)ACK確認(rèn)模式 Queue -> C
    listener:
      simple:
        acknowledge-mode: manual # 代表手動(dòng)ACK確認(rèn)
        # 一些基本參數(shù)的設(shè)置
        concurrency: 3
        prefetch: 15
        retry:
          enabled: true
          max-attempts: 5
        max-concurrency: 10

3. 公共Constants類

/**
 * @author Mr.Horse
 * @version 1.0
 * @description: {description}
 * @date 2021/4/23 15:28
 */

public class Constants {

    /**
     * 第一個(gè)配置Queue,Exchange,Key(非注解方式)
     */
    public final static String HORSE_SIMPLE_QUEUE = "HORSE_SIMPLE_QUEUE";
    public final static String HORSE_SIMPLE_EXCHANGE = "HORSE_SIMPLE_EXCHANGE";
    public final static String HORSE_SIMPLE_KEY = "HORSE_SIMPLE_KEY";

    /**
     * 第二個(gè)配置Queue,Exchange,Key(注解方式)
     */
    public final static String HORSE_ANNOTATION_QUEUE = "HORSE_ANNOTATION_QUEUE";
    public final static String HORSE_ANNOTATION_EXCHANGE = "HORSE_ANNOTATION_EXCHANGE";
    public final static String HORSE_ANNOTATION_KEY = "HORSE_ANNOTATION_KEY";


    //************************************延時(shí)消息隊(duì)列配置信息**************************
    /**
     * 延時(shí)隊(duì)列信息配置
     */
    public final static String HORSE_DELAY_EXCHANGE = "HORSE_DELAY_EXCHANGE";
    public final static String HORSE_DELAY_QUEUE = "HORSE_DELAY_QUEUE";
    public final static String HORSE_DELAY_KEY = "HORSE_DELAY_KEY";

    /**
     * 死信隊(duì)列
     */
    public final static String HORSE_DEAD_EXCHANGE = "HORSE_DEAD_EXCHANGE";
    public final static String HORSE_DEAD_QUEUE = "HORSE_DEAD_QUEUE";
    public final static String HORSE_DEAD_KEY = "HORSE_DEAD_KEY";

    //**************************************延時(shí)消息隊(duì)列配置信息(插件版)******************************
    /**
     * 新延時(shí)隊(duì)列信息配置
     */
    public final static String HORSE_PLUGIN_EXCHANGE = "HORSE_PLUGIN_EXCHANGE";
    public final static String HORSE_PLUGIN_QUEUE = "HORSE_PLUGIN_QUEUE";
    public final static String HORSE_PLUGIN_KEY = "HORSE_PLUGIN_KEY";

}

簡(jiǎn)單消息隊(duì)列(direct模式)

4. RabbitTemplate模板配置

主要定義消息投遞Exchange成功回調(diào)函數(shù)和消息從Exchange投遞到消息隊(duì)列失敗的回調(diào)函數(shù)。

package com.topsun.rabbit;

import com.sun.org.apache.xpath.internal.operations.Bool;
import com.topsun.constants.Constants;
import org.slf4j.Logger;
import org.slf4j.LoggerFactory;
import org.springframework.amqp.core.*;
import org.springframework.amqp.rabbit.connection.CachingConnectionFactory;
import org.springframework.amqp.rabbit.core.RabbitTemplate;
import org.springframework.amqp.support.converter.Jackson2JsonMessageConverter;
import org.springframework.beans.factory.annotation.Autowired;
import org.springframework.context.annotation.Bean;
import org.springframework.context.annotation.Configuration;

/**
 * @author Mr.Horse
 * @version 1.0
 * @description: {description}
 * @date 2021/4/23 14:17
 */
@Configuration
public class RabbitConfig {

    private static Logger logger = LoggerFactory.getLogger(RabbitConfig.class);


    @Autowired
    private CachingConnectionFactory connectionFactory;

    /**
     * @return
     */
    @Bean
    public RabbitTemplate rabbitTemplate() {
        RabbitTemplate rabbitTemplate = new RabbitTemplate(connectionFactory);
        // 觸發(fā)setReturnCallback回調(diào)必須設(shè)置mandatory=true,否則Exchange沒有找到Queue就會(huì)丟棄掉消息, 而不會(huì)觸發(fā)回調(diào)
        rabbitTemplate.setMandatory(Boolean.TRUE);
        // 設(shè)置序列化機(jī)制
        rabbitTemplate.setMessageConverter(new Jackson2JsonMessageConverter());
        // 消息由投遞到Exchange中時(shí)觸發(fā)的回調(diào)
        rabbitTemplate.setConfirmCallback((correlationData, ack, cause) ->
                logger.info("消息發(fā)送到Exchange情況反饋:唯一標(biāo)識(shí):correlationData={},消息確認(rèn):ack={},原因:cause={}",
                        correlationData, ack, cause)
        );
        // 消息由Exchange發(fā)送到Queue時(shí)失敗觸發(fā)的回調(diào)
        rabbitTemplate.setReturnsCallback((returnedMessage) -> {
            // 如果是插件形式實(shí)現(xiàn)的延時(shí)隊(duì)列,則直接返回
            // 原因: 因?yàn)榘l(fā)送方確實(shí)沒有投遞到隊(duì)列上,只是在交換器上暫存,等過(guò)期時(shí)間到了 才會(huì)發(fā)往隊(duì)列,從而實(shí)現(xiàn)延時(shí)隊(duì)列的操作
            if (Constants.HORSE_PLUGIN_EXCHANGE.equals(returnedMessage.getExchange())) {
                return;
            }
            logger.warn("消息由Exchange發(fā)送到Queue時(shí)失敗:message={},replyCode={},replyText={},exchange={},rountingKey={}",
                    returnedMessage.getMessage(), returnedMessage.getReplyText(), returnedMessage.getReplyText(),
                    returnedMessage.getExchange(), returnedMessage.getRoutingKey());
        });
        return rabbitTemplate;
    }

    //*******************************************直接配置綁定關(guān)系*****************************************
    /**
     * 聲明隊(duì)列
     *
     * @return
     */
    @Bean
    public Queue horseQueue() {
        return new Queue(Constants.HORSE_SIMPLE_QUEUE, Boolean.TRUE);
    }

    /**
     * 聲明指定模式交換機(jī)
     *
     * @return
     */
    @Bean
    public DirectExchange horseExchange() {
        return new DirectExchange(Constants.HORSE_SIMPLE_EXCHANGE, Boolean.TRUE, Boolean.FALSE);
    }

    /**
     * 綁定交換機(jī),隊(duì)列,路由Key
     *
     * @return
     */
    @Bean
    public Binding horseBinding() {
        return BindingBuilder.bind(horseQueue()).to(horseExchange()).with(Constants.HORSE_SIMPLE_KEY);
    }

}

5. 定義消息監(jiān)聽器

基于 @RabbitListenerzi注解,實(shí)現(xiàn)自定義消息監(jiān)聽器。主要有兩種實(shí)現(xiàn)方式:

  • 如果在配置類中聲明了Queue、Excehange以及他們直接的綁定,這里直接指定隊(duì)列進(jìn)行消息監(jiān)聽
  • 如果前面什么也沒做,這里可以直接用注解的方式進(jìn)行綁定實(shí)現(xiàn)消息監(jiān)聽
package com.topsun.rabbit;

import com.rabbitmq.client.Channel;
import com.topsun.constants.Constants;
import org.slf4j.Logger;
import org.slf4j.LoggerFactory;
import org.springframework.amqp.core.Message;
import org.springframework.amqp.rabbit.annotation.Exchange;
import org.springframework.amqp.rabbit.annotation.Queue;
import org.springframework.amqp.rabbit.annotation.QueueBinding;
import org.springframework.amqp.rabbit.annotation.RabbitListener;
import org.springframework.stereotype.Component;

import java.io.IOException;

/**
 * @author Mr.Horse
 * @version 1.0
 * @description: {description}
 * @date 2021/4/23 14:58
 */

@Component
public class MsgListener {

    private static Logger logger = LoggerFactory.getLogger(MsgListener.class);

    /**
     * 配置類中已經(jīng)完成綁定,這里直接根據(jù)隊(duì)列值接收
     *
     * @param message
     * @param channel
     * @param msg
     */
    @RabbitListenerzi(queues = Constants.HORSE_SIMPLE_QUEUE)
    public void customListener(Message message, Channel channel, String msg) {
        // 獲取每條消息唯一標(biāo)識(shí)(用于手動(dòng)ACK確認(rèn))
        long tag = message.getMessageProperties().getDeliveryTag();
        try {
            logger.info(" ==> customListener接收" + msg);
            // 手動(dòng)ACK確認(rèn)
            channel.basicAck(tag, false);
        } catch (IOException e) {
            logger.error(" ==> 消息接收失敗: {}", tag);
        }
    }

    /**
     * 根據(jù)注解的形式進(jìn)行綁定接收
     *
     * @param message
     * @param channel
     * @param msg
     */
    @RabbitListener(bindings = @QueueBinding(
            value = @Queue(value = Constants.HORSE_ANNOTATION_QUEUE, durable = "true"),
            exchange = @Exchange(value = Constants.HORSE_ANNOTATION_EXCHANGE, ignoreDeclarationExceptions = "true"),
            key = {Constants.HORSE_ANNOTATION_KEY}
    ))
    public void annotationListener(Message message, Channel channel, String msg) {
        // 獲取每條消息唯一標(biāo)識(shí)(用于手動(dòng)ACK確認(rèn))
        long tag = message.getMessageProperties().getDeliveryTag();
        try {
            logger.info(" ==> annotationListener接收" + msg);
            // 手動(dòng)ACK確認(rèn)
            channel.basicAck(tag, false);
        } catch (IOException e) {
            logger.error(" ==> 消息接收失敗: {}", tag);
        }
    }

}


6. 測(cè)試接口

這里發(fā)送100條消息:

  • 奇數(shù)條到非注解方式的消息監(jiān)聽器
  • 偶數(shù)條到注解式消息監(jiān)聽器
@GetMapping("/rabbit")
    public void sendMsg() {
        for (int i = 1; i <= 100; i++) {
            String msg = "第" + i + "條消息";
            logger.info("==> 發(fā)送" + msg);
            if (i % 2 == 1) {
                rabbitTemplate.convertAndSend(Constants.HORSE_SIMPLE_EXCHANGE, Constants.HORSE_SIMPLE_KEY, msg, new CorrelationData(String.valueOf(i)));
            } else {
                rabbitTemplate.convertAndSend(Constants.HORSE_ANNOTATION_EXCHANGE, Constants.HORSE_ANNOTATION_KEY, msg, new CorrelationData(String.valueOf(i)));
            }
        }
    }

結(jié)果:自行測(cè)試過(guò),非常成功:smile::smile::smile:

延時(shí)消息隊(duì)列

原理:生產(chǎn)者生產(chǎn)一條延時(shí)消息,根據(jù)需要延時(shí)時(shí)間的不同,利用不同的routingkey將消息路由到不同的延時(shí)隊(duì)列,每個(gè)隊(duì)列都設(shè)置了不同的TTL屬性,并綁定在同一個(gè)死信交換機(jī)中,消息過(guò)期后,根據(jù)routingkey的不同,又會(huì)被路由到不同的死信隊(duì)列中,消費(fèi)者只需要監(jiān)聽對(duì)應(yīng)的死信隊(duì)列進(jìn)行處理即可。

7. 配置綁定相關(guān)信息

/**
 * @author Mr.Horse
 * @version 1.0
 * @description: {description}
 * @date 2021/4/24 14:22
 */

@Configuration
public class DelayRabbitConfig {

    private static Logger logger = LoggerFactory.getLogger(DelayRabbitConfig.class);

    /**
     * 聲明延時(shí)隊(duì)列交換機(jī)
     *
     * @return
     */
    @Bean
    public DirectExchange delayExchange() {
        return new DirectExchange(Constants.HORSE_DELAY_EXCHANGE, Boolean.TRUE, Boolean.FALSE);
    }

    /**
     * 聲明死信隊(duì)列交換機(jī)
     *
     * @return
     */
    @Bean
    public DirectExchange deadExchange() {
        return new DirectExchange(Constants.HORSE_DEAD_EXCHANGE, Boolean.TRUE, Boolean.FALSE);
    }

    /**
     * 聲明延時(shí)隊(duì)列 延時(shí)10s(單位:ms),并將延時(shí)隊(duì)列綁定到對(duì)應(yīng)的死信交換機(jī)和路由Key
     *
     * @return
     */
    @Bean
    public Queue delayQueue() {
        Map<String, Object> args = new HashMap<>(3);
        // x-dead-letter-exchange    這里聲明當(dāng)前隊(duì)列綁定的死信交換機(jī)
        args.put("x-dead-letter-exchange", Constants.HORSE_DEAD_EXCHANGE);
        // x-dead-letter-routing-key  這里聲明當(dāng)前隊(duì)列的死信路由key
        args.put("x-dead-letter-routing-key", Constants.HORSE_DEAD_KEY);
        // x-message-ttl  聲明隊(duì)列的TTL(過(guò)期時(shí)間)
        // 可以在這里直接寫死,也可以進(jìn)行動(dòng)態(tài)的設(shè)置(推薦動(dòng)態(tài)設(shè)置)
        // args.put("x-message-ttl", 10000);
        return QueueBuilder.durable(Constants.HORSE_DELAY_QUEUE).withArguments(args).build();
    }

    /**
     * 聲明死信隊(duì)列
     *
     * @return
     */
    @Bean
    public Queue deadQueue() {
        return new Queue(Constants.HORSE_DEAD_QUEUE, Boolean.TRUE);
    }


    /**
     * 延時(shí)隊(duì)列綁定管理
     *
     * @return
     */
    @Bean
    public Binding delayBinding() {
        return BindingBuilder.bind(delayQueue()).to(delayExchange()).with(Constants.HORSE_DELAY_KEY);
    }

    /**
     * 死信隊(duì)列綁定管理
     *
     * @return
     */
    @Bean
    public Binding deadBinding() {
        return BindingBuilder.bind(deadQueue()).to(deadExchange()).with(Constants.HORSE_DEAD_KEY);
    }

    //**********************************延時(shí)消息隊(duì)列配置信息(插件版)************************************

    @Bean
    public Queue pluginQueue() {
        return new Queue(Constants.HORSE_PLUGIN_QUEUE);
    }

   /**
     * 設(shè)置延時(shí)隊(duì)列的交換機(jī),必須是 CustomExchange 類型交換機(jī)
     * 參數(shù)必須,不能改變
     * @return
     */
    @Bean
    public CustomExchange customPluginExchange() {
        Map<String, Object> args = new HashMap<>(2);
        args.put("x-delayed-type", "direct");
        return new CustomExchange(Constants.HORSE_PLUGIN_EXCHANGE, "x-delayed-message", Boolean.TRUE, Boolean.FALSE, args);
    }

    @Bean
    public Binding pluginBinding() {
        return BindingBuilder.bind(pluginQueue()).to(customPluginExchange()).with(Constants.HORSE_PLUGIN_KEY).noargs();
    }

}

8. 定義延時(shí)監(jiān)聽器

/**
 * @author Mr.Horse
 * @version 1.0
 * @description: {description}
 * @date 2021/4/24 14:51
 */
@Component
public class DelayMsgListener {

    private static Logger logger = LoggerFactory.getLogger(DelayMsgListener.class);


    /**
     * 監(jiān)聽死信隊(duì)列
     *
     * @param message
     * @param channel
     * @param msg
     */
    @RabbitListener(queues = Constants.HORSE_DEAD_QUEUE)
    public void consumeDeadListener(Message message, Channel channel, String msg) {
        long tag = message.getMessageProperties().getDeliveryTag();
        try {
            logger.info(" ==> consumeDeadListener接收" + msg);
            // 手動(dòng)ACK確認(rèn)
            channel.basicAck(tag, false);
        } catch (IOException e) {
            logger.error(" ==> 消息接收失敗: {}", tag);
        }
    }

    /**
     * 監(jiān)聽延時(shí)隊(duì)列(插件版)
     *
     * @param message
     * @param channel
     * @param msg
     */
    @RabbitListener(queues = Constants.HORSE_PLUGIN_QUEUE)
    public void consumePluginListener(Message message, Channel channel, String msg) {
        long tag = message.getMessageProperties().getDeliveryTag();
        try {
            logger.info(" ==> consumePluginListener" + msg);
            // 手動(dòng)ACK確認(rèn)
            channel.basicAck(tag, false);
        } catch (IOException e) {
            logger.error(" ==> 消息接收失敗: {}", tag);
        }
    }

}

9. 測(cè)試接口

   // 基于特性的延時(shí)隊(duì)列
	@GetMapping("/delay/rabbit")
    public void delayMsg(@RequestParam("expire") Long expire) {
        for (int i = 1; i <= 10; i++) {
            String msg = "第" + i + "條消息";
            logger.info("==> 發(fā)送" + msg);
            // 這里可以動(dòng)態(tài)的設(shè)置過(guò)期時(shí)間
            rabbitTemplate.convertAndSend(Constants.HORSE_DELAY_EXCHANGE, Constants.HORSE_DELAY_KEY, msg,
                    message -> {
                        message.getMessageProperties().setExpiration(String.valueOf(expire));
                        return message;
                    },
                    new CorrelationData(String.valueOf(i)));
        }
    }

	// 基于插件的延時(shí)隊(duì)列
    @GetMapping("/delay/plugin")
    public void delayPluginMsg(@RequestParam("expire") Integer expire) {
        for (int i = 1; i <= 10; i++) {
            String msg = "第" + i + "條消息";
            logger.info("==> 發(fā)送" + msg);
            // 動(dòng)態(tài)設(shè)置過(guò)期時(shí)間
            rabbitTemplate.convertAndSend(Constants.HORSE_PLUGIN_EXCHANGE, Constants.HORSE_PLUGIN_KEY, msg, message -> {
                message.getMessageProperties().setDeliveryMode(MessageDeliveryMode.PERSISTENT);
                message.getMessageProperties().setDelay(expire);
                return message;
            }, new CorrelationData(String.valueOf(i)));

        }
    }

結(jié)果:你懂的:scream_cat::scream_cat::scream_cat:

RabbitMQ的基礎(chǔ)使用演示到此結(jié)束。

總結(jié)

到此這篇關(guān)于SpringBoot整合RabbitMQ消息隊(duì)列的文章就介紹到這了,更多相關(guān)SpringBoot整合RabbitMQ消息隊(duì)列內(nèi)容請(qǐng)搜索腳本之家以前的文章或繼續(xù)瀏覽下面的相關(guān)文章希望大家以后多多支持腳本之家!

相關(guān)文章

  • 一文帶你了解如何正確使用Java中的字符串常量池

    一文帶你了解如何正確使用Java中的字符串常量池

    研究表明,Java堆中對(duì)象占據(jù)最大比重的就是字符串對(duì)象,所以弄清楚字符串知識(shí)對(duì)學(xué)習(xí)Java很重要。本文主要重點(diǎn)聊聊字符串常量池,希望對(duì)大家有所幫助
    2022-12-12
  • JSON.toJSONString()方法在Java中的使用方法及應(yīng)用場(chǎng)景

    JSON.toJSONString()方法在Java中的使用方法及應(yīng)用場(chǎng)景

    這篇文章主要給大家介紹了關(guān)于JSON.toJSONString()方法在Java中的使用方法及應(yīng)用場(chǎng)景,JSON.toJSONString是將對(duì)象轉(zhuǎn)化為Json字符串,文中通過(guò)代碼介紹的非常詳細(xì),需要的朋友可以參考下
    2024-04-04
  • Java調(diào)用wsdl接口的兩種方法(axis和wsimport)

    Java調(diào)用wsdl接口的兩種方法(axis和wsimport)

    本文主要介紹了Java調(diào)用wsdl接口的兩種方法(axis和wsimport),文中通過(guò)示例代碼介紹的非常詳細(xì),對(duì)大家的學(xué)習(xí)或者工作具有一定的參考學(xué)習(xí)價(jià)值,需要的朋友們下面隨著小編來(lái)一起學(xué)習(xí)學(xué)習(xí)吧
    2023-03-03
  • 純注解版spring與mybatis的整合過(guò)程

    純注解版spring與mybatis的整合過(guò)程

    這篇文章主要介紹了純注解版spring與mybatis的整合過(guò)程,本文通過(guò)示例代碼給大家介紹的非常詳細(xì),對(duì)大家的學(xué)習(xí)或工作具有一定的參考借鑒價(jià)值,需要的朋友可以參考下
    2022-06-06
  • Retrofit+RxJava實(shí)現(xiàn)帶進(jìn)度下載文件

    Retrofit+RxJava實(shí)現(xiàn)帶進(jìn)度下載文件

    這篇文章主要為大家詳細(xì)介紹了Retrofit+RxJava實(shí)現(xiàn)帶進(jìn)度下載文件,具有一定的參考價(jià)值,感興趣的小伙伴們可以參考一下
    2018-05-05
  • SpringBoot與Quartz集成實(shí)現(xiàn)分布式定時(shí)任務(wù)集群的代碼實(shí)例

    SpringBoot與Quartz集成實(shí)現(xiàn)分布式定時(shí)任務(wù)集群的代碼實(shí)例

    今天小編就為大家分享一篇關(guān)于SpringBoot與Quartz集成實(shí)現(xiàn)分布式定時(shí)任務(wù)集群的代碼實(shí)例,小編覺得內(nèi)容挺不錯(cuò)的,現(xiàn)在分享給大家,具有很好的參考價(jià)值,需要的朋友一起跟隨小編來(lái)看看吧
    2019-03-03
  • 解析阿里一面CyclicBarrier和CountDownLatch的區(qū)別

    解析阿里一面CyclicBarrier和CountDownLatch的區(qū)別

    這篇文章主要介紹了阿里一面CyclicBarrier和CountDownLatch的區(qū)別是啥,本文給大家介紹的非常詳細(xì),對(duì)大家的學(xué)習(xí)或工作具有一定的參考借鑒價(jià)值,需要的朋友可以參考下
    2021-03-03
  • 剖析Java中阻塞隊(duì)列的實(shí)現(xiàn)原理及應(yīng)用場(chǎng)景

    剖析Java中阻塞隊(duì)列的實(shí)現(xiàn)原理及應(yīng)用場(chǎng)景

    這篇文章主要介紹了剖析Java中阻塞隊(duì)列的實(shí)現(xiàn)原理及應(yīng)用場(chǎng)景,這里也對(duì)阻塞和非阻塞隊(duì)列的不同之處進(jìn)行了對(duì)比,需要的朋友可以參考下
    2015-12-12
  • Messges Queue消息隊(duì)列詳解

    Messges Queue消息隊(duì)列詳解

    這篇文章主要介紹了Messges Queue消息隊(duì)列詳解,消息隊(duì)列一般簡(jiǎn)稱為 MQ,是指利用高效可靠的消息傳遞機(jī)制進(jìn)行與平臺(tái)無(wú)關(guān)的數(shù)據(jù)交流,并基于數(shù)據(jù)通信來(lái)進(jìn)行分布式系統(tǒng)的集成,是在消息的傳輸過(guò)程中保存消息的容器,需要的朋友可以參考下
    2023-07-07
  • 2020版IDEA整合GitHub的方法詳解

    2020版IDEA整合GitHub的方法詳解

    這篇文章主要介紹了2020版IDEA整合GitHub的方法,本文通過(guò)圖文并茂的形式給大家介紹的非常詳細(xì),對(duì)大家的學(xué)習(xí)或工作具有一定的參考借鑒價(jià)值,需要的朋友可以參考下
    2020-08-08

最新評(píng)論