You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@pulsar.apache.org by ur...@apache.org on 2022/06/01 03:35:54 UTC

[pulsar] branch fix/remove-website-build-workflow created (now 043c0859be8)

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

urfree pushed a change to branch fix/remove-website-build-workflow
in repository https://gitbox.apache.org/repos/asf/pulsar.git


      at 043c0859be8 update

This branch includes the following new commits:

     new f8d2d97a8fb Merge branch 'master' into fix/remove-website-build-workflow
     new 043c0859be8 update

The 2 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.



[pulsar] 01/02: Merge branch 'master' into fix/remove-website-build-workflow

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

urfree pushed a commit to branch fix/remove-website-build-workflow
in repository https://gitbox.apache.org/repos/asf/pulsar.git

commit f8d2d97a8fbd0cd171d1fc722654daa88e32c4e2
Merge: fff34b118ae 01d7bfa681b
Author: Li Li <ur...@apache.org>
AuthorDate: Wed Jun 1 11:30:21 2022 +0800

    Merge branch 'master' into fix/remove-website-build-workflow

 .github/PULL_REQUEST_TEMPLATE.md                   |   4 +-
 .github/workflows/ci-owasp-dependency-check.yaml   |  10 +
 .gitignore                                         |   1 +
 .../wrapper/maven-wrapper.properties               |  21 +-
 README.md                                          |   3 +
 bin/pulsar                                         |   2 +-
 bin/pulsar-daemon                                  |   7 +-
 buildtools/pom.xml                                 |   2 +-
 conf/bkenv.sh                                      |   5 +-
 conf/broker.conf                                   |  10 +-
 conf/pulsar_env.sh                                 |   5 +-
 conf/standalone.conf                               |   6 +-
 distribution/server/src/assemble/LICENSE.bin.txt   |  52 +-
 docker/pulsar/Dockerfile                           |  10 +-
 .../bookkeeper/mledger/ManagedLedgerConfig.java    |   9 +
 .../bookkeeper/mledger/impl/ManagedCursorImpl.java |  14 +-
 .../bookkeeper/mledger/impl/RangeSetWrapper.java   | 165 ++++++
 .../apache/bookkeeper/mledger/util/RangeCache.java |  12 +-
 .../bookkeeper/mledger/impl/ManagedLedgerTest.java |  29 ++
 .../mledger/impl/RangeSetWrapperTest.java          | 512 ++++++++++++++++++
 .../bookkeeper/mledger/util/RangeCacheTest.java    |  29 +-
 mvnw                                               | 316 +++++++++++
 mvnw.cmd                                           | 188 +++++++
 pom.xml                                            |  22 +-
 .../apache/pulsar/broker/ServiceConfiguration.java |  21 +-
 .../pulsar/broker/resources/ClusterResources.java  |  12 +
 .../broker/resources/NamespaceResources.java       |  15 +
 .../pulsar/broker/resources/PulsarResources.java   |   3 +-
 pulsar-broker/pom.xml                              |   6 +
 .../org/apache/pulsar/PulsarBrokerStarter.java     |   2 +
 .../java/org/apache/pulsar/PulsarStandalone.java   | 150 ++++--
 .../org/apache/pulsar/PulsarStandaloneBuilder.java |   8 -
 .../org/apache/pulsar/PulsarStandaloneStarter.java |  22 +-
 .../org/apache/pulsar/broker/PulsarService.java    |  19 +-
 .../pulsar/broker/admin/impl/ClustersBase.java     | 577 +++++++++------------
 .../pulsar/broker/admin/impl/NamespacesBase.java   | 161 +++---
 .../broker/admin/impl/PersistentTopicsBase.java    |  39 +-
 .../broker/admin/impl/ResourceQuotasBase.java      | 123 ++---
 .../broker/admin/impl/SchemasResourceBase.java     |  30 +-
 .../apache/pulsar/broker/admin/v1/Namespaces.java  |  69 ++-
 .../pulsar/broker/admin/v1/PersistentTopics.java   |   3 +-
 .../pulsar/broker/admin/v1/ResourceQuotas.java     |  63 ++-
 .../apache/pulsar/broker/admin/v2/Namespaces.java  | 117 +++--
 .../pulsar/broker/admin/v2/PersistentTopics.java   |  56 +-
 .../pulsar/broker/admin/v2/ResourceQuotas.java     |  64 ++-
 .../pulsar/broker/loadbalance/ResourceUnit.java    |   5 +
 .../impl/ModularLoadManagerWrapper.java            |  14 +-
 .../loadbalance/impl/SimpleResourceUnit.java       |  22 +-
 .../pulsar/broker/namespace/NamespaceService.java  |  24 +-
 .../pulsar/broker/service/AbstractTopic.java       | 100 +++-
 .../pulsar/broker/service/BrokerService.java       |  13 +-
 .../apache/pulsar/broker/service/ServerCnx.java    |  50 +-
 .../apache/pulsar/broker/service/Subscription.java |   2 +
 .../org/apache/pulsar/broker/service/Topic.java    |   2 +-
 .../nonpersistent/NonPersistentSubscription.java   |  10 +-
 .../service/nonpersistent/NonPersistentTopic.java  |  16 +-
 .../service/persistent/MessageDeduplication.java   |   2 +-
 .../service/persistent/PersistentSubscription.java |   1 +
 .../broker/service/persistent/PersistentTopic.java |  58 ++-
 .../ReplicatedSubscriptionsController.java         |   2 +-
 .../buffer/impl/TopicTransactionBuffer.java        |  72 ++-
 .../pendingack/impl/PendingAckHandleImpl.java      |  49 +-
 .../apache/pulsar/compaction/CompactorTool.java    |   4 +-
 .../pulsar/broker/EmbeddedPulsarCluster.java       |   5 +-
 .../apache/pulsar/broker/admin/AdminApi2Test.java  |  74 ++-
 .../broker/admin/AdminApiDelayedDelivery.java      |   2 -
 .../broker/admin/AdminApiMaxUnackedMessages.java   |   2 -
 .../pulsar/broker/admin/AdminApiOffloadTest.java   |   2 -
 .../pulsar/broker/admin/AdminApiSchemaTest.java    |  23 +
 .../broker/admin/AdminApiSubscriptionTest.java     |  69 +++
 .../apache/pulsar/broker/admin/AdminApiTest.java   |   4 +-
 .../org/apache/pulsar/broker/admin/AdminTest.java  |  32 +-
 .../broker/admin/MaxUnackedMessagesTest.java       |   2 -
 .../apache/pulsar/broker/admin/NamespacesTest.java |  41 ++
 .../pulsar/broker/admin/NamespacesV2Test.java      | 162 ++++++
 .../pulsar/broker/admin/PersistentTopicsTest.java  |   2 +-
 .../pulsar/broker/admin/TopicMessageTTLTest.java   |   3 -
 .../broker/admin/TopicPoliciesDisableTest.java     |   1 -
 .../pulsar/broker/admin/TopicPoliciesTest.java     |   2 -
 .../pulsar/broker/admin/v1/V1_AdminApi2Test.java   |   2 +
 .../pulsar/broker/admin/v1/V1_AdminApiTest.java    |   2 +
 .../broker/admin/v3/AdminApiTransactionTest.java   |   1 -
 .../broker/intercept/BrokerInterceptorTest.java    |   2 +
 .../loadbalance/AdvertisedListenersTest.java       |  18 +-
 .../RGUsageMTAggrWaitForAllMsgsTest.java           |   6 +-
 .../broker/service/BacklogQuotaManagerTest.java    |   2 +
 .../broker/service/BrokerBookieIsolationTest.java  |   2 +
 .../BrokerServiceAutoTopicCreationTest.java        |   2 -
 .../pulsar/broker/service/BrokerServiceTest.java   |   2 +
 .../pulsar/broker/service/BrokerTestBase.java      |   6 +
 .../broker/service/ExclusiveProducerTest.java      | 102 +++-
 .../broker/service/InactiveTopicDeleteTest.java    |   9 -
 .../PersistentDispatcherFailoverConsumerTest.java  |   2 +
 .../broker/service/PersistentTopicE2ETest.java     |   6 +-
 .../pulsar/broker/service/PersistentTopicTest.java |   2 +
 .../PrecisTopicPublishRateThrottleTest.java        |   2 -
 .../broker/service/ReplicatorRateLimiterTest.java  |   2 -
 .../pulsar/broker/service/ReplicatorTestBase.java  |   2 -
 .../service/ReplicatorTopicPoliciesTest.java       |   6 -
 .../pulsar/broker/service/ServerCnxTest.java       | 147 ++++++
 .../pulsar/broker/service/SubscribeRateTest.java   |   2 -
 .../SystemTopicBasedTopicPoliciesServiceTest.java  |   2 -
 .../service/persistent/DelayedDeliveryTest.java    |   2 -
 .../service/persistent/MessageDuplicationTest.java |   7 +
 .../PersistentTopicStreamingDispatcherTest.java    |   2 +
 .../service/persistent/TopicDuplicationTest.java   |   4 -
 .../broker/stats/LedgerOffloaderMetricsTest.java   |   2 +-
 .../broker/stats/ManagedCursorMetricsTest.java     |   2 +
 .../pulsar/broker/stats/PrometheusMetricsTest.java |   4 +-
 .../broker/stats/TransactionMetricsTest.java       |  10 +
 .../systopic/PartitionedSystemTopicTest.java       |  67 ++-
 .../pulsar/broker/transaction/TransactionTest.java |   2 +-
 .../broker/transaction/TransactionTestBase.java    |   2 -
 .../buffer/TransactionLowWaterMarkTest.java        | 141 ++++-
 .../pendingack/PendingAckPersistentTest.java       |  21 +-
 .../api/AuthorizationProducerConsumerTest.java     |   2 -
 .../client/api/NonDurableSubscriptionTest.java     |   2 +
 .../apache/pulsar/client/api/SimpleSchemaTest.java |  52 +-
 .../apache/pulsar/client/impl/LookupRetryTest.java |   2 +
 .../common/naming/ServiceConfigurationTest.java    |   2 +-
 .../pulsar/compaction/CompactionRetentionTest.java |   2 -
 .../worker/PulsarFunctionLocalRunTest.java         |   2 +
 .../java/org/apache/pulsar/schema/SchemaTest.java  |  17 +-
 ...hemaTypeCompatibilityCheckOnTopicLevelTest.java |   3 -
 .../org/apache/pulsar/client/admin/Topics.java     |  84 ++-
 .../pulsar/client/admin/internal/TopicsImpl.java   |  54 +-
 .../pulsar/client/api/ProducerAccessMode.java      |   6 +
 .../apache/pulsar/client/api/ProducerBuilder.java  |   2 +
 pulsar-client-cpp/include/pulsar/Result.h          |   2 +
 pulsar-client-cpp/include/pulsar/c/result.h        |   3 +-
 pulsar-client-cpp/lib/BlockingQueue.h              | 155 +-----
 pulsar-client-cpp/lib/ClientImpl.cc                |   2 +
 pulsar-client-cpp/lib/ConsumerImpl.cc              |  11 +-
 pulsar-client-cpp/lib/ExecutorService.cc           |   4 +-
 pulsar-client-cpp/lib/Future.h                     |  20 +
 pulsar-client-cpp/lib/MemoryLimitController.cc     |  15 +-
 pulsar-client-cpp/lib/MemoryLimitController.h      |   5 +-
 pulsar-client-cpp/lib/MultiTopicsConsumerImpl.cc   |   9 +-
 pulsar-client-cpp/lib/PartitionedConsumerImpl.cc   |   3 +-
 pulsar-client-cpp/lib/ProducerImpl.cc              |  18 +-
 pulsar-client-cpp/lib/Result.cc                    |   3 +
 pulsar-client-cpp/lib/Semaphore.cc                 |  16 +-
 pulsar-client-cpp/lib/Semaphore.h                  |   5 +-
 pulsar-client-cpp/lib/UnboundedBlockingQueue.h     |  27 +-
 pulsar-client-cpp/pulsar-test-service-start.sh     |   1 -
 pulsar-client-cpp/python/CMakeLists.txt            |   4 +-
 pulsar-client-cpp/python/build-mac-wheels.sh       |   8 +-
 pulsar-client-cpp/python/setup.py                  |   2 +-
 pulsar-client-cpp/python/src/client.cc             |  61 +--
 pulsar-client-cpp/python/src/consumer.cc           |  46 +-
 pulsar-client-cpp/python/src/enums.cc              |   3 +-
 pulsar-client-cpp/python/src/exceptions.cc         |  11 +-
 pulsar-client-cpp/python/src/producer.cc           |  20 +-
 pulsar-client-cpp/python/src/pulsar.cc             |   1 -
 pulsar-client-cpp/python/src/reader.cc             |  29 +-
 .../python/src/utils.cc                            |  39 +-
 pulsar-client-cpp/python/src/utils.h               |  33 ++
 pulsar-client-cpp/test-conf/standalone-ssl.conf    |   2 +-
 pulsar-client-cpp/test-conf/standalone.conf        |   2 +-
 pulsar-client-cpp/tests/BlockingQueueTest.cc       | 113 ++--
 pulsar-client-cpp/tests/ProducerTest.cc            |   1 +
 pulsar-client-cpp/tests/SemaphoreTest.cc           |  23 +-
 .../tests/UnboundedBlockingQueueTest.cc            | 178 +++++++
 .../apache/pulsar/admin/cli/CmdFunctionsTest.java  |  39 +-
 .../pulsar/admin/cli/PulsarAdminToolTest.java      |  28 +-
 .../java/org/apache/pulsar/admin/cli/CmdBase.java  |  20 +
 .../org/apache/pulsar/admin/cli/CmdFunctions.java  |  12 +-
 .../org/apache/pulsar/admin/cli/CmdNamespaces.java |  37 +-
 .../pulsar/admin/cli/CmdPersistentTopics.java      |   9 +-
 .../apache/pulsar/admin/cli/CmdTopicPolicies.java  |  21 +-
 .../org/apache/pulsar/admin/cli/CmdTopics.java     |  79 +--
 .../apache/pulsar/client/impl/ConsumerBase.java    |  10 +-
 .../pulsar/client/impl/MemoryLimitController.java  |  14 +-
 .../org/apache/pulsar/client/impl/MessageImpl.java |  26 +-
 .../pulsar/client/impl/ProducerBuilderImpl.java    |  10 +-
 .../apache/pulsar/client/impl/ProducerImpl.java    |  11 +-
 .../pulsar/client/impl/ProducerResponse.java       |  14 +-
 .../pulsar/client/impl/PulsarClientImpl.java       |  13 +-
 .../apache/pulsar/client/impl/ResetCursorData.java |  10 +-
 .../impl/schema/generic/GenericJsonReader.java     |  16 +-
 .../pulsar/client/impl/ClientTestFixtures.java     |  23 +-
 .../pulsar/client/impl/ConnectionTimeoutTest.java  |  61 ++-
 .../client/impl/MultiTopicsConsumerImplTest.java   |  52 +-
 .../client/impl/ProducerBuilderImplTest.java       |  11 +
 pulsar-common/pom.xml                              |   2 -
 .../org/apache/pulsar/common/naming/Metadata.java  |  13 +-
 .../policies/data/HierarchyTopicPolicies.java      |   3 +
 .../pulsar/common/policies/data/TopicPolicies.java |   6 +
 .../apache/pulsar/common/protocol/Commands.java    |   6 +-
 .../org/apache/pulsar/common/util/FutureUtil.java  |  11 +
 pulsar-common/src/main/proto/PulsarApi.proto       |   1 +
 .../apache/pulsar/common/naming/MetadataTests.java |  21 +-
 .../pulsar/functions/instance/InstanceUtils.java   |   4 +-
 .../src/scripts/run_python_instance_tests.sh       |   2 +-
 .../functions/api/examples/UserConfigFunction.java |   8 +-
 .../runtime/thread/ThreadRuntimeFactoryTest.java   |   5 +-
 .../functions/worker/PulsarWorkerService.java      |  50 +-
 .../pulsar/functions/worker/WorkerUtils.java       |   5 +-
 pulsar-io/batch-data-generator/pom.xml             |   2 +-
 pulsar-io/batch-discovery-triggerers/pom.xml       |   2 +-
 pulsar-io/canal/pom.xml                            |   1 -
 .../io/elasticsearch/ElasticSearchConfig.java      |   7 +
 .../pulsar/io/elasticsearch/ElasticSearchSink.java |  44 +-
 .../pulsar/io/elasticsearch/JsonConverter.java     |  20 +-
 .../elasticsearch/ElasticSearchExtractTests.java   | 140 +++++
 .../io/elasticsearch/JsonConverterTests.java       |  12 +
 .../pulsar/io/jdbc/BaseJdbcAutoSchemaSink.java     |  88 +++-
 .../apache/pulsar/io/jdbc/JdbcAbstractSink.java    |   8 +-
 pulsar-io/jdbc/sqlite/pom.xml                      |   5 +
 .../apache/pulsar/io/jdbc/SqliteJdbcSinkTest.java  | 140 ++++-
 .../pulsar/io/kinesis/json/JsonConverter.java      |  17 +-
 .../pulsar/metadata/api/MetadataStoreConfig.java   |   2 +
 .../pulsar/metadata/api/MetadataStoreFactory.java  |   4 +
 .../pulsar/metadata/bookkeeper/BKCluster.java      |  86 ++-
 .../coordination/impl/CoordinationServiceImpl.java |   7 +-
 .../metadata/impl/MetadataStoreFactoryImpl.java    |   8 +
 .../pulsar/metadata/bookkeeper/EndToEndTest.java   |   9 +-
 pulsar-sql/presto-distribution/LICENSE             |  50 +-
 .../decoder/json/PulsarJsonFieldDecoder.java       |  22 +
 .../decoder/json/PulsarJsonRowDecoderFactory.java  |  11 +-
 .../sql/presto/decoder/avro/TestAvroDecoder.java   |  13 +-
 .../sql/presto/decoder/json/TestJsonDecoder.java   |  20 +
 .../Oauth2PerformanceTransactionTest.java          |   1 -
 .../testclient/PerformanceTransactionTest.java     |   2 +-
 .../apache/pulsar/websocket/WebSocketService.java  |   2 +
 site2/.gitignore                                   |   3 +-
 site2/docs/adaptors-kafka.md                       |  56 +-
 site2/docs/admin-api-brokers.md                    |  46 +-
 site2/docs/admin-api-clusters.md                   |  54 +-
 site2/docs/admin-api-functions.md                  |  90 ++--
 site2/docs/admin-api-namespaces.md                 |  80 +--
 site2/docs/admin-api-overview.md                   |  10 +-
 site2/docs/admin-api-packages.md                   |  46 +-
 site2/docs/admin-api-permissions.md                |  16 +-
 site2/docs/admin-api-tenants.md                    |  44 +-
 site2/docs/admin-api-topics.md                     | 180 +++----
 site2/docs/administration-geo.md                   |  10 +-
 site2/docs/administration-isolation.md             |  22 +-
 site2/docs/administration-pulsar-manager.md        |   4 +-
 site2/docs/administration-zk-bk.md                 |   4 +-
 site2/docs/client-libraries-java.md                |  14 +-
 site2/docs/client-libraries-node.md                |   2 +-
 site2/docs/client-libraries-python.md              |   2 +-
 site2/docs/client-libraries-websocket.md           |  14 +-
 site2/docs/client-libraries.md                     |  10 +-
 site2/docs/concepts-architecture-overview.md       |   6 +-
 site2/docs/concepts-messaging.md                   |  24 +-
 site2/docs/concepts-multi-tenancy.md               |   2 +-
 site2/docs/concepts-overview.md                    |   2 +-
 site2/docs/concepts-proxy-sni-routing.md           |   2 +-
 site2/docs/concepts-tiered-storage.md              |   2 +-
 site2/docs/cookbooks-compaction.md                 |   2 +-
 site2/docs/cookbooks-deduplication.md              |   4 +-
 site2/docs/cookbooks-non-persistent.md             |   2 +-
 site2/docs/cookbooks-retention-expiry.md           |  34 +-
 site2/docs/deploy-bare-metal-multi-cluster.md      |   4 +-
 site2/docs/deploy-bare-metal.md                    |   6 +-
 site2/docs/deploy-monitoring.md                    |   4 +-
 site2/docs/develop-binary-protocol.md              |   8 +
 site2/docs/developing-binary-protocol.md           |  14 +-
 site2/docs/functions-debug.md                      |   4 +-
 site2/docs/functions-deploy.md                     |  18 +-
 site2/docs/functions-develop.md                    |  28 +-
 site2/docs/functions-overview.md                   |   4 +-
 site2/docs/functions-package.md                    |   2 +-
 site2/docs/functions-worker.md                     |   7 +-
 site2/docs/getting-started-helm.md                 |   2 +-
 site2/docs/getting-started-pulsar.md               |   2 +-
 site2/docs/getting-started-standalone.md           |   6 +-
 site2/docs/io-cli.md                               |   8 +
 site2/docs/io-debug.md                             |   2 +-
 site2/docs/io-elasticsearch-sink.md                |   1 +
 site2/docs/io-kafka-source.md                      |   4 +-
 site2/docs/io-overview.md                          |   8 +-
 site2/docs/io-quickstart.md                        |  46 +-
 site2/docs/io-use.md                               | 139 +++--
 site2/docs/kubernetes-helm.md                      |   2 +-
 site2/docs/performance-pulsar-perf.md              |   4 +-
 site2/docs/reference-cli-tools.md                  |   4 +-
 site2/docs/reference-configuration.md              |  14 +-
 site2/docs/reference-connector-admin.md            |   2 +-
 site2/docs/reference-pulsar-admin.md               |   4 +-
 site2/docs/reference-rest-api-overview.md          |  10 +-
 site2/docs/schema-evolution-compatibility.md       |  32 +-
 site2/docs/schema-manage.md                        |  36 +-
 site2/docs/schema-understand.md                    |   2 +-
 site2/docs/security-athenz.md                      |   2 +-
 site2/docs/security-authorization.md               |   2 +-
 site2/docs/security-basic-auth.md                  | 127 +++++
 site2/docs/security-encryption.md                  |   4 +-
 site2/docs/security-extending.md                   |  22 +-
 site2/docs/security-jwt.md                         |   4 +-
 site2/docs/security-overview.md                    |   4 +-
 site2/docs/security-tls-authentication.md          |   4 +-
 site2/docs/standalone.md                           |   6 +-
 site2/docs/tiered-storage-aliyun.md                |  12 +-
 site2/docs/tiered-storage-aws.md                   |  10 +-
 site2/docs/tiered-storage-azure.md                 |  10 +-
 site2/docs/tiered-storage-filesystem.md            |   8 +-
 site2/docs/tiered-storage-gcs.md                   |  10 +-
 site2/docs/tiered-storage-overview.md              |  17 +-
 site2/docs/txn-monitor.md                          |   4 +-
 site2/docs/txn-use.md                              |   2 +-
 site2/docs/txn-what.md                             |   2 +-
 site2/docs/txn-why.md                              |   2 +-
 site2/website/pulsar-manager-release-notes.md      |  14 +
 site2/website/pulsar-manager-release.json          |   1 +
 site2/website/sidebars.json                        |   4 +-
 site2/website/start.sh                             |   7 +-
 .../version-2.1.1-incubating/administration-geo.md |  17 -
 .../version-2.1.1-incubating/concepts-overview.md  |   2 +-
 .../version-2.10.0/concepts-overview.md            |   2 +-
 .../versioned_docs/version-2.10.0/io-cli.md        |   8 +
 .../versioned_docs/version-2.10.0/io-overview.md   |   5 +-
 .../versioned_docs/version-2.10.0/io-quickstart.md |  46 +-
 .../versioned_docs/version-2.10.0/io-use.md        |  46 +-
 .../version-2.10.0/schema-understand.md            |   2 +-
 .../version-2.10.0/security-basic-auth.md          | 127 +++++
 .../version-2.10.0/security-overview.md            |   2 +-
 .../version-2.10.0/tiered-storage-filesystem.md    |   1 +
 .../version-2.10.0/tiered-storage-overview.md      |  11 +-
 .../version-2.2.0/administration-geo.md            |  17 -
 .../version-2.2.0/concepts-overview.md             |   2 +-
 .../version-2.2.1/administration-geo.md            |  17 -
 .../version-2.3.0/administration-geo.md            |  17 -
 .../version-2.3.1/administration-geo.md            |  17 -
 .../version-2.3.2/concepts-overview.md             |   2 +-
 .../version-2.4.0/concepts-overview.md             |   2 +-
 .../version-2.4.1/concepts-overview.md             |   2 +-
 .../version-2.4.1/schema-understand.md             |   2 +-
 .../version-2.4.2/concepts-overview.md             |   2 +-
 .../version-2.4.2/schema-understand.md             |   2 +-
 .../version-2.5.0/concepts-overview.md             |   2 +-
 .../version-2.5.0/schema-understand.md             |   2 +-
 .../version-2.5.1/concepts-overview.md             |   2 +-
 .../version-2.5.1/schema-understand.md             |   2 +-
 .../version-2.5.2/concepts-overview.md             |   2 +-
 .../version-2.5.2/schema-understand.md             |   2 +-
 .../version-2.6.0/concepts-overview.md             |   2 +-
 .../version-2.6.0/schema-understand.md             |   2 +-
 .../version-2.6.1/concepts-overview.md             |   2 +-
 .../version-2.6.1/schema-understand.md             |   2 +-
 .../version-2.6.2/concepts-overview.md             |   2 +-
 .../version-2.6.2/schema-understand.md             |   2 +-
 .../version-2.6.3/concepts-overview.md             |   2 +-
 .../version-2.6.3/schema-understand.md             |   2 +-
 .../version-2.6.4/concepts-overview.md             |   2 +-
 .../version-2.6.4/schema-understand.md             |   2 +-
 .../version-2.7.0/concepts-overview.md             |   2 +-
 .../version-2.7.0/functions-worker.md              |   5 +-
 .../version-2.7.0/schema-understand.md             |   2 +-
 .../version-2.7.0/tiered-storage-overview.md       |   5 +-
 .../version-2.7.1/concepts-overview.md             |   2 +-
 .../version-2.7.1/functions-worker.md              |   5 +-
 .../version-2.7.1/schema-understand.md             |   2 +-
 .../version-2.7.2/concepts-overview.md             |   2 +-
 .../version-2.7.2/functions-worker.md              |   5 +-
 .../version-2.7.2/schema-understand.md             |   2 +-
 .../version-2.7.2/tiered-storage-overview.md       |   5 +-
 .../version-2.7.3/concepts-overview.md             |   2 +-
 .../version-2.7.3/functions-worker.md              |   5 +-
 .../version-2.7.3/schema-understand.md             |   2 +-
 .../version-2.7.3/tiered-storage-overview.md       |   5 +-
 .../version-2.7.4/concepts-overview.md             |   2 +-
 .../version-2.7.4/functions-worker.md              |   5 +-
 .../version-2.7.4/schema-understand.md             |   2 +-
 .../version-2.7.4/tiered-storage-overview.md       |   5 +-
 .../version-2.8.0/concepts-overview.md             |   2 +-
 .../version-2.8.0/functions-worker.md              |   5 +-
 .../version-2.8.0/schema-understand.md             |   2 +-
 .../version-2.8.0/security-basic-auth.md           | 127 +++++
 .../version-2.8.0/security-overview.md             |   3 +-
 .../version-2.8.0/tiered-storage-overview.md       |   5 +-
 .../version-2.8.1/concepts-overview.md             |   2 +-
 .../version-2.8.1/functions-worker.md              |   5 +-
 .../version-2.8.1/schema-understand.md             |   2 +-
 .../version-2.8.1/security-basic-auth.md           | 127 +++++
 .../version-2.8.1/security-overview.md             |   3 +-
 .../version-2.8.1/tiered-storage-overview.md       |   5 +-
 .../version-2.8.2/concepts-overview.md             |   2 +-
 .../version-2.8.2/functions-worker.md              |   5 +-
 .../version-2.8.2/schema-understand.md             |   2 +-
 .../version-2.8.2/security-basic-auth.md           | 127 +++++
 .../version-2.8.2/security-overview.md             |   3 +-
 .../version-2.8.2/tiered-storage-overview.md       |   9 +-
 .../version-2.8.3/concepts-overview.md             |   2 +-
 .../version-2.8.3/functions-worker.md              |   5 +-
 .../version-2.8.3/schema-understand.md             |   2 +-
 .../version-2.8.3/security-basic-auth.md           | 127 +++++
 .../version-2.8.3/security-overview.md             |   3 +-
 .../version-2.8.3/tiered-storage-overview.md       |   9 +-
 .../version-2.9.0/concepts-overview.md             |   2 +-
 .../version-2.9.0/functions-worker.md              |   5 +-
 .../version-2.9.0/schema-understand.md             |   2 +-
 .../version-2.9.0/security-basic-auth.md           | 127 +++++
 .../version-2.9.0/security-overview.md             |   3 +-
 .../version-2.9.0/tiered-storage-overview.md       |  11 +-
 .../version-2.9.1/administration-geo.md            |  17 -
 .../version-2.9.1/concepts-overview.md             |   2 +-
 .../version-2.9.1/functions-worker.md              |   5 +-
 .../version-2.9.1/schema-understand.md             |   2 +-
 .../version-2.9.1/security-basic-auth.md           | 127 +++++
 .../version-2.9.1/security-overview.md             |   3 +-
 .../version-2.9.1/tiered-storage-overview.md       |   9 +-
 .../version-2.9.2/administration-geo.md            |  17 -
 .../version-2.9.2/concepts-overview.md             |   2 +-
 .../version-2.9.2/schema-understand.md             |   2 +-
 .../version-2.9.2/security-basic-auth.md           | 127 +++++
 .../version-2.9.2/security-overview.md             |   2 +
 .../version-2.9.2/tiered-storage-overview.md       |  11 +-
 .../version-2.10.0-sidebars.json                   |   8 +-
 .../versioned_sidebars/version-2.8.0-sidebars.json |   4 +
 .../versioned_sidebars/version-2.8.1-sidebars.json |   4 +
 .../versioned_sidebars/version-2.8.2-sidebars.json |   4 +
 .../versioned_sidebars/version-2.8.3-sidebars.json |   4 +
 .../versioned_sidebars/version-2.9.0-sidebars.json |   4 +
 .../versioned_sidebars/version-2.9.1-sidebars.json |   4 +
 .../versioned_sidebars/version-2.9.2-sidebars.json |   4 +
 src/owasp-dependency-check-false-positives.xml     |   9 +
 .../java/org/apache/zookeeper/MockZooKeeper.java   |   6 +
 .../pulsar/tests/integration/cli/CLITest.java      |  25 +
 .../cli/ClusterMetadataTearDownTest.java           |   6 +
 .../io/sinks/ElasticSearchSinkTester.java          |  23 +-
 .../io/sinks/JdbcPostgresSinkTester.java           |  88 +++-
 .../integration/io/sinks/KinesisSinkTester.java    |  26 +-
 .../integration/io/sinks/PulsarIOSinkRunner.java   |   2 +-
 .../integration/io/sinks/PulsarSinksTest.java      |   6 +-
 .../integration/messaging/GeoReplicationTest.java  |  18 +-
 .../topologies/PulsarStandaloneTestBase.java       |   3 +-
 .../jcloud/provider/JCloudBlobStoreProvider.java   |  54 +-
 .../provider/TieredStorageConfiguration.java       |  13 +
 .../provider/JCloudBlobStoreProviderTests.java     |  31 +-
 .../provider/TieredStorageConfigurationTests.java  |  17 +
 433 files changed, 7660 insertions(+), 2645 deletions(-)


