当前位置: 首页 > news >正文

RabbitMQ用法的6种核心模式全面解析

在这里插入图片描述

文章目录
      • **一、RabbitMQ核心架构解析**
        • 1. AMQP协议模型
        • 2. 消息流转原理
      • **二、六大核心用法详解**
        • **1. 简单队列模式(Hello World)**
        • **2. 工作队列模式(Work Queues)**
        • **3. 发布/订阅模式(Pub/Sub)**
        • **4. 路由模式(Routing)**
        • **5. 主题模式(Topics)**
        • **6. RPC模式(远程调用)**
      • **三、高级特性实战**
        • **1. 消息持久化**
        • **2. 死信队列(DLX)**
        • **3. 延迟队列(插件实现)**
      • **四、集群与高可用方案**
        • 1. 镜像队列配置
        • 2. 联邦跨机房部署
      • **五、性能调优指南**
      • **六、企业级应用场景**
        • 1. 电商订单系统
        • 2. 物联网数据管道
        • 3. 微服务通信
      • **七、监控与故障排查**
        • 1. 关键监控指标
        • 2. 常见问题处理
      • **八、安全加固方案**
      • **演进趋势**

在这里插入图片描述

一、RabbitMQ核心架构解析
1. AMQP协议模型

#mermaid-svg-bCCcGiq5hHFnzpl3 {font-family:“trebuchet ms”,verdana,arial,sans-serif;font-size:16px;fill:#333;}#mermaid-svg-bCCcGiq5hHFnzpl3 .error-icon{fill:#552222;}#mermaid-svg-bCCcGiq5hHFnzpl3 .error-text{fill:#552222;stroke:#552222;}#mermaid-svg-bCCcGiq5hHFnzpl3 .edge-thickness-normal{stroke-width:2px;}#mermaid-svg-bCCcGiq5hHFnzpl3 .edge-thickness-thick{stroke-width:3.5px;}#mermaid-svg-bCCcGiq5hHFnzpl3 .edge-pattern-solid{stroke-dasharray:0;}#mermaid-svg-bCCcGiq5hHFnzpl3 .edge-pattern-dashed{stroke-dasharray:3;}#mermaid-svg-bCCcGiq5hHFnzpl3 .edge-pattern-dotted{stroke-dasharray:2;}#mermaid-svg-bCCcGiq5hHFnzpl3 .marker{fill:#333333;stroke:#333333;}#mermaid-svg-bCCcGiq5hHFnzpl3 .marker.cross{stroke:#333333;}#mermaid-svg-bCCcGiq5hHFnzpl3 svg{font-family:“trebuchet ms”,verdana,arial,sans-serif;font-size:16px;}#mermaid-svg-bCCcGiq5hHFnzpl3 .label{font-family:“trebuchet ms”,verdana,arial,sans-serif;color:#333;}#mermaid-svg-bCCcGiq5hHFnzpl3 .cluster-label text{fill:#333;}#mermaid-svg-bCCcGiq5hHFnzpl3 .cluster-label span{color:#333;}#mermaid-svg-bCCcGiq5hHFnzpl3 .label text,#mermaid-svg-bCCcGiq5hHFnzpl3 span{fill:#333;color:#333;}#mermaid-svg-bCCcGiq5hHFnzpl3 .node rect,#mermaid-svg-bCCcGiq5hHFnzpl3 .node circle,#mermaid-svg-bCCcGiq5hHFnzpl3 .node ellipse,#mermaid-svg-bCCcGiq5hHFnzpl3 .node polygon,#mermaid-svg-bCCcGiq5hHFnzpl3 .node path{fill:#ECECFF;stroke:#9370DB;stroke-width:1px;}#mermaid-svg-bCCcGiq5hHFnzpl3 .node .label{text-align:center;}#mermaid-svg-bCCcGiq5hHFnzpl3 .node.clickable{cursor:pointer;}#mermaid-svg-bCCcGiq5hHFnzpl3 .arrowheadPath{fill:#333333;}#mermaid-svg-bCCcGiq5hHFnzpl3 .edgePath .path{stroke:#333333;stroke-width:2.0px;}#mermaid-svg-bCCcGiq5hHFnzpl3 .flowchart-link{stroke:#333333;fill:none;}#mermaid-svg-bCCcGiq5hHFnzpl3 .edgeLabel{background-color:#e8e8e8;text-align:center;}#mermaid-svg-bCCcGiq5hHFnzpl3 .edgeLabel rect{opacity:0.5;background-color:#e8e8e8;fill:#e8e8e8;}#mermaid-svg-bCCcGiq5hHFnzpl3 .cluster rect{fill:#ffffde;stroke:#aaaa33;stroke-width:1px;}#mermaid-svg-bCCcGiq5hHFnzpl3 .cluster text{fill:#333;}#mermaid-svg-bCCcGiq5hHFnzpl3 .cluster span{color:#333;}#mermaid-svg-bCCcGiq5hHFnzpl3 div.mermaidTooltip{position:absolute;text-align:center;max-width:200px;padding:2px;font-family:“trebuchet ms”,verdana,arial,sans-serif;font-size:12px;background:hsl(80, 100%, 96.2745098039%);border:1px solid #aaaa33;border-radius:2px;pointer-events:none;z-index:100;}#mermaid-svg-bCCcGiq5hHFnzpl3 :root{–mermaid-font-family:“trebuchet ms”,verdana,arial,sans-serif;}

