You are viewing a plain text version of this content. The canonical link for it is here.
Posted to dev@submarine.apache.org by ji...@apache.org on 2020/09/09 15:26:00 UTC

[submarine] branch master updated: SUBMARINE-620. Fix hard coding of shebang in some scripts

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

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


The following commit(s) were added to refs/heads/master by this push:
     new e7c75a7  SUBMARINE-620. Fix hard coding of shebang in some scripts
e7c75a7 is described below

commit e7c75a7d5657038463afb9225d75fd71e4545ed5
Author: Wanqiang Ji <ji...@apache.org>
AuthorDate: Mon Sep 7 23:56:26 2020 +0800

    SUBMARINE-620. Fix hard coding of shebang in some scripts
    
    ### What is this PR for?
    Fix hard coding of shebang in some scripts
    
    ### What type of PR is it?
    [Bug Fix]
    
    ### Todos
    
    ### What is the Jira issue?
    https://issues.apache.org/jira/browse/SUBMARINE-620
    
    ### Questions:
    * Does the licenses files need update? No
    * Is there breaking changes for older versions? No
    * Does this needs documentation? No
    
    Author: Wanqiang Ji <ji...@apache.org>
    
    Closes #397 from jiwq/SUBMARINE-620 and squashes the following commits:
    
    b6e2360 [Wanqiang Ji] SUBMARINE-620. Fix hard coding of shebang in some scripts
---
 bin/common.sh                                                         | 2 +-
 bin/submarine-daemon.sh                                               | 2 +-
 bin/submarine.sh                                                      | 2 +-
 conf/submarine-env.sh.template                                        | 2 +-
 dev-support/cicd/build_and_start_cicd_image.sh                        | 2 +-
 dev-support/cicd/common_release.sh                                    | 2 +-
 dev-support/cicd/create_release.sh                                    | 2 +-
 dev-support/cicd/entry.sh                                             | 2 +-
 dev-support/cicd/publish_release.sh                                   | 2 +-
 dev-support/docker-images/database/build.sh                           | 2 +-
 dev-support/docker-images/database/startup.sh                         | 2 +-
 dev-support/docker-images/jupyter/build.sh                            | 2 +-
 dev-support/docker-images/jupyter/start-notebook.sh                   | 2 +-
 dev-support/docker-images/operator/build.sh                           | 2 +-
 dev-support/docker-images/submarine/build.sh                          | 2 +-
 dev-support/k8s/deploy-kubeflow-operators.sh                          | 2 +-
 dev-support/k8s/deploy-notebook-controller.sh                         | 2 +-
 dev-support/k8s/pytorchjob/deploy-pytorch-operator.sh                 | 2 +-
 dev-support/mini-submarine/build_mini-submarine.sh                    | 2 +-
 dev-support/mini-submarine/conf/bootstrap.sh                          | 2 +-
 dev-support/mini-submarine/conf/setup-mysql.sh                        | 4 ++--
 dev-support/mini-submarine/conf/submarine-env.sh                      | 4 ++--
 dev-support/mini-submarine/conf/yarn-ds-docker.sh                     | 2 +-
 dev-support/mini-submarine/spark-script/run_gpu_ds.sh                 | 2 +-
 dev-support/mini-submarine/spark-script/run_pyspark.sh                | 2 +-
 dev-support/mini-submarine/spark-script/run_pyspark_docker.sh         | 2 +-
 dev-support/mini-submarine/spark-script/run_spark.sh                  | 2 +-
 dev-support/mini-submarine/spark-script/run_spark_docker.sh           | 2 +-
 dev-support/mini-submarine/submarine/build_python_virtual_env.sh      | 2 +-
 .../mini-submarine/submarine/run_customized_submarine-all_mnist.sh    | 2 +-
 dev-support/mini-submarine/submarine/run_submarine_mnist_tf2_tony.sh  | 2 +-
 dev-support/mini-submarine/submarine/run_submarine_mnist_tony.sh      | 2 +-
 dev-support/mini-submarine/submarine/run_submarine_mnist_tony_rpc.sh  | 2 +-
 .../mini-submarine/submarine/run_submarine_mxnet_cifar10_tony.sh      | 2 +-
 .../mini-submarine/submarine/run_submarine_pytorch_mnist_tony.sh      | 2 +-
 dev-support/pysubmarine/bootstrap.sh                                  | 2 +-
 dev-support/pysubmarine/gen-sdk.sh                                    | 2 +-
 .../package/hadoop/yarn/sbin/start-mr-jobhistory.sh                   | 2 +-
 .../package/hadoop/yarn/sbin/stop-mr-jobhistory.sh                    | 2 +-
 dev-support/submarine-installer/scripts/yarn.sh                       | 2 +-
 dev-support/submarine-installer/scripts/yarn_insecure.sh              | 2 +-
 dev-support/travis/install_external_dependencies.sh                   | 2 +-
 docs/database/init-database.sh                                        | 2 +-
 docs/ecosystem/kaldi/sge/gencfs.sh                                    | 2 +-
 docs/ecosystem/kaldi/sge/sge_run.sh                                   | 2 +-
 docs/userdocs/yarn/TestAndTroubleshooting.md                          | 2 +-
 submarine-cloud/build.sh                                              | 2 +-
 submarine-cloud/hack/deploy-submarine.sh                              | 2 +-
 submarine-cloud/hack/integration-test.sh                              | 2 +-
 .../server/submitter/yarnservice/command/LaunchScriptBuilder.java     | 2 +-
 .../submarine/client/cli/yarnservice/YarnServiceRunJobCliTest.java    | 2 +-
 .../yarnservice/command/AbstractTFLaunchCommandTestHelper.java        | 2 +-
 52 files changed, 54 insertions(+), 54 deletions(-)