[pulsar] 02/02: update

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

urfree pushed a commit to branch fix/remove-website-build-workflow
in repository https://gitbox.apache.org/repos/asf/pulsar.git

commit 043c0859be86dba36e180fa64552a28a74983efb
Author: Li Li <ur...@apache.org>
AuthorDate: Wed Jun 1 11:35:41 2022 +0800

    update
    
    Signed-off-by: Li Li <ur...@apache.org>
---
 site2/tools/build-site.sh            | 82 ------------------------------------
 site2/tools/debug-site.sh            | 31 --------------
 site2/tools/docker-build-site.sh     | 50 ----------------------
 site2/tools/publish-website.sh       | 50 ----------------------
 site2/tools/pulsar-admin-doc-gen.sh  | 70 ------------------------------
 site2/tools/pulsar-client-doc-gen.sh | 52 -----------------------
 site2/tools/pulsar-doc-gen.sh        | 64 ----------------------------
 site2/tools/pulsar-perf-doc-gen.sh   | 52 -----------------------
 8 files changed, 451 deletions(-)

diff --git a/site2/tools/build-site.sh b/site2/tools/build-site.sh
deleted file mode 100755
index 1a23803e9c0..00000000000
--- a/site2/tools/build-site.sh
+++ /dev/null
@@ -1,82 +0,0 @@
-#!/usr/bin/env bash
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-
-ROOT_DIR=$(git rev-parse --show-toplevel)
-VERSION=$(${ROOT_DIR}/src/get-project-version.py)
-
-function workaround_crowdin_problem_by_copying_files() {
-  # TODO: remove this after figuring out why crowdin removed code tab when generating translated files
-  # https://github.com/apache/pulsar/issues/5816
-  node scripts/fix-tab.js 
-}
-
-
-set -x -e
-
-export NODE_OPTIONS="--max-old-space-size=4096" #increase to 4GB, default is 512MB
-${ROOT_DIR}/site2/tools/generate-api-docs.sh
-cd ${ROOT_DIR}/site2/website
-yarn
-yarn write-translations
-
-# The crowdin upload and download take a long time to run, and have resulted in timeouts. In order to ensure that the
-# website is still able to get published, we only run the download and upload if current hour is 0-5.
-# This leads to executing crowdin-upload and crowdin-download once per day when website build is scheduled
-# to run with cron expression '0 */6 * * *'
-CURRENT_HOUR=$(date +%H)
-if [[ "$CROWDIN_DOCUSAURUS_API_KEY" != "UNSET" || $CURRENT_HOUR -lt 6 ]]; then
-  # upload only if environment variable CROWDIN_UPLOAD=1 is set
-  if [[ "$CROWDIN_UPLOAD" == "1" ]]; then
-    yarn run crowdin-upload
-  fi
-  yarn run crowdin-download
-
-  workaround_crowdin_problem_by_copying_files
-else
-  # set English as the only language to build in this case
-  cat > languages.js <<'EOF'
-const languages = [
-{
-  enabled: true,
-  name: 'English',
-  tag: 'en',
-}];
-module.exports = languages;
-EOF
-fi
-
-yarn build
-
-node ./scripts/replace.js
-node ./scripts/split-swagger-by-version.js
-
-# Generate document for command line tools.
-${ROOT_DIR}/site2/tools/pulsar-admin-doc-gen.sh
-${ROOT_DIR}/site2/tools/pulsar-client-doc-gen.sh
-${ROOT_DIR}/site2/tools/pulsar-perf-doc-gen.sh
-${ROOT_DIR}/site2/tools/pulsar-doc-gen.sh
-cd ${ROOT_DIR}/site2/website
-
-rm -rf ${ROOT_DIR}/generated-site/content
-mkdir -p ${ROOT_DIR}/generated-site/content
-cp -R ${ROOT_DIR}/generated-site/api ${ROOT_DIR}/generated-site/content
-cp -R ./build/pulsar/* ${ROOT_DIR}/generated-site/content
-cp -R ${ROOT_DIR}/generated-site/tools ${ROOT_DIR}/generated-site/content
-cp -R ${ROOT_DIR}/site2/website/static/swagger/* ${ROOT_DIR}/generated-site/content/swagger/
diff --git a/site2/tools/debug-site.sh b/site2/tools/debug-site.sh
deleted file mode 100755
index e993bbfc8bf..00000000000
--- a/site2/tools/debug-site.sh
+++ /dev/null
@@ -1,31 +0,0 @@
-#!/usr/bin/env bash
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-
-ROOT_DIR=$(git rev-parse --show-toplevel)
-container_id=$(docker ps | grep pulsar-website-nginx | awk '{print $1}')
-
-if [ -n "$container_id" ]
-then
-docker rm -f $container_id
-fi
-
-docker run --name pulsar-website-nginx -p 80:80 -v $ROOT_DIR/generated-site/content:/usr/share/nginx/html:ro -d nginx
-
-echo "Website is running: http://localhost"
diff --git a/site2/tools/docker-build-site.sh b/site2/tools/docker-build-site.sh
deleted file mode 100755
index 702829122b0..00000000000
--- a/site2/tools/docker-build-site.sh
+++ /dev/null
@@ -1,50 +0,0 @@
-#!/usr/bin/env bash
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-
-# Build Pulsar website within a Docker container
-
-# Fail script in case of errors
-set -e
-
-ROOT_DIR=$(git rev-parse --show-toplevel)
-cd $ROOT_DIR/pulsar-client-cpp
-
-BUILD_IMAGE_NAME="${BUILD_IMAGE_NAME:-apachepulsar/pulsar-build}"
-BUILD_IMAGE_VERSION="${BUILD_IMAGE_VERSION:-ubuntu-16.04-pb3-website}"
-
-IMAGE="$BUILD_IMAGE_NAME:$BUILD_IMAGE_VERSION"
-
-echo "---- Build Pulsar website using image $IMAGE"
-
-#docker pull $IMAGE
-
-CI_USER=$(id -u)
-CI_GROUP=$(id -g)
-
-# crowdin keys
-CROWDIN_DOCUSAURUS_PROJECT_ID=${CROWDIN_DOCUSAURUS_PROJECT_ID:-"apache-pulsar"}
-CROWDIN_DOCUSAURUS_API_KEY=${CROWDIN_DOCUSAURUS_API_KEY:-UNSET}
-
-DOCKER_CMD="docker run -i -e CI_USER=$CI_USER -e CI_GROUP=$CI_GROUP -v $HOME/.m2:/root/.m2 -e CROWDIN_DOCUSAURUS_PROJECT_ID=${CROWDIN_DOCUSAURUS_PROJECT_ID} -e CROWDIN_DOCUSAURUS_API_KEY=${CROWDIN_DOCUSAURUS_API_KEY} -v $ROOT_DIR:/pulsar $IMAGE"
-
-sed -i "s#$ROOT_DIR#/pulsar#g" $ROOT_DIR/distribution/server/target/classpath.txt
-sed -i "s#$HOME#/root#g" $ROOT_DIR/distribution/server/target/classpath.txt
-
-$DOCKER_CMD bash -l -c 'export JAVA_HOME=/usr/lib/jvm/java-11-openjdk-amd64 && cd /pulsar && /pulsar/site2/tools/build-site.sh'
diff --git a/site2/tools/publish-website.sh b/site2/tools/publish-website.sh
deleted file mode 100755
index b9191d2691e..00000000000
--- a/site2/tools/publish-website.sh
+++ /dev/null
@@ -1,50 +0,0 @@
-#!/usr/bin/env bash
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-
-set -e
-
-ROOT_DIR=$(git rev-parse --show-toplevel)
-
-ORIGIN_REPO=$(git remote show origin | grep 'Push  URL' | awk -F// '{print $NF}')
-echo "ORIGIN_REPO: $ORIGIN_REPO"
-
-GENERATED_SITE_DIR=$ROOT_DIR/generated-site
-
-PULSAR_SITE_TMP=/tmp/pulsar-site
-(
-  cd $ROOT_DIR
-  REVISION=$(git rev-parse --short HEAD)
-
-  rm -rf $PULSAR_SITE_TMP
-  mkdir $PULSAR_SITE_TMP
-  cd $PULSAR_SITE_TMP
-
-  git clone --depth 1 -b asf-site "https://$GH_TOKEN@$ORIGIN_REPO" .
-  git config user.name "Pulsar Site Updater"
-  git config user.email "dev@pulsar.apache.org"
-  
-  # copy the apache generated dir
-  cp -r $GENERATED_SITE_DIR/content/* $PULSAR_SITE_TMP/content
-
-  git add -A .
-  git diff-index --quiet HEAD || (git commit -m "Updated site at revision $REVISION" && git push -q origin HEAD:asf-site)
-
-  rm -rf $PULSAR_SITE_TMP
-)
diff --git a/site2/tools/pulsar-admin-doc-gen.sh b/site2/tools/pulsar-admin-doc-gen.sh
deleted file mode 100755
index 37f0611ecbd..00000000000
--- a/site2/tools/pulsar-admin-doc-gen.sh
+++ /dev/null
@@ -1,70 +0,0 @@
-#!/usr/bin/env bash
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-
-ROOT_DIR=$(git rev-parse --show-toplevel)
-VERSION=`${ROOT_DIR}/src/get-project-version.py`
-DEST_DIR=$ROOT_DIR/generated-site
-
-cd $ROOT_DIR
-
-mkdir -p $DEST_DIR/tools/pulsar-admin/${VERSION}
-mkdir -p $DEST_DIR/tools/pulsar-admin/${VERSION}/node_modules
-mkdir -p $ROOT_DIR/site2/website/brodocs/documents
-
-$ROOT_DIR/bin/pulsar-admin documents generate broker-stats > $ROOT_DIR/site2/website/brodocs/documents/broker-stats.md
-$ROOT_DIR/bin/pulsar-admin documents generate brokers > $ROOT_DIR/site2/website/brodocs/documents/brokers.md
-$ROOT_DIR/bin/pulsar-admin documents generate clusters > $ROOT_DIR/site2/website/brodocs/documents/clusters.md
-$ROOT_DIR/bin/pulsar-admin documents generate functions > $ROOT_DIR/site2/website/brodocs/documents/functions.md
-$ROOT_DIR/bin/pulsar-admin documents generate functions-worker > $ROOT_DIR/site2/website/brodocs/documents/functions-worker.md
-$ROOT_DIR/bin/pulsar-admin documents generate namespaces > $ROOT_DIR/site2/website/brodocs/documents/namespaces.md
-$ROOT_DIR/bin/pulsar-admin documents generate ns-isolation-policy > $ROOT_DIR/site2/website/brodocs/documents/ns-isolation-policy.md
-$ROOT_DIR/bin/pulsar-admin documents generate sources > $ROOT_DIR/site2/website/brodocs/documents/sources.md
-$ROOT_DIR/bin/pulsar-admin documents generate sinks > $ROOT_DIR/site2/website/brodocs/documents/sinks.md
-$ROOT_DIR/bin/pulsar-admin documents generate topics > $ROOT_DIR/site2/website/brodocs/documents/topics.md
-$ROOT_DIR/bin/pulsar-admin documents generate topicPolicies > $ROOT_DIR/site2/website/brodocs/documents/topicPolicies.md
-$ROOT_DIR/bin/pulsar-admin documents generate proxy-stats > $ROOT_DIR/site2/website/brodocs/documents/proxy-stats.md
-$ROOT_DIR/bin/pulsar-admin documents generate resourcegroups > $ROOT_DIR/site2/website/brodocs/documents/resourcegroups.md
-$ROOT_DIR/bin/pulsar-admin documents generate transactions > $ROOT_DIR/site2/website/brodocs/documents/transactions.md
-$ROOT_DIR/bin/pulsar-admin documents generate tenants > $ROOT_DIR/site2/website/brodocs/documents/tenants.md
-$ROOT_DIR/bin/pulsar-admin documents generate resource-quotas > $ROOT_DIR/site2/website/brodocs/documents/resource-quotas.md
-$ROOT_DIR/bin/pulsar-admin documents generate schemas > $ROOT_DIR/site2/website/brodocs/documents/schemas.md
-$ROOT_DIR/bin/pulsar-admin documents generate packages > $ROOT_DIR/site2/website/brodocs/documents/packages.md
-$ROOT_DIR/bin/pulsar-admin documents generate bookies > $ROOT_DIR/site2/website/brodocs/documents/bookies.md
-
-cd $ROOT_DIR/site2/website/brodocs
-cp pulsar-admin-manifest.json manifest.json
-node brodoc.js
-
-cp index.html $DEST_DIR/tools/pulsar-admin/${VERSION}/
-cp navData.js stylesheet.css $DEST_DIR/tools/pulsar-admin/${VERSION}/
-cp scroll.js tabvisibility.js $DEST_DIR/tools/pulsar-admin/${VERSION}/
-cp favicon.ico $DEST_DIR/tools/pulsar-admin/${VERSION}/
-mkdir -p $DEST_DIR/tools/pulsar-admin/${VERSION}/node_modules/bootstrap/dist/css
-cp -r $ROOT_DIR/site2/website/node_modules/bootstrap/dist/css/bootstrap.min.css $DEST_DIR/tools/pulsar-admin/${VERSION}/node_modules/bootstrap/dist/css
-mkdir -p $DEST_DIR/tools/pulsar-admin/${VERSION}/node_modules/font-awesome/css
-cp -r $ROOT_DIR/site2/website/node_modules/font-awesome/css/font-awesome.min.css $DEST_DIR/tools/pulsar-admin/${VERSION}/node_modules/font-awesome/css
-mkdir -p $DEST_DIR/tools/pulsar-admin/${VERSION}/node_modules/highlight.js/styles
-cp -r $ROOT_DIR/site2/website/node_modules/highlight.js/styles/default.css $DEST_DIR/tools/pulsar-admin/${VERSION}/node_modules/highlight.js/styles
-mkdir -p $DEST_DIR/tools/pulsar-admin/${VERSION}/node_modules/jquery/dist
-cp -r $ROOT_DIR/site2/website/node_modules/jquery/dist/jquery.min.js $DEST_DIR/tools/pulsar-admin/${VERSION}/node_modules/jquery/dist/
-mkdir -p $DEST_DIR/tools/pulsar-admin/${VERSION}/node_modules/jquery.scrollto
-cp -r $ROOT_DIR/site2/website/node_modules/jquery.scrollto/jquery.scrollTo.min.js $DEST_DIR/tools/pulsar-admin/${VERSION}/node_modules/jquery.scrollto
-
-
diff --git a/site2/tools/pulsar-client-doc-gen.sh b/site2/tools/pulsar-client-doc-gen.sh
deleted file mode 100755
index 99b2b57cefb..00000000000
--- a/site2/tools/pulsar-client-doc-gen.sh
+++ /dev/null
@@ -1,52 +0,0 @@
-#!/usr/bin/env bash
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-
-ROOT_DIR=$(git rev-parse --show-toplevel)
-VERSION=`${ROOT_DIR}/src/get-project-version.py`
-DEST_DIR=$ROOT_DIR/generated-site
-
-cd $ROOT_DIR
-
-mkdir -p $DEST_DIR/tools/pulsar-client/${VERSION}
-mkdir -p $DEST_DIR/tools/pulsar-client/${VERSION}/node_modules
-mkdir -p $ROOT_DIR/site2/website/brodocs/documents
-
-$ROOT_DIR/bin/pulsar-client generate_documentation > $ROOT_DIR/site2/website/brodocs/documents/pulsar-client.md
-
-cd $ROOT_DIR/site2/website/brodocs
-cp pulsar-client-manifest.json manifest.json
-node brodoc.js
-
-cp index.html $DEST_DIR/tools/pulsar-client/${VERSION}/
-cp navData.js stylesheet.css $DEST_DIR/tools/pulsar-client/${VERSION}/
-cp scroll.js tabvisibility.js $DEST_DIR/tools/pulsar-client/${VERSION}/
-cp favicon.ico $DEST_DIR/tools/pulsar-client/${VERSION}/
-mkdir -p $DEST_DIR/tools/pulsar-client/${VERSION}/node_modules/bootstrap/dist/css
-cp -r $ROOT_DIR/site2/website/node_modules/bootstrap/dist/css/bootstrap.min.css $DEST_DIR/tools/pulsar-client/${VERSION}/node_modules/bootstrap/dist/css
-mkdir -p $DEST_DIR/tools/pulsar-client/${VERSION}/node_modules/font-awesome/css
-cp -r $ROOT_DIR/site2/website/node_modules/font-awesome/css/font-awesome.min.css $DEST_DIR/tools/pulsar-client/${VERSION}/node_modules/font-awesome/css
-mkdir -p $DEST_DIR/tools/pulsar-client/${VERSION}/node_modules/highlight.js/styles
-cp -r $ROOT_DIR/site2/website/node_modules/highlight.js/styles/default.css $DEST_DIR/tools/pulsar-client/${VERSION}/node_modules/highlight.js/styles
-mkdir -p $DEST_DIR/tools/pulsar-client/${VERSION}/node_modules/jquery/dist
-cp -r $ROOT_DIR/site2/website/node_modules/jquery/dist/jquery.min.js $DEST_DIR/tools/pulsar-client/${VERSION}/node_modules/jquery/dist/
-mkdir -p $DEST_DIR/tools/pulsar-client/${VERSION}/node_modules/jquery.scrollto
-cp -r $ROOT_DIR/site2/website/node_modules/jquery.scrollto/jquery.scrollTo.min.js $DEST_DIR/tools/pulsar-client/${VERSION}/node_modules/jquery.scrollto
-
-
diff --git a/site2/tools/pulsar-doc-gen.sh b/site2/tools/pulsar-doc-gen.sh
deleted file mode 100755
index 70cb0e28c31..00000000000
--- a/site2/tools/pulsar-doc-gen.sh
+++ /dev/null
@@ -1,64 +0,0 @@
-#!/usr/bin/env bash
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-
-ROOT_DIR=$(git rev-parse --show-toplevel)
-VERSION=`${ROOT_DIR}/src/get-project-version.py`
-DEST_DIR=$ROOT_DIR/generated-site
-
-cd $ROOT_DIR
-
-mkdir -p $DEST_DIR/tools/pulsar/${VERSION}
-mkdir -p $DEST_DIR/tools/pulsar/${VERSION}/node_modules
-mkdir -p $ROOT_DIR/site2/website/brodocs/documents
-
-$ROOT_DIR/bin/pulsar broker -g > $ROOT_DIR/site2/website/brodocs/documents/broker.md
-$ROOT_DIR/bin/pulsar broker-tool gen-doc > $ROOT_DIR/site2/website/brodocs/documents/broker-tool.md
-$ROOT_DIR/bin/pulsar compact-topic -t tmp -g > $ROOT_DIR/site2/website/brodocs/documents/compact-topic.md
-$ROOT_DIR/bin/pulsar tokens gen-doc > $ROOT_DIR/site2/website/brodocs/documents/tokens.md
-$ROOT_DIR/bin/pulsar proxy -g > $ROOT_DIR/site2/website/brodocs/documents/proxy.md
-$ROOT_DIR/bin/pulsar functions-worker -g > $ROOT_DIR/site2/website/brodocs/documents/functions-worker.md
-$ROOT_DIR/bin/pulsar standalone -g > $ROOT_DIR/site2/website/brodocs/documents/standalone.md
-$ROOT_DIR/bin/pulsar initialize-cluster-metadata -cs cs -uw uw -zk zk -c c -g > $ROOT_DIR/site2/website/brodocs/documents/initialize-cluster-metadata.md
-$ROOT_DIR/bin/pulsar delete-cluster-metadata -zk zk -g > $ROOT_DIR/site2/website/brodocs/documents/delete-cluster-metadata.md
-$ROOT_DIR/bin/pulsar initialize-transaction-coordinator-metadata -cs cs -c c -g > $ROOT_DIR/site2/website/brodocs/documents/initialize-transaction-coordinator-metadata.md
-$ROOT_DIR/bin/pulsar initialize-namespace -cs cs -c c -g demo > $ROOT_DIR/site2/website/brodocs/documents/initialize-namespace.md
-$ROOT_DIR/bin/pulsar version -g > $ROOT_DIR/site2/website/brodocs/documents/version.md
-$ROOT_DIR/bin/pulsar websocket -g > $ROOT_DIR/site2/website/brodocs/documents/websocket.md
-
-cd $ROOT_DIR/site2/website/brodocs
-cp pulsar-manifest.json manifest.json
-node brodoc.js
-
-cp index.html $DEST_DIR/tools/pulsar/${VERSION}/
-cp navData.js stylesheet.css $DEST_DIR/tools/pulsar/${VERSION}/
-cp scroll.js tabvisibility.js $DEST_DIR/tools/pulsar/${VERSION}/
-cp favicon.ico $DEST_DIR/tools/pulsar/${VERSION}/
-mkdir -p $DEST_DIR/tools/pulsar/${VERSION}/node_modules/bootstrap/dist/css
-cp -r $ROOT_DIR/site2/website/node_modules/bootstrap/dist/css/bootstrap.min.css $DEST_DIR/tools/pulsar/${VERSION}/node_modules/bootstrap/dist/css
-mkdir -p $DEST_DIR/tools/pulsar/${VERSION}/node_modules/font-awesome/css
-cp -r $ROOT_DIR/site2/website/node_modules/font-awesome/css/font-awesome.min.css $DEST_DIR/tools/pulsar/${VERSION}/node_modules/font-awesome/css
-mkdir -p $DEST_DIR/tools/pulsar/${VERSION}/node_modules/highlight.js/styles
-cp -r $ROOT_DIR/site2/website/node_modules/highlight.js/styles/default.css $DEST_DIR/tools/pulsar/${VERSION}/node_modules/highlight.js/styles
-mkdir -p $DEST_DIR/tools/pulsar/${VERSION}/node_modules/jquery/dist
-cp -r $ROOT_DIR/site2/website/node_modules/jquery/dist/jquery.min.js $DEST_DIR/tools/pulsar/${VERSION}/node_modules/jquery/dist/
-mkdir -p $DEST_DIR/tools/pulsar/${VERSION}/node_modules/jquery.scrollto
-cp -r $ROOT_DIR/site2/website/node_modules/jquery.scrollto/jquery.scrollTo.min.js $DEST_DIR/tools/pulsar/${VERSION}/node_modules/jquery.scrollto
-
-
diff --git a/site2/tools/pulsar-perf-doc-gen.sh b/site2/tools/pulsar-perf-doc-gen.sh
deleted file mode 100755
index ef44469fe1a..00000000000
--- a/site2/tools/pulsar-perf-doc-gen.sh
+++ /dev/null
@@ -1,52 +0,0 @@
-#!/usr/bin/env bash
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#   http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing,
-# software distributed under the License is distributed on an
-# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
-# KIND, either express or implied.  See the License for the
-# specific language governing permissions and limitations
-# under the License.
-#
-
-ROOT_DIR=$(git rev-parse --show-toplevel)
-VERSION=`${ROOT_DIR}/src/get-project-version.py`
-DEST_DIR=$ROOT_DIR/generated-site
-
-cd $ROOT_DIR
-
-mkdir -p $DEST_DIR/tools/pulsar-perf/${VERSION}
-mkdir -p $DEST_DIR/tools/pulsar-perf/${VERSION}/node_modules
-mkdir -p $ROOT_DIR/site2/website/brodocs/documents
-
-$ROOT_DIR/bin/pulsar-perf gen-doc > $ROOT_DIR/site2/website/brodocs/documents/pulsar-perf.md
-
-cd $ROOT_DIR/site2/website/brodocs
-cp pulsar-perf-manifest.json manifest.json
-node brodoc.js
-
-cp index.html $DEST_DIR/tools/pulsar-perf/${VERSION}/
-cp navData.js stylesheet.css $DEST_DIR/tools/pulsar-perf/${VERSION}/
-cp scroll.js tabvisibility.js $DEST_DIR/tools/pulsar-perf/${VERSION}/
-cp favicon.ico $DEST_DIR/tools/pulsar-perf/${VERSION}/
-mkdir -p $DEST_DIR/tools/pulsar-perf/${VERSION}/node_modules/bootstrap/dist/css
-cp -r $ROOT_DIR/site2/website/node_modules/bootstrap/dist/css/bootstrap.min.css $DEST_DIR/tools/pulsar-perf/${VERSION}/node_modules/bootstrap/dist/css
-mkdir -p $DEST_DIR/tools/pulsar-perf/${VERSION}/node_modules/font-awesome/css
-cp -r $ROOT_DIR/site2/website/node_modules/font-awesome/css/font-awesome.min.css $DEST_DIR/tools/pulsar-perf/${VERSION}/node_modules/font-awesome/css
-mkdir -p $DEST_DIR/tools/pulsar-perf/${VERSION}/node_modules/highlight.js/styles
-cp -r $ROOT_DIR/site2/website/node_modules/highlight.js/styles/default.css $DEST_DIR/tools/pulsar-perf/${VERSION}/node_modules/highlight.js/styles
-mkdir -p $DEST_DIR/tools/pulsar-perf/${VERSION}/node_modules/jquery/dist
-cp -r $ROOT_DIR/site2/website/node_modules/jquery/dist/jquery.min.js $DEST_DIR/tools/pulsar-perf/${VERSION}/node_modules/jquery/dist/
-mkdir -p $DEST_DIR/tools/pulsar-perf/${VERSION}/node_modules/jquery.scrollto
-cp -r $ROOT_DIR/site2/website/node_modules/jquery.scrollto/jquery.scrollTo.min.js $DEST_DIR/tools/pulsar-perf/${VERSION}/node_modules/jquery.scrollto
-
-