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/21 04:27:05 UTC

[shardingsphere-elasticjob-lite] branch master updated: Rename example package to asf (#801)

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-elasticjob-lite.git


The following commit(s) were added to refs/heads/master by this push:
     new b710339  Rename example package to asf (#801)
b710339 is described below

commit b7103396ea0671af46341c3b4a984ad980dc28ac
Author: Liang Zhang <te...@163.com>
AuthorDate: Sun Jun 21 12:26:57 2020 +0800

    Rename example package to asf (#801)
---
 .../lite}/example/EmbedZookeeperServer.java        | 16 ++++++++--------
 .../lite}/example/fixture/entity/Foo.java          | 16 ++++++++--------
 .../example/fixture/repository/FooRepository.java  | 18 +++++++++---------
 .../fixture/repository/FooRepositoryFactory.java   | 17 ++++++++---------
 .../example/job/dataflow/JavaDataflowJob.java      | 22 +++++++++++-----------
 .../example/job/dataflow/SpringDataflowJob.java    | 20 ++++++++++----------
 .../lite}/example/job/simple/JavaSimpleJob.java    | 22 +++++++++++-----------
 .../lite}/example/job/simple/SpringSimpleJob.java  | 20 ++++++++++----------
 .../elasticjob/lite}/example/JavaMain.java         | 20 ++++++++++----------
 .../elasticjob/lite}/example/SpringMain.java       | 16 ++++++++--------
 .../main/resources/META-INF/applicationContext.xml | 21 ++++++++++++---------
 .../src/main/resources/conf/job.properties         |  6 ++----
 .../elasticjob/lite}/example/SpringBootMain.java   | 16 ++++++++--------
 .../lite}/example/config/DataflowJobConfig.java    | 18 +++++++++---------
 .../lite}/example/config/JobEventConfig.java       | 16 ++++++++--------
 .../lite}/example/config/RegistryCenterConfig.java | 16 ++++++++--------
 .../lite}/example/config/SimpleJobConfig.java      | 18 +++++++++---------
 17 files changed, 149 insertions(+), 149 deletions(-)

diff --git a/examples/elastic-job-example-embed-zk/src/main/java/com/dangdang/ddframe/job/example/EmbedZookeeperServer.java b/examples/elastic-job-example-embed-zk/src/main/java/org/apache/shardingsphere/elasticjob/lite/example/EmbedZookeeperServer.java
similarity index 75%
rename from examples/elastic-job-example-embed-zk/src/main/java/com/dangdang/ddframe/job/example/EmbedZookeeperServer.java
rename to examples/elastic-job-example-embed-zk/src/main/java/org/apache/shardingsphere/elasticjob/lite/example/EmbedZookeeperServer.java
index 318e9a8..931a7ba 100644
--- a/examples/elastic-job-example-embed-zk/src/main/java/com/dangdang/ddframe/job/example/EmbedZookeeperServer.java
+++ b/examples/elastic-job-example-embed-zk/src/main/java/org/apache/shardingsphere/elasticjob/lite/example/EmbedZookeeperServer.java
@@ -1,21 +1,21 @@
 /*
- * Copyright 1999-2015 dangdang.com.
- * <p>
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
  *
  *     http://www.apache.org/licenses/LICENSE-2.0
- *
+ *  
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,
  * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
  * See the License for the specific language governing permissions and
  * limitations under the License.
- * </p>
  */
 
-package com.dangdang.ddframe.job.example;
+package org.apache.shardingsphere.elasticjob.lite.example;
 
 import org.apache.curator.test.TestingServer;
 
diff --git a/examples/elastic-job-example-jobs/src/main/java/com/dangdang/ddframe/job/example/fixture/entity/Foo.java b/examples/elastic-job-example-jobs/src/main/java/org/apache/shardingsphere/elasticjob/lite/example/fixture/entity/Foo.java
similarity index 72%
rename from examples/elastic-job-example-jobs/src/main/java/com/dangdang/ddframe/job/example/fixture/entity/Foo.java
rename to examples/elastic-job-example-jobs/src/main/java/org/apache/shardingsphere/elasticjob/lite/example/fixture/entity/Foo.java
index 4acdfb6..67c8ffd 100644
--- a/examples/elastic-job-example-jobs/src/main/java/com/dangdang/ddframe/job/example/fixture/entity/Foo.java
+++ b/examples/elastic-job-example-jobs/src/main/java/org/apache/shardingsphere/elasticjob/lite/example/fixture/entity/Foo.java
@@ -1,21 +1,21 @@
 /*
- * Copyright 1999-2015 dangdang.com.
- * <p>
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
  *
  *     http://www.apache.org/licenses/LICENSE-2.0
- *
+ *  
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,
  * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
  * See the License for the specific language governing permissions and
  * limitations under the License.
- * </p>
  */
 
