You are viewing a plain text version of this content. The canonical link for it is here.
Posted to notifications@shardingsphere.apache.org by zh...@apache.org on 2020/06/10 16:09:11 UTC

[shardingsphere-elastic-job-lite] branch master updated: Replace Chinese comments with English #764 (#765)

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

zhangliang pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/shardingsphere-elastic-job-lite.git


The following commit(s) were added to refs/heads/master by this push:
     new 40172bb  Replace Chinese comments with English #764 (#765)
40172bb is described below

commit 40172bb4c239e7de92ea39e7d02ee9f9fe23d760
Author: Tboy <gu...@immomo.com>
AuthorDate: Thu Jun 11 00:08:03 2020 +0800

    Replace Chinese comments with English #764 (#765)
---
 .../restful/config/RegistryCenterRESTfulAPI.java   |  6 ++---
 .../elasticjob/lite/api/JobScheduler.java          |  2 +-
 .../lite/event/rdb/JobEventRdbSearch.java          |  6 ++---
 .../lite/event/rdb/JobEventRdbStorage.java         | 16 ++++++-------
 .../lite/executor/AbstractElasticJobExecutor.java  |  4 ++--
 .../lite/internal/config/ConfigurationService.java |  2 +-
 .../lite/internal/failover/FailoverService.java    |  2 +-
 .../internal/instance/TriggerListenerManager.java  |  2 +-
 .../reg/zookeeper/ZookeeperRegistryCenter.java     |  7 +++---
 .../statistics/rdb/StatisticRdbRepository.java     | 26 +++++++++++-----------
 .../lite/util/config/ShardingItemParameters.java   |  2 +-
 .../common/AbstractJobBeanDefinitionParser.java    |  2 +-
 .../ddframe/job/example/EmbedZookeeperServer.java  |  8 +++----
 13 files changed, 42 insertions(+), 43 deletions(-)

diff --git a/elastic-job-lite-console/src/main/java/org/apache/shardingsphere/elasticjob/lite/console/restful/config/RegistryCenterRESTfulAPI.java b/elastic-job-lite-console/src/main/java/org/apache/shardingsphere/elasticjob/lite/console/restful/config/RegistryCenterRESTfulAPI.java
index c7e4945..77736dd 100644
--- a/elastic-job-lite-console/src/main/java/org/apache/shardingsphere/elasticjob/lite/console/restful/config/RegistryCenterRESTfulAPI.java
+++ b/elastic-job-lite-console/src/main/java/org/apache/shardingsphere/elasticjob/lite/console/restful/config/RegistryCenterRESTfulAPI.java
@@ -60,8 +60,8 @@ public final class RegistryCenterRESTfulAPI {
     }
     
     /**
-     * 读取注册中心配置集合.
-     * 
+     * load configuration from registry center
+     *
      * @param request HTTP request
      * @return registry center configurations
      */