diff --git a/bin/common.sh b/bin/common.sh
index 9f5f2ec..ecf9469 100755
--- a/bin/common.sh
+++ b/bin/common.sh
@@ -1,4 +1,4 @@
-#!/bin/bash
+#!/usr/bin/env bash
 #
 # Licensed to the Apache Software Foundation (ASF) under one or more
 # contributor license agreements.  See the NOTICE file distributed with
diff --git a/bin/submarine-daemon.sh b/bin/submarine-daemon.sh
index 319f4b6..f7fcdc8 100755
--- a/bin/submarine-daemon.sh
+++ b/bin/submarine-daemon.sh
@@ -1,4 +1,4 @@
-#!/bin/bash
+#!/usr/bin/env bash
 #
 # Licensed to the Apache Software Foundation (ASF) under one
 # or more contributor license agreements.  See the NOTICE file
diff --git a/bin/submarine.sh b/bin/submarine.sh
index 198a865..8a5d6e8 100755
--- a/bin/submarine.sh
+++ b/bin/submarine.sh
@@ -1,4 +1,4 @@
-#!/bin/bash
+#!/usr/bin/env bash
 #
 # Licensed to the Apache Software Foundation (ASF) under one
 # or more contributor license agreements.  See the NOTICE file
diff --git a/conf/submarine-env.sh.template b/conf/submarine-env.sh.template
index 5b66539..97ae1d8 100644
--- a/conf/submarine-env.sh.template
+++ b/conf/submarine-env.sh.template
@@ -1,4 +1,4 @@
-#!/bin/bash
+#!/usr/bin/env bash
 #
 # Licensed to the Apache Software Foundation (ASF) under one or more
 # contributor license agreements.  See the NOTICE file distributed with
diff --git a/dev-support/cicd/build_and_start_cicd_image.sh b/dev-support/cicd/build_and_start_cicd_image.sh
index 2447c2b..a43600f 100755
--- a/dev-support/cicd/build_and_start_cicd_image.sh
+++ b/dev-support/cicd/build_and_start_cicd_image.sh
@@ -1,4 +1,4 @@
-#!/bin/bash
+#!/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.
diff --git a/dev-support/cicd/common_release.sh b/dev-support/cicd/common_release.sh
index 995d6f4..517bc37 100755
--- a/dev-support/cicd/common_release.sh
+++ b/dev-support/cicd/common_release.sh
@@ -1,4 +1,4 @@
-#!/bin/bash
+#!/usr/bin/env bash
 
 #
 # Licensed to the Apache Software Foundation (ASF) under one or more
diff --git a/dev-support/cicd/create_release.sh b/dev-support/cicd/create_release.sh
index f4621d3..f49b24e 100755
--- a/dev-support/cicd/create_release.sh
+++ b/dev-support/cicd/create_release.sh
@@ -1,4 +1,4 @@
-#!/bin/bash
+#!/usr/bin/env bash
 
 #
 # Licensed to the Apache Software Foundation (ASF) under one or more
