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 2019/12/23 16:04:07 UTC

[GitHub] [pulsar] jiazhai opened a new pull request #5923: Fix reader builder clone error

jiazhai opened a new pull request #5923: Fix reader builder clone error
URL: https://github.com/apache/pulsar/pull/5923
 
 
   
   ### Motivation
   In reader builder, clone() method does not clone the config, and will cause error once we call a builder.clone() concurrently to create readers. This PR mainly try to fix this issue.
   
   ### Modifications
   
   - use conf.clone(), to make sure conf is cloned.
   - add test to verify it.
   - fix other small issues, like get() methods, and access level, make it align with consumer/producer builder. 
   
   ### Verifying this change
   ut passed.

----------------------------------------------------------------
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.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

[GitHub] [pulsar] jiazhai commented on issue #5923: Fix reader builder clone error

Posted by GitBox <gi...@apache.org>.
jiazhai commented on issue #5923: Fix reader builder clone error
URL: https://github.com/apache/pulsar/pull/5923#issuecomment-569563219
 
 
   run java8 tests

----------------------------------------------------------------
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.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

[GitHub] [pulsar] jiazhai edited a comment on issue #5923: Fix reader builder clone error

Posted by GitBox <gi...@apache.org>.
jiazhai edited a comment on issue #5923: Fix reader builder clone error
URL: https://github.com/apache/pulsar/pull/5923#issuecomment-568863753
 
 
   run java8 tests
   
   ```
   org.apache.pulsar.broker.service.PersistentFailoverE2ETest.testSimpleConsumerEventsWithoutPartition
   org.apache.pulsar.client.api.BrokerServiceLookupTest.testModularLoadManagerSplitBundle
   ```

----------------------------------------------------------------
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.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

[GitHub] [pulsar] jiazhai edited a comment on issue #5923: Fix reader builder clone error

Posted by GitBox <gi...@apache.org>.
jiazhai edited a comment on issue #5923: Fix reader builder clone error
URL: https://github.com/apache/pulsar/pull/5923#issuecomment-568638512
 
 
   run java8 tests
   
   unrelated tests:
   ```
   org.apache.pulsar.client.api.BrokerServiceLookupTest.testSplitUnloadLookupTest
   org.apache.pulsar.client.api.v1.V1_ProducerConsumerTest.testConcurrentConsumerReceiveWhileReconnect
   org.apache.pulsar.io.PulsarFunctionE2ETest.testPulsarFunctionStats
   ```

----------------------------------------------------------------
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.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

[GitHub] [pulsar] jiazhai commented on issue #5923: Fix reader builder clone error

Posted by GitBox <gi...@apache.org>.
jiazhai commented on issue #5923: Fix reader builder clone error
URL: https://github.com/apache/pulsar/pull/5923#issuecomment-568638512
 
 
   run java8 tests

----------------------------------------------------------------
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.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

[GitHub] [pulsar] jiazhai edited a comment on issue #5923: Fix reader builder clone error

Posted by GitBox <gi...@apache.org>.
jiazhai edited a comment on issue #5923: Fix reader builder clone error
URL: https://github.com/apache/pulsar/pull/5923#issuecomment-570165631
 
 
   run java8 tests
   run integration tests
   
   Test Result (1 failure / +1)
   org.apache.pulsar.broker.loadbalance.SimpleLoadManagerImplTest.setup

----------------------------------------------------------------
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.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

[GitHub] [pulsar] jiazhai edited a comment on issue #5923: Fix reader builder clone error

Posted by GitBox <gi...@apache.org>.
jiazhai edited a comment on issue #5923: Fix reader builder clone error
URL: https://github.com/apache/pulsar/pull/5923#issuecomment-569510134
 
 
   run java8 tests
   
   for error
   org.apache.pulsar.broker.admin.v1.V1_AdminApiTest.setup

----------------------------------------------------------------
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.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

[GitHub] [pulsar] jiazhai commented on issue #5923: Fix reader builder clone error

Posted by GitBox <gi...@apache.org>.
jiazhai commented on issue #5923: Fix reader builder clone error
URL: https://github.com/apache/pulsar/pull/5923#issuecomment-569510134
 
 
   run java8 tests

----------------------------------------------------------------
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.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

[GitHub] [pulsar] jiazhai commented on issue #5923: Fix reader builder clone error