Channel

Binding

Publisher/Consumer

VirtualHost

Exchange

Queue

Consumer

  • 核心组件
    • Broker:消息代理服务器
    • Virtual Host:逻辑隔离单元(类似MySQL的database)
    • Channel:复用TCP连接的轻量级链接(减少3次握手开销)
    • Exchange:路由决策引擎(4种类型)
    • Queue:存储消息的缓冲区(内存/磁盘持久化)
2. 消息流转原理
# 生产者发布消息
channel.basic_publish(exchange='orders',routing_key='payment',body=json.dumps(order),properties=pika.BasicProperties(delivery_mode=2,  # 持久化消息headers={'priority': 'high'})
)# 消费者订阅
def callback(ch, method, properties, body):process_message(body)ch.basic_ack(delivery_tag=method.delivery_tag)  # 手动ACKchannel.basic_consume(queue='payment_queue',on_message_callback=callback,auto_ack=False  # 关闭自动确认
)

二、六大核心用法详解
1. 简单队列模式(Hello World)

场景:单生产者-单消费者基础通信
拓扑结构

[Producer] → [Queue] → [Consumer]

Java实现

// 生产者
ConnectionFactory factory = new ConnectionFactory();
factory.setHost("localhost");
try (Connection conn = factory.newConnection();Channel channel = conn.createChannel()) {channel.queueDeclare("hello", false, false, false, null);channel.basicPublish("", "hello", null, "Hello World!".getBytes());
}// 消费者
DeliverCallback callback = (consumerTag, delivery) -> {String msg = new String(delivery.getBody(), "UTF-8");System.out.println("Received: " + msg);
};
channel.basicConsume("hello", true, callback, consumerTag -> {});

性能指标

  • 吞吐量:约5,000 msg/sec(非持久化)
  • 延迟:<5ms(局域网环境)

2. 工作队列模式(Work Queues)

场景:任务分发与负载均衡
关键配置

channel.basic_qos(prefetch_count=1,  # 每次只分发1条消息global=False       # 应用于当前channel
)

消息公平分发原理

  1. 消费者声明处理能力(prefetch_count)
  2. Broker暂停向忙碌消费者发送新消息
  3. 收到ACK后分配下一条消息

Golang实现

// 工作者进程
msgs, err := ch.Consume("task_queue","",false,  // auto-ackfalse,false,false,nil,
)for msg := range msgs {processTask(msg.Body)msg.Ack(false)  // 手动确认
}

