You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@pulsar.apache.org by lh...@apache.org on 2021/12/22 15:59:51 UTC

[pulsar] branch branch-2.9 updated (519ff43 -> 107161f)

This is an automated email from the ASF dual-hosted git repository.

lhotari pushed a change to branch branch-2.9
in repository https://gitbox.apache.org/repos/asf/pulsar.git.


    from 519ff43  [owasp] suppress false positive netty-tc-native (#13364)
     new 8435cfe  Flaky tests: ElasticSearchClientTests tests time out (#12694)
     new ae1b29a  Fix ProxyServiceStarterTest flaky tests (#12344)
     new 107161f  Bump version to 2.9.2-SNAPSHOT

The 3 revisions listed above as "new" are entirely new to this
repository and will be described in separate emails.  The revisions
listed as "add" were already present in the repository and have only
been added to this reference.


Summary of changes:
 bouncy-castle/bc/pom.xml                           |  2 +-
 bouncy-castle/bcfips-include-test/pom.xml          |  2 +-
 bouncy-castle/bcfips/pom.xml                       |  2 +-
 bouncy-castle/pom.xml                              |  2 +-
 buildtools/pom.xml                                 |  2 +-
 distribution/io/pom.xml                            |  2 +-
 distribution/offloaders/pom.xml                    |  2 +-
 distribution/pom.xml                               |  2 +-
 distribution/server/pom.xml                        |  2 +-
 docker/grafana/pom.xml                             |  2 +-
 docker/pom.xml                                     |  2 +-
 docker/pulsar-all/pom.xml                          |  2 +-
 docker/pulsar/pom.xml                              |  2 +-
 jclouds-shaded/pom.xml                             |  2 +-
 kafka-connect-avro-converter-shaded/pom.xml        |  2 +-
 managed-ledger/pom.xml                             |  2 +-
 pom.xml                                            |  2 +-
 pulsar-broker-auth-athenz/pom.xml                  |  2 +-
 pulsar-broker-auth-sasl/pom.xml                    |  2 +-
 pulsar-broker-common/pom.xml                       |  2 +-
 pulsar-broker-shaded/pom.xml                       |  2 +-
 pulsar-broker/pom.xml                              |  2 +-
 pulsar-client-1x-base/pom.xml                      |  2 +-
 pulsar-client-1x-base/pulsar-client-1x/pom.xml     |  2 +-
 .../pulsar-client-2x-shaded/pom.xml                |  2 +-
 pulsar-client-admin-api/pom.xml                    |  2 +-
 pulsar-client-admin-shaded/pom.xml                 |  2 +-
 pulsar-client-admin/pom.xml                        |  2 +-
 pulsar-client-all/pom.xml                          |  2 +-
 pulsar-client-api/pom.xml                          |  2 +-
 pulsar-client-auth-athenz/pom.xml                  |  2 +-
 pulsar-client-auth-sasl/pom.xml                    |  2 +-
 pulsar-client-messagecrypto-bc/pom.xml             |  2 +-
 pulsar-client-shaded/pom.xml                       |  2 +-
 pulsar-client-tools-test/pom.xml                   |  2 +-
 pulsar-client-tools/pom.xml                        |  2 +-
 pulsar-client/pom.xml                              |  2 +-
 pulsar-common/pom.xml                              |  2 +-
 pulsar-config-validation/pom.xml                   |  2 +-
 pulsar-functions/api-java/pom.xml                  |  2 +-
 pulsar-functions/instance/pom.xml                  |  2 +-
 pulsar-functions/java-examples/pom.xml             |  2 +-
 pulsar-functions/localrun-shaded/pom.xml           |  2 +-
 pulsar-functions/localrun/pom.xml                  |  2 +-
 pulsar-functions/pom.xml                           |  2 +-
 pulsar-functions/proto/pom.xml                     |  2 +-
 pulsar-functions/runtime-all/pom.xml               |  2 +-
 pulsar-functions/runtime/pom.xml                   |  2 +-
 pulsar-functions/secrets/pom.xml                   |  2 +-
 pulsar-functions/utils/pom.xml                     |  2 +-
 pulsar-functions/worker/pom.xml                    |  2 +-
 pulsar-io/aerospike/pom.xml                        |  2 +-
 pulsar-io/aws/pom.xml                              |  2 +-
 pulsar-io/batch-data-generator/pom.xml             |  2 +-
 pulsar-io/batch-discovery-triggerers/pom.xml       |  2 +-
 pulsar-io/canal/pom.xml                            |  2 +-
 pulsar-io/cassandra/pom.xml                        |  2 +-
 pulsar-io/common/pom.xml                           |  2 +-
 pulsar-io/core/pom.xml                             |  2 +-
 pulsar-io/data-generator/pom.xml                   |  2 +-
 pulsar-io/debezium/core/pom.xml                    |  2 +-
 pulsar-io/debezium/mongodb/pom.xml                 |  2 +-
 pulsar-io/debezium/mssql/pom.xml                   |  2 +-
 pulsar-io/debezium/mysql/pom.xml                   |  2 +-
 pulsar-io/debezium/oracle/pom.xml                  |  2 +-
 pulsar-io/debezium/pom.xml                         |  2 +-
 pulsar-io/debezium/postgres/pom.xml                |  2 +-
 pulsar-io/docs/pom.xml                             |  2 +-
 pulsar-io/dynamodb/pom.xml                         |  2 +-
 pulsar-io/elastic-search/pom.xml                   |  2 +-
 .../io/elasticsearch/ElasticSearchClientTests.java |  6 +--
 .../testcontainers/ChaosContainer.java             | 61 +++++++++++++++++-----
 pulsar-io/file/pom.xml                             |  2 +-
 pulsar-io/flume/pom.xml                            |  2 +-
 pulsar-io/hbase/pom.xml                            |  2 +-
 pulsar-io/hdfs2/pom.xml                            |  2 +-
 pulsar-io/hdfs3/pom.xml                            |  2 +-
 pulsar-io/influxdb/pom.xml                         |  2 +-
 pulsar-io/jdbc/clickhouse/pom.xml                  |  2 +-
 pulsar-io/jdbc/core/pom.xml                        |  2 +-
 pulsar-io/jdbc/mariadb/pom.xml                     |  2 +-
 pulsar-io/jdbc/pom.xml                             |  2 +-
 pulsar-io/jdbc/postgres/pom.xml                    |  2 +-
 pulsar-io/jdbc/sqlite/pom.xml                      |  2 +-
 pulsar-io/kafka-connect-adaptor-nar/pom.xml        |  2 +-
 pulsar-io/kafka-connect-adaptor/pom.xml            |  2 +-
 pulsar-io/kafka/pom.xml                            |  2 +-
 pulsar-io/kinesis/pom.xml                          |  2 +-
 pulsar-io/mongo/pom.xml                            |  2 +-
 pulsar-io/netty/pom.xml                            |  2 +-
 pulsar-io/nsq/pom.xml                              |  2 +-
 pulsar-io/pom.xml                                  |  2 +-
 pulsar-io/rabbitmq/pom.xml                         |  2 +-
 pulsar-io/redis/pom.xml                            |  2 +-
 pulsar-io/solr/pom.xml                             |  2 +-
 pulsar-io/twitter/pom.xml                          |  2 +-
 pulsar-metadata/pom.xml                            |  2 +-
 .../bookkeeper-storage/pom.xml                     |  2 +-
 pulsar-package-management/core/pom.xml             |  2 +-
 pulsar-package-management/pom.xml                  |  2 +-
 pulsar-proxy/pom.xml                               |  2 +-
 .../pulsar/proxy/server/ProxyServiceStarter.java   |  5 ++
 .../proxy/server/ProxyServiceStarterTest.java      | 16 ++++--
 pulsar-sql/pom.xml                                 |  2 +-
 pulsar-sql/presto-distribution/pom.xml             |  2 +-
 pulsar-sql/presto-pulsar-plugin/pom.xml            |  2 +-
 pulsar-sql/presto-pulsar/pom.xml                   |  2 +-
 pulsar-testclient/pom.xml                          |  2 +-
 pulsar-transaction/common/pom.xml                  |  2 +-
 pulsar-transaction/coordinator/pom.xml             |  2 +-
 pulsar-transaction/pom.xml                         |  2 +-
 pulsar-websocket/pom.xml                           |  2 +-
 pulsar-zookeeper-utils/pom.xml                     |  2 +-
 structured-event-log/pom.xml                       |  2 +-
 testmocks/pom.xml                                  |  2 +-
 tests/bc_2_0_0/pom.xml                             |  2 +-
 tests/bc_2_0_1/pom.xml                             |  2 +-
 tests/bc_2_6_0/pom.xml                             |  2 +-
 tests/docker-images/java-test-functions/pom.xml    |  2 +-
 tests/docker-images/java-test-image/pom.xml        |  2 +-
 tests/docker-images/latest-version-image/pom.xml   |  2 +-
 tests/docker-images/pom.xml                        |  2 +-
 tests/integration/pom.xml                          |  2 +-
 tests/pom.xml                                      |  2 +-
 tests/pulsar-client-admin-shade-test/pom.xml       |  2 +-
 tests/pulsar-client-all-shade-test/pom.xml         |  2 +-
 tests/pulsar-client-shade-test/pom.xml             |  2 +-
 tiered-storage/file-system/pom.xml                 |  2 +-
 tiered-storage/jcloud/pom.xml                      |  2 +-
 tiered-storage/pom.xml                             |  2 +-
 130 files changed, 194 insertions(+), 146 deletions(-)

[pulsar] 01/03: Flaky tests: ElasticSearchClientTests tests time out (#12694)

Posted by lh...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

lhotari pushed a commit to branch branch-2.9
in repository https://gitbox.apache.org/repos/asf/pulsar.git

commit 8435cfe95ee03aa115b065d2b132e6d2a9a8f49d
Author: Nicolò Boschi <bo...@gmail.com>
AuthorDate: Fri Nov 19 17:13:10 2021 +0100

    Flaky tests: ElasticSearchClientTests tests time out (#12694)
    
    (cherry picked from commit dc48d29dc5d37793b0b2e6da28e7ba9b79bd4e49)
---
 .../io/elasticsearch/ElasticSearchClientTests.java |  6 +--
 .../testcontainers/ChaosContainer.java             | 61 +++++++++++++++++-----
 2 files changed, 52 insertions(+), 15 deletions(-)

diff --git a/pulsar-io/elastic-search/src/test/java/org/apache/pulsar/io/elasticsearch/ElasticSearchClientTests.java b/pulsar-io/elastic-search/src/test/java/org/apache/pulsar/io/elasticsearch/ElasticSearchClientTests.java
index aeacaf8..fb927c5 100644
--- a/pulsar-io/elastic-search/src/test/java/org/apache/pulsar/io/elasticsearch/ElasticSearchClientTests.java
+++ b/pulsar-io/elastic-search/src/test/java/org/apache/pulsar/io/elasticsearch/ElasticSearchClientTests.java
@@ -201,7 +201,7 @@ public class ElasticSearchClientTests {
                 assertEquals(mockRecord.failed, 0);
                 assertEquals(client.totalHits(index), 2);
 
-                ChaosContainer<?> chaosContainer = new ChaosContainer<>(container.getContainerName(), "15s");
+                ChaosContainer<?> chaosContainer = ChaosContainer.pauseContainerForSeconds(container.getContainerName(), 15);
                 chaosContainer.start();
 
                 client.bulkIndex(mockRecord, Pair.of("3", "{\"a\":3}"));
@@ -248,12 +248,12 @@ public class ElasticSearchClientTests {
                 });
                 client.flush();
                 Awaitility.await().untilAsserted(() -> {
-                    assertEquals(mockRecord.acked, 5);
                     assertEquals(mockRecord.failed, 0);
+                    assertEquals(mockRecord.acked, 5);
                     assertEquals(client.totalHits(index), 5);
                 });
 
-                ChaosContainer<?> chaosContainer = new ChaosContainer<>(container.getContainerName(), "30s");
+                ChaosContainer<?> chaosContainer = ChaosContainer.pauseContainerForSeconds(container.getContainerName(), 30);
                 chaosContainer.start();
                 Thread.sleep(1000L);
 
diff --git a/pulsar-io/elastic-search/src/test/java/org/apache/pulsar/io/elasticsearch/testcontainers/ChaosContainer.java b/pulsar-io/elastic-search/src/test/java/org/apache/pulsar/io/elasticsearch/testcontainers/ChaosContainer.java
index 7e7734f..4b296bb 100644
--- a/pulsar-io/elastic-search/src/test/java/org/apache/pulsar/io/elasticsearch/testcontainers/ChaosContainer.java
+++ b/pulsar-io/elastic-search/src/test/java/org/apache/pulsar/io/elasticsearch/testcontainers/ChaosContainer.java
@@ -19,26 +19,63 @@
 package org.apache.pulsar.io.elasticsearch.testcontainers;
 
 import lombok.extern.slf4j.Slf4j;
+import org.awaitility.Awaitility;
 import org.testcontainers.containers.BindMode;
 import org.testcontainers.containers.GenericContainer;
 import org.testcontainers.containers.wait.strategy.Wait;
+import org.testcontainers.containers.wait.strategy.WaitStrategy;
 
+import java.util.ArrayList;
+import java.util.List;
 import java.util.Optional;
+import java.util.concurrent.TimeUnit;
+import java.util.function.Consumer;
+import java.util.function.Predicate;
 
 // see https://github.com/alexei-led/pumba
 @Slf4j
 public class ChaosContainer<SELF extends ChaosContainer<SELF>> extends GenericContainer<SELF> {
 
-  public static final String PUMBA_IMAGE = Optional.ofNullable(System.getenv("PUMBA_IMAGE"))
-          .orElse("gaiaadm/pumba:latest");
-
-  public ChaosContainer(String targetContainer, String pause) {
-    super(PUMBA_IMAGE);
-    setCommand("--log-level info --interval 60s pause --duration " + pause + " " + targetContainer);
-    addFileSystemBind("/var/run/docker.sock", "/var/run/docker.sock", BindMode.READ_WRITE);
-    setWaitStrategy(Wait.forLogMessage(".*pausing container.*", 1));
-    withLogConsumer(o -> {
-      log.info("pumba> {}", o.getUtf8String());
-    });
-  }
+    public static final String PUMBA_IMAGE = Optional.ofNullable(System.getenv("PUMBA_IMAGE"))
+            .orElse("gaiaadm/pumba:0.8.0");
+
+    private final List<String> logs = new ArrayList<>();
+    private Consumer<ChaosContainer> beforeStop;
+
+    public static ChaosContainer pauseContainerForSeconds(String targetContainer, int seconds) {
+        return new ChaosContainer(targetContainer, "pause --duration " + seconds + "s", Wait.forLogMessage(".*pausing container.*", 1),
+                (Consumer<ChaosContainer>) chaosContainer -> Awaitility
+                        .await()
+                        .atMost(seconds + 5, TimeUnit.SECONDS)
+                        .until(() -> {
+                                    boolean found = chaosContainer.logs.stream().anyMatch((Predicate<String>) line -> line.contains("stop pausing container"));
+                                    if (!found) {
+                                        log.debug("ChaosContainer stop requested. waiting for \"stop pausing container\" log");
+                                        log.debug(String.join("\n", chaosContainer.logs));
+                                    }
+                                    return found;
+                                }
+                        ));
+    }
+
+    private ChaosContainer(String targetContainer, String command, WaitStrategy waitStrategy, Consumer<ChaosContainer> beforeStop) {
+        super(PUMBA_IMAGE);
+        setCommand("--log-level info " + command + " " + targetContainer);
+        addFileSystemBind("/var/run/docker.sock", "/var/run/docker.sock", BindMode.READ_WRITE);
+        setWaitStrategy(waitStrategy);
+        withLogConsumer(o -> {
+            final String string = o.getUtf8String();
+            log.info("pumba> {}", string);
+            logs.add(string);
+        });
+        this.beforeStop = beforeStop;
+    }
+
+    @Override
+    public void stop() {
+        if (getContainerId() != null && beforeStop != null) {
+            beforeStop.accept(this);
+        }
+        super.stop();
+    }
 }
\ No newline at end of file

[pulsar] 03/03: Bump version to 2.9.2-SNAPSHOT

Posted by lh...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

lhotari pushed a commit to branch branch-2.9
in repository https://gitbox.apache.org/repos/asf/pulsar.git

commit 107161f7ae2e0317f752142b169259b2f61b4d84
Author: Lari Hotari <lh...@apache.org>
AuthorDate: Wed Dec 22 17:57:58 2021 +0200

    Bump version to 2.9.2-SNAPSHOT
---
 bouncy-castle/bc/pom.xml                              | 2 +-
 bouncy-castle/bcfips-include-test/pom.xml             | 2 +-
 bouncy-castle/bcfips/pom.xml                          | 2 +-
 bouncy-castle/pom.xml                                 | 2 +-
 buildtools/pom.xml                                    | 2 +-
 distribution/io/pom.xml                               | 2 +-
 distribution/offloaders/pom.xml                       | 2 +-
 distribution/pom.xml                                  | 2 +-
 distribution/server/pom.xml                           | 2 +-
 docker/grafana/pom.xml                                | 2 +-
 docker/pom.xml                                        | 2 +-
 docker/pulsar-all/pom.xml                             | 2 +-
 docker/pulsar/pom.xml                                 | 2 +-
 jclouds-shaded/pom.xml                                | 2 +-
 kafka-connect-avro-converter-shaded/pom.xml           | 2 +-
 managed-ledger/pom.xml                                | 2 +-
 pom.xml                                               | 2 +-
 pulsar-broker-auth-athenz/pom.xml                     | 2 +-
 pulsar-broker-auth-sasl/pom.xml                       | 2 +-
 pulsar-broker-common/pom.xml                          | 2 +-
 pulsar-broker-shaded/pom.xml                          | 2 +-
 pulsar-broker/pom.xml                                 | 2 +-
 pulsar-client-1x-base/pom.xml                         | 2 +-
 pulsar-client-1x-base/pulsar-client-1x/pom.xml        | 2 +-
 pulsar-client-1x-base/pulsar-client-2x-shaded/pom.xml | 2 +-
 pulsar-client-admin-api/pom.xml                       | 2 +-
 pulsar-client-admin-shaded/pom.xml                    | 2 +-
 pulsar-client-admin/pom.xml                           | 2 +-
 pulsar-client-all/pom.xml                             | 2 +-
 pulsar-client-api/pom.xml                             | 2 +-
 pulsar-client-auth-athenz/pom.xml                     | 2 +-
 pulsar-client-auth-sasl/pom.xml                       | 2 +-
 pulsar-client-messagecrypto-bc/pom.xml                | 2 +-
 pulsar-client-shaded/pom.xml                          | 2 +-
 pulsar-client-tools-test/pom.xml                      | 2 +-
 pulsar-client-tools/pom.xml                           | 2 +-
 pulsar-client/pom.xml                                 | 2 +-
 pulsar-common/pom.xml                                 | 2 +-
 pulsar-config-validation/pom.xml                      | 2 +-
 pulsar-functions/api-java/pom.xml                     | 2 +-
 pulsar-functions/instance/pom.xml                     | 2 +-
 pulsar-functions/java-examples/pom.xml                | 2 +-
 pulsar-functions/localrun-shaded/pom.xml              | 2 +-
 pulsar-functions/localrun/pom.xml                     | 2 +-
 pulsar-functions/pom.xml                              | 2 +-
 pulsar-functions/proto/pom.xml                        | 2 +-
 pulsar-functions/runtime-all/pom.xml                  | 2 +-
 pulsar-functions/runtime/pom.xml                      | 2 +-
 pulsar-functions/secrets/pom.xml                      | 2 +-
 pulsar-functions/utils/pom.xml                        | 2 +-
 pulsar-functions/worker/pom.xml                       | 2 +-
 pulsar-io/aerospike/pom.xml                           | 2 +-
 pulsar-io/aws/pom.xml                                 | 2 +-
 pulsar-io/batch-data-generator/pom.xml                | 2 +-
 pulsar-io/batch-discovery-triggerers/pom.xml          | 2 +-
 pulsar-io/canal/pom.xml                               | 2 +-
 pulsar-io/cassandra/pom.xml                           | 2 +-
 pulsar-io/common/pom.xml                              | 2 +-
 pulsar-io/core/pom.xml                                | 2 +-
 pulsar-io/data-generator/pom.xml                      | 2 +-
 pulsar-io/debezium/core/pom.xml                       | 2 +-
 pulsar-io/debezium/mongodb/pom.xml                    | 2 +-
 pulsar-io/debezium/mssql/pom.xml                      | 2 +-
 pulsar-io/debezium/mysql/pom.xml                      | 2 +-
 pulsar-io/debezium/oracle/pom.xml                     | 2 +-
 pulsar-io/debezium/pom.xml                            | 2 +-
 pulsar-io/debezium/postgres/pom.xml                   | 2 +-
 pulsar-io/docs/pom.xml                                | 2 +-
 pulsar-io/dynamodb/pom.xml                            | 2 +-
 pulsar-io/elastic-search/pom.xml                      | 2 +-
 pulsar-io/file/pom.xml                                | 2 +-
 pulsar-io/flume/pom.xml                               | 2 +-
 pulsar-io/hbase/pom.xml                               | 2 +-
 pulsar-io/hdfs2/pom.xml                               | 2 +-
 pulsar-io/hdfs3/pom.xml                               | 2 +-
 pulsar-io/influxdb/pom.xml                            | 2 +-
 pulsar-io/jdbc/clickhouse/pom.xml                     | 2 +-
 pulsar-io/jdbc/core/pom.xml                           | 2 +-
 pulsar-io/jdbc/mariadb/pom.xml                        | 2 +-
 pulsar-io/jdbc/pom.xml                                | 2 +-
 pulsar-io/jdbc/postgres/pom.xml                       | 2 +-
 pulsar-io/jdbc/sqlite/pom.xml                         | 2 +-
 pulsar-io/kafka-connect-adaptor-nar/pom.xml           | 2 +-
 pulsar-io/kafka-connect-adaptor/pom.xml               | 2 +-
 pulsar-io/kafka/pom.xml                               | 2 +-
 pulsar-io/kinesis/pom.xml                             | 2 +-
 pulsar-io/mongo/pom.xml                               | 2 +-
 pulsar-io/netty/pom.xml                               | 2 +-
 pulsar-io/nsq/pom.xml                                 | 2 +-
 pulsar-io/pom.xml                                     | 2 +-
 pulsar-io/rabbitmq/pom.xml                            | 2 +-
 pulsar-io/redis/pom.xml                               | 2 +-
 pulsar-io/solr/pom.xml                                | 2 +-
 pulsar-io/twitter/pom.xml                             | 2 +-
 pulsar-metadata/pom.xml                               | 2 +-
 pulsar-package-management/bookkeeper-storage/pom.xml  | 2 +-
 pulsar-package-management/core/pom.xml                | 2 +-
 pulsar-package-management/pom.xml                     | 2 +-
 pulsar-proxy/pom.xml                                  | 2 +-
 pulsar-sql/pom.xml                                    | 2 +-
 pulsar-sql/presto-distribution/pom.xml                | 2 +-
 pulsar-sql/presto-pulsar-plugin/pom.xml               | 2 +-
 pulsar-sql/presto-pulsar/pom.xml                      | 2 +-
 pulsar-testclient/pom.xml                             | 2 +-
 pulsar-transaction/common/pom.xml                     | 2 +-
 pulsar-transaction/coordinator/pom.xml                | 2 +-
 pulsar-transaction/pom.xml                            | 2 +-
 pulsar-websocket/pom.xml                              | 2 +-
 pulsar-zookeeper-utils/pom.xml                        | 2 +-
 structured-event-log/pom.xml                          | 2 +-
 testmocks/pom.xml                                     | 2 +-
 tests/bc_2_0_0/pom.xml                                | 2 +-
 tests/bc_2_0_1/pom.xml                                | 2 +-
 tests/bc_2_6_0/pom.xml                                | 2 +-
 tests/docker-images/java-test-functions/pom.xml       | 2 +-
 tests/docker-images/java-test-image/pom.xml           | 2 +-
 tests/docker-images/latest-version-image/pom.xml      | 2 +-
 tests/docker-images/pom.xml                           | 2 +-
 tests/integration/pom.xml                             | 2 +-
 tests/pom.xml                                         | 2 +-
 tests/pulsar-client-admin-shade-test/pom.xml          | 2 +-
 tests/pulsar-client-all-shade-test/pom.xml            | 2 +-
 tests/pulsar-client-shade-test/pom.xml                | 2 +-
 tiered-storage/file-system/pom.xml                    | 2 +-
 tiered-storage/jcloud/pom.xml                         | 2 +-
 tiered-storage/pom.xml                                | 2 +-
 126 files changed, 126 insertions(+), 126 deletions(-)

diff --git a/bouncy-castle/bc/pom.xml b/bouncy-castle/bc/pom.xml
index 257f396..6128d5b 100644
--- a/bouncy-castle/bc/pom.xml
+++ b/bouncy-castle/bc/pom.xml
@@ -25,7 +25,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>bouncy-castle-parent</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
     <relativePath>..</relativePath>
   </parent>
 
diff --git a/bouncy-castle/bcfips-include-test/pom.xml b/bouncy-castle/bcfips-include-test/pom.xml
index a58e46a..31a706e 100644
--- a/bouncy-castle/bcfips-include-test/pom.xml
+++ b/bouncy-castle/bcfips-include-test/pom.xml
@@ -24,7 +24,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>bouncy-castle-parent</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
     <relativePath>..</relativePath>
   </parent>
 
diff --git a/bouncy-castle/bcfips/pom.xml b/bouncy-castle/bcfips/pom.xml
index 7264209..0a3f88a 100644
--- a/bouncy-castle/bcfips/pom.xml
+++ b/bouncy-castle/bcfips/pom.xml
@@ -25,7 +25,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>bouncy-castle-parent</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
     <relativePath>..</relativePath>
   </parent>
 
diff --git a/bouncy-castle/pom.xml b/bouncy-castle/pom.xml
index 57cfabb..d5aed2f 100644
--- a/bouncy-castle/pom.xml
+++ b/bouncy-castle/pom.xml
@@ -25,7 +25,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
     <relativePath>..</relativePath>
   </parent>
 
diff --git a/buildtools/pom.xml b/buildtools/pom.xml
index 4b6f4e4..b43161a 100644
--- a/buildtools/pom.xml
+++ b/buildtools/pom.xml
@@ -31,7 +31,7 @@
 
   <groupId>org.apache.pulsar</groupId>
   <artifactId>buildtools</artifactId>
-  <version>2.9.1</version>
+  <version>2.9.2-SNAPSHOT</version>
   <packaging>jar</packaging>
   <name>Pulsar Build Tools</name>
 
diff --git a/distribution/io/pom.xml b/distribution/io/pom.xml
index 84e8ee7..ce67238 100644
--- a/distribution/io/pom.xml
+++ b/distribution/io/pom.xml
@@ -25,7 +25,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>distribution</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
     <relativePath>..</relativePath>
   </parent>
 
diff --git a/distribution/offloaders/pom.xml b/distribution/offloaders/pom.xml
index 6bfc10da..a09bdfd 100644
--- a/distribution/offloaders/pom.xml
+++ b/distribution/offloaders/pom.xml
@@ -25,7 +25,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>distribution</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
     <relativePath>..</relativePath>
   </parent>
 
diff --git a/distribution/pom.xml b/distribution/pom.xml
index ff3b0c6..33f4c3c 100644
--- a/distribution/pom.xml
+++ b/distribution/pom.xml
@@ -25,7 +25,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
     <relativePath>..</relativePath>
   </parent>
 
diff --git a/distribution/server/pom.xml b/distribution/server/pom.xml
index 35e9ea3..990455b 100644
--- a/distribution/server/pom.xml
+++ b/distribution/server/pom.xml
@@ -25,7 +25,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>distribution</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
     <relativePath>..</relativePath>
   </parent>
 
diff --git a/docker/grafana/pom.xml b/docker/grafana/pom.xml
index f771f22..988705f 100644
--- a/docker/grafana/pom.xml
+++ b/docker/grafana/pom.xml
@@ -23,7 +23,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>docker-images</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
   </parent>
   <modelVersion>4.0.0</modelVersion>
   <artifactId>grafana-docker-image</artifactId>
diff --git a/docker/pom.xml b/docker/pom.xml
index 2a56ba7..0166e0b 100644
--- a/docker/pom.xml
+++ b/docker/pom.xml
@@ -26,7 +26,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
   </parent>
   <artifactId>docker-images</artifactId>
   <name>Apache Pulsar :: Docker Images</name>
diff --git a/docker/pulsar-all/pom.xml b/docker/pulsar-all/pom.xml
index 4a120af..f909fa8 100644
--- a/docker/pulsar-all/pom.xml
+++ b/docker/pulsar-all/pom.xml
@@ -23,7 +23,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>docker-images</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
   </parent>
   <modelVersion>4.0.0</modelVersion>
   <artifactId>pulsar-all-docker-image</artifactId>
diff --git a/docker/pulsar/pom.xml b/docker/pulsar/pom.xml
index 86dc760..a5a0cd0 100644
--- a/docker/pulsar/pom.xml
+++ b/docker/pulsar/pom.xml
@@ -23,7 +23,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>docker-images</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
   </parent>
   <modelVersion>4.0.0</modelVersion>
   <artifactId>pulsar-docker-image</artifactId>
diff --git a/jclouds-shaded/pom.xml b/jclouds-shaded/pom.xml
index 989bcfe..2900155 100644
--- a/jclouds-shaded/pom.xml
+++ b/jclouds-shaded/pom.xml
@@ -26,7 +26,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
     <relativePath>..</relativePath>
   </parent>
 
diff --git a/kafka-connect-avro-converter-shaded/pom.xml b/kafka-connect-avro-converter-shaded/pom.xml
index 0550447..96a0b56 100644
--- a/kafka-connect-avro-converter-shaded/pom.xml
+++ b/kafka-connect-avro-converter-shaded/pom.xml
@@ -26,7 +26,7 @@
     <parent>
         <artifactId>pulsar</artifactId>
         <groupId>org.apache.pulsar</groupId>
-        <version>2.9.1</version>
+        <version>2.9.2-SNAPSHOT</version>
         <relativePath>..</relativePath>
     </parent>
 
diff --git a/managed-ledger/pom.xml b/managed-ledger/pom.xml
index 27ef663..e7e9d98 100644
--- a/managed-ledger/pom.xml
+++ b/managed-ledger/pom.xml
@@ -25,7 +25,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
     <relativePath>..</relativePath>
   </parent>
 
diff --git a/pom.xml b/pom.xml
index 362f348..088e9cb 100644
--- a/pom.xml
+++ b/pom.xml
@@ -32,7 +32,7 @@
   <groupId>org.apache.pulsar</groupId>
   <artifactId>pulsar</artifactId>
 
-  <version>2.9.1</version>
+  <version>2.9.2-SNAPSHOT</version>
 
   <name>Pulsar</name>
   <description>Pulsar is a distributed pub-sub messaging platform with a very
diff --git a/pulsar-broker-auth-athenz/pom.xml b/pulsar-broker-auth-athenz/pom.xml
index cc5e217..bf0b444 100644
--- a/pulsar-broker-auth-athenz/pom.xml
+++ b/pulsar-broker-auth-athenz/pom.xml
@@ -26,7 +26,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
   </parent>
 
   <artifactId>pulsar-broker-auth-athenz</artifactId>
diff --git a/pulsar-broker-auth-sasl/pom.xml b/pulsar-broker-auth-sasl/pom.xml
index af45d2b..426e89b 100644
--- a/pulsar-broker-auth-sasl/pom.xml
+++ b/pulsar-broker-auth-sasl/pom.xml
@@ -26,7 +26,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
   </parent>
 
   <artifactId>pulsar-broker-auth-sasl</artifactId>
diff --git a/pulsar-broker-common/pom.xml b/pulsar-broker-common/pom.xml
index 1686656..d78bf0d 100644
--- a/pulsar-broker-common/pom.xml
+++ b/pulsar-broker-common/pom.xml
@@ -26,7 +26,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
   </parent>
 
   <artifactId>pulsar-broker-common</artifactId>
diff --git a/pulsar-broker-shaded/pom.xml b/pulsar-broker-shaded/pom.xml
index 7e074af..569b910 100644
--- a/pulsar-broker-shaded/pom.xml
+++ b/pulsar-broker-shaded/pom.xml
@@ -26,7 +26,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
     <relativePath>..</relativePath>
   </parent>
 
diff --git a/pulsar-broker/pom.xml b/pulsar-broker/pom.xml
index 86bc562..68efb88 100644
--- a/pulsar-broker/pom.xml
+++ b/pulsar-broker/pom.xml
@@ -25,7 +25,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
     <relativePath>..</relativePath>
   </parent>
 
diff --git a/pulsar-client-1x-base/pom.xml b/pulsar-client-1x-base/pom.xml
index 45c4a8c..304eb8a 100644
--- a/pulsar-client-1x-base/pom.xml
+++ b/pulsar-client-1x-base/pom.xml
@@ -25,7 +25,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
     <relativePath>..</relativePath>
   </parent>
 
diff --git a/pulsar-client-1x-base/pulsar-client-1x/pom.xml b/pulsar-client-1x-base/pulsar-client-1x/pom.xml
index 4f9b9dc..56afd8a 100644
--- a/pulsar-client-1x-base/pulsar-client-1x/pom.xml
+++ b/pulsar-client-1x-base/pulsar-client-1x/pom.xml
@@ -25,7 +25,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar-client-1x-base</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
     <relativePath>..</relativePath>
   </parent>
 
diff --git a/pulsar-client-1x-base/pulsar-client-2x-shaded/pom.xml b/pulsar-client-1x-base/pulsar-client-2x-shaded/pom.xml
index f291d1c..4063145 100644
--- a/pulsar-client-1x-base/pulsar-client-2x-shaded/pom.xml
+++ b/pulsar-client-1x-base/pulsar-client-2x-shaded/pom.xml
@@ -25,7 +25,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar-client-1x-base</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
     <relativePath>..</relativePath>
   </parent>
 
diff --git a/pulsar-client-admin-api/pom.xml b/pulsar-client-admin-api/pom.xml
index ce51144..e1261ac 100644
--- a/pulsar-client-admin-api/pom.xml
+++ b/pulsar-client-admin-api/pom.xml
@@ -25,7 +25,7 @@
     <parent>
         <groupId>org.apache.pulsar</groupId>
         <artifactId>pulsar</artifactId>
-        <version>2.9.1</version>
+        <version>2.9.2-SNAPSHOT</version>
         <relativePath>..</relativePath>
     </parent>
 
diff --git a/pulsar-client-admin-shaded/pom.xml b/pulsar-client-admin-shaded/pom.xml
index c37d74b..f567b37 100644
--- a/pulsar-client-admin-shaded/pom.xml
+++ b/pulsar-client-admin-shaded/pom.xml
@@ -26,7 +26,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
     <relativePath>..</relativePath>
   </parent>
 
diff --git a/pulsar-client-admin/pom.xml b/pulsar-client-admin/pom.xml
index e433733..7f49866 100644
--- a/pulsar-client-admin/pom.xml
+++ b/pulsar-client-admin/pom.xml
@@ -26,7 +26,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
     <relativePath>..</relativePath>
   </parent>
 
diff --git a/pulsar-client-all/pom.xml b/pulsar-client-all/pom.xml
index c5296c3..fa98349 100644
--- a/pulsar-client-all/pom.xml
+++ b/pulsar-client-all/pom.xml
@@ -25,7 +25,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
     <relativePath>..</relativePath>
   </parent>
 
diff --git a/pulsar-client-api/pom.xml b/pulsar-client-api/pom.xml
index 4cdd80b..e7a890d 100644
--- a/pulsar-client-api/pom.xml
+++ b/pulsar-client-api/pom.xml
@@ -25,7 +25,7 @@
     <parent>
         <groupId>org.apache.pulsar</groupId>
         <artifactId>pulsar</artifactId>
-        <version>2.9.1</version>
+        <version>2.9.2-SNAPSHOT</version>
         <relativePath>..</relativePath>
     </parent>
 
diff --git a/pulsar-client-auth-athenz/pom.xml b/pulsar-client-auth-athenz/pom.xml
index b6256f5..ae23cf1 100644
--- a/pulsar-client-auth-athenz/pom.xml
+++ b/pulsar-client-auth-athenz/pom.xml
@@ -25,7 +25,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
     <relativePath>..</relativePath>
   </parent>
 
diff --git a/pulsar-client-auth-sasl/pom.xml b/pulsar-client-auth-sasl/pom.xml
index bb7d4d6..ce82078 100644
--- a/pulsar-client-auth-sasl/pom.xml
+++ b/pulsar-client-auth-sasl/pom.xml
@@ -25,7 +25,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
     <relativePath>..</relativePath>
   </parent>
 
diff --git a/pulsar-client-messagecrypto-bc/pom.xml b/pulsar-client-messagecrypto-bc/pom.xml
index 58e1d3d..73cc277 100644
--- a/pulsar-client-messagecrypto-bc/pom.xml
+++ b/pulsar-client-messagecrypto-bc/pom.xml
@@ -25,7 +25,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
     <relativePath>..</relativePath>
   </parent>
 
diff --git a/pulsar-client-shaded/pom.xml b/pulsar-client-shaded/pom.xml
index 6f3487d..8e533d6 100644
--- a/pulsar-client-shaded/pom.xml
+++ b/pulsar-client-shaded/pom.xml
@@ -25,7 +25,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
     <relativePath>..</relativePath>
   </parent>
 
diff --git a/pulsar-client-tools-test/pom.xml b/pulsar-client-tools-test/pom.xml
index 922b5eb..cae4afe 100644
--- a/pulsar-client-tools-test/pom.xml
+++ b/pulsar-client-tools-test/pom.xml
@@ -24,7 +24,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
     <relativePath>..</relativePath>
   </parent>
 
diff --git a/pulsar-client-tools/pom.xml b/pulsar-client-tools/pom.xml
index 60e0f7a..c6d261bf 100644
--- a/pulsar-client-tools/pom.xml
+++ b/pulsar-client-tools/pom.xml
@@ -24,7 +24,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
     <relativePath>..</relativePath>
   </parent>
 
diff --git a/pulsar-client/pom.xml b/pulsar-client/pom.xml
index 0b5564c..ce19286 100644
--- a/pulsar-client/pom.xml
+++ b/pulsar-client/pom.xml
@@ -25,7 +25,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
     <relativePath>..</relativePath>
   </parent>
 
diff --git a/pulsar-common/pom.xml b/pulsar-common/pom.xml
index ba2502e..31706b7 100644
--- a/pulsar-common/pom.xml
+++ b/pulsar-common/pom.xml
@@ -26,7 +26,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
     <relativePath>..</relativePath>
   </parent>
 
diff --git a/pulsar-config-validation/pom.xml b/pulsar-config-validation/pom.xml
index 2319a17..c10d161d 100644
--- a/pulsar-config-validation/pom.xml
+++ b/pulsar-config-validation/pom.xml
@@ -26,7 +26,7 @@
     <parent>
         <groupId>org.apache.pulsar</groupId>
         <artifactId>pulsar</artifactId>
-        <version>2.9.1</version>
+        <version>2.9.2-SNAPSHOT</version>
         <relativePath>..</relativePath>
     </parent>
 
diff --git a/pulsar-functions/api-java/pom.xml b/pulsar-functions/api-java/pom.xml
index 9c786d9..14f5744 100644
--- a/pulsar-functions/api-java/pom.xml
+++ b/pulsar-functions/api-java/pom.xml
@@ -24,7 +24,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar-functions</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
   </parent>
 
   <artifactId>pulsar-functions-api</artifactId>
diff --git a/pulsar-functions/instance/pom.xml b/pulsar-functions/instance/pom.xml
index 2c16c1f..180936d 100644
--- a/pulsar-functions/instance/pom.xml
+++ b/pulsar-functions/instance/pom.xml
@@ -25,7 +25,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar-functions</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
   </parent>
 
   <artifactId>pulsar-functions-instance</artifactId>
diff --git a/pulsar-functions/java-examples/pom.xml b/pulsar-functions/java-examples/pom.xml
index e75a9fc..c5f84bc 100644
--- a/pulsar-functions/java-examples/pom.xml
+++ b/pulsar-functions/java-examples/pom.xml
@@ -24,7 +24,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar-functions</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
   </parent>
 
   <artifactId>pulsar-functions-api-examples</artifactId>
diff --git a/pulsar-functions/localrun-shaded/pom.xml b/pulsar-functions/localrun-shaded/pom.xml
index 092a714..05f57fd 100644
--- a/pulsar-functions/localrun-shaded/pom.xml
+++ b/pulsar-functions/localrun-shaded/pom.xml
@@ -26,7 +26,7 @@
     <parent>
         <groupId>org.apache.pulsar</groupId>
         <artifactId>pulsar-functions</artifactId>
-        <version>2.9.1</version>
+        <version>2.9.2-SNAPSHOT</version>
         <relativePath>..</relativePath>
     </parent>
 
diff --git a/pulsar-functions/localrun/pom.xml b/pulsar-functions/localrun/pom.xml
index f5bf0ea..f71052b 100644
--- a/pulsar-functions/localrun/pom.xml
+++ b/pulsar-functions/localrun/pom.xml
@@ -26,7 +26,7 @@
     <parent>
         <groupId>org.apache.pulsar</groupId>
         <artifactId>pulsar-functions</artifactId>
-        <version>2.9.1</version>
+        <version>2.9.2-SNAPSHOT</version>
         <relativePath>..</relativePath>
     </parent>
 
diff --git a/pulsar-functions/pom.xml b/pulsar-functions/pom.xml
index fcc43a88..ef69d3a 100644
--- a/pulsar-functions/pom.xml
+++ b/pulsar-functions/pom.xml
@@ -25,7 +25,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
   </parent>
 
   <artifactId>pulsar-functions</artifactId>
diff --git a/pulsar-functions/proto/pom.xml b/pulsar-functions/proto/pom.xml
index 846e519..45dcdf2 100644
--- a/pulsar-functions/proto/pom.xml
+++ b/pulsar-functions/proto/pom.xml
@@ -27,7 +27,7 @@
     <parent>
         <groupId>org.apache.pulsar</groupId>
         <artifactId>pulsar-functions</artifactId>
-        <version>2.9.1</version>
+        <version>2.9.2-SNAPSHOT</version>
     </parent>
 
     <artifactId>pulsar-functions-proto</artifactId>
diff --git a/pulsar-functions/runtime-all/pom.xml b/pulsar-functions/runtime-all/pom.xml
index c1a058f..f486f52 100644
--- a/pulsar-functions/runtime-all/pom.xml
+++ b/pulsar-functions/runtime-all/pom.xml
@@ -26,7 +26,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar-functions</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
     <relativePath>..</relativePath>
   </parent>
 
diff --git a/pulsar-functions/runtime/pom.xml b/pulsar-functions/runtime/pom.xml
index 316c300..4a1a7a4 100644
--- a/pulsar-functions/runtime/pom.xml
+++ b/pulsar-functions/runtime/pom.xml
@@ -25,7 +25,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar-functions</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
   </parent>
 
   <artifactId>pulsar-functions-runtime</artifactId>
diff --git a/pulsar-functions/secrets/pom.xml b/pulsar-functions/secrets/pom.xml
index 4c1f434..6526a1d 100644
--- a/pulsar-functions/secrets/pom.xml
+++ b/pulsar-functions/secrets/pom.xml
@@ -24,7 +24,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar-functions</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
   </parent>
 
   <artifactId>pulsar-functions-secrets</artifactId>
diff --git a/pulsar-functions/utils/pom.xml b/pulsar-functions/utils/pom.xml
index 2f29075..accf6a4 100644
--- a/pulsar-functions/utils/pom.xml
+++ b/pulsar-functions/utils/pom.xml
@@ -25,7 +25,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar-functions</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
   </parent>
 
   <artifactId>pulsar-functions-utils</artifactId>
diff --git a/pulsar-functions/worker/pom.xml b/pulsar-functions/worker/pom.xml
index 992415c..100e582 100644
--- a/pulsar-functions/worker/pom.xml
+++ b/pulsar-functions/worker/pom.xml
@@ -25,7 +25,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar-functions</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
     <relativePath>..</relativePath>
   </parent>
 
diff --git a/pulsar-io/aerospike/pom.xml b/pulsar-io/aerospike/pom.xml
index 0a9961b..9ccb68b 100644
--- a/pulsar-io/aerospike/pom.xml
+++ b/pulsar-io/aerospike/pom.xml
@@ -24,7 +24,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar-io</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
   </parent>
 
   <artifactId>pulsar-io-aerospike</artifactId>
diff --git a/pulsar-io/aws/pom.xml b/pulsar-io/aws/pom.xml
index fcd079c..9bc8460 100644
--- a/pulsar-io/aws/pom.xml
+++ b/pulsar-io/aws/pom.xml
@@ -24,7 +24,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar-io</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
   </parent>
 
   <artifactId>pulsar-io-aws</artifactId>
diff --git a/pulsar-io/batch-data-generator/pom.xml b/pulsar-io/batch-data-generator/pom.xml
index 742ed49..8141194 100644
--- a/pulsar-io/batch-data-generator/pom.xml
+++ b/pulsar-io/batch-data-generator/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.pulsar</groupId>
         <artifactId>pulsar-io</artifactId>
-        <version>2.9.1</version>
+        <version>2.9.2-SNAPSHOT</version>
     </parent>
 
     <artifactId>pulsar-io-batch-data-generator</artifactId>
diff --git a/pulsar-io/batch-discovery-triggerers/pom.xml b/pulsar-io/batch-discovery-triggerers/pom.xml
index 056e13e..0f9b8a9 100644
--- a/pulsar-io/batch-discovery-triggerers/pom.xml
+++ b/pulsar-io/batch-discovery-triggerers/pom.xml
@@ -25,7 +25,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar-io</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
   </parent>
 
   <artifactId>pulsar-io-batch-discovery-triggerers</artifactId>
diff --git a/pulsar-io/canal/pom.xml b/pulsar-io/canal/pom.xml
index 7e32670..8449146 100644
--- a/pulsar-io/canal/pom.xml
+++ b/pulsar-io/canal/pom.xml
@@ -25,7 +25,7 @@
     <parent>
         <groupId>org.apache.pulsar</groupId>
         <artifactId>pulsar-io</artifactId>
-        <version>2.9.1</version>
+        <version>2.9.2-SNAPSHOT</version>
     </parent>
     <modelVersion>4.0.0</modelVersion>
 
diff --git a/pulsar-io/cassandra/pom.xml b/pulsar-io/cassandra/pom.xml
index 1ead477..103c3c9 100644
--- a/pulsar-io/cassandra/pom.xml
+++ b/pulsar-io/cassandra/pom.xml
@@ -24,7 +24,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar-io</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
   </parent>
 
   <artifactId>pulsar-io-cassandra</artifactId>
diff --git a/pulsar-io/common/pom.xml b/pulsar-io/common/pom.xml
index c643d20..a93eea0 100644
--- a/pulsar-io/common/pom.xml
+++ b/pulsar-io/common/pom.xml
@@ -27,7 +27,7 @@
     <parent>
         <groupId>org.apache.pulsar</groupId>
         <artifactId>pulsar-io</artifactId>
-        <version>2.9.1</version>
+        <version>2.9.2-SNAPSHOT</version>
     </parent>
 
     <artifactId>pulsar-io-common</artifactId>
diff --git a/pulsar-io/core/pom.xml b/pulsar-io/core/pom.xml
index bba433e..1cb0867 100644
--- a/pulsar-io/core/pom.xml
+++ b/pulsar-io/core/pom.xml
@@ -24,7 +24,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar-io</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
   </parent>
 
   <artifactId>pulsar-io-core</artifactId>
diff --git a/pulsar-io/data-generator/pom.xml b/pulsar-io/data-generator/pom.xml
index 7906e44..ed00d32bb 100644
--- a/pulsar-io/data-generator/pom.xml
+++ b/pulsar-io/data-generator/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.pulsar</groupId>
         <artifactId>pulsar-io</artifactId>
-        <version>2.9.1</version>
+        <version>2.9.2-SNAPSHOT</version>
     </parent>
 
     <artifactId>pulsar-io-data-generator</artifactId>
diff --git a/pulsar-io/debezium/core/pom.xml b/pulsar-io/debezium/core/pom.xml
index 29aea0e..9e2bbe3 100644
--- a/pulsar-io/debezium/core/pom.xml
+++ b/pulsar-io/debezium/core/pom.xml
@@ -24,7 +24,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar-io-debezium</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
   </parent>
 
   <artifactId>pulsar-io-debezium-core</artifactId>
diff --git a/pulsar-io/debezium/mongodb/pom.xml b/pulsar-io/debezium/mongodb/pom.xml
index 3e651d4..e44b076 100644
--- a/pulsar-io/debezium/mongodb/pom.xml
+++ b/pulsar-io/debezium/mongodb/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.pulsar</groupId>
         <artifactId>pulsar-io-debezium</artifactId>
-        <version>2.9.1</version>
+        <version>2.9.2-SNAPSHOT</version>
     </parent>
 
     <artifactId>pulsar-io-debezium-mongodb</artifactId>
diff --git a/pulsar-io/debezium/mssql/pom.xml b/pulsar-io/debezium/mssql/pom.xml
index 2410c8e..1474443 100644
--- a/pulsar-io/debezium/mssql/pom.xml
+++ b/pulsar-io/debezium/mssql/pom.xml
@@ -24,7 +24,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar-io-debezium</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
   </parent>
 
   <artifactId>pulsar-io-debezium-mssql</artifactId>
diff --git a/pulsar-io/debezium/mysql/pom.xml b/pulsar-io/debezium/mysql/pom.xml
index 99ecc53..122c4f5 100644
--- a/pulsar-io/debezium/mysql/pom.xml
+++ b/pulsar-io/debezium/mysql/pom.xml
@@ -24,7 +24,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar-io-debezium</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
   </parent>
 
   <artifactId>pulsar-io-debezium-mysql</artifactId>
diff --git a/pulsar-io/debezium/oracle/pom.xml b/pulsar-io/debezium/oracle/pom.xml
index 9248e2e..08203dc 100644
--- a/pulsar-io/debezium/oracle/pom.xml
+++ b/pulsar-io/debezium/oracle/pom.xml
@@ -24,7 +24,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar-io-debezium</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
   </parent>
 
   <artifactId>pulsar-io-debezium-oracle</artifactId>
diff --git a/pulsar-io/debezium/pom.xml b/pulsar-io/debezium/pom.xml
index 245b168..25e5248 100644
--- a/pulsar-io/debezium/pom.xml
+++ b/pulsar-io/debezium/pom.xml
@@ -25,7 +25,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar-io</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
   </parent>
 
   <artifactId>pulsar-io-debezium</artifactId>
diff --git a/pulsar-io/debezium/postgres/pom.xml b/pulsar-io/debezium/postgres/pom.xml
index a3d38fd..0408076 100644
--- a/pulsar-io/debezium/postgres/pom.xml
+++ b/pulsar-io/debezium/postgres/pom.xml
@@ -24,7 +24,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar-io-debezium</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
   </parent>
 
   <artifactId>pulsar-io-debezium-postgres</artifactId>
diff --git a/pulsar-io/docs/pom.xml b/pulsar-io/docs/pom.xml
index 07c9654..836345e 100644
--- a/pulsar-io/docs/pom.xml
+++ b/pulsar-io/docs/pom.xml
@@ -24,7 +24,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar-io</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
   </parent>
 
   <artifactId>pulsar-io-docs</artifactId>
diff --git a/pulsar-io/dynamodb/pom.xml b/pulsar-io/dynamodb/pom.xml
index 3562cdc..9074b91 100644
--- a/pulsar-io/dynamodb/pom.xml
+++ b/pulsar-io/dynamodb/pom.xml
@@ -24,7 +24,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar-io</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
   </parent>
 
   <artifactId>pulsar-io-dynamodb</artifactId>
diff --git a/pulsar-io/elastic-search/pom.xml b/pulsar-io/elastic-search/pom.xml
index b01ac3f..779c4ff 100644
--- a/pulsar-io/elastic-search/pom.xml
+++ b/pulsar-io/elastic-search/pom.xml
@@ -23,7 +23,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar-io</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
   </parent>
   <artifactId>pulsar-io-elastic-search</artifactId>
   <name>Pulsar IO :: ElasticSearch</name>
diff --git a/pulsar-io/file/pom.xml b/pulsar-io/file/pom.xml
index 3f61066..338bdfc 100644
--- a/pulsar-io/file/pom.xml
+++ b/pulsar-io/file/pom.xml
@@ -23,7 +23,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar-io</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
   </parent>
 
   <artifactId>pulsar-io-file</artifactId>
diff --git a/pulsar-io/flume/pom.xml b/pulsar-io/flume/pom.xml
index 8600a85..051902a 100644
--- a/pulsar-io/flume/pom.xml
+++ b/pulsar-io/flume/pom.xml
@@ -25,7 +25,7 @@
     <parent>
         <groupId>org.apache.pulsar</groupId>
         <artifactId>pulsar-io</artifactId>
-        <version>2.9.1</version>
+        <version>2.9.2-SNAPSHOT</version>
     </parent>
 
     <artifactId>pulsar-io-flume</artifactId>
diff --git a/pulsar-io/hbase/pom.xml b/pulsar-io/hbase/pom.xml
index 17257fa..388bcd6 100644
--- a/pulsar-io/hbase/pom.xml
+++ b/pulsar-io/hbase/pom.xml
@@ -25,7 +25,7 @@
     <parent>
         <artifactId>pulsar-io</artifactId>
         <groupId>org.apache.pulsar</groupId>
-        <version>2.9.1</version>
+        <version>2.9.2-SNAPSHOT</version>
     </parent>
     <artifactId>pulsar-io-hbase</artifactId>
     <name>Pulsar IO :: Hbase</name>
diff --git a/pulsar-io/hdfs2/pom.xml b/pulsar-io/hdfs2/pom.xml
index f3ffa71..bc4f19c 100644
--- a/pulsar-io/hdfs2/pom.xml
+++ b/pulsar-io/hdfs2/pom.xml
@@ -23,7 +23,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar-io</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
   </parent>
   <artifactId>pulsar-io-hdfs2</artifactId>
   <name>Pulsar IO :: Hdfs2</name>
diff --git a/pulsar-io/hdfs3/pom.xml b/pulsar-io/hdfs3/pom.xml
index e80e366..2d4f332 100644
--- a/pulsar-io/hdfs3/pom.xml
+++ b/pulsar-io/hdfs3/pom.xml
@@ -23,7 +23,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar-io</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
   </parent>
   <artifactId>pulsar-io-hdfs3</artifactId>
   <name>Pulsar IO :: Hdfs3</name>
diff --git a/pulsar-io/influxdb/pom.xml b/pulsar-io/influxdb/pom.xml
index a929ab3..8c7c6d0 100644
--- a/pulsar-io/influxdb/pom.xml
+++ b/pulsar-io/influxdb/pom.xml
@@ -25,7 +25,7 @@
     <parent>
         <artifactId>pulsar-io</artifactId>
         <groupId>org.apache.pulsar</groupId>
-        <version>2.9.1</version>
+        <version>2.9.2-SNAPSHOT</version>
     </parent>
 
     <artifactId>pulsar-io-influxdb</artifactId>
diff --git a/pulsar-io/jdbc/clickhouse/pom.xml b/pulsar-io/jdbc/clickhouse/pom.xml
index 2f93507..c368fba 100644
--- a/pulsar-io/jdbc/clickhouse/pom.xml
+++ b/pulsar-io/jdbc/clickhouse/pom.xml
@@ -24,7 +24,7 @@
   <parent>
     <artifactId>pulsar-io-jdbc</artifactId>
     <groupId>org.apache.pulsar</groupId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
   </parent>
   <modelVersion>4.0.0</modelVersion>
 
diff --git a/pulsar-io/jdbc/core/pom.xml b/pulsar-io/jdbc/core/pom.xml
index 26df287..1e2c66e 100644
--- a/pulsar-io/jdbc/core/pom.xml
+++ b/pulsar-io/jdbc/core/pom.xml
@@ -24,7 +24,7 @@
   <parent>
     <artifactId>pulsar-io-jdbc</artifactId>
     <groupId>org.apache.pulsar</groupId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
   </parent>
   <modelVersion>4.0.0</modelVersion>
 
diff --git a/pulsar-io/jdbc/mariadb/pom.xml b/pulsar-io/jdbc/mariadb/pom.xml
index e357409..807baaa 100644
--- a/pulsar-io/jdbc/mariadb/pom.xml
+++ b/pulsar-io/jdbc/mariadb/pom.xml
@@ -24,7 +24,7 @@
   <parent>
     <artifactId>pulsar-io-jdbc</artifactId>
     <groupId>org.apache.pulsar</groupId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
   </parent>
   <modelVersion>4.0.0</modelVersion>
 
diff --git a/pulsar-io/jdbc/pom.xml b/pulsar-io/jdbc/pom.xml
index 774dc30..b81637e 100644
--- a/pulsar-io/jdbc/pom.xml
+++ b/pulsar-io/jdbc/pom.xml
@@ -32,7 +32,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar-io</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
   </parent>
 
   <artifactId>pulsar-io-jdbc</artifactId>
diff --git a/pulsar-io/jdbc/postgres/pom.xml b/pulsar-io/jdbc/postgres/pom.xml
index 06ad0cc..5166bad 100644
--- a/pulsar-io/jdbc/postgres/pom.xml
+++ b/pulsar-io/jdbc/postgres/pom.xml
@@ -24,7 +24,7 @@
   <parent>
     <artifactId>pulsar-io-jdbc</artifactId>
     <groupId>org.apache.pulsar</groupId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
   </parent>
   <modelVersion>4.0.0</modelVersion>
 
diff --git a/pulsar-io/jdbc/sqlite/pom.xml b/pulsar-io/jdbc/sqlite/pom.xml
index 8a61e14..4500bf9 100644
--- a/pulsar-io/jdbc/sqlite/pom.xml
+++ b/pulsar-io/jdbc/sqlite/pom.xml
@@ -24,7 +24,7 @@
   <parent>
     <artifactId>pulsar-io-jdbc</artifactId>
     <groupId>org.apache.pulsar</groupId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
   </parent>
   <modelVersion>4.0.0</modelVersion>
   <artifactId>pulsar-io-jdbc-sqlite</artifactId>
diff --git a/pulsar-io/kafka-connect-adaptor-nar/pom.xml b/pulsar-io/kafka-connect-adaptor-nar/pom.xml
index 27eb402..7518cf7 100644
--- a/pulsar-io/kafka-connect-adaptor-nar/pom.xml
+++ b/pulsar-io/kafka-connect-adaptor-nar/pom.xml
@@ -24,7 +24,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar-io</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
   </parent>
 
   <artifactId>pulsar-io-kafka-connect-adaptor-nar</artifactId>
diff --git a/pulsar-io/kafka-connect-adaptor/pom.xml b/pulsar-io/kafka-connect-adaptor/pom.xml
index f0af99c..24baed8 100644
--- a/pulsar-io/kafka-connect-adaptor/pom.xml
+++ b/pulsar-io/kafka-connect-adaptor/pom.xml
@@ -24,7 +24,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar-io</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
   </parent>
 
   <artifactId>pulsar-io-kafka-connect-adaptor</artifactId>
diff --git a/pulsar-io/kafka/pom.xml b/pulsar-io/kafka/pom.xml
index 9be6b78..dfb80b7 100644
--- a/pulsar-io/kafka/pom.xml
+++ b/pulsar-io/kafka/pom.xml
@@ -24,7 +24,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar-io</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
   </parent>
 
   <artifactId>pulsar-io-kafka</artifactId>
diff --git a/pulsar-io/kinesis/pom.xml b/pulsar-io/kinesis/pom.xml
index b1fe4c9..fdfa4cb 100644
--- a/pulsar-io/kinesis/pom.xml
+++ b/pulsar-io/kinesis/pom.xml
@@ -24,7 +24,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar-io</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
   </parent>
 
   <artifactId>pulsar-io-kinesis</artifactId>
diff --git a/pulsar-io/mongo/pom.xml b/pulsar-io/mongo/pom.xml
index 011609b..8cfc461 100644
--- a/pulsar-io/mongo/pom.xml
+++ b/pulsar-io/mongo/pom.xml
@@ -26,7 +26,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
       <artifactId>pulsar-io</artifactId>
-      <version>2.9.1</version>
+      <version>2.9.2-SNAPSHOT</version>
   </parent>
 
   <artifactId>pulsar-io-mongo</artifactId>
diff --git a/pulsar-io/netty/pom.xml b/pulsar-io/netty/pom.xml
index 8a55c34..957b26b 100644
--- a/pulsar-io/netty/pom.xml
+++ b/pulsar-io/netty/pom.xml
@@ -25,7 +25,7 @@
     <parent>
         <groupId>org.apache.pulsar</groupId>
         <artifactId>pulsar-io</artifactId>
-        <version>2.9.1</version>
+        <version>2.9.2-SNAPSHOT</version>
     </parent>
 
     <artifactId>pulsar-io-netty</artifactId>
diff --git a/pulsar-io/nsq/pom.xml b/pulsar-io/nsq/pom.xml
index a69f436..cd83ffb 100644
--- a/pulsar-io/nsq/pom.xml
+++ b/pulsar-io/nsq/pom.xml
@@ -24,7 +24,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar-io</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
   </parent>
  
   <artifactId>pulsar-io-nsq</artifactId>
diff --git a/pulsar-io/pom.xml b/pulsar-io/pom.xml
index 77b329c..e3a96af 100644
--- a/pulsar-io/pom.xml
+++ b/pulsar-io/pom.xml
@@ -25,7 +25,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
   </parent>
 
   <artifactId>pulsar-io</artifactId>
diff --git a/pulsar-io/rabbitmq/pom.xml b/pulsar-io/rabbitmq/pom.xml
index 3dc46c0..9a011ed 100644
--- a/pulsar-io/rabbitmq/pom.xml
+++ b/pulsar-io/rabbitmq/pom.xml
@@ -24,7 +24,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar-io</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
   </parent>
 
   <artifactId>pulsar-io-rabbitmq</artifactId>
diff --git a/pulsar-io/redis/pom.xml b/pulsar-io/redis/pom.xml
index b68dc8d..0fb713c 100644
--- a/pulsar-io/redis/pom.xml
+++ b/pulsar-io/redis/pom.xml
@@ -25,7 +25,7 @@
     <parent>
         <artifactId>pulsar-io</artifactId>
         <groupId>org.apache.pulsar</groupId>
-        <version>2.9.1</version>
+        <version>2.9.2-SNAPSHOT</version>
     </parent>
 
     <artifactId>pulsar-io-redis</artifactId>
diff --git a/pulsar-io/solr/pom.xml b/pulsar-io/solr/pom.xml
index 04b3e88..db3cafc 100644
--- a/pulsar-io/solr/pom.xml
+++ b/pulsar-io/solr/pom.xml
@@ -25,7 +25,7 @@
     <parent>
         <artifactId>pulsar-io</artifactId>
         <groupId>org.apache.pulsar</groupId>
-        <version>2.9.1</version>
+        <version>2.9.2-SNAPSHOT</version>
     </parent>
 
     <properties>
diff --git a/pulsar-io/twitter/pom.xml b/pulsar-io/twitter/pom.xml
index f6e45a4..01e5a0a 100644
--- a/pulsar-io/twitter/pom.xml
+++ b/pulsar-io/twitter/pom.xml
@@ -24,7 +24,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar-io</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
   </parent>
 
   <artifactId>pulsar-io-twitter</artifactId>
diff --git a/pulsar-metadata/pom.xml b/pulsar-metadata/pom.xml
index 4aaba09..56b3789 100644
--- a/pulsar-metadata/pom.xml
+++ b/pulsar-metadata/pom.xml
@@ -25,7 +25,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
     <relativePath>..</relativePath>
   </parent>
 
diff --git a/pulsar-package-management/bookkeeper-storage/pom.xml b/pulsar-package-management/bookkeeper-storage/pom.xml
index 598c597..0566dc0 100644
--- a/pulsar-package-management/bookkeeper-storage/pom.xml
+++ b/pulsar-package-management/bookkeeper-storage/pom.xml
@@ -25,7 +25,7 @@
     <parent>
         <artifactId>pulsar-package-management</artifactId>
         <groupId>org.apache.pulsar</groupId>
-        <version>2.9.1</version>
+        <version>2.9.2-SNAPSHOT</version>
     </parent>
     <modelVersion>4.0.0</modelVersion>
 
diff --git a/pulsar-package-management/core/pom.xml b/pulsar-package-management/core/pom.xml
index ba6b957..79b0c87 100644
--- a/pulsar-package-management/core/pom.xml
+++ b/pulsar-package-management/core/pom.xml
@@ -25,7 +25,7 @@
     <parent>
         <artifactId>pulsar-package-management</artifactId>
         <groupId>org.apache.pulsar</groupId>
-        <version>2.9.1</version>
+        <version>2.9.2-SNAPSHOT</version>
     </parent>
     <modelVersion>4.0.0</modelVersion>
 
diff --git a/pulsar-package-management/pom.xml b/pulsar-package-management/pom.xml
index dfab92a..6d954a3 100644
--- a/pulsar-package-management/pom.xml
+++ b/pulsar-package-management/pom.xml
@@ -25,7 +25,7 @@
     <parent>
         <artifactId>pulsar</artifactId>
         <groupId>org.apache.pulsar</groupId>
-        <version>2.9.1</version>
+        <version>2.9.2-SNAPSHOT</version>
         <relativePath>..</relativePath>
     </parent>
     <modelVersion>4.0.0</modelVersion>
diff --git a/pulsar-proxy/pom.xml b/pulsar-proxy/pom.xml
index ffb9cd7..fa8bd92a 100644
--- a/pulsar-proxy/pom.xml
+++ b/pulsar-proxy/pom.xml
@@ -24,7 +24,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
   </parent>
 
   <artifactId>pulsar-proxy</artifactId>
diff --git a/pulsar-sql/pom.xml b/pulsar-sql/pom.xml
index 0336b16..279b6a1 100644
--- a/pulsar-sql/pom.xml
+++ b/pulsar-sql/pom.xml
@@ -25,7 +25,7 @@
     <parent>
         <groupId>org.apache.pulsar</groupId>
         <artifactId>pulsar</artifactId>
-        <version>2.9.1</version>
+        <version>2.9.2-SNAPSHOT</version>
     </parent>
 
     <artifactId>pulsar-sql</artifactId>
diff --git a/pulsar-sql/presto-distribution/pom.xml b/pulsar-sql/presto-distribution/pom.xml
index 211d457..3909652 100644
--- a/pulsar-sql/presto-distribution/pom.xml
+++ b/pulsar-sql/presto-distribution/pom.xml
@@ -25,7 +25,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar-sql</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
   </parent>
 
   <artifactId>pulsar-presto-distribution</artifactId>
diff --git a/pulsar-sql/presto-pulsar-plugin/pom.xml b/pulsar-sql/presto-pulsar-plugin/pom.xml
index cc91cb5..c7a81a2 100644
--- a/pulsar-sql/presto-pulsar-plugin/pom.xml
+++ b/pulsar-sql/presto-pulsar-plugin/pom.xml
@@ -25,7 +25,7 @@
     <parent>
         <groupId>org.apache.pulsar</groupId>
         <artifactId>pulsar-sql</artifactId>
-        <version>2.9.1</version>
+        <version>2.9.2-SNAPSHOT</version>
     </parent>
 
     <artifactId>pulsar-presto-connector</artifactId>
diff --git a/pulsar-sql/presto-pulsar/pom.xml b/pulsar-sql/presto-pulsar/pom.xml
index 0afa345..7e81449 100644
--- a/pulsar-sql/presto-pulsar/pom.xml
+++ b/pulsar-sql/presto-pulsar/pom.xml
@@ -25,7 +25,7 @@
     <parent>
         <groupId>org.apache.pulsar</groupId>
         <artifactId>pulsar-sql</artifactId>
-        <version>2.9.1</version>
+        <version>2.9.2-SNAPSHOT</version>
     </parent>
 
     <artifactId>pulsar-presto-connector-original</artifactId>
diff --git a/pulsar-testclient/pom.xml b/pulsar-testclient/pom.xml
index 2d21778..15bc57d 100644
--- a/pulsar-testclient/pom.xml
+++ b/pulsar-testclient/pom.xml
@@ -25,7 +25,7 @@
 	<parent>
 		<groupId>org.apache.pulsar</groupId>
 		<artifactId>pulsar</artifactId>
-		<version>2.9.1</version>
+		<version>2.9.2-SNAPSHOT</version>
 		<relativePath>..</relativePath>
 	</parent>
 
diff --git a/pulsar-transaction/common/pom.xml b/pulsar-transaction/common/pom.xml
index 7041918..9a86ac7 100644
--- a/pulsar-transaction/common/pom.xml
+++ b/pulsar-transaction/common/pom.xml
@@ -27,7 +27,7 @@
     <parent>
         <groupId>org.apache.pulsar</groupId>
         <artifactId>pulsar-transaction-parent</artifactId>
-        <version>2.9.1</version>
+        <version>2.9.2-SNAPSHOT</version>
     </parent>
 
     <artifactId>pulsar-transaction-common</artifactId>
diff --git a/pulsar-transaction/coordinator/pom.xml b/pulsar-transaction/coordinator/pom.xml
index cbe82db..be2b920 100644
--- a/pulsar-transaction/coordinator/pom.xml
+++ b/pulsar-transaction/coordinator/pom.xml
@@ -27,7 +27,7 @@
     <parent>
         <groupId>org.apache.pulsar</groupId>
         <artifactId>pulsar-transaction-parent</artifactId>
-        <version>2.9.1</version>
+        <version>2.9.2-SNAPSHOT</version>
     </parent>
 
     <artifactId>pulsar-transaction-coordinator</artifactId>
diff --git a/pulsar-transaction/pom.xml b/pulsar-transaction/pom.xml
index 93982b6..0d0d9a0 100644
--- a/pulsar-transaction/pom.xml
+++ b/pulsar-transaction/pom.xml
@@ -25,7 +25,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
   </parent>
 
   <artifactId>pulsar-transaction-parent</artifactId>
diff --git a/pulsar-websocket/pom.xml b/pulsar-websocket/pom.xml
index 373ce32..03be75f 100644
--- a/pulsar-websocket/pom.xml
+++ b/pulsar-websocket/pom.xml
@@ -25,7 +25,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
     <relativePath>..</relativePath>
   </parent>
 
diff --git a/pulsar-zookeeper-utils/pom.xml b/pulsar-zookeeper-utils/pom.xml
index fbb3708..f1b5c8f 100644
--- a/pulsar-zookeeper-utils/pom.xml
+++ b/pulsar-zookeeper-utils/pom.xml
@@ -25,7 +25,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
     <relativePath>..</relativePath>
   </parent>
 
diff --git a/structured-event-log/pom.xml b/structured-event-log/pom.xml
index 859a9f6..805f7f9 100644
--- a/structured-event-log/pom.xml
+++ b/structured-event-log/pom.xml
@@ -25,7 +25,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
     <relativePath>..</relativePath>
   </parent>
 
diff --git a/testmocks/pom.xml b/testmocks/pom.xml
index 1babdf1..267ba52 100644
--- a/testmocks/pom.xml
+++ b/testmocks/pom.xml
@@ -25,7 +25,7 @@
   <parent>
     <artifactId>pulsar</artifactId>
     <groupId>org.apache.pulsar</groupId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
   </parent>
 
   <artifactId>testmocks</artifactId>
diff --git a/tests/bc_2_0_0/pom.xml b/tests/bc_2_0_0/pom.xml
index c6a80c0..3ed771e 100644
--- a/tests/bc_2_0_0/pom.xml
+++ b/tests/bc_2_0_0/pom.xml
@@ -25,7 +25,7 @@
     <parent>
         <groupId>org.apache.pulsar.tests</groupId>
         <artifactId>tests-parent</artifactId>
-        <version>2.9.1</version>
+        <version>2.9.2-SNAPSHOT</version>
     </parent>
 
     <artifactId>bc_2_0_0</artifactId>
diff --git a/tests/bc_2_0_1/pom.xml b/tests/bc_2_0_1/pom.xml
index 4364c18..fe187e0 100644
--- a/tests/bc_2_0_1/pom.xml
+++ b/tests/bc_2_0_1/pom.xml
@@ -25,7 +25,7 @@
     <parent>
         <groupId>org.apache.pulsar.tests</groupId>
         <artifactId>tests-parent</artifactId>
-        <version>2.9.1</version>
+        <version>2.9.2-SNAPSHOT</version>
     </parent>
 
     <artifactId>bc_2_0_1</artifactId>
diff --git a/tests/bc_2_6_0/pom.xml b/tests/bc_2_6_0/pom.xml
index 40b4ea3..a0f682a 100644
--- a/tests/bc_2_6_0/pom.xml
+++ b/tests/bc_2_6_0/pom.xml
@@ -25,7 +25,7 @@
     <parent>
         <groupId>org.apache.pulsar.tests</groupId>
         <artifactId>tests-parent</artifactId>
-        <version>2.9.1</version>
+        <version>2.9.2-SNAPSHOT</version>
     </parent>
     <modelVersion>4.0.0</modelVersion>
 
diff --git a/tests/docker-images/java-test-functions/pom.xml b/tests/docker-images/java-test-functions/pom.xml
index f02d10e..d632fa4 100644
--- a/tests/docker-images/java-test-functions/pom.xml
+++ b/tests/docker-images/java-test-functions/pom.xml
@@ -23,7 +23,7 @@
   <parent>
     <groupId>org.apache.pulsar.tests</groupId>
     <artifactId>docker-images</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
   </parent>
   <modelVersion>4.0.0</modelVersion>
   <artifactId>java-test-functions</artifactId>
diff --git a/tests/docker-images/java-test-image/pom.xml b/tests/docker-images/java-test-image/pom.xml
index 626eb5f..be94489 100644
--- a/tests/docker-images/java-test-image/pom.xml
+++ b/tests/docker-images/java-test-image/pom.xml
@@ -23,7 +23,7 @@
   <parent>
     <groupId>org.apache.pulsar.tests</groupId>
     <artifactId>docker-images</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
   </parent>
   <modelVersion>4.0.0</modelVersion>
   <artifactId>java-test-image</artifactId>
diff --git a/tests/docker-images/latest-version-image/pom.xml b/tests/docker-images/latest-version-image/pom.xml
index 5bee911..9ec7712 100644
--- a/tests/docker-images/latest-version-image/pom.xml
+++ b/tests/docker-images/latest-version-image/pom.xml
@@ -23,7 +23,7 @@
   <parent>
     <groupId>org.apache.pulsar.tests</groupId>
     <artifactId>docker-images</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
   </parent>
   <modelVersion>4.0.0</modelVersion>
   <artifactId>latest-version-image</artifactId>
diff --git a/tests/docker-images/pom.xml b/tests/docker-images/pom.xml
index 2ac23ba..02fad58 100644
--- a/tests/docker-images/pom.xml
+++ b/tests/docker-images/pom.xml
@@ -27,7 +27,7 @@
   <parent>
     <groupId>org.apache.pulsar.tests</groupId>
     <artifactId>tests-parent</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
   </parent>
   <artifactId>docker-images</artifactId>
   <name>Apache Pulsar :: Tests :: Docker Images</name>
diff --git a/tests/integration/pom.xml b/tests/integration/pom.xml
index dcbaa8f..48646fa 100644
--- a/tests/integration/pom.xml
+++ b/tests/integration/pom.xml
@@ -25,7 +25,7 @@
   <parent>
     <groupId>org.apache.pulsar.tests</groupId>
     <artifactId>tests-parent</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
   </parent>
 
   <artifactId>integration</artifactId>
diff --git a/tests/pom.xml b/tests/pom.xml
index 5eef28b..cfe68cd 100644
--- a/tests/pom.xml
+++ b/tests/pom.xml
@@ -26,7 +26,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
   </parent>
   <groupId>org.apache.pulsar.tests</groupId>
   <artifactId>tests-parent</artifactId>
diff --git a/tests/pulsar-client-admin-shade-test/pom.xml b/tests/pulsar-client-admin-shade-test/pom.xml
index 2a4d3c7..08fd384 100644
--- a/tests/pulsar-client-admin-shade-test/pom.xml
+++ b/tests/pulsar-client-admin-shade-test/pom.xml
@@ -26,7 +26,7 @@
     <parent>
         <groupId>org.apache.pulsar.tests</groupId>
         <artifactId>tests-parent</artifactId>
-        <version>2.9.1</version>
+        <version>2.9.2-SNAPSHOT</version>
     </parent>
 
     <artifactId>pulsar-client-admin-shade-test</artifactId>
diff --git a/tests/pulsar-client-all-shade-test/pom.xml b/tests/pulsar-client-all-shade-test/pom.xml
index 7fc147f..573c6cc 100644
--- a/tests/pulsar-client-all-shade-test/pom.xml
+++ b/tests/pulsar-client-all-shade-test/pom.xml
@@ -26,7 +26,7 @@
     <parent>
         <groupId>org.apache.pulsar.tests</groupId>
         <artifactId>tests-parent</artifactId>
-        <version>2.9.1</version>
+        <version>2.9.2-SNAPSHOT</version>
     </parent>
 
     <artifactId>pulsar-client-all-shade-test</artifactId>
diff --git a/tests/pulsar-client-shade-test/pom.xml b/tests/pulsar-client-shade-test/pom.xml
index 9ed80c8..92560ec 100644
--- a/tests/pulsar-client-shade-test/pom.xml
+++ b/tests/pulsar-client-shade-test/pom.xml
@@ -27,7 +27,7 @@
     <parent>
         <groupId>org.apache.pulsar.tests</groupId>
         <artifactId>tests-parent</artifactId>
-        <version>2.9.1</version>
+        <version>2.9.2-SNAPSHOT</version>
     </parent>
 
     <artifactId>pulsar-client-shade-test</artifactId>
diff --git a/tiered-storage/file-system/pom.xml b/tiered-storage/file-system/pom.xml
index b0c394c..9dc2963 100644
--- a/tiered-storage/file-system/pom.xml
+++ b/tiered-storage/file-system/pom.xml
@@ -25,7 +25,7 @@
     <parent>
         <groupId>org.apache.pulsar</groupId>
         <artifactId>tiered-storage-parent</artifactId>
-        <version>2.9.1</version>
+        <version>2.9.2-SNAPSHOT</version>
         <relativePath>..</relativePath>
     </parent>
 
diff --git a/tiered-storage/jcloud/pom.xml b/tiered-storage/jcloud/pom.xml
index f221b7d..4913bd8 100644
--- a/tiered-storage/jcloud/pom.xml
+++ b/tiered-storage/jcloud/pom.xml
@@ -25,7 +25,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>tiered-storage-parent</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
     <relativePath>..</relativePath>
   </parent>
 
diff --git a/tiered-storage/pom.xml b/tiered-storage/pom.xml
index e4e935b..2abd509 100644
--- a/tiered-storage/pom.xml
+++ b/tiered-storage/pom.xml
@@ -25,7 +25,7 @@
   <parent>
     <groupId>org.apache.pulsar</groupId>
     <artifactId>pulsar</artifactId>
-    <version>2.9.1</version>
+    <version>2.9.2-SNAPSHOT</version>
     <relativePath>..</relativePath>
   </parent>
 

[pulsar] 02/03: Fix ProxyServiceStarterTest flaky tests (#12344)

Posted by lh...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

lhotari pushed a commit to branch branch-2.9
in repository https://gitbox.apache.org/repos/asf/pulsar.git

commit ae1b29adc430dcd91c11254f5a523e3462f07f59
Author: Nicolò Boschi <bo...@gmail.com>
AuthorDate: Thu Oct 21 18:06:49 2021 +0200

    Fix ProxyServiceStarterTest flaky tests (#12344)
    
    * Fix ProxyServiceStarterTest flaky tests
    
    * revert formatting
    
    * use ephimeral port
    
    (cherry picked from commit 7ad46c8c18bb8365c9a2d1233a6cd58ecd6f541f)
---
 .../apache/pulsar/proxy/server/ProxyServiceStarter.java  |  5 +++++
 .../pulsar/proxy/server/ProxyServiceStarterTest.java     | 16 +++++++++++-----
 2 files changed, 16 insertions(+), 5 deletions(-)

diff --git a/pulsar-proxy/src/main/java/org/apache/pulsar/proxy/server/ProxyServiceStarter.java b/pulsar-proxy/src/main/java/org/apache/pulsar/proxy/server/ProxyServiceStarter.java
index c16844c..315607e 100644
--- a/pulsar-proxy/src/main/java/org/apache/pulsar/proxy/server/ProxyServiceStarter.java
+++ b/pulsar-proxy/src/main/java/org/apache/pulsar/proxy/server/ProxyServiceStarter.java
@@ -313,6 +313,11 @@ public class ProxyServiceStarter {
         return config;
     }
 
+    @VisibleForTesting
+    public WebServer getServer() {
+        return server;
+    }
+
     private static final Logger log = LoggerFactory.getLogger(ProxyServiceStarter.class);
 
 }
diff --git a/pulsar-proxy/src/test/java/org/apache/pulsar/proxy/server/ProxyServiceStarterTest.java b/pulsar-proxy/src/test/java/org/apache/pulsar/proxy/server/ProxyServiceStarterTest.java
index 3377ec2..bdba8d3 100644
--- a/pulsar-proxy/src/test/java/org/apache/pulsar/proxy/server/ProxyServiceStarterTest.java
+++ b/pulsar-proxy/src/test/java/org/apache/pulsar/proxy/server/ProxyServiceStarterTest.java
@@ -59,7 +59,8 @@ public class ProxyServiceStarterTest extends MockedPulsarServiceBaseTest {
         serviceStarter = new ProxyServiceStarter(ARGS);
         serviceStarter.getConfig().setBrokerServiceURL(pulsar.getBrokerServiceUrl());
         serviceStarter.getConfig().setBrokerWebServiceURL(pulsar.getWebServiceAddress());
-        serviceStarter.getConfig().setServicePort(Optional.of(11000));
+        serviceStarter.getConfig().setWebServicePort(Optional.of(0));
+        serviceStarter.getConfig().setServicePort(Optional.of(0));
         serviceStarter.getConfig().setWebSocketServiceEnabled(true);
         serviceStarter.start();
     }
@@ -71,14 +72,19 @@ public class ProxyServiceStarterTest extends MockedPulsarServiceBaseTest {
         serviceStarter.close();
     }
 
+    private String computeWsBasePath() {
+        return String.format("ws://localhost:%d/ws", serviceStarter.getServer().getListenPortHTTP().get());
+    }
+
     @Test
     public void testEnableWebSocketServer() throws Exception {
         HttpClient httpClient = new HttpClient();
         WebSocketClient webSocketClient = new WebSocketClient(httpClient);
         webSocketClient.start();
         MyWebSocket myWebSocket = new MyWebSocket();
-        String webSocketUri = "ws://localhost:8080/ws/pingpong";
+        String webSocketUri = computeWsBasePath() + "/pingpong";
         Future<Session> sessionFuture = webSocketClient.connect(myWebSocket, URI.create(webSocketUri));
+        System.out.println("uri" + webSocketUri);
         sessionFuture.get().getRemote().sendPing(ByteBuffer.wrap("ping".getBytes()));
         assertTrue(myWebSocket.getResponse().contains("ping"));
     }
@@ -86,7 +92,7 @@ public class ProxyServiceStarterTest extends MockedPulsarServiceBaseTest {
     @Test
     public void testProducer() throws Exception {
         @Cleanup
-        PulsarClient client = PulsarClient.builder().serviceUrl("pulsar://localhost:11000")
+        PulsarClient client = PulsarClient.builder().serviceUrl("pulsar://localhost:" + this.pulsar.getBrokerService().getListenPort().get())
                 .build();
 
         @Cleanup
@@ -105,7 +111,7 @@ public class ProxyServiceStarterTest extends MockedPulsarServiceBaseTest {
         WebSocketClient producerWebSocketClient = new WebSocketClient(producerClient);
         producerWebSocketClient.start();
         MyWebSocket producerSocket = new MyWebSocket();
-        String produceUri = "ws://localhost:8080/ws/producer/persistent/sample/test/local/websocket-topic";
+        String produceUri = computeWsBasePath() + "/producer/persistent/sample/test/local/websocket-topic";
         Future<Session> producerSession = producerWebSocketClient.connect(producerSocket, URI.create(produceUri));
 
         ProducerMessage produceRequest = new ProducerMessage();
@@ -116,7 +122,7 @@ public class ProxyServiceStarterTest extends MockedPulsarServiceBaseTest {
         WebSocketClient consumerWebSocketClient = new WebSocketClient(consumerClient);
         consumerWebSocketClient.start();
         MyWebSocket consumerSocket = new MyWebSocket();
-        String consumeUri = "ws://localhost:8080/ws/consumer/persistent/sample/test/local/websocket-topic/my-sub";
+        String consumeUri = computeWsBasePath() + "/consumer/persistent/sample/test/local/websocket-topic/my-sub";
         Future<Session> consumerSession = consumerWebSocketClient.connect(consumerSocket, URI.create(consumeUri));
         consumerSession.get().getRemote().sendPing(ByteBuffer.wrap("ping".getBytes()));
         producerSession.get().getRemote().sendString(ObjectMapperFactory.getThreadLocal().writeValueAsString(produceRequest));