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/12 08:06:49 UTC

[shardingsphere-elastic-job-cloud] branch master updated: Rename the package to asf (#17) (#21)

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-cloud.git


The following commit(s) were added to refs/heads/master by this push:
     new bc0129a  Rename the package to asf (#17) (#21)
bc0129a is described below

commit bc0129a36f5803c54928f3b53d19898b85347a7f
Author: Tboy <gu...@immomo.com>
AuthorDate: Fri Jun 12 16:06:40 2020 +0800

    Rename the package to asf (#17) (#21)
---
 README.md                                          |  2 +-
 docs/content/02-guide/local-executor.md            |  4 +-
 .../elasticjob/cloud/api/ElasticJob.java           |  2 +-
 .../elasticjob/cloud/api/JobType.java              |  2 +-
 .../elasticjob/cloud/api/ShardingContext.java      |  4 +-
 .../elasticjob/cloud/api/dataflow/DataflowJob.java |  6 +--
 .../elasticjob/cloud/api/script/ScriptJob.java     |  4 +-
 .../elasticjob/cloud/api/simple/SimpleJob.java     |  6 +--
 .../cloud/config/JobCoreConfiguration.java         |  4 +-
 .../cloud/config/JobRootConfiguration.java         |  2 +-
 .../cloud/config/JobTypeConfiguration.java         |  4 +-
 .../config/dataflow/DataflowJobConfiguration.java  |  8 ++--
 .../config/script/ScriptJobConfiguration.java      | 10 ++---
 .../config/simple/SimpleJobConfiguration.java      |  8 ++--
 .../elasticjob/cloud/context/ExecutionType.java    |  2 +-
 .../elasticjob/cloud/context/TaskContext.java      |  2 +-
 .../elasticjob/cloud/event/JobEvent.java           |  2 +-
 .../elasticjob/cloud/event/JobEventBus.java        |  4 +-
 .../cloud/event/JobEventConfiguration.java         |  2 +-
 .../elasticjob/cloud/event/JobEventIdentity.java   |  2 +-
 .../elasticjob/cloud/event/JobEventListener.java   |  6 +--
 .../JobEventListenerConfigurationException.java    |  2 +-
 .../elasticjob/cloud/event/rdb/DatabaseType.java   |  2 +-
 .../cloud/event/rdb/JobEventRdbConfiguration.java  |  8 ++--
 .../cloud/event/rdb/JobEventRdbIdentity.java       |  4 +-
 .../cloud/event/rdb/JobEventRdbListener.java       |  8 ++--
 .../cloud/event/rdb/JobEventRdbSearch.java         | 18 ++++----
 .../cloud/event/rdb/JobEventRdbStorage.java        |  8 ++--
 .../cloud/event/type/JobExecutionEvent.java        |  8 ++--
 .../event/type/JobExecutionEventThrowable.java     |  2 +-
 .../cloud/event/type/JobStatusTraceEvent.java      |  6 +--
 .../cloud/exception/AppConfigurationException.java |  2 +-
 .../elasticjob/cloud/exception/ExceptionUtil.java  |  2 +-
 .../cloud/exception/JobConfigurationException.java |  2 +-
 .../JobExecutionEnvironmentException.java          |  2 +-
 .../cloud/exception/JobStatisticException.java     |  2 +-
 .../cloud/exception/JobSystemException.java        |  2 +-
 .../cloud/executor/AbstractElasticJobExecutor.java | 24 +++++------
 .../cloud/executor/JobExecutorFactory.java         | 16 +++----
 .../elasticjob/cloud/executor/JobFacade.java       | 10 ++---
 .../cloud/executor/ShardingContexts.java           |  2 +-
 .../executor/handler/ExecutorServiceHandler.java   |  2 +-
 .../handler/ExecutorServiceHandlerRegistry.java    |  2 +-
 .../executor/handler/JobExceptionHandler.java      |  2 +-
 .../cloud/executor/handler/JobProperties.java      |  8 ++--
 .../impl/DefaultExecutorServiceHandler.java        |  6 +--
 .../handler/impl/DefaultJobExceptionHandler.java   |  4 +-
 .../cloud/executor/type/DataflowJobExecutor.java   | 12 +++---
 .../cloud/executor/type/ScriptJobExecutor.java     | 14 +++---
 .../cloud/executor/type/SimpleJobExecutor.java     | 10 ++---
 .../cloud/reg/base/CoordinatorRegistryCenter.java  |  2 +-
 .../cloud/reg/base/ElectionCandidate.java          |  2 +-
 .../elasticjob/cloud/reg/base/RegistryCenter.java  |  2 +-
 .../cloud/reg/exception/RegException.java          |  2 +-
 .../cloud/reg/exception/RegExceptionHandler.java   |  2 +-
 .../reg/zookeeper/ZookeeperConfiguration.java      |  2 +-
 .../reg/zookeeper/ZookeeperElectionService.java    |  6 +--
 .../reg/zookeeper/ZookeeperRegistryCenter.java     |  6 +--
 .../cloud/statistics/StatisticInterval.java        |  2 +-
 .../statistics/rdb/StatisticRdbRepository.java     | 12 +++---
 .../type/job/JobExecutionTypeStatistics.java       |  2 +-
 .../statistics/type/job/JobRegisterStatistics.java |  2 +-
 .../statistics/type/job/JobRunningStatistics.java  |  2 +-
 .../statistics/type/job/JobTypeStatistics.java     |  2 +-
 .../statistics/type/task/TaskResultStatistics.java |  4 +-
 .../type/task/TaskRunningStatistics.java           |  2 +-
 .../cloud/util/concurrent/BlockUtils.java          |  2 +-
 .../util/concurrent/ExecutorServiceObject.java     |  2 +-
 .../cloud/util/config/ShardingItemParameters.java  |  4 +-
 .../cloud/util/config/ShardingItems.java           |  2 +-
 .../elasticjob/cloud/util/digest/Encryption.java   |  4 +-
 .../elasticjob/cloud/util/env/HostException.java   |  2 +-
 .../elasticjob/cloud/util/env/IpUtils.java         |  2 +-
 .../elasticjob/cloud/util/env/TimeService.java     |  2 +-
 .../AbstractJobConfigurationGsonTypeAdapter.java   | 18 ++++----
 .../elasticjob/cloud/util/json/GsonFactory.java    |  2 +-
 .../elasticjob/cloud/AllCoreTests.java             | 28 ++++++------
 .../elasticjob/cloud/api/AllApiTests.java          |  2 +-
 .../elasticjob/cloud/api/ShardingContextTest.java  |  6 +--
 .../elasticjob/cloud/config/AllConfigTests.java    |  2 +-
 .../cloud/config/JobCoreConfigurationTest.java     |  8 ++--
 .../elasticjob/cloud/context/AllContextTests.java  |  2 +-
 .../elasticjob/cloud/context/TaskContextTest.java  |  4 +-
 .../elasticjob/cloud/event/AllEventTests.java      | 16 +++----
 .../elasticjob/cloud/event/JobEventBusTest.java    | 12 +++---
 .../cloud/event/JobExecutionEventTest.java         |  4 +-
 .../cloud/event/fixture/JobEventCaller.java        |  2 +-
 .../event/fixture/TestJobEventConfiguration.java   |  8 ++--
 .../fixture/TestJobEventFailureConfiguration.java  |  8 ++--
 .../cloud/event/fixture/TestJobEventIdentity.java  |  4 +-
 .../cloud/event/fixture/TestJobEventListener.java  |  8 ++--
 .../event/rdb/JobEventRdbConfigurationTest.java    |  4 +-
 .../cloud/event/rdb/JobEventRdbIdentityTest.java   |  2 +-
 .../cloud/event/rdb/JobEventRdbListenerTest.java   | 12 +++---
 .../cloud/event/rdb/JobEventRdbSearchTest.java     |  8 ++--
 .../cloud/event/rdb/JobEventRdbStorageTest.java    |  8 ++--
 .../cloud/exception/AllExceptionTests.java         |  2 +-
 .../cloud/exception/ExceptionUtilTest.java         |  2 +-
 .../exception/JobConfigurationExceptionTest.java   |  2 +-
 .../JobExecutionEnvironmentExceptionTest.java      |  2 +-
 .../cloud/exception/JobStatisticExceptionTest.java |  2 +-
 .../cloud/exception/JobSystemExceptionTest.java    |  2 +-
 .../cloud/executor/AllExecutorTests.java           | 20 ++++-----
 .../cloud/executor/JobExecutorFactoryTest.java     | 24 +++++------
 .../ExecutorServiceHandlerRegistryTest.java        |  4 +-
 .../cloud/executor/handler/JobPropertiesTest.java  | 10 ++---
 .../impl/DefaultJobExceptionHandlerTest.java       |  4 +-
 .../executor/type/DataflowJobExecutorTest.java     | 14 +++---
 .../cloud/executor/type/ElasticJobVerify.java      | 10 ++---
 .../cloud/executor/type/ScriptJobExecutorTest.java | 16 +++----
 .../cloud/executor/type/SimpleJobExecutorTest.java | 26 +++++------
 .../cloud/executor/type/WrongJobExecutorTest.java  | 12 +++---
 .../elasticjob/cloud/fixture/APIJsonConstants.java | 10 ++---
 .../cloud/fixture/EmbedTestingServer.java          |  4 +-
 .../cloud/fixture/ShardingContextsBuilder.java     |  4 +-
 .../config/TestDataflowJobConfiguration.java       | 18 ++++----
 .../fixture/config/TestJobRootConfiguration.java   |  6 +--
 .../fixture/config/TestScriptJobConfiguration.java | 16 +++----
 .../fixture/config/TestSimpleJobConfiguration.java | 18 ++++----
 .../elasticjob/cloud/fixture/context/TaskNode.java |  4 +-
 .../fixture/handler/IgnoreJobExceptionHandler.java |  4 +-
 .../fixture/handler/ThrowJobExceptionHandler.java  |  6 +--
 .../elasticjob/cloud/fixture/job/JobCaller.java    |  2 +-
 .../elasticjob/cloud/fixture/job/OtherJob.java     |  4 +-
 .../cloud/fixture/job/TestDataflowJob.java         |  6 +--
 .../cloud/fixture/job/TestSimpleJob.java           |  6 +--
 .../elasticjob/cloud/fixture/job/TestWrongJob.java |  6 +--
 .../elasticjob/cloud/reg/AllRegTests.java          | 20 ++++-----
 .../reg/exception/RegExceptionHandlerTest.java     |  2 +-
 .../reg/zookeeper/ZookeeperConfigurationTest.java  |  2 +-
 .../zookeeper/ZookeeperElectionServiceTest.java    |  6 +--
 .../ZookeeperRegistryCenterForAuthTest.java        |  6 +--
 .../ZookeeperRegistryCenterInitFailureTest.java    |  4 +-
 .../ZookeeperRegistryCenterMiscellaneousTest.java  |  4 +-
 .../ZookeeperRegistryCenterModifyTest.java         |  6 +--
 .../ZookeeperRegistryCenterQueryWithCacheTest.java |  6 +--
 ...okeeperRegistryCenterQueryWithoutCacheTest.java |  6 +--
 .../util/ZookeeperRegistryCenterTestUtil.java      |  4 +-
 .../cloud/statistics/AllStatisticsTests.java       |  4 +-
 .../statistics/rdb/StatisticRdbRepositoryTest.java | 12 +++---
 .../elasticjob/cloud/util/AllUtilTests.java        | 36 ++++++++--------
 .../util/concurrent/ExecutorServiceObjectTest.java |  2 +-
 .../util/config/ShardingItemParametersTest.java    |  4 +-
 .../cloud/util/config/ShardingItemsTest.java       |  2 +-
 .../cloud/util/digest/EncryptionTest.java          |  2 +-
 .../cloud/util/env/HostExceptionTest.java          |  2 +-
 .../elasticjob/cloud/util/env/IpUtilsTest.java     |  2 +-
 .../elasticjob/cloud/util/env/TimeServiceTest.java |  2 +-
 .../cloud/util/json/GsonFactoryTest.java           |  2 +-
 .../json/JobConfigurationGsonTypeAdapterTest.java  | 20 ++++-----
 .../src/test/resources/logback-test.xml            |  6 +--
 .../elasticjob/cloud/api/JobBootstrap.java         |  4 +-
 .../elasticjob/cloud/executor/CloudJobFacade.java  | 16 +++----
 .../cloud/executor/DaemonTaskScheduler.java        |  8 ++--
 .../cloud/executor/JobConfigurationContext.java    | 18 ++++----
 .../elasticjob/cloud/executor/TaskExecutor.java    | 16 +++----
 .../executor/local/LocalCloudJobConfiguration.java |  6 +--
 .../cloud/executor/local/LocalTaskExecutor.java    | 36 ++++++++--------
 .../cloud/executor/AllCloudExecutorTests.java      |  4 +-
 .../cloud/executor/CloudJobFacadeTest.java         | 18 ++++----
 .../cloud/executor/DaemonTaskSchedulerTest.java    |  6 +--
 .../executor/JobConfigurationContextTest.java      | 14 +++---
 .../cloud/executor/TaskExecutorTest.java           |  2 +-
 .../cloud/executor/TaskExecutorThreadTest.java     | 12 +++---
 .../elasticjob/cloud/executor/fixture/TestJob.java |  6 +--
 .../fixture/TestScriptJobConfiguration.java        | 12 +++---
 .../executor/local/AllLocalExecutorTests.java      |  2 +-
 .../executor/local/LocalTaskExecutorTest.java      | 16 +++----
 .../executor/local/fixture/TestDataflowJob.java    |  6 +--
 .../executor/local/fixture/TestSimpleJob.java      |  6 +--
 .../src/test/resources/applicationContext.xml      |  4 +-
 .../src/test/resources/logback-test.xml            |  2 +-
 .../elasticjob/cloud/restful/GsonJsonProvider.java |  4 +-
 .../elasticjob/cloud/restful/RestfulException.java |  2 +-
 .../cloud/restful/RestfulExceptionMapper.java      |  4 +-
 .../elasticjob/cloud/restful/RestfulServer.java    |  2 +-
 .../elasticjob/cloud/scheduler/Bootstrap.java      | 14 +++---
 .../config/app/CloudAppConfiguration.java          |  2 +-
 .../app/CloudAppConfigurationGsonFactory.java      |  6 +--
 .../config/app/CloudAppConfigurationNode.java      |  2 +-
 .../config/app/CloudAppConfigurationService.java   |  4 +-
 .../constants/CloudConfigurationConstants.java     |  2 +-
 .../config/job/CloudJobConfiguration.java          |  6 +--
 .../job/CloudJobConfigurationGsonFactory.java      | 10 ++---
 .../config/job/CloudJobConfigurationListener.java  |  8 ++--
 .../config/job/CloudJobConfigurationNode.java      |  2 +-
 .../config/job/CloudJobConfigurationService.java   |  4 +-
 .../config/job/CloudJobExecutionType.java          |  2 +-
 .../cloud/scheduler/context/JobContext.java        |  6 +--
 .../cloud/scheduler/env/BootstrapEnvironment.java  |  6 +--
 .../scheduler/env/FrameworkConfiguration.java      |  2 +-
 .../cloud/scheduler/env/MesosConfiguration.java    |  2 +-
 .../scheduler/env/RestfulServerConfiguration.java  |  2 +-
 .../cloud/scheduler/ha/FrameworkIDService.java     |  4 +-
 .../elasticjob/cloud/scheduler/ha/HANode.java      |  2 +-
 .../scheduler/ha/SchedulerElectionCandidate.java   | 10 ++---
 .../scheduler/mesos/AppConstraintEvaluator.java    |  8 ++--
 .../cloud/scheduler/mesos/FacadeService.java       | 32 +++++++-------
 .../cloud/scheduler/mesos/JobTaskRequest.java      |  6 +--
 .../cloud/scheduler/mesos/LaunchingTasks.java      |  8 ++--
 .../cloud/scheduler/mesos/LeasesQueue.java         |  2 +-
 .../cloud/scheduler/mesos/MesosStateService.java   |  6 +--
 .../cloud/scheduler/mesos/ReconcileService.java    |  8 ++--
 .../cloud/scheduler/mesos/SchedulerEngine.java     | 12 +++---
 .../cloud/scheduler/mesos/SchedulerService.java    | 22 +++++-----
 .../scheduler/mesos/SupportedExtractionType.java   |  2 +-
 .../cloud/scheduler/mesos/TaskInfoData.java        | 14 +++---
 .../mesos/TaskLaunchScheduledService.java          | 28 ++++++------
 .../cloud/scheduler/producer/ProducerManager.java  | 28 ++++++------
 .../producer/TransientProducerRepository.java      |  2 +-
 .../producer/TransientProducerScheduler.java       |  8 ++--
 .../scheduler/restful/CloudAppRestfulApi.java      | 26 +++++------
 .../scheduler/restful/CloudJobRestfulApi.java      | 50 +++++++++++-----------
 .../restful/CloudOperationRestfulApi.java          |  8 ++--
 .../cloud/scheduler/restful/RestfulService.java    | 14 +++---
 .../cloud/scheduler/state/StateNode.java           |  2 +-
 .../state/disable/app/DisableAppNode.java          |  4 +-
 .../state/disable/app/DisableAppService.java       |  6 +--
 .../state/disable/job/DisableJobNode.java          |  4 +-
 .../state/disable/job/DisableJobService.java       |  6 +--
 .../scheduler/state/failover/FailoverNode.java     |  6 +--
 .../scheduler/state/failover/FailoverService.java  | 18 ++++----
 .../scheduler/state/failover/FailoverTaskInfo.java |  4 +-
 .../cloud/scheduler/state/ready/ReadyNode.java     |  4 +-
 .../cloud/scheduler/state/ready/ReadyService.java  | 18 ++++----
 .../cloud/scheduler/state/running/RunningNode.java |  6 +--
 .../scheduler/state/running/RunningService.java    | 12 +++---
 .../scheduler/statistics/StatisticManager.java     | 38 ++++++++--------
 .../scheduler/statistics/StatisticsScheduler.java  |  6 +--
 .../scheduler/statistics/TaskResultMetaData.java   |  2 +-
 .../statistics/job/AbstractStatisticJob.java       |  6 +--
 .../statistics/job/JobRunningStatisticJob.java     | 18 ++++----
 .../statistics/job/RegisteredJobStatisticJob.java  | 12 +++---
 .../scheduler/statistics/job/StatisticJob.java     |  2 +-
 .../statistics/job/TaskResultStatisticJob.java     | 12 +++---
 .../statistics/util/StatisticTimeUtils.java        |  4 +-
 .../elasticjob/cloud/security/WwwAuthFilter.java   |  2 +-
 .../src/main/resources/bin/dcos.sh                 |  2 +-
 .../src/main/resources/bin/start.sh                |  2 +-
 .../shardingsphere}/elasticjob/cloud/AllTests.java |  8 ++--
 .../elasticjob/cloud/restful/AllRestfulTests.java  |  2 +-
 .../cloud/restful/RestfulExceptionTest.java        |  2 +-
 .../cloud/restful/RestfulServerTest.java           |  8 ++--
 .../elasticjob/cloud/restful/fixture/Caller.java   |  2 +-
 .../cloud/restful/fixture/TestFilter.java          |  2 +-
 .../cloud/restful/fixture/TestRestfulApi.java      |  2 +-
 .../cloud/scheduler/AllCloudSchedulerTests.java    | 20 ++++-----
 .../cloud/scheduler/config/AllConfigTests.java     |  6 +--
 .../config/app/AllCloudAppConfigTests.java         |  2 +-
 .../config/app/CloudAppConfigurationNodeTest.java  |  2 +-
 .../app/CloudAppConfigurationServiceTest.java      |  8 ++--
 .../config/job/AllCloudJobConfigTests.java         |  2 +-
 .../job/CloudJobConfigurationListenerTest.java     |  8 ++--
 .../config/job/CloudJobConfigurationNodeTest.java  |  2 +-
 .../job/CloudJobConfigurationServiceTest.java      |  8 ++--
 .../cloud/scheduler/context/AllContextTests.java   |  2 +-
 .../cloud/scheduler/context/JobContextTest.java    |  8 ++--
 .../cloud/scheduler/env/AllEnvTests.java           |  2 +-
 .../scheduler/env/BootstrapEnvironmentTest.java    |  6 +--
 .../fixture/CloudAppConfigurationBuilder.java      |  4 +-
 .../scheduler/fixture/CloudAppJsonConstants.java   |  2 +-
 .../fixture/CloudJobConfigurationBuilder.java      | 18 ++++----
 .../scheduler/fixture/CloudJsonConstants.java      | 12 +++---
 .../scheduler/fixture/EmbedTestingServer.java      |  4 +-
 .../cloud/scheduler/fixture/TaskNode.java          |  6 +--
 .../cloud/scheduler/fixture/TestSimpleJob.java     |  6 +--
 .../elasticjob/cloud/scheduler/ha/AllHATests.java  |  2 +-
 .../cloud/scheduler/ha/FrameworkIDServiceTest.java |  4 +-
 .../cloud/scheduler/mesos/AllMesosTests.java       |  4 +-
 .../mesos/AppConstraintEvaluatorTest.java          | 14 +++---
 .../cloud/scheduler/mesos/FacadeServiceTest.java   | 38 ++++++++--------
 .../cloud/scheduler/mesos/JobTaskRequestTest.java  |  8 ++--
 .../cloud/scheduler/mesos/LaunchingTasksTest.java  | 18 ++++----
 .../cloud/scheduler/mesos/LeasesQueueTest.java     |  4 +-
 .../scheduler/mesos/MesosStateServiceTest.java     |  8 ++--
 .../scheduler/mesos/ReconcileServiceTest.java      |  4 +-
 .../cloud/scheduler/mesos/SchedulerEngineTest.java | 20 ++++-----
 .../scheduler/mesos/SchedulerServiceTest.java      | 14 +++---
 .../mesos/SupportedExtractionTypeTest.java         |  2 +-
 .../cloud/scheduler/mesos/TaskInfoDataTest.java    |  6 +--
 .../mesos/TaskLaunchScheduledServiceTest.java      | 20 ++++-----
 .../scheduler/mesos/fixture/OfferBuilder.java      |  2 +-
 .../fixture/master/MesosMasterServerMock.java      |  2 +-
 .../mesos/fixture/slave/MesosSlaveServerMock.java  |  2 +-
 .../cloud/scheduler/producer/AllProducerTests.java |  2 +-
 .../cloud/scheduler/producer/ProducerJobTest.java  |  4 +-
 .../scheduler/producer/ProducerManagerTest.java    | 30 ++++++-------
 .../producer/TransientProducerRepositoryTest.java  |  2 +-
 .../producer/TransientProducerSchedulerTest.java   |  8 ++--
 .../restful/AbstractCloudRestfulApiTest.java       | 22 +++++-----
 .../cloud/scheduler/restful/AllRestfulTests.java   |  2 +-
 .../scheduler/restful/CloudAppRestfulApiTest.java  |  6 +--
 .../scheduler/restful/CloudJobRestfulApiTest.java  | 39 ++++++++---------
 .../restful/CloudOperationRestfulApiTest.java      |  4 +-
 .../cloud/scheduler/restful/RestfulTestsUtil.java  |  2 +-
 .../cloud/scheduler/state/AllStateTests.java       | 24 +++++------
 .../state/disable/app/DisableAppNodeTest.java      |  2 +-
 .../state/disable/app/DisableAppServiceTest.java   |  4 +-
 .../state/disable/job/DisableJobNodeTest.java      |  2 +-
 .../state/disable/job/DisableJobServiceTest.java   |  4 +-
 .../scheduler/state/failover/FailoverNodeTest.java |  6 +--
 .../state/failover/FailoverServiceTest.java        | 22 +++++-----
 .../cloud/scheduler/state/ready/ReadyNodeTest.java |  2 +-
 .../scheduler/state/ready/ReadyServiceTest.java    | 20 ++++-----
 .../scheduler/state/running/RunningNodeTest.java   |  4 +-
 .../state/running/RunningServiceTest.java          | 14 +++---
 .../scheduler/statistics/AllStatisticTests.java    | 16 +++----
 .../scheduler/statistics/StatisticManagerTest.java | 26 +++++------
 .../statistics/StatisticsSchedulerTest.java        |  6 +--
 .../statistics/TaskResultMetaDataTest.java         |  2 +-
 .../statistics/job/BaseStatisticJobTest.java       |  6 +--
 .../statistics/job/JobRunningStatisticJobTest.java | 18 ++++----
 .../job/RegisteredJobStatisticJobTest.java         | 14 +++---
 .../statistics/job/TaskResultStatisticJobTest.java | 12 +++---
 .../scheduler/statistics/job/TestStatisticJob.java |  4 +-
 .../statistics/util/StatisticTimeUtilsTest.java    |  5 +--
 .../src/test/resources/logback-test.xml            |  6 +--
 317 files changed, 1203 insertions(+), 1209 deletions(-)

diff --git a/README.md b/README.md
index 976920a..07c77b4 100644
--- a/README.md
+++ b/README.md
@@ -54,7 +54,7 @@ Elastic-Job-Lite and Elastic-Job-Cloud provide unified API. Developers only need
 ```xml
 <!-- import elastic-job cloud executor -->
 <dependency>
-    <groupId>io.elasticjob</groupId>
+    <groupId>org.apache.shardingsphere.elasticjob</groupId>
     <artifactId>elastic-job-cloud-executor</artifactId>
     <version>${lasted.release.version}</version>
 </dependency>
diff --git a/docs/content/02-guide/local-executor.md b/docs/content/02-guide/local-executor.md
index 91ee68c..0473cec 100644
--- a/docs/content/02-guide/local-executor.md
+++ b/docs/content/02-guide/local-executor.md
@@ -13,7 +13,7 @@ next = "/03-design"
 
 ## 配置
 
-使用`io.elasticjob.cloud.executor.local.LocalCloudJobConfiguration`配置本地作业。
+使用`org.apache.shardingsphere.elasticjob.cloud.executor.local.LocalCloudJobConfiguration`配置本地作业。
 
 ```java
 LocalCloudJobConfiguration config = new LocalCloudJobConfiguration(
@@ -30,7 +30,7 @@ LocalCloudJobConfiguration config = new LocalCloudJobConfiguration(
 
 ## 运行
 
-使用`io.elasticjob.cloud.executor.local.LocalTaskExecutor`运行作业。
+使用`org.apache.shardingsphere.elasticjob.cloud.executor.local.LocalTaskExecutor`运行作业。
 
 ```java
 new LocalTaskExecutor(localJobConfig).execute();
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/api/ElasticJob.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/api/ElasticJob.java
similarity index 94%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/api/ElasticJob.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/api/ElasticJob.java
index 613f20d..a4b30d3 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/api/ElasticJob.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/api/ElasticJob.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.api;
+package org.apache.shardingsphere.elasticjob.cloud.api;
 
 /**
  * 弹性化分布式作业标识接口.
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/api/JobType.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/api/JobType.java
similarity index 94%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/api/JobType.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/api/JobType.java
index 3b08da5..6753be9 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/api/JobType.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/api/JobType.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.api;
+package org.apache.shardingsphere.elasticjob.cloud.api;
 
 /**
  * 作业类型.
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/api/ShardingContext.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/api/ShardingContext.java
similarity index 93%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/api/ShardingContext.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/api/ShardingContext.java
index 8aa3295..5266524 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/api/ShardingContext.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/api/ShardingContext.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.api;
+package org.apache.shardingsphere.elasticjob.cloud.api;
 
-import io.elasticjob.cloud.executor.ShardingContexts;
+import org.apache.shardingsphere.elasticjob.cloud.executor.ShardingContexts;
 import lombok.Getter;
 import lombok.ToString;
 
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/api/dataflow/DataflowJob.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/api/dataflow/DataflowJob.java
similarity index 87%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/api/dataflow/DataflowJob.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/api/dataflow/DataflowJob.java
index 4b6924d..965bba0 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/api/dataflow/DataflowJob.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/api/dataflow/DataflowJob.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.api.dataflow;
+package org.apache.shardingsphere.elasticjob.cloud.api.dataflow;
 
-import io.elasticjob.cloud.api.ElasticJob;
-import io.elasticjob.cloud.api.ShardingContext;
+import org.apache.shardingsphere.elasticjob.cloud.api.ElasticJob;
+import org.apache.shardingsphere.elasticjob.cloud.api.ShardingContext;
 
 import java.util.List;
 
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/api/script/ScriptJob.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/api/script/ScriptJob.java
similarity index 87%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/api/script/ScriptJob.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/api/script/ScriptJob.java
index cd292ce..50df666 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/api/script/ScriptJob.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/api/script/ScriptJob.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.api.script;
+package org.apache.shardingsphere.elasticjob.cloud.api.script;
 
-import io.elasticjob.cloud.api.ElasticJob;
+import org.apache.shardingsphere.elasticjob.cloud.api.ElasticJob;
 
 /**
  * 脚本分布式作业接口.
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/api/simple/SimpleJob.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/api/simple/SimpleJob.java
similarity index 84%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/api/simple/SimpleJob.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/api/simple/SimpleJob.java
index caf55e4..584a15c 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/api/simple/SimpleJob.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/api/simple/SimpleJob.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.api.simple;
+package org.apache.shardingsphere.elasticjob.cloud.api.simple;
 
-import io.elasticjob.cloud.api.ElasticJob;
-import io.elasticjob.cloud.api.ShardingContext;
+import org.apache.shardingsphere.elasticjob.cloud.api.ElasticJob;
+import org.apache.shardingsphere.elasticjob.cloud.api.ShardingContext;
 
 /**
  * 简单分布式作业接口.
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/config/JobCoreConfiguration.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/config/JobCoreConfiguration.java
similarity index 97%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/config/JobCoreConfiguration.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/config/JobCoreConfiguration.java
index 8901769..495a0a1 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/config/JobCoreConfiguration.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/config/JobCoreConfiguration.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.config;
+package org.apache.shardingsphere.elasticjob.cloud.config;
 
 import com.google.common.base.Preconditions;
 import com.google.common.base.Strings;
-import io.elasticjob.cloud.executor.handler.JobProperties;
+import org.apache.shardingsphere.elasticjob.cloud.executor.handler.JobProperties;
 import lombok.AccessLevel;
 import lombok.AllArgsConstructor;
 import lombok.Getter;
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/config/JobRootConfiguration.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/config/JobRootConfiguration.java
similarity index 94%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/config/JobRootConfiguration.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/config/JobRootConfiguration.java
index 4b35e36..1c816a4 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/config/JobRootConfiguration.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/config/JobRootConfiguration.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.config;
+package org.apache.shardingsphere.elasticjob.cloud.config;
 
 /**
  * 作业配置根接口.
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/config/JobTypeConfiguration.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/config/JobTypeConfiguration.java
similarity index 91%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/config/JobTypeConfiguration.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/config/JobTypeConfiguration.java
index 35d05e1..8e49833 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/config/JobTypeConfiguration.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/config/JobTypeConfiguration.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.config;
+package org.apache.shardingsphere.elasticjob.cloud.config;
 
-import io.elasticjob.cloud.api.JobType;
+import org.apache.shardingsphere.elasticjob.cloud.api.JobType;
 
 /**
  * 作业类型配置.
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/config/dataflow/DataflowJobConfiguration.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/config/dataflow/DataflowJobConfiguration.java
similarity index 81%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/config/dataflow/DataflowJobConfiguration.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/config/dataflow/DataflowJobConfiguration.java
index a25c98f..562c926 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/config/dataflow/DataflowJobConfiguration.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/config/dataflow/DataflowJobConfiguration.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.config.dataflow;
+package org.apache.shardingsphere.elasticjob.cloud.config.dataflow;
 
-import io.elasticjob.cloud.api.JobType;
-import io.elasticjob.cloud.config.JobCoreConfiguration;
-import io.elasticjob.cloud.config.JobTypeConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.api.JobType;
+import org.apache.shardingsphere.elasticjob.cloud.config.JobCoreConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.config.JobTypeConfiguration;
 import lombok.Getter;
 import lombok.RequiredArgsConstructor;
 
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/config/script/ScriptJobConfiguration.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/config/script/ScriptJobConfiguration.java
similarity index 78%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/config/script/ScriptJobConfiguration.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/config/script/ScriptJobConfiguration.java
index 42c4f44..fa9e4c9 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/config/script/ScriptJobConfiguration.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/config/script/ScriptJobConfiguration.java
@@ -15,12 +15,12 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.config.script;
+package org.apache.shardingsphere.elasticjob.cloud.config.script;
 
-import io.elasticjob.cloud.api.JobType;
-import io.elasticjob.cloud.api.script.ScriptJob;
-import io.elasticjob.cloud.config.JobTypeConfiguration;
-import io.elasticjob.cloud.config.JobCoreConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.api.JobType;
+import org.apache.shardingsphere.elasticjob.cloud.api.script.ScriptJob;
+import org.apache.shardingsphere.elasticjob.cloud.config.JobTypeConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.config.JobCoreConfiguration;
 import lombok.Getter;
 import lombok.RequiredArgsConstructor;
 
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/config/simple/SimpleJobConfiguration.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/config/simple/SimpleJobConfiguration.java
similarity index 80%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/config/simple/SimpleJobConfiguration.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/config/simple/SimpleJobConfiguration.java
index 55c4329..4c92bdc 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/config/simple/SimpleJobConfiguration.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/config/simple/SimpleJobConfiguration.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.config.simple;
+package org.apache.shardingsphere.elasticjob.cloud.config.simple;
 
-import io.elasticjob.cloud.api.JobType;
-import io.elasticjob.cloud.config.JobCoreConfiguration;
-import io.elasticjob.cloud.config.JobTypeConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.api.JobType;
+import org.apache.shardingsphere.elasticjob.cloud.config.JobCoreConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.config.JobTypeConfiguration;
 import lombok.Getter;
 import lombok.RequiredArgsConstructor;
 
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/context/ExecutionType.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/context/ExecutionType.java
similarity index 94%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/context/ExecutionType.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/context/ExecutionType.java
index cb5fda2..a1cfcd2 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/context/ExecutionType.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/context/ExecutionType.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.context;
+package org.apache.shardingsphere.elasticjob.cloud.context;
 
 /**
  * 执行类型.
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/context/TaskContext.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/context/TaskContext.java
similarity index 98%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/context/TaskContext.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/context/TaskContext.java
index e22c5f4..465dcd3 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/context/TaskContext.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/context/TaskContext.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.context;
+package org.apache.shardingsphere.elasticjob.cloud.context;
 
 import com.google.common.base.Function;
 import com.google.common.base.Joiner;
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/event/JobEvent.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/event/JobEvent.java
similarity index 94%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/event/JobEvent.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/event/JobEvent.java
index 60b0c9f..e25edd5 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/event/JobEvent.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/event/JobEvent.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.event;
+package org.apache.shardingsphere.elasticjob.cloud.event;
 
 /**
  * 作业事件接口.
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/event/JobEventBus.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/event/JobEventBus.java
similarity index 94%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/event/JobEventBus.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/event/JobEventBus.java
index e8f0da6..10f3cc6 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/event/JobEventBus.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/event/JobEventBus.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.event;
+package org.apache.shardingsphere.elasticjob.cloud.event;
 
 import com.google.common.eventbus.AsyncEventBus;
 import com.google.common.eventbus.EventBus;
-import io.elasticjob.cloud.util.concurrent.ExecutorServiceObject;
+import org.apache.shardingsphere.elasticjob.cloud.util.concurrent.ExecutorServiceObject;
 import lombok.extern.slf4j.Slf4j;
 
 /**
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/event/JobEventConfiguration.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/event/JobEventConfiguration.java
similarity index 95%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/event/JobEventConfiguration.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/event/JobEventConfiguration.java
index 5abf49c..258c443 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/event/JobEventConfiguration.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/event/JobEventConfiguration.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.event;
+package org.apache.shardingsphere.elasticjob.cloud.event;
 
 /**
  * 作业事件配置标识接口.
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/event/JobEventIdentity.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/event/JobEventIdentity.java
similarity index 94%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/event/JobEventIdentity.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/event/JobEventIdentity.java
index 2872b57..ffc6d76 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/event/JobEventIdentity.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/event/JobEventIdentity.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.event;
+package org.apache.shardingsphere.elasticjob.cloud.event;
 
 /**
  * 作业事件标识.
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/event/JobEventListener.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/event/JobEventListener.java
similarity index 87%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/event/JobEventListener.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/event/JobEventListener.java
index 030f8ea..565d6c5 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/event/JobEventListener.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/event/JobEventListener.java
@@ -15,12 +15,12 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.event;
+package org.apache.shardingsphere.elasticjob.cloud.event;
 
 import com.google.common.eventbus.AllowConcurrentEvents;
 import com.google.common.eventbus.Subscribe;
-import io.elasticjob.cloud.event.type.JobExecutionEvent;
-import io.elasticjob.cloud.event.type.JobStatusTraceEvent;
+import org.apache.shardingsphere.elasticjob.cloud.event.type.JobExecutionEvent;
+import org.apache.shardingsphere.elasticjob.cloud.event.type.JobStatusTraceEvent;
 
 /**
  * 作业事件监听器.
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/event/JobEventListenerConfigurationException.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/event/JobEventListenerConfigurationException.java
similarity index 95%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/event/JobEventListenerConfigurationException.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/event/JobEventListenerConfigurationException.java
index 461222d..d755086 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/event/JobEventListenerConfigurationException.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/event/JobEventListenerConfigurationException.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.event;
+package org.apache.shardingsphere.elasticjob.cloud.event;
 
 /**
  * 作业事件监听器配置异常.
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/event/rdb/DatabaseType.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/event/rdb/DatabaseType.java
similarity index 97%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/event/rdb/DatabaseType.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/event/rdb/DatabaseType.java
index 7e408de..1efaf98 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/event/rdb/DatabaseType.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/event/rdb/DatabaseType.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.event.rdb;
+package org.apache.shardingsphere.elasticjob.cloud.event.rdb;
 
 import com.google.common.base.Optional;
 import com.google.common.base.Predicate;
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/event/rdb/JobEventRdbConfiguration.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/event/rdb/JobEventRdbConfiguration.java
similarity index 83%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/event/rdb/JobEventRdbConfiguration.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/event/rdb/JobEventRdbConfiguration.java
index 62b20bd..66ec1cc 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/event/rdb/JobEventRdbConfiguration.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/event/rdb/JobEventRdbConfiguration.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.event.rdb;
+package org.apache.shardingsphere.elasticjob.cloud.event.rdb;
 
-import io.elasticjob.cloud.event.JobEventConfiguration;
-import io.elasticjob.cloud.event.JobEventListener;
-import io.elasticjob.cloud.event.JobEventListenerConfigurationException;
+import org.apache.shardingsphere.elasticjob.cloud.event.JobEventConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.event.JobEventListener;
+import org.apache.shardingsphere.elasticjob.cloud.event.JobEventListenerConfigurationException;
 import lombok.Getter;
 import lombok.RequiredArgsConstructor;
 
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/event/rdb/JobEventRdbIdentity.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/event/rdb/JobEventRdbIdentity.java
similarity index 88%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/event/rdb/JobEventRdbIdentity.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/event/rdb/JobEventRdbIdentity.java
index 0544cd1..229c467 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/event/rdb/JobEventRdbIdentity.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/event/rdb/JobEventRdbIdentity.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.event.rdb;
+package org.apache.shardingsphere.elasticjob.cloud.event.rdb;
 
-import io.elasticjob.cloud.event.JobEventIdentity;
+import org.apache.shardingsphere.elasticjob.cloud.event.JobEventIdentity;
 
 /**
  * 关系型数据库作业事件标识.
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/event/rdb/JobEventRdbListener.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/event/rdb/JobEventRdbListener.java
similarity index 83%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/event/rdb/JobEventRdbListener.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/event/rdb/JobEventRdbListener.java
index 1e22666..04c1e16 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/event/rdb/JobEventRdbListener.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/event/rdb/JobEventRdbListener.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.event.rdb;
+package org.apache.shardingsphere.elasticjob.cloud.event.rdb;
 
-import io.elasticjob.cloud.event.JobEventListener;
-import io.elasticjob.cloud.event.type.JobExecutionEvent;
-import io.elasticjob.cloud.event.type.JobStatusTraceEvent;
+import org.apache.shardingsphere.elasticjob.cloud.event.JobEventListener;
+import org.apache.shardingsphere.elasticjob.cloud.event.type.JobExecutionEvent;
+import org.apache.shardingsphere.elasticjob.cloud.event.type.JobStatusTraceEvent;
 
 import javax.sql.DataSource;
 import java.sql.SQLException;
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/event/rdb/JobEventRdbSearch.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/event/rdb/JobEventRdbSearch.java
similarity index 94%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/event/rdb/JobEventRdbSearch.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/event/rdb/JobEventRdbSearch.java
index 629e602..a12446b 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/event/rdb/JobEventRdbSearch.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/event/rdb/JobEventRdbSearch.java
@@ -15,17 +15,15 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.event.rdb;
+package org.apache.shardingsphere.elasticjob.cloud.event.rdb;
 
 import com.google.common.base.CaseFormat;
 import com.google.common.base.Strings;
 import com.google.common.collect.Lists;
-import io.elasticjob.cloud.context.ExecutionType;
-import io.elasticjob.cloud.event.type.JobExecutionEvent;
-import io.elasticjob.cloud.event.type.JobExecutionEventThrowable;
-import io.elasticjob.cloud.event.type.JobStatusTraceEvent;
-import io.elasticjob.cloud.event.type.JobStatusTraceEvent.Source;
-import io.elasticjob.cloud.event.type.JobStatusTraceEvent.State;
+import org.apache.shardingsphere.elasticjob.cloud.context.ExecutionType;
+import org.apache.shardingsphere.elasticjob.cloud.event.type.JobExecutionEvent;
+import org.apache.shardingsphere.elasticjob.cloud.event.type.JobExecutionEventThrowable;
+import org.apache.shardingsphere.elasticjob.cloud.event.type.JobStatusTraceEvent;
 import lombok.Getter;
 import lombok.RequiredArgsConstructor;
 import lombok.extern.slf4j.Slf4j;
@@ -94,7 +92,7 @@ public final class JobEventRdbSearch {
                 JobExecutionEvent jobExecutionEvent = new JobExecutionEvent(resultSet.getString(1), resultSet.getString(2), resultSet.getString(3), resultSet.getString(4),
                         resultSet.getString(5), JobExecutionEvent.ExecutionSource.valueOf(resultSet.getString(6)), Integer.valueOf(resultSet.getString(7)), 
                         new Date(resultSet.getTimestamp(8).getTime()), resultSet.getTimestamp(9) == null ? null : new Date(resultSet.getTimestamp(9).getTime()), 
-                        resultSet.getBoolean(10), new JobExecutionEventThrowable(null, resultSet.getString(11)) 
+                        resultSet.getBoolean(10), new JobExecutionEventThrowable(null, resultSet.getString(11))
                         );
                 result.add(jobExecutionEvent);
             }
@@ -114,8 +112,8 @@ public final class JobEventRdbSearch {
                 ) {
             while (resultSet.next()) {
                 JobStatusTraceEvent jobStatusTraceEvent = new JobStatusTraceEvent(resultSet.getString(1), resultSet.getString(2), resultSet.getString(3), resultSet.getString(4),
-                        resultSet.getString(5), Source.valueOf(resultSet.getString(6)), ExecutionType.valueOf(resultSet.getString(7)), resultSet.getString(8),
-                        State.valueOf(resultSet.getString(9)), resultSet.getString(10), new Date(resultSet.getTimestamp(11).getTime()));
+                        resultSet.getString(5), JobStatusTraceEvent.Source.valueOf(resultSet.getString(6)), ExecutionType.valueOf(resultSet.getString(7)), resultSet.getString(8),
+                        JobStatusTraceEvent.State.valueOf(resultSet.getString(9)), resultSet.getString(10), new Date(resultSet.getTimestamp(11).getTime()));
                 result.add(jobStatusTraceEvent);
             }
         } catch (final SQLException ex) {
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/event/rdb/JobEventRdbStorage.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/event/rdb/JobEventRdbStorage.java
similarity index 98%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/event/rdb/JobEventRdbStorage.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/event/rdb/JobEventRdbStorage.java
index e1a16cb..133760e 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/event/rdb/JobEventRdbStorage.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/event/rdb/JobEventRdbStorage.java
@@ -15,12 +15,12 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.event.rdb;
+package org.apache.shardingsphere.elasticjob.cloud.event.rdb;
 
 import com.google.common.base.Strings;
-import io.elasticjob.cloud.context.ExecutionType;
-import io.elasticjob.cloud.event.type.JobExecutionEvent;
-import io.elasticjob.cloud.event.type.JobStatusTraceEvent;
+import org.apache.shardingsphere.elasticjob.cloud.context.ExecutionType;
+import org.apache.shardingsphere.elasticjob.cloud.event.type.JobExecutionEvent;
+import org.apache.shardingsphere.elasticjob.cloud.event.type.JobStatusTraceEvent;
 import lombok.extern.slf4j.Slf4j;
 
 import javax.sql.DataSource;
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/event/type/JobExecutionEvent.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/event/type/JobExecutionEvent.java
similarity index 91%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/event/type/JobExecutionEvent.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/event/type/JobExecutionEvent.java
index 4674956..dbb11f1 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/event/type/JobExecutionEvent.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/event/type/JobExecutionEvent.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.event.type;
+package org.apache.shardingsphere.elasticjob.cloud.event.type;
 
-import io.elasticjob.cloud.exception.ExceptionUtil;
-import io.elasticjob.cloud.event.JobEvent;
-import io.elasticjob.cloud.util.env.IpUtils;
+import org.apache.shardingsphere.elasticjob.cloud.exception.ExceptionUtil;
+import org.apache.shardingsphere.elasticjob.cloud.event.JobEvent;
+import org.apache.shardingsphere.elasticjob.cloud.util.env.IpUtils;
 import lombok.AllArgsConstructor;
 import lombok.Getter;
 import lombok.RequiredArgsConstructor;
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/event/type/JobExecutionEventThrowable.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/event/type/JobExecutionEventThrowable.java
similarity index 95%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/event/type/JobExecutionEventThrowable.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/event/type/JobExecutionEventThrowable.java
index 0a9165f..4adff2e 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/event/type/JobExecutionEventThrowable.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/event/type/JobExecutionEventThrowable.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.event.type;
+package org.apache.shardingsphere.elasticjob.cloud.event.type;
 
 import lombok.AllArgsConstructor;
 import lombok.Getter;
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/event/type/JobStatusTraceEvent.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/event/type/JobStatusTraceEvent.java
similarity index 90%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/event/type/JobStatusTraceEvent.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/event/type/JobStatusTraceEvent.java
index 227d07e..4049fbc 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/event/type/JobStatusTraceEvent.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/event/type/JobStatusTraceEvent.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.event.type;
+package org.apache.shardingsphere.elasticjob.cloud.event.type;
 
-import io.elasticjob.cloud.context.ExecutionType;
-import io.elasticjob.cloud.event.JobEvent;
+import org.apache.shardingsphere.elasticjob.cloud.context.ExecutionType;
+import org.apache.shardingsphere.elasticjob.cloud.event.JobEvent;
 import lombok.AllArgsConstructor;
 import lombok.Getter;
 import lombok.RequiredArgsConstructor;
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/exception/AppConfigurationException.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/exception/AppConfigurationException.java
similarity index 95%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/exception/AppConfigurationException.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/exception/AppConfigurationException.java
index 5807a04..60e935e 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/exception/AppConfigurationException.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/exception/AppConfigurationException.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.exception;
+package org.apache.shardingsphere.elasticjob.cloud.exception;
 
 /**
  * 作业App配置异常.
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/exception/ExceptionUtil.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/exception/ExceptionUtil.java
similarity index 96%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/exception/ExceptionUtil.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/exception/ExceptionUtil.java
index 199a3f8..5692165 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/exception/ExceptionUtil.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/exception/ExceptionUtil.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.exception;
+package org.apache.shardingsphere.elasticjob.cloud.exception;
 
 import lombok.AccessLevel;
 import lombok.NoArgsConstructor;
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/exception/JobConfigurationException.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/exception/JobConfigurationException.java
similarity index 95%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/exception/JobConfigurationException.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/exception/JobConfigurationException.java
index 4053e1a..836a707 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/exception/JobConfigurationException.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/exception/JobConfigurationException.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.exception;
+package org.apache.shardingsphere.elasticjob.cloud.exception;
 
 /**
  * 作业配置异常.
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/exception/JobExecutionEnvironmentException.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/exception/JobExecutionEnvironmentException.java
similarity index 94%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/exception/JobExecutionEnvironmentException.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/exception/JobExecutionEnvironmentException.java
index 3b93496..a149162 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/exception/JobExecutionEnvironmentException.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/exception/JobExecutionEnvironmentException.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.exception;
+package org.apache.shardingsphere.elasticjob.cloud.exception;
 
 /**
  * 作业执行环境异常.
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/exception/JobStatisticException.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/exception/JobStatisticException.java
similarity index 94%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/exception/JobStatisticException.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/exception/JobStatisticException.java
index 955c08a..0f8e6c2 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/exception/JobStatisticException.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/exception/JobStatisticException.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.exception;
+package org.apache.shardingsphere.elasticjob.cloud.exception;
 
 /**
  * 作业统计异常.
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/exception/JobSystemException.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/exception/JobSystemException.java
similarity index 95%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/exception/JobSystemException.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/exception/JobSystemException.java
index 68ccbf8..3cb073a 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/exception/JobSystemException.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/exception/JobSystemException.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.exception;
+package org.apache.shardingsphere.elasticjob.cloud.exception;
 
 /**
  * 作业系统异常.
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/executor/AbstractElasticJobExecutor.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/AbstractElasticJobExecutor.java
similarity index 90%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/executor/AbstractElasticJobExecutor.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/AbstractElasticJobExecutor.java
index 81f040d..6e532ca 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/executor/AbstractElasticJobExecutor.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/AbstractElasticJobExecutor.java
@@ -15,19 +15,19 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.executor;
+package org.apache.shardingsphere.elasticjob.cloud.executor;
 
-import io.elasticjob.cloud.api.ShardingContext;
-import io.elasticjob.cloud.exception.ExceptionUtil;
-import io.elasticjob.cloud.executor.handler.JobExceptionHandler;
-import io.elasticjob.cloud.config.JobRootConfiguration;
-import io.elasticjob.cloud.event.type.JobExecutionEvent;
-import io.elasticjob.cloud.event.type.JobStatusTraceEvent;
-import io.elasticjob.cloud.exception.JobExecutionEnvironmentException;
-import io.elasticjob.cloud.exception.JobSystemException;
-import io.elasticjob.cloud.executor.handler.ExecutorServiceHandler;
-import io.elasticjob.cloud.executor.handler.ExecutorServiceHandlerRegistry;
-import io.elasticjob.cloud.executor.handler.JobProperties;
+import org.apache.shardingsphere.elasticjob.cloud.api.ShardingContext;
+import org.apache.shardingsphere.elasticjob.cloud.exception.ExceptionUtil;
+import org.apache.shardingsphere.elasticjob.cloud.executor.handler.JobExceptionHandler;
+import org.apache.shardingsphere.elasticjob.cloud.config.JobRootConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.event.type.JobExecutionEvent;
+import org.apache.shardingsphere.elasticjob.cloud.event.type.JobStatusTraceEvent;
+import org.apache.shardingsphere.elasticjob.cloud.exception.JobExecutionEnvironmentException;
+import org.apache.shardingsphere.elasticjob.cloud.exception.JobSystemException;
+import org.apache.shardingsphere.elasticjob.cloud.executor.handler.ExecutorServiceHandler;
+import org.apache.shardingsphere.elasticjob.cloud.executor.handler.ExecutorServiceHandlerRegistry;
+import org.apache.shardingsphere.elasticjob.cloud.executor.handler.JobProperties;
 import lombok.AccessLevel;
 import lombok.Getter;
 import lombok.extern.slf4j.Slf4j;
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/executor/JobExecutorFactory.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/JobExecutorFactory.java
similarity index 75%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/executor/JobExecutorFactory.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/JobExecutorFactory.java
index a1962dd..063bac8 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/executor/JobExecutorFactory.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/JobExecutorFactory.java
@@ -15,15 +15,15 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.executor;
+package org.apache.shardingsphere.elasticjob.cloud.executor;
 
-import io.elasticjob.cloud.api.ElasticJob;
-import io.elasticjob.cloud.api.dataflow.DataflowJob;
-import io.elasticjob.cloud.api.simple.SimpleJob;
-import io.elasticjob.cloud.executor.type.DataflowJobExecutor;
-import io.elasticjob.cloud.exception.JobConfigurationException;
-import io.elasticjob.cloud.executor.type.ScriptJobExecutor;
-import io.elasticjob.cloud.executor.type.SimpleJobExecutor;
+import org.apache.shardingsphere.elasticjob.cloud.api.ElasticJob;
+import org.apache.shardingsphere.elasticjob.cloud.api.dataflow.DataflowJob;
+import org.apache.shardingsphere.elasticjob.cloud.api.simple.SimpleJob;
+import org.apache.shardingsphere.elasticjob.cloud.executor.type.DataflowJobExecutor;
+import org.apache.shardingsphere.elasticjob.cloud.exception.JobConfigurationException;
+import org.apache.shardingsphere.elasticjob.cloud.executor.type.ScriptJobExecutor;
+import org.apache.shardingsphere.elasticjob.cloud.executor.type.SimpleJobExecutor;
 import lombok.AccessLevel;
 import lombok.NoArgsConstructor;
 
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/executor/JobFacade.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/JobFacade.java
similarity index 90%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/executor/JobFacade.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/JobFacade.java
index e14a08a..cfa3924 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/executor/JobFacade.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/JobFacade.java
@@ -15,12 +15,12 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.executor;
+package org.apache.shardingsphere.elasticjob.cloud.executor;
 
-import io.elasticjob.cloud.config.JobRootConfiguration;
-import io.elasticjob.cloud.event.type.JobExecutionEvent;
-import io.elasticjob.cloud.event.type.JobStatusTraceEvent;
-import io.elasticjob.cloud.exception.JobExecutionEnvironmentException;
+import org.apache.shardingsphere.elasticjob.cloud.config.JobRootConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.event.type.JobExecutionEvent;
+import org.apache.shardingsphere.elasticjob.cloud.event.type.JobStatusTraceEvent;
+import org.apache.shardingsphere.elasticjob.cloud.exception.JobExecutionEnvironmentException;
 
 import java.util.Collection;
 
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/executor/ShardingContexts.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/ShardingContexts.java
similarity index 97%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/executor/ShardingContexts.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/ShardingContexts.java
index 7cdc520..942fb18 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/executor/ShardingContexts.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/ShardingContexts.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.executor;
+package org.apache.shardingsphere.elasticjob.cloud.executor;
 
 import lombok.Getter;
 import lombok.RequiredArgsConstructor;
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/executor/handler/ExecutorServiceHandler.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/handler/ExecutorServiceHandler.java
similarity index 94%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/executor/handler/ExecutorServiceHandler.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/handler/ExecutorServiceHandler.java
index f1bb686..ad2604e 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/executor/handler/ExecutorServiceHandler.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/handler/ExecutorServiceHandler.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.executor.handler;
+package org.apache.shardingsphere.elasticjob.cloud.executor.handler;
 
 import java.util.concurrent.ExecutorService;
 
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/executor/handler/ExecutorServiceHandlerRegistry.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/handler/ExecutorServiceHandlerRegistry.java
similarity index 96%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/executor/handler/ExecutorServiceHandlerRegistry.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/handler/ExecutorServiceHandlerRegistry.java
index 0d5064c..4e35e3e 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/executor/handler/ExecutorServiceHandlerRegistry.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/handler/ExecutorServiceHandlerRegistry.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.executor.handler;
+package org.apache.shardingsphere.elasticjob.cloud.executor.handler;
 
 import lombok.AccessLevel;
 import lombok.NoArgsConstructor;
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/executor/handler/JobExceptionHandler.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/handler/JobExceptionHandler.java
similarity index 94%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/executor/handler/JobExceptionHandler.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/handler/JobExceptionHandler.java
index 2781e26..f101059 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/executor/handler/JobExceptionHandler.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/handler/JobExceptionHandler.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.executor.handler;
+package org.apache.shardingsphere.elasticjob.cloud.executor.handler;
 
 /**
  * 作业异常处理器.
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/executor/handler/JobProperties.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/handler/JobProperties.java
similarity index 90%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/executor/handler/JobProperties.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/handler/JobProperties.java
index 8d8b993..a2505ae 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/executor/handler/JobProperties.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/handler/JobProperties.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.executor.handler;
+package org.apache.shardingsphere.elasticjob.cloud.executor.handler;
 
-import io.elasticjob.cloud.executor.handler.impl.DefaultJobExceptionHandler;
-import io.elasticjob.cloud.util.json.GsonFactory;
-import io.elasticjob.cloud.executor.handler.impl.DefaultExecutorServiceHandler;
+import org.apache.shardingsphere.elasticjob.cloud.executor.handler.impl.DefaultJobExceptionHandler;
+import org.apache.shardingsphere.elasticjob.cloud.util.json.GsonFactory;
+import org.apache.shardingsphere.elasticjob.cloud.executor.handler.impl.DefaultExecutorServiceHandler;
 import lombok.AllArgsConstructor;
 import lombok.Getter;
 import lombok.NoArgsConstructor;
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/executor/handler/impl/DefaultExecutorServiceHandler.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/handler/impl/DefaultExecutorServiceHandler.java
similarity index 83%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/executor/handler/impl/DefaultExecutorServiceHandler.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/handler/impl/DefaultExecutorServiceHandler.java
index 37ab326..b384a94 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/executor/handler/impl/DefaultExecutorServiceHandler.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/handler/impl/DefaultExecutorServiceHandler.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.executor.handler.impl;
+package org.apache.shardingsphere.elasticjob.cloud.executor.handler.impl;
 
-import io.elasticjob.cloud.util.concurrent.ExecutorServiceObject;
-import io.elasticjob.cloud.executor.handler.ExecutorServiceHandler;
+import org.apache.shardingsphere.elasticjob.cloud.util.concurrent.ExecutorServiceObject;
+import org.apache.shardingsphere.elasticjob.cloud.executor.handler.ExecutorServiceHandler;
 
 import java.util.concurrent.ExecutorService;
 
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/executor/handler/impl/DefaultJobExceptionHandler.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/handler/impl/DefaultJobExceptionHandler.java
similarity index 88%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/executor/handler/impl/DefaultJobExceptionHandler.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/handler/impl/DefaultJobExceptionHandler.java
index fe1746e..ea4233f 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/executor/handler/impl/DefaultJobExceptionHandler.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/handler/impl/DefaultJobExceptionHandler.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.executor.handler.impl;
+package org.apache.shardingsphere.elasticjob.cloud.executor.handler.impl;
 
-import io.elasticjob.cloud.executor.handler.JobExceptionHandler;
+import org.apache.shardingsphere.elasticjob.cloud.executor.handler.JobExceptionHandler;
 import lombok.extern.slf4j.Slf4j;
 
 /**
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/executor/type/DataflowJobExecutor.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/type/DataflowJobExecutor.java
similarity index 84%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/executor/type/DataflowJobExecutor.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/type/DataflowJobExecutor.java
index c5661ef..db03930 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/executor/type/DataflowJobExecutor.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/type/DataflowJobExecutor.java
@@ -15,13 +15,13 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.executor.type;
+package org.apache.shardingsphere.elasticjob.cloud.executor.type;
 
-import io.elasticjob.cloud.api.ShardingContext;
-import io.elasticjob.cloud.api.dataflow.DataflowJob;
-import io.elasticjob.cloud.config.dataflow.DataflowJobConfiguration;
-import io.elasticjob.cloud.executor.AbstractElasticJobExecutor;
-import io.elasticjob.cloud.executor.JobFacade;
+import org.apache.shardingsphere.elasticjob.cloud.api.ShardingContext;
+import org.apache.shardingsphere.elasticjob.cloud.api.dataflow.DataflowJob;
+import org.apache.shardingsphere.elasticjob.cloud.config.dataflow.DataflowJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.executor.AbstractElasticJobExecutor;
+import org.apache.shardingsphere.elasticjob.cloud.executor.JobFacade;
 
 import java.util.List;
 
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/executor/type/ScriptJobExecutor.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/type/ScriptJobExecutor.java
similarity index 80%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/executor/type/ScriptJobExecutor.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/type/ScriptJobExecutor.java
index c01ce9d..63291a3 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/executor/type/ScriptJobExecutor.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/type/ScriptJobExecutor.java
@@ -15,15 +15,15 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.executor.type;
+package org.apache.shardingsphere.elasticjob.cloud.executor.type;
 
 import com.google.common.base.Strings;
-import io.elasticjob.cloud.api.ShardingContext;
-import io.elasticjob.cloud.config.script.ScriptJobConfiguration;
-import io.elasticjob.cloud.exception.JobConfigurationException;
-import io.elasticjob.cloud.executor.AbstractElasticJobExecutor;
-import io.elasticjob.cloud.executor.JobFacade;
-import io.elasticjob.cloud.util.json.GsonFactory;
+import org.apache.shardingsphere.elasticjob.cloud.api.ShardingContext;
+import org.apache.shardingsphere.elasticjob.cloud.config.script.ScriptJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.exception.JobConfigurationException;
+import org.apache.shardingsphere.elasticjob.cloud.executor.AbstractElasticJobExecutor;
+import org.apache.shardingsphere.elasticjob.cloud.executor.JobFacade;
+import org.apache.shardingsphere.elasticjob.cloud.util.json.GsonFactory;
 import org.apache.commons.exec.CommandLine;
 import org.apache.commons.exec.DefaultExecutor;
 
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/executor/type/SimpleJobExecutor.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/type/SimpleJobExecutor.java
similarity index 77%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/executor/type/SimpleJobExecutor.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/type/SimpleJobExecutor.java
index 587773a..22473fe 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/executor/type/SimpleJobExecutor.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/type/SimpleJobExecutor.java
@@ -15,12 +15,12 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.executor.type;
+package org.apache.shardingsphere.elasticjob.cloud.executor.type;
 
-import io.elasticjob.cloud.api.ShardingContext;
-import io.elasticjob.cloud.api.simple.SimpleJob;
-import io.elasticjob.cloud.executor.AbstractElasticJobExecutor;
-import io.elasticjob.cloud.executor.JobFacade;
+import org.apache.shardingsphere.elasticjob.cloud.api.ShardingContext;
+import org.apache.shardingsphere.elasticjob.cloud.api.simple.SimpleJob;
+import org.apache.shardingsphere.elasticjob.cloud.executor.AbstractElasticJobExecutor;
+import org.apache.shardingsphere.elasticjob.cloud.executor.JobFacade;
 
 /**
  * 简单作业执行器.
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/reg/base/CoordinatorRegistryCenter.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/reg/base/CoordinatorRegistryCenter.java
similarity index 97%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/reg/base/CoordinatorRegistryCenter.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/reg/base/CoordinatorRegistryCenter.java
index cffc211..af8e7b6 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/reg/base/CoordinatorRegistryCenter.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/reg/base/CoordinatorRegistryCenter.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.reg.base;
+package org.apache.shardingsphere.elasticjob.cloud.reg.base;
 
 import java.util.List;
 
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/reg/base/ElectionCandidate.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/reg/base/ElectionCandidate.java
similarity index 95%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/reg/base/ElectionCandidate.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/reg/base/ElectionCandidate.java
index 27cd1d7..04c8189 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/reg/base/ElectionCandidate.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/reg/base/ElectionCandidate.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.reg.base;
+package org.apache.shardingsphere.elasticjob.cloud.reg.base;
 
 /**
  * 选举候选人.
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/reg/base/RegistryCenter.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/reg/base/RegistryCenter.java
similarity index 97%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/reg/base/RegistryCenter.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/reg/base/RegistryCenter.java
index ce4419c..a96d0bf 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/reg/base/RegistryCenter.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/reg/base/RegistryCenter.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.reg.base;
+package org.apache.shardingsphere.elasticjob.cloud.reg.base;
 
 /**
  * 注册中心.
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/reg/exception/RegException.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/reg/exception/RegException.java
similarity index 94%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/reg/exception/RegException.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/reg/exception/RegException.java
index d6f7ae4..bd2ca0f 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/reg/exception/RegException.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/reg/exception/RegException.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.reg.exception;
+package org.apache.shardingsphere.elasticjob.cloud.reg.exception;
 
 /**
  * 注册中心异常.
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/reg/exception/RegExceptionHandler.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/reg/exception/RegExceptionHandler.java
similarity index 97%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/reg/exception/RegExceptionHandler.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/reg/exception/RegExceptionHandler.java
index 2d5ec01..39e1131 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/reg/exception/RegExceptionHandler.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/reg/exception/RegExceptionHandler.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.reg.exception;
+package org.apache.shardingsphere.elasticjob.cloud.reg.exception;
 
 import lombok.AccessLevel;
 import lombok.NoArgsConstructor;
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/reg/zookeeper/ZookeeperConfiguration.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/reg/zookeeper/ZookeeperConfiguration.java
similarity index 96%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/reg/zookeeper/ZookeeperConfiguration.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/reg/zookeeper/ZookeeperConfiguration.java
index 30a3261..8719396 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/reg/zookeeper/ZookeeperConfiguration.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/reg/zookeeper/ZookeeperConfiguration.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.reg.zookeeper;
+package org.apache.shardingsphere.elasticjob.cloud.reg.zookeeper;
 
 import lombok.Getter;
 import lombok.RequiredArgsConstructor;
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/reg/zookeeper/ZookeeperElectionService.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/reg/zookeeper/ZookeeperElectionService.java
similarity index 92%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/reg/zookeeper/ZookeeperElectionService.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/reg/zookeeper/ZookeeperElectionService.java
index a24c7c4..a1b3209 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/reg/zookeeper/ZookeeperElectionService.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/reg/zookeeper/ZookeeperElectionService.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.reg.zookeeper;
+package org.apache.shardingsphere.elasticjob.cloud.reg.zookeeper;
 
-import io.elasticjob.cloud.reg.base.ElectionCandidate;
-import io.elasticjob.cloud.exception.JobSystemException;
+import org.apache.shardingsphere.elasticjob.cloud.reg.base.ElectionCandidate;
+import org.apache.shardingsphere.elasticjob.cloud.exception.JobSystemException;
 import lombok.extern.slf4j.Slf4j;
 import org.apache.curator.framework.CuratorFramework;
 import org.apache.curator.framework.recipes.leader.LeaderSelector;
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/reg/zookeeper/ZookeeperRegistryCenter.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/reg/zookeeper/ZookeeperRegistryCenter.java
similarity index 97%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/reg/zookeeper/ZookeeperRegistryCenter.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/reg/zookeeper/ZookeeperRegistryCenter.java
index 907eae4..a3876d0 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/reg/zookeeper/ZookeeperRegistryCenter.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/reg/zookeeper/ZookeeperRegistryCenter.java
@@ -15,13 +15,13 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.reg.zookeeper;
+package org.apache.shardingsphere.elasticjob.cloud.reg.zookeeper;
 
 import com.google.common.base.Charsets;
 import com.google.common.base.Preconditions;
 import com.google.common.base.Strings;
-import io.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
-import io.elasticjob.cloud.reg.exception.RegExceptionHandler;
+import org.apache.shardingsphere.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
+import org.apache.shardingsphere.elasticjob.cloud.reg.exception.RegExceptionHandler;
 import lombok.AccessLevel;
 import lombok.Getter;
 import lombok.extern.slf4j.Slf4j;
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/statistics/StatisticInterval.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/statistics/StatisticInterval.java
similarity index 94%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/statistics/StatisticInterval.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/statistics/StatisticInterval.java
index aba3c68..0928d4d 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/statistics/StatisticInterval.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/statistics/StatisticInterval.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.statistics;
+package org.apache.shardingsphere.elasticjob.cloud.statistics;
 
 import lombok.Getter;
 import lombok.RequiredArgsConstructor;
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/statistics/rdb/StatisticRdbRepository.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/statistics/rdb/StatisticRdbRepository.java
similarity index 97%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/statistics/rdb/StatisticRdbRepository.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/statistics/rdb/StatisticRdbRepository.java
index 0a96ee5..5faf16c 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/statistics/rdb/StatisticRdbRepository.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/statistics/rdb/StatisticRdbRepository.java
@@ -15,14 +15,14 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.statistics.rdb;
+package org.apache.shardingsphere.elasticjob.cloud.statistics.rdb;
 
 import com.google.common.base.Optional;
-import io.elasticjob.cloud.statistics.StatisticInterval;
-import io.elasticjob.cloud.statistics.type.job.JobRegisterStatistics;
-import io.elasticjob.cloud.statistics.type.job.JobRunningStatistics;
-import io.elasticjob.cloud.statistics.type.task.TaskResultStatistics;
-import io.elasticjob.cloud.statistics.type.task.TaskRunningStatistics;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.StatisticInterval;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.type.job.JobRegisterStatistics;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.type.job.JobRunningStatistics;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.type.task.TaskResultStatistics;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.type.task.TaskRunningStatistics;
 import lombok.extern.slf4j.Slf4j;
 
 import javax.sql.DataSource;
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/statistics/type/job/JobExecutionTypeStatistics.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/statistics/type/job/JobExecutionTypeStatistics.java
similarity index 93%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/statistics/type/job/JobExecutionTypeStatistics.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/statistics/type/job/JobExecutionTypeStatistics.java
index c481c6a..8348678 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/statistics/type/job/JobExecutionTypeStatistics.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/statistics/type/job/JobExecutionTypeStatistics.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.statistics.type.job;
+package org.apache.shardingsphere.elasticjob.cloud.statistics.type.job;
 
 import lombok.AllArgsConstructor;
 import lombok.Getter;
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/statistics/type/job/JobRegisterStatistics.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/statistics/type/job/JobRegisterStatistics.java
similarity index 94%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/statistics/type/job/JobRegisterStatistics.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/statistics/type/job/JobRegisterStatistics.java
index 7a4b271..0cb6215 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/statistics/type/job/JobRegisterStatistics.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/statistics/type/job/JobRegisterStatistics.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.statistics.type.job;
+package org.apache.shardingsphere.elasticjob.cloud.statistics.type.job;
 
 import lombok.AllArgsConstructor;
 import lombok.Getter;
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/statistics/type/job/JobRunningStatistics.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/statistics/type/job/JobRunningStatistics.java
similarity index 94%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/statistics/type/job/JobRunningStatistics.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/statistics/type/job/JobRunningStatistics.java
index faa3a21..4f1d224 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/statistics/type/job/JobRunningStatistics.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/statistics/type/job/JobRunningStatistics.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.statistics.type.job;
+package org.apache.shardingsphere.elasticjob.cloud.statistics.type.job;
 
 import lombok.AllArgsConstructor;
 import lombok.Getter;
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/statistics/type/job/JobTypeStatistics.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/statistics/type/job/JobTypeStatistics.java
similarity index 93%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/statistics/type/job/JobTypeStatistics.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/statistics/type/job/JobTypeStatistics.java
index b249986..1cbe4d6 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/statistics/type/job/JobTypeStatistics.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/statistics/type/job/JobTypeStatistics.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.statistics.type.job;
+package org.apache.shardingsphere.elasticjob.cloud.statistics.type.job;
 
 import lombok.AllArgsConstructor;
 import lombok.Getter;
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/statistics/type/task/TaskResultStatistics.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/statistics/type/task/TaskResultStatistics.java
similarity index 89%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/statistics/type/task/TaskResultStatistics.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/statistics/type/task/TaskResultStatistics.java
index ab64fa9..db42b32 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/statistics/type/task/TaskResultStatistics.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/statistics/type/task/TaskResultStatistics.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.statistics.type.task;
+package org.apache.shardingsphere.elasticjob.cloud.statistics.type.task;
 
-import io.elasticjob.cloud.statistics.StatisticInterval;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.StatisticInterval;
 import lombok.AllArgsConstructor;
 import lombok.Getter;
 import lombok.RequiredArgsConstructor;
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/statistics/type/task/TaskRunningStatistics.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/statistics/type/task/TaskRunningStatistics.java
similarity index 94%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/statistics/type/task/TaskRunningStatistics.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/statistics/type/task/TaskRunningStatistics.java
index ba65767..02f6aca 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/statistics/type/task/TaskRunningStatistics.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/statistics/type/task/TaskRunningStatistics.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.statistics.type.task;
+package org.apache.shardingsphere.elasticjob.cloud.statistics.type.task;
 
 import lombok.AllArgsConstructor;
 import lombok.Getter;
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/util/concurrent/BlockUtils.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/util/concurrent/BlockUtils.java
similarity index 95%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/util/concurrent/BlockUtils.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/util/concurrent/BlockUtils.java
index 8195b1d..556a26a 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/util/concurrent/BlockUtils.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/util/concurrent/BlockUtils.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.util.concurrent;
+package org.apache.shardingsphere.elasticjob.cloud.util.concurrent;
 
 import lombok.AccessLevel;
 import lombok.NoArgsConstructor;
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/util/concurrent/ExecutorServiceObject.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/util/concurrent/ExecutorServiceObject.java
similarity index 97%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/util/concurrent/ExecutorServiceObject.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/util/concurrent/ExecutorServiceObject.java
index bbd164c..3e6d90e 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/util/concurrent/ExecutorServiceObject.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/util/concurrent/ExecutorServiceObject.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.util.concurrent;
+package org.apache.shardingsphere.elasticjob.cloud.util.concurrent;
 
 import com.google.common.base.Joiner;
 import com.google.common.util.concurrent.MoreExecutors;
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/util/config/ShardingItemParameters.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/util/config/ShardingItemParameters.java
similarity index 95%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/util/config/ShardingItemParameters.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/util/config/ShardingItemParameters.java
index 1aab706..6f5ba6a 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/util/config/ShardingItemParameters.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/util/config/ShardingItemParameters.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.util.config;
+package org.apache.shardingsphere.elasticjob.cloud.util.config;
 
 import com.google.common.base.Strings;
-import io.elasticjob.cloud.exception.JobConfigurationException;
+import org.apache.shardingsphere.elasticjob.cloud.exception.JobConfigurationException;
 import lombok.AllArgsConstructor;
 import lombok.Getter;
 
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/util/config/ShardingItems.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/util/config/ShardingItems.java
similarity index 97%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/util/config/ShardingItems.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/util/config/ShardingItems.java
index 5b6b1b7..6e55997 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/util/config/ShardingItems.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/util/config/ShardingItems.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.util.config;
+package org.apache.shardingsphere.elasticjob.cloud.util.config;
 
 import com.google.common.base.Joiner;
 import com.google.common.base.Strings;
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/util/digest/Encryption.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/util/digest/Encryption.java
similarity index 92%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/util/digest/Encryption.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/util/digest/Encryption.java
index 808e504..90d4ba8 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/util/digest/Encryption.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/util/digest/Encryption.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.util.digest;
+package org.apache.shardingsphere.elasticjob.cloud.util.digest;
 
-import io.elasticjob.cloud.exception.JobSystemException;
+import org.apache.shardingsphere.elasticjob.cloud.exception.JobSystemException;
 import lombok.AccessLevel;
 import lombok.NoArgsConstructor;
 
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/util/env/HostException.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/util/env/HostException.java
similarity index 94%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/util/env/HostException.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/util/env/HostException.java
index 917806d..7b24ed5 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/util/env/HostException.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/util/env/HostException.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.util.env;
+package org.apache.shardingsphere.elasticjob.cloud.util.env;
 
 import java.io.IOException;
 
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/util/env/IpUtils.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/util/env/IpUtils.java
similarity index 98%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/util/env/IpUtils.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/util/env/IpUtils.java
index c5776af..3356ec4 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/util/env/IpUtils.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/util/env/IpUtils.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.util.env;
+package org.apache.shardingsphere.elasticjob.cloud.util.env;
 
 import lombok.AccessLevel;
 import lombok.NoArgsConstructor;
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/util/env/TimeService.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/util/env/TimeService.java
similarity index 94%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/util/env/TimeService.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/util/env/TimeService.java
index 36f3ff8..f98094d 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/util/env/TimeService.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/util/env/TimeService.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.util.env;
+package org.apache.shardingsphere.elasticjob.cloud.util.env;
 
 /**
  * 获取时间的服务.
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/util/json/AbstractJobConfigurationGsonTypeAdapter.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/util/json/AbstractJobConfigurationGsonTypeAdapter.java
similarity index 92%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/util/json/AbstractJobConfigurationGsonTypeAdapter.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/util/json/AbstractJobConfigurationGsonTypeAdapter.java
index b625160..edb3814 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/util/json/AbstractJobConfigurationGsonTypeAdapter.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/util/json/AbstractJobConfigurationGsonTypeAdapter.java
@@ -15,21 +15,21 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.util.json;
+package org.apache.shardingsphere.elasticjob.cloud.util.json;
 
 import com.google.common.base.Preconditions;
 import com.google.common.base.Strings;
 import com.google.gson.TypeAdapter;
 import com.google.gson.stream.JsonReader;
 import com.google.gson.stream.JsonWriter;
-import io.elasticjob.cloud.api.JobType;
-import io.elasticjob.cloud.config.JobTypeConfiguration;
-import io.elasticjob.cloud.config.script.ScriptJobConfiguration;
-import io.elasticjob.cloud.config.JobCoreConfiguration;
-import io.elasticjob.cloud.config.JobRootConfiguration;
-import io.elasticjob.cloud.config.dataflow.DataflowJobConfiguration;
-import io.elasticjob.cloud.config.simple.SimpleJobConfiguration;
-import io.elasticjob.cloud.executor.handler.JobProperties;
+import org.apache.shardingsphere.elasticjob.cloud.api.JobType;
+import org.apache.shardingsphere.elasticjob.cloud.config.JobTypeConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.config.script.ScriptJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.config.JobCoreConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.config.JobRootConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.config.dataflow.DataflowJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.config.simple.SimpleJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.executor.handler.JobProperties;
 
 import java.io.IOException;
 import java.util.HashMap;
diff --git a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/util/json/GsonFactory.java b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/util/json/GsonFactory.java
similarity index 96%
rename from elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/util/json/GsonFactory.java
rename to elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/util/json/GsonFactory.java
index ef11b0c..5fad3ee 100644
--- a/elastic-job-cloud-common/src/main/java/io/elasticjob/cloud/util/json/GsonFactory.java
+++ b/elastic-job-cloud-common/src/main/java/org/apache/shardingsphere/elasticjob/cloud/util/json/GsonFactory.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.util.json;
+package org.apache.shardingsphere.elasticjob.cloud.util.json;
 
 import com.google.gson.Gson;
 import com.google.gson.GsonBuilder;
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/AllCoreTests.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/AllCoreTests.java
similarity index 60%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/AllCoreTests.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/AllCoreTests.java
index f9e17d9..4251621 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/AllCoreTests.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/AllCoreTests.java
@@ -15,17 +15,17 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud;
+package org.apache.shardingsphere.elasticjob.cloud;
 
-import io.elasticjob.cloud.api.AllApiTests;
-import io.elasticjob.cloud.executor.AllExecutorTests;
-import io.elasticjob.cloud.statistics.AllStatisticsTests;
-import io.elasticjob.cloud.config.AllConfigTests;
-import io.elasticjob.cloud.context.AllContextTests;
-import io.elasticjob.cloud.event.AllEventTests;
-import io.elasticjob.cloud.exception.AllExceptionTests;
-import io.elasticjob.cloud.reg.AllRegTests;
-import io.elasticjob.cloud.util.AllUtilTests;
+import org.apache.shardingsphere.elasticjob.cloud.api.AllApiTests;
+import org.apache.shardingsphere.elasticjob.cloud.executor.AllExecutorTests;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.AllStatisticsTests;
+import org.apache.shardingsphere.elasticjob.cloud.config.AllConfigTests;
+import org.apache.shardingsphere.elasticjob.cloud.context.AllContextTests;
+import org.apache.shardingsphere.elasticjob.cloud.event.AllEventTests;
+import org.apache.shardingsphere.elasticjob.cloud.exception.AllExceptionTests;
+import org.apache.shardingsphere.elasticjob.cloud.reg.AllRegTests;
+import org.apache.shardingsphere.elasticjob.cloud.util.AllUtilTests;
 import lombok.AccessLevel;
 import lombok.NoArgsConstructor;
 import org.junit.runner.RunWith;
@@ -36,10 +36,10 @@ import org.junit.runners.Suite.SuiteClasses;
 @SuiteClasses({
         AllRegTests.class,
         AllContextTests.class,
-        AllApiTests.class, 
-        AllConfigTests.class, 
-        AllExecutorTests.class, 
-        AllEventTests.class, 
+        AllApiTests.class,
+        AllConfigTests.class,
+        AllExecutorTests.class,
+        AllEventTests.class,
         AllExceptionTests.class,
         AllStatisticsTests.class,
         AllUtilTests.class
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/api/AllApiTests.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/api/AllApiTests.java
similarity index 94%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/api/AllApiTests.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/api/AllApiTests.java
index 9c6a14e..312f511 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/api/AllApiTests.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/api/AllApiTests.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.api;
+package org.apache.shardingsphere.elasticjob.cloud.api;
 
 import org.junit.runner.RunWith;
 import org.junit.runners.Suite;
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/api/ShardingContextTest.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/api/ShardingContextTest.java
similarity index 90%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/api/ShardingContextTest.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/api/ShardingContextTest.java
index 427613d..72a082a 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/api/ShardingContextTest.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/api/ShardingContextTest.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.api;
+package org.apache.shardingsphere.elasticjob.cloud.api;
 
-import io.elasticjob.cloud.executor.ShardingContexts;
-import io.elasticjob.cloud.fixture.ShardingContextsBuilder;
+import org.apache.shardingsphere.elasticjob.cloud.executor.ShardingContexts;
+import org.apache.shardingsphere.elasticjob.cloud.fixture.ShardingContextsBuilder;
 import org.hamcrest.core.Is;
 import org.junit.Assert;
 import org.junit.Test;
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/config/AllConfigTests.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/config/AllConfigTests.java
similarity index 94%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/config/AllConfigTests.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/config/AllConfigTests.java
index 74c31d9..6044682 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/config/AllConfigTests.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/config/AllConfigTests.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.config;
+package org.apache.shardingsphere.elasticjob.cloud.config;
 
 import org.junit.runner.RunWith;
 import org.junit.runners.Suite;
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/config/JobCoreConfigurationTest.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/config/JobCoreConfigurationTest.java
similarity index 92%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/config/JobCoreConfigurationTest.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/config/JobCoreConfigurationTest.java
index f83b096..32df8f1 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/config/JobCoreConfigurationTest.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/config/JobCoreConfigurationTest.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.config;
+package org.apache.shardingsphere.elasticjob.cloud.config;
 
-import io.elasticjob.cloud.executor.handler.impl.DefaultJobExceptionHandler;
-import io.elasticjob.cloud.fixture.handler.IgnoreJobExceptionHandler;
-import io.elasticjob.cloud.executor.handler.JobProperties;
+import org.apache.shardingsphere.elasticjob.cloud.executor.handler.impl.DefaultJobExceptionHandler;
+import org.apache.shardingsphere.elasticjob.cloud.fixture.handler.IgnoreJobExceptionHandler;
+import org.apache.shardingsphere.elasticjob.cloud.executor.handler.JobProperties;
 import org.hamcrest.core.Is;
 import org.junit.Assert;
 import org.junit.Test;
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/context/AllContextTests.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/context/AllContextTests.java
similarity index 94%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/context/AllContextTests.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/context/AllContextTests.java
index 27a727c..aeaabed 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/context/AllContextTests.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/context/AllContextTests.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.context;
+package org.apache.shardingsphere.elasticjob.cloud.context;
 
 import org.junit.runner.RunWith;
 import org.junit.runners.Suite;
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/context/TaskContextTest.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/context/TaskContextTest.java
similarity index 97%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/context/TaskContextTest.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/context/TaskContextTest.java
index c727781..84ab679 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/context/TaskContextTest.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/context/TaskContextTest.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.context;
+package org.apache.shardingsphere.elasticjob.cloud.context;
 
 import com.google.common.collect.Lists;
-import io.elasticjob.cloud.fixture.context.TaskNode;
+import org.apache.shardingsphere.elasticjob.cloud.fixture.context.TaskNode;
 import org.hamcrest.core.Is;
 import org.hamcrest.core.StringStartsWith;
 import org.junit.Assert;
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/event/AllEventTests.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/event/AllEventTests.java
similarity index 66%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/event/AllEventTests.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/event/AllEventTests.java
index 8263d04..d50c85c 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/event/AllEventTests.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/event/AllEventTests.java
@@ -15,13 +15,13 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.event;
+package org.apache.shardingsphere.elasticjob.cloud.event;
 
-import io.elasticjob.cloud.event.rdb.JobEventRdbConfigurationTest;
-import io.elasticjob.cloud.event.rdb.JobEventRdbIdentityTest;
-import io.elasticjob.cloud.event.rdb.JobEventRdbListenerTest;
-import io.elasticjob.cloud.event.rdb.JobEventRdbSearchTest;
-import io.elasticjob.cloud.event.rdb.JobEventRdbStorageTest;
+import org.apache.shardingsphere.elasticjob.cloud.event.rdb.JobEventRdbConfigurationTest;
+import org.apache.shardingsphere.elasticjob.cloud.event.rdb.JobEventRdbIdentityTest;
+import org.apache.shardingsphere.elasticjob.cloud.event.rdb.JobEventRdbListenerTest;
+import org.apache.shardingsphere.elasticjob.cloud.event.rdb.JobEventRdbSearchTest;
+import org.apache.shardingsphere.elasticjob.cloud.event.rdb.JobEventRdbStorageTest;
 import org.junit.runner.RunWith;
 import org.junit.runners.Suite;
 
@@ -30,8 +30,8 @@ import org.junit.runners.Suite;
         JobExecutionEventTest.class, 
         JobEventBusTest.class, 
         JobEventRdbIdentityTest.class,
-        JobEventRdbConfigurationTest.class, 
-        JobEventRdbListenerTest.class, 
+        JobEventRdbConfigurationTest.class,
+        JobEventRdbListenerTest.class,
         JobEventRdbStorageTest.class,
         JobEventRdbSearchTest.class
     })
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/event/JobEventBusTest.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/event/JobEventBusTest.java
similarity index 85%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/event/JobEventBusTest.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/event/JobEventBusTest.java
index a0f8aaa..a45ca39 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/event/JobEventBusTest.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/event/JobEventBusTest.java
@@ -15,14 +15,14 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.event;
+package org.apache.shardingsphere.elasticjob.cloud.event;
 
 import com.google.common.eventbus.EventBus;
-import io.elasticjob.cloud.event.fixture.JobEventCaller;
-import io.elasticjob.cloud.event.fixture.TestJobEventConfiguration;
-import io.elasticjob.cloud.event.fixture.TestJobEventListener;
-import io.elasticjob.cloud.event.type.JobExecutionEvent;
-import io.elasticjob.cloud.event.fixture.TestJobEventFailureConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.event.fixture.JobEventCaller;
+import org.apache.shardingsphere.elasticjob.cloud.event.fixture.TestJobEventConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.event.fixture.TestJobEventListener;
+import org.apache.shardingsphere.elasticjob.cloud.event.type.JobExecutionEvent;
+import org.apache.shardingsphere.elasticjob.cloud.event.fixture.TestJobEventFailureConfiguration;
 import org.hamcrest.core.Is;
 import org.junit.Assert;
 import org.junit.Test;
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/event/JobExecutionEventTest.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/event/JobExecutionEventTest.java
similarity index 94%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/event/JobExecutionEventTest.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/event/JobExecutionEventTest.java
index e81b5f1..f5284c6 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/event/JobExecutionEventTest.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/event/JobExecutionEventTest.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.event;
+package org.apache.shardingsphere.elasticjob.cloud.event;
 
-import io.elasticjob.cloud.event.type.JobExecutionEvent;
+import org.apache.shardingsphere.elasticjob.cloud.event.type.JobExecutionEvent;
 import org.hamcrest.CoreMatchers;
 import org.hamcrest.core.Is;
 import org.junit.Assert;
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/event/fixture/JobEventCaller.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/event/fixture/JobEventCaller.java
similarity index 93%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/event/fixture/JobEventCaller.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/event/fixture/JobEventCaller.java
index 76bdd9e..d00cb41 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/event/fixture/JobEventCaller.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/event/fixture/JobEventCaller.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.event.fixture;
+package org.apache.shardingsphere.elasticjob.cloud.event.fixture;
 
 public interface JobEventCaller {
 
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/event/fixture/TestJobEventConfiguration.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/event/fixture/TestJobEventConfiguration.java
similarity index 79%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/event/fixture/TestJobEventConfiguration.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/event/fixture/TestJobEventConfiguration.java
index 22d7e67..4f6cd5b 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/event/fixture/TestJobEventConfiguration.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/event/fixture/TestJobEventConfiguration.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.event.fixture;
+package org.apache.shardingsphere.elasticjob.cloud.event.fixture;
 
-import io.elasticjob.cloud.event.JobEventConfiguration;
-import io.elasticjob.cloud.event.JobEventListener;
-import io.elasticjob.cloud.event.JobEventListenerConfigurationException;
+import org.apache.shardingsphere.elasticjob.cloud.event.JobEventConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.event.JobEventListener;
+import org.apache.shardingsphere.elasticjob.cloud.event.JobEventListenerConfigurationException;
 import lombok.RequiredArgsConstructor;
 
 @RequiredArgsConstructor
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/event/fixture/TestJobEventFailureConfiguration.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/event/fixture/TestJobEventFailureConfiguration.java
similarity index 78%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/event/fixture/TestJobEventFailureConfiguration.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/event/fixture/TestJobEventFailureConfiguration.java
index 0c7ef17..43decde 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/event/fixture/TestJobEventFailureConfiguration.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/event/fixture/TestJobEventFailureConfiguration.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.event.fixture;
+package org.apache.shardingsphere.elasticjob.cloud.event.fixture;
 
-import io.elasticjob.cloud.event.JobEventConfiguration;
-import io.elasticjob.cloud.event.JobEventListener;
-import io.elasticjob.cloud.event.JobEventListenerConfigurationException;
+import org.apache.shardingsphere.elasticjob.cloud.event.JobEventConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.event.JobEventListener;
+import org.apache.shardingsphere.elasticjob.cloud.event.JobEventListenerConfigurationException;
 
 public final class TestJobEventFailureConfiguration extends TestJobEventIdentity implements JobEventConfiguration {
     
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/event/fixture/TestJobEventIdentity.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/event/fixture/TestJobEventIdentity.java
similarity index 87%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/event/fixture/TestJobEventIdentity.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/event/fixture/TestJobEventIdentity.java
index 2961e8e..75bc221 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/event/fixture/TestJobEventIdentity.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/event/fixture/TestJobEventIdentity.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.event.fixture;
+package org.apache.shardingsphere.elasticjob.cloud.event.fixture;
 
-import io.elasticjob.cloud.event.JobEventIdentity;
+import org.apache.shardingsphere.elasticjob.cloud.event.JobEventIdentity;
 
 public class TestJobEventIdentity implements JobEventIdentity {
     
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/event/fixture/TestJobEventListener.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/event/fixture/TestJobEventListener.java
similarity index 83%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/event/fixture/TestJobEventListener.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/event/fixture/TestJobEventListener.java
index e5219ac..096337d 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/event/fixture/TestJobEventListener.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/event/fixture/TestJobEventListener.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.event.fixture;
+package org.apache.shardingsphere.elasticjob.cloud.event.fixture;
 
-import io.elasticjob.cloud.event.JobEventListener;
-import io.elasticjob.cloud.event.type.JobExecutionEvent;
-import io.elasticjob.cloud.event.type.JobStatusTraceEvent;
+import org.apache.shardingsphere.elasticjob.cloud.event.JobEventListener;
+import org.apache.shardingsphere.elasticjob.cloud.event.type.JobExecutionEvent;
+import org.apache.shardingsphere.elasticjob.cloud.event.type.JobStatusTraceEvent;
 import lombok.Getter;
 import lombok.RequiredArgsConstructor;
 
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/event/rdb/JobEventRdbConfigurationTest.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/event/rdb/JobEventRdbConfigurationTest.java
similarity index 93%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/event/rdb/JobEventRdbConfigurationTest.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/event/rdb/JobEventRdbConfigurationTest.java
index 04137ce..b52d827 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/event/rdb/JobEventRdbConfigurationTest.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/event/rdb/JobEventRdbConfigurationTest.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.event.rdb;
+package org.apache.shardingsphere.elasticjob.cloud.event.rdb;
 
-import io.elasticjob.cloud.event.JobEventListenerConfigurationException;
+import org.apache.shardingsphere.elasticjob.cloud.event.JobEventListenerConfigurationException;
 import org.apache.commons.dbcp.BasicDataSource;
 import org.hamcrest.CoreMatchers;
 import org.hamcrest.core.Is;
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/event/rdb/JobEventRdbIdentityTest.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/event/rdb/JobEventRdbIdentityTest.java
similarity index 94%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/event/rdb/JobEventRdbIdentityTest.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/event/rdb/JobEventRdbIdentityTest.java
index cea80ad..5a70e6a 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/event/rdb/JobEventRdbIdentityTest.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/event/rdb/JobEventRdbIdentityTest.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.event.rdb;
+package org.apache.shardingsphere.elasticjob.cloud.event.rdb;
 
 import org.hamcrest.core.Is;
 import org.junit.Assert;
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/event/rdb/JobEventRdbListenerTest.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/event/rdb/JobEventRdbListenerTest.java
similarity index 86%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/event/rdb/JobEventRdbListenerTest.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/event/rdb/JobEventRdbListenerTest.java
index 1a8417c..93865a1 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/event/rdb/JobEventRdbListenerTest.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/event/rdb/JobEventRdbListenerTest.java
@@ -15,13 +15,13 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.event.rdb;
+package org.apache.shardingsphere.elasticjob.cloud.event.rdb;
         
-import io.elasticjob.cloud.context.ExecutionType;
-import io.elasticjob.cloud.event.JobEventBus;
-import io.elasticjob.cloud.event.JobEventListenerConfigurationException;
-import io.elasticjob.cloud.event.type.JobExecutionEvent;
-import io.elasticjob.cloud.event.type.JobStatusTraceEvent;
+import org.apache.shardingsphere.elasticjob.cloud.context.ExecutionType;
+import org.apache.shardingsphere.elasticjob.cloud.event.JobEventBus;
+import org.apache.shardingsphere.elasticjob.cloud.event.JobEventListenerConfigurationException;
+import org.apache.shardingsphere.elasticjob.cloud.event.type.JobExecutionEvent;
+import org.apache.shardingsphere.elasticjob.cloud.event.type.JobStatusTraceEvent;
 import org.apache.commons.dbcp.BasicDataSource;
 import org.junit.Before;
 import org.junit.Test;
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/event/rdb/JobEventRdbSearchTest.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/event/rdb/JobEventRdbSearchTest.java
similarity index 97%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/event/rdb/JobEventRdbSearchTest.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/event/rdb/JobEventRdbSearchTest.java
index 0defcd5..a1b3b24 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/event/rdb/JobEventRdbSearchTest.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/event/rdb/JobEventRdbSearchTest.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.event.rdb;
+package org.apache.shardingsphere.elasticjob.cloud.event.rdb;
 
-import io.elasticjob.cloud.context.ExecutionType;
-import io.elasticjob.cloud.event.type.JobExecutionEvent;
-import io.elasticjob.cloud.event.type.JobStatusTraceEvent;
+import org.apache.shardingsphere.elasticjob.cloud.context.ExecutionType;
+import org.apache.shardingsphere.elasticjob.cloud.event.type.JobExecutionEvent;
+import org.apache.shardingsphere.elasticjob.cloud.event.type.JobStatusTraceEvent;
 import org.apache.commons.dbcp.BasicDataSource;
 import org.junit.BeforeClass;
 import org.junit.Test;
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/event/rdb/JobEventRdbStorageTest.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/event/rdb/JobEventRdbStorageTest.java
similarity index 96%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/event/rdb/JobEventRdbStorageTest.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/event/rdb/JobEventRdbStorageTest.java
index 1a0dec0..c549576 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/event/rdb/JobEventRdbStorageTest.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/event/rdb/JobEventRdbStorageTest.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.event.rdb;
+package org.apache.shardingsphere.elasticjob.cloud.event.rdb;
 
-import io.elasticjob.cloud.context.ExecutionType;
-import io.elasticjob.cloud.event.type.JobExecutionEvent;
-import io.elasticjob.cloud.event.type.JobStatusTraceEvent;
+import org.apache.shardingsphere.elasticjob.cloud.context.ExecutionType;
+import org.apache.shardingsphere.elasticjob.cloud.event.type.JobExecutionEvent;
+import org.apache.shardingsphere.elasticjob.cloud.event.type.JobStatusTraceEvent;
 import org.apache.commons.dbcp.BasicDataSource;
 import org.hamcrest.CoreMatchers;
 import org.hamcrest.core.Is;
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/exception/AllExceptionTests.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/exception/AllExceptionTests.java
similarity index 95%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/exception/AllExceptionTests.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/exception/AllExceptionTests.java
index 07e704c..0afd576 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/exception/AllExceptionTests.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/exception/AllExceptionTests.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.exception;
+package org.apache.shardingsphere.elasticjob.cloud.exception;
 
 import org.junit.runner.RunWith;
 import org.junit.runners.Suite;
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/exception/ExceptionUtilTest.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/exception/ExceptionUtilTest.java
similarity index 95%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/exception/ExceptionUtilTest.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/exception/ExceptionUtilTest.java
index 4d46348..c3330d2 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/exception/ExceptionUtilTest.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/exception/ExceptionUtilTest.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.exception;
+package org.apache.shardingsphere.elasticjob.cloud.exception;
 
 import org.hamcrest.core.Is;
 import org.junit.Assert;
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/exception/JobConfigurationExceptionTest.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/exception/JobConfigurationExceptionTest.java
similarity index 95%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/exception/JobConfigurationExceptionTest.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/exception/JobConfigurationExceptionTest.java
index aea216b..7b7f550 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/exception/JobConfigurationExceptionTest.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/exception/JobConfigurationExceptionTest.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.exception;
+package org.apache.shardingsphere.elasticjob.cloud.exception;
 
 import org.hamcrest.CoreMatchers;
 import org.hamcrest.core.Is;
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/exception/JobExecutionEnvironmentExceptionTest.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/exception/JobExecutionEnvironmentExceptionTest.java
similarity index 94%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/exception/JobExecutionEnvironmentExceptionTest.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/exception/JobExecutionEnvironmentExceptionTest.java
index 62cea11..3fa9639 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/exception/JobExecutionEnvironmentExceptionTest.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/exception/JobExecutionEnvironmentExceptionTest.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.exception;
+package org.apache.shardingsphere.elasticjob.cloud.exception;
 
 import org.hamcrest.core.Is;
 import org.junit.Assert;
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/exception/JobStatisticExceptionTest.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/exception/JobStatisticExceptionTest.java
similarity index 94%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/exception/JobStatisticExceptionTest.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/exception/JobStatisticExceptionTest.java
index ec5062d..c9f3869 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/exception/JobStatisticExceptionTest.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/exception/JobStatisticExceptionTest.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.exception;
+package org.apache.shardingsphere.elasticjob.cloud.exception;
 
 import org.junit.Test;
 
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/exception/JobSystemExceptionTest.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/exception/JobSystemExceptionTest.java
similarity index 95%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/exception/JobSystemExceptionTest.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/exception/JobSystemExceptionTest.java
index a420e69..de13673 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/exception/JobSystemExceptionTest.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/exception/JobSystemExceptionTest.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.exception;
+package org.apache.shardingsphere.elasticjob.cloud.exception;
 
 import org.hamcrest.CoreMatchers;
 import org.hamcrest.core.Is;
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/executor/AllExecutorTests.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/AllExecutorTests.java
similarity index 60%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/executor/AllExecutorTests.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/AllExecutorTests.java
index 038cce3..4afcbfd 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/executor/AllExecutorTests.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/AllExecutorTests.java
@@ -15,15 +15,15 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.executor;
+package org.apache.shardingsphere.elasticjob.cloud.executor;
 
-import io.elasticjob.cloud.executor.handler.ExecutorServiceHandlerRegistryTest;
-import io.elasticjob.cloud.executor.handler.JobPropertiesTest;
-import io.elasticjob.cloud.executor.handler.impl.DefaultJobExceptionHandlerTest;
-import io.elasticjob.cloud.executor.type.DataflowJobExecutorTest;
-import io.elasticjob.cloud.executor.type.ScriptJobExecutorTest;
-import io.elasticjob.cloud.executor.type.SimpleJobExecutorTest;
-import io.elasticjob.cloud.executor.type.WrongJobExecutorTest;
+import org.apache.shardingsphere.elasticjob.cloud.executor.handler.ExecutorServiceHandlerRegistryTest;
+import org.apache.shardingsphere.elasticjob.cloud.executor.handler.JobPropertiesTest;
+import org.apache.shardingsphere.elasticjob.cloud.executor.handler.impl.DefaultJobExceptionHandlerTest;
+import org.apache.shardingsphere.elasticjob.cloud.executor.type.DataflowJobExecutorTest;
+import org.apache.shardingsphere.elasticjob.cloud.executor.type.ScriptJobExecutorTest;
+import org.apache.shardingsphere.elasticjob.cloud.executor.type.SimpleJobExecutorTest;
+import org.apache.shardingsphere.elasticjob.cloud.executor.type.WrongJobExecutorTest;
 import org.junit.runner.RunWith;
 import org.junit.runners.Suite;
 import org.junit.runners.Suite.SuiteClasses;
@@ -31,12 +31,12 @@ import org.junit.runners.Suite.SuiteClasses;
 @RunWith(Suite.class)
 @SuiteClasses({
         JobExecutorFactoryTest.class,
-        ExecutorServiceHandlerRegistryTest.class, 
+        ExecutorServiceHandlerRegistryTest.class,
         JobPropertiesTest.class,
         DefaultJobExceptionHandlerTest.class, 
         SimpleJobExecutorTest.class,
         WrongJobExecutorTest.class,
-        DataflowJobExecutorTest.class, 
+        DataflowJobExecutorTest.class,
         ScriptJobExecutorTest.class
     })
 public final class AllExecutorTests {
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/executor/JobExecutorFactoryTest.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/JobExecutorFactoryTest.java
similarity index 74%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/executor/JobExecutorFactoryTest.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/JobExecutorFactoryTest.java
index 232106b..77eb9dc 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/executor/JobExecutorFactoryTest.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/JobExecutorFactoryTest.java
@@ -15,19 +15,19 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.executor;
+package org.apache.shardingsphere.elasticjob.cloud.executor;
 
-import io.elasticjob.cloud.exception.JobConfigurationException;
-import io.elasticjob.cloud.executor.type.DataflowJobExecutor;
-import io.elasticjob.cloud.fixture.config.TestDataflowJobConfiguration;
-import io.elasticjob.cloud.fixture.config.TestScriptJobConfiguration;
-import io.elasticjob.cloud.fixture.config.TestSimpleJobConfiguration;
-import io.elasticjob.cloud.fixture.job.TestDataflowJob;
-import io.elasticjob.cloud.executor.type.ScriptJobExecutor;
-import io.elasticjob.cloud.executor.type.SimpleJobExecutor;
-import io.elasticjob.cloud.fixture.handler.IgnoreJobExceptionHandler;
-import io.elasticjob.cloud.fixture.job.OtherJob;
-import io.elasticjob.cloud.fixture.job.TestSimpleJob;
+import org.apache.shardingsphere.elasticjob.cloud.exception.JobConfigurationException;
+import org.apache.shardingsphere.elasticjob.cloud.executor.type.DataflowJobExecutor;
+import org.apache.shardingsphere.elasticjob.cloud.fixture.config.TestDataflowJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.fixture.config.TestScriptJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.fixture.config.TestSimpleJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.fixture.job.TestDataflowJob;
+import org.apache.shardingsphere.elasticjob.cloud.executor.type.ScriptJobExecutor;
+import org.apache.shardingsphere.elasticjob.cloud.executor.type.SimpleJobExecutor;
+import org.apache.shardingsphere.elasticjob.cloud.fixture.handler.IgnoreJobExceptionHandler;
+import org.apache.shardingsphere.elasticjob.cloud.fixture.job.OtherJob;
+import org.apache.shardingsphere.elasticjob.cloud.fixture.job.TestSimpleJob;
 import org.hamcrest.CoreMatchers;
 import org.junit.Assert;
 import org.junit.Test;
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/executor/handler/ExecutorServiceHandlerRegistryTest.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/handler/ExecutorServiceHandlerRegistryTest.java
similarity index 95%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/executor/handler/ExecutorServiceHandlerRegistryTest.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/handler/ExecutorServiceHandlerRegistryTest.java
index 9e9c782..5c154ca 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/executor/handler/ExecutorServiceHandlerRegistryTest.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/handler/ExecutorServiceHandlerRegistryTest.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.executor.handler;
+package org.apache.shardingsphere.elasticjob.cloud.executor.handler;
 
-import io.elasticjob.cloud.executor.handler.impl.DefaultExecutorServiceHandler;
+import org.apache.shardingsphere.elasticjob.cloud.executor.handler.impl.DefaultExecutorServiceHandler;
 import lombok.RequiredArgsConstructor;
 import org.hamcrest.core.Is;
 import org.hamcrest.core.IsNot;
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/executor/handler/JobPropertiesTest.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/handler/JobPropertiesTest.java
similarity index 89%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/executor/handler/JobPropertiesTest.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/handler/JobPropertiesTest.java
index 71c2a27..836e498 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/executor/handler/JobPropertiesTest.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/handler/JobPropertiesTest.java
@@ -15,12 +15,12 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.executor.handler;
+package org.apache.shardingsphere.elasticjob.cloud.executor.handler;
 
-import io.elasticjob.cloud.executor.handler.impl.DefaultExecutorServiceHandler;
-import io.elasticjob.cloud.executor.handler.impl.DefaultJobExceptionHandler;
-import io.elasticjob.cloud.fixture.APIJsonConstants;
-import io.elasticjob.cloud.fixture.handler.IgnoreJobExceptionHandler;
+import org.apache.shardingsphere.elasticjob.cloud.executor.handler.impl.DefaultExecutorServiceHandler;
+import org.apache.shardingsphere.elasticjob.cloud.executor.handler.impl.DefaultJobExceptionHandler;
+import org.apache.shardingsphere.elasticjob.cloud.fixture.APIJsonConstants;
+import org.apache.shardingsphere.elasticjob.cloud.fixture.handler.IgnoreJobExceptionHandler;
 import org.hamcrest.core.Is;
 import org.junit.Assert;
 import org.junit.Test;
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/executor/handler/impl/DefaultJobExceptionHandlerTest.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/handler/impl/DefaultJobExceptionHandlerTest.java
similarity index 89%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/executor/handler/impl/DefaultJobExceptionHandlerTest.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/handler/impl/DefaultJobExceptionHandlerTest.java
index 69c93e5..d3003fd 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/executor/handler/impl/DefaultJobExceptionHandlerTest.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/handler/impl/DefaultJobExceptionHandlerTest.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.executor.handler.impl;
+package org.apache.shardingsphere.elasticjob.cloud.executor.handler.impl;
 
-import io.elasticjob.cloud.event.fixture.JobEventCaller;
+import org.apache.shardingsphere.elasticjob.cloud.event.fixture.JobEventCaller;
 import org.junit.Test;
 import org.junit.runner.RunWith;
 import org.mockito.Mock;
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/executor/type/DataflowJobExecutorTest.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/type/DataflowJobExecutorTest.java
similarity index 93%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/executor/type/DataflowJobExecutorTest.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/type/DataflowJobExecutorTest.java
index 9039ef8..7841fce 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/executor/type/DataflowJobExecutorTest.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/type/DataflowJobExecutorTest.java
@@ -15,14 +15,14 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.executor.type;
+package org.apache.shardingsphere.elasticjob.cloud.executor.type;
 
-import io.elasticjob.cloud.executor.JobFacade;
-import io.elasticjob.cloud.executor.ShardingContexts;
-import io.elasticjob.cloud.fixture.ShardingContextsBuilder;
-import io.elasticjob.cloud.fixture.config.TestDataflowJobConfiguration;
-import io.elasticjob.cloud.fixture.job.JobCaller;
-import io.elasticjob.cloud.fixture.job.TestDataflowJob;
+import org.apache.shardingsphere.elasticjob.cloud.executor.JobFacade;
+import org.apache.shardingsphere.elasticjob.cloud.executor.ShardingContexts;
+import org.apache.shardingsphere.elasticjob.cloud.fixture.ShardingContextsBuilder;
+import org.apache.shardingsphere.elasticjob.cloud.fixture.config.TestDataflowJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.fixture.job.JobCaller;
+import org.apache.shardingsphere.elasticjob.cloud.fixture.job.TestDataflowJob;
 import org.junit.After;
 import org.junit.Test;
 import org.junit.runner.RunWith;
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/executor/type/ElasticJobVerify.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/type/ElasticJobVerify.java
similarity index 86%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/executor/type/ElasticJobVerify.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/type/ElasticJobVerify.java
index a68520f..72160c7 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/executor/type/ElasticJobVerify.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/type/ElasticJobVerify.java
@@ -15,12 +15,12 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.executor.type;
+package org.apache.shardingsphere.elasticjob.cloud.executor.type;
 
-import io.elasticjob.cloud.executor.ShardingContexts;
-import io.elasticjob.cloud.event.type.JobStatusTraceEvent;
-import io.elasticjob.cloud.exception.JobExecutionEnvironmentException;
-import io.elasticjob.cloud.executor.JobFacade;
+import org.apache.shardingsphere.elasticjob.cloud.executor.ShardingContexts;
+import org.apache.shardingsphere.elasticjob.cloud.event.type.JobStatusTraceEvent;
+import org.apache.shardingsphere.elasticjob.cloud.exception.JobExecutionEnvironmentException;
+import org.apache.shardingsphere.elasticjob.cloud.executor.JobFacade;
 import lombok.AccessLevel;
 import lombok.NoArgsConstructor;
 
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/executor/type/ScriptJobExecutorTest.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/type/ScriptJobExecutorTest.java
similarity index 84%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/executor/type/ScriptJobExecutorTest.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/type/ScriptJobExecutorTest.java
index a1a8933..8e5e32b 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/executor/type/ScriptJobExecutorTest.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/type/ScriptJobExecutorTest.java
@@ -15,15 +15,15 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.executor.type;
+package org.apache.shardingsphere.elasticjob.cloud.executor.type;
 
-import io.elasticjob.cloud.executor.ShardingContexts;
-import io.elasticjob.cloud.fixture.config.TestScriptJobConfiguration;
-import io.elasticjob.cloud.exception.JobSystemException;
-import io.elasticjob.cloud.executor.JobFacade;
-import io.elasticjob.cloud.fixture.ShardingContextsBuilder;
-import io.elasticjob.cloud.fixture.handler.IgnoreJobExceptionHandler;
-import io.elasticjob.cloud.fixture.handler.ThrowJobExceptionHandler;
+import org.apache.shardingsphere.elasticjob.cloud.executor.ShardingContexts;
+import org.apache.shardingsphere.elasticjob.cloud.fixture.config.TestScriptJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.exception.JobSystemException;
+import org.apache.shardingsphere.elasticjob.cloud.executor.JobFacade;
+import org.apache.shardingsphere.elasticjob.cloud.fixture.ShardingContextsBuilder;
+import org.apache.shardingsphere.elasticjob.cloud.fixture.handler.IgnoreJobExceptionHandler;
+import org.apache.shardingsphere.elasticjob.cloud.fixture.handler.ThrowJobExceptionHandler;
 import org.junit.Test;
 import org.junit.runner.RunWith;
 import org.mockito.Mock;
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/executor/type/SimpleJobExecutorTest.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/type/SimpleJobExecutorTest.java
similarity index 91%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/executor/type/SimpleJobExecutorTest.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/type/SimpleJobExecutorTest.java
index 9e46a42..acad2f5 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/executor/type/SimpleJobExecutorTest.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/type/SimpleJobExecutorTest.java
@@ -15,20 +15,20 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.executor.type;
+package org.apache.shardingsphere.elasticjob.cloud.executor.type;
 
-import io.elasticjob.cloud.executor.AbstractElasticJobExecutor;
-import io.elasticjob.cloud.executor.ShardingContexts;
-import io.elasticjob.cloud.fixture.config.TestSimpleJobConfiguration;
-import io.elasticjob.cloud.event.type.JobStatusTraceEvent;
-import io.elasticjob.cloud.exception.JobExecutionEnvironmentException;
-import io.elasticjob.cloud.exception.JobSystemException;
-import io.elasticjob.cloud.executor.JobFacade;
-import io.elasticjob.cloud.executor.handler.impl.DefaultExecutorServiceHandler;
-import io.elasticjob.cloud.executor.handler.impl.DefaultJobExceptionHandler;
-import io.elasticjob.cloud.fixture.ShardingContextsBuilder;
-import io.elasticjob.cloud.fixture.job.JobCaller;
-import io.elasticjob.cloud.fixture.job.TestSimpleJob;
+import org.apache.shardingsphere.elasticjob.cloud.executor.AbstractElasticJobExecutor;
+import org.apache.shardingsphere.elasticjob.cloud.executor.ShardingContexts;
+import org.apache.shardingsphere.elasticjob.cloud.fixture.config.TestSimpleJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.event.type.JobStatusTraceEvent;
+import org.apache.shardingsphere.elasticjob.cloud.exception.JobExecutionEnvironmentException;
+import org.apache.shardingsphere.elasticjob.cloud.exception.JobSystemException;
+import org.apache.shardingsphere.elasticjob.cloud.executor.JobFacade;
+import org.apache.shardingsphere.elasticjob.cloud.executor.handler.impl.DefaultExecutorServiceHandler;
+import org.apache.shardingsphere.elasticjob.cloud.executor.handler.impl.DefaultJobExceptionHandler;
+import org.apache.shardingsphere.elasticjob.cloud.fixture.ShardingContextsBuilder;
+import org.apache.shardingsphere.elasticjob.cloud.fixture.job.JobCaller;
+import org.apache.shardingsphere.elasticjob.cloud.fixture.job.TestSimpleJob;
 import org.junit.Before;
 import org.junit.Test;
 import org.junit.runner.RunWith;
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/executor/type/WrongJobExecutorTest.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/type/WrongJobExecutorTest.java
similarity index 84%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/executor/type/WrongJobExecutorTest.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/type/WrongJobExecutorTest.java
index 936e549..494b5b5 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/executor/type/WrongJobExecutorTest.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/type/WrongJobExecutorTest.java
@@ -15,13 +15,13 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.executor.type;
+package org.apache.shardingsphere.elasticjob.cloud.executor.type;
 
-import io.elasticjob.cloud.event.type.JobStatusTraceEvent;
-import io.elasticjob.cloud.executor.JobFacade;
-import io.elasticjob.cloud.executor.ShardingContexts;
-import io.elasticjob.cloud.fixture.config.TestSimpleJobConfiguration;
-import io.elasticjob.cloud.fixture.job.TestWrongJob;
+import org.apache.shardingsphere.elasticjob.cloud.event.type.JobStatusTraceEvent;
+import org.apache.shardingsphere.elasticjob.cloud.executor.JobFacade;
+import org.apache.shardingsphere.elasticjob.cloud.executor.ShardingContexts;
+import org.apache.shardingsphere.elasticjob.cloud.fixture.config.TestSimpleJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.fixture.job.TestWrongJob;
 import org.junit.Before;
 import org.junit.Test;
 import org.junit.runner.RunWith;
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/fixture/APIJsonConstants.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/fixture/APIJsonConstants.java
similarity index 88%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/fixture/APIJsonConstants.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/fixture/APIJsonConstants.java
index 1a635a3..cf38fad 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/fixture/APIJsonConstants.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/fixture/APIJsonConstants.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.fixture;
+package org.apache.shardingsphere.elasticjob.cloud.fixture;
 
-import io.elasticjob.cloud.executor.handler.impl.DefaultExecutorServiceHandler;
+import org.apache.shardingsphere.elasticjob.cloud.executor.handler.impl.DefaultExecutorServiceHandler;
 import lombok.AccessLevel;
 import lombok.NoArgsConstructor;
 
@@ -27,16 +27,16 @@ public final class APIJsonConstants {
     private static final String JOB_PROPS_JSON = "{\"job_exception_handler\":\"%s\",\"executor_service_handler\":\"" + DefaultExecutorServiceHandler.class.getCanonicalName() + "\"}";
     
     // CHECKSTYLE:OFF
-    private static final String SIMPLE_JOB_JSON =  "{\"jobName\":\"test_job\",\"jobClass\":\"io.elasticjob.cloud.fixture.job.TestSimpleJob\",\"jobType\":\"SIMPLE\","
+    private static final String SIMPLE_JOB_JSON =  "{\"jobName\":\"test_job\",\"jobClass\":\"TestSimpleJob\",\"jobType\":\"SIMPLE\","
             + "\"cron\":\"0/1 * * * * ?\",\"shardingTotalCount\":3,\"shardingItemParameters\":\"0\\u003dA,1\\u003dB,2\\u003dC\",\"jobParameter\":\"param\",\"failover\":true,\"misfire\":false,"
             + "\"description\":\"desc\",\"jobProperties\":%s}";
     // CHECKSTYLE:ON
     
-    private static final String DATAFLOW_JOB_JSON = "{\"jobName\":\"test_job\",\"jobClass\":\"io.elasticjob.cloud.fixture.job.TestDataflowJob\",\"jobType\":\"DATAFLOW\","
+    private static final String DATAFLOW_JOB_JSON = "{\"jobName\":\"test_job\",\"jobClass\":\"TestDataflowJob\",\"jobType\":\"DATAFLOW\","
             + "\"cron\":\"0/1 * * * * ?\",\"shardingTotalCount\":3,\"shardingItemParameters\":\"\",\"jobParameter\":\"\",\"failover\":false,\"misfire\":true,\"description\":\"\","
             + "\"jobProperties\":%s,\"streamingProcess\":true}";
     
-    private static final String SCRIPT_JOB_JSON = "{\"jobName\":\"test_job\",\"jobClass\":\"io.elasticjob.cloud.api.script.ScriptJob\",\"jobType\":\"SCRIPT\",\"cron\":\"0/1 * * * * ?\","
+    private static final String SCRIPT_JOB_JSON = "{\"jobName\":\"test_job\",\"jobClass\":\"ScriptJob\",\"jobType\":\"SCRIPT\",\"cron\":\"0/1 * * * * ?\","
             + "\"shardingTotalCount\":3,\"shardingItemParameters\":\"\",\"jobParameter\":\"\",\"failover\":false,\"misfire\":true,\"description\":\"\","
             + "\"jobProperties\":%s,\"scriptCommandLine\":\"test.sh\"}";
 
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/fixture/EmbedTestingServer.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/fixture/EmbedTestingServer.java
similarity index 93%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/fixture/EmbedTestingServer.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/fixture/EmbedTestingServer.java
index da18f50..8ed71f1 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/fixture/EmbedTestingServer.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/fixture/EmbedTestingServer.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.fixture;
+package org.apache.shardingsphere.elasticjob.cloud.fixture;
 
 import com.google.common.base.Joiner;
-import io.elasticjob.cloud.reg.exception.RegExceptionHandler;
+import org.apache.shardingsphere.elasticjob.cloud.reg.exception.RegExceptionHandler;
 import lombok.AccessLevel;
 import lombok.NoArgsConstructor;
 import org.apache.curator.test.TestingServer;
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/fixture/ShardingContextsBuilder.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/fixture/ShardingContextsBuilder.java
similarity index 92%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/fixture/ShardingContextsBuilder.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/fixture/ShardingContextsBuilder.java
index c06edc2..63833ae 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/fixture/ShardingContextsBuilder.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/fixture/ShardingContextsBuilder.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.fixture;
+package org.apache.shardingsphere.elasticjob.cloud.fixture;
 
-import io.elasticjob.cloud.executor.ShardingContexts;
+import org.apache.shardingsphere.elasticjob.cloud.executor.ShardingContexts;
 import lombok.AccessLevel;
 import lombok.RequiredArgsConstructor;
 
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/fixture/config/TestDataflowJobConfiguration.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/fixture/config/TestDataflowJobConfiguration.java
similarity index 66%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/fixture/config/TestDataflowJobConfiguration.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/fixture/config/TestDataflowJobConfiguration.java
index b0b14ba..a0055a4 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/fixture/config/TestDataflowJobConfiguration.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/fixture/config/TestDataflowJobConfiguration.java
@@ -15,16 +15,16 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.fixture.config;
+package org.apache.shardingsphere.elasticjob.cloud.fixture.config;
 
-import io.elasticjob.cloud.config.JobRootConfiguration;
-import io.elasticjob.cloud.config.JobTypeConfiguration;
-import io.elasticjob.cloud.fixture.job.TestDataflowJob;
-import io.elasticjob.cloud.config.JobCoreConfiguration;
-import io.elasticjob.cloud.config.dataflow.DataflowJobConfiguration;
-import io.elasticjob.cloud.executor.handler.JobProperties;
-import io.elasticjob.cloud.fixture.ShardingContextsBuilder;
-import io.elasticjob.cloud.fixture.handler.IgnoreJobExceptionHandler;
+import org.apache.shardingsphere.elasticjob.cloud.config.JobRootConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.config.JobTypeConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.fixture.job.TestDataflowJob;
+import org.apache.shardingsphere.elasticjob.cloud.config.JobCoreConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.config.dataflow.DataflowJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.executor.handler.JobProperties;
+import org.apache.shardingsphere.elasticjob.cloud.fixture.ShardingContextsBuilder;
+import org.apache.shardingsphere.elasticjob.cloud.fixture.handler.IgnoreJobExceptionHandler;
 import lombok.RequiredArgsConstructor;
 
 @RequiredArgsConstructor
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/fixture/config/TestJobRootConfiguration.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/fixture/config/TestJobRootConfiguration.java
similarity index 83%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/fixture/config/TestJobRootConfiguration.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/fixture/config/TestJobRootConfiguration.java
index c796dd6..4321de1 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/fixture/config/TestJobRootConfiguration.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/fixture/config/TestJobRootConfiguration.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.fixture.config;
+package org.apache.shardingsphere.elasticjob.cloud.fixture.config;
 
-import io.elasticjob.cloud.config.JobTypeConfiguration;
-import io.elasticjob.cloud.config.JobRootConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.config.JobTypeConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.config.JobRootConfiguration;
 import lombok.RequiredArgsConstructor;
 
 @RequiredArgsConstructor
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/fixture/config/TestScriptJobConfiguration.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/fixture/config/TestScriptJobConfiguration.java
similarity index 69%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/fixture/config/TestScriptJobConfiguration.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/fixture/config/TestScriptJobConfiguration.java
index 18f05f3..c2772de 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/fixture/config/TestScriptJobConfiguration.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/fixture/config/TestScriptJobConfiguration.java
@@ -15,15 +15,15 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.fixture.config;
+package org.apache.shardingsphere.elasticjob.cloud.fixture.config;
 
-import io.elasticjob.cloud.config.JobTypeConfiguration;
-import io.elasticjob.cloud.config.script.ScriptJobConfiguration;
-import io.elasticjob.cloud.executor.handler.JobExceptionHandler;
-import io.elasticjob.cloud.config.JobCoreConfiguration;
-import io.elasticjob.cloud.config.JobRootConfiguration;
-import io.elasticjob.cloud.executor.handler.JobProperties;
-import io.elasticjob.cloud.fixture.ShardingContextsBuilder;
+import org.apache.shardingsphere.elasticjob.cloud.config.JobTypeConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.config.script.ScriptJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.executor.handler.JobExceptionHandler;
+import org.apache.shardingsphere.elasticjob.cloud.config.JobCoreConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.config.JobRootConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.executor.handler.JobProperties;
+import org.apache.shardingsphere.elasticjob.cloud.fixture.ShardingContextsBuilder;
 import lombok.RequiredArgsConstructor;
 
 @RequiredArgsConstructor
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/fixture/config/TestSimpleJobConfiguration.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/fixture/config/TestSimpleJobConfiguration.java
similarity index 76%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/fixture/config/TestSimpleJobConfiguration.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/fixture/config/TestSimpleJobConfiguration.java
index f934136..c0a20fb 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/fixture/config/TestSimpleJobConfiguration.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/fixture/config/TestSimpleJobConfiguration.java
@@ -15,16 +15,16 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.fixture.config;
+package org.apache.shardingsphere.elasticjob.cloud.fixture.config;
 
-import io.elasticjob.cloud.config.JobCoreConfiguration;
-import io.elasticjob.cloud.config.JobRootConfiguration;
-import io.elasticjob.cloud.config.JobTypeConfiguration;
-import io.elasticjob.cloud.config.simple.SimpleJobConfiguration;
-import io.elasticjob.cloud.executor.handler.JobProperties;
-import io.elasticjob.cloud.fixture.ShardingContextsBuilder;
-import io.elasticjob.cloud.fixture.handler.ThrowJobExceptionHandler;
-import io.elasticjob.cloud.fixture.job.TestSimpleJob;
+import org.apache.shardingsphere.elasticjob.cloud.config.JobCoreConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.config.JobRootConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.config.JobTypeConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.config.simple.SimpleJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.executor.handler.JobProperties;
+import org.apache.shardingsphere.elasticjob.cloud.fixture.ShardingContextsBuilder;
+import org.apache.shardingsphere.elasticjob.cloud.fixture.handler.ThrowJobExceptionHandler;
+import org.apache.shardingsphere.elasticjob.cloud.fixture.job.TestSimpleJob;
 import lombok.NoArgsConstructor;
 
 @NoArgsConstructor
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/fixture/context/TaskNode.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/fixture/context/TaskNode.java
similarity index 91%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/fixture/context/TaskNode.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/fixture/context/TaskNode.java
index 88e66fe..2c815c7 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/fixture/context/TaskNode.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/fixture/context/TaskNode.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.fixture.context;
+package org.apache.shardingsphere.elasticjob.cloud.fixture.context;
 
 import com.google.common.base.Joiner;
-import io.elasticjob.cloud.context.ExecutionType;
+import org.apache.shardingsphere.elasticjob.cloud.context.ExecutionType;
 import lombok.Builder;
 
 @Builder
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/fixture/handler/IgnoreJobExceptionHandler.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/fixture/handler/IgnoreJobExceptionHandler.java
similarity index 86%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/fixture/handler/IgnoreJobExceptionHandler.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/fixture/handler/IgnoreJobExceptionHandler.java
index 68c2570..6e93dfc 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/fixture/handler/IgnoreJobExceptionHandler.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/fixture/handler/IgnoreJobExceptionHandler.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.fixture.handler;
+package org.apache.shardingsphere.elasticjob.cloud.fixture.handler;
 
-import io.elasticjob.cloud.executor.handler.JobExceptionHandler;
+import org.apache.shardingsphere.elasticjob.cloud.executor.handler.JobExceptionHandler;
 
 public final class IgnoreJobExceptionHandler implements JobExceptionHandler {
     
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/fixture/handler/ThrowJobExceptionHandler.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/fixture/handler/ThrowJobExceptionHandler.java
similarity index 81%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/fixture/handler/ThrowJobExceptionHandler.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/fixture/handler/ThrowJobExceptionHandler.java
index a032322..80d2b68 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/fixture/handler/ThrowJobExceptionHandler.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/fixture/handler/ThrowJobExceptionHandler.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.fixture.handler;
+package org.apache.shardingsphere.elasticjob.cloud.fixture.handler;
 
-import io.elasticjob.cloud.executor.handler.JobExceptionHandler;
-import io.elasticjob.cloud.exception.JobSystemException;
+import org.apache.shardingsphere.elasticjob.cloud.executor.handler.JobExceptionHandler;
+import org.apache.shardingsphere.elasticjob.cloud.exception.JobSystemException;
 
 public final class ThrowJobExceptionHandler implements JobExceptionHandler {
     
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/fixture/job/JobCaller.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/fixture/job/JobCaller.java
similarity index 94%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/fixture/job/JobCaller.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/fixture/job/JobCaller.java
index 0b17d57..c8b0aae 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/fixture/job/JobCaller.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/fixture/job/JobCaller.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.fixture.job;
+package org.apache.shardingsphere.elasticjob.cloud.fixture.job;
 
 import java.util.List;
 
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/fixture/job/OtherJob.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/fixture/job/OtherJob.java
similarity index 86%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/fixture/job/OtherJob.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/fixture/job/OtherJob.java
index e253fcc..724a744 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/fixture/job/OtherJob.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/fixture/job/OtherJob.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.fixture.job;
+package org.apache.shardingsphere.elasticjob.cloud.fixture.job;
 
-import io.elasticjob.cloud.api.ElasticJob;
+import org.apache.shardingsphere.elasticjob.cloud.api.ElasticJob;
 
 public final class OtherJob implements ElasticJob {
 }
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/fixture/job/TestDataflowJob.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/fixture/job/TestDataflowJob.java
similarity index 86%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/fixture/job/TestDataflowJob.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/fixture/job/TestDataflowJob.java
index 1365222..31e00c7 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/fixture/job/TestDataflowJob.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/fixture/job/TestDataflowJob.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.fixture.job;
+package org.apache.shardingsphere.elasticjob.cloud.fixture.job;
 
-import io.elasticjob.cloud.api.ShardingContext;
-import io.elasticjob.cloud.api.dataflow.DataflowJob;
+import org.apache.shardingsphere.elasticjob.cloud.api.ShardingContext;
+import org.apache.shardingsphere.elasticjob.cloud.api.dataflow.DataflowJob;
 import lombok.RequiredArgsConstructor;
 
 import java.util.List;
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/fixture/job/TestSimpleJob.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/fixture/job/TestSimpleJob.java
similarity index 84%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/fixture/job/TestSimpleJob.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/fixture/job/TestSimpleJob.java
index 4e9b10d..6368022 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/fixture/job/TestSimpleJob.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/fixture/job/TestSimpleJob.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.fixture.job;
+package org.apache.shardingsphere.elasticjob.cloud.fixture.job;
 
-import io.elasticjob.cloud.api.ShardingContext;
-import io.elasticjob.cloud.api.simple.SimpleJob;
+import org.apache.shardingsphere.elasticjob.cloud.api.ShardingContext;
+import org.apache.shardingsphere.elasticjob.cloud.api.simple.SimpleJob;
 import lombok.RequiredArgsConstructor;
 
 @RequiredArgsConstructor
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/fixture/job/TestWrongJob.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/fixture/job/TestWrongJob.java
similarity index 83%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/fixture/job/TestWrongJob.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/fixture/job/TestWrongJob.java
index 0c265a2..1c8cfc6 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/fixture/job/TestWrongJob.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/fixture/job/TestWrongJob.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.fixture.job;
+package org.apache.shardingsphere.elasticjob.cloud.fixture.job;
 
-import io.elasticjob.cloud.api.ShardingContext;
-import io.elasticjob.cloud.api.simple.SimpleJob;
+import org.apache.shardingsphere.elasticjob.cloud.api.ShardingContext;
+import org.apache.shardingsphere.elasticjob.cloud.api.simple.SimpleJob;
 import lombok.RequiredArgsConstructor;
 
 @RequiredArgsConstructor
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/reg/AllRegTests.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/reg/AllRegTests.java
similarity index 61%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/reg/AllRegTests.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/reg/AllRegTests.java
index 8fe1e4b..7984e6d 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/reg/AllRegTests.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/reg/AllRegTests.java
@@ -15,17 +15,17 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.reg;
+package org.apache.shardingsphere.elasticjob.cloud.reg;
 
-import io.elasticjob.cloud.reg.zookeeper.ZookeeperRegistryCenterForAuthTest;
-import io.elasticjob.cloud.reg.zookeeper.ZookeeperRegistryCenterModifyTest;
-import io.elasticjob.cloud.reg.zookeeper.ZookeeperRegistryCenterQueryWithoutCacheTest;
-import io.elasticjob.cloud.reg.exception.RegExceptionHandlerTest;
-import io.elasticjob.cloud.reg.zookeeper.ZookeeperConfigurationTest;
-import io.elasticjob.cloud.reg.zookeeper.ZookeeperElectionServiceTest;
-import io.elasticjob.cloud.reg.zookeeper.ZookeeperRegistryCenterInitFailureTest;
-import io.elasticjob.cloud.reg.zookeeper.ZookeeperRegistryCenterMiscellaneousTest;
-import io.elasticjob.cloud.reg.zookeeper.ZookeeperRegistryCenterQueryWithCacheTest;
+import org.apache.shardingsphere.elasticjob.cloud.reg.zookeeper.ZookeeperRegistryCenterForAuthTest;
+import org.apache.shardingsphere.elasticjob.cloud.reg.zookeeper.ZookeeperRegistryCenterModifyTest;
+import org.apache.shardingsphere.elasticjob.cloud.reg.zookeeper.ZookeeperRegistryCenterQueryWithoutCacheTest;
+import org.apache.shardingsphere.elasticjob.cloud.reg.exception.RegExceptionHandlerTest;
+import org.apache.shardingsphere.elasticjob.cloud.reg.zookeeper.ZookeeperConfigurationTest;
+import org.apache.shardingsphere.elasticjob.cloud.reg.zookeeper.ZookeeperElectionServiceTest;
+import org.apache.shardingsphere.elasticjob.cloud.reg.zookeeper.ZookeeperRegistryCenterInitFailureTest;
+import org.apache.shardingsphere.elasticjob.cloud.reg.zookeeper.ZookeeperRegistryCenterMiscellaneousTest;
+import org.apache.shardingsphere.elasticjob.cloud.reg.zookeeper.ZookeeperRegistryCenterQueryWithCacheTest;
 import lombok.AccessLevel;
 import lombok.NoArgsConstructor;
 import org.junit.runner.RunWith;
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/reg/exception/RegExceptionHandlerTest.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/reg/exception/RegExceptionHandlerTest.java
similarity index 97%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/reg/exception/RegExceptionHandlerTest.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/reg/exception/RegExceptionHandlerTest.java
index 59f39e8..5e60bcb 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/reg/exception/RegExceptionHandlerTest.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/reg/exception/RegExceptionHandlerTest.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.reg.exception;
+package org.apache.shardingsphere.elasticjob.cloud.reg.exception;
 
 import org.apache.zookeeper.KeeperException.ConnectionLossException;
 import org.apache.zookeeper.KeeperException.NoNodeException;
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/reg/zookeeper/ZookeeperConfigurationTest.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/reg/zookeeper/ZookeeperConfigurationTest.java
similarity index 95%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/reg/zookeeper/ZookeeperConfigurationTest.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/reg/zookeeper/ZookeeperConfigurationTest.java
index 8dc4764..f7c1fc0 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/reg/zookeeper/ZookeeperConfigurationTest.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/reg/zookeeper/ZookeeperConfigurationTest.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.reg.zookeeper;
+package org.apache.shardingsphere.elasticjob.cloud.reg.zookeeper;
 
 import org.hamcrest.core.Is;
 import org.junit.Assert;
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/reg/zookeeper/ZookeeperElectionServiceTest.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/reg/zookeeper/ZookeeperElectionServiceTest.java
similarity index 92%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/reg/zookeeper/ZookeeperElectionServiceTest.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/reg/zookeeper/ZookeeperElectionServiceTest.java
index e233e74..47b0bcd 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/reg/zookeeper/ZookeeperElectionServiceTest.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/reg/zookeeper/ZookeeperElectionServiceTest.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.reg.zookeeper;
+package org.apache.shardingsphere.elasticjob.cloud.reg.zookeeper;
 
-import io.elasticjob.cloud.fixture.EmbedTestingServer;
-import io.elasticjob.cloud.reg.base.ElectionCandidate;
+import org.apache.shardingsphere.elasticjob.cloud.fixture.EmbedTestingServer;
+import org.apache.shardingsphere.elasticjob.cloud.reg.base.ElectionCandidate;
 import org.apache.curator.framework.CuratorFramework;
 import org.apache.curator.framework.CuratorFrameworkFactory;
 import org.apache.curator.retry.RetryOneTime;
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/reg/zookeeper/ZookeeperRegistryCenterForAuthTest.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/reg/zookeeper/ZookeeperRegistryCenterForAuthTest.java
similarity index 92%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/reg/zookeeper/ZookeeperRegistryCenterForAuthTest.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/reg/zookeeper/ZookeeperRegistryCenterForAuthTest.java
index f69dbdf..f9d7342 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/reg/zookeeper/ZookeeperRegistryCenterForAuthTest.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/reg/zookeeper/ZookeeperRegistryCenterForAuthTest.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.reg.zookeeper;
+package org.apache.shardingsphere.elasticjob.cloud.reg.zookeeper;
 
-import io.elasticjob.cloud.fixture.EmbedTestingServer;
-import io.elasticjob.cloud.reg.zookeeper.util.ZookeeperRegistryCenterTestUtil;
+import org.apache.shardingsphere.elasticjob.cloud.fixture.EmbedTestingServer;
+import org.apache.shardingsphere.elasticjob.cloud.reg.zookeeper.util.ZookeeperRegistryCenterTestUtil;
 import org.apache.curator.framework.CuratorFramework;
 import org.apache.curator.framework.CuratorFrameworkFactory;
 import org.apache.curator.retry.RetryOneTime;
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/reg/zookeeper/ZookeeperRegistryCenterInitFailureTest.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/reg/zookeeper/ZookeeperRegistryCenterInitFailureTest.java
similarity index 89%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/reg/zookeeper/ZookeeperRegistryCenterInitFailureTest.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/reg/zookeeper/ZookeeperRegistryCenterInitFailureTest.java
index b69994a..2fd552a 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/reg/zookeeper/ZookeeperRegistryCenterInitFailureTest.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/reg/zookeeper/ZookeeperRegistryCenterInitFailureTest.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.reg.zookeeper;
+package org.apache.shardingsphere.elasticjob.cloud.reg.zookeeper;
 
-import io.elasticjob.cloud.reg.exception.RegException;
+import org.apache.shardingsphere.elasticjob.cloud.reg.exception.RegException;
 import org.junit.Test;
 
 public final class ZookeeperRegistryCenterInitFailureTest {
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/reg/zookeeper/ZookeeperRegistryCenterMiscellaneousTest.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/reg/zookeeper/ZookeeperRegistryCenterMiscellaneousTest.java
similarity index 94%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/reg/zookeeper/ZookeeperRegistryCenterMiscellaneousTest.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/reg/zookeeper/ZookeeperRegistryCenterMiscellaneousTest.java
index 4523677..b1cb83b 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/reg/zookeeper/ZookeeperRegistryCenterMiscellaneousTest.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/reg/zookeeper/ZookeeperRegistryCenterMiscellaneousTest.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.reg.zookeeper;
+package org.apache.shardingsphere.elasticjob.cloud.reg.zookeeper;
 
-import io.elasticjob.cloud.fixture.EmbedTestingServer;
+import org.apache.shardingsphere.elasticjob.cloud.fixture.EmbedTestingServer;
 import org.apache.curator.framework.CuratorFramework;
 import org.apache.curator.framework.recipes.cache.TreeCache;
 import org.junit.AfterClass;
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/reg/zookeeper/ZookeeperRegistryCenterModifyTest.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/reg/zookeeper/ZookeeperRegistryCenterModifyTest.java
similarity index 95%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/reg/zookeeper/ZookeeperRegistryCenterModifyTest.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/reg/zookeeper/ZookeeperRegistryCenterModifyTest.java
index 4df3d7f..1db445e 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/reg/zookeeper/ZookeeperRegistryCenterModifyTest.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/reg/zookeeper/ZookeeperRegistryCenterModifyTest.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.reg.zookeeper;
+package org.apache.shardingsphere.elasticjob.cloud.reg.zookeeper;
 
-import io.elasticjob.cloud.fixture.EmbedTestingServer;
-import io.elasticjob.cloud.reg.zookeeper.util.ZookeeperRegistryCenterTestUtil;
+import org.apache.shardingsphere.elasticjob.cloud.fixture.EmbedTestingServer;
+import org.apache.shardingsphere.elasticjob.cloud.reg.zookeeper.util.ZookeeperRegistryCenterTestUtil;
 import org.apache.curator.framework.CuratorFramework;
 import org.apache.curator.framework.CuratorFrameworkFactory;
 import org.apache.curator.retry.RetryOneTime;
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/reg/zookeeper/ZookeeperRegistryCenterQueryWithCacheTest.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/reg/zookeeper/ZookeeperRegistryCenterQueryWithCacheTest.java
similarity index 89%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/reg/zookeeper/ZookeeperRegistryCenterQueryWithCacheTest.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/reg/zookeeper/ZookeeperRegistryCenterQueryWithCacheTest.java
index 496598d..3745476 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/reg/zookeeper/ZookeeperRegistryCenterQueryWithCacheTest.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/reg/zookeeper/ZookeeperRegistryCenterQueryWithCacheTest.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.reg.zookeeper;
+package org.apache.shardingsphere.elasticjob.cloud.reg.zookeeper;
 
-import io.elasticjob.cloud.fixture.EmbedTestingServer;
-import io.elasticjob.cloud.reg.zookeeper.util.ZookeeperRegistryCenterTestUtil;
+import org.apache.shardingsphere.elasticjob.cloud.fixture.EmbedTestingServer;
+import org.apache.shardingsphere.elasticjob.cloud.reg.zookeeper.util.ZookeeperRegistryCenterTestUtil;
 import org.junit.AfterClass;
 import org.junit.BeforeClass;
 import org.junit.Test;
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/reg/zookeeper/ZookeeperRegistryCenterQueryWithoutCacheTest.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/reg/zookeeper/ZookeeperRegistryCenterQueryWithoutCacheTest.java
similarity index 93%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/reg/zookeeper/ZookeeperRegistryCenterQueryWithoutCacheTest.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/reg/zookeeper/ZookeeperRegistryCenterQueryWithoutCacheTest.java
index cd836e3..8ccaddb 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/reg/zookeeper/ZookeeperRegistryCenterQueryWithoutCacheTest.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/reg/zookeeper/ZookeeperRegistryCenterQueryWithoutCacheTest.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.reg.zookeeper;
+package org.apache.shardingsphere.elasticjob.cloud.reg.zookeeper;
 
-import io.elasticjob.cloud.fixture.EmbedTestingServer;
-import io.elasticjob.cloud.reg.zookeeper.util.ZookeeperRegistryCenterTestUtil;
+import org.apache.shardingsphere.elasticjob.cloud.fixture.EmbedTestingServer;
+import org.apache.shardingsphere.elasticjob.cloud.reg.zookeeper.util.ZookeeperRegistryCenterTestUtil;
 import org.hamcrest.core.Is;
 import org.junit.AfterClass;
 import org.junit.Assert;
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/reg/zookeeper/util/ZookeeperRegistryCenterTestUtil.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/reg/zookeeper/util/ZookeeperRegistryCenterTestUtil.java
similarity index 89%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/reg/zookeeper/util/ZookeeperRegistryCenterTestUtil.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/reg/zookeeper/util/ZookeeperRegistryCenterTestUtil.java
index 3de5be0..93fa5e5 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/reg/zookeeper/util/ZookeeperRegistryCenterTestUtil.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/reg/zookeeper/util/ZookeeperRegistryCenterTestUtil.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.reg.zookeeper.util;
+package org.apache.shardingsphere.elasticjob.cloud.reg.zookeeper.util;
 
-import io.elasticjob.cloud.reg.zookeeper.ZookeeperRegistryCenter;
+import org.apache.shardingsphere.elasticjob.cloud.reg.zookeeper.ZookeeperRegistryCenter;
 import lombok.AccessLevel;
 import lombok.NoArgsConstructor;
 
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/statistics/AllStatisticsTests.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/statistics/AllStatisticsTests.java
similarity index 87%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/statistics/AllStatisticsTests.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/statistics/AllStatisticsTests.java
index b55cb99..3fed7bf 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/statistics/AllStatisticsTests.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/statistics/AllStatisticsTests.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.statistics;
+package org.apache.shardingsphere.elasticjob.cloud.statistics;
 
-import io.elasticjob.cloud.statistics.rdb.StatisticRdbRepositoryTest;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.rdb.StatisticRdbRepositoryTest;
 import lombok.AccessLevel;
 import lombok.NoArgsConstructor;
 import org.junit.runner.RunWith;
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/statistics/rdb/StatisticRdbRepositoryTest.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/statistics/rdb/StatisticRdbRepositoryTest.java
similarity index 94%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/statistics/rdb/StatisticRdbRepositoryTest.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/statistics/rdb/StatisticRdbRepositoryTest.java
index 1d81a49..720a17b 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/statistics/rdb/StatisticRdbRepositoryTest.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/statistics/rdb/StatisticRdbRepositoryTest.java
@@ -15,14 +15,14 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.statistics.rdb;
+package org.apache.shardingsphere.elasticjob.cloud.statistics.rdb;
 
 import com.google.common.base.Optional;
-import io.elasticjob.cloud.statistics.StatisticInterval;
-import io.elasticjob.cloud.statistics.type.job.JobRegisterStatistics;
-import io.elasticjob.cloud.statistics.type.job.JobRunningStatistics;
-import io.elasticjob.cloud.statistics.type.task.TaskResultStatistics;
-import io.elasticjob.cloud.statistics.type.task.TaskRunningStatistics;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.StatisticInterval;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.type.job.JobRegisterStatistics;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.type.job.JobRunningStatistics;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.type.task.TaskResultStatistics;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.type.task.TaskRunningStatistics;
 import org.apache.commons.dbcp.BasicDataSource;
 import org.hamcrest.core.Is;
 import org.junit.Assert;
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/util/AllUtilTests.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/util/AllUtilTests.java
similarity index 51%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/util/AllUtilTests.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/util/AllUtilTests.java
index cccd0e2..feba6ea 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/util/AllUtilTests.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/util/AllUtilTests.java
@@ -15,17 +15,17 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.util;
+package org.apache.shardingsphere.elasticjob.cloud.util;
 
-import io.elasticjob.cloud.util.concurrent.ExecutorServiceObjectTest;
-import io.elasticjob.cloud.util.config.ShardingItemParametersTest;
-import io.elasticjob.cloud.util.config.ShardingItemsTest;
-import io.elasticjob.cloud.util.digest.EncryptionTest;
-import io.elasticjob.cloud.util.env.HostExceptionTest;
-import io.elasticjob.cloud.util.env.IpUtilsTest;
-import io.elasticjob.cloud.util.env.TimeServiceTest;
-import io.elasticjob.cloud.util.json.GsonFactoryTest;
-import io.elasticjob.cloud.util.json.JobConfigurationGsonTypeAdapterTest;
+import org.apache.shardingsphere.elasticjob.cloud.util.concurrent.ExecutorServiceObjectTest;
+import org.apache.shardingsphere.elasticjob.cloud.util.config.ShardingItemParametersTest;
+import org.apache.shardingsphere.elasticjob.cloud.util.config.ShardingItemsTest;
+import org.apache.shardingsphere.elasticjob.cloud.util.digest.EncryptionTest;
+import org.apache.shardingsphere.elasticjob.cloud.util.env.HostExceptionTest;
+import org.apache.shardingsphere.elasticjob.cloud.util.env.IpUtilsTest;
+import org.apache.shardingsphere.elasticjob.cloud.util.env.TimeServiceTest;
+import org.apache.shardingsphere.elasticjob.cloud.util.json.GsonFactoryTest;
+import org.apache.shardingsphere.elasticjob.cloud.util.json.JobConfigurationGsonTypeAdapterTest;
 import lombok.AccessLevel;
 import lombok.NoArgsConstructor;
 import org.junit.runner.RunWith;
@@ -34,14 +34,14 @@ import org.junit.runners.Suite.SuiteClasses;
 
 @RunWith(Suite.class)
 @SuiteClasses({
-        ExecutorServiceObjectTest.class, 
-        EncryptionTest.class, 
-        TimeServiceTest.class, 
-        IpUtilsTest.class, 
-        HostExceptionTest.class, 
-        GsonFactoryTest.class, 
-        JobConfigurationGsonTypeAdapterTest.class, 
-        ShardingItemsTest.class, 
+        ExecutorServiceObjectTest.class,
+        EncryptionTest.class,
+        TimeServiceTest.class,
+        IpUtilsTest.class,
+        HostExceptionTest.class,
+        GsonFactoryTest.class,
+        JobConfigurationGsonTypeAdapterTest.class,
+        ShardingItemsTest.class,
         ShardingItemParametersTest.class
     })
 @NoArgsConstructor(access = AccessLevel.PRIVATE)
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/util/concurrent/ExecutorServiceObjectTest.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/util/concurrent/ExecutorServiceObjectTest.java
similarity index 97%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/util/concurrent/ExecutorServiceObjectTest.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/util/concurrent/ExecutorServiceObjectTest.java
index 546ece6..3d9c318 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/util/concurrent/ExecutorServiceObjectTest.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/util/concurrent/ExecutorServiceObjectTest.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.util.concurrent;
+package org.apache.shardingsphere.elasticjob.cloud.util.concurrent;
 
 import org.hamcrest.core.Is;
 import org.junit.Assert;
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/util/config/ShardingItemParametersTest.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/util/config/ShardingItemParametersTest.java
similarity index 92%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/util/config/ShardingItemParametersTest.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/util/config/ShardingItemParametersTest.java
index 470f28a..6ff0815 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/util/config/ShardingItemParametersTest.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/util/config/ShardingItemParametersTest.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.util.config;
+package org.apache.shardingsphere.elasticjob.cloud.util.config;
 
-import io.elasticjob.cloud.exception.JobConfigurationException;
+import org.apache.shardingsphere.elasticjob.cloud.exception.JobConfigurationException;
 import org.junit.Test;
 
 import java.util.Collections;
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/util/config/ShardingItemsTest.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/util/config/ShardingItemsTest.java
similarity index 96%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/util/config/ShardingItemsTest.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/util/config/ShardingItemsTest.java
index bf88c04..48d60de 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/util/config/ShardingItemsTest.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/util/config/ShardingItemsTest.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.util.config;
+package org.apache.shardingsphere.elasticjob.cloud.util.config;
 
 import org.junit.Test;
 
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/util/digest/EncryptionTest.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/util/digest/EncryptionTest.java
similarity index 94%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/util/digest/EncryptionTest.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/util/digest/EncryptionTest.java
index cc3161a..50e42ba 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/util/digest/EncryptionTest.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/util/digest/EncryptionTest.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.util.digest;
+package org.apache.shardingsphere.elasticjob.cloud.util.digest;
 
 import org.hamcrest.core.Is;
 import org.junit.Assert;
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/util/env/HostExceptionTest.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/util/env/HostExceptionTest.java
similarity index 94%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/util/env/HostExceptionTest.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/util/env/HostExceptionTest.java
index ea44c23..b757f4b 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/util/env/HostExceptionTest.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/util/env/HostExceptionTest.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.util.env;
+package org.apache.shardingsphere.elasticjob.cloud.util.env;
 
 import org.hamcrest.core.Is;
 import org.junit.Test;
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/util/env/IpUtilsTest.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/util/env/IpUtilsTest.java
similarity index 94%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/util/env/IpUtilsTest.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/util/env/IpUtilsTest.java
index f18f117..ee89d79 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/util/env/IpUtilsTest.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/util/env/IpUtilsTest.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.util.env;
+package org.apache.shardingsphere.elasticjob.cloud.util.env;
 
 import org.junit.Test;
 
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/util/env/TimeServiceTest.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/util/env/TimeServiceTest.java
similarity index 94%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/util/env/TimeServiceTest.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/util/env/TimeServiceTest.java
index 13920b1..111ff10 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/util/env/TimeServiceTest.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/util/env/TimeServiceTest.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.util.env;
+package org.apache.shardingsphere.elasticjob.cloud.util.env;
 
 import org.junit.Assert;
 import org.junit.Test;
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/util/json/GsonFactoryTest.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/util/json/GsonFactoryTest.java
similarity index 96%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/util/json/GsonFactoryTest.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/util/json/GsonFactoryTest.java
index f1107a9..fa3b6cd 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/util/json/GsonFactoryTest.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/util/json/GsonFactoryTest.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.util.json;
+package org.apache.shardingsphere.elasticjob.cloud.util.json;
 
 import com.google.gson.Gson;
 import com.google.gson.TypeAdapter;
diff --git a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/util/json/JobConfigurationGsonTypeAdapterTest.java b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/util/json/JobConfigurationGsonTypeAdapterTest.java
similarity index 84%
rename from elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/util/json/JobConfigurationGsonTypeAdapterTest.java
rename to elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/util/json/JobConfigurationGsonTypeAdapterTest.java
index 3e13171..9253362 100644
--- a/elastic-job-cloud-common/src/test/java/io/elasticjob/cloud/util/json/JobConfigurationGsonTypeAdapterTest.java
+++ b/elastic-job-cloud-common/src/test/java/org/apache/shardingsphere/elasticjob/cloud/util/json/JobConfigurationGsonTypeAdapterTest.java
@@ -15,19 +15,19 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.util.json;
+package org.apache.shardingsphere.elasticjob.cloud.util.json;
 
 import com.google.gson.stream.JsonReader;
 import com.google.gson.stream.JsonWriter;
-import io.elasticjob.cloud.config.JobTypeConfiguration;
-import io.elasticjob.cloud.fixture.APIJsonConstants;
-import io.elasticjob.cloud.fixture.config.TestDataflowJobConfiguration;
-import io.elasticjob.cloud.fixture.config.TestJobRootConfiguration;
-import io.elasticjob.cloud.fixture.config.TestScriptJobConfiguration;
-import io.elasticjob.cloud.fixture.config.TestSimpleJobConfiguration;
-import io.elasticjob.cloud.executor.handler.impl.DefaultExecutorServiceHandler;
-import io.elasticjob.cloud.fixture.handler.IgnoreJobExceptionHandler;
-import io.elasticjob.cloud.fixture.handler.ThrowJobExceptionHandler;
+import org.apache.shardingsphere.elasticjob.cloud.config.JobTypeConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.fixture.APIJsonConstants;
+import org.apache.shardingsphere.elasticjob.cloud.fixture.config.TestDataflowJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.fixture.config.TestJobRootConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.fixture.config.TestScriptJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.fixture.config.TestSimpleJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.executor.handler.impl.DefaultExecutorServiceHandler;
+import org.apache.shardingsphere.elasticjob.cloud.fixture.handler.IgnoreJobExceptionHandler;
+import org.apache.shardingsphere.elasticjob.cloud.fixture.handler.ThrowJobExceptionHandler;
 import org.hamcrest.core.Is;
 import org.junit.Assert;
 import org.junit.BeforeClass;
diff --git a/elastic-job-cloud-common/src/test/resources/logback-test.xml b/elastic-job-cloud-common/src/test/resources/logback-test.xml
index 03049cb..8403c6f 100644
--- a/elastic-job-cloud-common/src/test/resources/logback-test.xml
+++ b/elastic-job-cloud-common/src/test/resources/logback-test.xml
@@ -36,8 +36,8 @@
         <appender-ref ref="STDOUT" />
     </root>
     
-    <logger name="io.elasticjob.cloud.event.rdb.JobEventRdbConfiguration" level="OFF" />
-    <logger name="io.elasticjob.cloud.event.JobEventBus" level="OFF" />
-    <logger name="io.elasticjob.cloud.executor.handler.impl.DefaultJobExceptionHandler" level="OFF" />
+    <logger name="org.apache.shardingsphere.elasticjob.cloud.event.rdb.JobEventRdbConfiguration" level="OFF" />
+    <logger name="org.apache.shardingsphere.elasticjob.cloud.event.JobEventBus" level="OFF" />
+    <logger name="org.apache.shardingsphere.elasticjob.cloud.executor.handler.impl.DefaultJobExceptionHandler" level="OFF" />
     <logger name="org.apache.curator.framework.recipes.leader.LeaderSelector" level="OFF" />
 </configuration>
diff --git a/elastic-job-cloud-executor/src/main/java/io/elasticjob/cloud/api/JobBootstrap.java b/elastic-job-cloud-executor/src/main/java/org/apache/shardingsphere/elasticjob/cloud/api/JobBootstrap.java
similarity index 91%
rename from elastic-job-cloud-executor/src/main/java/io/elasticjob/cloud/api/JobBootstrap.java
rename to elastic-job-cloud-executor/src/main/java/org/apache/shardingsphere/elasticjob/cloud/api/JobBootstrap.java
index 7e466c6..6cf3921 100644
--- a/elastic-job-cloud-executor/src/main/java/io/elasticjob/cloud/api/JobBootstrap.java
+++ b/elastic-job-cloud-executor/src/main/java/org/apache/shardingsphere/elasticjob/cloud/api/JobBootstrap.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.api;
+package org.apache.shardingsphere.elasticjob.cloud.api;
 
-import io.elasticjob.cloud.executor.TaskExecutor;
+import org.apache.shardingsphere.elasticjob.cloud.executor.TaskExecutor;
 import lombok.AccessLevel;
 import lombok.NoArgsConstructor;
 import org.apache.mesos.MesosExecutorDriver;
diff --git a/elastic-job-cloud-executor/src/main/java/io/elasticjob/cloud/executor/CloudJobFacade.java b/elastic-job-cloud-executor/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/CloudJobFacade.java
similarity index 84%
rename from elastic-job-cloud-executor/src/main/java/io/elasticjob/cloud/executor/CloudJobFacade.java
rename to elastic-job-cloud-executor/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/CloudJobFacade.java
index b1627e2..5c82d3c 100644
--- a/elastic-job-cloud-executor/src/main/java/io/elasticjob/cloud/executor/CloudJobFacade.java
+++ b/elastic-job-cloud-executor/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/CloudJobFacade.java
@@ -15,15 +15,15 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.executor;
+package org.apache.shardingsphere.elasticjob.cloud.executor;
 
-import io.elasticjob.cloud.config.JobRootConfiguration;
-import io.elasticjob.cloud.config.dataflow.DataflowJobConfiguration;
-import io.elasticjob.cloud.context.TaskContext;
-import io.elasticjob.cloud.event.JobEventBus;
-import io.elasticjob.cloud.event.type.JobExecutionEvent;
-import io.elasticjob.cloud.event.type.JobStatusTraceEvent;
-import io.elasticjob.cloud.exception.JobExecutionEnvironmentException;
+import org.apache.shardingsphere.elasticjob.cloud.config.JobRootConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.config.dataflow.DataflowJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.context.TaskContext;
+import org.apache.shardingsphere.elasticjob.cloud.event.JobEventBus;
+import org.apache.shardingsphere.elasticjob.cloud.event.type.JobExecutionEvent;
+import org.apache.shardingsphere.elasticjob.cloud.event.type.JobStatusTraceEvent;
+import org.apache.shardingsphere.elasticjob.cloud.exception.JobExecutionEnvironmentException;
 import lombok.RequiredArgsConstructor;
 
 import java.util.Collection;
diff --git a/elastic-job-cloud-executor/src/main/java/io/elasticjob/cloud/executor/DaemonTaskScheduler.java b/elastic-job-cloud-executor/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/DaemonTaskScheduler.java
similarity index 96%
rename from elastic-job-cloud-executor/src/main/java/io/elasticjob/cloud/executor/DaemonTaskScheduler.java
rename to elastic-job-cloud-executor/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/DaemonTaskScheduler.java
index 033233e..e95df67 100644
--- a/elastic-job-cloud-executor/src/main/java/io/elasticjob/cloud/executor/DaemonTaskScheduler.java
+++ b/elastic-job-cloud-executor/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/DaemonTaskScheduler.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.executor;
+package org.apache.shardingsphere.elasticjob.cloud.executor;
 
-import io.elasticjob.cloud.api.ElasticJob;
-import io.elasticjob.cloud.config.JobRootConfiguration;
-import io.elasticjob.cloud.exception.JobSystemException;
+import org.apache.shardingsphere.elasticjob.cloud.api.ElasticJob;
+import org.apache.shardingsphere.elasticjob.cloud.config.JobRootConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.exception.JobSystemException;
 import lombok.RequiredArgsConstructor;
 import lombok.Setter;
 import org.apache.mesos.ExecutorDriver;
diff --git a/elastic-job-cloud-executor/src/main/java/io/elasticjob/cloud/executor/JobConfigurationContext.java b/elastic-job-cloud-executor/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/JobConfigurationContext.java
similarity index 82%
rename from elastic-job-cloud-executor/src/main/java/io/elasticjob/cloud/executor/JobConfigurationContext.java
rename to elastic-job-cloud-executor/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/JobConfigurationContext.java
index 5bd576c..07679f4 100644
--- a/elastic-job-cloud-executor/src/main/java/io/elasticjob/cloud/executor/JobConfigurationContext.java
+++ b/elastic-job-cloud-executor/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/JobConfigurationContext.java
@@ -15,16 +15,16 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.executor;
+package org.apache.shardingsphere.elasticjob.cloud.executor;
 
-import io.elasticjob.cloud.api.JobType;
-import io.elasticjob.cloud.config.JobCoreConfiguration;
-import io.elasticjob.cloud.config.JobRootConfiguration;
-import io.elasticjob.cloud.config.JobTypeConfiguration;
-import io.elasticjob.cloud.config.script.ScriptJobConfiguration;
-import io.elasticjob.cloud.config.dataflow.DataflowJobConfiguration;
-import io.elasticjob.cloud.config.simple.SimpleJobConfiguration;
-import io.elasticjob.cloud.executor.handler.JobProperties.JobPropertiesEnum;
+import org.apache.shardingsphere.elasticjob.cloud.api.JobType;
+import org.apache.shardingsphere.elasticjob.cloud.config.JobCoreConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.config.JobRootConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.config.JobTypeConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.config.script.ScriptJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.config.dataflow.DataflowJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.config.simple.SimpleJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.executor.handler.JobProperties.JobPropertiesEnum;
 import com.google.common.base.Preconditions;
 import com.google.common.base.Strings;
 import lombok.Getter;
diff --git a/elastic-job-cloud-executor/src/main/java/io/elasticjob/cloud/executor/TaskExecutor.java b/elastic-job-cloud-executor/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/TaskExecutor.java
similarity index 93%
rename from elastic-job-cloud-executor/src/main/java/io/elasticjob/cloud/executor/TaskExecutor.java
rename to elastic-job-cloud-executor/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/TaskExecutor.java
index 8db199d..71e6209 100644
--- a/elastic-job-cloud-executor/src/main/java/io/elasticjob/cloud/executor/TaskExecutor.java
+++ b/elastic-job-cloud-executor/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/TaskExecutor.java
@@ -15,15 +15,15 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.executor;
+package org.apache.shardingsphere.elasticjob.cloud.executor;
 
-import io.elasticjob.cloud.api.ElasticJob;
-import io.elasticjob.cloud.api.script.ScriptJob;
-import io.elasticjob.cloud.event.JobEventBus;
-import io.elasticjob.cloud.event.rdb.JobEventRdbConfiguration;
-import io.elasticjob.cloud.exception.ExceptionUtil;
-import io.elasticjob.cloud.exception.JobSystemException;
-import io.elasticjob.cloud.util.concurrent.ExecutorServiceObject;
+import org.apache.shardingsphere.elasticjob.cloud.api.ElasticJob;
+import org.apache.shardingsphere.elasticjob.cloud.api.script.ScriptJob;
+import org.apache.shardingsphere.elasticjob.cloud.event.JobEventBus;
+import org.apache.shardingsphere.elasticjob.cloud.event.rdb.JobEventRdbConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.exception.ExceptionUtil;
+import org.apache.shardingsphere.elasticjob.cloud.exception.JobSystemException;
+import org.apache.shardingsphere.elasticjob.cloud.util.concurrent.ExecutorServiceObject;
 import com.google.common.base.Strings;
 import lombok.RequiredArgsConstructor;
 import lombok.extern.slf4j.Slf4j;
diff --git a/elastic-job-cloud-executor/src/main/java/io/elasticjob/cloud/executor/local/LocalCloudJobConfiguration.java b/elastic-job-cloud-executor/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/local/LocalCloudJobConfiguration.java
similarity index 86%
rename from elastic-job-cloud-executor/src/main/java/io/elasticjob/cloud/executor/local/LocalCloudJobConfiguration.java
rename to elastic-job-cloud-executor/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/local/LocalCloudJobConfiguration.java
index 15c7c54..88ea65c 100644
--- a/elastic-job-cloud-executor/src/main/java/io/elasticjob/cloud/executor/local/LocalCloudJobConfiguration.java
+++ b/elastic-job-cloud-executor/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/local/LocalCloudJobConfiguration.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.executor.local;
+package org.apache.shardingsphere.elasticjob.cloud.executor.local;
 
-import io.elasticjob.cloud.config.JobRootConfiguration;
-import io.elasticjob.cloud.config.JobTypeConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.config.JobRootConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.config.JobTypeConfiguration;
 import lombok.AllArgsConstructor;
 import lombok.Getter;
 import lombok.RequiredArgsConstructor;
diff --git a/elastic-job-cloud-executor/src/main/java/io/elasticjob/cloud/executor/local/LocalTaskExecutor.java b/elastic-job-cloud-executor/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/local/LocalTaskExecutor.java
similarity index 78%
rename from elastic-job-cloud-executor/src/main/java/io/elasticjob/cloud/executor/local/LocalTaskExecutor.java
rename to elastic-job-cloud-executor/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/local/LocalTaskExecutor.java
index 42befd1..4412644 100644
--- a/elastic-job-cloud-executor/src/main/java/io/elasticjob/cloud/executor/local/LocalTaskExecutor.java
+++ b/elastic-job-cloud-executor/src/main/java/org/apache/shardingsphere/elasticjob/cloud/executor/local/LocalTaskExecutor.java
@@ -15,25 +15,25 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.executor.local;
+package org.apache.shardingsphere.elasticjob.cloud.executor.local;
 
-import io.elasticjob.cloud.api.ElasticJob;
-import io.elasticjob.cloud.api.JobType;
-import io.elasticjob.cloud.api.dataflow.DataflowJob;
-import io.elasticjob.cloud.api.simple.SimpleJob;
-import io.elasticjob.cloud.config.JobCoreConfiguration;
-import io.elasticjob.cloud.config.script.ScriptJobConfiguration;
-import io.elasticjob.cloud.event.JobEventBus;
-import io.elasticjob.cloud.executor.AbstractElasticJobExecutor;
-import io.elasticjob.cloud.executor.CloudJobFacade;
-import io.elasticjob.cloud.executor.JobConfigurationContext;
-import io.elasticjob.cloud.executor.ShardingContexts;
-import io.elasticjob.cloud.executor.type.DataflowJobExecutor;
-import io.elasticjob.cloud.config.dataflow.DataflowJobConfiguration;
-import io.elasticjob.cloud.exception.JobSystemException;
-import io.elasticjob.cloud.executor.type.ScriptJobExecutor;
-import io.elasticjob.cloud.executor.type.SimpleJobExecutor;
-import io.elasticjob.cloud.util.config.ShardingItemParameters;
+import org.apache.shardingsphere.elasticjob.cloud.api.ElasticJob;
+import org.apache.shardingsphere.elasticjob.cloud.api.JobType;
+import org.apache.shardingsphere.elasticjob.cloud.api.dataflow.DataflowJob;
+import org.apache.shardingsphere.elasticjob.cloud.api.simple.SimpleJob;
+import org.apache.shardingsphere.elasticjob.cloud.config.JobCoreConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.config.script.ScriptJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.event.JobEventBus;
+import org.apache.shardingsphere.elasticjob.cloud.executor.AbstractElasticJobExecutor;
+import org.apache.shardingsphere.elasticjob.cloud.executor.CloudJobFacade;
+import org.apache.shardingsphere.elasticjob.cloud.executor.JobConfigurationContext;
+import org.apache.shardingsphere.elasticjob.cloud.executor.ShardingContexts;
+import org.apache.shardingsphere.elasticjob.cloud.executor.type.DataflowJobExecutor;
+import org.apache.shardingsphere.elasticjob.cloud.config.dataflow.DataflowJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.exception.JobSystemException;
+import org.apache.shardingsphere.elasticjob.cloud.executor.type.ScriptJobExecutor;
+import org.apache.shardingsphere.elasticjob.cloud.executor.type.SimpleJobExecutor;
+import org.apache.shardingsphere.elasticjob.cloud.util.config.ShardingItemParameters;
 import com.google.common.base.Joiner;
 import com.google.common.base.Strings;
 import lombok.RequiredArgsConstructor;
diff --git a/elastic-job-cloud-executor/src/test/java/io/elasticjob/cloud/executor/AllCloudExecutorTests.java b/elastic-job-cloud-executor/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/AllCloudExecutorTests.java
similarity index 89%
rename from elastic-job-cloud-executor/src/test/java/io/elasticjob/cloud/executor/AllCloudExecutorTests.java
rename to elastic-job-cloud-executor/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/AllCloudExecutorTests.java
index 9f794a7..0f19c8b 100644
--- a/elastic-job-cloud-executor/src/test/java/io/elasticjob/cloud/executor/AllCloudExecutorTests.java
+++ b/elastic-job-cloud-executor/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/AllCloudExecutorTests.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.executor;
+package org.apache.shardingsphere.elasticjob.cloud.executor;
 
-import io.elasticjob.cloud.executor.local.AllLocalExecutorTests;
+import org.apache.shardingsphere.elasticjob.cloud.executor.local.AllLocalExecutorTests;
 import lombok.AccessLevel;
 import lombok.NoArgsConstructor;
 import org.junit.runner.RunWith;
diff --git a/elastic-job-cloud-executor/src/test/java/io/elasticjob/cloud/executor/CloudJobFacadeTest.java b/elastic-job-cloud-executor/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/CloudJobFacadeTest.java
similarity index 88%
rename from elastic-job-cloud-executor/src/test/java/io/elasticjob/cloud/executor/CloudJobFacadeTest.java
rename to elastic-job-cloud-executor/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/CloudJobFacadeTest.java
index ad7b094..6f695a8 100644
--- a/elastic-job-cloud-executor/src/test/java/io/elasticjob/cloud/executor/CloudJobFacadeTest.java
+++ b/elastic-job-cloud-executor/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/CloudJobFacadeTest.java
@@ -15,16 +15,16 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.executor;
+package org.apache.shardingsphere.elasticjob.cloud.executor;
 
-import io.elasticjob.cloud.api.ElasticJob;
-import io.elasticjob.cloud.api.JobType;
-import io.elasticjob.cloud.context.ExecutionType;
-import io.elasticjob.cloud.config.JobRootConfiguration;
-import io.elasticjob.cloud.event.JobEventBus;
-import io.elasticjob.cloud.event.type.JobExecutionEvent;
-import io.elasticjob.cloud.exception.JobExecutionEnvironmentException;
-import io.elasticjob.cloud.event.type.JobStatusTraceEvent;
+import org.apache.shardingsphere.elasticjob.cloud.api.ElasticJob;
+import org.apache.shardingsphere.elasticjob.cloud.api.JobType;
+import org.apache.shardingsphere.elasticjob.cloud.context.ExecutionType;
+import org.apache.shardingsphere.elasticjob.cloud.config.JobRootConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.event.JobEventBus;
+import org.apache.shardingsphere.elasticjob.cloud.event.type.JobExecutionEvent;
+import org.apache.shardingsphere.elasticjob.cloud.exception.JobExecutionEnvironmentException;
+import org.apache.shardingsphere.elasticjob.cloud.event.type.JobStatusTraceEvent;
 import org.junit.Test;
 import org.mockito.Mock;
 import org.mockito.MockitoAnnotations;
diff --git a/elastic-job-cloud-executor/src/test/java/io/elasticjob/cloud/executor/DaemonTaskSchedulerTest.java b/elastic-job-cloud-executor/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/DaemonTaskSchedulerTest.java
similarity index 94%
rename from elastic-job-cloud-executor/src/test/java/io/elasticjob/cloud/executor/DaemonTaskSchedulerTest.java
rename to elastic-job-cloud-executor/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/DaemonTaskSchedulerTest.java
index d6124bc..604213b 100644
--- a/elastic-job-cloud-executor/src/test/java/io/elasticjob/cloud/executor/DaemonTaskSchedulerTest.java
+++ b/elastic-job-cloud-executor/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/DaemonTaskSchedulerTest.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.executor;
+package org.apache.shardingsphere.elasticjob.cloud.executor;
 
-import io.elasticjob.cloud.executor.fixture.TestScriptJobConfiguration;
-import io.elasticjob.cloud.context.ExecutionType;
+import org.apache.shardingsphere.elasticjob.cloud.executor.fixture.TestScriptJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.context.ExecutionType;
 import org.apache.mesos.ExecutorDriver;
 import org.apache.mesos.Protos.TaskID;
 import org.apache.mesos.Protos.TaskState;
diff --git a/elastic-job-cloud-executor/src/test/java/io/elasticjob/cloud/executor/JobConfigurationContextTest.java b/elastic-job-cloud-executor/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/JobConfigurationContextTest.java
similarity index 85%
rename from elastic-job-cloud-executor/src/test/java/io/elasticjob/cloud/executor/JobConfigurationContextTest.java
rename to elastic-job-cloud-executor/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/JobConfigurationContextTest.java
index e5133f6..e990a9a 100644
--- a/elastic-job-cloud-executor/src/test/java/io/elasticjob/cloud/executor/JobConfigurationContextTest.java
+++ b/elastic-job-cloud-executor/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/JobConfigurationContextTest.java
@@ -15,14 +15,14 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.executor;
+package org.apache.shardingsphere.elasticjob.cloud.executor;
 
-import io.elasticjob.cloud.api.JobType;
-import io.elasticjob.cloud.config.script.ScriptJobConfiguration;
-import io.elasticjob.cloud.executor.fixture.TestJob;
-import io.elasticjob.cloud.config.dataflow.DataflowJobConfiguration;
-import io.elasticjob.cloud.config.simple.SimpleJobConfiguration;
-import io.elasticjob.cloud.exception.JobExecutionEnvironmentException;
+import org.apache.shardingsphere.elasticjob.cloud.api.JobType;
+import org.apache.shardingsphere.elasticjob.cloud.config.script.ScriptJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.executor.fixture.TestJob;
+import org.apache.shardingsphere.elasticjob.cloud.config.dataflow.DataflowJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.config.simple.SimpleJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.exception.JobExecutionEnvironmentException;
 import org.hamcrest.core.Is;
 import org.junit.Assert;
 import org.junit.Test;
diff --git a/elastic-job-cloud-executor/src/test/java/io/elasticjob/cloud/executor/TaskExecutorTest.java b/elastic-job-cloud-executor/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/TaskExecutorTest.java
similarity index 98%
rename from elastic-job-cloud-executor/src/test/java/io/elasticjob/cloud/executor/TaskExecutorTest.java
rename to elastic-job-cloud-executor/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/TaskExecutorTest.java
index 456807b..ed7ddc8 100644
--- a/elastic-job-cloud-executor/src/test/java/io/elasticjob/cloud/executor/TaskExecutorTest.java
+++ b/elastic-job-cloud-executor/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/TaskExecutorTest.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.executor;
+package org.apache.shardingsphere.elasticjob.cloud.executor;
 
 import com.google.protobuf.ByteString;
 import org.apache.commons.lang3.SerializationUtils;
diff --git a/elastic-job-cloud-executor/src/test/java/io/elasticjob/cloud/executor/TaskExecutorThreadTest.java b/elastic-job-cloud-executor/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/TaskExecutorThreadTest.java
similarity index 94%
rename from elastic-job-cloud-executor/src/test/java/io/elasticjob/cloud/executor/TaskExecutorThreadTest.java
rename to elastic-job-cloud-executor/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/TaskExecutorThreadTest.java
index 96c36fc..f42cf32 100644
--- a/elastic-job-cloud-executor/src/test/java/io/elasticjob/cloud/executor/TaskExecutorThreadTest.java
+++ b/elastic-job-cloud-executor/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/TaskExecutorThreadTest.java
@@ -15,12 +15,12 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.executor;
+package org.apache.shardingsphere.elasticjob.cloud.executor;
 
-import io.elasticjob.cloud.api.JobType;
-import io.elasticjob.cloud.context.ExecutionType;
-import io.elasticjob.cloud.executor.fixture.TestJob;
-import io.elasticjob.cloud.exception.JobSystemException;
+import org.apache.shardingsphere.elasticjob.cloud.api.JobType;
+import org.apache.shardingsphere.elasticjob.cloud.context.ExecutionType;
+import org.apache.shardingsphere.elasticjob.cloud.executor.fixture.TestJob;
+import org.apache.shardingsphere.elasticjob.cloud.exception.JobSystemException;
 import com.google.protobuf.ByteString;
 import org.apache.commons.lang3.SerializationUtils;
 import org.apache.mesos.ExecutorDriver;
@@ -81,7 +81,7 @@ public final class TaskExecutorThreadTest {
         try {
             taskThread.run();
         } catch (final JobSystemException ex) {
-            Assert.assertTrue(ex.getMessage().startsWith("Elastic-Job: Class 'io.elasticjob.cloud.executor.TaskExecutorThreadTest' must implements ElasticJob interface."));
+            Assert.assertTrue(ex.getMessage().startsWith("Elastic-Job: Class 'TaskExecutorThreadTest' must implements ElasticJob interface."));
         }
     }
     
diff --git a/elastic-job-cloud-executor/src/test/java/io/elasticjob/cloud/executor/fixture/TestJob.java b/elastic-job-cloud-executor/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/fixture/TestJob.java
similarity index 81%
rename from elastic-job-cloud-executor/src/test/java/io/elasticjob/cloud/executor/fixture/TestJob.java
rename to elastic-job-cloud-executor/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/fixture/TestJob.java
index 80b1cf5..f80f428 100644
--- a/elastic-job-cloud-executor/src/test/java/io/elasticjob/cloud/executor/fixture/TestJob.java
+++ b/elastic-job-cloud-executor/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/fixture/TestJob.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.executor.fixture;
+package org.apache.shardingsphere.elasticjob.cloud.executor.fixture;
 
-import io.elasticjob.cloud.api.ShardingContext;
-import io.elasticjob.cloud.api.simple.SimpleJob;
+import org.apache.shardingsphere.elasticjob.cloud.api.ShardingContext;
+import org.apache.shardingsphere.elasticjob.cloud.api.simple.SimpleJob;
 
 public final class TestJob implements SimpleJob {
     
diff --git a/elastic-job-cloud-executor/src/test/java/io/elasticjob/cloud/executor/fixture/TestScriptJobConfiguration.java b/elastic-job-cloud-executor/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/fixture/TestScriptJobConfiguration.java
similarity index 73%
rename from elastic-job-cloud-executor/src/test/java/io/elasticjob/cloud/executor/fixture/TestScriptJobConfiguration.java
rename to elastic-job-cloud-executor/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/fixture/TestScriptJobConfiguration.java
index c38b568..be71167 100644
--- a/elastic-job-cloud-executor/src/test/java/io/elasticjob/cloud/executor/fixture/TestScriptJobConfiguration.java
+++ b/elastic-job-cloud-executor/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/fixture/TestScriptJobConfiguration.java
@@ -15,13 +15,13 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.executor.fixture;
+package org.apache.shardingsphere.elasticjob.cloud.executor.fixture;
 
-import io.elasticjob.cloud.config.JobTypeConfiguration;
-import io.elasticjob.cloud.config.script.ScriptJobConfiguration;
-import io.elasticjob.cloud.config.JobCoreConfiguration;
-import io.elasticjob.cloud.config.JobRootConfiguration;
-import io.elasticjob.cloud.executor.handler.JobProperties;
+import org.apache.shardingsphere.elasticjob.cloud.config.JobTypeConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.config.script.ScriptJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.config.JobCoreConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.config.JobRootConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.executor.handler.JobProperties;
 import lombok.RequiredArgsConstructor;
 
 @RequiredArgsConstructor
diff --git a/elastic-job-cloud-executor/src/test/java/io/elasticjob/cloud/executor/local/AllLocalExecutorTests.java b/elastic-job-cloud-executor/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/local/AllLocalExecutorTests.java
similarity index 94%
rename from elastic-job-cloud-executor/src/test/java/io/elasticjob/cloud/executor/local/AllLocalExecutorTests.java
rename to elastic-job-cloud-executor/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/local/AllLocalExecutorTests.java
index a79a3a8..8e41ad0 100644
--- a/elastic-job-cloud-executor/src/test/java/io/elasticjob/cloud/executor/local/AllLocalExecutorTests.java
+++ b/elastic-job-cloud-executor/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/local/AllLocalExecutorTests.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.executor.local;
+package org.apache.shardingsphere.elasticjob.cloud.executor.local;
 
 import lombok.AccessLevel;
 import lombok.NoArgsConstructor;
diff --git a/elastic-job-cloud-executor/src/test/java/io/elasticjob/cloud/executor/local/LocalTaskExecutorTest.java b/elastic-job-cloud-executor/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/local/LocalTaskExecutorTest.java
similarity index 88%
rename from elastic-job-cloud-executor/src/test/java/io/elasticjob/cloud/executor/local/LocalTaskExecutorTest.java
rename to elastic-job-cloud-executor/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/local/LocalTaskExecutorTest.java
index 5179cc4..e9f1831 100644
--- a/elastic-job-cloud-executor/src/test/java/io/elasticjob/cloud/executor/local/LocalTaskExecutorTest.java
+++ b/elastic-job-cloud-executor/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/local/LocalTaskExecutorTest.java
@@ -15,15 +15,15 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.executor.local;
+package org.apache.shardingsphere.elasticjob.cloud.executor.local;
 
-import io.elasticjob.cloud.config.script.ScriptJobConfiguration;
-import io.elasticjob.cloud.executor.local.fixture.TestDataflowJob;
-import io.elasticjob.cloud.executor.local.fixture.TestSimpleJob;
-import io.elasticjob.cloud.config.JobCoreConfiguration;
-import io.elasticjob.cloud.config.dataflow.DataflowJobConfiguration;
-import io.elasticjob.cloud.config.simple.SimpleJobConfiguration;
-import io.elasticjob.cloud.exception.JobSystemException;
+import org.apache.shardingsphere.elasticjob.cloud.config.script.ScriptJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.executor.local.fixture.TestDataflowJob;
+import org.apache.shardingsphere.elasticjob.cloud.executor.local.fixture.TestSimpleJob;
+import org.apache.shardingsphere.elasticjob.cloud.config.JobCoreConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.config.dataflow.DataflowJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.config.simple.SimpleJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.exception.JobSystemException;
 import org.hamcrest.core.Is;
 import org.junit.Assert;
 import org.junit.Before;
diff --git a/elastic-job-cloud-executor/src/test/java/io/elasticjob/cloud/executor/local/fixture/TestDataflowJob.java b/elastic-job-cloud-executor/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/local/fixture/TestDataflowJob.java
similarity index 87%
rename from elastic-job-cloud-executor/src/test/java/io/elasticjob/cloud/executor/local/fixture/TestDataflowJob.java
rename to elastic-job-cloud-executor/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/local/fixture/TestDataflowJob.java
index 9f8fac7..2085e94 100644
--- a/elastic-job-cloud-executor/src/test/java/io/elasticjob/cloud/executor/local/fixture/TestDataflowJob.java
+++ b/elastic-job-cloud-executor/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/local/fixture/TestDataflowJob.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.executor.local.fixture;
+package org.apache.shardingsphere.elasticjob.cloud.executor.local.fixture;
 
-import io.elasticjob.cloud.api.ShardingContext;
-import io.elasticjob.cloud.api.dataflow.DataflowJob;
+import org.apache.shardingsphere.elasticjob.cloud.api.ShardingContext;
+import org.apache.shardingsphere.elasticjob.cloud.api.dataflow.DataflowJob;
 import com.google.common.base.Function;
 import com.google.common.collect.Lists;
 import lombok.Getter;
diff --git a/elastic-job-cloud-executor/src/test/java/io/elasticjob/cloud/executor/local/fixture/TestSimpleJob.java b/elastic-job-cloud-executor/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/local/fixture/TestSimpleJob.java
similarity index 87%
rename from elastic-job-cloud-executor/src/test/java/io/elasticjob/cloud/executor/local/fixture/TestSimpleJob.java
rename to elastic-job-cloud-executor/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/local/fixture/TestSimpleJob.java
index 73cce56..7e0285a 100644
--- a/elastic-job-cloud-executor/src/test/java/io/elasticjob/cloud/executor/local/fixture/TestSimpleJob.java
+++ b/elastic-job-cloud-executor/src/test/java/org/apache/shardingsphere/elasticjob/cloud/executor/local/fixture/TestSimpleJob.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.executor.local.fixture;
+package org.apache.shardingsphere.elasticjob.cloud.executor.local.fixture;
 
-import io.elasticjob.cloud.api.ShardingContext;
-import io.elasticjob.cloud.api.simple.SimpleJob;
+import org.apache.shardingsphere.elasticjob.cloud.api.ShardingContext;
+import org.apache.shardingsphere.elasticjob.cloud.api.simple.SimpleJob;
 import com.google.common.base.Strings;
 import lombok.Getter;
 import lombok.Setter;
diff --git a/elastic-job-cloud-executor/src/test/resources/applicationContext.xml b/elastic-job-cloud-executor/src/test/resources/applicationContext.xml
index fff7a23..c48167f 100644
--- a/elastic-job-cloud-executor/src/test/resources/applicationContext.xml
+++ b/elastic-job-cloud-executor/src/test/resources/applicationContext.xml
@@ -22,6 +22,6 @@
     xsi:schemaLocation="http://www.springframework.org/schema/beans 
                         http://www.springframework.org/schema/beans/spring-beans.xsd 
                         ">
-    <bean id="testJob" class="io.elasticjob.cloud.executor.fixture.TestJob" />
-    <bean id="testSimpleJob" class="io.elasticjob.cloud.executor.local.fixture.TestSimpleJob" />
+    <bean id="testJob" class="org.apache.shardingsphere.elasticjob.cloud.executor.fixture.TestJob" />
+    <bean id="testSimpleJob" class="org.apache.shardingsphere.elasticjob.cloud.executor.local.fixture.TestSimpleJob" />
 </beans>
diff --git a/elastic-job-cloud-executor/src/test/resources/logback-test.xml b/elastic-job-cloud-executor/src/test/resources/logback-test.xml
index ef40def..bb06d79 100644
--- a/elastic-job-cloud-executor/src/test/resources/logback-test.xml
+++ b/elastic-job-cloud-executor/src/test/resources/logback-test.xml
@@ -36,5 +36,5 @@
         <appender-ref ref="STDOUT" />
     </root>
     
-    <logger name="io.elasticjob.cloud.executor.TaskExecutor" level="OFF" />
+    <logger name="org.apache.shardingsphere.elasticjob.cloud.executor.TaskExecutor" level="OFF" />
 </configuration>
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/restful/GsonJsonProvider.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/restful/GsonJsonProvider.java
similarity index 96%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/restful/GsonJsonProvider.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/restful/GsonJsonProvider.java
index eb21b2a..f9cc311 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/restful/GsonJsonProvider.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/restful/GsonJsonProvider.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.restful;
+package org.apache.shardingsphere.elasticjob.cloud.restful;
 
-import io.elasticjob.cloud.util.json.GsonFactory;
+import org.apache.shardingsphere.elasticjob.cloud.util.json.GsonFactory;
 
 import javax.ws.rs.Consumes;
 import javax.ws.rs.Produces;
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/restful/RestfulException.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/restful/RestfulException.java
similarity index 94%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/restful/RestfulException.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/restful/RestfulException.java
index 8f0f7b6..c72d3b8 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/restful/RestfulException.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/restful/RestfulException.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.restful;
+package org.apache.shardingsphere.elasticjob.cloud.restful;
 
 /**
  * REST API异常.
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/restful/RestfulExceptionMapper.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/restful/RestfulExceptionMapper.java
similarity index 90%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/restful/RestfulExceptionMapper.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/restful/RestfulExceptionMapper.java
index 20e6706..76b7973 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/restful/RestfulExceptionMapper.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/restful/RestfulExceptionMapper.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.restful;
+package org.apache.shardingsphere.elasticjob.cloud.restful;
 
-import io.elasticjob.cloud.exception.ExceptionUtil;
+import org.apache.shardingsphere.elasticjob.cloud.exception.ExceptionUtil;
 
 import javax.ws.rs.core.MediaType;
 import javax.ws.rs.core.Response;
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/restful/RestfulServer.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/restful/RestfulServer.java
similarity index 98%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/restful/RestfulServer.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/restful/RestfulServer.java
index 6a290af..9e117e9 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/restful/RestfulServer.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/restful/RestfulServer.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.restful;
+package org.apache.shardingsphere.elasticjob.cloud.restful;
 
 import com.google.common.base.Joiner;
 import com.google.common.base.Optional;
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/Bootstrap.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/Bootstrap.java
similarity index 79%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/Bootstrap.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/Bootstrap.java
index 4b738a5..ea1c34f 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/Bootstrap.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/Bootstrap.java
@@ -15,14 +15,14 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler;
 
-import io.elasticjob.cloud.scheduler.ha.HANode;
-import io.elasticjob.cloud.scheduler.env.BootstrapEnvironment;
-import io.elasticjob.cloud.scheduler.ha.SchedulerElectionCandidate;
-import io.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
-import io.elasticjob.cloud.reg.zookeeper.ZookeeperElectionService;
-import io.elasticjob.cloud.reg.zookeeper.ZookeeperRegistryCenter;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.ha.HANode;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.env.BootstrapEnvironment;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.ha.SchedulerElectionCandidate;
+import org.apache.shardingsphere.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
+import org.apache.shardingsphere.elasticjob.cloud.reg.zookeeper.ZookeeperElectionService;
+import org.apache.shardingsphere.elasticjob.cloud.reg.zookeeper.ZookeeperRegistryCenter;
 import lombok.AccessLevel;
 import lombok.NoArgsConstructor;
 import lombok.extern.slf4j.Slf4j;
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/config/app/CloudAppConfiguration.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/app/CloudAppConfiguration.java
similarity index 94%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/config/app/CloudAppConfiguration.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/app/CloudAppConfiguration.java
index 46cbc06..97889df 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/config/app/CloudAppConfiguration.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/app/CloudAppConfiguration.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.config.app;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.config.app;
 
 import lombok.AllArgsConstructor;
 import lombok.Getter;
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/config/app/CloudAppConfigurationGsonFactory.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/app/CloudAppConfigurationGsonFactory.java
similarity index 95%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/config/app/CloudAppConfigurationGsonFactory.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/app/CloudAppConfigurationGsonFactory.java
index 4244a8b..caefc1d 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/config/app/CloudAppConfigurationGsonFactory.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/app/CloudAppConfigurationGsonFactory.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.config.app;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.config.app;
 
-import io.elasticjob.cloud.scheduler.config.constants.CloudConfigurationConstants;
-import io.elasticjob.cloud.util.json.GsonFactory;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.constants.CloudConfigurationConstants;
+import org.apache.shardingsphere.elasticjob.cloud.util.json.GsonFactory;
 import com.google.gson.TypeAdapter;
 import com.google.gson.stream.JsonReader;
 import com.google.gson.stream.JsonWriter;
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/config/app/CloudAppConfigurationNode.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/app/CloudAppConfigurationNode.java
similarity index 94%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/config/app/CloudAppConfigurationNode.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/app/CloudAppConfigurationNode.java
index d0e863a..1e72708 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/config/app/CloudAppConfigurationNode.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/app/CloudAppConfigurationNode.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.config.app;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.config.app;
 
 import lombok.AccessLevel;
 import lombok.NoArgsConstructor;
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/config/app/CloudAppConfigurationService.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/app/CloudAppConfigurationService.java
similarity index 95%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/config/app/CloudAppConfigurationService.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/app/CloudAppConfigurationService.java
index e1252ba..f47cf66 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/config/app/CloudAppConfigurationService.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/app/CloudAppConfigurationService.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.config.app;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.config.app;
 
-import io.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
+import org.apache.shardingsphere.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
 import com.google.common.base.Optional;
 import lombok.RequiredArgsConstructor;
 
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/config/constants/CloudConfigurationConstants.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/constants/CloudConfigurationConstants.java
similarity index 95%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/config/constants/CloudConfigurationConstants.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/constants/CloudConfigurationConstants.java
index f977adf..98c35e2 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/config/constants/CloudConfigurationConstants.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/constants/CloudConfigurationConstants.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.config.constants;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.config.constants;
 
 /**
  * Cloud配置的常量.
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/config/job/CloudJobConfiguration.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/job/CloudJobConfiguration.java
similarity index 87%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/config/job/CloudJobConfiguration.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/job/CloudJobConfiguration.java
index 224b96b..93637eb 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/config/job/CloudJobConfiguration.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/job/CloudJobConfiguration.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.config.job;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job;
 
-import io.elasticjob.cloud.config.JobTypeConfiguration;
-import io.elasticjob.cloud.config.JobRootConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.config.JobTypeConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.config.JobRootConfiguration;
 import lombok.AllArgsConstructor;
 import lombok.Getter;
 import lombok.RequiredArgsConstructor;
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/config/job/CloudJobConfigurationGsonFactory.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/job/CloudJobConfigurationGsonFactory.java
similarity index 93%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/config/job/CloudJobConfigurationGsonFactory.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/job/CloudJobConfigurationGsonFactory.java
index 2f54ed0..a37bc35 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/config/job/CloudJobConfigurationGsonFactory.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/job/CloudJobConfigurationGsonFactory.java
@@ -15,12 +15,12 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.config.job;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job;
 
-import io.elasticjob.cloud.scheduler.config.constants.CloudConfigurationConstants;
-import io.elasticjob.cloud.config.JobTypeConfiguration;
-import io.elasticjob.cloud.util.json.AbstractJobConfigurationGsonTypeAdapter;
-import io.elasticjob.cloud.util.json.GsonFactory;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.constants.CloudConfigurationConstants;
+import org.apache.shardingsphere.elasticjob.cloud.config.JobTypeConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.util.json.AbstractJobConfigurationGsonTypeAdapter;
+import org.apache.shardingsphere.elasticjob.cloud.util.json.GsonFactory;
 import com.google.common.base.Preconditions;
 import com.google.gson.stream.JsonReader;
 import com.google.gson.stream.JsonWriter;
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/config/job/CloudJobConfigurationListener.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/job/CloudJobConfigurationListener.java
similarity index 93%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/config/job/CloudJobConfigurationListener.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/job/CloudJobConfigurationListener.java
index f32f1ad..5c0110d 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/config/job/CloudJobConfigurationListener.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/job/CloudJobConfigurationListener.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.config.job;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job;
 
-import io.elasticjob.cloud.scheduler.producer.ProducerManager;
-import io.elasticjob.cloud.scheduler.state.ready.ReadyService;
-import io.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.producer.ProducerManager;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.state.ready.ReadyService;
+import org.apache.shardingsphere.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
 import lombok.extern.slf4j.Slf4j;
 import org.apache.curator.framework.CuratorFramework;
 import org.apache.curator.framework.recipes.cache.TreeCache;
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/config/job/CloudJobConfigurationNode.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/job/CloudJobConfigurationNode.java
similarity index 94%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/config/job/CloudJobConfigurationNode.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/job/CloudJobConfigurationNode.java
index 2bdb6e6..9d1cdfb 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/config/job/CloudJobConfigurationNode.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/job/CloudJobConfigurationNode.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.config.job;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job;
 
 import lombok.AccessLevel;
 import lombok.NoArgsConstructor;
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/config/job/CloudJobConfigurationService.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/job/CloudJobConfigurationService.java
similarity index 95%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/config/job/CloudJobConfigurationService.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/job/CloudJobConfigurationService.java
index c7b15a0..bba6240 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/config/job/CloudJobConfigurationService.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/job/CloudJobConfigurationService.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.config.job;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job;
 
 import com.google.common.base.Optional;
-import io.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
+import org.apache.shardingsphere.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
 import lombok.RequiredArgsConstructor;
 
 import java.util.ArrayList;
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/config/job/CloudJobExecutionType.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/job/CloudJobExecutionType.java
similarity index 92%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/config/job/CloudJobExecutionType.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/job/CloudJobExecutionType.java
index 9f3f735..be1ada7 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/config/job/CloudJobExecutionType.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/job/CloudJobExecutionType.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.config.job;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job;
 
 /**
  * 作业执行类型.
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/context/JobContext.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/context/JobContext.java
similarity index 88%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/context/JobContext.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/context/JobContext.java
index 2d481c1..4e3ce72 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/context/JobContext.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/context/JobContext.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.context;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.context;
 
-import io.elasticjob.cloud.scheduler.config.job.CloudJobConfiguration;
-import io.elasticjob.cloud.context.ExecutionType;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.context.ExecutionType;
 import lombok.Getter;
 import lombok.RequiredArgsConstructor;
 
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/env/BootstrapEnvironment.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/env/BootstrapEnvironment.java
similarity index 97%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/env/BootstrapEnvironment.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/env/BootstrapEnvironment.java
index e84cc31..a129ec6 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/env/BootstrapEnvironment.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/env/BootstrapEnvironment.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.env;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.env;
 
-import io.elasticjob.cloud.event.rdb.JobEventRdbConfiguration;
-import io.elasticjob.cloud.reg.zookeeper.ZookeeperConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.event.rdb.JobEventRdbConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.reg.zookeeper.ZookeeperConfiguration;
 import com.google.common.base.Optional;
 import com.google.common.base.Preconditions;
 import com.google.common.base.Strings;
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/env/FrameworkConfiguration.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/env/FrameworkConfiguration.java
similarity index 95%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/env/FrameworkConfiguration.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/env/FrameworkConfiguration.java
index 1c218c0..8389d83 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/env/FrameworkConfiguration.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/env/FrameworkConfiguration.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.env;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.env;
 
 import lombok.Getter;
 import lombok.RequiredArgsConstructor;
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/env/MesosConfiguration.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/env/MesosConfiguration.java
similarity index 95%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/env/MesosConfiguration.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/env/MesosConfiguration.java
index 7d187d7..60c012d 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/env/MesosConfiguration.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/env/MesosConfiguration.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.env;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.env;
 
 import lombok.Getter;
 import lombok.RequiredArgsConstructor;
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/env/RestfulServerConfiguration.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/env/RestfulServerConfiguration.java
similarity index 94%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/env/RestfulServerConfiguration.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/env/RestfulServerConfiguration.java
index aab19a8..a4b3179 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/env/RestfulServerConfiguration.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/env/RestfulServerConfiguration.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.env;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.env;
 
 import lombok.Getter;
 import lombok.RequiredArgsConstructor;
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/ha/FrameworkIDService.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/ha/FrameworkIDService.java
similarity index 92%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/ha/FrameworkIDService.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/ha/FrameworkIDService.java
index dbc9188..2e59ffb 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/ha/FrameworkIDService.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/ha/FrameworkIDService.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.ha;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.ha;
 
-import io.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
+import org.apache.shardingsphere.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
 import com.google.common.base.Optional;
 import com.google.common.base.Strings;
 import lombok.RequiredArgsConstructor;
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/ha/HANode.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/ha/HANode.java
similarity index 94%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/ha/HANode.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/ha/HANode.java
index 4239621..ebc8821 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/ha/HANode.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/ha/HANode.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.ha;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.ha;
 
 /**
  * 保存HA相关数据节点.
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/ha/SchedulerElectionCandidate.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/ha/SchedulerElectionCandidate.java
similarity index 80%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/ha/SchedulerElectionCandidate.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/ha/SchedulerElectionCandidate.java
index 63c1d9a..19c3a1e 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/ha/SchedulerElectionCandidate.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/ha/SchedulerElectionCandidate.java
@@ -15,12 +15,12 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.ha;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.ha;
 
-import io.elasticjob.cloud.scheduler.mesos.SchedulerService;
-import io.elasticjob.cloud.reg.base.ElectionCandidate;
-import io.elasticjob.cloud.exception.JobSystemException;
-import io.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.mesos.SchedulerService;
+import org.apache.shardingsphere.elasticjob.cloud.reg.base.ElectionCandidate;
+import org.apache.shardingsphere.elasticjob.cloud.exception.JobSystemException;
+import org.apache.shardingsphere.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
 
 /**
  * 调度器选举候选人.
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/mesos/AppConstraintEvaluator.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/AppConstraintEvaluator.java
similarity index 95%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/mesos/AppConstraintEvaluator.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/AppConstraintEvaluator.java
index 4b197aa..a803060 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/mesos/AppConstraintEvaluator.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/AppConstraintEvaluator.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.mesos;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.mesos;
 
-import io.elasticjob.cloud.scheduler.config.app.CloudAppConfiguration;
-import io.elasticjob.cloud.scheduler.config.job.CloudJobConfiguration;
-import io.elasticjob.cloud.context.TaskContext;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.app.CloudAppConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.context.TaskContext;
 import com.google.common.base.Optional;
 import com.google.common.base.Preconditions;
 import com.netflix.fenzo.ConstraintEvaluator;
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/mesos/FacadeService.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/FacadeService.java
similarity index 88%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/mesos/FacadeService.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/FacadeService.java
index c8381d8..ee62bf3 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/mesos/FacadeService.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/FacadeService.java
@@ -15,23 +15,23 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.mesos;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.mesos;
 
-import io.elasticjob.cloud.scheduler.config.app.CloudAppConfigurationService;
-import io.elasticjob.cloud.scheduler.config.job.CloudJobConfiguration;
-import io.elasticjob.cloud.scheduler.state.disable.app.DisableAppService;
-import io.elasticjob.cloud.scheduler.state.disable.job.DisableJobService;
-import io.elasticjob.cloud.scheduler.state.running.RunningService;
-import io.elasticjob.cloud.context.ExecutionType;
-import io.elasticjob.cloud.scheduler.config.app.CloudAppConfiguration;
-import io.elasticjob.cloud.scheduler.config.job.CloudJobConfigurationService;
-import io.elasticjob.cloud.scheduler.config.job.CloudJobExecutionType;
-import io.elasticjob.cloud.scheduler.context.JobContext;
-import io.elasticjob.cloud.scheduler.state.failover.FailoverService;
-import io.elasticjob.cloud.scheduler.state.failover.FailoverTaskInfo;
-import io.elasticjob.cloud.scheduler.state.ready.ReadyService;
-import io.elasticjob.cloud.context.TaskContext;
-import io.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.app.CloudAppConfigurationService;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.state.disable.app.DisableAppService;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.state.disable.job.DisableJobService;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.state.running.RunningService;
+import org.apache.shardingsphere.elasticjob.cloud.context.ExecutionType;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.app.CloudAppConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobConfigurationService;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobExecutionType;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.context.JobContext;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.state.failover.FailoverService;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.state.failover.FailoverTaskInfo;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.state.ready.ReadyService;
+import org.apache.shardingsphere.elasticjob.cloud.context.TaskContext;
+import org.apache.shardingsphere.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
 import com.google.common.base.Function;
 import com.google.common.base.Optional;
 import com.google.common.collect.Lists;
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/mesos/JobTaskRequest.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/JobTaskRequest.java
similarity index 91%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/mesos/JobTaskRequest.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/JobTaskRequest.java
index 1366131..584185a 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/mesos/JobTaskRequest.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/JobTaskRequest.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.mesos;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.mesos;
 
-import io.elasticjob.cloud.scheduler.config.job.CloudJobConfiguration;
-import io.elasticjob.cloud.context.TaskContext;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.context.TaskContext;
 import com.netflix.fenzo.ConstraintEvaluator;
 import com.netflix.fenzo.TaskRequest;
 import com.netflix.fenzo.VMTaskFitnessCalculator;
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/mesos/LaunchingTasks.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/LaunchingTasks.java
similarity index 93%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/mesos/LaunchingTasks.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/LaunchingTasks.java
index db8b20e..80abea3 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/mesos/LaunchingTasks.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/LaunchingTasks.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.mesos;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.mesos;
 
-import io.elasticjob.cloud.context.ExecutionType;
-import io.elasticjob.cloud.scheduler.context.JobContext;
-import io.elasticjob.cloud.context.TaskContext;
+import org.apache.shardingsphere.elasticjob.cloud.context.ExecutionType;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.context.JobContext;
+import org.apache.shardingsphere.elasticjob.cloud.context.TaskContext;
 import com.netflix.fenzo.TaskAssignmentResult;
 import com.netflix.fenzo.TaskRequest;
 import com.netflix.fenzo.VMAssignmentResult;
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/mesos/LeasesQueue.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/LeasesQueue.java
similarity index 96%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/mesos/LeasesQueue.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/LeasesQueue.java
index d239de7..eb2656a 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/mesos/LeasesQueue.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/LeasesQueue.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.mesos;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.mesos;
 
 import com.netflix.fenzo.VirtualMachineLease;
 import com.netflix.fenzo.plugins.VMLeaseObject;
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/mesos/MesosStateService.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/MesosStateService.java
similarity index 96%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/mesos/MesosStateService.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/MesosStateService.java
index ec0f8ef..0313658 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/mesos/MesosStateService.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/MesosStateService.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.mesos;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.mesos;
 
-import io.elasticjob.cloud.scheduler.ha.FrameworkIDService;
-import io.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.ha.FrameworkIDService;
+import org.apache.shardingsphere.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
 import com.google.common.base.Function;
 import com.google.common.base.Optional;
 import com.google.common.base.Preconditions;
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/mesos/ReconcileService.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/ReconcileService.java
similarity index 92%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/mesos/ReconcileService.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/ReconcileService.java
index 0a3dc84..d668a48 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/mesos/ReconcileService.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/ReconcileService.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.mesos;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.mesos;
 
-import io.elasticjob.cloud.scheduler.env.BootstrapEnvironment;
-import io.elasticjob.cloud.scheduler.env.FrameworkConfiguration;
-import io.elasticjob.cloud.context.TaskContext;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.env.BootstrapEnvironment;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.env.FrameworkConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.context.TaskContext;
 import com.google.common.base.Function;
 import com.google.common.collect.Collections2;
 import com.google.common.util.concurrent.AbstractScheduledService;
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/mesos/SchedulerEngine.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/SchedulerEngine.java
similarity index 93%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/mesos/SchedulerEngine.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/SchedulerEngine.java
index 974fb12..d13f5dd 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/mesos/SchedulerEngine.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/SchedulerEngine.java
@@ -15,13 +15,13 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.mesos;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.mesos;
 
-import io.elasticjob.cloud.scheduler.statistics.StatisticManager;
-import io.elasticjob.cloud.scheduler.ha.FrameworkIDService;
-import io.elasticjob.cloud.context.TaskContext;
-import io.elasticjob.cloud.event.JobEventBus;
-import io.elasticjob.cloud.event.type.JobStatusTraceEvent;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.statistics.StatisticManager;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.ha.FrameworkIDService;
+import org.apache.shardingsphere.elasticjob.cloud.context.TaskContext;
+import org.apache.shardingsphere.elasticjob.cloud.event.JobEventBus;
+import org.apache.shardingsphere.elasticjob.cloud.event.type.JobStatusTraceEvent;
 import com.netflix.fenzo.TaskScheduler;
 import lombok.RequiredArgsConstructor;
 import lombok.extern.slf4j.Slf4j;
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/mesos/SchedulerService.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/SchedulerService.java
similarity index 86%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/mesos/SchedulerService.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/SchedulerService.java
index 0944d99..2058e51 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/mesos/SchedulerService.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/SchedulerService.java
@@ -15,18 +15,18 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.mesos;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.mesos;
 
-import io.elasticjob.cloud.scheduler.restful.RestfulService;
-import io.elasticjob.cloud.scheduler.statistics.StatisticManager;
-import io.elasticjob.cloud.event.rdb.JobEventRdbConfiguration;
-import io.elasticjob.cloud.scheduler.config.job.CloudJobConfigurationListener;
-import io.elasticjob.cloud.scheduler.env.BootstrapEnvironment;
-import io.elasticjob.cloud.scheduler.env.MesosConfiguration;
-import io.elasticjob.cloud.scheduler.ha.FrameworkIDService;
-import io.elasticjob.cloud.scheduler.producer.ProducerManager;
-import io.elasticjob.cloud.event.JobEventBus;
-import io.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.restful.RestfulService;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.statistics.StatisticManager;
+import org.apache.shardingsphere.elasticjob.cloud.event.rdb.JobEventRdbConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobConfigurationListener;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.env.BootstrapEnvironment;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.env.MesosConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.ha.FrameworkIDService;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.producer.ProducerManager;
+import org.apache.shardingsphere.elasticjob.cloud.event.JobEventBus;
+import org.apache.shardingsphere.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
 import com.google.common.base.Optional;
 import com.google.common.util.concurrent.Service;
 import com.netflix.fenzo.TaskScheduler;
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/mesos/SupportedExtractionType.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/SupportedExtractionType.java
similarity index 96%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/mesos/SupportedExtractionType.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/SupportedExtractionType.java
index f175f44..614372e 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/mesos/SupportedExtractionType.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/SupportedExtractionType.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.mesos;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.mesos;
 
 import lombok.NoArgsConstructor;
 
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/mesos/TaskInfoData.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/TaskInfoData.java
similarity index 83%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/mesos/TaskInfoData.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/TaskInfoData.java
index d3d46ac..43ec440 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/mesos/TaskInfoData.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/TaskInfoData.java
@@ -15,14 +15,14 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.mesos;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.mesos;
 
-import io.elasticjob.cloud.scheduler.config.job.CloudJobConfiguration;
-import io.elasticjob.cloud.scheduler.config.job.CloudJobExecutionType;
-import io.elasticjob.cloud.config.script.ScriptJobConfiguration;
-import io.elasticjob.cloud.executor.ShardingContexts;
-import io.elasticjob.cloud.config.dataflow.DataflowJobConfiguration;
-import io.elasticjob.cloud.executor.handler.JobProperties;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobExecutionType;
+import org.apache.shardingsphere.elasticjob.cloud.config.script.ScriptJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.executor.ShardingContexts;
+import org.apache.shardingsphere.elasticjob.cloud.config.dataflow.DataflowJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.executor.handler.JobProperties;
 import lombok.RequiredArgsConstructor;
 import org.apache.commons.lang3.SerializationUtils;
 
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/mesos/TaskLaunchScheduledService.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/TaskLaunchScheduledService.java
similarity index 92%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/mesos/TaskLaunchScheduledService.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/TaskLaunchScheduledService.java
index 2695947..075588d 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/mesos/TaskLaunchScheduledService.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/TaskLaunchScheduledService.java
@@ -15,21 +15,21 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.mesos;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.mesos;
 
-import io.elasticjob.cloud.api.JobType;
-import io.elasticjob.cloud.scheduler.config.app.CloudAppConfiguration;
-import io.elasticjob.cloud.scheduler.config.job.CloudJobConfiguration;
-import io.elasticjob.cloud.scheduler.config.job.CloudJobExecutionType;
-import io.elasticjob.cloud.scheduler.env.BootstrapEnvironment;
-import io.elasticjob.cloud.config.script.ScriptJobConfiguration;
-import io.elasticjob.cloud.context.ExecutionType;
-import io.elasticjob.cloud.context.TaskContext;
-import io.elasticjob.cloud.event.JobEventBus;
-import io.elasticjob.cloud.event.type.JobStatusTraceEvent;
-import io.elasticjob.cloud.executor.ShardingContexts;
-import io.elasticjob.cloud.util.json.GsonFactory;
-import io.elasticjob.cloud.util.config.ShardingItemParameters;
+import org.apache.shardingsphere.elasticjob.cloud.api.JobType;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.app.CloudAppConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobExecutionType;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.env.BootstrapEnvironment;
+import org.apache.shardingsphere.elasticjob.cloud.config.script.ScriptJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.context.ExecutionType;
+import org.apache.shardingsphere.elasticjob.cloud.context.TaskContext;
+import org.apache.shardingsphere.elasticjob.cloud.event.JobEventBus;
+import org.apache.shardingsphere.elasticjob.cloud.event.type.JobStatusTraceEvent;
+import org.apache.shardingsphere.elasticjob.cloud.executor.ShardingContexts;
+import org.apache.shardingsphere.elasticjob.cloud.util.json.GsonFactory;
+import org.apache.shardingsphere.elasticjob.cloud.util.config.ShardingItemParameters;
 import com.google.common.base.Joiner;
 import com.google.common.base.Optional;
 import com.google.common.base.Predicate;
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/producer/ProducerManager.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/producer/ProducerManager.java
similarity index 83%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/producer/ProducerManager.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/producer/ProducerManager.java
index 003ba86..9acdb63 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/producer/ProducerManager.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/producer/ProducerManager.java
@@ -15,21 +15,21 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.producer;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.producer;
 
-import io.elasticjob.cloud.scheduler.config.app.CloudAppConfigurationService;
-import io.elasticjob.cloud.scheduler.config.job.CloudJobConfiguration;
-import io.elasticjob.cloud.scheduler.config.job.CloudJobConfigurationService;
-import io.elasticjob.cloud.scheduler.config.job.CloudJobExecutionType;
-import io.elasticjob.cloud.scheduler.state.disable.app.DisableAppService;
-import io.elasticjob.cloud.scheduler.state.disable.job.DisableJobService;
-import io.elasticjob.cloud.scheduler.state.running.RunningService;
-import io.elasticjob.cloud.exception.AppConfigurationException;
-import io.elasticjob.cloud.exception.JobConfigurationException;
-import io.elasticjob.cloud.scheduler.config.app.CloudAppConfiguration;
-import io.elasticjob.cloud.scheduler.state.ready.ReadyService;
-import io.elasticjob.cloud.context.TaskContext;
-import io.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.app.CloudAppConfigurationService;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobConfigurationService;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobExecutionType;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.state.disable.app.DisableAppService;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.state.disable.job.DisableJobService;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.state.running.RunningService;
+import org.apache.shardingsphere.elasticjob.cloud.exception.AppConfigurationException;
+import org.apache.shardingsphere.elasticjob.cloud.exception.JobConfigurationException;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.app.CloudAppConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.state.ready.ReadyService;
+import org.apache.shardingsphere.elasticjob.cloud.context.TaskContext;
+import org.apache.shardingsphere.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
 import com.google.common.base.Optional;
 import com.google.common.collect.Lists;
 import lombok.extern.slf4j.Slf4j;
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/producer/TransientProducerRepository.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/producer/TransientProducerRepository.java
similarity index 97%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/producer/TransientProducerRepository.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/producer/TransientProducerRepository.java
index 936e82c..842433d 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/producer/TransientProducerRepository.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/producer/TransientProducerRepository.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.producer;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.producer;
 
 import org.quartz.JobKey;
 
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/producer/TransientProducerScheduler.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/producer/TransientProducerScheduler.java
similarity index 94%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/producer/TransientProducerScheduler.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/producer/TransientProducerScheduler.java
index 18213ab..ba01603 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/producer/TransientProducerScheduler.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/producer/TransientProducerScheduler.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.producer;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.producer;
 
-import io.elasticjob.cloud.scheduler.config.job.CloudJobConfiguration;
-import io.elasticjob.cloud.scheduler.state.ready.ReadyService;
-import io.elasticjob.cloud.exception.JobSystemException;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.state.ready.ReadyService;
+import org.apache.shardingsphere.elasticjob.cloud.exception.JobSystemException;
 import lombok.Setter;
 import org.quartz.CronScheduleBuilder;
 import org.quartz.Job;
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/restful/CloudAppRestfulApi.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/restful/CloudAppRestfulApi.java
similarity index 86%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/restful/CloudAppRestfulApi.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/restful/CloudAppRestfulApi.java
index 36df778..b14d65f 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/restful/CloudAppRestfulApi.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/restful/CloudAppRestfulApi.java
@@ -15,20 +15,20 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.restful;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.restful;
 
-import io.elasticjob.cloud.scheduler.config.app.CloudAppConfigurationGsonFactory;
-import io.elasticjob.cloud.scheduler.mesos.MesosStateService;
-import io.elasticjob.cloud.scheduler.state.disable.app.DisableAppService;
-import io.elasticjob.cloud.scheduler.config.app.CloudAppConfiguration;
-import io.elasticjob.cloud.scheduler.config.app.CloudAppConfigurationService;
-import io.elasticjob.cloud.scheduler.config.job.CloudJobConfiguration;
-import io.elasticjob.cloud.scheduler.config.job.CloudJobConfigurationService;
-import io.elasticjob.cloud.scheduler.producer.ProducerManager;
-import io.elasticjob.cloud.exception.AppConfigurationException;
-import io.elasticjob.cloud.exception.JobSystemException;
-import io.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
-import io.elasticjob.cloud.util.json.GsonFactory;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.app.CloudAppConfigurationGsonFactory;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.mesos.MesosStateService;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.state.disable.app.DisableAppService;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.app.CloudAppConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.app.CloudAppConfigurationService;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobConfigurationService;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.producer.ProducerManager;
+import org.apache.shardingsphere.elasticjob.cloud.exception.AppConfigurationException;
+import org.apache.shardingsphere.elasticjob.cloud.exception.JobSystemException;
+import org.apache.shardingsphere.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
+import org.apache.shardingsphere.elasticjob.cloud.util.json.GsonFactory;
 import com.google.common.base.Optional;
 import org.apache.mesos.Protos.ExecutorID;
 import org.apache.mesos.Protos.SlaveID;
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/restful/CloudJobRestfulApi.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/restful/CloudJobRestfulApi.java
similarity index 87%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/restful/CloudJobRestfulApi.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/restful/CloudJobRestfulApi.java
index 5e9d694..b03cace 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/restful/CloudJobRestfulApi.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/restful/CloudJobRestfulApi.java
@@ -15,32 +15,32 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.restful;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.restful;
 
-import io.elasticjob.cloud.scheduler.config.job.CloudJobConfiguration;
-import io.elasticjob.cloud.scheduler.statistics.StatisticManager;
-import io.elasticjob.cloud.event.rdb.JobEventRdbConfiguration;
-import io.elasticjob.cloud.event.rdb.JobEventRdbSearch;
-import io.elasticjob.cloud.event.type.JobExecutionEvent;
-import io.elasticjob.cloud.scheduler.config.job.CloudJobConfigurationGsonFactory;
-import io.elasticjob.cloud.scheduler.config.job.CloudJobConfigurationService;
-import io.elasticjob.cloud.scheduler.config.job.CloudJobExecutionType;
-import io.elasticjob.cloud.scheduler.env.BootstrapEnvironment;
-import io.elasticjob.cloud.scheduler.mesos.FacadeService;
-import io.elasticjob.cloud.scheduler.producer.ProducerManager;
-import io.elasticjob.cloud.scheduler.state.failover.FailoverTaskInfo;
-import io.elasticjob.cloud.statistics.StatisticInterval;
-import io.elasticjob.cloud.statistics.type.job.JobRegisterStatistics;
-import io.elasticjob.cloud.statistics.type.task.TaskResultStatistics;
-import io.elasticjob.cloud.context.TaskContext;
-import io.elasticjob.cloud.event.type.JobStatusTraceEvent;
-import io.elasticjob.cloud.exception.JobSystemException;
-import io.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
-import io.elasticjob.cloud.statistics.type.job.JobExecutionTypeStatistics;
-import io.elasticjob.cloud.statistics.type.job.JobRunningStatistics;
-import io.elasticjob.cloud.statistics.type.job.JobTypeStatistics;
-import io.elasticjob.cloud.statistics.type.task.TaskRunningStatistics;
-import io.elasticjob.cloud.util.json.GsonFactory;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.statistics.StatisticManager;
+import org.apache.shardingsphere.elasticjob.cloud.event.rdb.JobEventRdbConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.event.rdb.JobEventRdbSearch;
+import org.apache.shardingsphere.elasticjob.cloud.event.type.JobExecutionEvent;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobConfigurationGsonFactory;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobConfigurationService;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobExecutionType;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.env.BootstrapEnvironment;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.mesos.FacadeService;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.producer.ProducerManager;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.state.failover.FailoverTaskInfo;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.StatisticInterval;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.type.job.JobRegisterStatistics;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.type.task.TaskResultStatistics;
+import org.apache.shardingsphere.elasticjob.cloud.context.TaskContext;
+import org.apache.shardingsphere.elasticjob.cloud.event.type.JobStatusTraceEvent;
+import org.apache.shardingsphere.elasticjob.cloud.exception.JobSystemException;
+import org.apache.shardingsphere.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.type.job.JobExecutionTypeStatistics;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.type.job.JobRunningStatistics;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.type.job.JobTypeStatistics;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.type.task.TaskRunningStatistics;
+import org.apache.shardingsphere.elasticjob.cloud.util.json.GsonFactory;
 import com.google.common.base.Optional;
 import com.google.common.base.Preconditions;
 import com.google.common.base.Strings;
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/restful/CloudOperationRestfulApi.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/restful/CloudOperationRestfulApi.java
similarity index 90%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/restful/CloudOperationRestfulApi.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/restful/CloudOperationRestfulApi.java
index b0bc957..00b5fc5 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/restful/CloudOperationRestfulApi.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/restful/CloudOperationRestfulApi.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.restful;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.restful;
 
-import io.elasticjob.cloud.scheduler.mesos.MesosStateService;
-import io.elasticjob.cloud.scheduler.mesos.ReconcileService;
-import io.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.mesos.MesosStateService;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.mesos.ReconcileService;
+import org.apache.shardingsphere.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
 import com.google.common.base.Preconditions;
 import com.google.common.base.Strings;
 import com.google.gson.JsonArray;
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/restful/RestfulService.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/restful/RestfulService.java
similarity index 78%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/restful/RestfulService.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/restful/RestfulService.java
index 53e23fa..1cd1d96 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/restful/RestfulService.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/restful/RestfulService.java
@@ -15,14 +15,14 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.restful;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.restful;
 
-import io.elasticjob.cloud.scheduler.env.RestfulServerConfiguration;
-import io.elasticjob.cloud.scheduler.mesos.ReconcileService;
-import io.elasticjob.cloud.scheduler.producer.ProducerManager;
-import io.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
-import io.elasticjob.cloud.restful.RestfulServer;
-import io.elasticjob.cloud.security.WwwAuthFilter;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.env.RestfulServerConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.mesos.ReconcileService;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.producer.ProducerManager;
+import org.apache.shardingsphere.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
+import org.apache.shardingsphere.elasticjob.cloud.restful.RestfulServer;
+import org.apache.shardingsphere.elasticjob.cloud.security.WwwAuthFilter;
 import com.google.common.base.Optional;
 
 /**
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/state/StateNode.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/StateNode.java
similarity index 94%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/state/StateNode.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/StateNode.java
index 2fb9d11..faa177f 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/state/StateNode.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/StateNode.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.state;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.state;
 
 import lombok.AccessLevel;
 import lombok.NoArgsConstructor;
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/state/disable/app/DisableAppNode.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/disable/app/DisableAppNode.java
similarity index 88%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/state/disable/app/DisableAppNode.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/disable/app/DisableAppNode.java
index 9af6943..fa4cd65 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/state/disable/app/DisableAppNode.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/disable/app/DisableAppNode.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.state.disable.app;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.state.disable.app;
 
-import io.elasticjob.cloud.scheduler.state.StateNode;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.state.StateNode;
 import lombok.AccessLevel;
 import lombok.NoArgsConstructor;
 
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/state/disable/app/DisableAppService.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/disable/app/DisableAppService.java
similarity index 90%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/state/disable/app/DisableAppService.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/disable/app/DisableAppService.java
index d8846ed..53181da 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/state/disable/app/DisableAppService.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/disable/app/DisableAppService.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.state.disable.app;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.state.disable.app;
 
-import io.elasticjob.cloud.scheduler.env.BootstrapEnvironment;
-import io.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.env.BootstrapEnvironment;
+import org.apache.shardingsphere.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
 import lombok.extern.slf4j.Slf4j;
 
 /**
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/state/disable/job/DisableJobNode.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/disable/job/DisableJobNode.java
similarity index 88%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/state/disable/job/DisableJobNode.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/disable/job/DisableJobNode.java
index 4aa7d04..a982f03 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/state/disable/job/DisableJobNode.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/disable/job/DisableJobNode.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.state.disable.job;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.state.disable.job;
 
-import io.elasticjob.cloud.scheduler.state.StateNode;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.state.StateNode;
 import lombok.AccessLevel;
 import lombok.NoArgsConstructor;
 
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/state/disable/job/DisableJobService.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/disable/job/DisableJobService.java
similarity index 90%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/state/disable/job/DisableJobService.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/disable/job/DisableJobService.java
index 978d954..4267460 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/state/disable/job/DisableJobService.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/disable/job/DisableJobService.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.state.disable.job;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.state.disable.job;
 
-import io.elasticjob.cloud.scheduler.env.BootstrapEnvironment;
-import io.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.env.BootstrapEnvironment;
+import org.apache.shardingsphere.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
 import lombok.extern.slf4j.Slf4j;
 
 /**
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/state/failover/FailoverNode.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/failover/FailoverNode.java
similarity index 87%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/state/failover/FailoverNode.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/failover/FailoverNode.java
index e5defe3..5d87e67 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/state/failover/FailoverNode.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/failover/FailoverNode.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.state.failover;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.state.failover;
 
-import io.elasticjob.cloud.context.TaskContext;
-import io.elasticjob.cloud.scheduler.state.StateNode;
+import org.apache.shardingsphere.elasticjob.cloud.context.TaskContext;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.state.StateNode;
 import lombok.AccessLevel;
 import lombok.NoArgsConstructor;
 
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/state/failover/FailoverService.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/failover/FailoverService.java
similarity index 90%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/state/failover/FailoverService.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/failover/FailoverService.java
index 25480cb..8ff667c 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/state/failover/FailoverService.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/failover/FailoverService.java
@@ -15,16 +15,16 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.state.failover;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.state.failover;
 
-import io.elasticjob.cloud.scheduler.config.job.CloudJobConfiguration;
-import io.elasticjob.cloud.scheduler.config.job.CloudJobConfigurationService;
-import io.elasticjob.cloud.scheduler.env.BootstrapEnvironment;
-import io.elasticjob.cloud.scheduler.state.running.RunningService;
-import io.elasticjob.cloud.context.ExecutionType;
-import io.elasticjob.cloud.scheduler.context.JobContext;
-import io.elasticjob.cloud.context.TaskContext;
-import io.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobConfigurationService;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.env.BootstrapEnvironment;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.state.running.RunningService;
+import org.apache.shardingsphere.elasticjob.cloud.context.ExecutionType;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.context.JobContext;
+import org.apache.shardingsphere.elasticjob.cloud.context.TaskContext;
+import org.apache.shardingsphere.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
 import com.google.common.base.Charsets;
 import com.google.common.base.Optional;
 import com.google.common.base.Strings;
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/state/failover/FailoverTaskInfo.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/failover/FailoverTaskInfo.java
similarity index 88%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/state/failover/FailoverTaskInfo.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/failover/FailoverTaskInfo.java
index 090944d..2f4f0b0 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/state/failover/FailoverTaskInfo.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/failover/FailoverTaskInfo.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.state.failover;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.state.failover;
 
-import io.elasticjob.cloud.context.TaskContext;
+import org.apache.shardingsphere.elasticjob.cloud.context.TaskContext;
 import lombok.Getter;
 import lombok.RequiredArgsConstructor;
 
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/state/ready/ReadyNode.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/ready/ReadyNode.java
similarity index 89%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/state/ready/ReadyNode.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/ready/ReadyNode.java
index 6c99066..d6c6221 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/state/ready/ReadyNode.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/ready/ReadyNode.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.state.ready;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.state.ready;
 
-import io.elasticjob.cloud.scheduler.state.StateNode;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.state.StateNode;
 import lombok.AccessLevel;
 import lombok.NoArgsConstructor;
 
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/state/ready/ReadyService.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/ready/ReadyService.java
similarity index 89%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/state/ready/ReadyService.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/ready/ReadyService.java
index 2756635..ba10f7d 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/state/ready/ReadyService.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/ready/ReadyService.java
@@ -15,16 +15,16 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.state.ready;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.state.ready;
 
-import io.elasticjob.cloud.scheduler.config.job.CloudJobConfiguration;
-import io.elasticjob.cloud.scheduler.config.job.CloudJobConfigurationService;
-import io.elasticjob.cloud.scheduler.config.job.CloudJobExecutionType;
-import io.elasticjob.cloud.scheduler.context.JobContext;
-import io.elasticjob.cloud.scheduler.env.BootstrapEnvironment;
-import io.elasticjob.cloud.scheduler.state.running.RunningService;
-import io.elasticjob.cloud.context.ExecutionType;
-import io.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobConfigurationService;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobExecutionType;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.context.JobContext;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.env.BootstrapEnvironment;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.state.running.RunningService;
+import org.apache.shardingsphere.elasticjob.cloud.context.ExecutionType;
+import org.apache.shardingsphere.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
 import com.google.common.base.Function;
 import com.google.common.base.Optional;
 import com.google.common.base.Strings;
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/state/running/RunningNode.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/running/RunningNode.java
similarity index 87%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/state/running/RunningNode.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/running/RunningNode.java
index f75866d..7f85aa7 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/state/running/RunningNode.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/running/RunningNode.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.state.running;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.state.running;
 
-import io.elasticjob.cloud.scheduler.state.StateNode;
-import io.elasticjob.cloud.context.TaskContext;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.state.StateNode;
+import org.apache.shardingsphere.elasticjob.cloud.context.TaskContext;
 import lombok.AccessLevel;
 import lombok.NoArgsConstructor;
 
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/state/running/RunningService.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/running/RunningService.java
similarity index 94%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/state/running/RunningService.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/running/RunningService.java
index c554a53..01b9515 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/state/running/RunningService.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/running/RunningService.java
@@ -15,13 +15,13 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.state.running;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.state.running;
 
-import io.elasticjob.cloud.scheduler.config.job.CloudJobConfiguration;
-import io.elasticjob.cloud.scheduler.config.job.CloudJobConfigurationService;
-import io.elasticjob.cloud.scheduler.config.job.CloudJobExecutionType;
-import io.elasticjob.cloud.context.TaskContext;
-import io.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobConfigurationService;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobExecutionType;
+import org.apache.shardingsphere.elasticjob.cloud.context.TaskContext;
+import org.apache.shardingsphere.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
 import com.google.common.base.Function;
 import com.google.common.base.Optional;
 import com.google.common.base.Predicate;
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/statistics/StatisticManager.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/StatisticManager.java
similarity index 86%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/statistics/StatisticManager.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/StatisticManager.java
index 99c0320..71dac38 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/statistics/StatisticManager.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/StatisticManager.java
@@ -15,26 +15,26 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.statistics;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.statistics;
 
-import io.elasticjob.cloud.api.JobType;
-import io.elasticjob.cloud.scheduler.statistics.job.JobRunningStatisticJob;
-import io.elasticjob.cloud.event.rdb.JobEventRdbConfiguration;
-import io.elasticjob.cloud.scheduler.config.job.CloudJobConfiguration;
-import io.elasticjob.cloud.scheduler.config.job.CloudJobConfigurationService;
-import io.elasticjob.cloud.scheduler.config.job.CloudJobExecutionType;
-import io.elasticjob.cloud.scheduler.statistics.job.RegisteredJobStatisticJob;
-import io.elasticjob.cloud.scheduler.statistics.job.TaskResultStatisticJob;
-import io.elasticjob.cloud.scheduler.statistics.util.StatisticTimeUtils;
-import io.elasticjob.cloud.statistics.type.job.JobRegisterStatistics;
-import io.elasticjob.cloud.statistics.type.task.TaskResultStatistics;
-import io.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
-import io.elasticjob.cloud.statistics.StatisticInterval;
-import io.elasticjob.cloud.statistics.rdb.StatisticRdbRepository;
-import io.elasticjob.cloud.statistics.type.job.JobExecutionTypeStatistics;
-import io.elasticjob.cloud.statistics.type.job.JobRunningStatistics;
-import io.elasticjob.cloud.statistics.type.job.JobTypeStatistics;
-import io.elasticjob.cloud.statistics.type.task.TaskRunningStatistics;
+import org.apache.shardingsphere.elasticjob.cloud.api.JobType;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.statistics.job.JobRunningStatisticJob;
+import org.apache.shardingsphere.elasticjob.cloud.event.rdb.JobEventRdbConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobConfigurationService;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobExecutionType;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.statistics.job.RegisteredJobStatisticJob;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.statistics.job.TaskResultStatisticJob;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.statistics.util.StatisticTimeUtils;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.type.job.JobRegisterStatistics;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.type.task.TaskResultStatistics;
+import org.apache.shardingsphere.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.StatisticInterval;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.rdb.StatisticRdbRepository;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.type.job.JobExecutionTypeStatistics;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.type.job.JobRunningStatistics;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.type.job.JobTypeStatistics;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.type.task.TaskRunningStatistics;
 import com.google.common.base.Optional;
 import lombok.AccessLevel;
 import lombok.RequiredArgsConstructor;
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/statistics/StatisticsScheduler.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/StatisticsScheduler.java
similarity index 92%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/statistics/StatisticsScheduler.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/StatisticsScheduler.java
index 7767dc9..0800302 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/statistics/StatisticsScheduler.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/StatisticsScheduler.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.statistics;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.statistics;
 
-import io.elasticjob.cloud.scheduler.statistics.job.StatisticJob;
-import io.elasticjob.cloud.exception.JobStatisticException;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.statistics.job.StatisticJob;
+import org.apache.shardingsphere.elasticjob.cloud.exception.JobStatisticException;
 import org.quartz.JobDetail;
 import org.quartz.Scheduler;
 import org.quartz.SchedulerException;
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/statistics/TaskResultMetaData.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/TaskResultMetaData.java
similarity index 96%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/statistics/TaskResultMetaData.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/TaskResultMetaData.java
index d8840d5..a41a4f4 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/statistics/TaskResultMetaData.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/TaskResultMetaData.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.statistics;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.statistics;
 
 import java.util.concurrent.atomic.AtomicInteger;
 
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/statistics/job/AbstractStatisticJob.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/job/AbstractStatisticJob.java
similarity index 87%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/statistics/job/AbstractStatisticJob.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/job/AbstractStatisticJob.java
index 52b6c38..d11bb56 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/statistics/job/AbstractStatisticJob.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/job/AbstractStatisticJob.java
@@ -15,15 +15,15 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.statistics.job;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.statistics.job;
 
 import java.util.ArrayList;
 import java.util.Collections;
 import java.util.Date;
 import java.util.List;
 
-import io.elasticjob.cloud.scheduler.statistics.util.StatisticTimeUtils;
-import io.elasticjob.cloud.statistics.StatisticInterval;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.statistics.util.StatisticTimeUtils;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.StatisticInterval;
 
 /**
  * 统计作业抽象类.
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/statistics/job/JobRunningStatisticJob.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/job/JobRunningStatisticJob.java
similarity index 88%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/statistics/job/JobRunningStatisticJob.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/job/JobRunningStatisticJob.java
index ac3dc0b..e07027c 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/statistics/job/JobRunningStatisticJob.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/job/JobRunningStatisticJob.java
@@ -15,16 +15,16 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.statistics.job;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.statistics.job;
 
-import io.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
-import io.elasticjob.cloud.scheduler.state.running.RunningService;
-import io.elasticjob.cloud.scheduler.statistics.util.StatisticTimeUtils;
-import io.elasticjob.cloud.context.TaskContext;
-import io.elasticjob.cloud.statistics.StatisticInterval;
-import io.elasticjob.cloud.statistics.rdb.StatisticRdbRepository;
-import io.elasticjob.cloud.statistics.type.job.JobRunningStatistics;
-import io.elasticjob.cloud.statistics.type.task.TaskRunningStatistics;
+import org.apache.shardingsphere.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.state.running.RunningService;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.statistics.util.StatisticTimeUtils;
+import org.apache.shardingsphere.elasticjob.cloud.context.TaskContext;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.StatisticInterval;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.rdb.StatisticRdbRepository;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.type.job.JobRunningStatistics;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.type.task.TaskRunningStatistics;
 import com.google.common.base.Optional;
 import lombok.NoArgsConstructor;
 import lombok.Setter;
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/statistics/job/RegisteredJobStatisticJob.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/job/RegisteredJobStatisticJob.java
similarity index 86%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/statistics/job/RegisteredJobStatisticJob.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/job/RegisteredJobStatisticJob.java
index 041bdf6..15748f6 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/statistics/job/RegisteredJobStatisticJob.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/job/RegisteredJobStatisticJob.java
@@ -15,13 +15,13 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.statistics.job;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.statistics.job;
 
-import io.elasticjob.cloud.scheduler.config.job.CloudJobConfigurationService;
-import io.elasticjob.cloud.scheduler.statistics.util.StatisticTimeUtils;
-import io.elasticjob.cloud.statistics.StatisticInterval;
-import io.elasticjob.cloud.statistics.rdb.StatisticRdbRepository;
-import io.elasticjob.cloud.statistics.type.job.JobRegisterStatistics;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobConfigurationService;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.statistics.util.StatisticTimeUtils;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.StatisticInterval;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.rdb.StatisticRdbRepository;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.type.job.JobRegisterStatistics;
 import com.google.common.base.Optional;
 import lombok.AllArgsConstructor;
 import lombok.NoArgsConstructor;
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/statistics/job/StatisticJob.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/job/StatisticJob.java
similarity index 94%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/statistics/job/StatisticJob.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/job/StatisticJob.java
index 6470abf..624e979 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/statistics/job/StatisticJob.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/job/StatisticJob.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.statistics.job;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.statistics.job;
 
 import java.util.Map;
 
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/statistics/job/TaskResultStatisticJob.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/job/TaskResultStatisticJob.java
similarity index 88%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/statistics/job/TaskResultStatisticJob.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/job/TaskResultStatisticJob.java
index e7f78da..ebe39ba 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/statistics/job/TaskResultStatisticJob.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/job/TaskResultStatisticJob.java
@@ -15,13 +15,13 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.statistics.job;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.statistics.job;
 
-import io.elasticjob.cloud.scheduler.statistics.TaskResultMetaData;
-import io.elasticjob.cloud.scheduler.statistics.util.StatisticTimeUtils;
-import io.elasticjob.cloud.statistics.StatisticInterval;
-import io.elasticjob.cloud.statistics.rdb.StatisticRdbRepository;
-import io.elasticjob.cloud.statistics.type.task.TaskResultStatistics;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.statistics.TaskResultMetaData;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.statistics.util.StatisticTimeUtils;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.StatisticInterval;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.rdb.StatisticRdbRepository;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.type.task.TaskResultStatistics;
 import com.google.common.base.Optional;
 import lombok.AllArgsConstructor;
 import lombok.NoArgsConstructor;
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/statistics/util/StatisticTimeUtils.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/util/StatisticTimeUtils.java
similarity index 93%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/statistics/util/StatisticTimeUtils.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/util/StatisticTimeUtils.java
index c4ea064..1b722b9 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/scheduler/statistics/util/StatisticTimeUtils.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/util/StatisticTimeUtils.java
@@ -15,12 +15,12 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.statistics.util;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.statistics.util;
 
 import java.util.Calendar;
 import java.util.Date;
 
-import io.elasticjob.cloud.statistics.StatisticInterval;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.StatisticInterval;
 
 import lombok.AccessLevel;
 import lombok.NoArgsConstructor;
diff --git a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/security/WwwAuthFilter.java b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/security/WwwAuthFilter.java
similarity index 98%
rename from elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/security/WwwAuthFilter.java
rename to elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/security/WwwAuthFilter.java
index 4bee83b..7882052 100644
--- a/elastic-job-cloud-scheduler/src/main/java/io/elasticjob/cloud/security/WwwAuthFilter.java
+++ b/elastic-job-cloud-scheduler/src/main/java/org/apache/shardingsphere/elasticjob/cloud/security/WwwAuthFilter.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.security;
+package org.apache.shardingsphere.elasticjob.cloud.security;
 
 import com.google.common.base.Joiner;
 import lombok.extern.slf4j.Slf4j;
diff --git a/elastic-job-cloud-scheduler/src/main/resources/bin/dcos.sh b/elastic-job-cloud-scheduler/src/main/resources/bin/dcos.sh
index 57276b5..9ae38fe 100755
--- a/elastic-job-cloud-scheduler/src/main/resources/bin/dcos.sh
+++ b/elastic-job-cloud-scheduler/src/main/resources/bin/dcos.sh
@@ -3,7 +3,7 @@ cd `dirname $0`
 cd ..
 DEPLOY_DIR=`pwd`
 LIB_DIR=${DEPLOY_DIR}/lib/*
-CONTAINER_MAIN=io.elasticjob.cloud.scheduler.Bootstrap
+CONTAINER_MAIN=Bootstrap
 JAVA_OPTS=" -Djava.awt.headless=true -Djava.net.preferIPv4Stack=true -Djava.library.path=/usr/local/lib:/usr/lib:/usr/lib64"
 
 java ${JAVA_OPTS} -classpath ${LIB_DIR}:. ${CONTAINER_MAIN}
diff --git a/elastic-job-cloud-scheduler/src/main/resources/bin/start.sh b/elastic-job-cloud-scheduler/src/main/resources/bin/start.sh
index 4e6ae43..77411b9 100755
--- a/elastic-job-cloud-scheduler/src/main/resources/bin/start.sh
+++ b/elastic-job-cloud-scheduler/src/main/resources/bin/start.sh
@@ -4,7 +4,7 @@ cd ..
 DEPLOY_DIR=`pwd`
 CONF_DIR=${DEPLOY_DIR}/conf
 LIB_DIR=${DEPLOY_DIR}/lib/*
-CONTAINER_MAIN=io.elasticjob.cloud.scheduler.Bootstrap
+CONTAINER_MAIN=Bootstrap
 JAVA_OPTS=" -Djava.awt.headless=true -Djava.net.preferIPv4Stack=true -Djava.library.path=/usr/local/lib:/usr/lib:/usr/lib64"
 
 source ${CONF_DIR}/elastic-job-cloud-scheduler.properties
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/AllTests.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/AllTests.java
similarity index 82%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/AllTests.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/AllTests.java
index 15d1de0..0a584a2 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/AllTests.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/AllTests.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud;
+package org.apache.shardingsphere.elasticjob.cloud;
 
-import io.elasticjob.cloud.restful.AllRestfulTests;
-import io.elasticjob.cloud.scheduler.AllCloudSchedulerTests;
+import org.apache.shardingsphere.elasticjob.cloud.restful.AllRestfulTests;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.AllCloudSchedulerTests;
 import lombok.AccessLevel;
 import lombok.NoArgsConstructor;
 import org.junit.runner.RunWith;
@@ -28,7 +28,7 @@ import org.junit.runners.Suite.SuiteClasses;
 @RunWith(Suite.class)
 @SuiteClasses({
         AllCloudSchedulerTests.class,
-        AllRestfulTests.class 
+        AllRestfulTests.class
     })
 @NoArgsConstructor(access = AccessLevel.PRIVATE)
 public final class AllTests {
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/restful/AllRestfulTests.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/restful/AllRestfulTests.java
similarity index 95%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/restful/AllRestfulTests.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/restful/AllRestfulTests.java
index 1aa8a46..f862ebf 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/restful/AllRestfulTests.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/restful/AllRestfulTests.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.restful;
+package org.apache.shardingsphere.elasticjob.cloud.restful;
 
 import lombok.AccessLevel;
 import lombok.NoArgsConstructor;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/restful/RestfulExceptionTest.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/restful/RestfulExceptionTest.java
similarity index 94%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/restful/RestfulExceptionTest.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/restful/RestfulExceptionTest.java
index 332fae4..a5b6a66 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/restful/RestfulExceptionTest.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/restful/RestfulExceptionTest.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.restful;
+package org.apache.shardingsphere.elasticjob.cloud.restful;
 
 import org.hamcrest.core.IsInstanceOf;
 import org.junit.Assert;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/restful/RestfulServerTest.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/restful/RestfulServerTest.java
similarity index 92%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/restful/RestfulServerTest.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/restful/RestfulServerTest.java
index 93a414a..8a83e5b 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/restful/RestfulServerTest.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/restful/RestfulServerTest.java
@@ -15,12 +15,12 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.restful;
+package org.apache.shardingsphere.elasticjob.cloud.restful;
 
 import com.google.common.base.Optional;
-import io.elasticjob.cloud.restful.fixture.TestFilter;
-import io.elasticjob.cloud.restful.fixture.TestRestfulApi;
-import io.elasticjob.cloud.restful.fixture.Caller;
+import org.apache.shardingsphere.elasticjob.cloud.restful.fixture.TestFilter;
+import org.apache.shardingsphere.elasticjob.cloud.restful.fixture.TestRestfulApi;
+import org.apache.shardingsphere.elasticjob.cloud.restful.fixture.Caller;
 import org.eclipse.jetty.client.ContentExchange;
 import org.eclipse.jetty.client.HttpClient;
 import org.eclipse.jetty.io.ByteArrayBuffer;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/restful/fixture/Caller.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/restful/fixture/Caller.java
similarity index 93%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/restful/fixture/Caller.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/restful/fixture/Caller.java
index b5afcb3..d3b34b6 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/restful/fixture/Caller.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/restful/fixture/Caller.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.restful.fixture;
+package org.apache.shardingsphere.elasticjob.cloud.restful.fixture;
 
 public interface Caller {
 
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/restful/fixture/TestFilter.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/restful/fixture/TestFilter.java
similarity index 96%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/restful/fixture/TestFilter.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/restful/fixture/TestFilter.java
index 4d6d7df..1f70648 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/restful/fixture/TestFilter.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/restful/fixture/TestFilter.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.restful.fixture;
+package org.apache.shardingsphere.elasticjob.cloud.restful.fixture;
 
 import javax.servlet.Filter;
 import javax.servlet.FilterChain;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/restful/fixture/TestRestfulApi.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/restful/fixture/TestRestfulApi.java
similarity index 96%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/restful/fixture/TestRestfulApi.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/restful/fixture/TestRestfulApi.java
index f50c863..01e5ff4 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/restful/fixture/TestRestfulApi.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/restful/fixture/TestRestfulApi.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.restful.fixture;
+package org.apache.shardingsphere.elasticjob.cloud.restful.fixture;
 
 import com.google.common.collect.Maps;
 import lombok.Setter;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/AllCloudSchedulerTests.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/AllCloudSchedulerTests.java
similarity index 60%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/AllCloudSchedulerTests.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/AllCloudSchedulerTests.java
index 88b8080..cd8416e 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/AllCloudSchedulerTests.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/AllCloudSchedulerTests.java
@@ -15,17 +15,17 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler;
 
-import io.elasticjob.cloud.scheduler.env.AllEnvTests;
-import io.elasticjob.cloud.scheduler.producer.AllProducerTests;
-import io.elasticjob.cloud.scheduler.restful.AllRestfulTests;
-import io.elasticjob.cloud.scheduler.config.AllConfigTests;
-import io.elasticjob.cloud.scheduler.context.AllContextTests;
-import io.elasticjob.cloud.scheduler.ha.AllHATests;
-import io.elasticjob.cloud.scheduler.mesos.AllMesosTests;
-import io.elasticjob.cloud.scheduler.state.AllStateTests;
-import io.elasticjob.cloud.scheduler.statistics.AllStatisticTests;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.env.AllEnvTests;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.producer.AllProducerTests;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.restful.AllRestfulTests;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.AllConfigTests;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.context.AllContextTests;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.ha.AllHATests;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.mesos.AllMesosTests;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.state.AllStateTests;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.statistics.AllStatisticTests;
 import org.junit.runner.RunWith;
 import org.junit.runners.Suite;
 
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/config/AllConfigTests.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/AllConfigTests.java
similarity index 79%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/config/AllConfigTests.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/AllConfigTests.java
index c2e68af..34cfeea 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/config/AllConfigTests.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/AllConfigTests.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.config;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.config;
 
-import io.elasticjob.cloud.scheduler.config.app.AllCloudAppConfigTests;
-import io.elasticjob.cloud.scheduler.config.job.AllCloudJobConfigTests;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.app.AllCloudAppConfigTests;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.AllCloudJobConfigTests;
 import org.junit.runner.RunWith;
 import org.junit.runners.Suite;
 
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/config/app/AllCloudAppConfigTests.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/app/AllCloudAppConfigTests.java
similarity index 93%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/config/app/AllCloudAppConfigTests.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/app/AllCloudAppConfigTests.java
index 05e0e0d..545f4b6 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/config/app/AllCloudAppConfigTests.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/app/AllCloudAppConfigTests.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.config.app;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.config.app;
 
 import org.junit.runner.RunWith;
 import org.junit.runners.Suite;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/config/app/CloudAppConfigurationNodeTest.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/app/CloudAppConfigurationNodeTest.java
similarity index 93%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/config/app/CloudAppConfigurationNodeTest.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/app/CloudAppConfigurationNodeTest.java
index 4855066..72005da 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/config/app/CloudAppConfigurationNodeTest.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/app/CloudAppConfigurationNodeTest.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.config.app;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.config.app;
 
 import org.hamcrest.core.Is;
 import org.junit.Assert;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/config/app/CloudAppConfigurationServiceTest.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/app/CloudAppConfigurationServiceTest.java
similarity index 91%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/config/app/CloudAppConfigurationServiceTest.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/app/CloudAppConfigurationServiceTest.java
index ab6bcf4..12beee3 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/config/app/CloudAppConfigurationServiceTest.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/app/CloudAppConfigurationServiceTest.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.config.app;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.config.app;
 
-import io.elasticjob.cloud.scheduler.fixture.CloudAppConfigurationBuilder;
-import io.elasticjob.cloud.scheduler.fixture.CloudAppJsonConstants;
-import io.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.fixture.CloudAppConfigurationBuilder;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.fixture.CloudAppJsonConstants;
+import org.apache.shardingsphere.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
 import com.google.common.base.Optional;
 import org.hamcrest.core.Is;
 import org.junit.Assert;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/config/job/AllCloudJobConfigTests.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/job/AllCloudJobConfigTests.java
similarity index 93%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/config/job/AllCloudJobConfigTests.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/job/AllCloudJobConfigTests.java
index 364f287..92a33cb 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/config/job/AllCloudJobConfigTests.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/job/AllCloudJobConfigTests.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.config.job;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job;
 
 import org.junit.runner.RunWith;
 import org.junit.runners.Suite;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/config/job/CloudJobConfigurationListenerTest.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/job/CloudJobConfigurationListenerTest.java
similarity index 94%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/config/job/CloudJobConfigurationListenerTest.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/job/CloudJobConfigurationListenerTest.java
index 7a4d0ec..868bf78 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/config/job/CloudJobConfigurationListenerTest.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/job/CloudJobConfigurationListenerTest.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.config.job;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job;
 
-import io.elasticjob.cloud.scheduler.fixture.CloudJsonConstants;
-import io.elasticjob.cloud.scheduler.producer.ProducerManager;
-import io.elasticjob.cloud.scheduler.state.ready.ReadyService;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.fixture.CloudJsonConstants;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.producer.ProducerManager;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.state.ready.ReadyService;
 import org.apache.curator.framework.recipes.cache.ChildData;
 import org.apache.curator.framework.recipes.cache.TreeCacheEvent;
 import org.junit.Before;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/config/job/CloudJobConfigurationNodeTest.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/job/CloudJobConfigurationNodeTest.java
similarity index 93%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/config/job/CloudJobConfigurationNodeTest.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/job/CloudJobConfigurationNodeTest.java
index 7b5ff2b..ea14ea5 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/config/job/CloudJobConfigurationNodeTest.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/job/CloudJobConfigurationNodeTest.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.config.job;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job;
 
 import org.hamcrest.core.Is;
 import org.junit.Assert;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/config/job/CloudJobConfigurationServiceTest.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/job/CloudJobConfigurationServiceTest.java
similarity index 93%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/config/job/CloudJobConfigurationServiceTest.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/job/CloudJobConfigurationServiceTest.java
index 23413fa..ec65486 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/config/job/CloudJobConfigurationServiceTest.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/config/job/CloudJobConfigurationServiceTest.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.config.job;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job;
 
-import io.elasticjob.cloud.scheduler.fixture.CloudJobConfigurationBuilder;
-import io.elasticjob.cloud.scheduler.fixture.CloudJsonConstants;
-import io.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.fixture.CloudJobConfigurationBuilder;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.fixture.CloudJsonConstants;
+import org.apache.shardingsphere.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
 import com.google.common.base.Optional;
 import org.hamcrest.core.Is;
 import org.junit.Assert;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/context/AllContextTests.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/context/AllContextTests.java
similarity index 93%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/context/AllContextTests.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/context/AllContextTests.java
index e093f85..154b3e6 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/context/AllContextTests.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/context/AllContextTests.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.context;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.context;
 
 import org.junit.runner.RunWith;
 import org.junit.runners.Suite;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/context/JobContextTest.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/context/JobContextTest.java
similarity index 80%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/context/JobContextTest.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/context/JobContextTest.java
index f2cc503..273adce 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/context/JobContextTest.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/context/JobContextTest.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.context;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.context;
 
-import io.elasticjob.cloud.scheduler.config.job.CloudJobConfiguration;
-import io.elasticjob.cloud.scheduler.fixture.CloudJobConfigurationBuilder;
-import io.elasticjob.cloud.context.ExecutionType;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.fixture.CloudJobConfigurationBuilder;
+import org.apache.shardingsphere.elasticjob.cloud.context.ExecutionType;
 import org.hamcrest.core.Is;
 import org.junit.Assert;
 import org.junit.Test;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/env/AllEnvTests.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/env/AllEnvTests.java
similarity index 93%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/env/AllEnvTests.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/env/AllEnvTests.java
index 27ec271..0ed9a58 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/env/AllEnvTests.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/env/AllEnvTests.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.env;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.env;
 
 import org.junit.runner.RunWith;
 import org.junit.runners.Suite;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/env/BootstrapEnvironmentTest.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/env/BootstrapEnvironmentTest.java
similarity index 96%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/env/BootstrapEnvironmentTest.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/env/BootstrapEnvironmentTest.java
index ebf71ae..a903af6 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/env/BootstrapEnvironmentTest.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/env/BootstrapEnvironmentTest.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.env;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.env;
 
-import io.elasticjob.cloud.event.rdb.JobEventRdbConfiguration;
-import io.elasticjob.cloud.reg.zookeeper.ZookeeperConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.event.rdb.JobEventRdbConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.reg.zookeeper.ZookeeperConfiguration;
 import com.google.common.base.Optional;
 import org.apache.commons.dbcp.BasicDataSource;
 import org.hamcrest.core.Is;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/fixture/CloudAppConfigurationBuilder.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/fixture/CloudAppConfigurationBuilder.java
similarity index 88%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/fixture/CloudAppConfigurationBuilder.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/fixture/CloudAppConfigurationBuilder.java
index 6b958c0..dafb25f 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/fixture/CloudAppConfigurationBuilder.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/fixture/CloudAppConfigurationBuilder.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.fixture;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.fixture;
 
-import io.elasticjob.cloud.scheduler.config.app.CloudAppConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.app.CloudAppConfiguration;
 import lombok.AccessLevel;
 import lombok.NoArgsConstructor;
 
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/fixture/CloudAppJsonConstants.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/fixture/CloudAppJsonConstants.java
similarity index 95%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/fixture/CloudAppJsonConstants.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/fixture/CloudAppJsonConstants.java
index ec5c664..efba518 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/fixture/CloudAppJsonConstants.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/fixture/CloudAppJsonConstants.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.fixture;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.fixture;
 
 import lombok.AccessLevel;
 import lombok.NoArgsConstructor;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/fixture/CloudJobConfigurationBuilder.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/fixture/CloudJobConfigurationBuilder.java
similarity index 89%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/fixture/CloudJobConfigurationBuilder.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/fixture/CloudJobConfigurationBuilder.java
index 087cffd..00917f2 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/fixture/CloudJobConfigurationBuilder.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/fixture/CloudJobConfigurationBuilder.java
@@ -15,15 +15,15 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.fixture;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.fixture;
 
-import io.elasticjob.cloud.api.simple.SimpleJob;
-import io.elasticjob.cloud.scheduler.config.job.CloudJobConfiguration;
-import io.elasticjob.cloud.scheduler.config.job.CloudJobExecutionType;
-import io.elasticjob.cloud.config.JobCoreConfiguration;
-import io.elasticjob.cloud.config.dataflow.DataflowJobConfiguration;
-import io.elasticjob.cloud.config.script.ScriptJobConfiguration;
-import io.elasticjob.cloud.config.simple.SimpleJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.api.simple.SimpleJob;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobExecutionType;
+import org.apache.shardingsphere.elasticjob.cloud.config.JobCoreConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.config.dataflow.DataflowJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.config.script.ScriptJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.config.simple.SimpleJobConfiguration;
 import lombok.AccessLevel;
 import lombok.NoArgsConstructor;
 
@@ -37,7 +37,7 @@ public final class CloudJobConfigurationBuilder {
      */
     public static CloudJobConfiguration createCloudJobConfiguration(final String jobName) {
         return new CloudJobConfiguration("test_app",
-                new SimpleJobConfiguration(JobCoreConfiguration.newBuilder(jobName, "0/30 * * * * ?", 10).failover(true).misfire(true).build(), TestSimpleJob.class.getCanonicalName()), 
+                new SimpleJobConfiguration(JobCoreConfiguration.newBuilder(jobName, "0/30 * * * * ?", 10).failover(true).misfire(true).build(), TestSimpleJob.class.getCanonicalName()),
                 1.0d, 128.0d, CloudJobExecutionType.TRANSIENT);
     }
 
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/fixture/CloudJsonConstants.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/fixture/CloudJsonConstants.java
similarity index 87%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/fixture/CloudJsonConstants.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/fixture/CloudJsonConstants.java
index 187cdab..5806c12 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/fixture/CloudJsonConstants.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/fixture/CloudJsonConstants.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.fixture;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.fixture;
 
-import io.elasticjob.cloud.scheduler.config.job.CloudJobExecutionType;
-import io.elasticjob.cloud.executor.handler.impl.DefaultExecutorServiceHandler;
-import io.elasticjob.cloud.executor.handler.impl.DefaultJobExceptionHandler;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobExecutionType;
+import org.apache.shardingsphere.elasticjob.cloud.executor.handler.impl.DefaultExecutorServiceHandler;
+import org.apache.shardingsphere.elasticjob.cloud.executor.handler.impl.DefaultJobExceptionHandler;
 import lombok.AccessLevel;
 import lombok.NoArgsConstructor;
 
@@ -29,12 +29,12 @@ public final class CloudJsonConstants {
     private static final String JOB_PROPS_JSON = "{\"job_exception_handler\":\"" + DefaultJobExceptionHandler.class.getCanonicalName() + "\","
             + "\"executor_service_handler\":\"" + DefaultExecutorServiceHandler.class.getCanonicalName() + "\"}";
     
-    private static final String JOB_JSON = "{\"jobName\":\"%s\",\"jobClass\":\"io.elasticjob.cloud.scheduler.fixture.TestSimpleJob\",\"jobType\":\"SIMPLE\","
+    private static final String JOB_JSON = "{\"jobName\":\"%s\",\"jobClass\":\"TestSimpleJob\",\"jobType\":\"SIMPLE\","
             + "\"cron\":\"0/30 * * * * ?\",\"shardingTotalCount\":10,\"shardingItemParameters\":\"\",\"jobParameter\":\"\",\"failover\":true,\"misfire\":%s,\"description\":\"\","
             + "\"jobProperties\":" + JOB_PROPS_JSON + ",\"appName\":\"test_app\",\"cpuCount\":1.0,\"memoryMB\":128.0," 
             + "\"jobExecutionType\":\"%s\"}";
     
-    private static final String SPRING_JOB_JSON = "{\"jobName\":\"test_spring_job\",\"jobClass\":\"io.elasticjob.cloud.scheduler.fixture.TestSimpleJob\",\"jobType\":\"SIMPLE\","
+    private static final String SPRING_JOB_JSON = "{\"jobName\":\"test_spring_job\",\"jobClass\":\"TestSimpleJob\",\"jobType\":\"SIMPLE\","
             + "\"cron\":\"0/30 * * * * ?\",\"shardingTotalCount\":10,\"shardingItemParameters\":\"\",\"jobParameter\":\"\",\"failover\":true,\"misfire\":true,\"description\":\"\","
             + "\"jobProperties\":" + JOB_PROPS_JSON + ",\"appName\":\"test_spring_app\",\"cpuCount\":1.0,\"memoryMB\":128.0,"
             + "\"jobExecutionType\":\"TRANSIENT\",\"beanName\":\"springSimpleJob\","
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/fixture/EmbedTestingServer.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/fixture/EmbedTestingServer.java
similarity index 93%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/fixture/EmbedTestingServer.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/fixture/EmbedTestingServer.java
index a566c52..09cc389 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/fixture/EmbedTestingServer.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/fixture/EmbedTestingServer.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.fixture;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.fixture;
 
-import io.elasticjob.cloud.reg.exception.RegExceptionHandler;
+import org.apache.shardingsphere.elasticjob.cloud.reg.exception.RegExceptionHandler;
 import com.google.common.base.Joiner;
 import lombok.AccessLevel;
 import lombok.NoArgsConstructor;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/fixture/TaskNode.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/fixture/TaskNode.java
similarity index 89%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/fixture/TaskNode.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/fixture/TaskNode.java
index 831ed0e..df2d82e 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/fixture/TaskNode.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/fixture/TaskNode.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.fixture;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.fixture;
 
-import io.elasticjob.cloud.context.ExecutionType;
+import org.apache.shardingsphere.elasticjob.cloud.context.ExecutionType;
 import com.google.common.base.Joiner;
-import io.elasticjob.cloud.context.TaskContext;
+import org.apache.shardingsphere.elasticjob.cloud.context.TaskContext;
 import lombok.Builder;
 
 @Builder
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/fixture/TestSimpleJob.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/fixture/TestSimpleJob.java
similarity index 81%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/fixture/TestSimpleJob.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/fixture/TestSimpleJob.java
index 667ca05..01969d0 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/fixture/TestSimpleJob.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/fixture/TestSimpleJob.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.fixture;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.fixture;
 
-import io.elasticjob.cloud.api.ShardingContext;
-import io.elasticjob.cloud.api.simple.SimpleJob;
+import org.apache.shardingsphere.elasticjob.cloud.api.ShardingContext;
+import org.apache.shardingsphere.elasticjob.cloud.api.simple.SimpleJob;
 
 public final class TestSimpleJob implements SimpleJob {
     
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/ha/AllHATests.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/ha/AllHATests.java
similarity index 93%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/ha/AllHATests.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/ha/AllHATests.java
index d627346..d9d5f1f 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/ha/AllHATests.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/ha/AllHATests.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.ha;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.ha;
 
 import org.junit.runner.RunWith;
 import org.junit.runners.Suite;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/ha/FrameworkIDServiceTest.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/ha/FrameworkIDServiceTest.java
similarity index 93%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/ha/FrameworkIDServiceTest.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/ha/FrameworkIDServiceTest.java
index b1aa6d0..dcfe835 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/ha/FrameworkIDServiceTest.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/ha/FrameworkIDServiceTest.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.ha;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.ha;
 
-import io.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
+import org.apache.shardingsphere.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
 import com.google.common.base.Optional;
 import org.junit.Before;
 import org.junit.Test;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/mesos/AllMesosTests.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/AllMesosTests.java
similarity index 90%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/mesos/AllMesosTests.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/AllMesosTests.java
index 0c3eda7..a709a47 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/mesos/AllMesosTests.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/AllMesosTests.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.mesos;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.mesos;
 
-import io.elasticjob.cloud.scheduler.ha.FrameworkIDServiceTest;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.ha.FrameworkIDServiceTest;
 import org.junit.runner.RunWith;
 import org.junit.runners.Suite;
 
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/mesos/AppConstraintEvaluatorTest.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/AppConstraintEvaluatorTest.java
similarity index 93%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/mesos/AppConstraintEvaluatorTest.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/AppConstraintEvaluatorTest.java
index f664100..705813d 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/mesos/AppConstraintEvaluatorTest.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/AppConstraintEvaluatorTest.java
@@ -15,14 +15,14 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.mesos;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.mesos;
 
-import io.elasticjob.cloud.scheduler.fixture.CloudJobConfigurationBuilder;
-import io.elasticjob.cloud.context.ExecutionType;
-import io.elasticjob.cloud.scheduler.config.app.CloudAppConfiguration;
-import io.elasticjob.cloud.scheduler.config.job.CloudJobConfiguration;
-import io.elasticjob.cloud.scheduler.fixture.CloudAppConfigurationBuilder;
-import io.elasticjob.cloud.context.TaskContext;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.fixture.CloudJobConfigurationBuilder;
+import org.apache.shardingsphere.elasticjob.cloud.context.ExecutionType;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.app.CloudAppConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.fixture.CloudAppConfigurationBuilder;
+import org.apache.shardingsphere.elasticjob.cloud.context.TaskContext;
 import com.google.common.base.Optional;
 import com.google.common.collect.ImmutableList;
 import com.netflix.fenzo.ConstraintEvaluator;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/mesos/FacadeServiceTest.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/FacadeServiceTest.java
similarity index 89%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/mesos/FacadeServiceTest.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/FacadeServiceTest.java
index a1cb263..99313ac 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/mesos/FacadeServiceTest.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/FacadeServiceTest.java
@@ -15,25 +15,25 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.mesos;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.mesos;
 
-import io.elasticjob.cloud.scheduler.config.app.CloudAppConfigurationService;
-import io.elasticjob.cloud.scheduler.config.job.CloudJobConfiguration;
-import io.elasticjob.cloud.scheduler.config.job.CloudJobConfigurationService;
-import io.elasticjob.cloud.scheduler.config.job.CloudJobExecutionType;
-import io.elasticjob.cloud.scheduler.fixture.CloudJobConfigurationBuilder;
-import io.elasticjob.cloud.scheduler.fixture.TaskNode;
-import io.elasticjob.cloud.scheduler.state.disable.app.DisableAppService;
-import io.elasticjob.cloud.scheduler.state.disable.job.DisableJobService;
-import io.elasticjob.cloud.scheduler.state.running.RunningService;
-import io.elasticjob.cloud.context.ExecutionType;
-import io.elasticjob.cloud.scheduler.config.app.CloudAppConfiguration;
-import io.elasticjob.cloud.scheduler.context.JobContext;
-import io.elasticjob.cloud.scheduler.fixture.CloudAppConfigurationBuilder;
-import io.elasticjob.cloud.scheduler.state.failover.FailoverService;
-import io.elasticjob.cloud.scheduler.state.ready.ReadyService;
-import io.elasticjob.cloud.context.TaskContext;
-import io.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.app.CloudAppConfigurationService;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobConfigurationService;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobExecutionType;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.fixture.CloudJobConfigurationBuilder;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.fixture.TaskNode;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.state.disable.app.DisableAppService;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.state.disable.job.DisableJobService;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.state.running.RunningService;
+import org.apache.shardingsphere.elasticjob.cloud.context.ExecutionType;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.app.CloudAppConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.context.JobContext;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.fixture.CloudAppConfigurationBuilder;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.state.failover.FailoverService;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.state.ready.ReadyService;
+import org.apache.shardingsphere.elasticjob.cloud.context.TaskContext;
+import org.apache.shardingsphere.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
 import com.google.common.base.Optional;
 import com.google.common.collect.Sets;
 import org.hamcrest.core.Is;
@@ -129,7 +129,7 @@ public final class FacadeServiceTest {
     @Test
     public void assertRemoveLaunchTasksFromQueue() {
         facadeService.removeLaunchTasksFromQueue(Arrays.asList(
-                TaskContext.from(TaskNode.builder().type(ExecutionType.FAILOVER).build().getTaskNodeValue()), 
+                TaskContext.from(TaskNode.builder().type(ExecutionType.FAILOVER).build().getTaskNodeValue()),
                 TaskContext.from(TaskNode.builder().build().getTaskNodeValue())));
         Mockito.verify(failoverService).remove(Collections.singletonList(TaskContext.MetaInfo.from(TaskNode.builder().build().getTaskNodePath())));
         Mockito.verify(readyService).remove(Sets.newHashSet("test_job"));
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/mesos/JobTaskRequestTest.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/JobTaskRequestTest.java
similarity index 91%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/mesos/JobTaskRequestTest.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/JobTaskRequestTest.java
index dd7890d..1723bc7 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/mesos/JobTaskRequestTest.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/JobTaskRequestTest.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.mesos;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.mesos;
 
-import io.elasticjob.cloud.scheduler.fixture.CloudJobConfigurationBuilder;
-import io.elasticjob.cloud.context.ExecutionType;
-import io.elasticjob.cloud.context.TaskContext;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.fixture.CloudJobConfigurationBuilder;
+import org.apache.shardingsphere.elasticjob.cloud.context.ExecutionType;
+import org.apache.shardingsphere.elasticjob.cloud.context.TaskContext;
 import com.netflix.fenzo.TaskRequest;
 import org.hamcrest.core.Is;
 import org.hamcrest.core.StringStartsWith;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/mesos/LaunchingTasksTest.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/LaunchingTasksTest.java
similarity index 78%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/mesos/LaunchingTasksTest.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/LaunchingTasksTest.java
index 8d5851e..0cc4857 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/mesos/LaunchingTasksTest.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/LaunchingTasksTest.java
@@ -15,16 +15,16 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.mesos;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.mesos;
 
-import io.elasticjob.cloud.scheduler.config.job.CloudJobConfigurationService;
-import io.elasticjob.cloud.scheduler.context.JobContext;
-import io.elasticjob.cloud.scheduler.fixture.CloudJobConfigurationBuilder;
-import io.elasticjob.cloud.scheduler.state.failover.FailoverService;
-import io.elasticjob.cloud.scheduler.state.ready.ReadyService;
-import io.elasticjob.cloud.scheduler.state.running.RunningService;
-import io.elasticjob.cloud.context.ExecutionType;
-import io.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobConfigurationService;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.context.JobContext;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.fixture.CloudJobConfigurationBuilder;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.state.failover.FailoverService;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.state.ready.ReadyService;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.state.running.RunningService;
+import org.apache.shardingsphere.elasticjob.cloud.context.ExecutionType;
+import org.apache.shardingsphere.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
 import com.netflix.fenzo.TaskRequest;
 import org.hamcrest.core.Is;
 import org.junit.Assert;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/mesos/LeasesQueueTest.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/LeasesQueueTest.java
similarity index 89%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/mesos/LeasesQueueTest.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/LeasesQueueTest.java
index 99608a9..73cb868 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/mesos/LeasesQueueTest.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/LeasesQueueTest.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.mesos;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.mesos;
 
-import io.elasticjob.cloud.scheduler.mesos.fixture.OfferBuilder;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.mesos.fixture.OfferBuilder;
 import org.hamcrest.core.Is;
 import org.junit.Assert;
 import org.junit.Test;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/mesos/MesosStateServiceTest.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/MesosStateServiceTest.java
similarity index 91%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/mesos/MesosStateServiceTest.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/MesosStateServiceTest.java
index 93f7757..0ae217e 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/mesos/MesosStateServiceTest.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/MesosStateServiceTest.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.mesos;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.mesos;
 
-import io.elasticjob.cloud.scheduler.ha.HANode;
-import io.elasticjob.cloud.scheduler.restful.AbstractCloudRestfulApiTest;
-import io.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.ha.HANode;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.restful.AbstractCloudRestfulApiTest;
+import org.apache.shardingsphere.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
 import com.google.gson.JsonArray;
 import org.hamcrest.core.Is;
 import org.junit.Assert;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/mesos/ReconcileServiceTest.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/ReconcileServiceTest.java
similarity index 95%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/mesos/ReconcileServiceTest.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/ReconcileServiceTest.java
index d5ffdfe..2516532 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/mesos/ReconcileServiceTest.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/ReconcileServiceTest.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.mesos;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.mesos;
 
-import io.elasticjob.cloud.context.TaskContext;
+import org.apache.shardingsphere.elasticjob.cloud.context.TaskContext;
 import com.google.common.collect.Sets;
 import org.apache.mesos.Protos;
 import org.apache.mesos.SchedulerDriver;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/mesos/SchedulerEngineTest.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/SchedulerEngineTest.java
similarity index 95%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/mesos/SchedulerEngineTest.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/SchedulerEngineTest.java
index de32504..5a55406 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/mesos/SchedulerEngineTest.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/SchedulerEngineTest.java
@@ -15,17 +15,17 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.mesos;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.mesos;
 
-import io.elasticjob.cloud.scheduler.fixture.CloudJobConfigurationBuilder;
-import io.elasticjob.cloud.scheduler.state.running.RunningService;
-import io.elasticjob.cloud.scheduler.statistics.StatisticManager;
-import io.elasticjob.cloud.scheduler.fixture.TaskNode;
-import io.elasticjob.cloud.scheduler.ha.FrameworkIDService;
-import io.elasticjob.cloud.scheduler.mesos.fixture.OfferBuilder;
-import io.elasticjob.cloud.context.TaskContext;
-import io.elasticjob.cloud.event.JobEventBus;
-import io.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.fixture.CloudJobConfigurationBuilder;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.state.running.RunningService;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.statistics.StatisticManager;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.fixture.TaskNode;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.ha.FrameworkIDService;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.mesos.fixture.OfferBuilder;
+import org.apache.shardingsphere.elasticjob.cloud.context.TaskContext;
+import org.apache.shardingsphere.elasticjob.cloud.event.JobEventBus;
+import org.apache.shardingsphere.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
 import com.google.common.base.Optional;
 import com.netflix.fenzo.TaskScheduler;
 import com.netflix.fenzo.functions.Action2;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/mesos/SchedulerServiceTest.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/SchedulerServiceTest.java
similarity index 89%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/mesos/SchedulerServiceTest.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/SchedulerServiceTest.java
index 64dd6c0..126ee4f 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/mesos/SchedulerServiceTest.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/SchedulerServiceTest.java
@@ -15,14 +15,14 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.mesos;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.mesos;
 
-import io.elasticjob.cloud.scheduler.restful.RestfulService;
-import io.elasticjob.cloud.scheduler.statistics.StatisticManager;
-import io.elasticjob.cloud.scheduler.env.BootstrapEnvironment;
-import io.elasticjob.cloud.scheduler.config.job.CloudJobConfigurationListener;
-import io.elasticjob.cloud.scheduler.env.FrameworkConfiguration;
-import io.elasticjob.cloud.scheduler.producer.ProducerManager;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.restful.RestfulService;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.statistics.StatisticManager;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.env.BootstrapEnvironment;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobConfigurationListener;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.env.FrameworkConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.producer.ProducerManager;
 import com.google.common.util.concurrent.Service;
 import org.apache.mesos.SchedulerDriver;
 import org.junit.Before;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/mesos/SupportedExtractionTypeTest.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/SupportedExtractionTypeTest.java
similarity index 96%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/mesos/SupportedExtractionTypeTest.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/SupportedExtractionTypeTest.java
index e652035..59333cd 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/mesos/SupportedExtractionTypeTest.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/SupportedExtractionTypeTest.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.mesos;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.mesos;
 
 import org.junit.Test;
 
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/mesos/TaskInfoDataTest.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/TaskInfoDataTest.java
similarity index 90%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/mesos/TaskInfoDataTest.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/TaskInfoDataTest.java
index 7ce8822..e1c5e9e 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/mesos/TaskInfoDataTest.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/TaskInfoDataTest.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.mesos;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.mesos;
 
-import io.elasticjob.cloud.scheduler.fixture.CloudJobConfigurationBuilder;
-import io.elasticjob.cloud.executor.ShardingContexts;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.fixture.CloudJobConfigurationBuilder;
+import org.apache.shardingsphere.elasticjob.cloud.executor.ShardingContexts;
 import org.apache.commons.lang3.SerializationUtils;
 import org.hamcrest.core.Is;
 import org.junit.Assert;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/mesos/TaskLaunchScheduledServiceTest.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/TaskLaunchScheduledServiceTest.java
similarity index 89%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/mesos/TaskLaunchScheduledServiceTest.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/TaskLaunchScheduledServiceTest.java
index fb4c96f..dd91769 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/mesos/TaskLaunchScheduledServiceTest.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/TaskLaunchScheduledServiceTest.java
@@ -15,17 +15,17 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.mesos;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.mesos;
 
-import io.elasticjob.cloud.scheduler.config.job.CloudJobExecutionType;
-import io.elasticjob.cloud.scheduler.fixture.CloudAppConfigurationBuilder;
-import io.elasticjob.cloud.scheduler.fixture.CloudJobConfigurationBuilder;
-import io.elasticjob.cloud.context.ExecutionType;
-import io.elasticjob.cloud.event.JobEventBus;
-import io.elasticjob.cloud.scheduler.context.JobContext;
-import io.elasticjob.cloud.scheduler.mesos.fixture.OfferBuilder;
-import io.elasticjob.cloud.context.TaskContext;
-import io.elasticjob.cloud.event.type.JobStatusTraceEvent;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobExecutionType;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.fixture.CloudAppConfigurationBuilder;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.fixture.CloudJobConfigurationBuilder;
+import org.apache.shardingsphere.elasticjob.cloud.context.ExecutionType;
+import org.apache.shardingsphere.elasticjob.cloud.event.JobEventBus;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.context.JobContext;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.mesos.fixture.OfferBuilder;
+import org.apache.shardingsphere.elasticjob.cloud.context.TaskContext;
+import org.apache.shardingsphere.elasticjob.cloud.event.type.JobStatusTraceEvent;
 import com.google.common.base.Optional;
 import com.google.common.collect.Lists;
 import com.google.common.collect.Sets;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/mesos/fixture/OfferBuilder.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/fixture/OfferBuilder.java
similarity index 96%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/mesos/fixture/OfferBuilder.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/fixture/OfferBuilder.java
index 0dbcfd6..2b32248 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/mesos/fixture/OfferBuilder.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/fixture/OfferBuilder.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.mesos.fixture;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.mesos.fixture;
 
 import lombok.AccessLevel;
 import lombok.NoArgsConstructor;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/mesos/fixture/master/MesosMasterServerMock.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/fixture/master/MesosMasterServerMock.java
similarity index 99%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/mesos/fixture/master/MesosMasterServerMock.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/fixture/master/MesosMasterServerMock.java
index 019722b..b9361b1 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/mesos/fixture/master/MesosMasterServerMock.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/fixture/master/MesosMasterServerMock.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.mesos.fixture.master;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.mesos.fixture.master;
 
 import com.google.gson.JsonObject;
 import com.google.gson.JsonParser;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/mesos/fixture/slave/MesosSlaveServerMock.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/fixture/slave/MesosSlaveServerMock.java
similarity index 99%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/mesos/fixture/slave/MesosSlaveServerMock.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/fixture/slave/MesosSlaveServerMock.java
index d1f6c23..2dbfe32 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/mesos/fixture/slave/MesosSlaveServerMock.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/mesos/fixture/slave/MesosSlaveServerMock.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.mesos.fixture.slave;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.mesos.fixture.slave;
 
 import com.google.gson.JsonObject;
 import com.google.gson.JsonParser;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/producer/AllProducerTests.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/producer/AllProducerTests.java
similarity index 94%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/producer/AllProducerTests.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/producer/AllProducerTests.java
index 353b070..202f48a 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/producer/AllProducerTests.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/producer/AllProducerTests.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.producer;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.producer;
 
 import org.junit.runner.RunWith;
 import org.junit.runners.Suite;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/producer/ProducerJobTest.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/producer/ProducerJobTest.java
similarity index 93%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/producer/ProducerJobTest.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/producer/ProducerJobTest.java
index 4124bc7..7470ba6 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/producer/ProducerJobTest.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/producer/ProducerJobTest.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.producer;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.producer;
 
-import io.elasticjob.cloud.scheduler.state.ready.ReadyService;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.state.ready.ReadyService;
 import org.junit.Before;
 import org.junit.Test;
 import org.junit.runner.RunWith;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/producer/ProducerManagerTest.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/producer/ProducerManagerTest.java
similarity index 85%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/producer/ProducerManagerTest.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/producer/ProducerManagerTest.java
index d61c176..f715d8f 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/producer/ProducerManagerTest.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/producer/ProducerManagerTest.java
@@ -15,22 +15,22 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.producer;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.producer;
 
-import io.elasticjob.cloud.scheduler.config.app.CloudAppConfigurationService;
-import io.elasticjob.cloud.scheduler.config.job.CloudJobConfiguration;
-import io.elasticjob.cloud.scheduler.config.job.CloudJobConfigurationService;
-import io.elasticjob.cloud.scheduler.config.job.CloudJobExecutionType;
-import io.elasticjob.cloud.scheduler.fixture.CloudAppConfigurationBuilder;
-import io.elasticjob.cloud.scheduler.fixture.CloudJobConfigurationBuilder;
-import io.elasticjob.cloud.scheduler.state.disable.job.DisableJobService;
-import io.elasticjob.cloud.scheduler.state.running.RunningService;
-import io.elasticjob.cloud.exception.AppConfigurationException;
-import io.elasticjob.cloud.exception.JobConfigurationException;
-import io.elasticjob.cloud.scheduler.config.app.CloudAppConfiguration;
-import io.elasticjob.cloud.scheduler.state.ready.ReadyService;
-import io.elasticjob.cloud.context.TaskContext;
-import io.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.app.CloudAppConfigurationService;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobConfigurationService;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobExecutionType;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.fixture.CloudAppConfigurationBuilder;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.fixture.CloudJobConfigurationBuilder;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.state.disable.job.DisableJobService;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.state.running.RunningService;
+import org.apache.shardingsphere.elasticjob.cloud.exception.AppConfigurationException;
+import org.apache.shardingsphere.elasticjob.cloud.exception.JobConfigurationException;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.app.CloudAppConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.state.ready.ReadyService;
+import org.apache.shardingsphere.elasticjob.cloud.context.TaskContext;
+import org.apache.shardingsphere.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
 import com.google.common.base.Optional;
 import com.google.common.collect.Lists;
 import org.apache.mesos.Protos;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/producer/TransientProducerRepositoryTest.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/producer/TransientProducerRepositoryTest.java
similarity index 97%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/producer/TransientProducerRepositoryTest.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/producer/TransientProducerRepositoryTest.java
index 79ee5a9..4c04201 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/producer/TransientProducerRepositoryTest.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/producer/TransientProducerRepositoryTest.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.producer;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.producer;
 
 import org.junit.Test;
 import org.junit.runner.RunWith;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/producer/TransientProducerSchedulerTest.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/producer/TransientProducerSchedulerTest.java
similarity index 90%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/producer/TransientProducerSchedulerTest.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/producer/TransientProducerSchedulerTest.java
index 781b18f..e344d15 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/producer/TransientProducerSchedulerTest.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/producer/TransientProducerSchedulerTest.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.producer;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.producer;
 
-import io.elasticjob.cloud.scheduler.fixture.CloudJobConfigurationBuilder;
-import io.elasticjob.cloud.scheduler.config.job.CloudJobConfiguration;
-import io.elasticjob.cloud.scheduler.state.ready.ReadyService;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.fixture.CloudJobConfigurationBuilder;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.state.ready.ReadyService;
 import org.junit.Before;
 import org.junit.Test;
 import org.junit.runner.RunWith;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/restful/AbstractCloudRestfulApiTest.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/restful/AbstractCloudRestfulApiTest.java
similarity index 76%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/restful/AbstractCloudRestfulApiTest.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/restful/AbstractCloudRestfulApiTest.java
index 29f5a93..ab3cb7f 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/restful/AbstractCloudRestfulApiTest.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/restful/AbstractCloudRestfulApiTest.java
@@ -15,18 +15,18 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.restful;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.restful;
 
-import io.elasticjob.cloud.scheduler.mesos.MesosStateService;
-import io.elasticjob.cloud.scheduler.mesos.ReconcileService;
-import io.elasticjob.cloud.scheduler.mesos.fixture.slave.MesosSlaveServerMock;
-import io.elasticjob.cloud.event.rdb.JobEventRdbSearch;
-import io.elasticjob.cloud.scheduler.env.RestfulServerConfiguration;
-import io.elasticjob.cloud.scheduler.mesos.FacadeService;
-import io.elasticjob.cloud.scheduler.mesos.fixture.master.MesosMasterServerMock;
-import io.elasticjob.cloud.scheduler.producer.ProducerManager;
-import io.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
-import io.elasticjob.cloud.restful.RestfulServer;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.mesos.MesosStateService;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.mesos.ReconcileService;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.mesos.fixture.slave.MesosSlaveServerMock;
+import org.apache.shardingsphere.elasticjob.cloud.event.rdb.JobEventRdbSearch;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.env.RestfulServerConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.mesos.FacadeService;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.mesos.fixture.master.MesosMasterServerMock;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.producer.ProducerManager;
+import org.apache.shardingsphere.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
+import org.apache.shardingsphere.elasticjob.cloud.restful.RestfulServer;
 import com.google.common.base.Optional;
 import lombok.AccessLevel;
 import lombok.Getter;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/restful/AllRestfulTests.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/restful/AllRestfulTests.java
similarity index 93%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/restful/AllRestfulTests.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/restful/AllRestfulTests.java
index 8e748ea..e473e95 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/restful/AllRestfulTests.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/restful/AllRestfulTests.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.restful;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.restful;
 
 import org.junit.runner.RunWith;
 import org.junit.runners.Suite;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/restful/CloudAppRestfulApiTest.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/restful/CloudAppRestfulApiTest.java
similarity index 96%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/restful/CloudAppRestfulApiTest.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/restful/CloudAppRestfulApiTest.java
index f988c5a..86c1d67 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/restful/CloudAppRestfulApiTest.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/restful/CloudAppRestfulApiTest.java
@@ -15,11 +15,11 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.restful;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.restful;
 
 import com.google.common.collect.Lists;
-import io.elasticjob.cloud.scheduler.fixture.CloudAppJsonConstants;
-import io.elasticjob.cloud.scheduler.fixture.CloudJsonConstants;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.fixture.CloudAppJsonConstants;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.fixture.CloudJsonConstants;
 import org.hamcrest.core.Is;
 import org.junit.Assert;
 import org.junit.Test;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/restful/CloudJobRestfulApiTest.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/restful/CloudJobRestfulApiTest.java
similarity index 92%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/restful/CloudJobRestfulApiTest.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/restful/CloudJobRestfulApiTest.java
index ae01a10..a1255d3 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/restful/CloudJobRestfulApiTest.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/restful/CloudJobRestfulApiTest.java
@@ -15,26 +15,23 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.restful;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.restful;
 
-import io.elasticjob.cloud.scheduler.config.job.CloudJobExecutionType;
-import io.elasticjob.cloud.scheduler.fixture.TaskNode;
-import io.elasticjob.cloud.scheduler.state.running.RunningService;
-import io.elasticjob.cloud.context.ExecutionType;
-import io.elasticjob.cloud.event.rdb.JobEventRdbSearch;
-import io.elasticjob.cloud.event.type.JobExecutionEvent;
-import io.elasticjob.cloud.scheduler.fixture.CloudAppJsonConstants;
-import io.elasticjob.cloud.scheduler.fixture.CloudJsonConstants;
-import io.elasticjob.cloud.scheduler.state.failover.FailoverTaskInfo;
-import io.elasticjob.cloud.statistics.type.task.TaskResultStatistics;
-import io.elasticjob.cloud.util.json.GsonFactory;
-import io.elasticjob.cloud.context.TaskContext;
-import io.elasticjob.cloud.context.TaskContext.MetaInfo;
-import io.elasticjob.cloud.event.type.JobStatusTraceEvent;
-import io.elasticjob.cloud.event.type.JobStatusTraceEvent.Source;
-import io.elasticjob.cloud.event.type.JobStatusTraceEvent.State;
-import io.elasticjob.cloud.statistics.type.job.JobExecutionTypeStatistics;
-import io.elasticjob.cloud.statistics.type.job.JobTypeStatistics;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobExecutionType;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.fixture.TaskNode;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.state.running.RunningService;
+import org.apache.shardingsphere.elasticjob.cloud.context.ExecutionType;
+import org.apache.shardingsphere.elasticjob.cloud.event.rdb.JobEventRdbSearch;
+import org.apache.shardingsphere.elasticjob.cloud.event.type.JobExecutionEvent;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.fixture.CloudAppJsonConstants;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.fixture.CloudJsonConstants;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.state.failover.FailoverTaskInfo;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.type.task.TaskResultStatistics;
+import org.apache.shardingsphere.elasticjob.cloud.util.json.GsonFactory;
+import org.apache.shardingsphere.elasticjob.cloud.context.TaskContext;
+import org.apache.shardingsphere.elasticjob.cloud.event.type.JobStatusTraceEvent;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.type.job.JobExecutionTypeStatistics;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.type.job.JobTypeStatistics;
 import com.google.common.collect.Lists;
 import org.hamcrest.core.Is;
 import org.junit.Assert;
@@ -169,7 +166,7 @@ public final class CloudJobRestfulApiTest extends AbstractCloudRestfulApiTest {
         Mockito.when(getRegCenter().getChildrenKeys("/state/failover/test_job")).thenReturn(Lists.newArrayList("test_job@-@0"));
         String originalTaskId = UUID.randomUUID().toString();
         Mockito.when(getRegCenter().get("/state/failover/test_job/test_job@-@0")).thenReturn(originalTaskId);
-        FailoverTaskInfo expectedFailoverTask = new FailoverTaskInfo(MetaInfo.from("test_job@-@0"), originalTaskId);
+        FailoverTaskInfo expectedFailoverTask = new FailoverTaskInfo(TaskContext.MetaInfo.from("test_job@-@0"), originalTaskId);
         Collection<FailoverTaskInfo> expectedResult = Lists.newArrayList(expectedFailoverTask);
         Assert.assertThat(RestfulTestsUtil.sentGetRequest("http://127.0.0.1:19000/api/job/tasks/failover"), Is.is(GsonFactory.getGson().toJson(expectedResult)));
         Mockito.verify(getRegCenter()).isExisted("/state/failover");
@@ -207,7 +204,7 @@ public final class CloudJobRestfulApiTest extends AbstractCloudRestfulApiTest {
     public void assertFindJobStatusTraceEvent() throws Exception {
         ReflectionUtils.setFieldValue(CloudJobRestfulApi.class, CloudJobRestfulApi.class.getDeclaredField("jobEventRdbSearch"), getJobEventRdbSearch());
         JobStatusTraceEvent jobStatusTraceEvent = new JobStatusTraceEvent(
-                "test-job", "fake_task_id", "fake_slave_id", Source.LITE_EXECUTOR, ExecutionType.READY, "0", State.TASK_RUNNING, "message is empty.");
+                "test-job", "fake_task_id", "fake_slave_id", JobStatusTraceEvent.Source.LITE_EXECUTOR, ExecutionType.READY, "0", JobStatusTraceEvent.State.TASK_RUNNING, "message is empty.");
         Mockito.when(getJobEventRdbSearch().findJobStatusTraceEvents(Mockito.any(JobEventRdbSearch.Condition.class))).thenReturn(new JobEventRdbSearch.Result<>(0,
                 Lists.newArrayList(jobStatusTraceEvent)));
         Assert.assertThat(RestfulTestsUtil.sentGetRequest("http://127.0.0.1:19000/api/job/events/statusTraces?" + buildFindJobEventsQueryParameter()),
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/restful/CloudOperationRestfulApiTest.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/restful/CloudOperationRestfulApiTest.java
similarity index 95%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/restful/CloudOperationRestfulApiTest.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/restful/CloudOperationRestfulApiTest.java
index b73d997..702bffd 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/restful/CloudOperationRestfulApiTest.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/restful/CloudOperationRestfulApiTest.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.restful;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.restful;
 
-import io.elasticjob.cloud.scheduler.ha.HANode;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.ha.HANode;
 import org.hamcrest.core.Is;
 import org.junit.Assert;
 import org.junit.Test;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/restful/RestfulTestsUtil.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/restful/RestfulTestsUtil.java
similarity index 98%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/restful/RestfulTestsUtil.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/restful/RestfulTestsUtil.java
index fa68d1e..9a27220 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/restful/RestfulTestsUtil.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/restful/RestfulTestsUtil.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.restful;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.restful;
 
 import org.eclipse.jetty.client.ContentExchange;
 import org.eclipse.jetty.client.HttpClient;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/state/AllStateTests.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/AllStateTests.java
similarity index 54%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/state/AllStateTests.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/AllStateTests.java
index 97cecb3..8a634aa 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/state/AllStateTests.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/AllStateTests.java
@@ -15,25 +15,25 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.state;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.state;
 
-import io.elasticjob.cloud.scheduler.state.disable.job.DisableJobNodeTest;
-import io.elasticjob.cloud.scheduler.state.disable.job.DisableJobServiceTest;
-import io.elasticjob.cloud.scheduler.state.failover.FailoverNodeTest;
-import io.elasticjob.cloud.scheduler.state.failover.FailoverServiceTest;
-import io.elasticjob.cloud.scheduler.state.ready.ReadyServiceTest;
-import io.elasticjob.cloud.scheduler.state.running.RunningServiceTest;
-import io.elasticjob.cloud.scheduler.state.disable.app.DisableAppNodeTest;
-import io.elasticjob.cloud.scheduler.state.disable.app.DisableAppServiceTest;
-import io.elasticjob.cloud.scheduler.state.ready.ReadyNodeTest;
-import io.elasticjob.cloud.scheduler.state.running.RunningNodeTest;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.state.disable.job.DisableJobNodeTest;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.state.disable.job.DisableJobServiceTest;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.state.failover.FailoverNodeTest;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.state.failover.FailoverServiceTest;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.state.ready.ReadyServiceTest;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.state.running.RunningServiceTest;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.state.disable.app.DisableAppNodeTest;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.state.disable.app.DisableAppServiceTest;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.state.ready.ReadyNodeTest;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.state.running.RunningNodeTest;
 import org.junit.runner.RunWith;
 import org.junit.runners.Suite;
 
 @RunWith(Suite.class)
 @Suite.SuiteClasses({
         ReadyNodeTest.class, 
-        ReadyServiceTest.class, 
+        ReadyServiceTest.class,
         FailoverNodeTest.class, 
         FailoverServiceTest.class,
         RunningNodeTest.class,
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/state/disable/app/DisableAppNodeTest.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/disable/app/DisableAppNodeTest.java
similarity index 93%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/state/disable/app/DisableAppNodeTest.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/disable/app/DisableAppNodeTest.java
index 820fb81..b52744b 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/state/disable/app/DisableAppNodeTest.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/disable/app/DisableAppNodeTest.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.state.disable.app;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.state.disable.app;
 
 import org.hamcrest.core.Is;
 import org.junit.Assert;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/state/disable/app/DisableAppServiceTest.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/disable/app/DisableAppServiceTest.java
similarity index 93%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/state/disable/app/DisableAppServiceTest.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/disable/app/DisableAppServiceTest.java
index eefaea9..f5b8227 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/state/disable/app/DisableAppServiceTest.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/disable/app/DisableAppServiceTest.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.state.disable.app;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.state.disable.app;
 
-import io.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
+import org.apache.shardingsphere.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
 import org.junit.Assert;
 import org.junit.Before;
 import org.junit.Test;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/state/disable/job/DisableJobNodeTest.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/disable/job/DisableJobNodeTest.java
similarity index 93%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/state/disable/job/DisableJobNodeTest.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/disable/job/DisableJobNodeTest.java
index 5289e4a..a4b9f99 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/state/disable/job/DisableJobNodeTest.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/disable/job/DisableJobNodeTest.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.state.disable.job;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.state.disable.job;
 
 import org.hamcrest.core.Is;
 import org.junit.Assert;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/state/disable/job/DisableJobServiceTest.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/disable/job/DisableJobServiceTest.java
similarity index 93%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/state/disable/job/DisableJobServiceTest.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/disable/job/DisableJobServiceTest.java
index 40d1efa..8fe23b3 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/state/disable/job/DisableJobServiceTest.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/disable/job/DisableJobServiceTest.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.state.disable.job;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.state.disable.job;
 
-import io.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
+import org.apache.shardingsphere.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
 import org.junit.Assert;
 import org.junit.Before;
 import org.junit.Test;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/state/failover/FailoverNodeTest.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/failover/FailoverNodeTest.java
similarity index 86%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/state/failover/FailoverNodeTest.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/failover/FailoverNodeTest.java
index bc4d340..39855e0 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/state/failover/FailoverNodeTest.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/failover/FailoverNodeTest.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.state.failover;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.state.failover;
 
-import io.elasticjob.cloud.context.ExecutionType;
-import io.elasticjob.cloud.scheduler.fixture.TaskNode;
+import org.apache.shardingsphere.elasticjob.cloud.context.ExecutionType;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.fixture.TaskNode;
 import org.hamcrest.core.Is;
 import org.junit.Assert;
 import org.junit.Test;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/state/failover/FailoverServiceTest.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/failover/FailoverServiceTest.java
similarity index 93%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/state/failover/FailoverServiceTest.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/failover/FailoverServiceTest.java
index 5ee7844..89303bc 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/state/failover/FailoverServiceTest.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/failover/FailoverServiceTest.java
@@ -15,18 +15,18 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.state.failover;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.state.failover;
 
-import io.elasticjob.cloud.scheduler.fixture.CloudJobConfigurationBuilder;
-import io.elasticjob.cloud.context.ExecutionType;
-import io.elasticjob.cloud.scheduler.config.job.CloudJobConfiguration;
-import io.elasticjob.cloud.scheduler.config.job.CloudJobConfigurationService;
-import io.elasticjob.cloud.scheduler.context.JobContext;
-import io.elasticjob.cloud.scheduler.env.BootstrapEnvironment;
-import io.elasticjob.cloud.scheduler.fixture.TaskNode;
-import io.elasticjob.cloud.scheduler.state.running.RunningService;
-import io.elasticjob.cloud.context.TaskContext;
-import io.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.fixture.CloudJobConfigurationBuilder;
+import org.apache.shardingsphere.elasticjob.cloud.context.ExecutionType;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobConfigurationService;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.context.JobContext;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.env.BootstrapEnvironment;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.fixture.TaskNode;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.state.running.RunningService;
+import org.apache.shardingsphere.elasticjob.cloud.context.TaskContext;
+import org.apache.shardingsphere.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
 import com.google.common.base.Optional;
 import com.google.common.collect.Lists;
 import org.hamcrest.core.Is;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/state/ready/ReadyNodeTest.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/ready/ReadyNodeTest.java
similarity index 93%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/state/ready/ReadyNodeTest.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/ready/ReadyNodeTest.java
index 8c1f682..b415db7 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/state/ready/ReadyNodeTest.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/ready/ReadyNodeTest.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.state.ready;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.state.ready;
 
 import org.hamcrest.core.Is;
 import org.junit.Assert;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/state/ready/ReadyServiceTest.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/ready/ReadyServiceTest.java
similarity index 94%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/state/ready/ReadyServiceTest.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/ready/ReadyServiceTest.java
index 0c4f86e..eb965a6 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/state/ready/ReadyServiceTest.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/ready/ReadyServiceTest.java
@@ -15,17 +15,17 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.state.ready;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.state.ready;
 
-import io.elasticjob.cloud.scheduler.fixture.CloudJobConfigurationBuilder;
-import io.elasticjob.cloud.context.ExecutionType;
-import io.elasticjob.cloud.scheduler.config.job.CloudJobConfiguration;
-import io.elasticjob.cloud.scheduler.config.job.CloudJobConfigurationService;
-import io.elasticjob.cloud.scheduler.config.job.CloudJobExecutionType;
-import io.elasticjob.cloud.scheduler.context.JobContext;
-import io.elasticjob.cloud.scheduler.env.BootstrapEnvironment;
-import io.elasticjob.cloud.scheduler.state.running.RunningService;
-import io.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.fixture.CloudJobConfigurationBuilder;
+import org.apache.shardingsphere.elasticjob.cloud.context.ExecutionType;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobConfigurationService;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobExecutionType;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.context.JobContext;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.env.BootstrapEnvironment;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.state.running.RunningService;
+import org.apache.shardingsphere.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
 import com.google.common.base.Optional;
 import com.google.common.collect.Lists;
 import org.hamcrest.core.Is;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/state/running/RunningNodeTest.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/running/RunningNodeTest.java
similarity index 89%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/state/running/RunningNodeTest.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/running/RunningNodeTest.java
index 64c433d..136633b 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/state/running/RunningNodeTest.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/running/RunningNodeTest.java
@@ -15,9 +15,9 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.state.running;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.state.running;
 
-import io.elasticjob.cloud.scheduler.fixture.TaskNode;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.fixture.TaskNode;
 import org.hamcrest.core.Is;
 import org.junit.Assert;
 import org.junit.Test;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/state/running/RunningServiceTest.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/running/RunningServiceTest.java
similarity index 92%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/state/running/RunningServiceTest.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/running/RunningServiceTest.java
index 72c00a5..0932081 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/state/running/RunningServiceTest.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/state/running/RunningServiceTest.java
@@ -15,14 +15,14 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.state.running;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.state.running;
 
-import io.elasticjob.cloud.context.ExecutionType;
-import io.elasticjob.cloud.scheduler.config.job.CloudJobExecutionType;
-import io.elasticjob.cloud.scheduler.fixture.CloudJsonConstants;
-import io.elasticjob.cloud.scheduler.fixture.TaskNode;
-import io.elasticjob.cloud.context.TaskContext;
-import io.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
+import org.apache.shardingsphere.elasticjob.cloud.context.ExecutionType;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobExecutionType;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.fixture.CloudJsonConstants;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.fixture.TaskNode;
+import org.apache.shardingsphere.elasticjob.cloud.context.TaskContext;
+import org.apache.shardingsphere.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
 import org.hamcrest.core.Is;
 import org.junit.After;
 import org.junit.Assert;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/statistics/AllStatisticTests.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/AllStatisticTests.java
similarity index 64%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/statistics/AllStatisticTests.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/AllStatisticTests.java
index 6d7aee8..2c2cde1 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/statistics/AllStatisticTests.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/AllStatisticTests.java
@@ -15,13 +15,13 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.statistics;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.statistics;
 
-import io.elasticjob.cloud.scheduler.statistics.job.JobRunningStatisticJobTest;
-import io.elasticjob.cloud.scheduler.statistics.job.RegisteredJobStatisticJobTest;
-import io.elasticjob.cloud.scheduler.statistics.job.TaskResultStatisticJobTest;
-import io.elasticjob.cloud.scheduler.statistics.util.StatisticTimeUtilsTest;
-import io.elasticjob.cloud.scheduler.statistics.job.BaseStatisticJobTest;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.statistics.job.JobRunningStatisticJobTest;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.statistics.job.RegisteredJobStatisticJobTest;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.statistics.job.TaskResultStatisticJobTest;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.statistics.util.StatisticTimeUtilsTest;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.statistics.job.BaseStatisticJobTest;
 import org.junit.runner.RunWith;
 import org.junit.runners.Suite;
 
@@ -29,11 +29,11 @@ import org.junit.runners.Suite;
 @Suite.SuiteClasses({
         StatisticManagerTest.class, 
         StatisticsSchedulerTest.class, 
-        BaseStatisticJobTest.class, 
+        BaseStatisticJobTest.class,
         TaskResultMetaDataTest.class, 
         StatisticTimeUtilsTest.class, 
         RegisteredJobStatisticJobTest.class, 
-        TaskResultStatisticJobTest.class, 
+        TaskResultStatisticJobTest.class,
         JobRunningStatisticJobTest.class
     })
 public final class AllStatisticTests {
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/statistics/StatisticManagerTest.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/StatisticManagerTest.java
similarity index 91%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/statistics/StatisticManagerTest.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/StatisticManagerTest.java
index ff195d1..548028d 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/statistics/StatisticManagerTest.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/StatisticManagerTest.java
@@ -15,19 +15,19 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.statistics;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.statistics;
 
-import io.elasticjob.cloud.scheduler.config.job.CloudJobConfigurationService;
-import io.elasticjob.cloud.scheduler.config.job.CloudJobExecutionType;
-import io.elasticjob.cloud.scheduler.fixture.CloudJobConfigurationBuilder;
-import io.elasticjob.cloud.event.rdb.JobEventRdbConfiguration;
-import io.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
-import io.elasticjob.cloud.statistics.StatisticInterval;
-import io.elasticjob.cloud.statistics.rdb.StatisticRdbRepository;
-import io.elasticjob.cloud.statistics.type.job.JobRegisterStatistics;
-import io.elasticjob.cloud.statistics.type.job.JobRunningStatistics;
-import io.elasticjob.cloud.statistics.type.task.TaskResultStatistics;
-import io.elasticjob.cloud.statistics.type.task.TaskRunningStatistics;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobConfigurationService;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobExecutionType;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.fixture.CloudJobConfigurationBuilder;
+import org.apache.shardingsphere.elasticjob.cloud.event.rdb.JobEventRdbConfiguration;
+import org.apache.shardingsphere.elasticjob.cloud.reg.base.CoordinatorRegistryCenter;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.StatisticInterval;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.rdb.StatisticRdbRepository;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.type.job.JobRegisterStatistics;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.type.job.JobRunningStatistics;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.type.task.TaskResultStatistics;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.type.task.TaskRunningStatistics;
 import com.google.common.base.Optional;
 import com.google.common.collect.Lists;
 import org.hamcrest.core.Is;
@@ -144,7 +144,7 @@ public class StatisticManagerTest {
     public void assertJobExecutionTypeStatistics() throws NoSuchFieldException {
         ReflectionUtils.setFieldValue(statisticManager, "configurationService", configurationService);
         Mockito.when(configurationService.loadAll()).thenReturn(Lists.newArrayList(
-                CloudJobConfigurationBuilder.createCloudJobConfiguration("test_job_1", CloudJobExecutionType.DAEMON), 
+                CloudJobConfigurationBuilder.createCloudJobConfiguration("test_job_1", CloudJobExecutionType.DAEMON),
                 CloudJobConfigurationBuilder.createCloudJobConfiguration("test_job_2", CloudJobExecutionType.TRANSIENT)));
         Assert.assertThat(statisticManager.getJobExecutionTypeStatistics().getDaemonJobCount(), Is.is(1));
         Assert.assertThat(statisticManager.getJobExecutionTypeStatistics().getTransientJobCount(), Is.is(1));
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/statistics/StatisticsSchedulerTest.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/StatisticsSchedulerTest.java
similarity index 89%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/statistics/StatisticsSchedulerTest.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/StatisticsSchedulerTest.java
index 035e0d6..4808e61 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/statistics/StatisticsSchedulerTest.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/StatisticsSchedulerTest.java
@@ -15,10 +15,10 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.statistics;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.statistics;
 
-import io.elasticjob.cloud.scheduler.statistics.job.StatisticJob;
-import io.elasticjob.cloud.scheduler.statistics.job.TestStatisticJob;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.statistics.job.StatisticJob;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.statistics.job.TestStatisticJob;
 import org.junit.Before;
 import org.junit.Test;
 import org.junit.runner.RunWith;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/statistics/TaskResultMetaDataTest.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/TaskResultMetaDataTest.java
similarity index 96%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/statistics/TaskResultMetaDataTest.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/TaskResultMetaDataTest.java
index 799b296..0680293 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/statistics/TaskResultMetaDataTest.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/TaskResultMetaDataTest.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.statistics;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.statistics;
 
 import static org.hamcrest.CoreMatchers.is;
 import static org.junit.Assert.assertThat;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/statistics/job/BaseStatisticJobTest.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/job/BaseStatisticJobTest.java
similarity index 88%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/statistics/job/BaseStatisticJobTest.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/job/BaseStatisticJobTest.java
index 4196be9..b1e71c6 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/statistics/job/BaseStatisticJobTest.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/job/BaseStatisticJobTest.java
@@ -15,15 +15,15 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.statistics.job;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.statistics.job;
 
 import static org.hamcrest.CoreMatchers.is;
 import static org.junit.Assert.assertThat;
 
 import java.util.Date;
 
-import io.elasticjob.cloud.scheduler.statistics.util.StatisticTimeUtils;
-import io.elasticjob.cloud.statistics.StatisticInterval;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.statistics.util.StatisticTimeUtils;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.StatisticInterval;
 import org.junit.Before;
 import org.junit.Test;
 
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/statistics/job/JobRunningStatisticJobTest.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/job/JobRunningStatisticJobTest.java
similarity index 87%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/statistics/job/JobRunningStatisticJobTest.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/job/JobRunningStatisticJobTest.java
index 7408a85..dab554b 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/statistics/job/JobRunningStatisticJobTest.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/job/JobRunningStatisticJobTest.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.statistics.job;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.statistics.job;
 
 import java.util.Collections;
 import java.util.HashMap;
@@ -23,12 +23,14 @@ import java.util.HashSet;
 import java.util.Map;
 import java.util.Set;
 
-import io.elasticjob.cloud.scheduler.fixture.TaskNode;
-import io.elasticjob.cloud.scheduler.state.running.RunningService;
-import io.elasticjob.cloud.scheduler.statistics.util.StatisticTimeUtils;
-import io.elasticjob.cloud.statistics.StatisticInterval;
-import io.elasticjob.cloud.statistics.type.job.JobRunningStatistics;
-import io.elasticjob.cloud.context.TaskContext;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.fixture.TaskNode;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.state.running.RunningService;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.statistics.util.StatisticTimeUtils;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.StatisticInterval;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.type.job.JobRunningStatistics;
+import org.apache.shardingsphere.elasticjob.cloud.context.TaskContext;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.rdb.StatisticRdbRepository;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.type.task.TaskRunningStatistics;
 import org.hamcrest.core.Is;
 import org.junit.Assert;
 import org.junit.Before;
@@ -41,8 +43,6 @@ import org.mockito.junit.MockitoJUnitRunner;
 import org.quartz.SchedulerException;
 import org.quartz.Trigger;
 
-import io.elasticjob.cloud.statistics.rdb.StatisticRdbRepository;
-import io.elasticjob.cloud.statistics.type.task.TaskRunningStatistics;
 import com.google.common.base.Optional;
 
 @RunWith(MockitoJUnitRunner.class)
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/statistics/job/RegisteredJobStatisticJobTest.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/job/RegisteredJobStatisticJobTest.java
similarity index 86%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/statistics/job/RegisteredJobStatisticJobTest.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/job/RegisteredJobStatisticJobTest.java
index 6075094..c37b173 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/statistics/job/RegisteredJobStatisticJobTest.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/job/RegisteredJobStatisticJobTest.java
@@ -15,14 +15,14 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.statistics.job;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.statistics.job;
 
-import io.elasticjob.cloud.scheduler.fixture.CloudJobConfigurationBuilder;
-import io.elasticjob.cloud.scheduler.config.job.CloudJobConfigurationService;
-import io.elasticjob.cloud.scheduler.statistics.util.StatisticTimeUtils;
-import io.elasticjob.cloud.statistics.StatisticInterval;
-import io.elasticjob.cloud.statistics.rdb.StatisticRdbRepository;
-import io.elasticjob.cloud.statistics.type.job.JobRegisterStatistics;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.fixture.CloudJobConfigurationBuilder;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.config.job.CloudJobConfigurationService;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.statistics.util.StatisticTimeUtils;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.StatisticInterval;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.rdb.StatisticRdbRepository;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.type.job.JobRegisterStatistics;
 import com.google.common.base.Optional;
 import com.google.common.collect.Lists;
 import org.junit.Before;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/statistics/job/TaskResultStatisticJobTest.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/job/TaskResultStatisticJobTest.java
similarity index 89%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/statistics/job/TaskResultStatisticJobTest.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/job/TaskResultStatisticJobTest.java
index e45654f..47ce2c0 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/statistics/job/TaskResultStatisticJobTest.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/job/TaskResultStatisticJobTest.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.statistics.job;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.statistics.job;
 
 import static org.hamcrest.CoreMatchers.is;
 import static org.junit.Assert.assertThat;
@@ -24,9 +24,11 @@ import static org.mockito.Mockito.times;
 import static org.mockito.Mockito.verify;
 import static org.mockito.Mockito.when;
 
-import io.elasticjob.cloud.scheduler.statistics.TaskResultMetaData;
-import io.elasticjob.cloud.scheduler.statistics.util.StatisticTimeUtils;
-import io.elasticjob.cloud.statistics.type.task.TaskResultStatistics;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.statistics.TaskResultMetaData;
+import org.apache.shardingsphere.elasticjob.cloud.scheduler.statistics.util.StatisticTimeUtils;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.type.task.TaskResultStatistics;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.StatisticInterval;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.rdb.StatisticRdbRepository;
 import org.junit.Before;
 import org.junit.Test;
 import org.junit.runner.RunWith;
@@ -35,8 +37,6 @@ import org.mockito.junit.MockitoJUnitRunner;
 import org.quartz.SchedulerException;
 import org.quartz.Trigger;
 
-import io.elasticjob.cloud.statistics.StatisticInterval;
-import io.elasticjob.cloud.statistics.rdb.StatisticRdbRepository;
 import com.google.common.base.Optional;
 
 @RunWith(MockitoJUnitRunner.class)
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/statistics/job/TestStatisticJob.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/job/TestStatisticJob.java
similarity index 92%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/statistics/job/TestStatisticJob.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/job/TestStatisticJob.java
index c65a360..75e04ef 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/statistics/job/TestStatisticJob.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/job/TestStatisticJob.java
@@ -15,12 +15,12 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.statistics.job;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.statistics.job;
 
 import java.util.HashMap;
 import java.util.Map;
 
-import io.elasticjob.cloud.statistics.StatisticInterval;
+import org.apache.shardingsphere.elasticjob.cloud.statistics.StatisticInterval;
 import org.quartz.CronScheduleBuilder;
 import org.quartz.JobBuilder;
 import org.quartz.JobDetail;
diff --git a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/statistics/util/StatisticTimeUtilsTest.java b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/util/StatisticTimeUtilsTest.java
similarity index 95%
rename from elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/statistics/util/StatisticTimeUtilsTest.java
rename to elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/util/StatisticTimeUtilsTest.java
index 2e2152c..1076118 100644
--- a/elastic-job-cloud-scheduler/src/test/java/io/elasticjob/cloud/scheduler/statistics/util/StatisticTimeUtilsTest.java
+++ b/elastic-job-cloud-scheduler/src/test/java/org/apache/shardingsphere/elasticjob/cloud/scheduler/statistics/util/StatisticTimeUtilsTest.java
@@ -15,7 +15,7 @@
  * limitations under the License.
  */
 
-package io.elasticjob.cloud.scheduler.statistics.util;
+package org.apache.shardingsphere.elasticjob.cloud.scheduler.statistics.util;
 
 import static org.hamcrest.CoreMatchers.is;
 import static org.junit.Assert.assertThat;
@@ -23,10 +23,9 @@ import static org.junit.Assert.assertThat;
 import java.text.SimpleDateFormat;
 import java.util.Date;
 
+import org.apache.shardingsphere.elasticjob.cloud.statistics.StatisticInterval;
 import org.junit.Test;
 
-import io.elasticjob.cloud.statistics.StatisticInterval;
-
 public class StatisticTimeUtilsTest {
     
     @Test
diff --git a/elastic-job-cloud-scheduler/src/test/resources/logback-test.xml b/elastic-job-cloud-scheduler/src/test/resources/logback-test.xml
index 68cb68d..7defc2b 100644
--- a/elastic-job-cloud-scheduler/src/test/resources/logback-test.xml
+++ b/elastic-job-cloud-scheduler/src/test/resources/logback-test.xml
@@ -37,7 +37,7 @@
         <appender-ref ref="STDOUT" />
     </root>
     
-    <logger name="io.elasticjob.cloud.scheduler.mesos.SchedulerEngine" level="OFF" />
-    <logger name="io.elasticjob.cloud.scheduler.state.ready.ReadyService" level="OFF" />
-    <logger name="io.elasticjob.cloud.scheduler.state.failover.FailoverService" level="OFF" />
+    <logger name="org.apache.shardingsphere.elasticjob.cloud.scheduler.mesos.SchedulerEngine" level="OFF" />
+    <logger name="org.apache.shardingsphere.elasticjob.cloud.scheduler.state.ready.ReadyService" level="OFF" />
+    <logger name="org.apache.shardingsphere.elasticjob.cloud.scheduler.state.failover.FailoverService" level="OFF" />
 </configuration>