Posted by GitBox <gi...@apache.org>.
jiazhai commented on issue #5923: Fix reader builder clone error
URL: https://github.com/apache/pulsar/pull/5923#issuecomment-570111311
 
 
   run java8 tests
   run integration tests

----------------------------------------------------------------
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.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

[GitHub] [pulsar] jiazhai edited a comment on issue #5923: Fix reader builder clone error

Posted by GitBox <gi...@apache.org>.
jiazhai edited a comment on issue #5923: Fix reader builder clone error
URL: https://github.com/apache/pulsar/pull/5923#issuecomment-568906072
 
 
   run java8 tests
   
   org.apache.pulsar.broker.service.BacklogQuotaManagerTest.setup
   org.apache.pulsar.client.api.MessageDispatchThrottlingTest.setup
   org.apache.pulsar.client.api.SimpleProducerConsumerTest.setup
   org.apache.pulsar.websocket.proxy.ProxyConfigurationTest.setup

----------------------------------------------------------------
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.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

[GitHub] [pulsar] jiazhai commented on issue #5923: Fix reader builder clone error

Posted by GitBox <gi...@apache.org>.
jiazhai commented on issue #5923: Fix reader builder clone error
URL: https://github.com/apache/pulsar/pull/5923#issuecomment-568628520
 
 
   run java8 tests
   run integration tests

----------------------------------------------------------------
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.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

[GitHub] [pulsar] jiazhai commented on issue #5923: Fix reader builder clone error

Posted by GitBox <gi...@apache.org>.
jiazhai commented on issue #5923: Fix reader builder clone error
URL: https://github.com/apache/pulsar/pull/5923#issuecomment-570578083
 
 
   run java8 tests

----------------------------------------------------------------
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.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

[GitHub] [pulsar] jiazhai edited a comment on issue #5923: Fix reader builder clone error

Posted by GitBox <gi...@apache.org>.
jiazhai edited a comment on issue #5923: Fix reader builder clone error
URL: https://github.com/apache/pulsar/pull/5923#issuecomment-570578083
 
 
   run java8 tests
   
   
   org.apache.pulsar.broker.admin.AdminApiTlsAuthTest.setup
   org.apache.pulsar.client.api.DispatcherBlockConsumerTest.setup

----------------------------------------------------------------
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.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

[GitHub] [pulsar] jiazhai commented on issue #5923: Fix reader builder clone error

Posted by GitBox <gi...@apache.org>.
jiazhai commented on issue #5923: Fix reader builder clone error
URL: https://github.com/apache/pulsar/pull/5923#issuecomment-568863753
 
 
   run java8 tests

----------------------------------------------------------------
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.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

[GitHub] [pulsar] jiazhai edited a comment on issue #5923: Fix reader builder clone error

Posted by GitBox <gi...@apache.org>.
jiazhai edited a comment on issue #5923: Fix reader builder clone error
URL: https://github.com/apache/pulsar/pull/5923#issuecomment-568942279
 
 
   run java8 tests
   ```
   org.apache.pulsar.client.impl.schema.KeyValueSchemaInfoTest.encodeDecodeNestedKeyValueSchemaInfo
   org.apache.pulsar.client.impl.schema.KeyValueSchemaInfoTest.encodeDecodeNestedKeyValueSchemaInfo
   org.apache.pulsar.client.impl.schema.KeyValueSchemaInfoTest.encodeDecodeNestedKeyValueSchemaInfo
   org.apache.pulsar.client.impl.schema.KeyValueSchemaInfoTest.testKeyValueSchemaInfoToString
   ```

----------------------------------------------------------------
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.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

[GitHub] [pulsar] jiazhai edited a comment on issue #5923: Fix reader builder clone error

Posted by GitBox <gi...@apache.org>.
jiazhai edited a comment on issue #5923: Fix reader builder clone error
URL: https://github.com/apache/pulsar/pull/5923#issuecomment-570129329
 
 
   run java8 tests
   run integration tests
   
   Test Result (2 failures / -3)
   org.apache.pulsar.client.impl.schema.PrimitiveSchemaTest.allSchemasShouldRoundtripInput
   org.apache.pulsar.client.impl.schema.PrimitiveSchemaTest.allSchemasShouldSupportNull

----------------------------------------------------------------
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.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

[GitHub] [pulsar] jiazhai commented on issue #5923: Fix reader builder clone error

