You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@pulsar.apache.org by GitBox <gi...@apache.org> on 2021/09/22 04:34:50 UTC

[GitHub] [pulsar] liangjiangliang opened a new issue #12125: Repeated consumption

liangjiangliang opened a new issue #12125:
URL: https://github.com/apache/pulsar/issues/12125


    In the case of normal consumption, consumption to individual historical records 
   


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

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



[GitHub] [pulsar] github-actions[bot] commented on issue #12125: Repeated consumption

Posted by GitBox <gi...@apache.org>.
github-actions[bot] commented on issue #12125:
URL: https://github.com/apache/pulsar/issues/12125#issuecomment-1054903005


   The issue had no activity for 30 days, mark with Stale label.


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

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



[GitHub] [pulsar] liangjiangliang edited a comment on issue #12125: Repeated consumption

Posted by GitBox <gi...@apache.org>.
liangjiangliang edited a comment on issue #12125:
URL: https://github.com/apache/pulsar/issues/12125#issuecomment-924722964


   how to find out the problem ,when we get  Messages<String> msgs
   Iterator it=msgs.iterator();
    while(it.hasNext()){Message<String> msg= (Message<String>) it.next();
   String by = msg.getValue();
    LOG.info("—————表:"+topic+"获取数据_________"+by);
   }
   we find very less record(about 1/1000000) print twice.


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

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



[GitHub] [pulsar] liangjiangliang edited a comment on issue #12125: Repeated consumption

Posted by GitBox <gi...@apache.org>.
liangjiangliang edited a comment on issue #12125:
URL: https://github.com/apache/pulsar/issues/12125#issuecomment-924722964


   how to find out the problem ,when we get  Messages<String> msgs
   Iterator it=msgs.iterator();
    while(it.hasNext()){Message<String> msg= (Message<String>) it.next();
   String by = msg.getValue();
    LOG.info("—————表:"+topic+"获取数据_________"+by);
   }
   we find some record print twice.


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

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



[GitHub] [pulsar] Shoothzj commented on issue #12125: Repeated consumption

Posted by GitBox <gi...@apache.org>.
Shoothzj commented on issue #12125:
URL: https://github.com/apache/pulsar/issues/12125#issuecomment-924652168


   could you please give more specific description and how to reproduce


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

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



[GitHub] [pulsar] liangjiangliang commented on issue #12125: Repeated consumption

Posted by GitBox <gi...@apache.org>.
liangjiangliang commented on issue #12125:
URL: https://github.com/apache/pulsar/issues/12125#issuecomment-924720552


   we use the consumer of Java pulsarClient :
   `Messages<String> msgs=someTopicsConsumer.batchReceive();` 
   `SubscriptionType subscriptionType = SubscriptionType.Shared;
               someTopicsConsumer = client.newConsumer(Schema.STRING)
                      .topic(topic)
                      .subscriptionType(subscriptionType)
                      .subscriptionName("sink_"+SinkConstants.getINSTNAME())
                      .batchReceivePolicy(BatchReceivePolicy.builder()
                               .maxNumMessages(0)
                               .maxNumBytes(1024*1024*1700)
                               .timeout(600, TimeUnit.MILLISECONDS)
                               .build())
                       .receiverQueueSize(28000)
                       .subscribe();`


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

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



[GitHub] [pulsar] Shoothzj commented on issue #12125: Repeated consumption

Posted by GitBox <gi...@apache.org>.
Shoothzj commented on issue #12125:
URL: https://github.com/apache/pulsar/issues/12125#issuecomment-926285681


   > could this due to the ack was lost?
   
   He does not config ackTimeout, the unack message would not resend unless restart the consumer.
   @liangjiangliang If you doesn't restart the consumer or broker in your test.
   Can you check if the topic are unload, you can search 
   ```java
   // org.apache.pulsar.broker.namespace.OwnedBundle.handleUnloadRequest
   LOG.info("Unloading {} namespace-bundle with {} topics completed in {} ms", this.bundle,
                               unloadedTopics, unloadBundleTime, ex);
   ```


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

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



[GitHub] [pulsar] Shoothzj edited a comment on issue #12125: Repeated consumption

Posted by GitBox <gi...@apache.org>.
Shoothzj edited a comment on issue #12125:
URL: https://github.com/apache/pulsar/issues/12125#issuecomment-926285681


   > could this due to the ack was lost?
   
   He does not config ackTimeout, the unack message would not resend unless restart the consumer.
   @liangjiangliang If you doesn't restart the consumer or broker in your test.
   Can you check if the topic are unloaded, you can search 
   ```java
   // org.apache.pulsar.broker.namespace.OwnedBundle.handleUnloadRequest
   LOG.info("Unloading {} namespace-bundle with {} topics completed in {} ms", this.bundle,
                               unloadedTopics, unloadBundleTime, ex);
   ```


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

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



[GitHub] [pulsar] MarvinCai commented on issue #12125: Repeated consumption

Posted by GitBox <gi...@apache.org>.
MarvinCai commented on issue #12125:
URL: https://github.com/apache/pulsar/issues/12125#issuecomment-925058378


   could this due to the ack was lost? 


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

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



[GitHub] [pulsar] liangjiangliang commented on issue #12125: Repeated consumption

Posted by GitBox <gi...@apache.org>.
liangjiangliang commented on issue #12125:
URL: https://github.com/apache/pulsar/issues/12125#issuecomment-924722964


   how to find out the problem ,when we get  Iterator it=msgs.iterator();
    while(it.hasNext()){Message<String> msg= (Message<String>) it.next();
   String by = msg.getValue();
    LOG.info("—————表:"+topic+"获取数据_________"+by);


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

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