You are viewing a plain text version of this content. The canonical link for it is here.
Posted to dev@rocketmq.apache.org by GitBox <gi...@apache.org> on 2022/10/14 08:46:58 UTC

[GitHub] [rocketmq] lizhiboo opened a new issue, #5315: DefaultLitePullConsumerImpl's persistConsumeOffset method should not be called by MQClientInstance if DefaultLitePullConsumerImpl disable autoCommit

lizhiboo opened a new issue, #5315:
URL: https://github.com/apache/rocketmq/issues/5315

   ```java
   @Override
       public void persistConsumerOffset() {
           try {
               checkServiceState();
               Set<MessageQueue> mqs = new HashSet<MessageQueue>();
               if (this.subscriptionType == SubscriptionType.SUBSCRIBE) {
                   Set<MessageQueue> allocateMq = this.rebalanceImpl.getProcessQueueTable().keySet();
                   mqs.addAll(allocateMq);
               } else if (this.subscriptionType == SubscriptionType.ASSIGN) {
                   Set<MessageQueue> assignedMessageQueue = this.assignedMessageQueue.getAssignedMessageQueues();
                   mqs.addAll(assignedMessageQueue);
               }
               this.offsetStore.persistAll(mqs);
           } catch (Exception e) {
               log.error("Persist consumer offset error for group: {} ", this.defaultLitePullConsumer.getConsumerGroup(), e);
           }
       }
   ```


-- 
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: dev-unsubscribe@rocketmq.apache.org.apache.org

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


[GitHub] [rocketmq] codersfarm commented on issue #5315: DefaultLitePullConsumerImpl's persistConsumeOffset method should not be called by MQClientInstance if DefaultLitePullConsumerImpl disable autoCommit

Posted by GitBox <gi...@apache.org>.
codersfarm commented on issue #5315:
URL: https://github.com/apache/rocketmq/issues/5315#issuecomment-1285057220

   if disable autoCommit,the bleow code in MQClientInstance should be disable?
   ```
   this.scheduledExecutorService.scheduleAtFixedRate(new Runnable() {
   
               @Override
               public void run() {
                   try {
                       MQClientInstance.this.persistAllConsumerOffset();
                   } catch (Exception e) {
                       log.error("ScheduledTask persistAllConsumerOffset exception", e);
                   }
               }
           }, 1000 * 10, this.clientConfig.getPersistConsumerOffsetInterval(), TimeUnit.MILLISECONDS);
   ```


-- 
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-unsubscribe@rocketmq.apache.org

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


Re: [I] DefaultLitePullConsumerImpl's persistConsumeOffset method should not be called by MQClientInstance if DefaultLitePullConsumerImpl disable autoCommit [rocketmq]

Posted by "github-actions[bot] (via GitHub)" <gi...@apache.org>.
github-actions[bot] commented on issue #5315:
URL: https://github.com/apache/rocketmq/issues/5315#issuecomment-1773541597

   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-unsubscribe@rocketmq.apache.org

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


Re: [I] DefaultLitePullConsumerImpl's persistConsumeOffset method should not be called by MQClientInstance if DefaultLitePullConsumerImpl disable autoCommit [rocketmq]

Posted by "github-actions[bot] (via GitHub)" <gi...@apache.org>.
github-actions[bot] commented on issue #5315:
URL: https://github.com/apache/rocketmq/issues/5315#issuecomment-1778256810

   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-unsubscribe@rocketmq.apache.org

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


[GitHub] [rocketmq] ni-ze commented on issue #5315: DefaultLitePullConsumerImpl's persistConsumeOffset method should not be called by MQClientInstance if DefaultLitePullConsumerImpl disable autoCommit

Posted by GitBox <gi...@apache.org>.
ni-ze commented on issue #5315:
URL: https://github.com/apache/rocketmq/issues/5315#issuecomment-1280759160

   Agree, If autoCommit is false, means that user will not commit offset to broker until do it by themselves.


-- 
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: dev-unsubscribe@rocketmq.apache.org

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


Re: [I] DefaultLitePullConsumerImpl's persistConsumeOffset method should not be called by MQClientInstance if DefaultLitePullConsumerImpl disable autoCommit [rocketmq]

Posted by "github-actions[bot] (via GitHub)" <gi...@apache.org>.
github-actions[bot] closed issue #5315: DefaultLitePullConsumerImpl's persistConsumeOffset method should not be called by MQClientInstance if DefaultLitePullConsumerImpl disable autoCommit
URL: https://github.com/apache/rocketmq/issues/5315


-- 
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-unsubscribe@rocketmq.apache.org

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