-package com.dangdang.ddframe.job.example.fixture.entity;
+package org.apache.shardingsphere.elasticjob.lite.example.fixture.entity;
 
 import java.io.Serializable;
 
diff --git a/examples/elastic-job-example-jobs/src/main/java/com/dangdang/ddframe/job/example/fixture/repository/FooRepository.java b/examples/elastic-job-example-jobs/src/main/java/org/apache/shardingsphere/elasticjob/lite/example/fixture/repository/FooRepository.java
similarity index 75%
rename from examples/elastic-job-example-jobs/src/main/java/com/dangdang/ddframe/job/example/fixture/repository/FooRepository.java
rename to examples/elastic-job-example-jobs/src/main/java/org/apache/shardingsphere/elasticjob/lite/example/fixture/repository/FooRepository.java
index 2ce4577..163e53e 100644
--- a/examples/elastic-job-example-jobs/src/main/java/com/dangdang/ddframe/job/example/fixture/repository/FooRepository.java
+++ b/examples/elastic-job-example-jobs/src/main/java/org/apache/shardingsphere/elasticjob/lite/example/fixture/repository/FooRepository.java
@@ -1,23 +1,23 @@
 /*
- * Copyright 1999-2015 dangdang.com.
- * <p>
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
  *
  *     http://www.apache.org/licenses/LICENSE-2.0
- *
+ *  
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,
  * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
  * See the License for the specific language governing permissions and
  * limitations under the License.
- * </p>
  */
 
-package com.dangdang.ddframe.job.example.fixture.repository;
+package org.apache.shardingsphere.elasticjob.lite.example.fixture.repository;
 
-import com.dangdang.ddframe.job.example.fixture.entity.Foo;
+import org.apache.shardingsphere.elasticjob.lite.example.fixture.entity.Foo;
 import org.springframework.stereotype.Repository;
 
 import java.util.ArrayList;
diff --git a/examples/elastic-job-example-jobs/src/main/java/com/dangdang/ddframe/job/example/fixture/repository/FooRepositoryFactory.java b/examples/elastic-job-example-jobs/src/main/java/org/apache/shardingsphere/elasticjob/lite/example/fixture/repository/FooRepositoryFactory.java
similarity index 54%
rename from examples/elastic-job-example-jobs/src/main/java/com/dangdang/ddframe/job/example/fixture/repository/FooRepositoryFactory.java
rename to examples/elastic-job-example-jobs/src/main/java/org/apache/shardingsphere/elasticjob/lite/example/fixture/repository/FooRepositoryFactory.java
index fd47341..ae5d75e 100644
--- a/examples/elastic-job-example-jobs/src/main/java/com/dangdang/ddframe/job/example/fixture/repository/FooRepositoryFactory.java
+++ b/examples/elastic-job-example-jobs/src/main/java/org/apache/shardingsphere/elasticjob/lite/example/fixture/repository/FooRepositoryFactory.java
@@ -1,21 +1,21 @@
 /*
- * Copyright 1999-2015 dangdang.com.
- * <p>
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
  *
  *     http://www.apache.org/licenses/LICENSE-2.0
- *
+ *  
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,
  * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
  * See the License for the specific language governing permissions and
  * limitations under the License.
- * </p>
  */
 