diff --git a/dev-support/cicd/entry.sh b/dev-support/cicd/entry.sh
index a6a1394..811683f 100755
--- a/dev-support/cicd/entry.sh
+++ b/dev-support/cicd/entry.sh
@@ -1,4 +1,4 @@
-#!/bin/bash
+#!/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.
diff --git a/dev-support/cicd/publish_release.sh b/dev-support/cicd/publish_release.sh
index 1a1ee90..91f6852 100755
--- a/dev-support/cicd/publish_release.sh
+++ b/dev-support/cicd/publish_release.sh
@@ -1,4 +1,4 @@
-#!/bin/bash
+#!/usr/bin/env bash
 #
 # Licensed to the Apache Software Foundation (ASF) under one or more
 # contributor license agreements.  See the NOTICE file distributed with
diff --git a/dev-support/docker-images/database/build.sh b/dev-support/docker-images/database/build.sh
index 7b463ba..cde8bf3 100755
--- a/dev-support/docker-images/database/build.sh
+++ b/dev-support/docker-images/database/build.sh
@@ -1,4 +1,4 @@
-#!/bin/bash
+#!/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.
diff --git a/dev-support/docker-images/database/startup.sh b/dev-support/docker-images/database/startup.sh
index 7fe0fd1..884fab6 100755
--- a/dev-support/docker-images/database/startup.sh
+++ b/dev-support/docker-images/database/startup.sh
@@ -1,4 +1,4 @@
-#!/bin/bash
+#!/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.
diff --git a/dev-support/docker-images/jupyter/build.sh b/dev-support/docker-images/jupyter/build.sh
index 977a6cc..ac0a3d8 100755
--- a/dev-support/docker-images/jupyter/build.sh
+++ b/dev-support/docker-images/jupyter/build.sh
@@ -1,4 +1,4 @@
-#!/bin/bash
+#!/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.
diff --git a/dev-support/docker-images/jupyter/start-notebook.sh b/dev-support/docker-images/jupyter/start-notebook.sh
index e39def5..62962fe 100755
--- a/dev-support/docker-images/jupyter/start-notebook.sh
+++ b/dev-support/docker-images/jupyter/start-notebook.sh
@@ -1,4 +1,4 @@
-#!/bin/bash
+#!/usr/bin/env bash
 #
 # Licensed to the Apache Software Foundation (ASF) under one
 # or more contributor license agreements.  See the NOTICE file
diff --git a/dev-support/docker-images/operator/build.sh b/dev-support/docker-images/operator/build.sh
index f015980..ce910fc 100755
--- a/dev-support/docker-images/operator/build.sh
+++ b/dev-support/docker-images/operator/build.sh
@@ -1,4 +1,4 @@
-#!/bin/bash
+#!/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.
diff --git a/dev-support/docker-images/submarine/build.sh b/dev-support/docker-images/submarine/build.sh
index 87f2ed5..db1c8a2 100755
--- a/dev-support/docker-images/submarine/build.sh
+++ b/dev-support/docker-images/submarine/build.sh
@@ -1,4 +1,4 @@
-#!/bin/bash
+#!/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.
diff --git a/dev-support/k8s/deploy-kubeflow-operators.sh b/dev-support/k8s/deploy-kubeflow-operators.sh
index 26ad872..43e27ee 100755
--- a/dev-support/k8s/deploy-kubeflow-operators.sh
+++ b/dev-support/k8s/deploy-kubeflow-operators.sh
@@ -1,4 +1,4 @@
-#!/bin/bash
+#!/usr/bin/env bash
 #
 # Licensed to the Apache Software Foundation (ASF) under one
 # or more contributor license agreements.  See the NOTICE file
diff --git a/dev-support/k8s/deploy-notebook-controller.sh b/dev-support/k8s/deploy-notebook-controller.sh
index d983ca5..159a249 100755
--- a/dev-support/k8s/deploy-notebook-controller.sh
+++ b/dev-support/k8s/deploy-notebook-controller.sh
@@ -1,4 +1,4 @@
-#!/bin/bash
+#!/usr/bin/env bash
 #
 # Licensed to the Apache Software Foundation (ASF) under one
 # or more contributor license agreements.  See the NOTICE file
diff --git a/dev-support/k8s/pytorchjob/deploy-pytorch-operator.sh b/dev-support/k8s/pytorchjob/deploy-pytorch-operator.sh
index 5eff1b4..07f7b07 100755
--- a/dev-support/k8s/pytorchjob/deploy-pytorch-operator.sh
+++ b/dev-support/k8s/pytorchjob/deploy-pytorch-operator.sh
@@ -1,4 +1,4 @@
-#!/bin/bash
+#!/usr/bin/env bash
 #
 # Licensed to the Apache Software Foundation (ASF) under one
 # or more contributor license agreements.  See the NOTICE file
