@@ -213,25 +213,25 @@ private[spark] class ClientArguments(args: Array[String], sparkConf: SparkConf)
213213 private def getUsageMessage (unknownParam : List [String ] = null ): String = {
214214 val message = if (unknownParam != null ) s " Unknown/unsupported param $unknownParam\n " else " "
215215 message + """
216- |Usage: org.apache.spark.deploy.yarn.Client [options]
217- |Options:
218- | --jar JAR_PATH Path to your application's JAR file (required in yarn-cluster
219- | mode)
220- | --class CLASS_NAME Name of your application's main class (required)
221- | --arg ARG Argument to be passed to your application's main class.
222- | Multiple invocations are possible, each will be passed in order.
223- | --num-executors NUM Number of executors to start (Default: 2)
224- | --executor-cores NUM Number of cores for the executors (Default: 1).
225- | --driver-memory MEM Memory for driver (e.g. 1000M, 2G) (Default: 512 Mb)
226- | --cores NUM Number of cores used by the driver (Default: 1).
227- | --executor-memory MEM Memory per executor (e.g. 1000M, 2G) (Default: 1G)
228- | --name NAME The name of your application (Default: Spark)
229- | --queue QUEUE The hadoop queue to use for allocation requests (Default:
230- | 'default')
231- | --addJars jars Comma separated list of local jars that want SparkContext.addJar
232- | to work with.
233- | --files files Comma separated list of files to be distributed with the job.
234- | --archives archives Comma separated list of archives to be distributed with the job.
235- """ .stripMargin
216+ |Usage: org.apache.spark.deploy.yarn.Client [options]
217+ |Options:
218+ | --jar JAR_PATH Path to your application's JAR file (required in yarn-cluster
219+ | mode)
220+ | --class CLASS_NAME Name of your application's main class (required)
221+ | --arg ARG Argument to be passed to your application's main class.
222+ | Multiple invocations are possible, each will be passed in order.
223+ | --num-executors NUM Number of executors to start (Default: 2)
224+ | --executor-cores NUM Number of cores for the executors (Default: 1).
225+ | --driver-memory MEM Memory for driver (e.g. 1000M, 2G) (Default: 512 Mb)
226+ | --cores NUM Number of cores used by the driver (Default: 1).
227+ | --executor-memory MEM Memory per executor (e.g. 1000M, 2G) (Default: 1G)
228+ | --name NAME The name of your application (Default: Spark)
229+ | --queue QUEUE The hadoop queue to use for allocation requests (Default:
230+ | 'default')
231+ | --addJars jars Comma separated list of local jars that want SparkContext.addJar
232+ | to work with.
233+ | --files files Comma separated list of files to be distributed with the job.
234+ | --archives archives Comma separated list of archives to be distributed with the job.
235+ """ .stripMargin
236236 }
237237}
0 commit comments