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/02 00:59:11 UTC

[pulsar] branch master updated: [feature][website] remove website build workflow due to it had been migrated to repo pulsar-site (#15645)

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

urfree pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/pulsar.git


The following commit(s) were added to refs/heads/master by this push:
     new 46fb5bfe7de [feature][website] remove website build workflow due to it had been migrated to repo pulsar-site (#15645)
46fb5bfe7de is described below

commit 46fb5bfe7deaf16197a00ed743ce2f6064941d54
Author: Li Li <ur...@apache.org>
AuthorDate: Thu Jun 2 08:59:00 2022 +0800

    [feature][website] remove website build workflow due to it had been migrated to repo pulsar-site (#15645)
---
 .github/workflows/ci-pulsar-website-build.yaml | 86 --------------------------
 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 ----------------
 9 files changed, 537 deletions(-)

diff --git a/.github/workflows/ci-pulsar-website-build.yaml b/.github/workflows/ci-pulsar-website-build.yaml
deleted file mode 100644
index be412d3aa73..00000000000
--- a/.github/workflows/ci-pulsar-website-build.yaml
+++ /dev/null
@@ -1,86 +0,0 @@
-#
-# 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.
-#
-
-name: CI - Pulsar Website build
-on:
-  schedule:
-    - cron: '0 */6 * * *'
-
-env:
-  MAVEN_OPTS: -Dhttp.keepAlive=false -Dmaven.wagon.http.pool=false -Dmaven.wagon.http.retryHandler.class=standard -Dmaven.wagon.http.retryHandler.count=3
-
-jobs:
-  build-website:
-    if: ${{ github.repository == 'apache/pulsar' }}
-    name: Build and publish pulsar website
-    runs-on: ubuntu-latest
-    timeout-minutes: 180
-    steps:
-      - name: checkout
-        uses: actions/checkout@v2
-
-      - name: Tune Runner VM
-        uses: ./.github/actions/tune-runner-vm
-
-      - name: Cache local Maven repository
-        uses: actions/cache@v2
-        with:
-          path: |
-            ~/.m2/repository/*/*/*
-            !~/.m2/repository/org/apache/pulsar
-          key: ${{ runner.os }}-m2-dependencies-website-${{ hashFiles('**/pom.xml') }}
-          restore-keys: |
-            ${{ runner.os }}-m2-dependencies-all-${{ hashFiles('**/pom.xml') }}
-            ${{ runner.os }}-m2-dependencies-core-modules-${{ hashFiles('**/pom.xml') }}
-            ${{ runner.os }}-m2-dependencies-core-modules-
-
-      - name: Set up JDK 17
-        uses: actions/setup-java@v2
-        with:
-          distribution: 'temurin'
-          java-version: 17
-
-      - name: clean disk
-        run: |
-          sudo rm -rf /usr/share/dotnet /usr/local/lib/android /opt/ghc
-          sudo apt clean
-          docker rmi $(docker images -q) -f
-          df -h
-
-      - name: run install by skip tests
-        run: mvn -q -B -ntp install -Pcore-modules,-main -DskipTests -DskipSourceReleaseAssembly=true -Dspotbugs.skip=true -Dlicense.skip=true
-
-      - name: generate swagger json file
-        run: mvn -B -ntp -pl pulsar-broker install -DskipTests -Pswagger
-
-      - name: publish
-        env:
-          GH_TOKEN: ${{ secrets.PULSARBOT_TOKEN }}
-          CROWDIN_DOCUSAURUS_API_KEY: ${{ secrets.PULSAR_CROWDIN_DOCUSAURUS_API_KEY }}
-        run: |
-          export CROWDIN_DOCUSAURUS_PROJECT_ID=apache-pulsar
-          echo "Copying swagger json file ..."
-          mkdir -p site2/website/static/swagger/master/
-          cp pulsar-broker/target/docs/swagger*.json site2/website/static/swagger/master
-          echo "Copied swagger json file."
-          echo "Building Website"
-          # Build the new website
-          site2/tools/docker-build-site.sh
-          # Script was initially made for travis
-          bash -e site2/tools/publish-website.sh
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
-
-