Posted by GitBox <gi...@apache.org>.
jiazhai commented on issue #5923: Fix reader builder clone error
URL: https://github.com/apache/pulsar/pull/5923#issuecomment-568900644
 
 
   run java8 tests

----------------------------------------------------------------
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.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

[GitHub] [pulsar] jiazhai commented on issue #5923: Fix reader builder clone error

Posted by GitBox <gi...@apache.org>.
jiazhai commented on issue #5923: Fix reader builder clone error
URL: https://github.com/apache/pulsar/pull/5923#issuecomment-568906072
 
 
   run java8 tests
   
   

----------------------------------------------------------------
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.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

[GitHub] [pulsar] jiazhai merged pull request #5923: Fix reader builder clone error

Posted by GitBox <gi...@apache.org>.
jiazhai merged pull request #5923: Fix reader builder clone error
URL: https://github.com/apache/pulsar/pull/5923
 
 
   

----------------------------------------------------------------
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.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

[GitHub] [pulsar] jiazhai edited a comment on issue #5923: Fix reader builder clone error

Posted by GitBox <gi...@apache.org>.
jiazhai edited a comment on issue #5923: Fix reader builder clone error
URL: https://github.com/apache/pulsar/pull/5923#issuecomment-568900644
 
 
   run java8 tests
   
   ```
   org.apache.pulsar.client.api.v1.V1_ProducerConsumerTest.testConcurrentConsumerReceiveWhileReconnect
   org.apache.pulsar.client.api.v1.V1_ProducerConsumerTest.testConcurrentConsumerReceiveWhileReconnect
   org.apache.pulsar.client.api.v1.V1_ProducerConsumerTest.testConcurrentConsumerReceiveWhileReconnect
   org.apache.pulsar.client.impl.BrokerClientIntegrationTest.testUnsupportedBatchMessageConsumer
   
   ```

----------------------------------------------------------------
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.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

[GitHub] [pulsar] jiazhai commented on issue #5923: Fix reader builder clone error

Posted by GitBox <gi...@apache.org>.
jiazhai commented on issue #5923: Fix reader builder clone error
URL: https://github.com/apache/pulsar/pull/5923#issuecomment-570440783
 
 
   run java8 tests
   
   

----------------------------------------------------------------
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.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

[GitHub] [pulsar] jiazhai commented on issue #5923: Fix reader builder clone error

Posted by GitBox <gi...@apache.org>.
jiazhai commented on issue #5923: Fix reader builder clone error
URL: https://github.com/apache/pulsar/pull/5923#issuecomment-570165631
 
 
   run java8 tests
   run integration tests
   

----------------------------------------------------------------
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.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

[GitHub] [pulsar] jiazhai commented on issue #5923: Fix reader builder clone error

Posted by GitBox <gi...@apache.org>.
jiazhai commented on issue #5923: Fix reader builder clone error
URL: https://github.com/apache/pulsar/pull/5923#issuecomment-570129329
 
 
   run java8 tests
   run integration tests

----------------------------------------------------------------
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.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

[GitHub] [pulsar] jiazhai commented on issue #5923: Fix reader builder clone error

Posted by GitBox <gi...@apache.org>.
jiazhai commented on issue #5923: Fix reader builder clone error
URL: https://github.com/apache/pulsar/pull/5923#issuecomment-570439694
 
 
   run java8 tests
   

----------------------------------------------------------------
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.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

[GitHub] [pulsar] jiazhai commented on issue #5923: Fix reader builder clone error

Posted by GitBox <gi...@apache.org>.
jiazhai commented on issue #5923: Fix reader builder clone error
URL: https://github.com/apache/pulsar/pull/5923#issuecomment-570565589
 
 
   run java8 tests
   
   

----------------------------------------------------------------
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.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

[GitHub] [pulsar] jiazhai commented on issue #5923: Fix reader builder clone error

Posted by GitBox <gi...@apache.org>.
jiazhai commented on issue #5923: Fix reader builder clone error
URL: https://github.com/apache/pulsar/pull/5923#issuecomment-568942279
 
 
   run java8 tests

----------------------------------------------------------------
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.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services

[GitHub] [pulsar] jiazhai commented on issue #5923: Fix reader builder clone error

Posted by GitBox <gi...@apache.org>.
jiazhai commented on issue #5923: Fix reader builder clone error
URL: https://github.com/apache/pulsar/pull/5923#issuecomment-569419070
 
 
   run java8 tests

----------------------------------------------------------------
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.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services