-package com.dangdang.ddframe.job.example.fixture.repository;
+package org.apache.shardingsphere.elasticjob.lite.example.fixture.repository;
 
 public final class FooRepositoryFactory {
     
@@ -24,5 +24,4 @@ public final class FooRepositoryFactory {
     public static FooRepository getFooRepository() {
         return fooRepository;
     }
-    
 }
diff --git a/examples/elastic-job-example-jobs/src/main/java/com/dangdang/ddframe/job/example/job/dataflow/JavaDataflowJob.java b/examples/elastic-job-example-jobs/src/main/java/org/apache/shardingsphere/elasticjob/lite/example/job/dataflow/JavaDataflowJob.java
similarity index 68%
rename from examples/elastic-job-example-jobs/src/main/java/com/dangdang/ddframe/job/example/job/dataflow/JavaDataflowJob.java
rename to examples/elastic-job-example-jobs/src/main/java/org/apache/shardingsphere/elasticjob/lite/example/job/dataflow/JavaDataflowJob.java
index 78b08f9..43903a9 100644
--- a/examples/elastic-job-example-jobs/src/main/java/com/dangdang/ddframe/job/example/job/dataflow/JavaDataflowJob.java
+++ b/examples/elastic-job-example-jobs/src/main/java/org/apache/shardingsphere/elasticjob/lite/example/job/dataflow/JavaDataflowJob.java
@@ -1,27 +1,27 @@
 /*
- * Copyright 1999-2015 dangdang.com.
- * <p>
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
  *
  *     http://www.apache.org/licenses/LICENSE-2.0
- *
+ *  
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,
  * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
  * See the License for the specific language governing permissions and
  * limitations under the License.
- * </p>
  */
 
-package com.dangdang.ddframe.job.example.job.dataflow;
+package org.apache.shardingsphere.elasticjob.lite.example.job.dataflow;
 
-import com.dangdang.ddframe.job.example.fixture.entity.Foo;
-import com.dangdang.ddframe.job.example.fixture.repository.FooRepository;
-import com.dangdang.ddframe.job.example.fixture.repository.FooRepositoryFactory;
 import org.apache.shardingsphere.elasticjob.lite.api.ShardingContext;
 import org.apache.shardingsphere.elasticjob.lite.api.dataflow.DataflowJob;
+import org.apache.shardingsphere.elasticjob.lite.example.fixture.entity.Foo;
+import org.apache.shardingsphere.elasticjob.lite.example.fixture.repository.FooRepository;
+import org.apache.shardingsphere.elasticjob.lite.example.fixture.repository.FooRepositoryFactory;
 
 import java.text.SimpleDateFormat;
 import java.util.Date;
diff --git a/examples/elastic-job-example-jobs/src/main/java/com/dangdang/ddframe/job/example/job/dataflow/SpringDataflowJob.java b/examples/elastic-job-example-jobs/src/main/java/org/apache/shardingsphere/elasticjob/lite/example/job/dataflow/SpringDataflowJob.java
similarity index 71%
rename from examples/elastic-job-example-jobs/src/main/java/com/dangdang/ddframe/job/example/job/dataflow/SpringDataflowJob.java
rename to examples/elastic-job-example-jobs/src/main/java/org/apache/shardingsphere/elasticjob/lite/example/job/dataflow/SpringDataflowJob.java
index 5cff556..082b4a6 100644
--- a/examples/elastic-job-example-jobs/src/main/java/com/dangdang/ddframe/job/example/job/dataflow/SpringDataflowJob.java
+++ b/examples/elastic-job-example-jobs/src/main/java/org/apache/shardingsphere/elasticjob/lite/example/job/dataflow/SpringDataflowJob.java
@@ -1,26 +1,26 @@
 /*
- * Copyright 1999-2015 dangdang.com.
- * <p>
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
  *
  *     http://www.apache.org/licenses/LICENSE-2.0
- *
+ *  
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,
  * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
  * See the License for the specific language governing permissions and
  * limitations under the License.
- * </p>
  */
 
-package com.dangdang.ddframe.job.example.job.dataflow;
+package org.apache.shardingsphere.elasticjob.lite.example.job.dataflow;
 
-import com.dangdang.ddframe.job.example.fixture.entity.Foo;
-import com.dangdang.ddframe.job.example.fixture.repository.FooRepository;
 import org.apache.shardingsphere.elasticjob.lite.api.ShardingContext;
 import org.apache.shardingsphere.elasticjob.lite.api.dataflow.DataflowJob;
+import org.apache.shardingsphere.elasticjob.lite.example.fixture.entity.Foo;
+import org.apache.shardingsphere.elasticjob.lite.example.fixture.repository.FooRepository;
 
 import javax.annotation.Resource;
 import java.text.SimpleDateFormat;
diff --git a/examples/elastic-job-example-jobs/src/main/java/com/dangdang/ddframe/job/example/job/simple/JavaSimpleJob.java b/examples/elastic-job-example-jobs/src/main/java/org/apache/shardingsphere/elasticjob/lite/example/job/simple/JavaSimpleJob.java
similarity index 62%
rename from examples/elastic-job-example-jobs/src/main/java/com/dangdang/ddframe/job/example/job/simple/JavaSimpleJob.java
rename to examples/elastic-job-example-jobs/src/main/java/org/apache/shardingsphere/elasticjob/lite/example/job/simple/JavaSimpleJob.java
index 0663bd4..d5aed69 100644
--- a/examples/elastic-job-example-jobs/src/main/java/com/dangdang/ddframe/job/example/job/simple/JavaSimpleJob.java
+++ b/examples/elastic-job-example-jobs/src/main/java/org/apache/shardingsphere/elasticjob/lite/example/job/simple/JavaSimpleJob.java
@@ -1,27 +1,27 @@
 /*
- * Copyright 1999-2015 dangdang.com.
- * <p>
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
  *
  *     http://www.apache.org/licenses/LICENSE-2.0
- *
+ *  
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,
  * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
  * See the License for the specific language governing permissions and
  * limitations under the License.
- * </p>
  */
 
-package com.dangdang.ddframe.job.example.job.simple;
+package org.apache.shardingsphere.elasticjob.lite.example.job.simple;
 
-import com.dangdang.ddframe.job.example.fixture.entity.Foo;
-import com.dangdang.ddframe.job.example.fixture.repository.FooRepository;
-import com.dangdang.ddframe.job.example.fixture.repository.FooRepositoryFactory;
 import org.apache.shardingsphere.elasticjob.lite.api.ShardingContext;
 import org.apache.shardingsphere.elasticjob.lite.api.simple.SimpleJob;
+import org.apache.shardingsphere.elasticjob.lite.example.fixture.entity.Foo;
+import org.apache.shardingsphere.elasticjob.lite.example.fixture.repository.FooRepository;
+import org.apache.shardingsphere.elasticjob.lite.example.fixture.repository.FooRepositoryFactory;
 
 import java.text.SimpleDateFormat;
 import java.util.Date;
diff --git a/examples/elastic-job-example-jobs/src/main/java/com/dangdang/ddframe/job/example/job/simple/SpringSimpleJob.java b/examples/elastic-job-example-jobs/src/main/java/org/apache/shardingsphere/elasticjob/lite/example/job/simple/SpringSimpleJob.java
similarity index 65%
rename from examples/elastic-job-example-jobs/src/main/java/com/dangdang/ddframe/job/example/job/simple/SpringSimpleJob.java
rename to examples/elastic-job-example-jobs/src/main/java/org/apache/shardingsphere/elasticjob/lite/example/job/simple/SpringSimpleJob.java
index bf1cc52..4b4ae64 100644
--- a/examples/elastic-job-example-jobs/src/main/java/com/dangdang/ddframe/job/example/job/simple/SpringSimpleJob.java
+++ b/examples/elastic-job-example-jobs/src/main/java/org/apache/shardingsphere/elasticjob/lite/example/job/simple/SpringSimpleJob.java
@@ -1,26 +1,26 @@
 /*
- * Copyright 1999-2015 dangdang.com.
- * <p>
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
  *
  *     http://www.apache.org/licenses/LICENSE-2.0
- *
+ *  
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,
  * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
  * See the License for the specific language governing permissions and
  * limitations under the License.
- * </p>
  */
 
-package com.dangdang.ddframe.job.example.job.simple;
+package org.apache.shardingsphere.elasticjob.lite.example.job.simple;
 
-import com.dangdang.ddframe.job.example.fixture.entity.Foo;
-import com.dangdang.ddframe.job.example.fixture.repository.FooRepository;
 import org.apache.shardingsphere.elasticjob.lite.api.ShardingContext;
 import org.apache.shardingsphere.elasticjob.lite.api.simple.SimpleJob;
+import org.apache.shardingsphere.elasticjob.lite.example.fixture.entity.Foo;
+import org.apache.shardingsphere.elasticjob.lite.example.fixture.repository.FooRepository;
 
 import javax.annotation.Resource;
 import java.text.SimpleDateFormat;
diff --git a/examples/elastic-job-example-lite-java/src/main/java/com/dangdang/ddframe/job/example/JavaMain.java b/examples/elastic-job-example-lite-java/src/main/java/org/apache/shardingsphere/elasticjob/lite/example/JavaMain.java
similarity index 89%
rename from examples/elastic-job-example-lite-java/src/main/java/com/dangdang/ddframe/job/example/JavaMain.java
rename to examples/elastic-job-example-lite-java/src/main/java/org/apache/shardingsphere/elasticjob/lite/example/JavaMain.java
index d65458d..6ed4e97 100644
--- a/examples/elastic-job-example-lite-java/src/main/java/com/dangdang/ddframe/job/example/JavaMain.java
+++ b/examples/elastic-job-example-lite-java/src/main/java/org/apache/shardingsphere/elasticjob/lite/example/JavaMain.java
@@ -1,24 +1,22 @@
 /*
- * Copyright 1999-2015 dangdang.com.
- * <p>
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
  *
  *     http://www.apache.org/licenses/LICENSE-2.0
- *
+ *  
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,
  * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
  * See the License for the specific language governing permissions and
  * limitations under the License.
- * </p>
  */
 
-package com.dangdang.ddframe.job.example;
+package org.apache.shardingsphere.elasticjob.lite.example;
 
-import com.dangdang.ddframe.job.example.job.dataflow.JavaDataflowJob;
-import com.dangdang.ddframe.job.example.job.simple.JavaSimpleJob;
 import org.apache.commons.dbcp.BasicDataSource;
 import org.apache.shardingsphere.elasticjob.lite.api.JobScheduler;
 import org.apache.shardingsphere.elasticjob.lite.config.JobCoreConfiguration;
@@ -28,6 +26,8 @@ import org.apache.shardingsphere.elasticjob.lite.config.script.ScriptJobConfigur
 import org.apache.shardingsphere.elasticjob.lite.config.simple.SimpleJobConfiguration;
 import org.apache.shardingsphere.elasticjob.lite.event.JobEventConfiguration;
 import org.apache.shardingsphere.elasticjob.lite.event.rdb.JobEventRdbConfiguration;
+import org.apache.shardingsphere.elasticjob.lite.example.job.dataflow.JavaDataflowJob;
+import org.apache.shardingsphere.elasticjob.lite.example.job.simple.JavaSimpleJob;
 import org.apache.shardingsphere.elasticjob.lite.reg.base.CoordinatorRegistryCenter;
 import org.apache.shardingsphere.elasticjob.lite.reg.zookeeper.ZookeeperConfiguration;
 import org.apache.shardingsphere.elasticjob.lite.reg.zookeeper.ZookeeperRegistryCenter;
diff --git a/examples/elastic-job-example-lite-spring/src/main/java/com/dangdang/ddframe/job/example/SpringMain.java b/examples/elastic-job-example-lite-spring/src/main/java/org/apache/shardingsphere/elasticjob/lite/example/SpringMain.java
similarity index 62%
rename from examples/elastic-job-example-lite-spring/src/main/java/com/dangdang/ddframe/job/example/SpringMain.java
rename to examples/elastic-job-example-lite-spring/src/main/java/org/apache/shardingsphere/elasticjob/lite/example/SpringMain.java
index a0ce284..05a75f8 100644
--- a/examples/elastic-job-example-lite-spring/src/main/java/com/dangdang/ddframe/job/example/SpringMain.java
+++ b/examples/elastic-job-example-lite-spring/src/main/java/org/apache/shardingsphere/elasticjob/lite/example/SpringMain.java
@@ -1,21 +1,21 @@
 /*
- * Copyright 1999-2015 dangdang.com.
- * <p>
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
  *
  *     http://www.apache.org/licenses/LICENSE-2.0
- *
+ *  
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,
  * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
  * See the License for the specific language governing permissions and
  * limitations under the License.
- * </p>
  */
 
-package com.dangdang.ddframe.job.example;
+package org.apache.shardingsphere.elasticjob.lite.example;
 
 import org.springframework.context.support.ClassPathXmlApplicationContext;
 
diff --git a/examples/elastic-job-example-lite-spring/src/main/resources/META-INF/applicationContext.xml b/examples/elastic-job-example-lite-spring/src/main/resources/META-INF/applicationContext.xml
index 0705947..401681e 100644
--- a/examples/elastic-job-example-lite-spring/src/main/resources/META-INF/applicationContext.xml
+++ b/examples/elastic-job-example-lite-spring/src/main/resources/META-INF/applicationContext.xml
@@ -2,18 +2,18 @@
 <beans xmlns="http://www.springframework.org/schema/beans"
     xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
     xmlns:context="http://www.springframework.org/schema/context" 
-    xmlns:reg="http://www.dangdang.com/schema/ddframe/reg" 
-    xmlns:job="http://www.dangdang.com/schema/ddframe/job" 
+    xmlns:reg="http://elasticjob.shardingsphere.apache.org/schema/reg" 
+    xmlns:job="http://elasticjob.shardingsphere.apache.org/schema/job" 
     xsi:schemaLocation="http://www.springframework.org/schema/beans 
                         http://www.springframework.org/schema/beans/spring-beans.xsd 
                         http://www.springframework.org/schema/context 
                         http://www.springframework.org/schema/context/spring-context.xsd 
-                        http://www.dangdang.com/schema/ddframe/reg 
-                        http://www.dangdang.com/schema/ddframe/reg/reg.xsd 
-                        http://www.dangdang.com/schema/ddframe/job 
-                        http://www.dangdang.com/schema/ddframe/job/job.xsd 
+                        http://elasticjob.shardingsphere.apache.org/schema/reg
+                        http://elasticjob.shardingsphere.apache.org/schema/reg.xsd
+                        http://elasticjob.shardingsphere.apache.org/schema/job
+                        http://elasticjob.shardingsphere.apache.org/schema/job.xsd
                         ">
-    <context:component-scan base-package="com.dangdang.ddframe.job.example" />
+    <context:component-scan base-package="org.apache.shardingsphere.elasticjob.lite.example" />
     <context:property-placeholder location="classpath:conf/*.properties" />
     
     <bean id="elasticJobLog" class="org.apache.commons.dbcp.BasicDataSource" destroy-method="close">
@@ -24,9 +24,12 @@
     </bean>
     
     <reg:zookeeper id="regCenter" server-lists="${serverLists}" namespace="${namespace}" base-sleep-time-milliseconds="${baseSleepTimeMilliseconds}" max-sleep-time-milliseconds="${maxSleepTimeMilliseconds}" max-retries="${maxRetries}" />
+
+    <bean id="simpleJob" class="org.apache.shardingsphere.elasticjob.lite.example.job.simple.SpringSimpleJob" />
+    <bean id="dataflowJob" class="org.apache.shardingsphere.elasticjob.lite.example.job.dataflow.SpringDataflowJob" />
     
-    <job:simple id="${simple.id}" class="${simple.class}" registry-center-ref="regCenter" sharding-total-count="${simple.shardingTotalCount}" cron="${simple.cron}" sharding-item-parameters="${simple.shardingItemParameters}" monitor-execution="${simple.monitorExecution}" monitor-port="${simple.monitorPort}" failover="${simple.failover}" description="${simple.description}" disabled="${simple.disabled}" overwrite="${simple.overwrite}" event-trace-rdb-data-source="elasticJobLog" />
-    <job:dataflow id="${dataflow.id}" class="${dataflow.class}" registry-center-ref="regCenter" sharding-total-count="${dataflow.shardingTotalCount}" cron="${dataflow.cron}" sharding-item-parameters="${dataflow.shardingItemParameters}" monitor-execution="${dataflow.monitorExecution}" failover="${dataflow.failover}" max-time-diff-seconds="${dataflow.maxTimeDiffSeconds}" streaming-process="${dataflow.streamingProcess}" description="${dataflow.description}" disabled="${dataflow.disabled}" o [...]
+    <job:simple id="${simple.id}" job-ref="simpleJob" registry-center-ref="regCenter" sharding-total-count="${simple.shardingTotalCount}" cron="${simple.cron}" sharding-item-parameters="${simple.shardingItemParameters}" monitor-execution="${simple.monitorExecution}" monitor-port="${simple.monitorPort}" failover="${simple.failover}" description="${simple.description}" disabled="${simple.disabled}" overwrite="${simple.overwrite}" event-trace-rdb-data-source="elasticJobLog" />
+    <job:dataflow id="${dataflow.id}" job-ref="dataflowJob" registry-center-ref="regCenter" sharding-total-count="${dataflow.shardingTotalCount}" cron="${dataflow.cron}" sharding-item-parameters="${dataflow.shardingItemParameters}" monitor-execution="${dataflow.monitorExecution}" failover="${dataflow.failover}" max-time-diff-seconds="${dataflow.maxTimeDiffSeconds}" streaming-process="${dataflow.streamingProcess}" description="${dataflow.description}" disabled="${dataflow.disabled}" overw [...]
     
     <!-- use absolute path to run script job -->
     <!--
diff --git a/examples/elastic-job-example-lite-spring/src/main/resources/conf/job.properties b/examples/elastic-job-example-lite-spring/src/main/resources/conf/job.properties
index 023f53e..f186836 100644
--- a/examples/elastic-job-example-lite-spring/src/main/resources/conf/job.properties
+++ b/examples/elastic-job-example-lite-spring/src/main/resources/conf/job.properties
@@ -3,13 +3,12 @@ event.rdb.url=jdbc:h2:mem:job_event_storage
 event.rdb.username=sa
 event.rdb.password=
 
-listener.simple=com.dangdang.ddframe.job.example.listener.SpringSimpleListener
-listener.distributed=com.dangdang.ddframe.job.example.listener.SpringSimpleDistributeListener
+listener.simple=org.apache.shardingsphere.elasticjob.lite.example.listener.SpringSimpleListener
+listener.distributed=org.apache.shardingsphere.elasticjob.lite.example.listener.SpringSimpleDistributeListener
 listener.distributed.startedTimeoutMilliseconds=1000
 listener.distributed.completedTimeoutMilliseconds=3000
 
 simple.id=springSimpleJob
-simple.class=com.dangdang.ddframe.job.example.job.simple.SpringSimpleJob
 simple.cron=0/5 * * * * ?
 simple.shardingTotalCount=3
 simple.shardingItemParameters=0=Beijing,1=Shanghai,2=Guangzhou
@@ -21,7 +20,6 @@ simple.overwrite=true
 simple.monitorPort=9888
 
 dataflow.id=springDataflowJob
-dataflow.class=com.dangdang.ddframe.job.example.job.dataflow.SpringDataflowJob
 dataflow.cron=0/5 * * * * ?
 dataflow.shardingTotalCount=3
 dataflow.shardingItemParameters=0=Beijing,1=Shanghai,2=Guangzhou
diff --git a/examples/elastic-job-example-lite-springboot/src/main/java/com/dangdang/ddframe/job/example/SpringBootMain.java b/examples/elastic-job-example-lite-springboot/src/main/java/org/apache/shardingsphere/elasticjob/lite/example/SpringBootMain.java
similarity index 61%
rename from examples/elastic-job-example-lite-springboot/src/main/java/com/dangdang/ddframe/job/example/SpringBootMain.java
rename to examples/elastic-job-example-lite-springboot/src/main/java/org/apache/shardingsphere/elasticjob/lite/example/SpringBootMain.java
index 81f404b..0cbdca2 100644
--- a/examples/elastic-job-example-lite-springboot/src/main/java/com/dangdang/ddframe/job/example/SpringBootMain.java
+++ b/examples/elastic-job-example-lite-springboot/src/main/java/org/apache/shardingsphere/elasticjob/lite/example/SpringBootMain.java
@@ -1,21 +1,21 @@
 /*
- * Copyright 1999-2015 dangdang.com.
- * <p>
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
  *
  *     http://www.apache.org/licenses/LICENSE-2.0
- *
+ *  
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,
  * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
  * See the License for the specific language governing permissions and
  * limitations under the License.
- * </p>
  */
 
-package com.dangdang.ddframe.job.example;
+package org.apache.shardingsphere.elasticjob.lite.example;
 
 import org.springframework.boot.SpringApplication;
 import org.springframework.boot.autoconfigure.SpringBootApplication;
diff --git a/examples/elastic-job-example-lite-springboot/src/main/java/com/dangdang/ddframe/job/example/config/DataflowJobConfig.java b/examples/elastic-job-example-lite-springboot/src/main/java/org/apache/shardingsphere/elasticjob/lite/example/config/DataflowJobConfig.java
similarity index 81%
rename from examples/elastic-job-example-lite-springboot/src/main/java/com/dangdang/ddframe/job/example/config/DataflowJobConfig.java
rename to examples/elastic-job-example-lite-springboot/src/main/java/org/apache/shardingsphere/elasticjob/lite/example/config/DataflowJobConfig.java
index c6c39f4..5a85f36 100644
--- a/examples/elastic-job-example-lite-springboot/src/main/java/com/dangdang/ddframe/job/example/config/DataflowJobConfig.java
+++ b/examples/elastic-job-example-lite-springboot/src/main/java/org/apache/shardingsphere/elasticjob/lite/example/config/DataflowJobConfig.java
@@ -1,29 +1,29 @@
 /*
- * Copyright 1999-2015 dangdang.com.
- * <p>
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
  *
  *     http://www.apache.org/licenses/LICENSE-2.0
- *
+ *  
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,
  * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
  * See the License for the specific language governing permissions and
  * limitations under the License.
- * </p>
  */
 
-package com.dangdang.ddframe.job.example.config;
+package org.apache.shardingsphere.elasticjob.lite.example.config;
 
-import com.dangdang.ddframe.job.example.job.dataflow.SpringDataflowJob;
 import org.apache.shardingsphere.elasticjob.lite.api.JobScheduler;
 import org.apache.shardingsphere.elasticjob.lite.api.dataflow.DataflowJob;
 import org.apache.shardingsphere.elasticjob.lite.config.JobCoreConfiguration;
 import org.apache.shardingsphere.elasticjob.lite.config.LiteJobConfiguration;
 import org.apache.shardingsphere.elasticjob.lite.config.dataflow.DataflowJobConfiguration;
 import org.apache.shardingsphere.elasticjob.lite.event.JobEventConfiguration;
+import org.apache.shardingsphere.elasticjob.lite.example.job.dataflow.SpringDataflowJob;
 import org.apache.shardingsphere.elasticjob.lite.reg.zookeeper.ZookeeperRegistryCenter;
 import org.springframework.beans.factory.annotation.Value;
 import org.springframework.context.annotation.Bean;
diff --git a/examples/elastic-job-example-lite-springboot/src/main/java/com/dangdang/ddframe/job/example/config/JobEventConfig.java b/examples/elastic-job-example-lite-springboot/src/main/java/org/apache/shardingsphere/elasticjob/lite/example/config/JobEventConfig.java
similarity index 66%
rename from examples/elastic-job-example-lite-springboot/src/main/java/com/dangdang/ddframe/job/example/config/JobEventConfig.java
rename to examples/elastic-job-example-lite-springboot/src/main/java/org/apache/shardingsphere/elasticjob/lite/example/config/JobEventConfig.java
index 0eb87ec..8c08de9 100644
--- a/examples/elastic-job-example-lite-springboot/src/main/java/com/dangdang/ddframe/job/example/config/JobEventConfig.java
+++ b/examples/elastic-job-example-lite-springboot/src/main/java/org/apache/shardingsphere/elasticjob/lite/example/config/JobEventConfig.java
@@ -1,21 +1,21 @@
 /*
- * Copyright 1999-2015 dangdang.com.
- * <p>
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
  *
  *     http://www.apache.org/licenses/LICENSE-2.0
- *
+ *  
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,
  * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
  * See the License for the specific language governing permissions and
  * limitations under the License.
- * </p>
  */
 
-package com.dangdang.ddframe.job.example.config;
+package org.apache.shardingsphere.elasticjob.lite.example.config;
 
 import org.apache.shardingsphere.elasticjob.lite.event.JobEventConfiguration;
 import org.apache.shardingsphere.elasticjob.lite.event.rdb.JobEventRdbConfiguration;
diff --git a/examples/elastic-job-example-lite-springboot/src/main/java/com/dangdang/ddframe/job/example/config/RegistryCenterConfig.java b/examples/elastic-job-example-lite-springboot/src/main/java/org/apache/shardingsphere/elasticjob/lite/example/config/RegistryCenterConfig.java
similarity index 71%
rename from examples/elastic-job-example-lite-springboot/src/main/java/com/dangdang/ddframe/job/example/config/RegistryCenterConfig.java
rename to examples/elastic-job-example-lite-springboot/src/main/java/org/apache/shardingsphere/elasticjob/lite/example/config/RegistryCenterConfig.java
index 992dace..4aa6c90 100644
--- a/examples/elastic-job-example-lite-springboot/src/main/java/com/dangdang/ddframe/job/example/config/RegistryCenterConfig.java
+++ b/examples/elastic-job-example-lite-springboot/src/main/java/org/apache/shardingsphere/elasticjob/lite/example/config/RegistryCenterConfig.java
@@ -1,21 +1,21 @@
 /*
- * Copyright 1999-2015 dangdang.com.
- * <p>
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
  *
  *     http://www.apache.org/licenses/LICENSE-2.0
- *
+ *  
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,
  * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
  * See the License for the specific language governing permissions and
  * limitations under the License.
- * </p>
  */
 
-package com.dangdang.ddframe.job.example.config;
+package org.apache.shardingsphere.elasticjob.lite.example.config;
 
 import org.apache.shardingsphere.elasticjob.lite.reg.zookeeper.ZookeeperConfiguration;
 import org.apache.shardingsphere.elasticjob.lite.reg.zookeeper.ZookeeperRegistryCenter;
diff --git a/examples/elastic-job-example-lite-springboot/src/main/java/com/dangdang/ddframe/job/example/config/SimpleJobConfig.java b/examples/elastic-job-example-lite-springboot/src/main/java/org/apache/shardingsphere/elasticjob/lite/example/config/SimpleJobConfig.java
similarity index 80%
rename from examples/elastic-job-example-lite-springboot/src/main/java/com/dangdang/ddframe/job/example/config/SimpleJobConfig.java
rename to examples/elastic-job-example-lite-springboot/src/main/java/org/apache/shardingsphere/elasticjob/lite/example/config/SimpleJobConfig.java
index 07bd6b4..41757f9 100644
--- a/examples/elastic-job-example-lite-springboot/src/main/java/com/dangdang/ddframe/job/example/config/SimpleJobConfig.java
+++ b/examples/elastic-job-example-lite-springboot/src/main/java/org/apache/shardingsphere/elasticjob/lite/example/config/SimpleJobConfig.java
@@ -1,29 +1,29 @@
 /*
- * Copyright 1999-2015 dangdang.com.
- * <p>
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
  *
  *     http://www.apache.org/licenses/LICENSE-2.0
- *
+ *  
  * Unless required by applicable law or agreed to in writing, software
  * distributed under the License is distributed on an "AS IS" BASIS,
  * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
  * See the License for the specific language governing permissions and
  * limitations under the License.
- * </p>
  */
 
-package com.dangdang.ddframe.job.example.config;
+package org.apache.shardingsphere.elasticjob.lite.example.config;
 
-import com.dangdang.ddframe.job.example.job.simple.SpringSimpleJob;
 import org.apache.shardingsphere.elasticjob.lite.api.JobScheduler;
 import org.apache.shardingsphere.elasticjob.lite.api.simple.SimpleJob;
 import org.apache.shardingsphere.elasticjob.lite.config.JobCoreConfiguration;
 import org.apache.shardingsphere.elasticjob.lite.config.LiteJobConfiguration;
 import org.apache.shardingsphere.elasticjob.lite.config.simple.SimpleJobConfiguration;
 import org.apache.shardingsphere.elasticjob.lite.event.JobEventConfiguration;
+import org.apache.shardingsphere.elasticjob.lite.example.job.simple.SpringSimpleJob;
 import org.apache.shardingsphere.elasticjob.lite.reg.zookeeper.ZookeeperRegistryCenter;
 import org.springframework.beans.factory.annotation.Value;
 import org.springframework.context.annotation.Bean;