diff --git a/dev-support/mini-submarine/build_mini-submarine.sh b/dev-support/mini-submarine/build_mini-submarine.sh
index 0c13b4a..819bab2 100755
--- a/dev-support/mini-submarine/build_mini-submarine.sh
+++ b/dev-support/mini-submarine/build_mini-submarine.sh
@@ -1,4 +1,4 @@
-#!/bin/bash
+#!/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.
diff --git a/dev-support/mini-submarine/conf/bootstrap.sh b/dev-support/mini-submarine/conf/bootstrap.sh
index 1b1077c..3152c6a 100755
--- a/dev-support/mini-submarine/conf/bootstrap.sh
+++ b/dev-support/mini-submarine/conf/bootstrap.sh
@@ -1,4 +1,4 @@
-#!/bin/bash
+#!/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.
diff --git a/dev-support/mini-submarine/conf/setup-mysql.sh b/dev-support/mini-submarine/conf/setup-mysql.sh
index 4ad211f..d59632b 100755
--- a/dev-support/mini-submarine/conf/setup-mysql.sh
+++ b/dev-support/mini-submarine/conf/setup-mysql.sh
@@ -1,4 +1,4 @@
-#!/bin/bash
+#!/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.
@@ -35,4 +35,4 @@ mysql -e "use metastore_test; source /home/yarn/database/metastore.sql;"
 mysql -e "CREATE DATABASE metastore;"
 mysql -e "CREATE USER 'metastore'@'%' IDENTIFIED BY 'password';"
 mysql -e "GRANT ALL PRIVILEGES ON * . * TO 'metastore'@'%';"
-mysql -e "use metastore; source /home/yarn/database/metastore.sql;"
\ No newline at end of file
+mysql -e "use metastore; source /home/yarn/database/metastore.sql;"
diff --git a/dev-support/mini-submarine/conf/submarine-env.sh b/dev-support/mini-submarine/conf/submarine-env.sh
index 87eb221..64ea565 100644
--- a/dev-support/mini-submarine/conf/submarine-env.sh
+++ b/dev-support/mini-submarine/conf/submarine-env.sh
@@ -1,4 +1,4 @@
-#!/bin/bash
+#!/usr/bin/env bash
 #
 # Licensed to the Apache Software Foundation (ASF) under one or more
 # contributor license agreements.  See the NOTICE file distributed with
@@ -26,4 +26,4 @@
 
 # Set Submarine server classpath. If you want to visit hdfs, just add hadoop
 # configuration path.
-export SUBMARINE_SERVER_CLASSPATH+=":/usr/local/hadoop/etc/hadoop"
\ No newline at end of file
+export SUBMARINE_SERVER_CLASSPATH+=":/usr/local/hadoop/etc/hadoop"
diff --git a/dev-support/mini-submarine/conf/yarn-ds-docker.sh b/dev-support/mini-submarine/conf/yarn-ds-docker.sh
index df1e3bc..5232e03 100755
--- a/dev-support/mini-submarine/conf/yarn-ds-docker.sh
+++ b/dev-support/mini-submarine/conf/yarn-ds-docker.sh
@@ -13,6 +13,6 @@
 # See the License for the specific language governing permissions and
 # limitations under the License.
 
-#!/bin/bash
+#!/usr/bin/env bash
 DS=/usr/local/hadoop/share/hadoop/yarn/hadoop-yarn-applications-distributedshell-${HADOOP_VER}.jar
 /usr/local/hadoop/bin/yarn jar ${DS} -jar ${DS} -shell_command "cat /proc/1/cgroup" -shell_env YARN_CONTAINER_RUNTIME_TYPE=docker -shell_env YARN_CONTAINER_RUNTIME_DOCKER_IMAGE=library/ubuntu
diff --git a/dev-support/mini-submarine/spark-script/run_gpu_ds.sh b/dev-support/mini-submarine/spark-script/run_gpu_ds.sh
index 04b0431..26321a4 100755
--- a/dev-support/mini-submarine/spark-script/run_gpu_ds.sh
+++ b/dev-support/mini-submarine/spark-script/run_gpu_ds.sh
@@ -13,7 +13,7 @@
 # See the License for the specific language governing permissions and
 # limitations under the License.
 
-#!/bin/bash
+#!/usr/bin/env bash
 
 #JAR_PATH=/usr/local/hadoop/share/hadoop/yarn/hadoop-yarn-applications-distributedshell-${HADOOP_VER}.jar
 