适用场景

  • 图像处理任务队列
  • 订单处理系统
  • 日志分析管道

3. 发布/订阅模式(Pub/Sub)

拓扑结构

[Producer] → [Fanout Exchange] → [Queue1][Queue2][Queue3]→ [Consumer1][Consumer2][Consumer3]

Node.js实现

// 发布者
channel.assertExchange('logs', 'fanout', { durable: false });
channel.publish('logs', '', Buffer.from('Log Message'));// 订阅者
channel.assertQueue('', { exclusive: true }, (err, q) => {channel.bindQueue(q.queue, 'logs', '');channel.consume(q.queue, (msg) => {console.log(msg.content.toString());}, { noAck: true });
});

消息广播原理

  • Fanout Exchange忽略routing_key
  • 所有绑定队列获得消息副本
  • 临时队列(exclusive)适合瞬时消费者

4. 路由模式(Routing)

场景:按条件接收消息(如错误日志分级)
Exchange类型:direct
Python示例

# 绑定不同路由键
channel.queue_bind(exchange='direct_logs',queue=queue_name,routing_key='error'
)# 发布带路由键的消息
channel.basic_publish(exchange='direct_logs',routing_key='error',  # 可以是error/warning/infobody=message
)

消息筛选流程

  1. 队列通过binding key绑定到Exchange
  2. 消息携带routing_key到达Exchange
  3. 完全匹配的binding接收消息

5. 主题模式(Topics)

