[GH] (rocketmq): Workflow run "PR-CI" failed!

2024-12-13 Thread GitBox


The GitHub Actions job "PR-CI" on rocketmq.git has failed.
Run started by GitHub user i36lib (triggered by RongtongJin).

Head commit for run:
c20d14584dbd69a12344a461b544d9fc8241c327 / Fury 
[ISSUE #9047] optimize code format and reduce some methods cognitive complexity

Report URL: https://github.com/apache/rocketmq/actions/runs/12312946777

With regards,
GitHub Actions via GitBox



[GH] (rocketmq): Workflow run "E2E test for pull request" failed!

2024-12-13 Thread GitBox


The GitHub Actions job "E2E test for pull request" on rocketmq.git has failed.
Run started by GitHub user i36lib (triggered by i36lib).

Head commit for run:
9aa081b8acfd01a40f50bd9c3face3c0d2c530b1 / guyinyou 
<36399867+guyin...@users.noreply.github.com>
[ISSUE #8988] Support dispatchBehindMilliseconds (#8989)

* support dispatchBehindMilliseconds

* Modify the initial value of currentReputTimestamp

-

Co-authored-by: guyinyou 

Report URL: https://github.com/apache/rocketmq/actions/runs/12325921109

With regards,
GitHub Actions via GitBox



[GH] (rocketmq): Workflow run "Build and Run Tests by Maven" failed!

2024-12-13 Thread GitBox


The GitHub Actions job "Build and Run Tests by Maven" on rocketmq.git has 
failed.
Run started by GitHub user i36lib (triggered by RongtongJin).

Head commit for run:
c20d14584dbd69a12344a461b544d9fc8241c327 / Fury 
[ISSUE #9047] optimize code format and reduce some methods cognitive complexity

Report URL: https://github.com/apache/rocketmq/actions/runs/12312946644

With regards,
GitHub Actions via GitBox



[GH] (rocketmq): Workflow run "Coverage" failed!

2024-12-13 Thread GitBox


The GitHub Actions job "Coverage" on rocketmq.git has failed.
Run started by GitHub user i36lib (triggered by RongtongJin).

Head commit for run:
c20d14584dbd69a12344a461b544d9fc8241c327 / Fury 
[ISSUE #9047] optimize code format and reduce some methods cognitive complexity

Report URL: https://github.com/apache/rocketmq/actions/runs/12312946641

With regards,
GitHub Actions via GitBox



Re: [I] [Enhancement] Make some SYSTEM_ERROR error more meaningful [rocketmq]

2024-12-13 Thread via GitHub


RongtongJin closed issue #9028: [Enhancement] Make some SYSTEM_ERROR error more 
meaningful
URL: https://github.com/apache/rocketmq/issues/9028


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: commits-unsubscr...@rocketmq.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] [ISSUE #9028]Adjust some error code for SYSTEM_ERROR [rocketmq]

2024-12-13 Thread via GitHub


RongtongJin merged PR #9027:
URL: https://github.com/apache/rocketmq/pull/9027


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: commits-unsubscr...@rocketmq.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



[GH] (rocketmq): Workflow run "Build and Run Tests by Maven" failed!

2024-12-13 Thread GitBox


The GitHub Actions job "Build and Run Tests by Maven" on rocketmq.git has 
failed.
Run started by GitHub user i36lib (triggered by github-actions[bot]).

Head commit for run:
c20d14584dbd69a12344a461b544d9fc8241c327 / Fury 
[ISSUE #9047] optimize code format and reduce some methods cognitive complexity

Report URL: https://github.com/apache/rocketmq/actions/runs/12312946644

With regards,
GitHub Actions via GitBox



[GH] (rocketmq): Workflow run "Build and Run Tests by Bazel" failed!

2024-12-13 Thread GitBox


The GitHub Actions job "Build and Run Tests by Bazel" on rocketmq.git has 
failed.
Run started by GitHub user i36lib (triggered by github-actions[bot]).

Head commit for run:
c20d14584dbd69a12344a461b544d9fc8241c327 / Fury 
[ISSUE #9047] optimize code format and reduce some methods cognitive complexity

Report URL: https://github.com/apache/rocketmq/actions/runs/12312946638

With regards,
GitHub Actions via GitBox



[GH] (rocketmq): Workflow run "Run Integration Tests" failed!

2024-12-13 Thread GitBox


The GitHub Actions job "Run Integration Tests" on rocketmq.git has failed.
Run started by GitHub user i36lib (triggered by RongtongJin).

Head commit for run:
c20d14584dbd69a12344a461b544d9fc8241c327 / Fury 
[ISSUE #9047] optimize code format and reduce some methods cognitive complexity

Report URL: https://github.com/apache/rocketmq/actions/runs/12312946657

With regards,
GitHub Actions via GitBox



(rocketmq) branch develop updated: [ISSUE #9028] Adjust some error code for SYSTEM_ERROR (#9027)

2024-12-13 Thread jinrongtong
This is an automated email from the ASF dual-hosted git repository.

jinrongtong pushed a commit to branch develop
in repository https://gitbox.apache.org/repos/asf/rocketmq.git


The following commit(s) were added to refs/heads/develop by this push:
 new b5cf3ca90a [ISSUE #9028] Adjust some error code for SYSTEM_ERROR 
(#9027)
b5cf3ca90a is described below

commit b5cf3ca90aba1765519ccd3244dc31e3852051ea
Author: Vincent Lee 
AuthorDate: Sat Dec 14 10:08:54 2024 +0800

[ISSUE #9028] Adjust some error code for SYSTEM_ERROR (#9027)

* feat: change some SYSTEM_ERROR to more meaningful error code

Change-Id: I4b6ffa5aa18325eeadc29941c5788244c2770423

* feat: change some SYSTEM_ERROR to more meaningful error code

Change-Id: I0c6ff75c5a2f7adde73261da93608781260e09da

* test: adjust test case for error code

Change-Id: I302ff5ad204280b55c8427ba4e8563b042263aeb

* test: adjust test case for error code

Change-Id: I7fc958c865c53b2a66b7bd77b6fb69f1546d2826
---
 .../rocketmq/broker/client/net/Broker2Client.java  |  2 +-
 .../processor/AbstractSendMessageProcessor.java|  4 +--
 .../broker/processor/AdminBrokerProcessor.java | 30 +++---
 .../broker/processor/ConsumerManageProcessor.java  |  4 +--
 .../broker/processor/NotificationProcessor.java|  2 +-
 .../broker/processor/PeekMessageProcessor.java |  2 +-
 .../broker/processor/PollingInfoProcessor.java |  2 +-
 .../broker/processor/PopMessageProcessor.java  |  4 +--
 .../broker/processor/PullMessageProcessor.java |  2 +-
 .../broker/client/net/Broker2ClientTest.java   |  2 +-
 .../broker/processor/AdminBrokerProcessorTest.java | 16 ++--
 .../broker/processor/PeekMessageProcessorTest.java |  2 +-
 .../rocketmq/remoting/protocol/ResponseCode.java   |  2 ++
 13 files changed, 38 insertions(+), 36 deletions(-)

diff --git 
a/broker/src/main/java/org/apache/rocketmq/broker/client/net/Broker2Client.java 
b/broker/src/main/java/org/apache/rocketmq/broker/client/net/Broker2Client.java
index f43f79b1be..f8984963f9 100644
--- 
a/broker/src/main/java/org/apache/rocketmq/broker/client/net/Broker2Client.java
+++ 
b/broker/src/main/java/org/apache/rocketmq/broker/client/net/Broker2Client.java
@@ -113,7 +113,7 @@ public class Broker2Client {
 TopicConfig topicConfig = 
this.brokerController.getTopicConfigManager().selectTopicConfig(topic);
 if (null == topicConfig) {
 log.error("[reset-offset] reset offset failed, no topic in this 
broker. topic={}", topic);
-response.setCode(ResponseCode.SYSTEM_ERROR);
+response.setCode(ResponseCode.TOPIC_NOT_EXIST);
 response.setRemark("[reset-offset] reset offset failed, no topic 
in this broker. topic=" + topic);
 return response;
 }
diff --git 
a/broker/src/main/java/org/apache/rocketmq/broker/processor/AbstractSendMessageProcessor.java
 
b/broker/src/main/java/org/apache/rocketmq/broker/processor/AbstractSendMessageProcessor.java
index ba2d1b5f32..39befedaa2 100644
--- 
a/broker/src/main/java/org/apache/rocketmq/broker/processor/AbstractSendMessageProcessor.java
+++ 
b/broker/src/main/java/org/apache/rocketmq/broker/processor/AbstractSendMessageProcessor.java
@@ -467,7 +467,7 @@ public abstract class AbstractSendMessageProcessor 
implements NettyRequestProces
 
 TopicValidator.ValidateTopicResult result = 
TopicValidator.validateTopic(requestHeader.getTopic());
 if (!result.isValid()) {
-response.setCode(ResponseCode.SYSTEM_ERROR);
+response.setCode(ResponseCode.INVALID_PARAMETER);
 response.setRemark(result.getRemark());
 return response;
 }
@@ -522,7 +522,7 @@ public abstract class AbstractSendMessageProcessor 
implements NettyRequestProces
 RemotingHelper.parseChannelRemoteAddr(ctx.channel()));
 
 LOGGER.warn(errorInfo);
-response.setCode(ResponseCode.SYSTEM_ERROR);
+response.setCode(ResponseCode.INVALID_PARAMETER);
 response.setRemark(errorInfo);
 
 return response;
diff --git 
a/broker/src/main/java/org/apache/rocketmq/broker/processor/AdminBrokerProcessor.java
 
b/broker/src/main/java/org/apache/rocketmq/broker/processor/AdminBrokerProcessor.java
index b9b8b06d7a..ffac714c1b 100644
--- 
a/broker/src/main/java/org/apache/rocketmq/broker/processor/AdminBrokerProcessor.java
+++ 
b/broker/src/main/java/org/apache/rocketmq/broker/processor/AdminBrokerProcessor.java
@@ -425,7 +425,7 @@ public class AdminBrokerProcessor implements 
NettyRequestProcessor {
 SubscriptionGroupConfig groupConfig = 
this.brokerController.getSubscriptionGroupManager().getSubscriptionGroupTable().get(requestHeader.getGroup());
 if (groupConfig == null) {
 LOGGER.error("No group in this broker, client: {} group: {}", 
ctx.channel().remoteAddress(), requestHeader.getGroup());
-   

Re: [PR] [ISSUE #9002]when bytebuffer is not enough, do not throw exception [rocketmq]

2024-12-13 Thread via GitHub


RongtongJin commented on PR #9003:
URL: https://github.com/apache/rocketmq/pull/9003#issuecomment-2542665791

   @leizhiyuan Could you please resolve the issue that's causing the CI to fail?


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: commits-unsubscr...@rocketmq.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



[GH] (rocketmq): Workflow run "Build and Run Tests by Bazel" failed!

2024-12-13 Thread GitBox


The GitHub Actions job "Build and Run Tests by Bazel" on rocketmq.git has 
failed.
Run started by GitHub user i36lib (triggered by RongtongJin).

Head commit for run:
c20d14584dbd69a12344a461b544d9fc8241c327 / Fury 
[ISSUE #9047] optimize code format and reduce some methods cognitive complexity

Report URL: https://github.com/apache/rocketmq/actions/runs/12312946638

With regards,
GitHub Actions via GitBox



[GH] (rocketmq): Workflow run "Build and Run Tests by Bazel" failed!

2024-12-13 Thread GitBox


The GitHub Actions job "Build and Run Tests by Bazel" on rocketmq.git has 
failed.
Run started by GitHub user RongtongJin (triggered by RongtongJin).

Head commit for run:
b5cf3ca90aba1765519ccd3244dc31e3852051ea / Vincent Lee 
[ISSUE #9028] Adjust some error code for SYSTEM_ERROR (#9027)

* feat: change some SYSTEM_ERROR to more meaningful error code

Change-Id: I4b6ffa5aa18325eeadc29941c5788244c2770423

* feat: change some SYSTEM_ERROR to more meaningful error code

Change-Id: I0c6ff75c5a2f7adde73261da93608781260e09da

* test: adjust test case for error code

Change-Id: I302ff5ad204280b55c8427ba4e8563b042263aeb

* test: adjust test case for error code

Change-Id: I7fc958c865c53b2a66b7bd77b6fb69f1546d2826

Report URL: https://github.com/apache/rocketmq/actions/runs/12325927892

With regards,
GitHub Actions via GitBox



[GH] (rocketmq): Workflow run "Build and Run Tests by Bazel" failed!

2024-12-13 Thread GitBox


The GitHub Actions job "Build and Run Tests by Bazel" on rocketmq.git has 
failed.
Run started by GitHub user RongtongJin (triggered by github-actions[bot]).

Head commit for run:
b5cf3ca90aba1765519ccd3244dc31e3852051ea / Vincent Lee 
[ISSUE #9028] Adjust some error code for SYSTEM_ERROR (#9027)

* feat: change some SYSTEM_ERROR to more meaningful error code

Change-Id: I4b6ffa5aa18325eeadc29941c5788244c2770423

* feat: change some SYSTEM_ERROR to more meaningful error code

Change-Id: I0c6ff75c5a2f7adde73261da93608781260e09da

* test: adjust test case for error code

Change-Id: I302ff5ad204280b55c8427ba4e8563b042263aeb

* test: adjust test case for error code

Change-Id: I7fc958c865c53b2a66b7bd77b6fb69f1546d2826

Report URL: https://github.com/apache/rocketmq/actions/runs/12325927892

With regards,
GitHub Actions via GitBox



[GH] (rocketmq): Workflow run "Build and Run Tests by Bazel" failed!

2024-12-13 Thread GitBox


The GitHub Actions job "Build and Run Tests by Bazel" on rocketmq.git has 
failed.
Run started by GitHub user RongtongJin (triggered by github-actions[bot]).

Head commit for run:
b5cf3ca90aba1765519ccd3244dc31e3852051ea / Vincent Lee 
[ISSUE #9028] Adjust some error code for SYSTEM_ERROR (#9027)

* feat: change some SYSTEM_ERROR to more meaningful error code

Change-Id: I4b6ffa5aa18325eeadc29941c5788244c2770423

* feat: change some SYSTEM_ERROR to more meaningful error code

Change-Id: I0c6ff75c5a2f7adde73261da93608781260e09da

* test: adjust test case for error code

Change-Id: I302ff5ad204280b55c8427ba4e8563b042263aeb

* test: adjust test case for error code

Change-Id: I7fc958c865c53b2a66b7bd77b6fb69f1546d2826

Report URL: https://github.com/apache/rocketmq/actions/runs/12325927892

With regards,
GitHub Actions via GitBox



[GH] (rocketmq): Workflow run "Run Integration Tests" is working again!

2024-12-13 Thread GitBox


The GitHub Actions job "Run Integration Tests" on rocketmq.git has succeeded.
Run started by GitHub user RongtongJin (triggered by RongtongJin).

Head commit for run:
b5cf3ca90aba1765519ccd3244dc31e3852051ea / Vincent Lee 
[ISSUE #9028] Adjust some error code for SYSTEM_ERROR (#9027)

* feat: change some SYSTEM_ERROR to more meaningful error code

Change-Id: I4b6ffa5aa18325eeadc29941c5788244c2770423

* feat: change some SYSTEM_ERROR to more meaningful error code

Change-Id: I0c6ff75c5a2f7adde73261da93608781260e09da

* test: adjust test case for error code

Change-Id: I302ff5ad204280b55c8427ba4e8563b042263aeb

* test: adjust test case for error code

Change-Id: I7fc958c865c53b2a66b7bd77b6fb69f1546d2826

Report URL: https://github.com/apache/rocketmq/actions/runs/12325927886

With regards,
GitHub Actions via GitBox



[I] [Enhancement] 5.x client cant support broadcasting mode? [rocketmq-clients]

2024-12-13 Thread via GitHub


xieyj-apple opened a new issue, #888:
URL: https://github.com/apache/rocketmq-clients/issues/888

   ### Before Creating the Enhancement Request
   
   - [X] I have confirmed that this should be classified as an enhancement 
rather than a bug/feature.
   
   
   ### Programming Language of the Client
   
   Go
   
   ### Summary
   
   i cant find any settings to change cosummer modelbroadcasting or clusting
   
   ### Motivation
   
   i cant find any settings to change cosummer modelbroadcasting or clusting
   
   ### Describe the Solution You'd Like
   
   i cant find any settings to change cosummer modelbroadcasting or clusting
   
   ### Describe Alternatives You've Considered
   
   i cant find any settings to change cosummer modelbroadcasting or clusting
   
   ### Additional Context
   
   i cant find any settings to change cosummer modelbroadcasting or clusting


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: commits-unsubscr...@rocketmq.apache.org.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



[PR] [ISSUE #889] Python Example: start a simple consumer in background th… [rocketmq-clients]

2024-12-13 Thread via GitHub


herywang opened a new pull request, #890:
URL: https://github.com/apache/rocketmq-clients/pull/890

   …read (#889)
   
   
   
   ### Which Issue(s) This PR Fixes
   
   
   
   Fixes #889
   
   ### Brief Description
   
   
   
   ### How Did You Test This Change?
   
   
   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: commits-unsubscr...@rocketmq.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



[I] [Feature] Python - There are some error to start a consumer in background thread [rocketmq-clients]

2024-12-13 Thread via GitHub


herywang opened a new issue, #889:
URL: https://github.com/apache/rocketmq-clients/issues/889

   ### Programming Language of the Client
   
   Python
   
   ### Is Your Feature Request Related to a Problem?
   
   There are some problems with using a traditional method to start a 
background thread consumer in our program, such as this code snippet:
   ```python
   import threading
   def start_consumer():
   # Refer to simple_consumer_example.py to create a simple consumer
   
   # Starting a background consumer:
   t = threading.Thread(target=start_consumer)
   t.start()
   ```
   
   Using the above writing method, you will get the following error message in 
your `~/logs/rocketmq_python/rocketmq_client.log`
   
   such as:  `update topic route error, topic: xx, 'NoneType' object has no 
attribute 'encode'`
   such as:  `subscribe exception: 'NoneType' object has no attribute 'encode'`
   such as:  `There is no topic to receive the message`
   
   
   ### Describe the Solution You'd Like
   
   I will submit an example to start a simple rocketmq consumer in a background 
thread.
   
   ### Describe Alternatives You've Considered
   
   Using `asyncio` to start a backgroun consumer to resolve above error.
   
   ### Additional Context
   
   _No response_


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: commits-unsubscr...@rocketmq.apache.org.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [PR] [ISSUE #9025] [RIP-73] Pop Consumption Improvement Based on RocksDB [rocketmq]

2024-12-13 Thread via GitHub


lizhimins commented on code in PR #9048:
URL: https://github.com/apache/rocketmq/pull/9048#discussion_r1884965674


##
broker/src/main/java/org/apache/rocketmq/broker/pop/PopConsumerService.java:
##
@@ -0,0 +1,699 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package org.apache.rocketmq.broker.pop;
+
+import com.alibaba.fastjson.JSON;
+import com.google.common.annotations.VisibleForTesting;
+import com.google.common.base.Stopwatch;
+import java.nio.ByteBuffer;
+import java.nio.file.Paths;
+import java.util.ArrayList;
+import java.util.Collections;
+import java.util.HashMap;
+import java.util.List;
+import java.util.Objects;
+import java.util.Queue;
+import java.util.concurrent.CompletableFuture;
+import java.util.concurrent.CompletionException;
+import java.util.concurrent.ConcurrentHashMap;
+import java.util.concurrent.ConcurrentMap;
+import java.util.concurrent.LinkedBlockingQueue;
+import java.util.concurrent.TimeUnit;
+import java.util.concurrent.atomic.AtomicBoolean;
+import java.util.concurrent.atomic.AtomicLong;
+import org.apache.commons.lang3.StringUtils;
+import org.apache.commons.lang3.tuple.Triple;
+import org.apache.rocketmq.broker.BrokerController;
+import org.apache.rocketmq.common.BrokerConfig;
+import org.apache.rocketmq.common.KeyBuilder;
+import org.apache.rocketmq.common.MixAll;
+import org.apache.rocketmq.common.ServiceThread;
+import org.apache.rocketmq.common.TopicConfig;
+import org.apache.rocketmq.common.TopicFilterType;
+import org.apache.rocketmq.common.constant.LoggerName;
+import org.apache.rocketmq.common.constant.PermName;
+import org.apache.rocketmq.common.message.MessageAccessor;
+import org.apache.rocketmq.common.message.MessageConst;
+import org.apache.rocketmq.common.message.MessageDecoder;
+import org.apache.rocketmq.common.message.MessageExt;
+import org.apache.rocketmq.common.message.MessageExtBrokerInner;
+import org.apache.rocketmq.common.utils.ConcurrentHashMapUtils;
+import org.apache.rocketmq.remoting.protocol.header.ExtraInfoUtil;
+import org.apache.rocketmq.store.AppendMessageStatus;
+import org.apache.rocketmq.store.GetMessageResult;
+import org.apache.rocketmq.store.GetMessageStatus;
+import org.apache.rocketmq.store.MessageFilter;
+import org.apache.rocketmq.store.PutMessageResult;
+import org.apache.rocketmq.store.SelectMappedBufferResult;
+import org.apache.rocketmq.store.exception.ConsumeQueueException;
+import org.apache.rocketmq.store.pop.PopCheckPoint;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
+
+public class PopConsumerService extends ServiceThread {
+
+private static final Logger log = 
LoggerFactory.getLogger(LoggerName.ROCKETMQ_POP_LOGGER_NAME);
+private static final long OFFSET_NOT_EXIST = -1L;
+private static final String ROCKSDB_DIRECTORY = "kvStore";
+private static final int[] REWRITE_INTERVALS_IN_SECONDS =
+new int[] {10, 30, 60, 120, 180, 240, 300, 360, 420, 480, 540, 600, 
1200, 1800, 3600, 7200};
+
+private final AtomicBoolean consumerRunning;
+private final BrokerConfig brokerConfig;
+private final BrokerController brokerController;
+private final AtomicLong lastCleanupLockTime;
+private final PopConsumerCache popConsumerCache;
+private final PopConsumerKVStore popConsumerStore;
+private final PopConsumerLockService consumerLockService;
+private final ConcurrentMap 
requestCountTable;
+
+public PopConsumerService(BrokerController brokerController) {
+
+this.brokerController = brokerController;
+this.brokerConfig = brokerController.getBrokerConfig();
+
+this.consumerRunning = new AtomicBoolean(false);
+this.requestCountTable = new ConcurrentHashMap<>();
+this.lastCleanupLockTime = new AtomicLong(System.currentTimeMillis());
+this.consumerLockService = new 
PopConsumerLockService(TimeUnit.MINUTES.toMillis(2));
+this.popConsumerStore = new PopConsumerRocksdbStore(Paths.get(
+brokerController.getMessageStoreConfig().getStorePathRootDir(), 
ROCKSDB_DIRECTORY).toString());
+this.popConsumerCache = brokerConfig.isEnablePopBufferMerge() ? new 
PopConsumerCache(
+brokerController, this.popConsumerStore, thi

Re: [PR] [ISSUE #9025] [RIP-73] Pop Consumption Improvement Based on RocksDB [rocketmq]

2024-12-13 Thread via GitHub


lizhimins commented on code in PR #9048:
URL: https://github.com/apache/rocketmq/pull/9048#discussion_r1884964893


##
broker/src/main/java/org/apache/rocketmq/broker/processor/PopMessageProcessor.java:
##
@@ -213,27 +218,26 @@ public void notifyMessageArriving(final String topic, 
final int queueId, final S
 @Override
 public RemotingCommand processRequest(final ChannelHandlerContext ctx, 
RemotingCommand request)
 throws RemotingCommandException {
+
 final long beginTimeMills = 
this.brokerController.getMessageStore().now();
+
+// fill bron time to properties if not exist, why we need this?
 request.addExtFieldIfNotExist(BORN_TIME, 
String.valueOf(System.currentTimeMillis()));
 if (Objects.equals(request.getExtFields().get(BORN_TIME), "0")) {

Review Comment:
   I use put if not exist method here. This code is equivalent to the original. 
Maybe there was originally a value of 0? 



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: commits-unsubscr...@rocketmq.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [I] [Bug] when i updateAccessConfig with empty groupPerms, report error (org.apache.rocketmq.acl.common.AclException: Parse Resource format error for .) [rocketmq]

2024-12-13 Thread via GitHub


github-actions[bot] commented on issue #7662:
URL: https://github.com/apache/rocketmq/issues/7662#issuecomment-2542574389

   This issue is stale because it has been open for 365 days with no activity. 
It will be closed in 3 days if no further activity occurs.


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: commits-unsubscr...@rocketmq.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [I] [Enhancement] typo about mQ -> mq and getmQ -> getmq [rocketmq]

2024-12-13 Thread via GitHub


github-actions[bot] closed issue #7629: [Enhancement] typo about mQ -> mq and 
getmQ -> getmq
URL: https://github.com/apache/rocketmq/issues/7629


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: commits-unsubscr...@rocketmq.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [I] [Bug] Timed messages cannot be consumed [rocketmq]

2024-12-13 Thread via GitHub


github-actions[bot] commented on issue #7641:
URL: https://github.com/apache/rocketmq/issues/7641#issuecomment-2542574410

   This issue is stale because it has been open for 365 days with no activity. 
It will be closed in 3 days if no further activity occurs.


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: commits-unsubscr...@rocketmq.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



Re: [I] [Enhancement] typo about mQ -> mq and getmQ -> getmq [rocketmq]

2024-12-13 Thread via GitHub


github-actions[bot] commented on issue #7629:
URL: https://github.com/apache/rocketmq/issues/7629#issuecomment-2542574423

   This issue was closed because it has been inactive for 3 days since being 
marked as stale.


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: commits-unsubscr...@rocketmq.apache.org

For queries about this service, please contact Infrastructure at:
us...@infra.apache.org



[GH] (rocketmq): Workflow run "PUSH-CI" failed!

2024-12-13 Thread GitBox


The GitHub Actions job "PUSH-CI" on rocketmq.git has failed.
Run started by GitHub user RongtongJin (triggered by RongtongJin).

Head commit for run:
b5cf3ca90aba1765519ccd3244dc31e3852051ea / Vincent Lee 
[ISSUE #9028] Adjust some error code for SYSTEM_ERROR (#9027)

* feat: change some SYSTEM_ERROR to more meaningful error code

Change-Id: I4b6ffa5aa18325eeadc29941c5788244c2770423

* feat: change some SYSTEM_ERROR to more meaningful error code

Change-Id: I0c6ff75c5a2f7adde73261da93608781260e09da

* test: adjust test case for error code

Change-Id: I302ff5ad204280b55c8427ba4e8563b042263aeb

* test: adjust test case for error code

Change-Id: I7fc958c865c53b2a66b7bd77b6fb69f1546d2826

Report URL: https://github.com/apache/rocketmq/actions/runs/12325927895

With regards,
GitHub Actions via GitBox



[GH] (rocketmq): Workflow run "Coverage" is working again!

2024-12-13 Thread GitBox


The GitHub Actions job "Coverage" on rocketmq.git has succeeded.
Run started by GitHub user RongtongJin (triggered by RongtongJin).

Head commit for run:
b5cf3ca90aba1765519ccd3244dc31e3852051ea / Vincent Lee 
[ISSUE #9028] Adjust some error code for SYSTEM_ERROR (#9027)

* feat: change some SYSTEM_ERROR to more meaningful error code

Change-Id: I4b6ffa5aa18325eeadc29941c5788244c2770423

* feat: change some SYSTEM_ERROR to more meaningful error code

Change-Id: I0c6ff75c5a2f7adde73261da93608781260e09da

* test: adjust test case for error code

Change-Id: I302ff5ad204280b55c8427ba4e8563b042263aeb

* test: adjust test case for error code

Change-Id: I7fc958c865c53b2a66b7bd77b6fb69f1546d2826

Report URL: https://github.com/apache/rocketmq/actions/runs/12325927897

With regards,
GitHub Actions via GitBox



[GH] (rocketmq): Workflow run "Build and Run Tests by Maven" is working again!

2024-12-13 Thread GitBox


The GitHub Actions job "Build and Run Tests by Maven" on rocketmq.git has 
succeeded.
Run started by GitHub user RongtongJin (triggered by RongtongJin).

Head commit for run:
b5cf3ca90aba1765519ccd3244dc31e3852051ea / Vincent Lee 
[ISSUE #9028] Adjust some error code for SYSTEM_ERROR (#9027)

* feat: change some SYSTEM_ERROR to more meaningful error code

Change-Id: I4b6ffa5aa18325eeadc29941c5788244c2770423

* feat: change some SYSTEM_ERROR to more meaningful error code

Change-Id: I0c6ff75c5a2f7adde73261da93608781260e09da

* test: adjust test case for error code

Change-Id: I302ff5ad204280b55c8427ba4e8563b042263aeb

* test: adjust test case for error code

Change-Id: I7fc958c865c53b2a66b7bd77b6fb69f1546d2826

Report URL: https://github.com/apache/rocketmq/actions/runs/12325927888

With regards,
GitHub Actions via GitBox