1. 06 1月, 2020 2 次提交
    • S
      Release 2.5.0 · f2afad35
      Sijie Guo 提交于
      f2afad35
    • M
      Make unit tests to only use dynamically allocated ports (#5486) · f141efa6
      Matteo Merli 提交于
      * Make unit tests to only use dynamically allocated ports
      
      * Fixed proxy tests
      
      * Fixed zk test utils after merge
      
      * Fixed multi host client test
      
      * Fix for testConcurrentConsumerReceiveWhileReconnect
      
      * Increased timeout on testPulsarSourceLocalRunWithFile
      
      * Fixed newer test to also avoid port manager
      
      * Fixed test race condition with thread starting in PulsarFunctionLocalRunTest
      
      * Fixed ProxyWithAuthorizationNegTest
      
      * Fixed ProxySaslAuthenticationTest
      f141efa6
  2. 05 1月, 2020 1 次提交
  3. 04 1月, 2020 1 次提交
    • M
      Make standalone to advertise "localhost" to avoid failure when hostname is not resolvable (#5856) · f95c71f2
      Matteo Merli 提交于
      ### Motivation
      
      The standalone service is failing to startup when the hostname is not resolvable to an IP. This is common in laptops. 
      
      The reason is that the function worker in standalone is trying to connect to the advertised address rather than "localhost". 
      
      To fix this, we should make the standalone to always advertise "localhost" as the the broker address. This is ok because in any case the standalone treats the advertisement as the pulsar proxy, in that it forces the clients to always go through the same service url, so a client connecting from a different host won't have problems.
      f95c71f2
  4. 03 1月, 2020 6 次提交
    • J
      fix reader builder clone error (#5923) · 88fc4541
      Jia Zhai 提交于
      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.
      88fc4541
    • F
      [Reopen][Issue 5597] Retry when getPartitionedTopicMetadata failed (#5844) · c7094c9e
      Fangbin Sun 提交于
      Motivation
      Fixes #5597
      
      Add backoff retries when getting partitioned metadata from brokers.
      
      The change in #5734 (copy from #5603) used the wrong time unit when inited Backoff which failed to trigger the retry logic as expected.
      
      Modifications
      Correct the time unit and add some useful log.
      c7094c9e
    • Y
      [pulsar-flink]Cache Pulsar client to make it shared among tasks in a process (#5900) · 5c58ff48
      Yijie Shen 提交于
      * Cache Pulsar client to make it shared among tasks in a process
      
      * code format & add tests
      
      * fix style
      Co-authored-by: NSijie Guo <guosijie@gmail.com>
      5c58ff48
    • L
      fix 2 copies of 3bookie and stop 2 booksie after production. After the entire... · dcaa1d35
      liudezhi 提交于
      fix  2 copies of 3bookie and stop 2 booksie after production. After the entire bookie is restored, it can be produced at this time, and the produced data cannot be consumed normally. Restarting the broker can resume normal (#5965)
      
      After stopping the bookie and recovering, it can be produced at this time, but cannot be consumed normally. Restarting the broker can resume normal
      
      Fixes #5962
      
      Motivation
      problem :
      Topic(E=3,W=3,A=2), stopped 2 bookie nodes, then recover the 2 bookie,
      The message can be produced normally, but the consumer cannot pull the message unless the broker is restarted.
      We hope that the bookie summary will resume normal consumption
      
      Modifications
      The main cause of this problem is that readHandle.readAsync does not catch the exception,
      causing some methods to not trigger.
      therefore, added the exception capture module , and the exceptions involved in the bookeeper project are also fixed.
      dcaa1d35
    • G
      Update document for debezium (#5973) · cff311c2
      Guangning 提交于
      Fixes #4075
      
      Motivation
      Debezium Postgres connector will first create a snap for the current table. And this step will hang if the table is too big.
      
      Modifications
      Add an introduction to parameter max.queue.size
      Verifying this change
      Integration tests
      yarn build
      cff311c2
    • S
      [proxy] Proxy doesn't use the right ca certicate to connect to brokers (#5971) · d98562db
      Sijie Guo 提交于
      *Motivation*
      
      Currently proxy uses the proxy ca certicate to connect to brokers.
      It is fine if proxy and broker are using th same CA. However if the broker
      is using a different CA than proxy, "HTTP 502 Bad Gateway" is returned from proxy
      when tlsEnabledWithBroker is set to true.
      
      *Modifications*
      
      Change to use the right CA
      
      *Verify this change*
      
      Verify it is working in a production environment.
      d98562db
  5. 02 1月, 2020 1 次提交
  6. 01 1月, 2020 6 次提交
    • S
      Remove duplicated lombok annotations in the pulsar-io modules (#5911) · c648981c
      Sergii Zhevzhyk 提交于
      ### Motivation
      
      Most of the configuration classes of the connectors had the following annotations:
      
      ```
      @data
      @Setter	
      @Getter	
      @EqualsAndHashCode	
      @ToString
      ```
      
      The [@data](https://projectlombok.org/features/Data) annotation includes all other annotations:
      
      > All together now: A shortcut for @ToString, @EqualsAndHashCode, @Getter on all fields, @Setter on all non-final fields, and @RequiredArgsConstructor!
      
      
      ### Modifications
      
      Removed `@Setter`, `@Getter`, `@EqualsAndHashCode`, and '@ToString' if the `@data` annotation was also present
      c648981c
    • A
      [broker] Allow for namespace default of offload threshold (#5872) · 1aa32994
      Addison Higham 提交于
      Most namespace level configurations have corresponding cluster
      configuration that set a namespace default.
      
      The offload threshold does not, which makes it more difficult to ensure
      that namespaces have the cluster wide namespace defaults.
      
      There is one small wrinkle with this commit in that `-1` is used as a
      sentinel value to indicate to use the cluster default, this means that
      if the cluster default is to have offloading on and it is desired to
        disable a specific namespace, the namespace needs to set this value to
        some negative number other than `-1`!
      1aa32994
    • G
      [Issue 5454][pulsar-client-cpp]Fix cpp client schema version (#5930) · a26f67a2
      Guangning 提交于
      Fixes #5454 
      
      
      ### Motivation
      
      The current CPP client cannot correctly obtain the schema version, resulting in an error in parsing with java client when sending data with schema using python client.
      
      Test code:
      
      ```
      import pulsar
      import json
      
      from pulsar.schema import *
      
      class Test(Record):
          name = String()
          id = Integer()
      
      client = pulsar.Client('pulsar://localhost:6650');
      producer = client.create_producer('test-producer-schema', schema=AvroSchema(Test))
      producer.send(Test(name='Hello', id=1))
      client.close()
      ```
      
      
      
      ### Modifications
      
      * Add set schema version in msgmetadata
      
      ### Verifying this change
      
      Add check schema version in unit test SchemaTest
      a26f67a2
    • Y
      Fixes #5814: add SentConnectFrame state check when running `handleError` (#5913) · d6f90ddc
      Yong Zhang 提交于
      
      
      Fixes #5841
      
      *Motivation*
      
      when enabling authentication and authorization, if a user using
      the wrong key to send to the server, the server will return an
      `Error` message. There is no `Connected` message return to the
      client so the client is staying in `SentConnectFrame` and it can
      receive the server `Error` message.
      We need to check the `SentConnectFrame` state when receiving `Error` message.
      
      The client will throw error:
      
      ```
      java.lang.IllegalArgumentException: null
      	at com.google.common.base.Preconditions.checkArgument(Preconditions.java:108) ~[guava-21.0.jar:?]
      	at org.apache.pulsar.client.impl.ClientCnx.handleError(ClientCnx.java:588) ~[pulsar-client-original-2.4.1.jar:2.4.1]
      	at org.apache.pulsar.common.protocol.PulsarDecoder.channelRead(PulsarDecoder.java:154) ~[pulsar-common-2.4.1.jar:2.4.1]
      	at io.netty.channel.AbstractChannelHandlerContext.invokeChannelRead(AbstractChannelHandlerContext.java:362) [netty-all-4.1.32.Final.jar:4.1.32.Final]
      	at io.netty.channel.AbstractChannelHandlerContext.invokeChannelRead(AbstractChannelHandlerContext.java:348) [netty-all-4.1.32.Final.jar:4.1.32.Final]
      	at io.netty.channel.AbstractChannelHandlerContext.fireChannelRead(AbstractChannelHandlerContext.java:340) [netty-all-4.1.32.Final.jar:4.1.32.Final]
      	at io.netty.handler.codec.ByteToMessageDecoder.fireChannelRead(ByteToMessageDecoder.java:323) [netty-all-4.1.32.Final.jar:4.1.32.Final]
      	at io.netty.handler.codec.ByteToMessageDecoder.channelRead(ByteToMessageDecoder.java:297) [netty-all-4.1.32.Final.jar:4.1.32.Final]
      	at io.netty.channel.AbstractChannelHandlerContext.invokeChannelRead(AbstractChannelHandlerContext.java:362) [netty-all-4.1.32.Final.jar:4.1.32.Final]
      	at io.netty.channel.AbstractChannelHandlerContext.invokeChannelRead(AbstractChannelHandlerContext.java:348) [netty-all-4.1.32.Final.jar:4.1.32.Final]
      	at io.netty.channel.AbstractChannelHandlerContext.fireChannelRead(AbstractChannelHandlerContext.java:340) [netty-all-4.1.32.Final.jar:4.1.32.Final]
      	at io.netty.channel.DefaultChannelPipeline$HeadContext.channelRead(DefaultChannelPipeline.java:1434) [netty-all-4.1.32.Final.jar:4.1.32.Final]
      	at io.netty.channel.AbstractChannelHandlerContext.invokeChannelRead(AbstractChannelHandlerContext.java:362) [netty-all-4.1.32.Final.jar:4.1.32.Final]
      	at io.netty.channel.AbstractChannelHandlerContext.invokeChannelRead(AbstractChannelHandlerContext.java:348) [netty-all-4.1.32.Final.jar:4.1.32.Final]
      	at io.netty.channel.DefaultChannelPipeline.fireChannelRead(DefaultChannelPipeline.java:965) [netty-all-4.1.32.Final.jar:4.1.32.Final]
      	at io.netty.channel.epoll.AbstractEpollStreamChannel$EpollStreamUnsafe.epollInReady(AbstractEpollStreamChannel.java:799) [netty-all-4.1.32.Final.jar:4.1.32.Final]
      	at io.netty.channel.epoll.EpollEventLoop.processReady(EpollEventLoop.java:433) [netty-all-4.1.32.Final.jar:4.1.32.Final]
      	at io.netty.channel.epoll.EpollEventLoop.run(EpollEventLoop.java:330) [netty-all-4.1.32.Final.jar:4.1.32.Final]
      	at io.netty.util.concurrent.SingleThreadEventExecutor$5.run(SingleThreadEventExecutor.java:909) [netty-all-4.1.32.Final.jar:4.1.32.Final]
      	at io.netty.util.concurrent.FastThreadLocalRunnable.run(FastThreadLocalRunnable.java:30) [netty-all-4.1.32.Final.jar:4.1.32.Final]
      	at java.lang.Thread.run(Thread.java:748) [?:1.8.0_201]
      ```
      
      *Modifications*
      
      - Add `SentConnectFrame` check
      d6f90ddc
    • Z
      Vagrantfile update for build dependency (#5968) · babce5e0
      zuquan song 提交于
      Fixes #5967
      
      ### Motivation
      Cannot build the project successfully.
      
      ### Modifications
      Add install commands to install the unzip zip tools when vm sets up
      babce5e0
    • G
      Add diskUsageThreshold to 0.99 (#5970) · 757d971b
      Guangning 提交于
      ### Motivation
      
      The current GitHub action test will show that the disk space exceeds 95%, and then the bookie will detect that bookie exits, so fix this problem.
      
      ![image](https://user-images.githubusercontent.com/1907867/71616693-8748da00-2bf2-11ea-82f2-e54eda012136.png)
      
      
      ### Modifications
      
      * Configuration parameter disUsageThreshold is 0.99 to prevent bookie exit.
      
      ### Verifying this change
      
      Integration test pass
      757d971b
  7. 30 12月, 2019 1 次提交
  8. 27 12月, 2019 3 次提交
  9. 24 12月, 2019 6 次提交
  10. 23 12月, 2019 1 次提交
  11. 20 12月, 2019 11 次提交
  12. 19 12月, 2019 1 次提交