diff --git a/dev-support/mini-submarine/spark-script/run_pyspark.sh b/dev-support/mini-submarine/spark-script/run_pyspark.sh
index e399d9a..d834c87 100755
--- a/dev-support/mini-submarine/spark-script/run_pyspark.sh
+++ b/dev-support/mini-submarine/spark-script/run_pyspark.sh
@@ -13,7 +13,7 @@
 # See the License for the specific language governing permissions and
 # limitations under the License.
 
-#!/bin/bash
+#!/usr/bin/env bash
 SPARK_HOME=/opt/spark-${SPARK_VER}-bin-hadoop2.7
 ${SPARK_HOME}/bin/spark-submit \
 --master yarn \
diff --git a/dev-support/mini-submarine/spark-script/run_pyspark_docker.sh b/dev-support/mini-submarine/spark-script/run_pyspark_docker.sh
index db2106e..f4156c3 100755
--- a/dev-support/mini-submarine/spark-script/run_pyspark_docker.sh
+++ b/dev-support/mini-submarine/spark-script/run_pyspark_docker.sh
@@ -13,7 +13,7 @@
 # See the License for the specific language governing permissions and
 # limitations under the License.
 
-#!/bin/bash
+#!/usr/bin/env bash
 SPARK_HOME=/opt/spark-${SPARK_VER}-bin-hadoop2.7
 ${SPARK_HOME}/bin/spark-submit \
 --master yarn \
diff --git a/dev-support/mini-submarine/spark-script/run_spark.sh b/dev-support/mini-submarine/spark-script/run_spark.sh
index 550426f..f44b12c 100755
--- a/dev-support/mini-submarine/spark-script/run_spark.sh
+++ b/dev-support/mini-submarine/spark-script/run_spark.sh
@@ -13,7 +13,7 @@
 # See the License for the specific language governing permissions and
 # limitations under the License.
 
-#!/bin/bash
+#!/usr/bin/env bash
 
 SPARK_HOME=/opt/spark-${SPARK_VER}-bin-hadoop2.7
 ${SPARK_HOME}/bin/spark-submit --class org.apache.spark.examples.SparkPi \
diff --git a/dev-support/mini-submarine/spark-script/run_spark_docker.sh b/dev-support/mini-submarine/spark-script/run_spark_docker.sh
index 669041c..8b1078f 100755
--- a/dev-support/mini-submarine/spark-script/run_spark_docker.sh
+++ b/dev-support/mini-submarine/spark-script/run_spark_docker.sh
@@ -13,7 +13,7 @@
 # See the License for the specific language governing permissions and
 # limitations under the License.
 
-#!/bin/bash
+#!/usr/bin/env bash
 SPARK_HOME=/opt/spark-${SPARK_VER}-bin-hadoop2.7
 ${SPARK_HOME}/bin/spark-submit --class org.apache.spark.examples.SparkPi \
 --master yarn \
diff --git a/dev-support/mini-submarine/submarine/build_python_virtual_env.sh b/dev-support/mini-submarine/submarine/build_python_virtual_env.sh
index d441c0e..fcb9d14 100755
--- a/dev-support/mini-submarine/submarine/build_python_virtual_env.sh
+++ b/dev-support/mini-submarine/submarine/build_python_virtual_env.sh
@@ -13,7 +13,7 @@
 # See the License for the specific language governing permissions and
 # limitations under the License.
 
-#!/bin/bash
+#!/usr/bin/env bash
 wget https://files.pythonhosted.org/packages/33/bc/fa0b5347139cd9564f0d44ebd2b147ac97c36b2403943dbee8a25fd74012/virtualenv-16.0.0.tar.gz
 tar xf virtualenv-16.0.0.tar.gz
 
diff --git a/dev-support/mini-submarine/submarine/run_customized_submarine-all_mnist.sh b/dev-support/mini-submarine/submarine/run_customized_submarine-all_mnist.sh
index 138de0f..64646fc 100755
--- a/dev-support/mini-submarine/submarine/run_customized_submarine-all_mnist.sh
+++ b/dev-support/mini-submarine/submarine/run_customized_submarine-all_mnist.sh
@@ -13,7 +13,7 @@
 # See the License for the specific language governing permissions and
 # limitations under the License.
 