@@ -76,7 +76,7 @@ public final class RegistryCenterRESTfulAPI {
     }
     
     /**
-     * 添加注册中心.
+     * add registry center
      * 
      * @param config registry center configuration
      * @return success to add or not
diff --git a/elastic-job-lite-core/src/main/java/org/apache/shardingsphere/elasticjob/lite/api/JobScheduler.java b/elastic-job-lite-core/src/main/java/org/apache/shardingsphere/elasticjob/lite/api/JobScheduler.java
index 70cc1dd..d01326d 100644
--- a/elastic-job-lite-core/src/main/java/org/apache/shardingsphere/elasticjob/lite/api/JobScheduler.java
+++ b/elastic-job-lite-core/src/main/java/org/apache/shardingsphere/elasticjob/lite/api/JobScheduler.java
@@ -60,7 +60,7 @@ public class JobScheduler {
     
     private final CoordinatorRegistryCenter regCenter;
     
-    // TODO 为测试使用,测试用例不能反复new monitor service,以后需要把MonitorService重构为单例
+    // TODO Test use only. Should not create monitor service repeatedly. Will refactor MonitorService as singleton service in the future
     @Getter
     private final SchedulerFacade schedulerFacade;
     
diff --git a/elastic-job-lite-core/src/main/java/org/apache/shardingsphere/elasticjob/lite/event/rdb/JobEventRdbSearch.java b/elastic-job-lite-core/src/main/java/org/apache/shardingsphere/elasticjob/lite/event/rdb/JobEventRdbSearch.java
index 6dddad8..c4c0606 100644
--- a/elastic-job-lite-core/src/main/java/org/apache/shardingsphere/elasticjob/lite/event/rdb/JobEventRdbSearch.java
+++ b/elastic-job-lite-core/src/main/java/org/apache/shardingsphere/elasticjob/lite/event/rdb/JobEventRdbSearch.java
@@ -97,7 +97,7 @@ public final class JobEventRdbSearch {
                 result.add(jobExecutionEvent);
             }
         } catch (final SQLException ex) {
-            // TODO 记录失败直接输出日志, 未来可考虑配置化
+            // TODO log failure directly to output log, consider to be configurable in the future
             log.error("Fetch JobExecutionEvent from DB error:", ex);
         }
         return result;
@@ -117,7 +117,7 @@ public final class JobEventRdbSearch {
                 result.add(jobStatusTraceEvent);
             }
         } catch (final SQLException ex) {
-            // TODO 记录失败直接输出日志, 未来可考虑配置化
+            // TODO log failure directly to output log, consider to be configurable in the future
             log.error("Fetch JobStatusTraceEvent from DB error:", ex);
         }
         return result;
@@ -133,7 +133,7 @@ public final class JobEventRdbSearch {
             resultSet.next();
             result = resultSet.getInt(1);
         } catch (final SQLException ex) {
-            // TODO 记录失败直接输出日志,未来可考虑配置化
+            // TODO log failure directly to output log, consider to be configurable in the future
             log.error("Fetch EventCount from DB error:", ex);
         }
         return result;
diff --git a/elastic-job-lite-core/src/main/java/org/apache/shardingsphere/elasticjob/lite/event/rdb/JobEventRdbStorage.java b/elastic-job-lite-core/src/main/java/org/apache/shardingsphere/elasticjob/lite/event/rdb/JobEventRdbStorage.java
index 96b2603..a194a6f 100644
--- a/elastic-job-lite-core/src/main/java/org/apache/shardingsphere/elasticjob/lite/event/rdb/JobEventRdbStorage.java
+++ b/elastic-job-lite-core/src/main/java/org/apache/shardingsphere/elasticjob/lite/event/rdb/JobEventRdbStorage.java
@@ -184,7 +184,7 @@ final class JobEventRdbStorage {
             result = true;
         } catch (final SQLException ex) {
             if (!isDuplicateRecord(ex)) {
-                // TODO 记录失败直接输出日志,未来可考虑配置化
+                // TODO log failure directly to output log, consider to be configurable in the future
                 log.error(ex.getMessage());    
             }
         }
@@ -211,7 +211,7 @@ final class JobEventRdbStorage {
             }
             result = true;
         } catch (final SQLException ex) {
-            // TODO 记录失败直接输出日志,未来可考虑配置化
+            // TODO log failure directly to output log, consider to be configurable in the future
             log.error(ex.getMessage());
         }
         return result;
@@ -240,7 +240,7 @@ final class JobEventRdbStorage {
             if (isDuplicateRecord(ex)) {
                 return updateJobExecutionEventWhenSuccess(jobExecutionEvent);
             }
-            // TODO 记录失败直接输出日志,未来可考虑配置化
+            // TODO log failure directly to output log, consider to be configurable in the future
             log.error(ex.getMessage());
         }
         return result;
@@ -261,7 +261,7 @@ final class JobEventRdbStorage {
             }
             result = true;
         } catch (final SQLException ex) {
-            // TODO 记录失败直接输出日志,未来可考虑配置化
+            // TODO log failure directly to output log, consider to be configurable in the future
             log.error(ex.getMessage());
         }
         return result;
@@ -290,7 +290,7 @@ final class JobEventRdbStorage {
             if (isDuplicateRecord(ex)) {
                 return updateJobExecutionEventFailure(jobExecutionEvent);
             }
-            // TODO 记录失败直接输出日志,未来可考虑配置化
+            // TODO log failure directly to output log, consider to be configurable in the future
             log.error(ex.getMessage());
         }
         return result;
@@ -321,7 +321,7 @@ final class JobEventRdbStorage {
             preparedStatement.execute();
             result = true;
         } catch (final SQLException ex) {
-            // TODO 记录失败直接输出日志,未来可考虑配置化
+            // TODO log failure directly to output log, consider to be configurable in the future
             log.error(ex.getMessage());
         }
         return result;
@@ -339,7 +339,7 @@ final class JobEventRdbStorage {
                 return resultSet.getString("original_task_id");
             }
         } catch (final SQLException ex) {
-            // TODO 记录失败直接输出日志,未来可考虑配置化
+            // TODO log failure directly to output log, consider to be configurable in the future
             log.error(ex.getMessage());
         }
         return result;
@@ -364,7 +364,7 @@ final class JobEventRdbStorage {
                 result.add(jobStatusTraceEvent);
             }
         } catch (final SQLException | ParseException ex) {
-            // TODO 记录失败直接输出日志,未来可考虑配置化
+            // TODO log failure directly to output log, consider to be configurable in the future
             log.error(ex.getMessage());
         }
         return result;
diff --git a/elastic-job-lite-core/src/main/java/org/apache/shardingsphere/elasticjob/lite/executor/AbstractElasticJobExecutor.java b/elastic-job-lite-core/src/main/java/org/apache/shardingsphere/elasticjob/lite/executor/AbstractElasticJobExecutor.java
index 8374cf9..b773c4d 100644
--- a/elastic-job-lite-core/src/main/java/org/apache/shardingsphere/elasticjob/lite/executor/AbstractElasticJobExecutor.java
+++ b/elastic-job-lite-core/src/main/java/org/apache/shardingsphere/elasticjob/lite/executor/AbstractElasticJobExecutor.java
@@ -90,7 +90,7 @@ public abstract class AbstractElasticJobExecutor {
     }
     
     /**
-     * 执行作业.
+     * execute job.
      */
     public final void execute() {
         try {
@@ -147,7 +147,7 @@ public abstract class AbstractElasticJobExecutor {
         try {
             process(shardingContexts, executionSource);
         } finally {
-            // TODO 考虑增加作业失败的状态,并且考虑如何处理作业失败的整体回路
+            // TODO Consider increasing the status of job failure, and how to handle the overall loop of job failure
             jobFacade.registerJobCompleted(shardingContexts);
             if (itemErrorMessages.isEmpty()) {
                 if (shardingContexts.isAllowSendJobEvent()) {
diff --git a/elastic-job-lite-core/src/main/java/org/apache/shardingsphere/elasticjob/lite/internal/config/ConfigurationService.java b/elastic-job-lite-core/src/main/java/org/apache/shardingsphere/elasticjob/lite/internal/config/ConfigurationService.java
index 7e9e9dd..f886ca5 100644
--- a/elastic-job-lite-core/src/main/java/org/apache/shardingsphere/elasticjob/lite/internal/config/ConfigurationService.java
+++ b/elastic-job-lite-core/src/main/java/org/apache/shardingsphere/elasticjob/lite/internal/config/ConfigurationService.java
@@ -85,7 +85,7 @@ public final class ConfigurationService {
         }
         LiteJobConfiguration result = LiteJobConfigurationGsonFactory.fromJson(jobNodeStorage.getJobNodeDataDirectly(ConfigurationNode.ROOT));
         if (null == result) {
-            // TODO 应该删除整个job node, 并非仅仅删除config node
+            // TODO should remove the job node, not only the config node
             jobNodeStorage.removeJobNodeIfExisted(ConfigurationNode.ROOT);
         }
         return Optional.ofNullable(result);
diff --git a/elastic-job-lite-core/src/main/java/org/apache/shardingsphere/elasticjob/lite/internal/failover/FailoverService.java b/elastic-job-lite-core/src/main/java/org/apache/shardingsphere/elasticjob/lite/internal/failover/FailoverService.java
index 2da3317..a153ec8 100644
--- a/elastic-job-lite-core/src/main/java/org/apache/shardingsphere/elasticjob/lite/internal/failover/FailoverService.java
+++ b/elastic-job-lite-core/src/main/java/org/apache/shardingsphere/elasticjob/lite/internal/failover/FailoverService.java
@@ -157,7 +157,7 @@ public final class FailoverService {
             log.debug("Failover job '{}' begin, crashed item '{}'", jobName, crashedItem);
             jobNodeStorage.fillEphemeralJobNode(FailoverNode.getExecutionFailoverNode(crashedItem), JobRegistry.getInstance().getJobInstance(jobName).getJobInstanceId());
             jobNodeStorage.removeJobNodeIfExisted(FailoverNode.getItemsNode(crashedItem));
-            // TODO 不应使用triggerJob, 而是使用executor统一调度
+            // TODO Instead of using triggerJob, use executor for unified scheduling
             JobScheduleController jobScheduleController = JobRegistry.getInstance().getJobScheduleController(jobName);
             if (null != jobScheduleController) {
                 jobScheduleController.triggerJob();
diff --git a/elastic-job-lite-core/src/main/java/org/apache/shardingsphere/elasticjob/lite/internal/instance/TriggerListenerManager.java b/elastic-job-lite-core/src/main/java/org/apache/shardingsphere/elasticjob/lite/internal/instance/TriggerListenerManager.java
index 78a1390..e16055a 100644
--- a/elastic-job-lite-core/src/main/java/org/apache/shardingsphere/elasticjob/lite/internal/instance/TriggerListenerManager.java
+++ b/elastic-job-lite-core/src/main/java/org/apache/shardingsphere/elasticjob/lite/internal/instance/TriggerListenerManager.java
@@ -55,7 +55,7 @@ public final class TriggerListenerManager extends AbstractListenerManager {
             }
             instanceService.clearTriggerFlag();
             if (!JobRegistry.getInstance().isShutdown(jobName) && !JobRegistry.getInstance().isJobRunning(jobName)) {
-                // TODO 目前是作业运行时不能触发, 未来改为堆积式触发
+                // TODO At present, it cannot be triggered when the job is running, and it will be changed to a stacked trigger in the future.
                 JobRegistry.getInstance().getJobScheduleController(jobName).triggerJob();
             }
         }
diff --git a/elastic-job-lite-core/src/main/java/org/apache/shardingsphere/elasticjob/lite/reg/zookeeper/ZookeeperRegistryCenter.java b/elastic-job-lite-core/src/main/java/org/apache/shardingsphere/elasticjob/lite/reg/zookeeper/ZookeeperRegistryCenter.java
index e051e97..c87da46 100644
--- a/elastic-job-lite-core/src/main/java/org/apache/shardingsphere/elasticjob/lite/reg/zookeeper/ZookeeperRegistryCenter.java
+++ b/elastic-job-lite-core/src/main/java/org/apache/shardingsphere/elasticjob/lite/reg/zookeeper/ZookeeperRegistryCenter.java
@@ -115,10 +115,9 @@ public final class ZookeeperRegistryCenter implements CoordinatorRegistryCenter
         CloseableUtils.closeQuietly(client);
     }
     
-    /* TODO 等待500ms, cache先关闭再关闭client, 否则会抛异常
-     * 因为异步处理, 可能会导致client先关闭而cache还未关闭结束.
-     * 等待Curator新版本解决这个bug.
-     * BUG地址:https://issues.apache.org/jira/browse/CURATOR-157
+    /*
+     * sleep 500ms, let cache client close first and then client, otherwise will throw exception
+     * reference:https://issues.apache.org/jira/browse/CURATOR-157
      */
     private void waitForCacheClose() {
         try {
diff --git a/elastic-job-lite-core/src/main/java/org/apache/shardingsphere/elasticjob/lite/statistics/rdb/StatisticRdbRepository.java b/elastic-job-lite-core/src/main/java/org/apache/shardingsphere/elasticjob/lite/statistics/rdb/StatisticRdbRepository.java
index a08728f..93aa1bd 100644
--- a/elastic-job-lite-core/src/main/java/org/apache/shardingsphere/elasticjob/lite/statistics/rdb/StatisticRdbRepository.java
+++ b/elastic-job-lite-core/src/main/java/org/apache/shardingsphere/elasticjob/lite/statistics/rdb/StatisticRdbRepository.java
@@ -174,7 +174,7 @@ public class StatisticRdbRepository {
             preparedStatement.execute();
             result = true;
         } catch (final SQLException ex) {
-            // TODO 记录失败直接输出日志,未来可考虑配置化
+            // TODO log failure directly to output log, consider to be configurable in the future
             log.error("Insert taskResultStatistics to DB error:", ex);
         }
         return result;
@@ -198,7 +198,7 @@ public class StatisticRdbRepository {
             preparedStatement.execute();
             result = true;
         } catch (final SQLException ex) {
-            // TODO 记录失败直接输出日志,未来可考虑配置化
+            // TODO log failure directly to output log, consider to be configurable in the future
             log.error("Insert taskRunningStatistics to DB error:", ex);
         }
         return result;
@@ -222,7 +222,7 @@ public class StatisticRdbRepository {
             preparedStatement.execute();
             result = true;
         } catch (final SQLException ex) {
-            // TODO 记录失败直接输出日志,未来可考虑配置化
+            // TODO log failure directly to output log, consider to be configurable in the future
             log.error("Insert jobRunningStatistics to DB error:", ex);
         }
         return result;
@@ -246,7 +246,7 @@ public class StatisticRdbRepository {
             preparedStatement.execute();
             result = true;
         } catch (final SQLException ex) {
-            // TODO 记录失败直接输出日志,未来可考虑配置化
+            // TODO log failure directly to output log, consider to be configurable in the future
             log.error("Insert jobRegisterStatistics to DB error:", ex);
         }
         return result;
@@ -275,7 +275,7 @@ public class StatisticRdbRepository {
                 result.add(taskResultStatistics);
             }
         } catch (final SQLException ex) {
-            // TODO 记录失败直接输出日志,未来可考虑配置化
+            // TODO log failure directly to output log, consider to be configurable in the future
             log.error("Fetch taskResultStatistics from DB error:", ex);
         }
         return result;
@@ -302,7 +302,7 @@ public class StatisticRdbRepository {
                 result = new TaskResultStatistics(resultSet.getInt(1), resultSet.getInt(2), statisticInterval, new Date());
             }
         } catch (final SQLException ex) {
-            // TODO 记录失败直接输出日志,未来可考虑配置化
+            // TODO log failure directly to output log, consider to be configurable in the future
             log.error("Fetch summed taskResultStatistics from DB error:", ex);
         }
         return result;
@@ -328,7 +328,7 @@ public class StatisticRdbRepository {
                         statisticInterval, new Date(resultSet.getTimestamp(4).getTime()), new Date(resultSet.getTimestamp(5).getTime()));
             }
         } catch (final SQLException ex) {
-            // TODO 记录失败直接输出日志,未来可考虑配置化
+            // TODO log failure directly to output log, consider to be configurable in the future
             log.error("Fetch latest taskResultStatistics from DB error:", ex);
         }
         return Optional.ofNullable(result);
@@ -356,7 +356,7 @@ public class StatisticRdbRepository {
                 result.add(taskRunningStatistics);
             }
         } catch (final SQLException ex) {
-            // TODO 记录失败直接输出日志,未来可考虑配置化
+            // TODO log failure directly to output log, consider to be configurable in the future
             log.error("Fetch taskRunningStatistics from DB error:", ex);
         }
         return result;
@@ -384,7 +384,7 @@ public class StatisticRdbRepository {
                 result.add(jobRunningStatistics);
             }
         } catch (final SQLException ex) {
-            // TODO 记录失败直接输出日志,未来可考虑配置化
+            // TODO log failure directly to output log, consider to be configurable in the future
             log.error("Fetch jobRunningStatistics from DB error:", ex);
         }
         return result;
@@ -409,7 +409,7 @@ public class StatisticRdbRepository {
                         new Date(resultSet.getTimestamp(3).getTime()), new Date(resultSet.getTimestamp(4).getTime()));
             }
         } catch (final SQLException ex) {
-            // TODO 记录失败直接输出日志,未来可考虑配置化
+            // TODO log failure directly to output log, consider to be configurable in the future
             log.error("Fetch latest taskRunningStatistics from DB error:", ex);
         }
         return Optional.ofNullable(result);
