You are viewing a plain text version of this content. The canonical link for it is here.
Posted to issues@kylin.apache.org by GitBox <gi...@apache.org> on 2018/11/12 02:49:57 UTC

[GitHub] shaofengshi closed pull request #342: typos and format fixed

shaofengshi closed pull request #342: typos and format fixed
URL: https://github.com/apache/kylin/pull/342
 
 
   

This is a PR merged from a forked repository.
As GitHub hides the original diff on merge, it is displayed below for
the sake of provenance:

As this is a foreign pull request (from a fork), the diff is supplied
below (as it won't show otherwise due to GitHub magic):

diff --git a/website/_docs/install/configuration.cn.md b/website/_docs/install/configuration.cn.md
index 558b97fef2..1945658350 100644
--- a/website/_docs/install/configuration.cn.md
+++ b/website/_docs/install/configuration.cn.md
@@ -95,7 +95,7 @@ Kylin 的配置文件如下:
 
 ### Cube 配置重写		{#cube-config-override}
 
-在设计 Cube (**Cube Designer**)的 **Configuration overrides** 步骤可以添加配置项,进行 Cube 级别的配置重写,如下图所示:
+在设计 Cube (**Cube Designer**)的 **Configuration Overwrites** 步骤可以添加配置项,进行 Cube 级别的配置重写,如下图所示:
 ![](/images/install/override_config_cube.png)
 
 
@@ -104,7 +104,8 @@ Kylin 的配置文件如下:
 
 Kylin 支持在项目和 Cube 级别重写 `kylin_job_conf.xml` 和 `kylin_job_conf_inmem.xml` 中参数,以键值对的性质,按照如下格式替换:
 `kylin.job.mr.config.override.<key> = <value>`
-如果用户希望 Cube 的构建任务使用不同的 YARN resource queue,可以设置:`kylin.engine.mr.config-override.mapreduce.job.queuename={queueName}` 
+如果用户希望 Cube 的构建任务使用不同的 YARN resource queue,可以设置:
+`kylin.engine.mr.config-override.mapreduce.job.queuename={queueName}` 
 
 
 
@@ -112,7 +113,8 @@ Kylin 支持在项目和 Cube 级别重写 `kylin_job_conf.xml` 和 `kylin_job_c
 
 Kylin 支持在项目和 Cube 级别重写 `kylin_hive_conf.xml` 中参数,以键值对的性质,按照如下格式替换:
 `kylin.source.hive.config-override.<key> = <value>`
-如果用户希望 Hive 使用不同的 YARN resource queue,可以设置:`kylin.source.hive.config-override.mapreduce.job.queuename={queueName}` 
+如果用户希望 Hive 使用不同的 YARN resource queue,可以设置:
+`kylin.source.hive.config-override.mapreduce.job.queuename={queueName}` 
 
 
 
@@ -120,7 +122,8 @@ Kylin 支持在项目和 Cube 级别重写 `kylin_hive_conf.xml` 中参数,以
 
 Kylin 支持在项目和 Cube 级别重写 `kylin.properties` 中的 Spark 参数,以键值对的性质,按照如下格式替换:
 `kylin.engine.spark-conf.<key> = <value>`
-如果用户希望 Spark 使用不同的 YARN resource queue,可以设置:`kylin.engine.spark-conf.spark.yarn.queue={queueName}`
+如果用户希望 Spark 使用不同的 YARN resource queue,可以设置:
+`kylin.engine.spark-conf.spark.yarn.queue={queueName}`
 
 
 
@@ -137,7 +140,7 @@ Kylin 支持在项目和 Cube 级别重写 `kylin.properties` 中的 Spark 参
 - `kylin.env.zookeeper-base-path`:指定 Kylin 服务所用的 ZooKeeper 路径,默认值为 `/kylin`
 - `kylin.env.zookeeper-connect-string`:指定 ZooKeeper 连接字符串,如果为空,使用 HBase 的 ZooKeeper
 - `kylin.env.hadoop-conf-dir`:指定 Hadoop 配置文件目录,如果不指定的话,获取环境中的 `HADOOP_CONF_DIR`
-- `kylin.server.mode`:指定 Kylin 实例的运行模式,参数值可选 (`all` | `job` | `query`),默认值为 `all`,job 模式代表该服务仅用于任务调度,不用于查询;query 模式代表该服务仅用于查询,不用于构建任务的调度;all 模式代表该服务同时用于任务调度和 SQL 查询。
+- `kylin.server.mode`:指定 Kylin 实例的运行模式,参数值可选 `all`, `job`, `query`,默认值为 `all`,job 模式代表该服务仅用于任务调度,不用于查询;query 模式代表该服务仅用于查询,不用于构建任务的调度;all 模式代表该服务同时用于任务调度和 SQL 查询。
 - `kylin.server.cluster-name`:指定集群名称
 
 
@@ -277,7 +280,7 @@ Kylin 和 HBase 都在写入磁盘时使用压缩,因此,Kylin 将在其原
 
 ### Cube 构建算法 {#cube-algorithm}
 
-- `kylin.cube.algorithm`:指定 Cube 构建的算法,参数值可选 `auto`,`layer` 和 `inmem`, 默认值为 `auto`,即 Kylin 会通过采集数据动态地选择一个算法 (layer or inmem),如果用户很了解 Kylin 和自身的数据、集群,可以直接设置喜欢的算法
+- `kylin.cube.algorithm`:指定 Cube 构建的算法,参数值可选 `auto`,`layer` 和 `inmem`, 默认值为 auto,即 Kylin 会通过采集数据动态地选择一个算法 (layer or inmem),如果用户很了解 Kylin 和自身的数据、集群,可以直接设置喜欢的算法
 - `kylin.cube.algorithm.layer-or-inmem-threshold`:默认值为 7
 - `kylin.cube.algorithm.inmem-split-limit`:默认值为 500
 - `kylin.cube.algorithm.inmem-concurrent-threads`:默认值为 1
@@ -319,7 +322,7 @@ Kylin 和 HBase 都在写入磁盘时使用压缩,因此,Kylin 将在其原
 - `kylin.engine.mr.max-reducer-number`:MapReduce 任务中 Reducer 数目的最大值,默认值为 500
 - `kylin.engine.mr.mapper-input-rows`:每个 Mapper 可以处理的行数,默认值为 1000000,如果将这个值调小,会起更多的 Mapper
 - `kylin.engine.mr.max-cuboid-stats-calculator-number`:用于计算 Cube 统计数据的线程数量,默认值为 1
-- `kylin.engine.mr.build-dict-in-reducer`:是否在构建任务 **Extract Fact Table Distinct Columns** 的 Reduce 阶段构建字典,默认值为 `TRUE`
+- `kylin.engine.mr.build-dict-in-reducer`:是否在构建任务 **Extract Fact Table Distinct Columns** 的 Reduce 阶段构建字典,默认值为 TRUE
 - `kylin.engine.mr.yarn-check-interval-seconds`:构建引擎间隔多久检查 Hadoop 任务的状态,默认值为 10(s)    
 
 
@@ -341,16 +344,16 @@ Kylin 和 HBase 都在写入磁盘时使用压缩,因此,Kylin 将在其原
 ### 超高基维度的处理 {#uhc-config}
 
 Cube 构建默认在 **Extract Fact Table Distinct Column** 这一步为每一列分配一个 Reducer,对于超高基维度,可以通过以下参数增加 Reducer 个数
-- `kylin.engine.mr.build-uhc-dict-in-additional-step`:默认值为 `FALSE`,设置为 `TRUE`
+- `kylin.engine.mr.build-uhc-dict-in-additional-step`:默认值为 FALSE,设置为 TRUE
 - `kylin.engine.mr.uhc-reducer-count`:默认值为 1,可以设置为 5,即为每个超高基的列分配 5 个 Reducer。
 
 
 
 ### Spark 构建引擎  {#spark-cubing}
 
-- `kylin.engine.spark-conf.spark.master`:指定 Spark 运行模式,默认值为 `yarn`
-- `kylin.engine.spark-conf.spark.submit.deployMode`:指定 Spark on YARN 的部署模式,默认值为 `cluster`
-- `kylin.engine.spark-conf.spark.yarn.queue`:指定 Spark 资源队列,默认值为 `default`
+- `kylin.engine.spark-conf.spark.master`:指定 Spark 运行模式,默认值为 yarn
+- `kylin.engine.spark-conf.spark.submit.deployMode`:指定 Spark on YARN 的部署模式,默认值为 cluster
+- `kylin.engine.spark-conf.spark.yarn.queue`:指定 Spark 资源队列,默认值为 default
 - `kylin.engine.spark-conf.spark.driver.memory`:指定 Spark Driver 内存大小,默认值为 2G
 - `kylin.engine.spark-conf.spark.executor.memory`:指定 Spark Executor 内存大小,默认值为 4G
 - `kylin.engine.spark-conf.spark.yarn.executor.memoryOverhead`:指定 Spark Executor 堆外内存大小,默认值为 1024(MB)
@@ -464,11 +467,12 @@ Cube 构建默认在 **Extract Fact Table Distinct Column** 这一步为每一
 
 Kylin 在默认状态下不会启用压缩,不支持的压缩算法会阻碍 Kylin 的构建任务,但是一个合适的压缩算法可以减少存储开销和网络开销,提高整体系统运行效率。
 Kylin 可以使用三种类型的压缩,分别是 HBase 表压缩,Hive 输出压缩 和 MapReduce 任务输出压缩。 
+
 > **注意**:压缩设置只有在重启 Kylin 实例后才会生效。
 
 * HBase 表压缩
 
-该项压缩通过 `kyiln.properties` 中的 `kylin.hbase.default.compression.codec` 进行配置,参数值可选( `none` | `snappy` | `lzo` | `gzip` | `lz4`),默认值为 `none`,即不压缩数据。
+该项压缩通过 `kyiln.properties` 中的 `kylin.hbase.default.compression.codec` 进行配置,参数值可选 `none`,`snappy`, `lzo`, `gzip`, `lz4`),默认值为 none,即不压缩数据。
 
 > **注意**:在修改压缩算法前,请确保用户的 HBase 集群支持所选压缩算法。
 
@@ -509,7 +513,7 @@ Kylin 可以使用三种类型的压缩,分别是 HBase 表压缩,Hive 输
 
 
 
-### 查询配置 {$kylin-query}
+### 查询配置    {#kylin-query}
 
 本小节介绍 Kylin 查询有关的配置。
 
@@ -523,8 +527,8 @@ Kylin 可以使用三种类型的压缩,分别是 HBase 表压缩,Hive 输
 - `kylin.query.security.table-acl-enabled`:是否在查询时检查对应表的 ACL,默认值为 TRUE 
 - `kylin.query.calcite.extras-props.conformance`:是否严格解析,默认值为 LENIENT
 - `kylin.query.calcite.extras-props.caseSensitive`:是否大小写敏感,默认值为 TRUE
-- `kylin.query.calcite.extras-props.unquotedCasing`:是否需要将查询语句进行大小写转换,参数值可选( `UNCHANGED` | `TO_UPPER` | `TO_LOWER` ),默认值为 `TO_UPPER`,即全部大写
-- `kylin.query.calcite.extras-props.quoting`:是否添加引号,参数值可选( `DOUBLE_QUOTE` | `BACK_TICK` | `BRACKET`),默认值为 `DOUBLE_QUOTE`
+- `kylin.query.calcite.extras-props.unquotedCasing`:是否需要将查询语句进行大小写转换,参数值可选 `UNCHANGED`, `TO_UPPER`, `TO_LOWER` ,默认值为 `TO_UPPER`,即全部大写
+- `kylin.query.calcite.extras-props.quoting`:是否添加引号,参数值可选 `DOUBLE_QUOTE`, `BACK_TICK`,`BRACKET`,默认值为 DOUBLE_QUOTE
 - `kylin.query.statement-cache-max-num`:缓存的 PreparedStatement 的最大条数,默认值为 50000
 - `kylin.query.statement-cache-max-num-per-key`:每个键缓存的 PreparedStatement 的最大条数,默认值为 50 
 - `kylin.query.enable-dict-enumerator`:是否启用字典枚举器,默认值为 FALSE
@@ -584,7 +588,7 @@ Kylin 可以使用三种类型的压缩,分别是 HBase 表压缩,Hive 输
 
 ### 收集查询指标到 JMX {#jmx-metrics}
 
-- `kylin.server.query-metrics-enabled`:默认值为 `FALSE`,设为 `TRUE` 来将查询指标收集到 JMX
+- `kylin.server.query-metrics-enabled`:默认值为 FALSE,设为 TRUE 来将查询指标收集到 JMX
 
 > 提示:更多信息请参考 [JMX](https://www.oracle.com/technetwork/java/javase/tech/javamanagement-140525.html)
 
@@ -592,7 +596,7 @@ Kylin 可以使用三种类型的压缩,分别是 HBase 表压缩,Hive 输
 
 ### 收集查询指标到 dropwizard {#dropwizard-metrics}
 
-- `kylin.server.query-metrics2-enabled`:默认值为 `FALSE`,设为 `TRUE` 来将查询指标收集到 dropwizard
+- `kylin.server.query-metrics2-enabled`:默认值为 FALSE,设为 TRUE 来将查询指标收集到 dropwizard
 
 > 提示:更多信息请参考 [dropwizard](https://metrics.dropwizard.io/4.0.0/)
 
@@ -607,7 +611,7 @@ Kylin 可以使用三种类型的压缩,分别是 HBase 表压缩,Hive 输
 ### 集成 LDAP 实现单点登录	{#ldap-sso}
 
 - `kylin.security.profile=ldap`:启用 LDAP
-- `kylin.security.ldap.connection-server`:LDAP 服务器,如 `ldap://ldap_server:389`
+- `kylin.security.ldap.connection-server`:LDAP 服务器,如 ldap://ldap_server:389
 - `kylin.security.ldap.connection-username`:LDAP 用户名
 - `kylin.security.ldap.connection-password`:LDAP 密码
 - `kylin.security.ldap.user-search-base`:定义同步到 Kylin 的用户的范围
@@ -633,6 +637,6 @@ Kylin 可以使用三种类型的压缩,分别是 HBase 表压缩,Hive 输
 
 ### 启用 ZooKeeper ACL {#zookeeper-acl}
 
-- `kylin.env.zookeeper-acl-enabled`:启用 ZooKeeper ACL 以阻止未经授权的用户访问 Znode 或降低由此导致的不良操作的风险,默认值为 `FALSE`
-- `kylin.env.zookeeper.zk-auth`:使用 用户名:密码 作为 ACL 标识,默认值为 `digest:ADMIN:KYLIN`
-- `kylin.env.zookeeper.zk-acl`:使用单个 ID 作为 ACL 标识,默认值为 `world:anyone:rwcda`,`anyone` 表示任何人
\ No newline at end of file
+- `kylin.env.zookeeper-acl-enabled`:启用 ZooKeeper ACL 以阻止未经授权的用户访问 Znode 或降低由此导致的不良操作的风险,默认值为 FALSE
+- `kylin.env.zookeeper.zk-auth`:使用 用户名:密码 作为 ACL 标识,默认值为 digest:ADMIN:KYLIN
+- `kylin.env.zookeeper.zk-acl`:使用单个 ID 作为 ACL 标识,默认值为 world:anyone:rwcda,anyone 表示任何人
\ No newline at end of file
diff --git a/website/_docs/install/configuration.md b/website/_docs/install/configuration.md
index b95d3816d5..23136d89ad 100644
--- a/website/_docs/install/configuration.md
+++ b/website/_docs/install/configuration.md
@@ -146,7 +146,7 @@ This section introduces Kylin Deployment related configuration.
 - `kylin.storage.hbase.cluster-fs`: specifies the HDFS file system of the HBase cluster
 - `kylin.storage.hbase.cluster-hdfs-config-file`: specifies HDFS configuration file pointing to the HBase cluster
 
-> Tip: For more information, please refer to [Deploy Apache Kylin with Standalone HBase Cluster](http://kylin.apache.org/blog/2016/06/10/standalone-hbase-cluster/)
+> Note: For more information, please refer to [Deploy Apache Kylin with Standalone HBase Cluster](http://kylin.apache.org/blog/2016/06/10/standalone-hbase-cluster/)
 
 
 
@@ -180,15 +180,15 @@ This section introduces Kylin Metastore related configuration.
 
 ### Metadata {#metadata}
 
-- `kylin.metadata.url`: specifies the Metadata path. The default value is `kylin_metadata@hbase`
+- `kylin.metadata.url`: specifies the Metadata path. The default value is *kylin_metadata@hbase*
 - `kylin.metadata.dimension-encoding-max-length`: specifies the maximum length when the dimension is used as Rowkeys with fix_length encoding. The default value is 256.
 - `kylin.metadata.sync-retries`: specifies the number of Metadata sync retries. The default value is 3.
-- `kylin.metadata.sync-error-handler`: The default value is `DefaultSyncErrorHandler`
-- `kylin.metadata.check-copy-on-write`: whether clear metadata cache, default value is `FALSE`
+- `kylin.metadata.sync-error-handler`: The default value is *DefaultSyncErrorHandler*
+- `kylin.metadata.check-copy-on-write`: whether clear metadata cache, default value is *FALSE*
 - `kylin.metadata.hbase-client-scanner-timeout-period`: specifies the total timeout between the RPC call initiated by the HBase client. The default value is 10000 (ms).
 - `kylin.metadata.hbase-rpc-timeout`: specifies the timeout for HBase to perform RPC operations. The default value is 5000 (ms).
 - `kylin.metadata.hbase-client-retries-number`: specifies the number of HBase retries. The default value is 1 (times).
-- `kylin.metadata.resource-store-provider.jdbc`: specifies the class used by JDBC. The default value is `org.apache.kylin.common.persistence.JDBCResourceStore`
+- `kylin.metadata.resource-store-provider.jdbc`: specifies the class used by JDBC. The default value is *org.apache.kylin.common.persistence.JDBCResourceStore*
 
 
 
@@ -204,7 +204,7 @@ This section introduces Kylin Metastore related configuration.
 - `kylin.metadata.jdbc.max-cell-size`: The default value is 1 (MB)
 - `kylin.metadata.resource-store-provider.jdbc`: specifies the class used by JDBC. The default value is org.apache.kylin.common.persistence.JDBCResourceStore
 
-> Tip: For more information, please refer to [MySQL-based Metastore Configuration](/docs/tutorial/mysql_metastore.html)
+> Note: For more information, please refer to [MySQL-based Metastore Configuration](/docs/tutorial/mysql_metastore.html)
 
 
 
@@ -238,7 +238,7 @@ This section introduces Kylin data modeling and build related configuration.
 - `kylin.source.jdbc.sqoop-mapper-num`: specifies how many slices should be split. Sqoop will run a mapper for each slice. The default value is 4.
 - `kylin.source.jdbc.field-delimiter`: specifies the field separator. The default value is \
 
-> Tip: For more information, please refer to [Building a JDBC Data Source](/docs/tutorial/setup_jdbc_datasource.html).
+> Note: For more information, please refer to [Building a JDBC Data Source](/docs/tutorial/setup_jdbc_datasource.html).
 
 
 
@@ -366,7 +366,7 @@ Both Kylin and HBase use compression when writing to disk, so Kylin will multipl
 - `kylin.engine.spark-conf-mergedict.spark.executor.memory`: whether to request more memory for merging dictionary.The default value is 6G.
 - `kylin.engine.spark-conf-mergedict.spark.memory.fraction`: specifies the percentage of memory reserved for the system. The default value is 0.2
 
-> Tip: For more information, please refer to [Building Cubes with Spark](/docs/tutorial/cube_spark.html).
+> Note: For more information, please refer to [Building Cubes with Spark](/docs/tutorial/cube_spark.html).
 
 
 
@@ -379,7 +379,7 @@ Both Kylin and HBase use compression when writing to disk, so Kylin will multipl
 - `kylin.engine.spark-conf.spark.dynamicAllocation.maxExecutors`: specifies the maximum number of Executors applied for
 - `kylin.engine.spark-conf.spark.dynamicAllocation.executorIdleTimeout`: specifies the threshold of Executor being removed after being idle. The default value is 60(s)
 
-> Tip: For more information, please refer to the official documentation: [Dynamic Resource Allocation](http://spark.apache.org/docs/1.6.2/job-scheduling.html#dynamic-resource-allocation).
+> Note: For more information, please refer to the official documentation: [Dynamic Resource Allocation](http://spark.apache.org/docs/1.6.2/job-scheduling.html#dynamic-resource-allocation).
 
 
 
@@ -426,7 +426,7 @@ Both Kylin and HBase use compression when writing to disk, so Kylin will multipl
 - `kylin.cube.cubeplanner.mandatory-rollup-threshold`: the default value is 1000
 - `kylin.cube.cubeplanner.algorithm-threshold-genetic`: the default value is 23
 
-> Tip: For more information, please refer to [Using Cube Planner](/docs/tutorial/use_cube_planner.html).
+> Note: For more information, please refer to [Using Cube Planner](/docs/tutorial/use_cube_planner.html).
 
 
 
@@ -461,11 +461,13 @@ Both Kylin and HBase use compression when writing to disk, so Kylin will multipl
 
 Kylin does not enable Enable Compression by default. Unsupported compression algorithms can hinder Kylin's build jobs, but a suitable compression algorithm can reduce storage overhead and network overhead and improve overall system operation efficiency.
 Kylin can use three types of compression, HBase table compression, Hive output compression, and MapReduce job output compression.
+
 > *Note*: The compression settings will not take effect until the Kylin instance is restarted.
 
 * HBase table compression
 
-This compression is configured by `kylin.hbase.default.compression.codec` in `kyiln.properties`. Optional values include `none`, `snappy`, `lzo`, `gzip` and `lz4`. The default value is `none`, which means no data is compressed.
+This compression is configured by `kylin.hbase.default.compression.codec` in `kyiln.properties`. Optional values include `none`, `snappy`, `lzo`, `gzip` and `lz4`. The default value is none, which means no data is compressed.
+
 > *Note*: Before modifying the compression algorithm, make sure userr HBase cluster supports the selected compression algorithm.
 
 
@@ -505,7 +507,7 @@ This compression is configured via `kylin_job_conf.xml` and `kylin_job_conf_inme
 
 
 
-### Query Configuration {$kylin-query}
+### Query Configuration    {#kylin-query}
 
 This section introduces Kylin query related configuration.
 
@@ -568,7 +570,7 @@ This section introduces Kylin query related configuration.
 - `kylin.query.pushdown.update-enabled`: specifies whether to enable update in Query Pushdown. The default value is *FALSE*
 - `kylin.query.pushdown.cache-enabled`: whether to enable the cache of the pushdown query to improve the query efficiency of the same query. The default value is *FALSE*
 
-> Tip: For more information, please refer to [Query Pushdown](/docs/tutorial/query_pushdown.html)
+> Note: For more information, please refer to [Query Pushdown](/docs/tutorial/query_pushdown.html)
 
 
 
@@ -582,7 +584,7 @@ This section introduces Kylin query related configuration.
 
 - `kylin.server.query-metrics-enabled`: the default value is *FALSE*, set to *TRUE* to collect query metrics to JMX
 
-> Tip: For more information, please refer to [JMX](https://www.oracle.com/technetwork/java/javase/tech/javamanagement-140525.html)
+> Note: For more information, please refer to [JMX](https://www.oracle.com/technetwork/java/javase/tech/javamanagement-140525.html)
 
 
 
@@ -590,7 +592,7 @@ This section introduces Kylin query related configuration.
 
 - `kylin.server.query-metrics2-enabled`: the default value is *FALSE*, set to *TRUE* to collect query metrics into dropwizard
 
-> Tip: For more information, please refer to [dropwizard](https://metrics.dropwizard.io/4.0.0/)
+> Note: For more information, please refer to [dropwizard](https://metrics.dropwizard.io/4.0.0/)
 
 
 
@@ -623,7 +625,7 @@ This section introduces Kylin security-related configuration.
 
 - `kylin.server.external-acl-provider=org.apache.ranger.authorization.kylin.authorizer.RangerKylinAuthorizer`
 
-> Tip: For more information, please refer to [How to integrate the Kylin plugin in the installation documentation for Ranger](https://cwiki.apache.org/confluence/display/RANGER/Kylin+Plugin)
+> Note: For more information, please refer to [How to integrate the Kylin plugin in the installation documentation for Ranger](https://cwiki.apache.org/confluence/display/RANGER/Kylin+Plugin)
 
 
 
diff --git a/website/_docs/tutorial/mysql_metastore.cn.md b/website/_docs/tutorial/mysql_metastore.cn.md
index 499909064d..53b9da8e22 100644
--- a/website/_docs/tutorial/mysql_metastore.cn.md
+++ b/website/_docs/tutorial/mysql_metastore.cn.md
@@ -15,7 +15,7 @@ Kylin 支持 MySQL 作为 Metastore 存储。
 ### 准备工作
 
 1.安装 MySQL 服务,例如 v5.1.17
-2.下载 MySQL 的  JDBC 驱动 ( `mysql-connector-java-<version>.jar`) 并放置到 `$KYLIN_HOME/ext/` 目录下
+2.下载 MySQL 的  JDBC 驱动 ( `mysql-connector-java-<version>.jar`) 并放置到 `$KYLIN_HOME/ext/` 目录下。
 
 > 提示:如果没有该目录,请自行创建。
 
@@ -27,18 +27,18 @@ Kylin 支持 MySQL 作为 Metastore 存储。
 
 2.在配置文件 `kylin.properties` 中配置 `kylin.metadata.url={metadata_name}@jdbc`,该参数中各配置项的含义如下,其中 `url`、`username` 和 `password` 为必须配置项,其他项如果不配置将使用默认值。
 
-> 提示:`{metadata_name}` 需要替换成用户需要的元数据表名,如果这张表已存在,会使用现有的表;如果不存在,则会自动创建该表。
+> 提示:{metadata_name} 需要替换成用户需要的元数据表名,如果这张表已存在,会使用现有的表;如果不存在,则会自动创建该表。
 
 - `url`:JDBC 连接的 URL
 - `username`:JDBC 的用户名
 - `password`:JDBC 的密码,如果对密码进行了加密,填写加密后的密码
-- `driverClassName`: JDBC 的 driver 类名,默认值为 com.mysql.jdbc.Driver
+- `driverClassName`: JDBC 的 driver 类名,默认值为 `com.mysql.jdbc.Driver`
 - `maxActive`:最大数据库连接数,默认值为 5
 - `maxIdle`:最大等待中的连接数量,默认值为 5
 - `maxWait`:最大等待连接毫秒数,默认值为 1000
 - `removeAbandoned`:是否自动回收超时连接,默认值为 true
 - `removeAbandonedTimeout`:超时时间秒数,默认为 300
-- `passwordEncrypted`:是否对 JDBC 密码进行加密,默认为 false
+- `passwordEncrypted`:是否对 JDBC 密码进行加密,默认为 FALSE
 
 > 提示:如果需要对 JDBC 密码进行加密,请在 `$KYLIN_HOME/tomcat/webapps/kylin/WEB-INF/lib/`下运行如下命令:
 
@@ -63,6 +63,14 @@ org.apache.kylin.rest.security.PasswordPlaceholderConfigurer \
 AES test123
 ```
 
+执行结果如下:
+
+```
+AES encrypted password is:
+bUmSqT/opyqz89Geu0yQ3g==
+```
+将生成的密码填入 `kylin.metadata.url` 中的 `password` 中,设置 `passwordEncrypted` 为 TRUE。
+
 3.由于元数据不依赖于 HBase,所以需要在配置文件 `$KYLIN_HOME/conf/kylin.properties` 中添加 ZooKeeper 的连接项 `kylin.env.zookeeper-connect-string = host:port`。
 
 4.`kylin.properties` 的样例配置如下:
diff --git a/website/_docs/tutorial/mysql_metastore.md b/website/_docs/tutorial/mysql_metastore.md
index d4096258af..a88df4b382 100644
--- a/website/_docs/tutorial/mysql_metastore.md
+++ b/website/_docs/tutorial/mysql_metastore.md
@@ -14,21 +14,21 @@ Kylin supports MySQL as Metastore.
 
 ### Prerequisites
 
-1. Install MySQL, such as v5.1.17
-2. Download the MySQL JDBC driver ( `mysql-connector-java-<version>.jar`) and place it in the `$KYLIN_HOME/ext/` directory.
+1.Install MySQL, such as v5.1.17
+2.Download the MySQL JDBC driver ( `mysql-connector-java-<version>.jar`) and place it in the `$KYLIN_HOME/ext/` directory.
 
-> Tip: Please create it yourself, if you do not have this directory.
+> *Note*: Please create it yourself, if you do not have this directory.
 
 
 
 ### Configuration Steps
 
-1. Create a new database in MySQL for storing Kylin metadata, such as `kylin`
+1.Create a new database in MySQL for storing Kylin metadata, such as `kylin`
 
-2. Configure `kylin.metadata.url={metadata_name}@jdbc` in the configuration file `kylin.properties`. 
+2.Configure `kylin.metadata.url={metadata_name}@jdbc` in the configuration file `kylin.properties`. 
 The description of each configuration item in this parameter is as follows, where `url`, `username` and `password` are required.
 
-> Tip: `{metadata_name}` needs to be replaced with the metadata table name, if the table already exists, the existing table will be used; if it does not exist, the table will be created automatically.
+> Note: {metadata_name} needs to be replaced with the metadata table name, if the table already exists, the existing table will be used; if it does not exist, the table will be created automatically.
 
 - `url`: URL of the JDBC connection
 - `username`: JDBC username
@@ -44,7 +44,7 @@ The description of each configuration item in this parameter is as follows, wher
 > Note: To encrypt the JDBC password, run the following command under `$KYLIN_HOME/tomcat/webapps/kylin/WEB-INF/lib/`:
 
 ```sh
-Java -classpath kylin-server-base-<version>.jar\
+java -classpath kylin-server-base-<version>.jar\
 :kylin-core-common-<version>.jar\
 :spring-beans-4.3.10.RELEASE.jar:spring-core-4.3.10.RELEASE.jar\
 :commons-codec-1.7.jar \
@@ -55,7 +55,7 @@ AES <your_password>
 As in Kylin v2.5, execute the following command:
 
 ```sh
-Java -classpath kylin-server-base-2.5.0.jar\
+java -classpath kylin-server-base-2.5.0.jar\
 :kylin-core-common-2.5.0.jar\
 :spring-beans-4.3.10.RELEASE.jar\
 :spring-core-4.3.10.RELEASE.jar\
@@ -64,13 +64,22 @@ org.apache.kylin.rest.security.PasswordPlaceholderConfigurer \
 AES test123
 ```
 
-3. Since the metadata does not depend on HBase, you need to add the ZooKeeper connection configuration `kylin.env.zookeeper-connect-string = host:port` in the configuration file `kylin.properties`.
+The execution output is as belows:
 
-4. The sample configuration of `kylin.properties` is as follows:
+```
+AES encrypted password is:
+bUmSqT/opyqz89Geu0yQ3g==
+```
+
+Fill in the generated password into `password` in `kylin.metadata.url` and set `passwordEncrypted` to *TRUE*.
+
+3.Since the metadata does not depend on HBase, you need to add the ZooKeeper connection configuration `kylin.env.zookeeper-connect-string = host:port` in the configuration file `kylin.properties`.
+
+4.The sample configuration of `kylin.properties` is as follows:
 
 ```properties
 Kylin.metadata.url=mysql_test@jdbc,url=jdbc:mysql://localhost:3306/kylin,username=kylin_test,password=bUmSqT/opyqz89Geu0yQ3g==,maxActive=10,maxIdle=10,passwordEncrypted=true
 Kylin.env.zookeeper-connect-string=localhost:2181
 ```
 
-5. Start Kylin
\ No newline at end of file
+5.Start Kylin
\ No newline at end of file


 

----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services