-#!/bin/bash
+#!/usr/bin/env bash
 
 # Need to modify environment variables based on version
 while [ $# -gt 0 ]; do
diff --git a/dev-support/mini-submarine/submarine/run_submarine_mnist_tf2_tony.sh b/dev-support/mini-submarine/submarine/run_submarine_mnist_tf2_tony.sh
index e969d8d..f029512 100755
--- a/dev-support/mini-submarine/submarine/run_submarine_mnist_tf2_tony.sh
+++ b/dev-support/mini-submarine/submarine/run_submarine_mnist_tf2_tony.sh
@@ -1,4 +1,4 @@
-#!/bin/bash
+#!/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.
diff --git a/dev-support/mini-submarine/submarine/run_submarine_mnist_tony.sh b/dev-support/mini-submarine/submarine/run_submarine_mnist_tony.sh
index 7b9e8ed..c6d0a4d 100755
--- a/dev-support/mini-submarine/submarine/run_submarine_mnist_tony.sh
+++ b/dev-support/mini-submarine/submarine/run_submarine_mnist_tony.sh
@@ -13,7 +13,7 @@
 # See the License for the specific language governing permissions and
 # limitations under the License.
 
-#!/bin/bash
+#!/usr/bin/env bash
 
 # Below are configurable variables, please adapt base on your local environment.
 # Version of submarine jar
diff --git a/dev-support/mini-submarine/submarine/run_submarine_mnist_tony_rpc.sh b/dev-support/mini-submarine/submarine/run_submarine_mnist_tony_rpc.sh
index d7d084b..f93973f 100644
--- a/dev-support/mini-submarine/submarine/run_submarine_mnist_tony_rpc.sh
+++ b/dev-support/mini-submarine/submarine/run_submarine_mnist_tony_rpc.sh
@@ -13,7 +13,7 @@
 # See the License for the specific language governing permissions and
 # limitations under the License.
 
-#!/bin/bash
+#!/usr/bin/env bash
 while [ $# -gt 0 ]; do
   case "$1" in
     --debug*)
diff --git a/dev-support/mini-submarine/submarine/run_submarine_mxnet_cifar10_tony.sh b/dev-support/mini-submarine/submarine/run_submarine_mxnet_cifar10_tony.sh
index bfc1626..0561e54 100755
--- a/dev-support/mini-submarine/submarine/run_submarine_mxnet_cifar10_tony.sh
+++ b/dev-support/mini-submarine/submarine/run_submarine_mxnet_cifar10_tony.sh
@@ -1,4 +1,4 @@
-#!/bin/bash
+#!/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.
diff --git a/dev-support/mini-submarine/submarine/run_submarine_pytorch_mnist_tony.sh b/dev-support/mini-submarine/submarine/run_submarine_pytorch_mnist_tony.sh
index d85dabc..b4a81e0 100755
--- a/dev-support/mini-submarine/submarine/run_submarine_pytorch_mnist_tony.sh
+++ b/dev-support/mini-submarine/submarine/run_submarine_pytorch_mnist_tony.sh
@@ -1,4 +1,4 @@
-#!/bin/bash
+#!/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.
diff --git a/dev-support/pysubmarine/bootstrap.sh b/dev-support/pysubmarine/bootstrap.sh
index bd240b2..d4e3105 100755
--- a/dev-support/pysubmarine/bootstrap.sh
+++ b/dev-support/pysubmarine/bootstrap.sh
@@ -1,4 +1,4 @@
-#!/bin/bash
+#!/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.
diff --git a/dev-support/pysubmarine/gen-sdk.sh b/dev-support/pysubmarine/gen-sdk.sh
index 3afc89a..4647e76 100755
--- a/dev-support/pysubmarine/gen-sdk.sh
+++ b/dev-support/pysubmarine/gen-sdk.sh
@@ -1,4 +1,4 @@
-#!/bin/bash
+#!/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.
diff --git a/dev-support/submarine-installer/package/hadoop/yarn/sbin/start-mr-jobhistory.sh b/dev-support/submarine-installer/package/hadoop/yarn/sbin/start-mr-jobhistory.sh
index 4571147..5d54144 100755
--- a/dev-support/submarine-installer/package/hadoop/yarn/sbin/start-mr-jobhistory.sh
+++ b/dev-support/submarine-installer/package/hadoop/yarn/sbin/start-mr-jobhistory.sh
@@ -1,4 +1,4 @@
-#!/bin/bash
+#!/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
diff --git a/dev-support/submarine-installer/package/hadoop/yarn/sbin/stop-mr-jobhistory.sh b/dev-support/submarine-installer/package/hadoop/yarn/sbin/stop-mr-jobhistory.sh
index d49c1fa..98b9ae0 100755
--- a/dev-support/submarine-installer/package/hadoop/yarn/sbin/stop-mr-jobhistory.sh
+++ b/dev-support/submarine-installer/package/hadoop/yarn/sbin/stop-mr-jobhistory.sh
@@ -1,4 +1,4 @@
-#!/bin/bash
+#!/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
diff --git a/dev-support/submarine-installer/scripts/yarn.sh b/dev-support/submarine-installer/scripts/yarn.sh
index 7650abd..461c20e 100644
--- a/dev-support/submarine-installer/scripts/yarn.sh
+++ b/dev-support/submarine-installer/scripts/yarn.sh
@@ -1,4 +1,4 @@
-#!/bin/bash
+#!/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
diff --git a/dev-support/submarine-installer/scripts/yarn_insecure.sh b/dev-support/submarine-installer/scripts/yarn_insecure.sh
index 847c608..8e45710 100644
--- a/dev-support/submarine-installer/scripts/yarn_insecure.sh
+++ b/dev-support/submarine-installer/scripts/yarn_insecure.sh
@@ -1,4 +1,4 @@
-#!/bin/bash
+#!/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
diff --git a/dev-support/travis/install_external_dependencies.sh b/dev-support/travis/install_external_dependencies.sh
index a1565e8..c73f28b 100755
--- a/dev-support/travis/install_external_dependencies.sh
+++ b/dev-support/travis/install_external_dependencies.sh
@@ -1,4 +1,4 @@
-#!/bin/bash
+#!/usr/bin/env bash
 
 # Licensed to the Apache Software Foundation (ASF) under one or more
 # contributor license agreements.  See the NOTICE file distributed with
diff --git a/docs/database/init-database.sh b/docs/database/init-database.sh
index 60bf15f..f9bf047 100755
--- a/docs/database/init-database.sh
+++ b/docs/database/init-database.sh
@@ -1,4 +1,4 @@
-#!/bin/bash
+#!/usr/bin/env bash
 #
 # Licensed to the Apache Software Foundation (ASF) under one
 # or more contributor license agreements.  See the NOTICE file
diff --git a/docs/ecosystem/kaldi/sge/gencfs.sh b/docs/ecosystem/kaldi/sge/gencfs.sh
index 36e4630..4e5482d 100644
--- a/docs/ecosystem/kaldi/sge/gencfs.sh
+++ b/docs/ecosystem/kaldi/sge/gencfs.sh
@@ -1,4 +1,4 @@
-#!/bin/bash
+#!/usr/bin/env bash
 
 # Licensed to the Apache Software Foundation (ASF) under one or more
 # contributor license agreements.  See the NOTICE file distributed with
diff --git a/docs/ecosystem/kaldi/sge/sge_run.sh b/docs/ecosystem/kaldi/sge/sge_run.sh
index 7b5e166..d2076ee 100644
--- a/docs/ecosystem/kaldi/sge/sge_run.sh
+++ b/docs/ecosystem/kaldi/sge/sge_run.sh
@@ -1,4 +1,4 @@
-#!/bin/bash
+#!/usr/bin/env bash
 
 # Licensed to the Apache Software Foundation (ASF) under one or more
 # contributor license agreements.  See the NOTICE file distributed with
diff --git a/docs/userdocs/yarn/TestAndTroubleshooting.md b/docs/userdocs/yarn/TestAndTroubleshooting.md
index 6bca963..2101825 100644
--- a/docs/userdocs/yarn/TestAndTroubleshooting.md
+++ b/docs/userdocs/yarn/TestAndTroubleshooting.md
@@ -103,7 +103,7 @@ Error response from daemon: Unable to remove filesystem for 0bfafa146431771f6024
 Solution: to find which process leads to a `device or resource busy`, we can add a shell script, named `find-busy-mnt.sh`
 
 ```bash
-#!/bin/bash
+#!/usr/bin/env bash
 
 # A simple script to get information about mount points and pids and their
 # mount namespaces.
diff --git a/submarine-cloud/build.sh b/submarine-cloud/build.sh
index 7cb1e34..5bcabee 100755
--- a/submarine-cloud/build.sh
+++ b/submarine-cloud/build.sh
@@ -1,4 +1,4 @@
-#!/bin/bash
+#!/usr/bin/env bash
 #
 # Licensed to the Apache Software Foundation (ASF) under one or more
 # contributor license agreements.  See the NOTICE file distributed with
diff --git a/submarine-cloud/hack/deploy-submarine.sh b/submarine-cloud/hack/deploy-submarine.sh
index 7b340da..77a7bf0 100755
--- a/submarine-cloud/hack/deploy-submarine.sh
+++ b/submarine-cloud/hack/deploy-submarine.sh
@@ -1,4 +1,4 @@
-#!/bin/bash
+#!/usr/bin/env bash
 #
 # Licensed to the Apache Software Foundation (ASF) under one or more
 # contributor license agreements.  See the NOTICE file distributed with
diff --git a/submarine-cloud/hack/integration-test.sh b/submarine-cloud/hack/integration-test.sh
index 0ca5595..b0aff23 100755
--- a/submarine-cloud/hack/integration-test.sh
+++ b/submarine-cloud/hack/integration-test.sh
@@ -1,4 +1,4 @@
-#!/bin/bash
+#!/usr/bin/env bash
 #
 # Licensed to the Apache Software Foundation (ASF) under one or more
 # contributor license agreements.  See the NOTICE file distributed with
diff --git a/submarine-server/server-submitter/submitter-yarnservice/src/main/java/org/apache/submarine/server/submitter/yarnservice/command/LaunchScriptBuilder.java b/submarine-server/server-submitter/submitter-yarnservice/src/main/java/org/apache/submarine/server/submitter/yarnservice/command/LaunchScriptBuilder.java
index 9ec4b2f..ba2c7b8 100644
--- a/submarine-server/server-submitter/submitter-yarnservice/src/main/java/org/apache/submarine/server/submitter/yarnservice/command/LaunchScriptBuilder.java
+++ b/submarine-server/server-submitter/submitter-yarnservice/src/main/java/org/apache/submarine/server/submitter/yarnservice/command/LaunchScriptBuilder.java
@@ -106,6 +106,6 @@ public class LaunchScriptBuilder {
   }
 
   private void writeBashHeader(PrintWriter pw) {
-    pw.append("#!/bin/bash\n");
+    pw.append("#!/usr/bin/env bash\n");
   }
 }
diff --git a/submarine-server/server-submitter/submitter-yarnservice/src/test/java/org/apache/submarine/client/cli/yarnservice/YarnServiceRunJobCliTest.java b/submarine-server/server-submitter/submitter-yarnservice/src/test/java/org/apache/submarine/client/cli/yarnservice/YarnServiceRunJobCliTest.java
index 54bf7f0..58bda96 100644
--- a/submarine-server/server-submitter/submitter-yarnservice/src/test/java/org/apache/submarine/client/cli/yarnservice/YarnServiceRunJobCliTest.java
+++ b/submarine-server/server-submitter/submitter-yarnservice/src/test/java/org/apache/submarine/client/cli/yarnservice/YarnServiceRunJobCliTest.java
@@ -418,7 +418,7 @@ public class YarnServiceRunJobCliTest {
     }
 
     String expectedLaunchScript =
-        "#!/bin/bash\n" + "echo \"CLASSPATH:$CLASSPATH\"\n"
+        "#!/usr/bin/env bash\n" + "echo \"CLASSPATH:$CLASSPATH\"\n"
             + "echo \"HADOOP_CONF_DIR:$HADOOP_CONF_DIR\"\n"
             + "echo \"HADOOP_TOKEN_FILE_LOCATION:" +
             "$HADOOP_TOKEN_FILE_LOCATION\"\n"
diff --git a/submarine-server/server-submitter/submitter-yarnservice/src/test/java/org/apache/submarine/server/submitter/yarnservice/command/AbstractTFLaunchCommandTestHelper.java b/submarine-server/server-submitter/submitter-yarnservice/src/test/java/org/apache/submarine/server/submitter/yarnservice/command/AbstractTFLaunchCommandTestHelper.java
index 23df04b..f1cc19e 100644
--- a/submarine-server/server-submitter/submitter-yarnservice/src/test/java/org/apache/submarine/server/submitter/yarnservice/command/AbstractTFLaunchCommandTestHelper.java
+++ b/submarine-server/server-submitter/submitter-yarnservice/src/test/java/org/apache/submarine/server/submitter/yarnservice/command/AbstractTFLaunchCommandTestHelper.java
@@ -174,7 +174,7 @@ public abstract class AbstractTFLaunchCommandTestHelper {
         Paths.get(resultFile.toURI()),
         Charset.forName("UTF-8"));
 
-    assertEquals("#!/bin/bash", fileContents.get(0));
+    assertEquals("#!/usr/bin/env bash", fileContents.get(0));
     assertScriptContainsExportedEnvVar(fileContents, "HADOOP_HOME");
     assertScriptContainsExportedEnvVar(fileContents, "HADOOP_YARN_HOME");
     assertScriptContainsExportedEnvVarWithValue(fileContents,


---------------------------------------------------------------------
To unsubscribe, e-mail: dev-unsubscribe@submarine.apache.org
For additional commands, e-mail: dev-help@submarine.apache.org