@@ -434,7 +434,7 @@ public class StatisticRdbRepository {
                         new Date(resultSet.getTimestamp(3).getTime()), new Date(resultSet.getTimestamp(4).getTime()));
             }
         } catch (final SQLException ex) {
-            // TODO 记录失败直接输出日志,未来可考虑配置化
+            // TODO log failure directly to output log, consider to be configurable in the future
             log.error("Fetch latest jobRunningStatistics from DB error:", ex);
         }
         return Optional.ofNullable(result);
@@ -462,7 +462,7 @@ public class StatisticRdbRepository {
                 result.add(jobRegisterStatistics);
             }
         } catch (final SQLException ex) {
-            // TODO 记录失败直接输出日志,未来可考虑配置化
+            // TODO log failure directly to output log, consider to be configurable in the future
             log.error("Fetch jobRegisterStatistics from DB error:", ex);
         }
         return result;
@@ -487,7 +487,7 @@ public class StatisticRdbRepository {
                         new Date(resultSet.getTimestamp(3).getTime()), new Date(resultSet.getTimestamp(4).getTime()));
             }
         } catch (final SQLException ex) {
-            // TODO 记录失败直接输出日志,未来可考虑配置化
+            // TODO log failure directly to output log, consider to be configurable in the future
             log.error("Fetch latest jobRegisterStatistics from DB error:", ex);
         }
         return Optional.ofNullable(result);
