You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@tajo.apache.org by hy...@apache.org on 2013/03/25 10:23:07 UTC

[07/12] TAJO-2: remove all @author tags and update license header (hyunsik)

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/BinaryNode.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/BinaryNode.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/BinaryNode.java
index c8d463e..b53259b 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/BinaryNode.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/BinaryNode.java
@@ -1,4 +1,22 @@
 /**
+ * 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.
+ */
+
+/**
  * 
  */
 package tajo.engine.planner.logical;
@@ -6,10 +24,6 @@ package tajo.engine.planner.logical;
 import com.google.gson.annotations.Expose;
 import tajo.engine.json.GsonCreator;
 
-/**
- * @author Hyunsik Choi
- *
- */
 public abstract class BinaryNode extends LogicalNode implements Cloneable {
 	@Expose
 	LogicalNode outer = null;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/CreateTableNode.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/CreateTableNode.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/CreateTableNode.java
index e4e3168..b95db6b 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/CreateTableNode.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/CreateTableNode.java
@@ -1,3 +1,21 @@
+/**
+ * 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.
+ */
+
 package tajo.engine.planner.logical;
 
 import com.google.gson.annotations.Expose;
@@ -9,9 +27,6 @@ import tajo.catalog.proto.CatalogProtos.StoreType;
 import tajo.engine.json.GsonCreator;
 import tajo.util.TUtil;
 
-/**
- * @author Hyunsik Choi
-*/
 public class CreateTableNode extends LogicalNode implements Cloneable {
   @Expose private String tableName;
   @Expose private Column[] partitionKeys;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/EvalExprNode.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/EvalExprNode.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/EvalExprNode.java
index 37a9dff..6934eaa 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/EvalExprNode.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/EvalExprNode.java
@@ -1,4 +1,22 @@
 /**
+ * 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.
+ */
+
+/**
  * 
  */
 package tajo.engine.planner.logical;
@@ -8,15 +26,9 @@ import com.google.gson.annotations.Expose;
 import tajo.engine.json.GsonCreator;
 import tajo.engine.parser.QueryBlock;
 
-/**
- * @author Hyunsik Choi
- */
 public class EvalExprNode extends LogicalNode {
   @Expose private QueryBlock.Target[] exprs;
-  
-  /**
-   * 
-   */
+
   public EvalExprNode(QueryBlock.Target[] exprs) {
     super(ExprType.EXPRS);
     this.exprs = exprs;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/ExceptNode.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/ExceptNode.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/ExceptNode.java
index d6b29ad..71d51e0 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/ExceptNode.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/ExceptNode.java
@@ -1,13 +1,28 @@
 /**
+ * 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.
+ */
+
+/**
  * 
  */
 package tajo.engine.planner.logical;
 
 import tajo.engine.json.GsonCreator;
 
-/**
- * @author Hyunsik Choi
- */
 public class ExceptNode extends BinaryNode {
 
   public ExceptNode() {

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/ExprType.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/ExprType.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/ExprType.java
index ca967b4..7caae3f 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/ExprType.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/ExprType.java
@@ -1,12 +1,26 @@
 /**
- * 
+ * 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.
  */
-package tajo.engine.planner.logical;
 
 /**
- * @author Hyunsik Choi
- *
+ * 
  */
+package tajo.engine.planner.logical;
+
 public enum ExprType {
   BST_INDEX_SCAN,
   CREATE_INDEX,

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/GroupbyNode.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/GroupbyNode.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/GroupbyNode.java
index 7e976c4..d037e3d 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/GroupbyNode.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/GroupbyNode.java
@@ -1,6 +1,4 @@
-/*
- * Copyright 2012 Database Lab., Korea Univ.
- *
+/**
  * 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
@@ -29,9 +27,6 @@ import tajo.util.TUtil;
 
 import java.util.Arrays;
 
-/** 
- * @author Hyunsik Choi
- */
 public class GroupbyNode extends UnaryNode implements Cloneable {
 	@Expose
 	private Column[] columns;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/IndexScanNode.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/IndexScanNode.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/IndexScanNode.java
index 7af29ef..899d4e3 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/IndexScanNode.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/IndexScanNode.java
@@ -1,3 +1,21 @@
+/**
+ * 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.
+ */
+
 package tajo.engine.planner.logical;
 
 import com.google.gson.Gson;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/IndexWriteNode.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/IndexWriteNode.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/IndexWriteNode.java
index 278f756..d049789 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/IndexWriteNode.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/IndexWriteNode.java
@@ -1,4 +1,22 @@
 /**
+ * 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.
+ */
+
+/**
  * 
  */
 package tajo.engine.planner.logical;
@@ -12,9 +30,6 @@ import tajo.catalog.proto.CatalogProtos.IndexMethod;
 import tajo.engine.json.GsonCreator;
 import tajo.engine.parser.CreateIndexStmt;
 
-/**
- * @author Hyunsik Choi
- */
 public class IndexWriteNode extends UnaryNode {
   @Expose private String indexName;
   @Expose private boolean unique = false;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/IntersectNode.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/IntersectNode.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/IntersectNode.java
index f7d3b0b..a3f1a7c 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/IntersectNode.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/IntersectNode.java
@@ -1,13 +1,28 @@
 /**
+ * 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.
+ */
+
+/**
  * 
  */
 package tajo.engine.planner.logical;
 
 import tajo.engine.json.GsonCreator;
 
-/**
- * @author Hyunsik Choi
- */
 public class IntersectNode extends BinaryNode {
 
   public IntersectNode() {

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/JoinNode.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/JoinNode.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/JoinNode.java
index 22093e5..4ecd011 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/JoinNode.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/JoinNode.java
@@ -1,6 +1,4 @@
-/*
- * Copyright 2012 Database Lab., Korea Univ.
- *
+/**
  * 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
@@ -29,10 +27,6 @@ import tajo.engine.json.GsonCreator;
 import tajo.engine.parser.QueryBlock;
 import tajo.engine.planner.JoinType;
 
-/**
- * @author Hyunsik Choi
- * 
- */
 public class JoinNode extends BinaryNode implements Cloneable {
   @Expose private JoinType joinType;
   @Expose private EvalNode joinQual;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/LimitNode.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/LimitNode.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/LimitNode.java
index a9343c1..2e36daf 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/LimitNode.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/LimitNode.java
@@ -1,9 +1,11 @@
-/*
- * Copyright 2012 Database Lab., Korea Univ.
- *
- * 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
  *
@@ -21,10 +23,6 @@ import tajo.engine.json.GsonCreator;
 import tajo.engine.parser.QueryBlock.LimitClause;
 import tajo.util.TUtil;
 
-/**
- * @author Hyunsik Choi
- *
- */
 public final class LimitNode extends UnaryNode implements Cloneable {
 	@Expose
   private LimitClause limitClause;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/LogicalNode.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/LogicalNode.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/LogicalNode.java
index 93accac..d18fc77 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/LogicalNode.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/LogicalNode.java
@@ -1,4 +1,22 @@
 /**
+ * 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.
+ */
+
+/**
  * 
  */
 package tajo.engine.planner.logical;
@@ -6,10 +24,6 @@ package tajo.engine.planner.logical;
 import com.google.gson.annotations.Expose;
 import tajo.catalog.Schema;
 
-/**
- * @author Hyunsik Choi
- *
- */
 public abstract class LogicalNode implements Cloneable {
 	@Expose
 	private ExprType type;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/LogicalNodeVisitor.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/LogicalNodeVisitor.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/LogicalNodeVisitor.java
index 7e2d085..0ee74c6 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/LogicalNodeVisitor.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/LogicalNodeVisitor.java
@@ -1,12 +1,27 @@
 /**
+ * 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.
+ */
+
+/**
  * 
  */
 package tajo.engine.planner.logical;
 
 
-/**
- * @author Hyunsik Choi
- */
-public interface LogicalNodeVisitor {  
+public interface LogicalNodeVisitor {
   void visit(LogicalNode node);
 }

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/LogicalRootNode.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/LogicalRootNode.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/LogicalRootNode.java
index 0e8160d..fdb7981 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/LogicalRootNode.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/LogicalRootNode.java
@@ -1,10 +1,25 @@
+/**
+ * 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.
+ */
+
 package tajo.engine.planner.logical;
 
 import tajo.engine.json.GsonCreator;
 
-/**
- * @author Hyunsik Choi
- */
 public class LogicalRootNode extends UnaryNode implements Cloneable {
   public LogicalRootNode() {
     super(ExprType.ROOT);

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/ProjectionNode.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/ProjectionNode.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/ProjectionNode.java
index 7a0c0cb..5683fe5 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/ProjectionNode.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/ProjectionNode.java
@@ -1,3 +1,21 @@
+/**
+ * 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.
+ */
+
 package tajo.engine.planner.logical;
 
 import com.google.gson.annotations.Expose;
@@ -6,11 +24,6 @@ import tajo.engine.parser.QueryBlock.Target;
 
 import java.util.Arrays;
 
-/**
- * 
- * @author Hyunsik Choi
- *
- */
 public class ProjectionNode extends UnaryNode {
   /**
    * the targets are always filled even if the query is 'select *'

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/ScanNode.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/ScanNode.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/ScanNode.java
index 12ac8fa..41fbb86 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/ScanNode.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/ScanNode.java
@@ -1,6 +1,4 @@
-/*
- * Copyright 2012 Database Lab., Korea Univ.
- *
+/**
  * 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

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/SelectionNode.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/SelectionNode.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/SelectionNode.java
index 9ce8c29..f115a20 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/SelectionNode.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/SelectionNode.java
@@ -1,6 +1,4 @@
-/*
- * Copyright 2012 Database Lab., Korea Univ.
- *
+/**
  * 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
@@ -24,11 +22,6 @@ import com.google.gson.annotations.Expose;
 import tajo.engine.eval.EvalNode;
 import tajo.engine.json.GsonCreator;
 
-/**
- * 
- * @author Hyunsik Choi
- *
- */
 public class SelectionNode extends UnaryNode implements Cloneable {
 
 	@Expose

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/SortNode.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/SortNode.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/SortNode.java
index f6e754e..f2dd2f0 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/SortNode.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/SortNode.java
@@ -1,9 +1,11 @@
-/*
- * Copyright 2012 Database Lab., Korea Univ.
- *
- * 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
  *
@@ -23,10 +25,6 @@ import tajo.catalog.SortSpec;
 import tajo.engine.json.GsonCreator;
 import tajo.util.TUtil;
 
-/**
- * @author Hyunsik Choi
- *
- */
 public final class SortNode extends UnaryNode implements Cloneable {
 	@Expose
   private SortSpec[] sortKeys;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/StoreIndexNode.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/StoreIndexNode.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/StoreIndexNode.java
index 38d1779..b7ec221 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/StoreIndexNode.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/StoreIndexNode.java
@@ -1,3 +1,21 @@
+/**
+ * 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.
+ */
+
 package tajo.engine.planner.logical;
 
 public class StoreIndexNode extends StoreTableNode {

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/StoreTableNode.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/StoreTableNode.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/StoreTableNode.java
index 0776bed..e185f93 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/StoreTableNode.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/StoreTableNode.java
@@ -1,3 +1,21 @@
+/**
+ * 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.
+ */
+
 package tajo.engine.planner.logical;
 
 import com.google.common.base.Preconditions;
@@ -9,10 +27,6 @@ import tajo.util.TUtil;
 
 import static tajo.catalog.proto.CatalogProtos.StoreType;
 
-/**
- * @author Hyunsik Choi
- * 
- */
 public class StoreTableNode extends UnaryNode implements Cloneable {
   @Expose private String tableName;
   @Expose private StoreType storageType = StoreType.CSV;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/UnaryNode.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/UnaryNode.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/UnaryNode.java
index 4d0d90e..8778d66 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/UnaryNode.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/UnaryNode.java
@@ -1,4 +1,22 @@
 /**
+ * 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.
+ */
+
+/**
  * 
  */
 package tajo.engine.planner.logical;
@@ -7,10 +25,6 @@ import com.google.gson.annotations.Expose;
 import tajo.engine.json.GsonCreator;
 
 
-/**
- * @author Hyunsik Choi
- *
- */
 public abstract class UnaryNode extends LogicalNode implements Cloneable {
 	@Expose
 	LogicalNode subExpr;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/UnionNode.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/UnionNode.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/UnionNode.java
index bbef6cc..42b03e2 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/UnionNode.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/UnionNode.java
@@ -1,13 +1,28 @@
 /**
+ * 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.
+ */
+
+/**
  * 
  */
 package tajo.engine.planner.logical;
 
 import tajo.engine.json.GsonCreator;
 
-/**
- * @author Hyunsik Choi
- */
 public class UnionNode extends BinaryNode {
 
   public UnionNode() {

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/extended/PipeType.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/extended/PipeType.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/extended/PipeType.java
index f8b8d6b..2594068 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/extended/PipeType.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/extended/PipeType.java
@@ -1,3 +1,21 @@
+/**
+ * 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.
+ */
+
 package tajo.engine.planner.logical.extended;
 
 public enum PipeType {

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/extended/ReceiveNode.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/extended/ReceiveNode.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/extended/ReceiveNode.java
index cc428a6..ffdb9e6 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/extended/ReceiveNode.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/extended/ReceiveNode.java
@@ -1,4 +1,22 @@
 /**
+ * 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.
+ */
+
+/**
  * 
  */
 package tajo.engine.planner.logical.extended;
@@ -18,9 +36,6 @@ import java.net.URI;
 import java.util.*;
 import java.util.Map.Entry;
 
-/**
- * @author Hyunsik Choi
- */
 public final class ReceiveNode extends LogicalNode implements Cloneable {
   @Expose private PipeType pipeType;
   @Expose private RepartitionType repaType;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/extended/RepartitionType.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/extended/RepartitionType.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/extended/RepartitionType.java
index 3986763..b494ea4 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/extended/RepartitionType.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/extended/RepartitionType.java
@@ -1,3 +1,21 @@
+/**
+ * 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.
+ */
+
 package tajo.engine.planner.logical.extended;
 
 public enum RepartitionType {

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/extended/SendNode.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/extended/SendNode.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/extended/SendNode.java
index d37a267..2b3fd55 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/extended/SendNode.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/extended/SendNode.java
@@ -1,4 +1,22 @@
 /**
+ * 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.
+ */
+
+/**
  * 
  */
 package tajo.engine.planner.logical.extended;
@@ -24,8 +42,6 @@ import java.util.Map.Entry;
 /**
  * This logical node means that the worker sends intermediate data to 
  * some destined one or more workers.
- * 
- * @author Hyunsik Choi
  */
 public class SendNode extends UnaryNode {
   @Expose private PipeType pipeType;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/join/Edge.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/join/Edge.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/join/Edge.java
index 70a7080..ac1bc23 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/join/Edge.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/join/Edge.java
@@ -1,6 +1,4 @@
-/*
- * Copyright 2012 Database Lab., Korea Univ.
- *
+/**
  * 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
@@ -22,9 +20,6 @@ package tajo.engine.planner.logical.join;
 
 import tajo.engine.eval.EvalNode;
 
-/**
- * @author
- */
 public class Edge {
   private String src;
   private String target;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/join/JoinTree.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/join/JoinTree.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/join/JoinTree.java
index 32bf54b..13a27ca 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/join/JoinTree.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/logical/join/JoinTree.java
@@ -1,6 +1,4 @@
-/*
- * Copyright 2012 Database Lab., Korea Univ.
- *
+/**
  * 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
@@ -31,9 +29,6 @@ import java.util.Collections;
 import java.util.List;
 import java.util.Map;
 
-/**
- * @author Hyunsik Choi
- */
 public class JoinTree {
   private Map<String,List<Edge>> map
       = Maps.newHashMap();

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/AggregationExec.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/AggregationExec.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/AggregationExec.java
index e0e1a91..5f1a04d 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/AggregationExec.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/AggregationExec.java
@@ -1,9 +1,11 @@
-/*
- * Copyright 2012 Database Lab., Korea Univ.
- *
- * 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
  *

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/BNLJoinExec.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/BNLJoinExec.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/BNLJoinExec.java
index 8ab62e4..a79929d 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/BNLJoinExec.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/BNLJoinExec.java
@@ -1,9 +1,11 @@
-/*
- * Copyright 2012 Database Lab., Korea Univ.
- *
- * 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
  *

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/BSTIndexScanExec.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/BSTIndexScanExec.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/BSTIndexScanExec.java
index a8545b9..d03a649 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/BSTIndexScanExec.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/BSTIndexScanExec.java
@@ -1,9 +1,11 @@
-/*
- * Copyright 2012 Database Lab., Korea Univ.
- *
- * 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
  *

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/BinaryPhysicalExec.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/BinaryPhysicalExec.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/BinaryPhysicalExec.java
index a2a8a1b..74c980b 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/BinaryPhysicalExec.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/BinaryPhysicalExec.java
@@ -1,9 +1,11 @@
-/*
- * Copyright 2012 Database Lab., Korea Univ.
- *
- * 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
  *

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/EvalExprExec.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/EvalExprExec.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/EvalExprExec.java
index cbae857..6139fa4 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/EvalExprExec.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/EvalExprExec.java
@@ -1,9 +1,11 @@
-/*
- * Copyright 2012 Database Lab., Korea Univ.
- *
- * 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
  *
@@ -14,9 +16,6 @@
  * limitations under the License.
  */
 
-/**
- * 
- */
 package tajo.engine.planner.physical;
 
 import tajo.TaskAttemptContext;
@@ -28,16 +27,10 @@ import tajo.storage.VTuple;
 
 import java.io.IOException;
 
-/**
- * @author Hyunsik Choi
- */
 public class EvalExprExec extends PhysicalExec {
   private final EvalExprNode plan;
   private final EvalContext[] evalContexts;
-  
-  /**
-   * 
-   */
+
   public EvalExprExec(final TaskAttemptContext context, final EvalExprNode plan) {
     super(context, plan.getInSchema(), plan.getOutSchema());
     this.plan = plan;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/ExternalSortExec.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/ExternalSortExec.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/ExternalSortExec.java
index cb9330e..20fa0b0 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/ExternalSortExec.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/ExternalSortExec.java
@@ -1,9 +1,11 @@
-/*
- * Copyright 2012 Database Lab., Korea Univ.
- *
- * 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
  *

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/HashAggregateExec.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/HashAggregateExec.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/HashAggregateExec.java
index 1eeb11a..405e903 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/HashAggregateExec.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/HashAggregateExec.java
@@ -1,9 +1,11 @@
-/*
- * Copyright 2012 Database Lab., Korea Univ.
- *
- * 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
  *

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/HashJoinExec.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/HashJoinExec.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/HashJoinExec.java
index 3831b08..5604fa8 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/HashJoinExec.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/HashJoinExec.java
@@ -1,9 +1,11 @@
-/*
- * Copyright 2012 Database Lab., Korea Univ.
- *
- * 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
  *

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/HashPartitioner.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/HashPartitioner.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/HashPartitioner.java
index 918a308..ba2c2eb 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/HashPartitioner.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/HashPartitioner.java
@@ -1,9 +1,11 @@
-/*
- * Copyright 2012 Database Lab., Korea Univ.
- *
- * 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
  *
@@ -22,9 +24,6 @@ package tajo.engine.planner.physical;
 import tajo.storage.Tuple;
 import tajo.storage.VTuple;
 
-/**
- * @author Hyunsik Choi
- */
 public class HashPartitioner extends Partitioner {
   private final Tuple keyTuple;
   

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/IndexWriteExec.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/IndexWriteExec.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/IndexWriteExec.java
index cc04ccf..f197be0 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/IndexWriteExec.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/IndexWriteExec.java
@@ -1,9 +1,11 @@
-/*
- * Copyright 2012 Database Lab., Korea Univ.
- *
- * 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
  *
@@ -33,9 +35,6 @@ import tajo.util.IndexUtil;
 
 import java.io.IOException;
 
-/**
- * @author Hyunsik Choi
- */
 public class IndexWriteExec extends UnaryPhysicalExec {
   private int [] indexKeys = null;
   private final BSTIndexWriter indexWriter;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/IndexedStoreExec.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/IndexedStoreExec.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/IndexedStoreExec.java
index a9a4dda..4a693b4 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/IndexedStoreExec.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/IndexedStoreExec.java
@@ -1,9 +1,11 @@
-/*
- * Copyright 2012 Database Lab., Korea Univ.
- *
- * 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
  *
@@ -31,10 +33,6 @@ import tajo.storage.index.bst.BSTIndex;
 
 import java.io.IOException;
 
-/**
- * @author Hyunsik Choi
- *
- */
 public class IndexedStoreExec extends UnaryPhysicalExec {
   private static Log LOG = LogFactory.getLog(IndexedStoreExec.class);
   private final SortSpec[] sortSpecs;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/JoinTupleComparator.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/JoinTupleComparator.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/JoinTupleComparator.java
index 6bbd1a1..88c8485 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/JoinTupleComparator.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/JoinTupleComparator.java
@@ -1,3 +1,21 @@
+/**
+ * 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.
+ */
+
 package tajo.engine.planner.physical;
 
 import com.google.common.base.Preconditions;
@@ -11,10 +29,7 @@ import java.util.Comparator;
 
 /**
  * The Comparator class for Outer and Inner Tuples
- * 
- * @author ByungNam Lim
- * @author Hyunsik Choi
- * 
+ *
  * @see tajo.storage.Tuple
  */
 public class JoinTupleComparator implements Comparator<Tuple> {

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/LimitExec.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/LimitExec.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/LimitExec.java
index 2f820d0..d4dfc74 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/LimitExec.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/LimitExec.java
@@ -1,9 +1,11 @@
-/*
- * Copyright 2012 Database Lab., Korea Univ.
- *
- * 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
  *

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/MemSortExec.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/MemSortExec.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/MemSortExec.java
index eed7b8a..f264939 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/MemSortExec.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/MemSortExec.java
@@ -1,9 +1,11 @@
-/*
- * Copyright 2012 Database Lab., Korea Univ.
- *
- * 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
  *

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/MergeJoinExec.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/MergeJoinExec.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/MergeJoinExec.java
index cafb3ce..babc486 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/MergeJoinExec.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/MergeJoinExec.java
@@ -1,9 +1,11 @@
-/*
- * Copyright 2012 Database Lab., Korea Univ.
- *
- * 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
  *

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/NLJoinExec.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/NLJoinExec.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/NLJoinExec.java
index 987a2c0..5138e3c 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/NLJoinExec.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/NLJoinExec.java
@@ -1,9 +1,11 @@
-/*
- * Copyright 2012 Database Lab., Korea Univ.
- *
- * 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
  *

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/PartitionedStoreExec.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/PartitionedStoreExec.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/PartitionedStoreExec.java
index 7ebeaf3..056d963 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/PartitionedStoreExec.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/PartitionedStoreExec.java
@@ -1,9 +1,11 @@
-/*
- * Copyright 2012 Database Lab., Korea Univ.
- *
- * 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
  *

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/Partitioner.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/Partitioner.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/Partitioner.java
index d6971e5..4764fc0 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/Partitioner.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/Partitioner.java
@@ -1,4 +1,22 @@
 /**
+ * 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.
+ */
+
+/**
  * 
  */
 package tajo.engine.planner.physical;
@@ -6,9 +24,6 @@ package tajo.engine.planner.physical;
 import com.google.common.base.Preconditions;
 import tajo.storage.Tuple;
 
-/**
- * @author Hyunsik Choi
- */
 public abstract class Partitioner {
   protected final int [] partitionKeys;
   protected final int numPartitions;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/PhysicalExec.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/PhysicalExec.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/PhysicalExec.java
index 9945a57..06bedbe 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/PhysicalExec.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/PhysicalExec.java
@@ -1,9 +1,11 @@
-/*
- * Copyright 2012 Database Lab., Korea Univ.
- *
- * 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
  *

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/ProjectionExec.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/ProjectionExec.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/ProjectionExec.java
index 613c5e8..140520a 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/ProjectionExec.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/ProjectionExec.java
@@ -1,9 +1,11 @@
-/*
- * Copyright 2012 Database Lab., Korea Univ.
- *
- * 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
  *
@@ -28,9 +30,6 @@ import tajo.storage.VTuple;
 
 import java.io.IOException;
 
-/**
- * @author Hyunsik Choi
- */
 public class ProjectionExec extends UnaryPhysicalExec {
   private final ProjectionNode plan;
 

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/SelectionExec.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/SelectionExec.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/SelectionExec.java
index 0f41edf..2d9b5cb 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/SelectionExec.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/SelectionExec.java
@@ -1,9 +1,11 @@
-/*
- * Copyright 2012 Database Lab., Korea Univ.
- *
- * 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
  *
@@ -26,9 +28,6 @@ import tajo.storage.VTuple;
 
 import java.io.IOException;
 
-/**
- * @author : hyunsik
- */
 public class SelectionExec extends UnaryPhysicalExec  {
   private final EvalNode qual;
   private final EvalContext qualCtx;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/SeqScanExec.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/SeqScanExec.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/SeqScanExec.java
index 209e04d..5cf4fa0 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/SeqScanExec.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/SeqScanExec.java
@@ -1,9 +1,11 @@
-/*
- * Copyright 2012 Database Lab., Korea Univ.
- *
- * 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
  *

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/SortAggregateExec.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/SortAggregateExec.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/SortAggregateExec.java
index 2dfae81..74d2a2a 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/SortAggregateExec.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/SortAggregateExec.java
@@ -1,9 +1,11 @@
-/*
- * Copyright 2012 Database Lab., Korea Univ.
- *
- * 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
  *
@@ -25,8 +27,6 @@ import java.io.IOException;
 
 /**
  * This is the sort-based Aggregation Operator.
- * 
- * @author Hyunsik Choi
  */
 public class SortAggregateExec extends AggregationExec {
   private Tuple prevKey = null;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/SortExec.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/SortExec.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/SortExec.java
index 83796d4..6ebe548 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/SortExec.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/SortExec.java
@@ -1,9 +1,11 @@
-/*
- * Copyright 2012 Database Lab., Korea Univ.
- *
- * 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
  *

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/StoreTableExec.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/StoreTableExec.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/StoreTableExec.java
index b85acdd..70a7a3c 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/StoreTableExec.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/StoreTableExec.java
@@ -1,9 +1,11 @@
-/*
- * Copyright 2012 Database Lab., Korea Univ.
- *
- * 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
  *
@@ -35,9 +37,6 @@ import java.io.IOException;
 
 /**
  * This physical operator stores a relation into a table.
- * 
- * @author Hyunsik Choi
- *
  */
 public class StoreTableExec extends UnaryPhysicalExec {
   private final StoreTableNode plan;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/TunnelExec.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/TunnelExec.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/TunnelExec.java
index 50807e8..42d8f5c 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/TunnelExec.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/TunnelExec.java
@@ -1,9 +1,11 @@
-/*
- * Copyright 2012 Database Lab., Korea Univ.
- *
- * 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
  *

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/UnaryPhysicalExec.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/UnaryPhysicalExec.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/UnaryPhysicalExec.java
index a608b32..e623618 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/UnaryPhysicalExec.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/UnaryPhysicalExec.java
@@ -1,9 +1,11 @@
-/*
- * Copyright 2012 Database Lab., Korea Univ.
- *
- * 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
  *
@@ -22,9 +24,6 @@ import tajo.catalog.Schema;
 
 import java.io.IOException;
 
-/**
- * @author Hyunsik Choi
- */
 public abstract class UnaryPhysicalExec extends PhysicalExec {
   protected PhysicalExec child;
 

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/UnionExec.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/UnionExec.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/UnionExec.java
index 1100a79..de94f51 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/UnionExec.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/physical/UnionExec.java
@@ -1,9 +1,11 @@
-/*
- * Copyright 2012 Database Lab., Korea Univ.
- *
- * 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
  *
@@ -25,10 +27,6 @@ import tajo.storage.Tuple;
 
 import java.io.IOException;
 
-/**
- * @author Hyunsik Choi
- *
- */
 public class UnionExec extends BinaryPhysicalExec {
   private boolean nextOuter = true;
   private Tuple tuple;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/query/QueryUnitRequestImpl.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/query/QueryUnitRequestImpl.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/query/QueryUnitRequestImpl.java
index 290a557..3e24787 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/query/QueryUnitRequestImpl.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/query/QueryUnitRequestImpl.java
@@ -1,6 +1,4 @@
-/*
- * Copyright 2012 Database Lab., Korea Univ.
- *
+/**
  * 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

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/query/ResultSetImpl.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/query/ResultSetImpl.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/query/ResultSetImpl.java
index cb9c425..ee17219 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/query/ResultSetImpl.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/query/ResultSetImpl.java
@@ -1,4 +1,22 @@
 /**
+ * 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.
+ */
+
+/**
  * 
  */
 package tajo.engine.query;