场景:多维度消息分类(如传感器数据)
路由键规则

  • *匹配1个单词(如*.temperature
  • #匹配0-N个单词(如sensors.#

Java实现

// 绑定主题
channel.queueBind("queue1", "topic_logs", "*.critical");
channel.queueBind("queue2", "topic_logs", "kernel.*");// 发布主题消息
channel.basicPublish("topic_logs", "kernel.critical", null, msg.getBytes());

典型应用

  • IoT设备数据路由(device123.temperature
  • 多租户系统事件通知(tenantA.order.created

6. RPC模式(远程调用)

时序流程

#mermaid-svg-aMM4Be6s4zlNgmdh {font-family:“trebuchet ms”,verdana,arial,sans-serif;font-size:16px;fill:#333;}#mermaid-svg-aMM4Be6s4zlNgmdh .error-icon{fill:#552222;}#mermaid-svg-aMM4Be6s4zlNgmdh .error-text{fill:#552222;stroke:#552222;}#mermaid-svg-aMM4Be6s4zlNgmdh .edge-thickness-normal{stroke-width:2px;}#mermaid-svg-aMM4Be6s4zlNgmdh .edge-thickness-thick{stroke-width:3.5px;}#mermaid-svg-aMM4Be6s4zlNgmdh .edge-pattern-solid{stroke-dasharray:0;}#mermaid-svg-aMM4Be6s4zlNgmdh .edge-pattern-dashed{stroke-dasharray:3;}#mermaid-svg-aMM4Be6s4zlNgmdh .edge-pattern-dotted{stroke-dasharray:2;}#mermaid-svg-aMM4Be6s4zlNgmdh .marker{fill:#333333;stroke:#333333;}#mermaid-svg-aMM4Be6s4zlNgmdh .marker.cross{stroke:#333333;}#mermaid-svg-aMM4Be6s4zlNgmdh svg{font-family:“trebuchet ms”,verdana,arial,sans-serif;font-size:16px;}#mermaid-svg-aMM4Be6s4zlNgmdh .actor{stroke:hsl(259.6261682243, 59.7765363128%, 87.9019607843%);fill:#ECECFF;}#mermaid-svg-aMM4Be6s4zlNgmdh text.actor>tspan{fill:black;stroke:none;}#mermaid-svg-aMM4Be6s4zlNgmdh .actor-line{stroke:grey;}#mermaid-svg-aMM4Be6s4zlNgmdh .messageLine0{stroke-width:1.5;stroke-dasharray:none;stroke:#333;}#mermaid-svg-aMM4Be6s4zlNgmdh .messageLine1{stroke-width:1.5;stroke-dasharray:2,2;stroke:#333;}#mermaid-svg-aMM4Be6s4zlNgmdh #arrowhead path{fill:#333;stroke:#333;}#mermaid-svg-aMM4Be6s4zlNgmdh .sequenceNumber{fill:white;}#mermaid-svg-aMM4Be6s4zlNgmdh #sequencenumber{fill:#333;}#mermaid-svg-aMM4Be6s4zlNgmdh #crosshead path{fill:#333;stroke:#333;}#mermaid-svg-aMM4Be6s4zlNgmdh .messageText{fill:#333;stroke:#333;}#mermaid-svg-aMM4Be6s4zlNgmdh .labelBox{stroke:hsl(259.6261682243, 59.7765363128%, 87.9019607843%);fill:#ECECFF;}#mermaid-svg-aMM4Be6s4zlNgmdh .labelText,#mermaid-svg-aMM4Be6s4zlNgmdh .labelText>tspan{fill:black;stroke:none;}#mermaid-svg-aMM4Be6s4zlNgmdh .loopText,#mermaid-svg-aMM4Be6s4zlNgmdh .loopText>tspan{fill:black;stroke:none;}#mermaid-svg-aMM4Be6s4zlNgmdh .loopLine{stroke-width:2px;stroke-dasharray:2,2;stroke:hsl(259.6261682243, 59.7765363128%, 87.9019607843%);fill:hsl(259.6261682243, 59.7765363128%, 87.9019607843%);}#mermaid-svg-aMM4Be6s4zlNgmdh .note{stroke:#aaaa33;fill:#fff5ad;}#mermaid-svg-aMM4Be6s4zlNgmdh .noteText,#mermaid-svg-aMM4Be6s4zlNgmdh .noteText>tspan{fill:black;stroke:none;}#mermaid-svg-aMM4Be6s4zlNgmdh .activation0{fill:#f4f4f4;stroke:#666;}#mermaid-svg-aMM4Be6s4zlNgmdh .activation1{fill:#f4f4f4;stroke:#666;}#mermaid-svg-aMM4Be6s4zlNgmdh .activation2{fill:#f4f4f4;stroke:#666;}#mermaid-svg-aMM4Be6s4zlNgmdh .actorPopupMenu{position:absolute;}#mermaid-svg-aMM4Be6s4zlNgmdh .actorPopupMenuPanel{position:absolute;fill:#ECECFF;box-shadow:0px 8px 16px 0px rgba(0,0,0,0.2);filter:drop-shadow(3px 5px 2px rgb(0 0 0 / 0.4));}#mermaid-svg-aMM4Be6s4zlNgmdh .actor-man line{stroke:hsl(259.6261682243, 59.7765363128%, 87.9019607843%);fill:#ECECFF;}#mermaid-svg-aMM4Be6s4zlNgmdh .actor-man circle,#mermaid-svg-aMM4Be6s4zlNgmdh line{stroke:hsl(259.6261682243, 59.7765363128%, 87.9019607843%);fill:#ECECFF;stroke-width:2px;}#mermaid-svg-aMM4Be6s4zlNgmdh :root{–mermaid-font-family:“trebuchet ms”,verdana,arial,sans-serif;} Client Server 1. 发布请求到rpc_queue 包含reply_to和correlation_id 2. 响应返回到回调队列 3. 匹配correlation_id Client Server

Python完整实现

# RPC客户端
class RpcClient:def __init__(self):self.connection = pika.BlockingConnection()self.channel = self.connection.channel()result = self.channel.queue_declare('', exclusive=True)self.callback_queue = result.method.queueself.channel.basic_consume(queue=self.callback_queue,on_message_callback=self.on_response,auto_ack=True)self.response = Noneself.corr_id = Nonedef on_response(self, ch, method, props, body):if self.corr_id == props.correlation_id:self.response = bodydef call(self, n):self.response = Noneself.corr_id = str(uuid.uuid4())self.channel.basic_publish(exchange='',routing_key='rpc_queue',properties=pika.BasicProperties(reply_to=self.callback_queue,correlation_id=self.corr_id,),body=str(n))while self.response is None:self.connection.process_data_events()return int(self.response)

性能优化建议

  • 设置超时机制(避免无限等待)
  • 使用连接池管理Channel
  • 批量请求合并(减少网络往返)

三、高级特性实战
1. 消息持久化
// 队列持久化
boolean durable = true;
channel.queueDeclare("task_queue", durable, false, false, null);// 消息持久化
channel.basicPublish("", "task_queue", MessageProperties.PERSISTENT_TEXT_PLAIN,message.getBytes());

注意事项

  • 磁盘写入增加延迟(约20-50ms)
  • 需要配置镜像队列实现高可用
2. 死信队列(DLX)
# 配置死信交换
args = {"x-dead-letter-exchange": "dlx_exchange","x-message-ttl": 10000  # 10秒过期
}
channel.queue_declare(queue='work_queue',arguments=args
)

典型应用场景

  • 订单超时未支付取消
  • 失败消息重试机制
3. 延迟队列(插件实现)
# 安装插件
rabbitmq-plugins enable rabbitmq_delayed_message_exchange// 创建延迟交换
Map<String, Object> args = new HashMap<>();
args.put("x-delayed-type", "direct");
channel.exchangeDeclare("delayed_exchange", "x-delayed-message", true, false, args
);// 发送延迟消息
AMQP.BasicProperties props = new AMQP.BasicProperties.Builder().headers(new HashMap<String, Object>(){{put("x-delay", 5000);  // 5秒延迟}}).build();
channel.basicPublish("delayed_exchange", "routing_key", props, message.getBytes());

四、集群与高可用方案
1. 镜像队列配置
# 设置镜像策略
rabbitmqctl set_policy ha-all "^ha." '{"ha-mode":"all"}'

数据同步原理

  • GM(Guaranteed Multicast)协议保证一致性
  • 新消息同步到所有镜像节点后确认
2. 联邦跨机房部署
# federation配置文件
[federation-upstream]
name = east-coast
uri = amqp://server-east
max-hops = 2
[policy]
pattern = ^fed.
federation-upstream-set = all

五、性能调优指南

参数

推荐值

说明

channel_max

2048

每个连接的最大通道数

frame_max

131072

单个帧大小(128KB)

heartbeat

60

心跳间隔(秒)

prefetch_count

30-100

根据消费者处理能力调整

queue_index_max_journal_entries

32768

磁盘日志条目批处理大小

基准测试结果(16核32GB环境):

  • 持久化消息:12,000 msg/sec
  • 非持久化消息:85,000 msg/sec
  • 延迟:99% <15ms(局域网)

六、企业级应用场景
1. 电商订单系统

#mermaid-svg-VKqGndhYH3PvJlZa {font-family:“trebuchet ms”,verdana,arial,sans-serif;font-size:16px;fill:#333;}#mermaid-svg-VKqGndhYH3PvJlZa .error-icon{fill:#552222;}#mermaid-svg-VKqGndhYH3PvJlZa .error-text{fill:#552222;stroke:#552222;}#mermaid-svg-VKqGndhYH3PvJlZa .edge-thickness-normal{stroke-width:2px;}#mermaid-svg-VKqGndhYH3PvJlZa .edge-thickness-thick{stroke-width:3.5px;}#mermaid-svg-VKqGndhYH3PvJlZa .edge-pattern-solid{stroke-dasharray:0;}#mermaid-svg-VKqGndhYH3PvJlZa .edge-pattern-dashed{stroke-dasharray:3;}#mermaid-svg-VKqGndhYH3PvJlZa .edge-pattern-dotted{stroke-dasharray:2;}#mermaid-svg-VKqGndhYH3PvJlZa .marker{fill:#333333;stroke:#333333;}#mermaid-svg-VKqGndhYH3PvJlZa .marker.cross{stroke:#333333;}#mermaid-svg-VKqGndhYH3PvJlZa svg{font-family:“trebuchet ms”,verdana,arial,sans-serif;font-size:16px;}#mermaid-svg-VKqGndhYH3PvJlZa .label{font-family:“trebuchet ms”,verdana,arial,sans-serif;color:#333;}#mermaid-svg-VKqGndhYH3PvJlZa .cluster-label text{fill:#333;}#mermaid-svg-VKqGndhYH3PvJlZa .cluster-label span{color:#333;}#mermaid-svg-VKqGndhYH3PvJlZa .label text,#mermaid-svg-VKqGndhYH3PvJlZa span{fill:#333;color:#333;}#mermaid-svg-VKqGndhYH3PvJlZa .node rect,#mermaid-svg-VKqGndhYH3PvJlZa .node circle,#mermaid-svg-VKqGndhYH3PvJlZa .node ellipse,#mermaid-svg-VKqGndhYH3PvJlZa .node polygon,#mermaid-svg-VKqGndhYH3PvJlZa .node path{fill:#ECECFF;stroke:#9370DB;stroke-width:1px;}#mermaid-svg-VKqGndhYH3PvJlZa .node .label{text-align:center;}#mermaid-svg-VKqGndhYH3PvJlZa .node.clickable{cursor:pointer;}#mermaid-svg-VKqGndhYH3PvJlZa .arrowheadPath{fill:#333333;}#mermaid-svg-VKqGndhYH3PvJlZa .edgePath .path{stroke:#333333;stroke-width:2.0px;}#mermaid-svg-VKqGndhYH3PvJlZa .flowchart-link{stroke:#333333;fill:none;}#mermaid-svg-VKqGndhYH3PvJlZa .edgeLabel{background-color:#e8e8e8;text-align:center;}#mermaid-svg-VKqGndhYH3PvJlZa .edgeLabel rect{opacity:0.5;background-color:#e8e8e8;fill:#e8e8e8;}#mermaid-svg-VKqGndhYH3PvJlZa .cluster rect{fill:#ffffde;stroke:#aaaa33;stroke-width:1px;}#mermaid-svg-VKqGndhYH3PvJlZa .cluster text{fill:#333;}#mermaid-svg-VKqGndhYH3PvJlZa .cluster span{color:#333;}#mermaid-svg-VKqGndhYH3PvJlZa div.mermaidTooltip{position:absolute;text-align:center;max-width:200px;padding:2px;font-family:“trebuchet ms”,verdana,arial,sans-serif;font-size:12px;background:hsl(80, 100%, 96.2745098039%);border:1px solid #aaaa33;border-radius:2px;pointer-events:none;z-index:100;}#mermaid-svg-VKqGndhYH3PvJlZa :root{–mermaid-font-family:“trebuchet ms”,verdana,arial,sans-serif;}

order.created

OrderService

RabbitMQ

PaymentService

InventoryService

LogService

  • 使用Topic Exchange路由不同类型事件
  • 引入死信队列处理支付超时
2. 物联网数据管道
# 温度数据处理流程
def handle_temp_message(channel, method, properties, body):data = json.loads(body)if data['temp'] > 50:channel.basic_publish(exchange='alerts',routing_key='high_temp',body=body)store_to_tsdb(data)  # 存入时序数据库
3. 微服务通信
# Spring Cloud Stream配置
spring:cloud:stream:bindings:orderOutput:destination: ordersbinder: rabbitpaymentInput:destination: paymentsbinder: rabbitrabbit:bindings:orderOutput:producer:routingKeyExpression: '"payment"'paymentInput:consumer:bindingRoutingKey: payment

七、监控与故障排查
1. 关键监控指标
  • 消息堆积rabbitmqctl list_queues name messages_ready
  • 节点状态rabbitmq-diagnostics node_health_check
  • 吞吐量:Prometheus + Grafana监控
2. 常见问题处理

消息丢失场景

  1. 生产者未开启confirm模式 → 启用publisher confirms
  2. 队列未持久化 → 设置durable=true
  3. 消费者未ACK → 关闭auto_ack手动确认

性能瓶颈排查

# 查看Erlang进程状态
rabbitmqctl status | grep run_queue
# 网络检查
rabbitmq-diagnostics check_network

八、安全加固方案
  1. TLS加密传输

    # 生成证书
    openssl req -x509 -newkey rsa:4096 -keyout key.pem -out cert.pem -days 365
    # 配置RabbitMQ
    listeners.ssl.default = 5671
    ssl_options.cacertfile = /path/to/ca_certificate.pem
    ssl_options.certfile = /path/to/server_certificate.pem
    ssl_options.keyfile = /path/to/server_key.pem
    ssl_options.verify = verify_peer
    
  2. RBAC权限控制

    # 创建管理用户
    rabbitmqctl add_user admin strongpassword
    rabbitmqctl set_user_tags admin administrator
    rabbitmqctl set_permissions -p / admin ".*" ".*" ".*"
    

演进趋势
  1. MQTT协议支持:物联网轻量级通信
  2. Kubernetes Operator:云原生部署
  3. 与Apache Kafka集成:构建混合消息架构
  4. WASM插件:扩展消息处理能力

最佳实践建议

  • 生产环境始终启用持久化和镜像队列
  • 使用单独的Virtual Host隔离不同业务
  • 消息体保持精简(建议<1MB)
  • 实施蓝绿部署升级集群
    在这里插入图片描述
http://www.xdnf.cn/news/1099909.html

相关文章:

  • 零基础入门物联网-远程门禁开关:云平台创建
  • 自动驾驶控制系统
  • 李宏毅(深度学习)--(2)
  • 【TCP/IP】10. 引导协议与动态主机配置协议
  • 查看uniapp 项目中没有用到依赖
  • mx6ull-裸机学习实验15——RTC 实时时钟实验
  • 【养老机器人】核心技术
  • 栈题解——有效的括号【LeetCode】两种方法
  • LangChain框架 Prompts、Agents 应用
  • Git 学习笔记
  • OpenAI正准备推出一款搭载人工智能功能的网络浏览器,试图直接挑战Alphabet旗下
  • RISC-V:开源芯浪潮下的技术突围与职业新赛道 (二) RISC-V架构深度解剖(上)
  • 链表算法之【合并两个有序链表】
  • 【算法笔记 day three】滑动窗口(其他类型)
  • STM32第十九天 ESP8266-01S和电脑实现串口通信(2)
  • leetcode 3440. 重新安排会议得到最多空余时间 II 中等
  • 50天50个小项目 (Vue3 + Tailwindcss V4) ✨ | DoubleVerticalSlider(双垂直滑块)
  • idea如何打开extract surround
  • (C++)任务管理系统(文件存储)(正式版)(迭代器)(list列表基础教程)(STL基础知识)
  • 自动化脚本配置网络IP、主机名、网段
  • Python正则表达式实战指南
  • k8s:安装 Helm 私有仓库ChartMuseum、helm-push插件并上传、安装Zookeeper
  • 快速分页wpf
  • 解锁localtime:使用技巧与避坑指南
  • 深度学习中的常见损失函数详解及PyTorch实现
  • 初学者对编译和链接的学习笔记(含预编译详解)
  • c++-内部类
  • 网络安全初级
  • python正则表达式(小白五分钟从入门到精通)
  • 技术学习_检索增强生成(RAG)