diff --git a/elastic-job-lite-core/src/main/java/org/apache/shardingsphere/elasticjob/lite/util/config/ShardingItemParameters.java b/elastic-job-lite-core/src/main/java/org/apache/shardingsphere/elasticjob/lite/util/config/ShardingItemParameters.java
index bfd1fa3..6c67205 100644
--- a/elastic-job-lite-core/src/main/java/org/apache/shardingsphere/elasticjob/lite/util/config/ShardingItemParameters.java
+++ b/elastic-job-lite-core/src/main/java/org/apache/shardingsphere/elasticjob/lite/util/config/ShardingItemParameters.java
@@ -68,7 +68,7 @@ public final class ShardingItemParameters {
     }
     
     /**
-     * 分片项.
+     * sharding item.
      */
     @AllArgsConstructor
     private static final class ShardingItem {
diff --git a/elastic-job-lite-spring/src/main/java/org/apache/shardingsphere/elasticjob/lite/spring/job/parser/common/AbstractJobBeanDefinitionParser.java b/elastic-job-lite-spring/src/main/java/org/apache/shardingsphere/elasticjob/lite/spring/job/parser/common/AbstractJobBeanDefinitionParser.java
index 94bdab0..7b288cb 100644
--- a/elastic-job-lite-spring/src/main/java/org/apache/shardingsphere/elasticjob/lite/spring/job/parser/common/AbstractJobBeanDefinitionParser.java
+++ b/elastic-job-lite-spring/src/main/java/org/apache/shardingsphere/elasticjob/lite/spring/job/parser/common/AbstractJobBeanDefinitionParser.java
@@ -44,7 +44,7 @@ public abstract class AbstractJobBeanDefinitionParser extends AbstractBeanDefini
     protected AbstractBeanDefinition parseInternal(final Element element, final ParserContext parserContext) {
         BeanDefinitionBuilder factory = BeanDefinitionBuilder.rootBeanDefinition(SpringJobScheduler.class);
         factory.setInitMethodName("init");
-        //TODO 抽象子类
+        //TODO abstract subclass
         if ("".equals(element.getAttribute(BaseJobBeanDefinitionParserTag.JOB_REF_ATTRIBUTE))) {
             if ("".equals(element.getAttribute(BaseJobBeanDefinitionParserTag.CLASS_ATTRIBUTE))) {
                 factory.addConstructorArgValue(null);
diff --git a/examples/elastic-job-example-embed-zk/src/main/java/com/dangdang/ddframe/job/example/EmbedZookeeperServer.java b/examples/elastic-job-example-embed-zk/src/main/java/com/dangdang/ddframe/job/example/EmbedZookeeperServer.java
index 03c944c..9e11ea0 100644
--- a/examples/elastic-job-example-embed-zk/src/main/java/com/dangdang/ddframe/job/example/EmbedZookeeperServer.java
+++ b/examples/elastic-job-example-embed-zk/src/main/java/com/dangdang/ddframe/job/example/EmbedZookeeperServer.java
@@ -23,10 +23,10 @@ import java.io.File;
 import java.io.IOException;
 
 /**
- * 内存版的内嵌Zookeeper.
+ * embed Zookeeper.
  * 
  * <p>
- *     仅用于运行Elastic-Job的例子时无需额外启动Zookeeper. 如有必要, 请使用本地环境可用的Zookeeper代替.
+ *     Only used for examples
  * </p>
  */
 public final class EmbedZookeeperServer {
@@ -34,9 +34,9 @@ public final class EmbedZookeeperServer {
     private static TestingServer testingServer;
     
     /**
-     * 内存版的内嵌Zookeeper.
+     * embed Zookeeper.
      * 
-     * @param port Zookeeper的通信端口号
+     * @param port Zookeeper port
      */
     public static void start(final int port) {
         try {