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:01 UTC

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

Updated Branches:
  refs/heads/master ab60e744e -> 457fea185


http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-rpc/src/main/java/tajo/rpc/ProtoAsyncRpcClient.java
----------------------------------------------------------------------
diff --git a/tajo-rpc/src/main/java/tajo/rpc/ProtoAsyncRpcClient.java b/tajo-rpc/src/main/java/tajo/rpc/ProtoAsyncRpcClient.java
index 17ba938..22ce0aa 100644
--- a/tajo-rpc/src/main/java/tajo/rpc/ProtoAsyncRpcClient.java
+++ b/tajo-rpc/src/main/java/tajo/rpc/ProtoAsyncRpcClient.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,9 +33,6 @@ import java.util.Map;
 import java.util.concurrent.ConcurrentHashMap;
 import java.util.concurrent.atomic.AtomicInteger;
 
-/**
- * @author Hyunsik Choi
- */
 public class ProtoAsyncRpcClient extends NettyClientBase {
   private static final Log LOG = LogFactory.getLog(RpcProtos.class);
 

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-rpc/src/main/java/tajo/rpc/ProtoAsyncRpcServer.java
----------------------------------------------------------------------
diff --git a/tajo-rpc/src/main/java/tajo/rpc/ProtoAsyncRpcServer.java b/tajo-rpc/src/main/java/tajo/rpc/ProtoAsyncRpcServer.java
index 2e28071..a2ac5cc 100644
--- a/tajo-rpc/src/main/java/tajo/rpc/ProtoAsyncRpcServer.java
+++ b/tajo-rpc/src/main/java/tajo/rpc/ProtoAsyncRpcServer.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
  *
@@ -30,9 +32,6 @@ import tajo.rpc.RpcProtos.RpcResponse;
 import java.lang.reflect.Method;
 import java.net.InetSocketAddress;
 
-/**
- * @author Hyunsik Choi
- */
 public class ProtoAsyncRpcServer extends NettyServerBase {
   private static final Log LOG = LogFactory.getLog(ProtoAsyncRpcServer.class);
 

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-rpc/src/main/java/tajo/rpc/ProtoBlockingRpcClient.java
----------------------------------------------------------------------
diff --git a/tajo-rpc/src/main/java/tajo/rpc/ProtoBlockingRpcClient.java b/tajo-rpc/src/main/java/tajo/rpc/ProtoBlockingRpcClient.java
index 9c0170f..5c4b8e3 100644
--- a/tajo-rpc/src/main/java/tajo/rpc/ProtoBlockingRpcClient.java
+++ b/tajo-rpc/src/main/java/tajo/rpc/ProtoBlockingRpcClient.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
  *
@@ -34,9 +36,6 @@ import java.util.Map;
 import java.util.concurrent.*;
 import java.util.concurrent.atomic.AtomicInteger;
 
-/**
- * @author Hyunsik Choi
- */
 public class ProtoBlockingRpcClient extends NettyClientBase {
   private static final Log LOG = LogFactory.getLog(RpcProtos.class);
 

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-rpc/src/main/java/tajo/rpc/ProtoBlockingRpcServer.java
----------------------------------------------------------------------
diff --git a/tajo-rpc/src/main/java/tajo/rpc/ProtoBlockingRpcServer.java b/tajo-rpc/src/main/java/tajo/rpc/ProtoBlockingRpcServer.java
index 2b46147..e622bf9 100644
--- a/tajo-rpc/src/main/java/tajo/rpc/ProtoBlockingRpcServer.java
+++ b/tajo-rpc/src/main/java/tajo/rpc/ProtoBlockingRpcServer.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-rpc/src/main/java/tajo/rpc/ProtoPipelineFactory.java
----------------------------------------------------------------------
diff --git a/tajo-rpc/src/main/java/tajo/rpc/ProtoPipelineFactory.java b/tajo-rpc/src/main/java/tajo/rpc/ProtoPipelineFactory.java
index 141e954..ea61d86 100644
--- a/tajo-rpc/src/main/java/tajo/rpc/ProtoPipelineFactory.java
+++ b/tajo-rpc/src/main/java/tajo/rpc/ProtoPipelineFactory.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-rpc/src/main/java/tajo/rpc/RemoteCallException.java
----------------------------------------------------------------------
diff --git a/tajo-rpc/src/main/java/tajo/rpc/RemoteCallException.java b/tajo-rpc/src/main/java/tajo/rpc/RemoteCallException.java
index e8d8fcd..b319726 100644
--- a/tajo-rpc/src/main/java/tajo/rpc/RemoteCallException.java
+++ b/tajo-rpc/src/main/java/tajo/rpc/RemoteCallException.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-rpc/src/main/java/tajo/rpc/RemoteException.java
----------------------------------------------------------------------
diff --git a/tajo-rpc/src/main/java/tajo/rpc/RemoteException.java b/tajo-rpc/src/main/java/tajo/rpc/RemoteException.java
index eb1965a..7c8c84d 100644
--- a/tajo-rpc/src/main/java/tajo/rpc/RemoteException.java
+++ b/tajo-rpc/src/main/java/tajo/rpc/RemoteException.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-rpc/src/main/java/tajo/rpc/benchmark/BenchmarkAsyncRPC.java
----------------------------------------------------------------------
diff --git a/tajo-rpc/src/main/java/tajo/rpc/benchmark/BenchmarkAsyncRPC.java b/tajo-rpc/src/main/java/tajo/rpc/benchmark/BenchmarkAsyncRPC.java
index a2b557b..043449c 100644
--- a/tajo-rpc/src/main/java/tajo/rpc/benchmark/BenchmarkAsyncRPC.java
+++ b/tajo-rpc/src/main/java/tajo/rpc/benchmark/BenchmarkAsyncRPC.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-rpc/src/main/java/tajo/rpc/benchmark/BenchmarkBlockingRPC.java
----------------------------------------------------------------------
diff --git a/tajo-rpc/src/main/java/tajo/rpc/benchmark/BenchmarkBlockingRPC.java b/tajo-rpc/src/main/java/tajo/rpc/benchmark/BenchmarkBlockingRPC.java
index 1c26487..110c668 100644
--- a/tajo-rpc/src/main/java/tajo/rpc/benchmark/BenchmarkBlockingRPC.java
+++ b/tajo-rpc/src/main/java/tajo/rpc/benchmark/BenchmarkBlockingRPC.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-rpc/src/main/java/tajo/rpc/benchmark/BenchmarkHadoopRPC.java
----------------------------------------------------------------------
diff --git a/tajo-rpc/src/main/java/tajo/rpc/benchmark/BenchmarkHadoopRPC.java b/tajo-rpc/src/main/java/tajo/rpc/benchmark/BenchmarkHadoopRPC.java
index d8944ec..222411e 100644
--- a/tajo-rpc/src/main/java/tajo/rpc/benchmark/BenchmarkHadoopRPC.java
+++ b/tajo-rpc/src/main/java/tajo/rpc/benchmark/BenchmarkHadoopRPC.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-rpc/src/main/java/tajo/util/NetUtils.java
----------------------------------------------------------------------
diff --git a/tajo-rpc/src/main/java/tajo/util/NetUtils.java b/tajo-rpc/src/main/java/tajo/util/NetUtils.java
index 304231b..5800496 100644
--- a/tajo-rpc/src/main/java/tajo/util/NetUtils.java
+++ b/tajo-rpc/src/main/java/tajo/util/NetUtils.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-rpc/src/test/java/log4j.properties
----------------------------------------------------------------------
diff --git a/tajo-rpc/src/test/java/log4j.properties b/tajo-rpc/src/test/java/log4j.properties
index b089a38..c1ac487 100644
--- a/tajo-rpc/src/test/java/log4j.properties
+++ b/tajo-rpc/src/test/java/log4j.properties
@@ -1,7 +1,11 @@
-#
-# 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-rpc/src/test/java/tajo/rpc/TestNettyAsyncRpc.java
----------------------------------------------------------------------
diff --git a/tajo-rpc/src/test/java/tajo/rpc/TestNettyAsyncRpc.java b/tajo-rpc/src/test/java/tajo/rpc/TestNettyAsyncRpc.java
index a36c57e..50ff8fa 100644
--- a/tajo-rpc/src/test/java/tajo/rpc/TestNettyAsyncRpc.java
+++ b/tajo-rpc/src/test/java/tajo/rpc/TestNettyAsyncRpc.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-rpc/src/test/java/tajo/rpc/TestNettyBlockingRpc.java
----------------------------------------------------------------------
diff --git a/tajo-rpc/src/test/java/tajo/rpc/TestNettyBlockingRpc.java b/tajo-rpc/src/test/java/tajo/rpc/TestNettyBlockingRpc.java
index e4cbbd1..58b9bdb 100644
--- a/tajo-rpc/src/test/java/tajo/rpc/TestNettyBlockingRpc.java
+++ b/tajo-rpc/src/test/java/tajo/rpc/TestNettyBlockingRpc.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-rpc/src/test/java/tajo/rpc/TestProtoAsyncRpc.java
----------------------------------------------------------------------
diff --git a/tajo-rpc/src/test/java/tajo/rpc/TestProtoAsyncRpc.java b/tajo-rpc/src/test/java/tajo/rpc/TestProtoAsyncRpc.java
index 1ca4609..91303e3 100644
--- a/tajo-rpc/src/test/java/tajo/rpc/TestProtoAsyncRpc.java
+++ b/tajo-rpc/src/test/java/tajo/rpc/TestProtoAsyncRpc.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-rpc/src/test/java/tajo/rpc/TestProtoBlockingRpc.java
----------------------------------------------------------------------
diff --git a/tajo-rpc/src/test/java/tajo/rpc/TestProtoBlockingRpc.java b/tajo-rpc/src/test/java/tajo/rpc/TestProtoBlockingRpc.java
index f90deb0..39c4f88 100644
--- a/tajo-rpc/src/test/java/tajo/rpc/TestProtoBlockingRpc.java
+++ b/tajo-rpc/src/test/java/tajo/rpc/TestProtoBlockingRpc.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-rpc/src/test/java/tajo/rpc/test/impl/DummyProtocolAsyncImpl.java
----------------------------------------------------------------------
diff --git a/tajo-rpc/src/test/java/tajo/rpc/test/impl/DummyProtocolAsyncImpl.java b/tajo-rpc/src/test/java/tajo/rpc/test/impl/DummyProtocolAsyncImpl.java
index d872ecc..7908367 100644
--- a/tajo-rpc/src/test/java/tajo/rpc/test/impl/DummyProtocolAsyncImpl.java
+++ b/tajo-rpc/src/test/java/tajo/rpc/test/impl/DummyProtocolAsyncImpl.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-rpc/src/test/java/tajo/rpc/test/impl/DummyProtocolBlockingImpl.java
----------------------------------------------------------------------
diff --git a/tajo-rpc/src/test/java/tajo/rpc/test/impl/DummyProtocolBlockingImpl.java b/tajo-rpc/src/test/java/tajo/rpc/test/impl/DummyProtocolBlockingImpl.java
index a4ee4f3..de8e46a 100644
--- a/tajo-rpc/src/test/java/tajo/rpc/test/impl/DummyProtocolBlockingImpl.java
+++ b/tajo-rpc/src/test/java/tajo/rpc/test/impl/DummyProtocolBlockingImpl.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
  *


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

Posted by hy...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/query/ResultSetMetaDataImpl.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/query/ResultSetMetaDataImpl.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/query/ResultSetMetaDataImpl.java
index 24f92d8..ee9b7cf 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/query/ResultSetMetaDataImpl.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/query/ResultSetMetaDataImpl.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;
@@ -12,10 +30,6 @@ import java.sql.ResultSetMetaData;
 import java.sql.SQLException;
 import java.sql.Types;
 
-/**
- * @author jihoon
- *
- */
 public class ResultSetMetaDataImpl implements ResultSetMetaData {
   private TableMeta meta;
   

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/query/exception/AmbiguousFieldException.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/query/exception/AmbiguousFieldException.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/query/exception/AmbiguousFieldException.java
index cce520f..88bebb1 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/query/exception/AmbiguousFieldException.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/query/exception/AmbiguousFieldException.java
@@ -1,11 +1,23 @@
-package tajo.engine.query.exception;
-
-
-
 /**
- * @author Hyunsik Choi
+ * 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.exception;
+
 public class AmbiguousFieldException extends InvalidQueryException {
 	private static final long serialVersionUID = 3102675985226352347L;
 

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/query/exception/InvalidCastException.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/query/exception/InvalidCastException.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/query/exception/InvalidCastException.java
index 1b945c5..9732391 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/query/exception/InvalidCastException.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/query/exception/InvalidCastException.java
@@ -1,14 +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.query.exception;
 
 import tajo.catalog.proto.CatalogProtos.DataType;
 
-/**
- * @author Hyunsik Choi
- *
- */
 public class InvalidCastException extends InvalidQueryException {
 	private static final long serialVersionUID = -5090530469575858320L;
 

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/query/exception/InvalidEvalException.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/query/exception/InvalidEvalException.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/query/exception/InvalidEvalException.java
index 02b19f2..121f89b 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/query/exception/InvalidEvalException.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/query/exception/InvalidEvalException.java
@@ -1,12 +1,23 @@
 /**
- * 
+ * 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.exception;
 
-/**
- * @author Hyunsik Choi
- *
- */
 public class InvalidEvalException extends InvalidQueryException {
 	private static final long serialVersionUID = -2897003028483298256L;
 

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/query/exception/InvalidQueryException.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/query/exception/InvalidQueryException.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/query/exception/InvalidQueryException.java
index 911a9a6..2f723e2 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/query/exception/InvalidQueryException.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/query/exception/InvalidQueryException.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.query.exception;
 
 public class InvalidQueryException extends RuntimeException {

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/query/exception/NotSupportQueryException.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/query/exception/NotSupportQueryException.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/query/exception/NotSupportQueryException.java
index b4679c2..2fdf3ef 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/query/exception/NotSupportQueryException.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/query/exception/NotSupportQueryException.java
@@ -1,13 +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.query.exception;
 
 
-/**
- * @author hyunsik
- *
- */
 public class NotSupportQueryException extends InvalidQueryException {
 	private static final long serialVersionUID = 4079784008765680410L;
 

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/query/exception/TQLParseError.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/query/exception/TQLParseError.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/query/exception/TQLParseError.java
index abfd654..3f1e873 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/query/exception/TQLParseError.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/query/exception/TQLParseError.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/query/exception/TQLSyntaxError.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/query/exception/TQLSyntaxError.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/query/exception/TQLSyntaxError.java
index a64d0d3..e792562 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/query/exception/TQLSyntaxError.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/query/exception/TQLSyntaxError.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/query/exception/UndefinedFunctionException.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/query/exception/UndefinedFunctionException.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/query/exception/UndefinedFunctionException.java
index 107715b..a1c420e 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/query/exception/UndefinedFunctionException.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/query/exception/UndefinedFunctionException.java
@@ -1,13 +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.query.exception;
 
 
-/**
- * @author Hyunsik Choi
- *
- */
 public class UndefinedFunctionException extends InvalidQueryException {
 	private static final long serialVersionUID = 113593927391549716L;
 

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/utils/ProtoUtil.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/utils/ProtoUtil.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/utils/ProtoUtil.java
index 7430f21..4b02187 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/utils/ProtoUtil.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/utils/ProtoUtil.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.utils;
 
 import tajo.rpc.protocolrecords.PrimitiveProtos.StringProto;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/utils/SchemaUtil.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/utils/SchemaUtil.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/utils/SchemaUtil.java
index 21af15f..bde92c1 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/utils/SchemaUtil.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/utils/SchemaUtil.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/utils/ThreadUtil.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/utils/ThreadUtil.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/utils/ThreadUtil.java
index 6625239..92b5ba5 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/utils/ThreadUtil.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/utils/ThreadUtil.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.utils;
 
 import org.apache.commons.logging.Log;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/utils/TupleUtil.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/utils/TupleUtil.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/utils/TupleUtil.java
index 2af0ab8..be4a595 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/utils/TupleUtil.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/utils/TupleUtil.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.utils;
 
 import com.google.common.base.Preconditions;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/ipc/protocolrecords/QueryUnitRequest.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/ipc/protocolrecords/QueryUnitRequest.java b/tajo-core/tajo-core-backend/src/main/java/tajo/ipc/protocolrecords/QueryUnitRequest.java
index 03f8890..6c75186 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/ipc/protocolrecords/QueryUnitRequest.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/ipc/protocolrecords/QueryUnitRequest.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/master/ClientService.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/ClientService.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/ClientService.java
index 883fdff..106a586 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/ClientService.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/ClientService.java
@@ -1,7 +1,11 @@
-/*
- * 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/master/GlobalEngine.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/GlobalEngine.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/GlobalEngine.java
index 48fee12..252c84d 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/GlobalEngine.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/GlobalEngine.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/master/GlobalPlanner.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/GlobalPlanner.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/GlobalPlanner.java
index f8a39f8..8d3b400 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/GlobalPlanner.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/GlobalPlanner.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
  *
@@ -149,9 +151,6 @@ public class GlobalPlanner {
   /**
    * Transforms a logical plan to a two-phase plan. 
    * Store nodes are inserted for every logical nodes except store and scan nodes
-   * 
-   * @author jihoon
-   *
    */
   private class GlobalPlanBuilder implements LogicalNodeVisitor {
     @Override

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/master/GlobalPlannerUtils.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/GlobalPlannerUtils.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/GlobalPlannerUtils.java
index 30f30f8..1ecfa0e 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/GlobalPlannerUtils.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/GlobalPlannerUtils.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
@@ -35,9 +33,6 @@ import java.util.Collection;
 import java.util.Comparator;
 import java.util.Map;
 
-/**
- * @author jihoon
- */
 public class GlobalPlannerUtils {
   private static Log LOG = LogFactory.getLog(GlobalPlannerUtils.class);
 

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/master/Priority.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/Priority.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/Priority.java
index 954d510..7e95d17 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/Priority.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/Priority.java
@@ -1,8 +1,23 @@
-package tajo.master;
-
 /**
- * @author jihoon
+ * 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.master;
+
 public class Priority implements Comparable<Priority> {
   private int priority;
 

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/master/Query.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/Query.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/Query.java
index 56e1325..b57858f 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/Query.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/Query.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/master/QueryMaster.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/QueryMaster.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/QueryMaster.java
index 1149fa1..22f0daf 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/QueryMaster.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/QueryMaster.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/master/QueryUnit.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/QueryUnit.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/QueryUnit.java
index 50a23eb..38771e7 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/QueryUnit.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/QueryUnit.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/master/QueryUnitAttempt.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/QueryUnitAttempt.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/QueryUnitAttempt.java
index 94ca180..c4dfae3 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/QueryUnitAttempt.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/QueryUnitAttempt.java
@@ -1,7 +1,11 @@
-/*
- * 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/master/Repartitioner.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/Repartitioner.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/Repartitioner.java
index 98d4ac7..f0cbd25 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/Repartitioner.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/Repartitioner.java
@@ -1,7 +1,11 @@
-/*
- * 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/master/SchedulerUtils.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/SchedulerUtils.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/SchedulerUtils.java
index c895946..4abeefb 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/SchedulerUtils.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/SchedulerUtils.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.master;
 
 import com.google.common.collect.Lists;
@@ -7,9 +25,6 @@ import java.util.Comparator;
 import java.util.List;
 import java.util.Map;
 
-/**
- * @author jihoon
- */
 public class SchedulerUtils {
 
   public static class MapComparatorBySize implements Comparator<Map>{

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/master/SubQuery.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/SubQuery.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/SubQuery.java
index ab7836d..6f58834 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/SubQuery.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/SubQuery.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/master/SubQueryState.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/SubQueryState.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/SubQueryState.java
index b5d0223..673f1df 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/SubQueryState.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/SubQueryState.java
@@ -1,7 +1,11 @@
-/*
- * 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/master/TajoMaster.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/TajoMaster.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/TajoMaster.java
index d1ca849..08cc735 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/TajoMaster.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/TajoMaster.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/master/TaskContainerManager.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/TaskContainerManager.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/TaskContainerManager.java
index 85a2de5..8756dc4 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/TaskContainerManager.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/TaskContainerManager.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/master/TaskRunnerEvent.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/TaskRunnerEvent.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/TaskRunnerEvent.java
index 3df7631..4cadebb 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/TaskRunnerEvent.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/TaskRunnerEvent.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/master/TaskRunnerLauncher.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/TaskRunnerLauncher.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/TaskRunnerLauncher.java
index 65ea928..9cbad6b 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/TaskRunnerLauncher.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/TaskRunnerLauncher.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/master/TaskRunnerLauncherImpl.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/TaskRunnerLauncherImpl.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/TaskRunnerLauncherImpl.java
index 7c1a0ec..c22e3b4 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/TaskRunnerLauncherImpl.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/TaskRunnerLauncherImpl.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/master/TaskRunnerListener.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/TaskRunnerListener.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/TaskRunnerListener.java
index ba34928..661b458 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/TaskRunnerListener.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/TaskRunnerListener.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/master/TaskScheduler.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/TaskScheduler.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/TaskScheduler.java
index 0c7a124..e4218f0 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/TaskScheduler.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/TaskScheduler.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/master/TaskSchedulerImpl.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/TaskSchedulerImpl.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/TaskSchedulerImpl.java
index 3046028..3f92608 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/TaskSchedulerImpl.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/TaskSchedulerImpl.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/master/TaskState.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/TaskState.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/TaskState.java
index f77848d..52ed276 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/TaskState.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/TaskState.java
@@ -1,7 +1,11 @@
-/*
- * 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/master/cluster/ServerName.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/cluster/ServerName.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/cluster/ServerName.java
index 008ab95..0e87e67 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/cluster/ServerName.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/cluster/ServerName.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.master.cluster;
 
 public class ServerName implements Comparable<ServerName> {

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/master/cluster/WorkerListener.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/cluster/WorkerListener.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/cluster/WorkerListener.java
index 2d3b2b7..93b786d 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/cluster/WorkerListener.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/cluster/WorkerListener.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/master/cluster/event/WorkerEvent.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/cluster/event/WorkerEvent.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/cluster/event/WorkerEvent.java
index 52bfa77..545eb45 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/cluster/event/WorkerEvent.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/cluster/event/WorkerEvent.java
@@ -1,7 +1,11 @@
-/*
- * 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/master/cluster/event/WorkerEventType.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/cluster/event/WorkerEventType.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/cluster/event/WorkerEventType.java
index 843f924..8a9d69c 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/cluster/event/WorkerEventType.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/cluster/event/WorkerEventType.java
@@ -1,7 +1,11 @@
-/*
- * 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/master/event/ContainerAllocationEvent.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/ContainerAllocationEvent.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/ContainerAllocationEvent.java
index 86de1b6..f5d9a49 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/ContainerAllocationEvent.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/ContainerAllocationEvent.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/master/event/ContainerAllocatorEventType.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/ContainerAllocatorEventType.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/ContainerAllocatorEventType.java
index 659a997..b8463b5 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/ContainerAllocatorEventType.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/ContainerAllocatorEventType.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/master/event/ContainerEvent.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/ContainerEvent.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/ContainerEvent.java
index 8c571a0..e133d71 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/ContainerEvent.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/ContainerEvent.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/master/event/GrouppedContainerAllocatorEvent.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/GrouppedContainerAllocatorEvent.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/GrouppedContainerAllocatorEvent.java
index 1a697ea..d352192 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/GrouppedContainerAllocatorEvent.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/GrouppedContainerAllocatorEvent.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/master/event/QueryDiagnosticsUpdateEvent.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/QueryDiagnosticsUpdateEvent.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/QueryDiagnosticsUpdateEvent.java
index a1a6197..1c123e6 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/QueryDiagnosticsUpdateEvent.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/QueryDiagnosticsUpdateEvent.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/master/event/QueryEvent.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/QueryEvent.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/QueryEvent.java
index 7bb1903..793b5df 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/QueryEvent.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/QueryEvent.java
@@ -1,4 +1,4 @@
-/*
+/**
  * 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/master/event/QueryEventType.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/QueryEventType.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/QueryEventType.java
index e80d9bd..73c0445 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/QueryEventType.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/QueryEventType.java
@@ -1,4 +1,4 @@
-/*
+/**
  * 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/master/event/QueryFinishEvent.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/QueryFinishEvent.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/QueryFinishEvent.java
index 23db59c..d4625e1 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/QueryFinishEvent.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/QueryFinishEvent.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/master/event/QuerySubQueryEvent.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/QuerySubQueryEvent.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/QuerySubQueryEvent.java
index 9c36bba..9152875 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/QuerySubQueryEvent.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/QuerySubQueryEvent.java
@@ -1,4 +1,4 @@
-/*
+/**
  * 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/master/event/SubQueryCompletedEvent.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/SubQueryCompletedEvent.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/SubQueryCompletedEvent.java
index c8c65d2..345fc11 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/SubQueryCompletedEvent.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/SubQueryCompletedEvent.java
@@ -1,4 +1,4 @@
-/*
+/**
  * 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/master/event/SubQueryContainerAllocationEvent.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/SubQueryContainerAllocationEvent.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/SubQueryContainerAllocationEvent.java
index 7544d65..5eb197b 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/SubQueryContainerAllocationEvent.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/SubQueryContainerAllocationEvent.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/master/event/SubQueryEvent.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/SubQueryEvent.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/SubQueryEvent.java
index 44abf19..92ee2dd 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/SubQueryEvent.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/SubQueryEvent.java
@@ -1,4 +1,4 @@
-/*
+/**
  * 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/master/event/SubQueryEventType.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/SubQueryEventType.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/SubQueryEventType.java
index e954bfd..2c21411 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/SubQueryEventType.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/SubQueryEventType.java
@@ -1,4 +1,4 @@
-/*
+/**
  * 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/master/event/SubQuerySucceeEvent.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/SubQuerySucceeEvent.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/SubQuerySucceeEvent.java
index 78feb4d..2855b05 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/SubQuerySucceeEvent.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/SubQuerySucceeEvent.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/master/event/SubQueryTaskEvent.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/SubQueryTaskEvent.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/SubQueryTaskEvent.java
index c12876c..c50fd8d 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/SubQueryTaskEvent.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/SubQueryTaskEvent.java
@@ -1,4 +1,4 @@
-/*
+/**
  * 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/master/event/TaskAttemptAssignedEvent.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/TaskAttemptAssignedEvent.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/TaskAttemptAssignedEvent.java
index 3d9a26d..9fd0887 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/TaskAttemptAssignedEvent.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/TaskAttemptAssignedEvent.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/master/event/TaskAttemptEvent.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/TaskAttemptEvent.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/TaskAttemptEvent.java
index 4a4dd58..adedece 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/TaskAttemptEvent.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/TaskAttemptEvent.java
@@ -1,4 +1,4 @@
-/*
+/**
  * 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/master/event/TaskAttemptEventType.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/TaskAttemptEventType.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/TaskAttemptEventType.java
index d8f2739..5fa8bdf 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/TaskAttemptEventType.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/TaskAttemptEventType.java
@@ -1,4 +1,4 @@
-/*
+/**
  * 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/master/event/TaskAttemptStatusUpdateEvent.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/TaskAttemptStatusUpdateEvent.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/TaskAttemptStatusUpdateEvent.java
index b26591c..027e5c2 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/TaskAttemptStatusUpdateEvent.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/TaskAttemptStatusUpdateEvent.java
@@ -1,4 +1,4 @@
-/*
+/**
  * 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/master/event/TaskCompletionEvent.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/TaskCompletionEvent.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/TaskCompletionEvent.java
index 2a2b745..7557916 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/TaskCompletionEvent.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/TaskCompletionEvent.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/master/event/TaskEvent.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/TaskEvent.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/TaskEvent.java
index 693f5c6..d848be2 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/TaskEvent.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/TaskEvent.java
@@ -1,4 +1,4 @@
-/*
+/**
  * 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/master/event/TaskEventType.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/TaskEventType.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/TaskEventType.java
index 13b1c90..144c13e 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/TaskEventType.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/TaskEventType.java
@@ -1,4 +1,4 @@
-/*
+/**
  * 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/master/event/TaskFatalErrorEvent.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/TaskFatalErrorEvent.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/TaskFatalErrorEvent.java
index e702c53..9d70c2d 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/TaskFatalErrorEvent.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/TaskFatalErrorEvent.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/master/event/TaskRequestEvent.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/TaskRequestEvent.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/TaskRequestEvent.java
index 8870f7f..ee21447 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/TaskRequestEvent.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/TaskRequestEvent.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/master/event/TaskRunnerLaunchEvent.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/TaskRunnerLaunchEvent.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/TaskRunnerLaunchEvent.java
index c1a490d..2406b48 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/TaskRunnerLaunchEvent.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/TaskRunnerLaunchEvent.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/master/event/TaskRunnerStopEvent.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/TaskRunnerStopEvent.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/TaskRunnerStopEvent.java
index e8c8983..7e5a579 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/TaskRunnerStopEvent.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/TaskRunnerStopEvent.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/master/event/TaskScheduleEvent.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/TaskScheduleEvent.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/TaskScheduleEvent.java
index 06bdab6..95cd73c 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/TaskScheduleEvent.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/TaskScheduleEvent.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/master/event/TaskSchedulerEvent.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/TaskSchedulerEvent.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/TaskSchedulerEvent.java
index 6036118..d7eb859 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/TaskSchedulerEvent.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/TaskSchedulerEvent.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/master/event/TaskTAttemptEvent.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/TaskTAttemptEvent.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/TaskTAttemptEvent.java
index bde2dea..5b89915 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/TaskTAttemptEvent.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/event/TaskTAttemptEvent.java
@@ -1,4 +1,4 @@
-/*
+/**
  * 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/master/rm/RMCommunicator.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/rm/RMCommunicator.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/rm/RMCommunicator.java
index c4f273d..90a0737 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/rm/RMCommunicator.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/rm/RMCommunicator.java
@@ -1,7 +1,11 @@
-/*
- * 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/master/rm/RMContainerAllocator.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/master/rm/RMContainerAllocator.java b/tajo-core/tajo-core-backend/src/main/java/tajo/master/rm/RMContainerAllocator.java
index c3cf97d..4583efd 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/master/rm/RMContainerAllocator.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/master/rm/RMContainerAllocator.java
@@ -1,7 +1,11 @@
-/*
- * 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
  *


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

Posted by hy...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/net/CachedDNSResolver.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/net/CachedDNSResolver.java b/tajo-core/tajo-core-backend/src/main/java/tajo/net/CachedDNSResolver.java
index 251d1d5..74f0e86 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/net/CachedDNSResolver.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/net/CachedDNSResolver.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/scheduler/event/ScheduleTaskEvent.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/scheduler/event/ScheduleTaskEvent.java b/tajo-core/tajo-core-backend/src/main/java/tajo/scheduler/event/ScheduleTaskEvent.java
index 5d4e4b7..b66918f 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/scheduler/event/ScheduleTaskEvent.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/scheduler/event/ScheduleTaskEvent.java
@@ -1,4 +1,4 @@
-/*
+/**
  * 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/scheduler/event/SchedulerEvent.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/scheduler/event/SchedulerEvent.java b/tajo-core/tajo-core-backend/src/main/java/tajo/scheduler/event/SchedulerEvent.java
index 3bf35ae..7f05883 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/scheduler/event/SchedulerEvent.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/scheduler/event/SchedulerEvent.java
@@ -1,4 +1,4 @@
-/*
+/**
  * 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/scheduler/event/SchedulerEventType.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/scheduler/event/SchedulerEventType.java b/tajo-core/tajo-core-backend/src/main/java/tajo/scheduler/event/SchedulerEventType.java
index a0e325e..0d783f2 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/scheduler/event/SchedulerEventType.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/scheduler/event/SchedulerEventType.java
@@ -1,4 +1,4 @@
-/*
+/**
  * 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/util/GeoUtil.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/util/GeoUtil.java b/tajo-core/tajo-core-backend/src/main/java/tajo/util/GeoUtil.java
index cfc09f9..539b789 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/util/GeoUtil.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/util/GeoUtil.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.util;
 
 import com.maxmind.geoip.LookupService;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/util/IndexUtil.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/util/IndexUtil.java b/tajo-core/tajo-core-backend/src/main/java/tajo/util/IndexUtil.java
index e4a234e..78fa487 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/util/IndexUtil.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/util/IndexUtil.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/webapp/HttpServer.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/webapp/HttpServer.java b/tajo-core/tajo-core-backend/src/main/java/tajo/webapp/HttpServer.java
index 7bdcf1e..5bdab13 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/webapp/HttpServer.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/webapp/HttpServer.java
@@ -1,18 +1,19 @@
 /**
- * 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
- * 
+ * 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.
+ * 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.webapp;
@@ -44,8 +45,6 @@ import java.util.Map;
 
 /**
  * This class is borrowed from Hadoop and is simplified to our objective.
- * 
- * @author Hyunsik Choi
  */
 public class HttpServer {
   private static final Log LOG = LogFactory.getLog(HttpServer.class);

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/webapp/StaticHttpServer.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/webapp/StaticHttpServer.java b/tajo-core/tajo-core-backend/src/main/java/tajo/webapp/StaticHttpServer.java
index d548b7c..f9eff48 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/webapp/StaticHttpServer.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/webapp/StaticHttpServer.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.webapp;
 
 import org.apache.hadoop.conf.Configuration;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/worker/Fetcher.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/worker/Fetcher.java b/tajo-core/tajo-core-backend/src/main/java/tajo/worker/Fetcher.java
index ec2d5bc..6b0d4a2 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/worker/Fetcher.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/worker/Fetcher.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.worker;
 
 import org.apache.commons.logging.Log;
@@ -22,8 +40,6 @@ import static org.jboss.netty.channel.Channels.pipeline;
 /**
  * Fetcher fetches data from a given uri via HTTP protocol and stores them into
  * a specific file. It aims at asynchronous and efficient data transmit.
- * 
- * @author Hyunsik Choi
  */
 public class Fetcher {
   private final static Log LOG = LogFactory.getLog(Fetcher.class);

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/worker/InterDataRetriever.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/worker/InterDataRetriever.java b/tajo-core/tajo-core-backend/src/main/java/tajo/worker/InterDataRetriever.java
index 83125c5..ae22a82 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/worker/InterDataRetriever.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/worker/InterDataRetriever.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.worker;
@@ -20,9 +38,6 @@ import java.io.IOException;
 import java.util.Map;
 import java.util.Set;
 
-/**
- * @author Hyunsik Choi
- */
 @Deprecated
 public class InterDataRetriever implements DataRetriever {
   private final Log LOG = LogFactory.getLog(InterDataRetriever.class);

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/worker/PartitionRetrieverHandler.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/worker/PartitionRetrieverHandler.java b/tajo-core/tajo-core-backend/src/main/java/tajo/worker/PartitionRetrieverHandler.java
index 0891145..052ece7 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/worker/PartitionRetrieverHandler.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/worker/PartitionRetrieverHandler.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.worker;
 
 import tajo.worker.dataserver.retriever.FileChunk;
@@ -8,9 +26,6 @@ import java.io.IOException;
 import java.util.List;
 import java.util.Map;
 
-/**
- * @author Hyunsik Choi
- */
 public class PartitionRetrieverHandler implements RetrieverHandler {
   private final String baseDir;
 

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/worker/RangeRetrieverHandler.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/worker/RangeRetrieverHandler.java b/tajo-core/tajo-core-backend/src/main/java/tajo/worker/RangeRetrieverHandler.java
index 9e155e3..22890d5 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/worker/RangeRetrieverHandler.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/worker/RangeRetrieverHandler.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.worker;
 
 import org.apache.commons.codec.binary.Base64;
@@ -22,7 +40,6 @@ import java.util.List;
 import java.util.Map;
 
 /**
- * @author Hyunsik Choi
  *
  * It retrieves the file chunk ranged between start and end keys.
  * The start key is inclusive, but the end key is exclusive.

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/worker/TajoQueryEngine.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/worker/TajoQueryEngine.java b/tajo-core/tajo-core-backend/src/main/java/tajo/worker/TajoQueryEngine.java
index c96466f..70a401c 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/worker/TajoQueryEngine.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/worker/TajoQueryEngine.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
  *
@@ -29,9 +31,6 @@ import tajo.storage.StorageManager;
 
 import java.io.IOException;
 
-/**
- * @author Hyunsik Choi
- */
 public class TajoQueryEngine {
   private final static Log LOG = LogFactory.getLog(TajoQueryEngine.class);
   private final StorageManager storageManager;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/worker/Task.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/worker/Task.java b/tajo-core/tajo-core-backend/src/main/java/tajo/worker/Task.java
index d60e835..8b0df26 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/worker/Task.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/worker/Task.java
@@ -1,7 +1,11 @@
-/*
- * 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/worker/TaskRunner.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/worker/TaskRunner.java b/tajo-core/tajo-core-backend/src/main/java/tajo/worker/TaskRunner.java
index fa073e4..cf0dbc4 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/worker/TaskRunner.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/worker/TaskRunner.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/worker/dataserver/FileAccessForbiddenException.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/worker/dataserver/FileAccessForbiddenException.java b/tajo-core/tajo-core-backend/src/main/java/tajo/worker/dataserver/FileAccessForbiddenException.java
index e99cdf4..5f0c772 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/worker/dataserver/FileAccessForbiddenException.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/worker/dataserver/FileAccessForbiddenException.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.worker.dataserver;
 
 import java.io.IOException;
 
-/**
- * @author Hyunsik Choi
- */
 public class FileAccessForbiddenException extends IOException {
   private static final long serialVersionUID = -3383272565826389213L;
 

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/worker/dataserver/HttpDataServer.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/worker/dataserver/HttpDataServer.java b/tajo-core/tajo-core-backend/src/main/java/tajo/worker/dataserver/HttpDataServer.java
index f4eae46..a35922e 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/worker/dataserver/HttpDataServer.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/worker/dataserver/HttpDataServer.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.worker.dataserver;
 
 import org.apache.commons.logging.Log;
@@ -15,9 +33,6 @@ import tajo.worker.dataserver.retriever.DataRetriever;
 import java.net.InetSocketAddress;
 import java.util.concurrent.Executors;
 
-/**
- * @author Hyunsik Choi
- */
 public class HttpDataServer {
   private final static Log LOG = LogFactory.getLog(HttpDataServer.class);
 

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/worker/dataserver/HttpDataServerHandler.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/worker/dataserver/HttpDataServerHandler.java b/tajo-core/tajo-core-backend/src/main/java/tajo/worker/dataserver/HttpDataServerHandler.java
index f0ed420..31ab6e1 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/worker/dataserver/HttpDataServerHandler.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/worker/dataserver/HttpDataServerHandler.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.worker.dataserver;
 
 import org.apache.commons.logging.Log;
@@ -25,9 +43,6 @@ import static org.jboss.netty.handler.codec.http.HttpMethod.GET;
 import static org.jboss.netty.handler.codec.http.HttpResponseStatus.*;
 import static org.jboss.netty.handler.codec.http.HttpVersion.HTTP_1_1;
 
-/**
- * @author Hyunsik Choi
- */
 public class HttpDataServerHandler extends SimpleChannelUpstreamHandler {
   private final static Log LOG = LogFactory.getLog(HttpDataServer.class);
   private final DataRetriever retriever;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/worker/dataserver/HttpDataServerPipelineFactory.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/worker/dataserver/HttpDataServerPipelineFactory.java b/tajo-core/tajo-core-backend/src/main/java/tajo/worker/dataserver/HttpDataServerPipelineFactory.java
index f6e2989..e4fd554 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/worker/dataserver/HttpDataServerPipelineFactory.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/worker/dataserver/HttpDataServerPipelineFactory.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.worker.dataserver;
 
 import org.jboss.netty.channel.ChannelPipeline;
@@ -9,9 +27,6 @@ import tajo.worker.dataserver.retriever.DataRetriever;
 
 import static org.jboss.netty.channel.Channels.pipeline;
 
-/**
- * @author Hyunsik Choi
- */
 public class HttpDataServerPipelineFactory implements ChannelPipelineFactory {
   private final DataRetriever ret;
 

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/worker/dataserver/HttpUtil.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/worker/dataserver/HttpUtil.java b/tajo-core/tajo-core-backend/src/main/java/tajo/worker/dataserver/HttpUtil.java
index 587a8ae..4c18a0f 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/worker/dataserver/HttpUtil.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/worker/dataserver/HttpUtil.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.worker.dataserver;
 
 import com.google.common.collect.Maps;
@@ -7,9 +25,6 @@ import java.net.URI;
 import java.net.URLEncoder;
 import java.util.Map;
 
-/**
- * @author  Hyunsik Choi
- */
 public class HttpUtil {
   public static Map<String,String> getParams(URI uri) throws UnsupportedEncodingException {
     return getParamsFromQuery(uri.getQuery());

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/worker/dataserver/retriever/AdvancedDataRetriever.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/worker/dataserver/retriever/AdvancedDataRetriever.java b/tajo-core/tajo-core-backend/src/main/java/tajo/worker/dataserver/retriever/AdvancedDataRetriever.java
index 2965865..fef717b 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/worker/dataserver/retriever/AdvancedDataRetriever.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/worker/dataserver/retriever/AdvancedDataRetriever.java
@@ -1,6 +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.worker.dataserver.retriever;
 
 import com.google.common.collect.Lists;
@@ -24,9 +39,6 @@ import java.util.Collections;
 import java.util.List;
 import java.util.Map;
 
-/**
- * @author Hyunsik Choi
- */
 public class AdvancedDataRetriever implements DataRetriever {
   private final Log LOG = LogFactory.getLog(AdvancedDataRetriever.class);
   private final Map<String, RetrieverHandler> handlerMap = Maps.newConcurrentMap();

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/worker/dataserver/retriever/DataRetriever.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/worker/dataserver/retriever/DataRetriever.java b/tajo-core/tajo-core-backend/src/main/java/tajo/worker/dataserver/retriever/DataRetriever.java
index 34243a6..83d0540 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/worker/dataserver/retriever/DataRetriever.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/worker/dataserver/retriever/DataRetriever.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.worker.dataserver.retriever;
 
 import org.jboss.netty.channel.ChannelHandlerContext;
@@ -5,10 +23,7 @@ import org.jboss.netty.handler.codec.http.HttpRequest;
 
 import java.io.IOException;
 
-/**
- * @author Hyunsik Choi
- */
-public interface DataRetriever {  
+public interface DataRetriever {
   FileChunk [] handle(ChannelHandlerContext ctx, HttpRequest request)
       throws IOException;
 }

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/worker/dataserver/retriever/DirectoryRetriever.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/worker/dataserver/retriever/DirectoryRetriever.java b/tajo-core/tajo-core-backend/src/main/java/tajo/worker/dataserver/retriever/DirectoryRetriever.java
index c39fb87..bd44878 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/worker/dataserver/retriever/DirectoryRetriever.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/worker/dataserver/retriever/DirectoryRetriever.java
@@ -1,6 +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.worker.dataserver.retriever;
 
 import org.jboss.netty.channel.ChannelHandlerContext;
@@ -12,9 +27,6 @@ import java.io.File;
 import java.io.FileNotFoundException;
 import java.io.IOException;
 
-/**
- * @author Hyunsik Choi
- */
 public class DirectoryRetriever implements DataRetriever {
   public String baseDir;
   

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/worker/dataserver/retriever/FileChunk.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/worker/dataserver/retriever/FileChunk.java b/tajo-core/tajo-core-backend/src/main/java/tajo/worker/dataserver/retriever/FileChunk.java
index 87d46fe..9af274b 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/worker/dataserver/retriever/FileChunk.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/worker/dataserver/retriever/FileChunk.java
@@ -1,11 +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.worker.dataserver.retriever;
 
 import java.io.File;
 import java.io.FileNotFoundException;
 
-/**
- * @author Hyunsik Choi
- */
 public class FileChunk {
   private final File file;
   private final long startOffset;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/worker/dataserver/retriever/RetrieverHandler.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/worker/dataserver/retriever/RetrieverHandler.java b/tajo-core/tajo-core-backend/src/main/java/tajo/worker/dataserver/retriever/RetrieverHandler.java
index 9f7f9a3..ae2d5c4 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/worker/dataserver/retriever/RetrieverHandler.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/worker/dataserver/retriever/RetrieverHandler.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.worker.dataserver.retriever;
 
 import java.io.IOException;
 import java.util.List;
 import java.util.Map;
 
-/**
- * @author Hyunsik Choi
- */
 public interface RetrieverHandler {
   /**
    *

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/proto/CatalogProtocol.proto
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/proto/CatalogProtocol.proto b/tajo-core/tajo-core-backend/src/main/proto/CatalogProtocol.proto
index 7e4f70e..d273059 100644
--- a/tajo-core/tajo-core-backend/src/main/proto/CatalogProtocol.proto
+++ b/tajo-core/tajo-core-backend/src/main/proto/CatalogProtocol.proto
@@ -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/proto/CatalogProtos.proto
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/proto/CatalogProtos.proto b/tajo-core/tajo-core-backend/src/main/proto/CatalogProtos.proto
index 5464139..dd1bf69 100644
--- a/tajo-core/tajo-core-backend/src/main/proto/CatalogProtos.proto
+++ b/tajo-core/tajo-core-backend/src/main/proto/CatalogProtos.proto
@@ -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.
+ */
+
 option java_package = "tajo.catalog.proto";
 option java_outer_classname = "CatalogProtos";
 option optimize_for = SPEED;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/proto/ClientProtocol.proto
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/proto/ClientProtocol.proto b/tajo-core/tajo-core-backend/src/main/proto/ClientProtocol.proto
index 7634814..e78c87f 100644
--- a/tajo-core/tajo-core-backend/src/main/proto/ClientProtocol.proto
+++ b/tajo-core/tajo-core-backend/src/main/proto/ClientProtocol.proto
@@ -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/proto/MasterWorkerProtocol.proto
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/proto/MasterWorkerProtocol.proto b/tajo-core/tajo-core-backend/src/main/proto/MasterWorkerProtocol.proto
index fc180e2..c2f2aab 100644
--- a/tajo-core/tajo-core-backend/src/main/proto/MasterWorkerProtocol.proto
+++ b/tajo-core/tajo-core-backend/src/main/proto/MasterWorkerProtocol.proto
@@ -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/proto/MasterWorkerProtos.proto
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/proto/MasterWorkerProtos.proto b/tajo-core/tajo-core-backend/src/main/proto/MasterWorkerProtos.proto
index f337e4b..d8863e4 100644
--- a/tajo-core/tajo-core-backend/src/main/proto/MasterWorkerProtos.proto
+++ b/tajo-core/tajo-core-backend/src/main/proto/MasterWorkerProtos.proto
@@ -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.
+ */
+
 option java_package = "tajo.engine";
 option java_outer_classname = "MasterWorkerProtos";
 option java_generic_services = false;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/proto/PrimitiveProtos.proto
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/proto/PrimitiveProtos.proto b/tajo-core/tajo-core-backend/src/main/proto/PrimitiveProtos.proto
index 64893cb..5fa6903 100644
--- a/tajo-core/tajo-core-backend/src/main/proto/PrimitiveProtos.proto
+++ b/tajo-core/tajo-core-backend/src/main/proto/PrimitiveProtos.proto
@@ -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/proto/TajoIdProtos.proto
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/proto/TajoIdProtos.proto b/tajo-core/tajo-core-backend/src/main/proto/TajoIdProtos.proto
index 6ab0b09..abd47c0 100644
--- a/tajo-core/tajo-core-backend/src/main/proto/TajoIdProtos.proto
+++ b/tajo-core/tajo-core-backend/src/main/proto/TajoIdProtos.proto
@@ -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.
+ */
+
 option java_package = "tajo";
 option java_outer_classname = "TajoIdProtos";
 option java_generic_services = false;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/proto/tajo_protos.proto
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/proto/tajo_protos.proto b/tajo-core/tajo-core-backend/src/main/proto/tajo_protos.proto
index c8857d9..d4d2fee 100644
--- a/tajo-core/tajo-core-backend/src/main/proto/tajo_protos.proto
+++ b/tajo-core/tajo-core-backend/src/main/proto/tajo_protos.proto
@@ -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.
+ */
+
 option java_package = "tajo";
 option java_outer_classname = "TajoProtos";
 option java_generic_services = false;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/resources/log4j.properties
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/resources/log4j.properties b/tajo-core/tajo-core-backend/src/main/resources/log4j.properties
index f46fffb..2b42975 100644
--- a/tajo-core/tajo-core-backend/src/main/resources/log4j.properties
+++ b/tajo-core/tajo-core-backend/src/main/resources/log4j.properties
@@ -1,14 +1,20 @@
-#   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://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.
 #
-#   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.
 
 # log4j configuration used during build and unit tests
 

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/resources/tajo-default.xml
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/resources/tajo-default.xml b/tajo-core/tajo-core-backend/src/main/resources/tajo-default.xml
index 21f47a3..c003637 100644
--- a/tajo-core/tajo-core-backend/src/main/resources/tajo-default.xml
+++ b/tajo-core/tajo-core-backend/src/main/resources/tajo-default.xml
@@ -1,6 +1,24 @@
 <?xml version="1.0"?>
 <?xml-stylesheet type="text/xsl" href="configuration.xsl"?>
 
+<!--
+  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.
+  -->
+
 <configuration>
   <property>
     <name>tajo.cluster.distributed</name>

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/resources/webapps/admin/catalogview.jsp
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/resources/webapps/admin/catalogview.jsp b/tajo-core/tajo-core-backend/src/main/resources/webapps/admin/catalogview.jsp
index 0a22c60..bc58b2c 100644
--- a/tajo-core/tajo-core-backend/src/main/resources/webapps/admin/catalogview.jsp
+++ b/tajo-core/tajo-core-backend/src/main/resources/webapps/admin/catalogview.jsp
@@ -1,6 +1,23 @@
 <%@ page language="java" contentType="text/html; charset=UTF-8"
     pageEncoding="UTF-8"%>
-   
+<%--
+  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.
+-- %>
+
 <%@ page import="java.util.*" %>
 <%@ page import="nta.engine.cluster.ClusterManager" %>
 <%@ page import="com.google.gson.Gson" %>

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/resources/webapps/admin/index.jsp
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/resources/webapps/admin/index.jsp b/tajo-core/tajo-core-backend/src/main/resources/webapps/admin/index.jsp
index 2fc2e50..3e8af74 100644
--- a/tajo-core/tajo-core-backend/src/main/resources/webapps/admin/index.jsp
+++ b/tajo-core/tajo-core-backend/src/main/resources/webapps/admin/index.jsp
@@ -1,6 +1,23 @@
 <%@ page language="java" contentType="text/html; charset=UTF-8"
     pageEncoding="UTF-8"%>
-   
+<%--
+  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.
+-- %>
+
 <%@ page import="java.util.*" %>
 <%@ page import="tajo.webapp.StaticHttpServer" %>
 <%@ page import="nta.catalog.*" %>

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/resources/webapps/admin/nodedetail.jsp
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/resources/webapps/admin/nodedetail.jsp b/tajo-core/tajo-core-backend/src/main/resources/webapps/admin/nodedetail.jsp
index 9bbf230..45cac31 100644
--- a/tajo-core/tajo-core-backend/src/main/resources/webapps/admin/nodedetail.jsp
+++ b/tajo-core/tajo-core-backend/src/main/resources/webapps/admin/nodedetail.jsp
@@ -1,6 +1,23 @@
 <%@ page language="java" contentType="text/html; charset=UTF-8"
     pageEncoding="UTF-8"%>
-   
+<%--
+  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.
+-- %>
+
 <%@ page import="java.util.*" %>
 <%@ page import="java.net.InetAddress" %>
 <%@ page import = "java.io.*" %>

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/resources/webapps/admin/nodeview.jsp
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/resources/webapps/admin/nodeview.jsp b/tajo-core/tajo-core-backend/src/main/resources/webapps/admin/nodeview.jsp
index ffd2c9f..a709c48 100644
--- a/tajo-core/tajo-core-backend/src/main/resources/webapps/admin/nodeview.jsp
+++ b/tajo-core/tajo-core-backend/src/main/resources/webapps/admin/nodeview.jsp
@@ -1,6 +1,23 @@
 <%@ page language="java" contentType="text/html; charset=UTF-8"
     pageEncoding="UTF-8"%>
-   
+<%--
+  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.
+-- %>
+
 <%@ page import="java.util.*" %>
 <%@ page import="java.net.InetAddress" %>
 <%@ page import = "java.io.*" %>

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/resources/webapps/admin/queryview.jsp
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/resources/webapps/admin/queryview.jsp b/tajo-core/tajo-core-backend/src/main/resources/webapps/admin/queryview.jsp
index 91418b0..673ab0d 100644
--- a/tajo-core/tajo-core-backend/src/main/resources/webapps/admin/queryview.jsp
+++ b/tajo-core/tajo-core-backend/src/main/resources/webapps/admin/queryview.jsp
@@ -1,6 +1,23 @@
 <%@ page language="java" contentType="text/html; charset=UTF-8"
     pageEncoding="UTF-8"%>
-   
+<%--
+  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.
+-- %>
+
 <%@ page import="java.util.*" %>
 <%@ page import="tajo.webapp.StaticHttpServer" %>
 <%@ page import="nta.engine.*" %>

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/resources/webapps/admin/style.css
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/resources/webapps/admin/style.css b/tajo-core/tajo-core-backend/src/main/resources/webapps/admin/style.css
index b971c56..628e7bc 100644
--- a/tajo-core/tajo-core-backend/src/main/resources/webapps/admin/style.css
+++ b/tajo-core/tajo-core-backend/src/main/resources/webapps/admin/style.css
@@ -1,4 +1,22 @@
-<style type="text/css" > 
+/*
+ * 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.
+ */
+
+<style type="text/css" >
      
      h5 {}
      h1 {

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/test/java/log4j.properties
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/java/log4j.properties b/tajo-core/tajo-core-backend/src/test/java/log4j.properties
index c557d8f..c1ac487 100644
--- a/tajo-core/tajo-core-backend/src/test/java/log4j.properties
+++ b/tajo-core/tajo-core-backend/src/test/java/log4j.properties
@@ -1,14 +1,20 @@
-#   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://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.
 #
-#   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.
 
 # log4j configuration used during build and unit tests
 

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/test/java/tajo/BackendTestingUtil.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/java/tajo/BackendTestingUtil.java b/tajo-core/tajo-core-backend/src/test/java/tajo/BackendTestingUtil.java
index c7b21e7..1db61c2 100644
--- a/tajo-core/tajo-core-backend/src/test/java/tajo/BackendTestingUtil.java
+++ b/tajo-core/tajo-core-backend/src/test/java/tajo/BackendTestingUtil.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/test/java/tajo/IntegrationTest.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/java/tajo/IntegrationTest.java b/tajo-core/tajo-core-backend/src/test/java/tajo/IntegrationTest.java
index 91ba00b..4c8a29f 100644
--- a/tajo-core/tajo-core-backend/src/test/java/tajo/IntegrationTest.java
+++ b/tajo-core/tajo-core-backend/src/test/java/tajo/IntegrationTest.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;
 
 public interface IntegrationTest {

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/test/java/tajo/LocalTajoTestingUtility.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/java/tajo/LocalTajoTestingUtility.java b/tajo-core/tajo-core-backend/src/test/java/tajo/LocalTajoTestingUtility.java
index d3c63d0..9ce3383 100644
--- a/tajo-core/tajo-core-backend/src/test/java/tajo/LocalTajoTestingUtility.java
+++ b/tajo-core/tajo-core-backend/src/test/java/tajo/LocalTajoTestingUtility.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;
 
 import com.google.protobuf.ServiceException;
@@ -14,9 +32,6 @@ import tajo.conf.TajoConf;
 import java.io.IOException;
 import java.sql.ResultSet;
 
-/**
- * @author Hyunsik Choi
- */
 public class LocalTajoTestingUtility {
   private TajoTestingCluster util;
   private TajoConf conf;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/test/java/tajo/MiniTajoYarnCluster.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/java/tajo/MiniTajoYarnCluster.java b/tajo-core/tajo-core-backend/src/test/java/tajo/MiniTajoYarnCluster.java
index 31491aa..e3e7a3f 100644
--- a/tajo-core/tajo-core-backend/src/test/java/tajo/MiniTajoYarnCluster.java
+++ b/tajo-core/tajo-core-backend/src/test/java/tajo/MiniTajoYarnCluster.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/test/java/tajo/TajoTestingCluster.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/java/tajo/TajoTestingCluster.java b/tajo-core/tajo-core-backend/src/test/java/tajo/TajoTestingCluster.java
index e9df9a3..75fde3c 100644
--- a/tajo-core/tajo-core-backend/src/test/java/tajo/TajoTestingCluster.java
+++ b/tajo-core/tajo-core-backend/src/test/java/tajo/TajoTestingCluster.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/test/java/tajo/TestQueryIdFactory.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/java/tajo/TestQueryIdFactory.java b/tajo-core/tajo-core-backend/src/test/java/tajo/TestQueryIdFactory.java
index 141eb33..c455ec6 100644
--- a/tajo-core/tajo-core-backend/src/test/java/tajo/TestQueryIdFactory.java
+++ b/tajo-core/tajo-core-backend/src/test/java/tajo/TestQueryIdFactory.java
@@ -1,6 +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;
 
 import org.junit.Before;
@@ -8,10 +23,6 @@ import org.junit.Test;
 
 import static org.junit.Assert.assertTrue;
 
-/**
- * @author jihoon
- *
- */
 public class TestQueryIdFactory {
   
   @Before

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/test/java/tajo/TestQueryUnitId.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/java/tajo/TestQueryUnitId.java b/tajo-core/tajo-core-backend/src/test/java/tajo/TestQueryUnitId.java
index 6b97131..867d541 100644
--- a/tajo-core/tajo-core-backend/src/test/java/tajo/TestQueryUnitId.java
+++ b/tajo-core/tajo-core-backend/src/test/java/tajo/TestQueryUnitId.java
@@ -1,4 +1,4 @@
-/*
+/**
  * 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
@@ -25,9 +25,6 @@ import tajo.util.TajoIdUtils;
 
 import static org.junit.Assert.*;
 
-/**
- * @author Hyunsik Choi
- */
 public class TestQueryUnitId {
   @Test
   public void testQueryId() {

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/test/java/tajo/TpchTestBase.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/java/tajo/TpchTestBase.java b/tajo-core/tajo-core-backend/src/test/java/tajo/TpchTestBase.java
index aa362d2..809df1b 100644
--- a/tajo-core/tajo-core-backend/src/test/java/tajo/TpchTestBase.java
+++ b/tajo-core/tajo-core-backend/src/test/java/tajo/TpchTestBase.java
@@ -1,7 +1,11 @@
-/*
- * 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/test/java/tajo/benchmark/TestTPCH.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/java/tajo/benchmark/TestTPCH.java b/tajo-core/tajo-core-backend/src/test/java/tajo/benchmark/TestTPCH.java
index 889ec91..a325cae 100644
--- a/tajo-core/tajo-core-backend/src/test/java/tajo/benchmark/TestTPCH.java
+++ b/tajo-core/tajo-core-backend/src/test/java/tajo/benchmark/TestTPCH.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/test/java/tajo/client/TestTajoClient.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/java/tajo/client/TestTajoClient.java b/tajo-core/tajo-core-backend/src/test/java/tajo/client/TestTajoClient.java
index 4b9f099..ff7a292 100644
--- a/tajo-core/tajo-core-backend/src/test/java/tajo/client/TestTajoClient.java
+++ b/tajo-core/tajo-core-backend/src/test/java/tajo/client/TestTajoClient.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.client;
 
 import com.google.common.collect.Sets;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/test/java/tajo/cluster/TestServerName.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/java/tajo/cluster/TestServerName.java b/tajo-core/tajo-core-backend/src/test/java/tajo/cluster/TestServerName.java
index 55e3a65..3a6f053 100644
--- a/tajo-core/tajo-core-backend/src/test/java/tajo/cluster/TestServerName.java
+++ b/tajo-core/tajo-core-backend/src/test/java/tajo/cluster/TestServerName.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.cluster;
 
 import org.junit.Test;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/test/java/tajo/engine/eval/TestEvalTree.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/eval/TestEvalTree.java b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/eval/TestEvalTree.java
index fd78914..6e811b6 100644
--- a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/eval/TestEvalTree.java
+++ b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/eval/TestEvalTree.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/test/java/tajo/engine/eval/TestEvalTreeUtil.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/eval/TestEvalTreeUtil.java b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/eval/TestEvalTreeUtil.java
index abb8cda..0bb9b32 100644
--- a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/eval/TestEvalTreeUtil.java
+++ b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/eval/TestEvalTreeUtil.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
@@ -47,9 +45,6 @@ import java.util.Set;
 import static org.junit.Assert.assertEquals;
 import static org.junit.Assert.assertTrue;
 
-/**
- * @author Hyunsik Choi
- */
 public class TestEvalTreeUtil {
   static TajoTestingCluster util;
   static CatalogService catalog = null;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/test/java/tajo/engine/function/TestAggFunction.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/function/TestAggFunction.java b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/function/TestAggFunction.java
index bdd25e4..35c8859 100644
--- a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/function/TestAggFunction.java
+++ b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/function/TestAggFunction.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 static org.junit.Assert.assertTrue;
 
-/**
- * @author Hyunsik Choi
- */
 public class TestAggFunction {
 
   @Test

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/test/java/tajo/engine/function/TestBuiltinFunctions.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/function/TestBuiltinFunctions.java b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/function/TestBuiltinFunctions.java
index 2fdbe7e..abcbbed 100644
--- a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/function/TestBuiltinFunctions.java
+++ b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/function/TestBuiltinFunctions.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.function;
 
 import com.google.common.collect.Maps;
@@ -15,9 +33,6 @@ import java.util.Map;
 import static org.junit.Assert.assertEquals;
 import static org.junit.Assert.assertTrue;
 
-/**
- * @author Hyunsik Choi
- */
 @Category(IntegrationTest.class)
 public class TestBuiltinFunctions {
   static TpchTestBase tpch;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/test/java/tajo/engine/function/TestGeneralFunction.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/function/TestGeneralFunction.java b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/function/TestGeneralFunction.java
index e4fe9a6..5a85eeb 100644
--- a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/function/TestGeneralFunction.java
+++ b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/function/TestGeneralFunction.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.function;
 
 import org.junit.Test;
@@ -12,9 +30,6 @@ import java.util.Calendar;
 
 import static org.junit.Assert.assertEquals;
 
-/**
- * @author jihoon
- */
 public class TestGeneralFunction {
 
   @Test

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/test/java/tajo/engine/parser/TestNQLParser.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/parser/TestNQLParser.java b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/parser/TestNQLParser.java
index 2cd8587..ae72ee4 100644
--- a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/parser/TestNQLParser.java
+++ b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/parser/TestNQLParser.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.parser;
 
 import org.antlr.runtime.ANTLRStringStream;
@@ -11,13 +29,6 @@ import tajo.engine.query.exception.TQLSyntaxError;
 import static org.junit.Assert.assertEquals;
 import static org.junit.Assert.assertNull;
 
-/**
- * 이 클래스는 작성된 Antlr룰에 따라 생성되는 파서의 
- * abstract syntext tree가 예상되로 구성되는지 테스트 한다.
- * 
- * @author Hyunsik Choi
- * 
- */
 public class TestNQLParser {
   static final String[] selQueries = {
       "select id, name, age, gender from people", // 0


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

Posted by hy...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/statistics/StatisticsUtil.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/statistics/StatisticsUtil.java b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/statistics/StatisticsUtil.java
index 7661c0d..ee5ca68 100644
--- a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/statistics/StatisticsUtil.java
+++ b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/statistics/StatisticsUtil.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 org.apache.commons.logging.LogFactory;
 
 import java.util.List;
 
-/**
- * @author Hyunsik Choi
- */
 public class StatisticsUtil {
   private static final Log LOG = LogFactory.getLog(StatisticsUtil.class);
 

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/statistics/TableStat.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/statistics/TableStat.java b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/statistics/TableStat.java
index 6488cee..973865a 100644
--- a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/statistics/TableStat.java
+++ b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/statistics/TableStat.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,9 +33,6 @@ import tajo.common.ProtoObject;
 import java.util.ArrayList;
 import java.util.List;
 
-/**
- * @author Hyunsik Choi
- */
 public class TableStat implements ProtoObject<TableStatProto>, Cloneable {
   private TableStatProto proto = TableStatProto.getDefaultInstance();
   private TableStatProto.Builder builder = null;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/statistics/TupleUtil.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/statistics/TupleUtil.java b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/statistics/TupleUtil.java
index deaf4f6..ab3038c 100644
--- a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/statistics/TupleUtil.java
+++ b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/statistics/TupleUtil.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-catalog/tajo-catalog-common/src/main/proto/CatalogProtos.proto
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/src/main/proto/CatalogProtos.proto b/tajo-catalog/tajo-catalog-common/src/main/proto/CatalogProtos.proto
index 5464139..dd1bf69 100644
--- a/tajo-catalog/tajo-catalog-common/src/main/proto/CatalogProtos.proto
+++ b/tajo-catalog/tajo-catalog-common/src/main/proto/CatalogProtos.proto
@@ -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.
+ */
+
 option java_package = "tajo.catalog.proto";
 option java_outer_classname = "CatalogProtos";
 option optimize_for = SPEED;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/TestCatalogUtil.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/TestCatalogUtil.java b/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/TestCatalogUtil.java
index a3fd09d..5d85461 100644
--- a/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/TestCatalogUtil.java
+++ b/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/TestCatalogUtil.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-catalog/tajo-catalog-common/src/test/java/tajo/catalog/TestColumn.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/TestColumn.java b/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/TestColumn.java
index 359b696..2502b82 100644
--- a/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/TestColumn.java
+++ b/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/TestColumn.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,12 +27,7 @@ import tajo.catalog.proto.CatalogProtos.DataType;
 import static org.junit.Assert.assertEquals;
 import static org.junit.Assert.assertTrue;
 
-/**
- * 
- * @author Hyunsik Choi
- *
- */
-public class TestColumn {	
+public class TestColumn {
 	static final String FieldName1="f1";
 	static final String FieldName2="f2";
 	static final String FieldName3="f3";	

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/TestFunctionDesc.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/TestFunctionDesc.java b/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/TestFunctionDesc.java
index 54ad2be..49fc09f 100644
--- a/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/TestFunctionDesc.java
+++ b/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/TestFunctionDesc.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-catalog/tajo-catalog-common/src/test/java/tajo/catalog/TestIndexDesc.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/TestIndexDesc.java b/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/TestIndexDesc.java
index 3218973..afbfe5a 100644
--- a/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/TestIndexDesc.java
+++ b/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/TestIndexDesc.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.catalog;
 
 import org.junit.AfterClass;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/TestOptions.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/TestOptions.java b/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/TestOptions.java
index ad75989..045e8c7 100644
--- a/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/TestOptions.java
+++ b/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/TestOptions.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.catalog;
 
 import org.junit.Test;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/TestSchema.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/TestSchema.java b/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/TestSchema.java
index 6d70bb6..8b5bee3 100644
--- a/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/TestSchema.java
+++ b/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/TestSchema.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-catalog/tajo-catalog-common/src/test/java/tajo/catalog/TestTableDesc.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/TestTableDesc.java b/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/TestTableDesc.java
index 018b528..f3c60cf 100644
--- a/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/TestTableDesc.java
+++ b/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/TestTableDesc.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-catalog/tajo-catalog-common/src/test/java/tajo/catalog/TestTableInfo.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/TestTableInfo.java b/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/TestTableInfo.java
index cc4d760..052bbfe 100644
--- a/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/TestTableInfo.java
+++ b/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/TestTableInfo.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.catalog;
 
 import org.junit.Before;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/TestTableMeta.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/TestTableMeta.java b/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/TestTableMeta.java
index 463c0e3..e388375 100644
--- a/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/TestTableMeta.java
+++ b/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/TestTableMeta.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.catalog;
 
 import org.junit.Before;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/statistics/TestColumnStat.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/statistics/TestColumnStat.java b/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/statistics/TestColumnStat.java
index 017f336..9af4453 100644
--- a/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/statistics/TestColumnStat.java
+++ b/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/statistics/TestColumnStat.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.catalog.statistics;
 
 import org.junit.Test;
@@ -8,9 +26,6 @@ import tajo.datum.DatumFactory;
 import static org.junit.Assert.assertEquals;
 import static org.junit.Assert.assertTrue;
 
-/**
- * @author Hyunsik Choi
- */
 public class TestColumnStat {
 
   @Test

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/statistics/TestStatSet.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/statistics/TestStatSet.java b/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/statistics/TestStatSet.java
index b83aa96..3b03ddf 100644
--- a/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/statistics/TestStatSet.java
+++ b/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/statistics/TestStatSet.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-catalog/tajo-catalog-common/src/test/java/tajo/catalog/statistics/TestStatisticsUtil.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/statistics/TestStatisticsUtil.java b/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/statistics/TestStatisticsUtil.java
index 733d2de..9fa2d6e 100644
--- a/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/statistics/TestStatisticsUtil.java
+++ b/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/statistics/TestStatisticsUtil.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-catalog/tajo-catalog-common/src/test/java/tajo/catalog/statistics/TestTableStat.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/statistics/TestTableStat.java b/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/statistics/TestTableStat.java
index ff4d51b..3237d25 100644
--- a/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/statistics/TestTableStat.java
+++ b/tajo-catalog/tajo-catalog-common/src/test/java/tajo/catalog/statistics/TestTableStat.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,9 +25,6 @@ import tajo.catalog.proto.CatalogProtos;
 import static org.junit.Assert.assertEquals;
 import static org.junit.Assert.assertTrue;
 
-/**
- * @author Hyunsik Choi
- */
 public class TestTableStat {
   @Test
   public final void testTableStat() throws CloneNotSupportedException {

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-server/pom.xml
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-server/pom.xml b/tajo-catalog/tajo-catalog-server/pom.xml
index 3f07ba2..e72dd09 100644
--- a/tajo-catalog/tajo-catalog-server/pom.xml
+++ b/tajo-catalog/tajo-catalog-server/pom.xml
@@ -1,10 +1,12 @@
 <?xml version="1.0" encoding="UTF-8"?>
 <!--
-  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-catalog/tajo-catalog-server/src/main/java/tajo/catalog/AlreadyRegisteredURIException.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-server/src/main/java/tajo/catalog/AlreadyRegisteredURIException.java b/tajo-catalog/tajo-catalog-server/src/main/java/tajo/catalog/AlreadyRegisteredURIException.java
index db8fa20..5aa1cb1 100644
--- a/tajo-catalog/tajo-catalog-server/src/main/java/tajo/catalog/AlreadyRegisteredURIException.java
+++ b/tajo-catalog/tajo-catalog-server/src/main/java/tajo/catalog/AlreadyRegisteredURIException.java
@@ -1,14 +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.catalog;
 
 import java.net.URI;
 
-/**
- * @author Hyunsik Choi
- *
- */
 public class AlreadyRegisteredURIException extends RuntimeException {
 
 	private static final long serialVersionUID = 747390434221048348L;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-server/src/main/java/tajo/catalog/CatalogServer.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-server/src/main/java/tajo/catalog/CatalogServer.java b/tajo-catalog/tajo-catalog-server/src/main/java/tajo/catalog/CatalogServer.java
index 96cae1c..85600a8 100644
--- a/tajo-catalog/tajo-catalog-server/src/main/java/tajo/catalog/CatalogServer.java
+++ b/tajo-catalog/tajo-catalog-server/src/main/java/tajo/catalog/CatalogServer.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
  *
@@ -47,8 +49,6 @@ import java.util.concurrent.locks.ReentrantReadWriteLock;
  * This class provides the catalog service. The catalog service enables clients
  * to register, unregister and access information about tables, functions, and
  * cluster information.
- *
- * @author Hyunsik Choi
  */
 public class CatalogServer extends AbstractService {
 

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-server/src/main/java/tajo/catalog/LocalCatalog.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-server/src/main/java/tajo/catalog/LocalCatalog.java b/tajo-catalog/tajo-catalog-server/src/main/java/tajo/catalog/LocalCatalog.java
index fa84faa..6856736 100644
--- a/tajo-catalog/tajo-catalog-server/src/main/java/tajo/catalog/LocalCatalog.java
+++ b/tajo-catalog/tajo-catalog-server/src/main/java/tajo/catalog/LocalCatalog.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 java.io.IOException;
 /**
  * This class provides a catalog service interface in
  * local.
- *
- * @author Hyunsik Choi
- *
  */
 public class LocalCatalog extends AbstractCatalogClient {
   private static final Log LOG = LogFactory.getLog(LocalCatalog.class);

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-server/src/main/java/tajo/catalog/MiniCatalogServer.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-server/src/main/java/tajo/catalog/MiniCatalogServer.java b/tajo-catalog/tajo-catalog-server/src/main/java/tajo/catalog/MiniCatalogServer.java
index aea4e14..5117fe4 100644
--- a/tajo-catalog/tajo-catalog-server/src/main/java/tajo/catalog/MiniCatalogServer.java
+++ b/tajo-catalog/tajo-catalog-server/src/main/java/tajo/catalog/MiniCatalogServer.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,19 +16,12 @@
  * limitations under the License.
  */
 
-/**
- * 
- */
 package tajo.catalog;
 
 import tajo.conf.TajoConf;
 
 import java.io.IOException;
 
-/**
- * @author Hyunsik Choi
- *
- */
 public class MiniCatalogServer {
   private CatalogServer catalogServers;
   

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-server/src/main/java/tajo/catalog/store/CatalogStore.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-server/src/main/java/tajo/catalog/store/CatalogStore.java b/tajo-catalog/tajo-catalog-server/src/main/java/tajo/catalog/store/CatalogStore.java
index 15a1e6d..c4c7eaa 100644
--- a/tajo-catalog/tajo-catalog-server/src/main/java/tajo/catalog/store/CatalogStore.java
+++ b/tajo-catalog/tajo-catalog-server/src/main/java/tajo/catalog/store/CatalogStore.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.catalog.store;
 
 import tajo.catalog.FunctionDesc;
@@ -8,10 +26,7 @@ import java.io.Closeable;
 import java.io.IOException;
 import java.util.List;
 
-/** 
- * @author Hyunsik Choi
- */
-public interface CatalogStore extends Closeable { 
+public interface CatalogStore extends Closeable {
   void addTable(TableDesc desc) throws IOException;
   
   boolean existTable(String name) throws IOException;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-server/src/main/java/tajo/catalog/store/DBStore.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-server/src/main/java/tajo/catalog/store/DBStore.java b/tajo-catalog/tajo-catalog-server/src/main/java/tajo/catalog/store/DBStore.java
index 6c7bb7f..136872d 100644
--- a/tajo-catalog/tajo-catalog-server/src/main/java/tajo/catalog/store/DBStore.java
+++ b/tajo-catalog/tajo-catalog-server/src/main/java/tajo/catalog/store/DBStore.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
  *
@@ -38,9 +40,6 @@ import java.util.Map.Entry;
 import java.util.concurrent.locks.Lock;
 import java.util.concurrent.locks.ReentrantReadWriteLock;
 
-/**
- * @author Hyunsik Choi
- */
 public class DBStore implements CatalogStore {
   private final Log LOG = LogFactory.getLog(DBStore.class); 
   private final Configuration conf;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-server/src/main/java/tajo/catalog/store/MemStore.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-server/src/main/java/tajo/catalog/store/MemStore.java b/tajo-catalog/tajo-catalog-server/src/main/java/tajo/catalog/store/MemStore.java
index 3f54a4d..cfe68a4 100644
--- a/tajo-catalog/tajo-catalog-server/src/main/java/tajo/catalog/store/MemStore.java
+++ b/tajo-catalog/tajo-catalog-server/src/main/java/tajo/catalog/store/MemStore.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.catalog.store;
@@ -14,9 +32,6 @@ import java.util.ArrayList;
 import java.util.List;
 import java.util.Map;
 
-/**
- * @author Hyunsik Choi
- */
 public class MemStore implements CatalogStore {
   private final Map<String,TableDesc> tables
     = Maps.newHashMap();

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-server/src/main/resources/catalog-default.xml
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-server/src/main/resources/catalog-default.xml b/tajo-catalog/tajo-catalog-server/src/main/resources/catalog-default.xml
index 4cbbe01..218672f 100644
--- a/tajo-catalog/tajo-catalog-server/src/main/resources/catalog-default.xml
+++ b/tajo-catalog/tajo-catalog-server/src/main/resources/catalog-default.xml
@@ -2,11 +2,13 @@
 <?xml-stylesheet type="text/xsl" href="configuration.xsl"?>
 
 <!--
-  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-catalog/tajo-catalog-server/src/test/java/tajo/catalog/TestCatalog.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-server/src/test/java/tajo/catalog/TestCatalog.java b/tajo-catalog/tajo-catalog-server/src/test/java/tajo/catalog/TestCatalog.java
index b0fe626..269d8b4 100644
--- a/tajo-catalog/tajo-catalog-server/src/test/java/tajo/catalog/TestCatalog.java
+++ b/tajo-catalog/tajo-catalog-server/src/test/java/tajo/catalog/TestCatalog.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,12 +35,7 @@ import java.io.IOException;
 
 import static org.junit.Assert.*;
 
-/**
- * 
- * @author Hyunsik Choi
- *
- */
-public class TestCatalog {	
+public class TestCatalog {
 	static final String FieldName1="f1";
 	static final String FieldName2="f2";
 	static final String FieldName3="f3";	

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-server/src/test/java/tajo/catalog/TestDBStore.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-server/src/test/java/tajo/catalog/TestDBStore.java b/tajo-catalog/tajo-catalog-server/src/test/java/tajo/catalog/TestDBStore.java
index c3dc58c..033efa3 100644
--- a/tajo-catalog/tajo-catalog-server/src/test/java/tajo/catalog/TestDBStore.java
+++ b/tajo-catalog/tajo-catalog-server/src/test/java/tajo/catalog/TestDBStore.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
  *
@@ -34,9 +36,6 @@ import java.io.File;
 
 import static org.junit.Assert.*;
 
-/**
- * @author Hyunsik Choi
- */
 public class TestDBStore {
   private static final Log LOG = LogFactory.getLog(TestDBStore.class);  
   private static Configuration conf;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-server/src/test/java/tajo/catalog/statistics/TestColumnStat.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-server/src/test/java/tajo/catalog/statistics/TestColumnStat.java b/tajo-catalog/tajo-catalog-server/src/test/java/tajo/catalog/statistics/TestColumnStat.java
index 017f336..9af4453 100644
--- a/tajo-catalog/tajo-catalog-server/src/test/java/tajo/catalog/statistics/TestColumnStat.java
+++ b/tajo-catalog/tajo-catalog-server/src/test/java/tajo/catalog/statistics/TestColumnStat.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.catalog.statistics;
 
 import org.junit.Test;
@@ -8,9 +26,6 @@ import tajo.datum.DatumFactory;
 import static org.junit.Assert.assertEquals;
 import static org.junit.Assert.assertTrue;
 
-/**
- * @author Hyunsik Choi
- */
 public class TestColumnStat {
 
   @Test

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-server/src/test/java/tajo/catalog/statistics/TestStatSet.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-server/src/test/java/tajo/catalog/statistics/TestStatSet.java b/tajo-catalog/tajo-catalog-server/src/test/java/tajo/catalog/statistics/TestStatSet.java
index b83aa96..3b03ddf 100644
--- a/tajo-catalog/tajo-catalog-server/src/test/java/tajo/catalog/statistics/TestStatSet.java
+++ b/tajo-catalog/tajo-catalog-server/src/test/java/tajo/catalog/statistics/TestStatSet.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-catalog/tajo-catalog-server/src/test/java/tajo/catalog/statistics/TestStatisticsUtil.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-server/src/test/java/tajo/catalog/statistics/TestStatisticsUtil.java b/tajo-catalog/tajo-catalog-server/src/test/java/tajo/catalog/statistics/TestStatisticsUtil.java
index 733d2de..9fa2d6e 100644
--- a/tajo-catalog/tajo-catalog-server/src/test/java/tajo/catalog/statistics/TestStatisticsUtil.java
+++ b/tajo-catalog/tajo-catalog-server/src/test/java/tajo/catalog/statistics/TestStatisticsUtil.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-catalog/tajo-catalog-server/src/test/java/tajo/catalog/statistics/TestTableStat.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-server/src/test/java/tajo/catalog/statistics/TestTableStat.java b/tajo-catalog/tajo-catalog-server/src/test/java/tajo/catalog/statistics/TestTableStat.java
index ff4d51b..3237d25 100644
--- a/tajo-catalog/tajo-catalog-server/src/test/java/tajo/catalog/statistics/TestTableStat.java
+++ b/tajo-catalog/tajo-catalog-server/src/test/java/tajo/catalog/statistics/TestTableStat.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,9 +25,6 @@ import tajo.catalog.proto.CatalogProtos;
 import static org.junit.Assert.assertEquals;
 import static org.junit.Assert.assertTrue;
 
-/**
- * @author Hyunsik Choi
- */
 public class TestTableStat {
   @Test
   public final void testTableStat() throws CloneNotSupportedException {

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-server/src/test/resources/catalog-default.xml
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-server/src/test/resources/catalog-default.xml b/tajo-catalog/tajo-catalog-server/src/test/resources/catalog-default.xml
index c28e32a..2cc8d33 100644
--- a/tajo-catalog/tajo-catalog-server/src/test/resources/catalog-default.xml
+++ b/tajo-catalog/tajo-catalog-server/src/test/resources/catalog-default.xml
@@ -2,11 +2,13 @@
 <?xml-stylesheet type="text/xsl" href="configuration.xsl"?>
 
 <!--
-  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-catalog/tajo-catalog-server/src/test/resources/log4j.properties
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-server/src/test/resources/log4j.properties b/tajo-catalog/tajo-catalog-server/src/test/resources/log4j.properties
index f46fffb..2b42975 100644
--- a/tajo-catalog/tajo-catalog-server/src/test/resources/log4j.properties
+++ b/tajo-catalog/tajo-catalog-server/src/test/resources/log4j.properties
@@ -1,14 +1,20 @@
-#   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://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.
 #
-#   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.
 
 # log4j configuration used during build and unit tests
 

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-common/src/main/java/log4j.properties
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/java/log4j.properties b/tajo-common/src/main/java/log4j.properties
index 0941b49..29cb6a8 100644
--- a/tajo-common/src/main/java/log4j.properties
+++ b/tajo-common/src/main/java/log4j.properties
@@ -1,23 +1,3 @@
-#
-# 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
-# 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.
-#
-
 #   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
@@ -28,7 +8,7 @@
 #   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.
+#   limitations under the License. See accompanying LICENSE file.
 
 # log4j configuration used during build and unit tests
 

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-common/src/main/java/tajo/QueryId.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/java/tajo/QueryId.java b/tajo-common/src/main/java/tajo/QueryId.java
index 0c469f0..64844b4 100644
--- a/tajo-common/src/main/java/tajo/QueryId.java
+++ b/tajo-common/src/main/java/tajo/QueryId.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-common/src/main/java/tajo/QueryIdFactory.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/java/tajo/QueryIdFactory.java b/tajo-common/src/main/java/tajo/QueryIdFactory.java
index cc3b05b..1237037 100644
--- a/tajo-common/src/main/java/tajo/QueryIdFactory.java
+++ b/tajo-common/src/main/java/tajo/QueryIdFactory.java
@@ -1,10 +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-common/src/main/java/tajo/QueryUnitAttemptId.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/java/tajo/QueryUnitAttemptId.java b/tajo-common/src/main/java/tajo/QueryUnitAttemptId.java
index 6d6fc22..71f5e19 100644
--- a/tajo-common/src/main/java/tajo/QueryUnitAttemptId.java
+++ b/tajo-common/src/main/java/tajo/QueryUnitAttemptId.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-common/src/main/java/tajo/QueryUnitId.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/java/tajo/QueryUnitId.java b/tajo-common/src/main/java/tajo/QueryUnitId.java
index e7be242..40096f4 100644
--- a/tajo-common/src/main/java/tajo/QueryUnitId.java
+++ b/tajo-common/src/main/java/tajo/QueryUnitId.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
  *
@@ -24,10 +26,7 @@ import tajo.util.TajoIdUtils;
 
 import java.text.NumberFormat;
 
-/**
- * @author Hyunsik Choi
- */
-public class QueryUnitId implements Comparable<QueryUnitId>, 
+public class QueryUnitId implements Comparable<QueryUnitId>,
   ProtoObject<QueryUnitIdProto> {
   private static final String PREFIX = "t";
 

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-common/src/main/java/tajo/SubQueryId.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/java/tajo/SubQueryId.java b/tajo-common/src/main/java/tajo/SubQueryId.java
index b40965c..5666059 100644
--- a/tajo-common/src/main/java/tajo/SubQueryId.java
+++ b/tajo-common/src/main/java/tajo/SubQueryId.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-common/src/main/java/tajo/TajoConstants.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/java/tajo/TajoConstants.java b/tajo-common/src/main/java/tajo/TajoConstants.java
index 96807c0..e3d339e 100644
--- a/tajo-common/src/main/java/tajo/TajoConstants.java
+++ b/tajo-common/src/main/java/tajo/TajoConstants.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;
 
 public class TajoConstants {

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-common/src/main/java/tajo/common/ProtoObject.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/java/tajo/common/ProtoObject.java b/tajo-common/src/main/java/tajo/common/ProtoObject.java
index a8fff12..7285a54 100644
--- a/tajo-common/src/main/java/tajo/common/ProtoObject.java
+++ b/tajo-common/src/main/java/tajo/common/ProtoObject.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-common/src/main/java/tajo/common/Sleeper.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/java/tajo/common/Sleeper.java b/tajo-common/src/main/java/tajo/common/Sleeper.java
index 04b1647..b71e764 100644
--- a/tajo-common/src/main/java/tajo/common/Sleeper.java
+++ b/tajo-common/src/main/java/tajo/common/Sleeper.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-common/src/main/java/tajo/common/exception/InvalidAddressException.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/java/tajo/common/exception/InvalidAddressException.java b/tajo-common/src/main/java/tajo/common/exception/InvalidAddressException.java
index f4dd4fc..3bb7286 100644
--- a/tajo-common/src/main/java/tajo/common/exception/InvalidAddressException.java
+++ b/tajo-common/src/main/java/tajo/common/exception/InvalidAddressException.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-common/src/main/java/tajo/common/exception/NotImplementedException.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/java/tajo/common/exception/NotImplementedException.java b/tajo-common/src/main/java/tajo/common/exception/NotImplementedException.java
index 696ef37..3c5f7cd 100644
--- a/tajo-common/src/main/java/tajo/common/exception/NotImplementedException.java
+++ b/tajo-common/src/main/java/tajo/common/exception/NotImplementedException.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,14 +20,8 @@ package tajo.common.exception;
 
 public class NotImplementedException extends RuntimeException {
 
-  /**
-   * 
-   */
   private static final long serialVersionUID = 8515328809349325243L;
 
-  /**
-   * 
-   */
   public NotImplementedException() {
   }
 

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-common/src/main/java/tajo/common/type/IPv4.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/java/tajo/common/type/IPv4.java b/tajo-common/src/main/java/tajo/common/type/IPv4.java
index 8f3651b..761cc31 100644
--- a/tajo-common/src/main/java/tajo/common/type/IPv4.java
+++ b/tajo-common/src/main/java/tajo/common/type/IPv4.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-common/src/main/java/tajo/common/type/TimeRange.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/java/tajo/common/type/TimeRange.java b/tajo-common/src/main/java/tajo/common/type/TimeRange.java
index f56b681..ad2e889 100644
--- a/tajo-common/src/main/java/tajo/common/type/TimeRange.java
+++ b/tajo-common/src/main/java/tajo/common/type/TimeRange.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-common/src/main/java/tajo/conf/TajoConf.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/java/tajo/conf/TajoConf.java b/tajo-common/src/main/java/tajo/conf/TajoConf.java
index dce397c..2fc99f5 100644
--- a/tajo-common/src/main/java/tajo/conf/TajoConf.java
+++ b/tajo-common/src/main/java/tajo/conf/TajoConf.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-common/src/main/java/tajo/datum/ArrayDatum.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/java/tajo/datum/ArrayDatum.java b/tajo-common/src/main/java/tajo/datum/ArrayDatum.java
index 6fadee9..12151ed 100644
--- a/tajo-common/src/main/java/tajo/datum/ArrayDatum.java
+++ b/tajo-common/src/main/java/tajo/datum/ArrayDatum.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-common/src/main/java/tajo/datum/BoolDatum.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/java/tajo/datum/BoolDatum.java b/tajo-common/src/main/java/tajo/datum/BoolDatum.java
index 1d7fde5..0b1982a 100644
--- a/tajo-common/src/main/java/tajo/datum/BoolDatum.java
+++ b/tajo-common/src/main/java/tajo/datum/BoolDatum.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-common/src/main/java/tajo/datum/ByteDatum.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/java/tajo/datum/ByteDatum.java b/tajo-common/src/main/java/tajo/datum/ByteDatum.java
index adeeae4..3bce3ff 100644
--- a/tajo-common/src/main/java/tajo/datum/ByteDatum.java
+++ b/tajo-common/src/main/java/tajo/datum/ByteDatum.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-common/src/main/java/tajo/datum/BytesDatum.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/java/tajo/datum/BytesDatum.java b/tajo-common/src/main/java/tajo/datum/BytesDatum.java
index eaef207..1111ead 100644
--- a/tajo-common/src/main/java/tajo/datum/BytesDatum.java
+++ b/tajo-common/src/main/java/tajo/datum/BytesDatum.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,10 +29,6 @@ import java.nio.ByteBuffer;
 import java.nio.charset.Charset;
 import java.util.Arrays;
 
-/**
- * @author Hyunsik Choi
- *
- */
 public class BytesDatum extends Datum {
 	@Expose private byte[] val;
 	private ByteBuffer bb = null;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-common/src/main/java/tajo/datum/CharDatum.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/java/tajo/datum/CharDatum.java b/tajo-common/src/main/java/tajo/datum/CharDatum.java
index 713e689..ff82493 100644
--- a/tajo-common/src/main/java/tajo/datum/CharDatum.java
+++ b/tajo-common/src/main/java/tajo/datum/CharDatum.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-common/src/main/java/tajo/datum/Datum.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/java/tajo/datum/Datum.java b/tajo-common/src/main/java/tajo/datum/Datum.java
index f1bed76..c9e0fb9 100644
--- a/tajo-common/src/main/java/tajo/datum/Datum.java
+++ b/tajo-common/src/main/java/tajo/datum/Datum.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-common/src/main/java/tajo/datum/DatumFactory.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/java/tajo/datum/DatumFactory.java b/tajo-common/src/main/java/tajo/datum/DatumFactory.java
index 6517db7..7f19262 100644
--- a/tajo-common/src/main/java/tajo/datum/DatumFactory.java
+++ b/tajo-common/src/main/java/tajo/datum/DatumFactory.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-common/src/main/java/tajo/datum/DatumType.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/java/tajo/datum/DatumType.java b/tajo-common/src/main/java/tajo/datum/DatumType.java
index 5975ffd..5a26cb8 100644
--- a/tajo-common/src/main/java/tajo/datum/DatumType.java
+++ b/tajo-common/src/main/java/tajo/datum/DatumType.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-common/src/main/java/tajo/datum/DoubleDatum.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/java/tajo/datum/DoubleDatum.java b/tajo-common/src/main/java/tajo/datum/DoubleDatum.java
index a1f7487..0b48fa4 100644
--- a/tajo-common/src/main/java/tajo/datum/DoubleDatum.java
+++ b/tajo-common/src/main/java/tajo/datum/DoubleDatum.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-common/src/main/java/tajo/datum/FloatDatum.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/java/tajo/datum/FloatDatum.java b/tajo-common/src/main/java/tajo/datum/FloatDatum.java
index ec0c2fc..1a6da49 100644
--- a/tajo-common/src/main/java/tajo/datum/FloatDatum.java
+++ b/tajo-common/src/main/java/tajo/datum/FloatDatum.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-common/src/main/java/tajo/datum/IPv4Datum.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/java/tajo/datum/IPv4Datum.java b/tajo-common/src/main/java/tajo/datum/IPv4Datum.java
index 4baecc5..dd3e95b 100644
--- a/tajo-common/src/main/java/tajo/datum/IPv4Datum.java
+++ b/tajo-common/src/main/java/tajo/datum/IPv4Datum.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-common/src/main/java/tajo/datum/IntDatum.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/java/tajo/datum/IntDatum.java b/tajo-common/src/main/java/tajo/datum/IntDatum.java
index a64c617..281aba3 100644
--- a/tajo-common/src/main/java/tajo/datum/IntDatum.java
+++ b/tajo-common/src/main/java/tajo/datum/IntDatum.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-common/src/main/java/tajo/datum/LongDatum.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/java/tajo/datum/LongDatum.java b/tajo-common/src/main/java/tajo/datum/LongDatum.java
index 29ac7c5..ae53224 100644
--- a/tajo-common/src/main/java/tajo/datum/LongDatum.java
+++ b/tajo-common/src/main/java/tajo/datum/LongDatum.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-common/src/main/java/tajo/datum/NullDatum.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/java/tajo/datum/NullDatum.java b/tajo-common/src/main/java/tajo/datum/NullDatum.java
index a6f9ffe..2460a89 100644
--- a/tajo-common/src/main/java/tajo/datum/NullDatum.java
+++ b/tajo-common/src/main/java/tajo/datum/NullDatum.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-common/src/main/java/tajo/datum/NumericDatum.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/java/tajo/datum/NumericDatum.java b/tajo-common/src/main/java/tajo/datum/NumericDatum.java
index d078baa..3a7cb29 100644
--- a/tajo-common/src/main/java/tajo/datum/NumericDatum.java
+++ b/tajo-common/src/main/java/tajo/datum/NumericDatum.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-common/src/main/java/tajo/datum/ShortDatum.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/java/tajo/datum/ShortDatum.java b/tajo-common/src/main/java/tajo/datum/ShortDatum.java
index 2949f77..ff2f79c 100644
--- a/tajo-common/src/main/java/tajo/datum/ShortDatum.java
+++ b/tajo-common/src/main/java/tajo/datum/ShortDatum.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-common/src/main/java/tajo/datum/StringDatum.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/java/tajo/datum/StringDatum.java b/tajo-common/src/main/java/tajo/datum/StringDatum.java
index 0e947c8..8f26c54 100644
--- a/tajo-common/src/main/java/tajo/datum/StringDatum.java
+++ b/tajo-common/src/main/java/tajo/datum/StringDatum.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-common/src/main/java/tajo/datum/StringDatum2.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/java/tajo/datum/StringDatum2.java b/tajo-common/src/main/java/tajo/datum/StringDatum2.java
index 65685ae..8dd7c14 100644
--- a/tajo-common/src/main/java/tajo/datum/StringDatum2.java
+++ b/tajo-common/src/main/java/tajo/datum/StringDatum2.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-common/src/main/java/tajo/datum/exception/InvalidCastException.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/java/tajo/datum/exception/InvalidCastException.java b/tajo-common/src/main/java/tajo/datum/exception/InvalidCastException.java
index d1a0f86..0fa1f8b 100644
--- a/tajo-common/src/main/java/tajo/datum/exception/InvalidCastException.java
+++ b/tajo-common/src/main/java/tajo/datum/exception/InvalidCastException.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
@@ -23,9 +21,6 @@ package tajo.datum.exception;
 public class InvalidCastException extends RuntimeException {
 	private static final long serialVersionUID = -7689027447969916148L;
 
-	/**
-	 * 
-	 */
 	public InvalidCastException() {
 	}
 

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-common/src/main/java/tajo/datum/exception/InvalidOperationException.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/java/tajo/datum/exception/InvalidOperationException.java b/tajo-common/src/main/java/tajo/datum/exception/InvalidOperationException.java
index 8c5332c..5eaa8fe 100644
--- a/tajo-common/src/main/java/tajo/datum/exception/InvalidOperationException.java
+++ b/tajo-common/src/main/java/tajo/datum/exception/InvalidOperationException.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-common/src/main/java/tajo/datum/json/DatumAdapter.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/java/tajo/datum/json/DatumAdapter.java b/tajo-common/src/main/java/tajo/datum/json/DatumAdapter.java
index c27e283..a4328d3 100644
--- a/tajo-common/src/main/java/tajo/datum/json/DatumAdapter.java
+++ b/tajo-common/src/main/java/tajo/datum/json/DatumAdapter.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-common/src/main/java/tajo/datum/json/GsonCreator.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/java/tajo/datum/json/GsonCreator.java b/tajo-common/src/main/java/tajo/datum/json/GsonCreator.java
index 1b6154c..b973e3d 100644
--- a/tajo-common/src/main/java/tajo/datum/json/GsonCreator.java
+++ b/tajo-common/src/main/java/tajo/datum/json/GsonCreator.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-common/src/main/java/tajo/exception/InternalException.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/java/tajo/exception/InternalException.java b/tajo-common/src/main/java/tajo/exception/InternalException.java
index 981afa5..f119773 100644
--- a/tajo-common/src/main/java/tajo/exception/InternalException.java
+++ b/tajo-common/src/main/java/tajo/exception/InternalException.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,17 +23,9 @@ package tajo.exception;
 
 import java.io.IOException;
 
-/**
- * @author hyunsik
- *
- */
 public class InternalException extends IOException {
-
 	private static final long serialVersionUID = -262149616685882358L;
 
-	/**
-	 * 
-	 */
 	public InternalException() {
 	}
 	

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-common/src/main/java/tajo/exception/UnimplementedException.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/java/tajo/exception/UnimplementedException.java b/tajo-common/src/main/java/tajo/exception/UnimplementedException.java
index 0a1d2c3..e0c3f52 100644
--- a/tajo-common/src/main/java/tajo/exception/UnimplementedException.java
+++ b/tajo-common/src/main/java/tajo/exception/UnimplementedException.java
@@ -1,8 +1,23 @@
-package tajo.exception;
-
 /**
- * @author Hyunsik Choi
+ * 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.exception;
+
 public class UnimplementedException extends RuntimeException {
   private static final long serialVersionUID = -5467580471721530536L;
 

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-common/src/main/java/tajo/exception/UnsupportedException.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/java/tajo/exception/UnsupportedException.java b/tajo-common/src/main/java/tajo/exception/UnsupportedException.java
index 72170ee..1d0de75 100644
--- a/tajo-common/src/main/java/tajo/exception/UnsupportedException.java
+++ b/tajo-common/src/main/java/tajo/exception/UnsupportedException.java
@@ -1,8 +1,23 @@
-package tajo.exception;
-
 /**
- * @author Hyunsik Choi
+ * 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.exception;
+
 public class UnsupportedException extends RuntimeException {
   private static final long serialVersionUID = 6702291354858193578L;
 


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

Posted by hy...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/Country.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/Country.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/Country.java
index d701a65..8992f98 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/Country.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/Country.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.function;
 
 import tajo.catalog.Column;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/InCountry.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/InCountry.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/InCountry.java
index 5de0867..a7468fd 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/InCountry.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/InCountry.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.function;
 
 import tajo.catalog.Column;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/AvgDouble.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/AvgDouble.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/AvgDouble.java
index 9c362d7..39d0c28 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/AvgDouble.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/AvgDouble.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.datum.Datum;
 import tajo.datum.DatumFactory;
 import tajo.storage.Tuple;
 
-/**
- * @author Hyunsik Choi
- */
 public class AvgDouble extends AggFunction {
   public AvgDouble() {
     super(new Column[] {

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/AvgFloat.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/AvgFloat.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/AvgFloat.java
index c65b962..babedfd 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/AvgFloat.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/AvgFloat.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.function.builtin;
 
 import tajo.catalog.Column;
@@ -10,9 +28,6 @@ import tajo.datum.DatumFactory;
 import tajo.datum.FloatDatum;
 import tajo.storage.Tuple;
 
-/**
- * @author Hyunsik Choi
- */
 public class AvgFloat extends AggFunction<FloatDatum> {
 
   public AvgFloat() {

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/AvgInt.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/AvgInt.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/AvgInt.java
index 20dd5c1..2f41cf4 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/AvgInt.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/AvgInt.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.datum.DatumFactory;
 import tajo.datum.FloatDatum;
 import tajo.storage.Tuple;
 
-/**
- * @author Hyunsik Choi
- */
 public class AvgInt extends AggFunction<FloatDatum> {
 
   public AvgInt() {

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/AvgLong.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/AvgLong.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/AvgLong.java
index 089b51d..85aefa9 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/AvgLong.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/AvgLong.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
  *
@@ -27,9 +29,6 @@ import tajo.datum.DatumFactory;
 import tajo.datum.DoubleDatum;
 import tajo.storage.Tuple;
 
-/**
- * @author Hyunsik Choi
- */
 public class AvgLong extends AggFunction<DoubleDatum> {
 
   public AvgLong() {

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/CountRows.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/CountRows.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/CountRows.java
index 40eb072..e776de9 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/CountRows.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/CountRows.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.function.builtin;
 
 import tajo.catalog.Column;
@@ -9,9 +27,6 @@ import tajo.datum.DatumFactory;
 import tajo.datum.LongDatum;
 import tajo.storage.Tuple;
 
-/**
- * @author Hyunsik Choi
- */
 public class CountRows extends AggFunction<Datum> {
 
   public CountRows() {

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/CountValue.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/CountValue.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/CountValue.java
index e7a9cac..4eb18e5 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/CountValue.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/CountValue.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.function.builtin;
 
 import tajo.catalog.Column;
@@ -6,9 +24,6 @@ import tajo.catalog.proto.CatalogProtos;
 import tajo.datum.DatumType;
 import tajo.storage.Tuple;
 
-/**
- * @author Hyunsik Choi
- */
 public final class CountValue extends CountRows {
 
   public CountValue() {

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/Date.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/Date.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/Date.java
index 7441744..1d5d64c 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/Date.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/Date.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.function.builtin;
 
 import org.apache.commons.logging.Log;
@@ -13,9 +31,6 @@ import tajo.storage.Tuple;
 import java.text.ParseException;
 import java.text.SimpleDateFormat;
 
-/**
- * @author jihoon
- */
 public class Date extends GeneralFunction<LongDatum> {
   private final Log LOG = LogFactory.getLog(Date.class);
   private final static String dateFormat = "dd/MM/yyyy HH:mm:ss";

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/MaxDouble.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/MaxDouble.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/MaxDouble.java
index ec796b8..8b4db74 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/MaxDouble.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/MaxDouble.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.function.builtin;
 
 import tajo.catalog.Column;
@@ -10,9 +28,6 @@ import tajo.datum.DatumFactory;
 import tajo.datum.DoubleDatum;
 import tajo.storage.Tuple;
 
-/**
- * @author Hyunsik Choi
- */
 public class MaxDouble extends AggFunction<DoubleDatum> {
 
   public MaxDouble() {

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/MaxFloat.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/MaxFloat.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/MaxFloat.java
index 6776463..fdde18c 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/MaxFloat.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/MaxFloat.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.function.builtin;
 
 import tajo.catalog.Column;
@@ -9,9 +27,6 @@ import tajo.datum.Datum;
 import tajo.datum.DatumFactory;
 import tajo.storage.Tuple;
 
-/**
- * @author Hyunsik Choi
- */
 public class MaxFloat extends AggFunction<Datum> {
   public MaxFloat() {
     super(new Column[] {

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/MaxInt.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/MaxInt.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/MaxInt.java
index 6a74e64..25ea8d6 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/MaxInt.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/MaxInt.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.function.builtin;
 
 import tajo.catalog.Column;
@@ -9,9 +27,6 @@ import tajo.datum.Datum;
 import tajo.datum.DatumFactory;
 import tajo.storage.Tuple;
 
-/**
- * @author Hyunsik Choi
- */
 public class MaxInt extends AggFunction<Datum> {
 
   public MaxInt() {

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/MaxLong.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/MaxLong.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/MaxLong.java
index cc91765..24c10d5 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/MaxLong.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/MaxLong.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.function.builtin;
 
 import tajo.catalog.Column;
@@ -10,9 +28,6 @@ import tajo.datum.DatumFactory;
 import tajo.datum.LongDatum;
 import tajo.storage.Tuple;
 
-/**
- * @author Hyunsik Choi
- */
 public class MaxLong extends AggFunction<LongDatum> {
   public MaxLong() {
     super(new Column[] {

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/MinDouble.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/MinDouble.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/MinDouble.java
index 04e8ef6..82b4db0 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/MinDouble.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/MinDouble.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.function.builtin;
 
 import tajo.catalog.Column;
@@ -9,9 +27,6 @@ import tajo.datum.Datum;
 import tajo.datum.DatumFactory;
 import tajo.storage.Tuple;
 
-/**
- * @author Hyunsik Choi
- */
 public class MinDouble extends AggFunction<Datum> {
 
   public MinDouble() {

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/MinFloat.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/MinFloat.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/MinFloat.java
index 7101061..8c6cabd 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/MinFloat.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/MinFloat.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.function.builtin;
 
 import tajo.catalog.Column;
@@ -9,9 +27,6 @@ import tajo.datum.DatumFactory;
 import tajo.datum.FloatDatum;
 import tajo.storage.Tuple;
 
-/**
- * @author Hyunsik Choi
- */
 public class MinFloat extends AggFunction<FloatDatum> {
 
   public MinFloat() {

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/MinInt.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/MinInt.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/MinInt.java
index 7c852ef..90f9be8 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/MinInt.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/MinInt.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.function.builtin;
 
 import tajo.catalog.Column;
@@ -9,9 +27,6 @@ import tajo.datum.Datum;
 import tajo.datum.DatumFactory;
 import tajo.storage.Tuple;
 
-/**
- * @author Hyunsik Choi
- */
 public class MinInt extends AggFunction<Datum> {
 
   public MinInt() {

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/MinLong.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/MinLong.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/MinLong.java
index 576516e..85d484d 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/MinLong.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/MinLong.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.function.builtin;
 
 import tajo.catalog.Column;
@@ -10,9 +28,6 @@ import tajo.datum.DatumFactory;
 import tajo.datum.LongDatum;
 import tajo.storage.Tuple;
 
-/**
- * @author Hyunsik Choi
- */
 public class MinLong extends AggFunction<Datum> {
 
   public MinLong() {

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/MinString.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/MinString.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/MinString.java
index 6c6c7d8..333963e 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/MinString.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/MinString.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.function.builtin;
 
 import tajo.catalog.Column;
@@ -10,9 +28,6 @@ import tajo.datum.DatumFactory;
 import tajo.datum.StringDatum;
 import tajo.storage.Tuple;
 
-/**
- * @author Hyunsik Choi
- */
 public class MinString extends AggFunction<Datum> {
 
   public MinString() {

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/RandomInt.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/RandomInt.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/RandomInt.java
index 9caa437..a38583d 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/RandomInt.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/RandomInt.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.function.builtin;
 
 import tajo.catalog.Column;
@@ -9,9 +27,6 @@ import tajo.storage.Tuple;
 
 import java.util.Random;
 
-/**
- * @author Hyunsik Choi
- */
 public class RandomInt extends GeneralFunction<Datum> {
   private Random random;
 

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/SumDouble.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/SumDouble.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/SumDouble.java
index e85cc47..01754a2 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/SumDouble.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/SumDouble.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.function.builtin;
 
 import tajo.catalog.Column;
@@ -10,9 +28,6 @@ import tajo.datum.DatumFactory;
 import tajo.datum.DoubleDatum;
 import tajo.storage.Tuple;
 
-/**
- * @author Hyunsik Choi
- */
 public class SumDouble extends AggFunction<Datum> {
 
   public SumDouble() {

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/SumFloat.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/SumFloat.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/SumFloat.java
index 39f1a4a..102679d 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/SumFloat.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/SumFloat.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.function.builtin;
 
 import tajo.catalog.Column;
@@ -9,9 +27,6 @@ import tajo.datum.Datum;
 import tajo.datum.DatumFactory;
 import tajo.storage.Tuple;
 
-/**
- * @author Hyunsik Choi
- */
 public class SumFloat extends AggFunction<Datum> {
   public SumFloat() {
     super(new Column[] {

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/SumInt.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/SumInt.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/SumInt.java
index c22e4cd..b180f7a 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/SumInt.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/SumInt.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.function.builtin;
 
 import tajo.catalog.Column;
@@ -9,9 +27,6 @@ import tajo.datum.Datum;
 import tajo.datum.DatumFactory;
 import tajo.storage.Tuple;
 
-/**
- * @author Hyunsik Choi
- */
 public class SumInt extends AggFunction<Datum> {
 
   public SumInt() {

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/SumLong.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/SumLong.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/SumLong.java
index 54c944c..2e4d3c5 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/SumLong.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/SumLong.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.function.builtin;
 
 import tajo.catalog.Column;
@@ -10,9 +28,6 @@ import tajo.datum.DatumFactory;
 import tajo.datum.LongDatum;
 import tajo.storage.Tuple;
 
-/**
- * @author Hyunsik Choi
- */
 public class SumLong extends AggFunction<Datum> {
 
   public SumLong() {

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/Today.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/Today.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/Today.java
index dc16388..a4a334e 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/Today.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/function/builtin/Today.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.function.builtin;
 
 import tajo.catalog.Column;
@@ -7,9 +25,6 @@ import tajo.datum.DatumFactory;
 import tajo.datum.LongDatum;
 import tajo.storage.Tuple;
 
-/**
- * @author jihoon
- */
 public class Today extends GeneralFunction<LongDatum> {
 
   public Today() {

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/json/EvalNodeAdapter.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/json/EvalNodeAdapter.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/json/EvalNodeAdapter.java
index 2e231db..3f03a8a 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/json/EvalNodeAdapter.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/json/EvalNodeAdapter.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
@@ -28,10 +26,6 @@ import tajo.engine.eval.EvalNode;
 
 import java.lang.reflect.Type;
 
-/**
- * @author jihoon
- *
- */
 public class EvalNodeAdapter implements JsonSerializer<EvalNode>, JsonDeserializer<EvalNode> {
 
 	@Override

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/json/FragmentDeserializer.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/json/FragmentDeserializer.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/json/FragmentDeserializer.java
index d7ca6bf..46bd134 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/json/FragmentDeserializer.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/json/FragmentDeserializer.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.json;
@@ -13,10 +31,6 @@ import tajo.storage.Fragment;
 
 import java.lang.reflect.Type;
 
-/**
- * @author jihoon
- *
- */
 public class FragmentDeserializer implements JsonDeserializer<Fragment> {
 
 	@Override

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/json/FromTableDeserializer.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/json/FromTableDeserializer.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/json/FromTableDeserializer.java
index 18c2363..f2c3908 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/json/FromTableDeserializer.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/json/FromTableDeserializer.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.json;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/json/GsonCreator.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/json/GsonCreator.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/json/GsonCreator.java
index c3787c1..087a122 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/json/GsonCreator.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/json/GsonCreator.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/json/LogicalNodeAdapter.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/json/LogicalNodeAdapter.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/json/LogicalNodeAdapter.java
index 02f1eb8..8649002 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/json/LogicalNodeAdapter.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/json/LogicalNodeAdapter.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.json;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/CommandType.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/CommandType.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/CommandType.java
index 82352ea..049171f 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/CommandType.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/CommandType.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.parser;
 
 /**
- * @author Hyunsik Choi
- *
+ * 
  */
+package tajo.engine.parser;
+
 public enum CommandType {
 	// Select
 	SELECT,

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/CopyStmt.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/CopyStmt.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/CopyStmt.java
index 9b41fb1..0ef4c10 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/CopyStmt.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/CopyStmt.java
@@ -1,7 +1,11 @@
-/*
- * 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/parser/CreateIndexStmt.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/CreateIndexStmt.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/CreateIndexStmt.java
index 297d659..0c63c3d 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/CreateIndexStmt.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/CreateIndexStmt.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.parser;
@@ -9,9 +27,6 @@ import tajo.catalog.SortSpec;
 import tajo.catalog.proto.CatalogProtos.IndexMethod;
 import tajo.engine.planner.PlanningContext;
 
-/**
- * @author Hyunsik Choi
- */
 public class CreateIndexStmt extends ParseTree {
   private String idxName;
   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/parser/CreateTableStmt.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/CreateTableStmt.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/CreateTableStmt.java
index efe62e5..816a7f7 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/CreateTableStmt.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/CreateTableStmt.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.parser;
@@ -10,9 +28,6 @@ import tajo.catalog.proto.CatalogProtos.StoreType;
 import tajo.engine.planner.PlanningContext;
 import tajo.engine.planner.PlanningContextImpl;
 
-/**
- * @author Hyunsik Choi
- */
 public class CreateTableStmt extends ParseTree {
   private final String tableName;
   private Schema schema;  

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/EvalTreeBin.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/EvalTreeBin.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/EvalTreeBin.java
index 4c55cd4..45556d3 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/EvalTreeBin.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/EvalTreeBin.java
@@ -1,12 +1,23 @@
-package tajo.engine.parser;
-
 /**
- * 
- * Serialized된 evaluation tree를 담는다. 
- * 
- * @author Hyunsik Choi
+ * 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.parser;
+
 public class EvalTreeBin {
   private byte [] bytecode;
   

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/ParseTree.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/ParseTree.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/ParseTree.java
index 15303ee..2ac52d5 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/ParseTree.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/ParseTree.java
@@ -1,21 +1,19 @@
-/*
- * 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
+ * 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
  *
- *  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://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.
+ * 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.parser;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/ParseUtil.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/ParseUtil.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/ParseUtil.java
index 7ef6c13..b8f0b97 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/ParseUtil.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/ParseUtil.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
@@ -28,9 +26,6 @@ import tajo.catalog.proto.CatalogProtos.IndexMethod;
 import tajo.engine.eval.EvalNode;
 import tajo.engine.eval.InvalidEvalException;
 
-/**
- * @author Hyunsik Choi
- */
 public class ParseUtil {
   private static final Log LOG = LogFactory.getLog(ParseUtil.class);
   

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/ParserException.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/ParserException.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/ParserException.java
index 28db99e..634716e 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/ParserException.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/ParserException.java
@@ -1,11 +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.parser;
 
 /**
- * @author Hyunsik Choi
+ * 
  */
+package tajo.engine.parser;
+
 public class ParserException extends RuntimeException {
   private static final long serialVersionUID = -4392842405539056555L;
 

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/QueryAnalyzer.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/QueryAnalyzer.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/QueryAnalyzer.java
index c1c0f02..8ee1ad6 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/QueryAnalyzer.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/QueryAnalyzer.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
@@ -51,9 +49,7 @@ import java.util.ArrayList;
 import java.util.List;
 
 /**
- * This class transforms a query statement into a QueryBlock. 
- *
- * @author Hyunsik Choi
+ * This class transforms a query statement into a QueryBlock.
  *
  * @see tajo.engine.parser.QueryBlock
  */

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/QueryBlock.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/QueryBlock.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/QueryBlock.java
index cea8b0d..86b37d6 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/QueryBlock.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/QueryBlock.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
@@ -40,10 +38,7 @@ import java.util.Collections;
 import java.util.List;
 
 /**
- * This class contains a set of meta data about a query statement.
- *
- * @author Hyunsik Choi
- *
+ * This class contains a set of meta data about a query statement
  */
 public class QueryBlock extends ParseTree {
   private String storeTable = null;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/SetStmt.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/SetStmt.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/SetStmt.java
index 2d4b13e..ef3ea5e 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/SetStmt.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/SetStmt.java
@@ -1,7 +1,11 @@
-/*
- * 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/parser/StatementType.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/StatementType.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/StatementType.java
index 37ece7d..6926916 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/StatementType.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/StatementType.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.parser;
 
 /**
- * @author Hyunsik Choi
- *
+ * 
  */
+package tajo.engine.parser;
+
 public enum StatementType {
 	// Store
   STORE,

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/TableMap.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/TableMap.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/TableMap.java
index 75d2cba..a250e2c 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/TableMap.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/parser/TableMap.java
@@ -1,4 +1,4 @@
-/*
+/**
  * 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/plan/global/Annotation.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/plan/global/Annotation.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/plan/global/Annotation.java
index 3f656d1..6e62474 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/plan/global/Annotation.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/plan/global/Annotation.java
@@ -1,12 +1,23 @@
 /**
- * 
+ * 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.plan.global;
 
-/**
- * @author jihoon
- *
- */
 public abstract class Annotation {
 
 }

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/plan/global/GenericTask.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/plan/global/GenericTask.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/plan/global/GenericTask.java
index 8e23cc3..ce848e4 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/plan/global/GenericTask.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/plan/global/GenericTask.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.plan.global;
 
 import tajo.engine.planner.logical.ExprType;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/plan/global/GenericTaskGraph.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/plan/global/GenericTaskGraph.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/plan/global/GenericTaskGraph.java
index deb26a9..874dc54 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/plan/global/GenericTaskGraph.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/plan/global/GenericTaskGraph.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.plan.global;
 
 public class GenericTaskGraph {

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/JoinType.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/JoinType.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/JoinType.java
index c44a908..fd8dfce 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/JoinType.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/JoinType.java
@@ -1,10 +1,23 @@
-package tajo.engine.planner;
-
 /**
- * 
- * @author Hyunsik Choi
+ * 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;
+
 public enum JoinType {
   CROSS_JOIN,
   INNER,

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/LogicalOptimizer.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/LogicalOptimizer.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/LogicalOptimizer.java
index 3e134e3..d188dda 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/LogicalOptimizer.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/LogicalOptimizer.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
@@ -51,9 +49,6 @@ import java.util.*;
 
 /**
  * This class optimizes a logical plan corresponding to one query block.
- * 
- * @author Hyunsik Choi
- *
  */
 public class LogicalOptimizer {
   private static Log LOG = LogFactory.getLog(LogicalOptimizer.class);

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/LogicalPlanner.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/LogicalPlanner.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/LogicalPlanner.java
index aa5854e..19f22e2 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/LogicalPlanner.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/LogicalPlanner.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/PhysicalPlanner.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/PhysicalPlanner.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/PhysicalPlanner.java
index ef6a1d9..109468b 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/PhysicalPlanner.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/PhysicalPlanner.java
@@ -1,7 +1,11 @@
-/*
- * 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
  *
@@ -24,9 +28,6 @@ import tajo.exception.InternalException;
 
 /**
  * This class generates a physical execution plan.
- * 
- * @author Hyunsik Choi
- * 
  */
 public interface PhysicalPlanner {
   public PhysicalExec createPlan(TaskAttemptContext context,

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/PhysicalPlannerImpl.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/PhysicalPlannerImpl.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/PhysicalPlannerImpl.java
index 0c033c7..8fe317b 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/PhysicalPlannerImpl.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/PhysicalPlannerImpl.java
@@ -1,7 +1,11 @@
-/*
- * 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/PlannerUtil.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/PlannerUtil.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/PlannerUtil.java
index 97331e9..aeb44b0 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/PlannerUtil.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/PlannerUtil.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/PlanningContext.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/PlanningContext.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/PlanningContext.java
index fbf9d13..e62c237 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/PlanningContext.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/PlanningContext.java
@@ -1,4 +1,4 @@
-/*
+/**
  * 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
@@ -21,9 +21,6 @@ package tajo.engine.planner;
 import org.antlr.runtime.tree.Tree;
 import tajo.engine.parser.ParseTree;
 
-/**
- * @author Hyunsik Choi
- */
 public interface PlanningContext {
   String getRawQuery();
 

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/PlanningContextImpl.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/PlanningContextImpl.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/PlanningContextImpl.java
index 9bde7f5..494a28d 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/PlanningContextImpl.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/PlanningContextImpl.java
@@ -1,4 +1,4 @@
-/*
+/**
  * 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
@@ -21,9 +21,6 @@ package tajo.engine.planner;
 import org.antlr.runtime.tree.Tree;
 import tajo.engine.parser.ParseTree;
 
-/**
- * @author Hyunsik Choi
- */
 public class PlanningContextImpl implements PlanningContext  {
   private String rawQuery;
   // private TableMap tableMap = new TableMap();

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/Projector.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/Projector.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/Projector.java
index f823edb..c49ef29 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/Projector.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/Projector.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
@@ -27,9 +25,6 @@ import tajo.engine.eval.EvalNode;
 import tajo.engine.parser.QueryBlock.Target;
 import tajo.storage.Tuple;
 
-/**
- * @author Hyunsik Choi
- */
 public class Projector {
   private final Schema inSchema;
   private final Schema outSchema;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/RangeOverflowException.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/RangeOverflowException.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/RangeOverflowException.java
index 0671850..1b67bbc 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/RangeOverflowException.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/RangeOverflowException.java
@@ -1,11 +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;
 
 import tajo.storage.Tuple;
 import tajo.storage.TupleRange;
 
-/**
- * @author
- */
 public class RangeOverflowException extends RuntimeException {
   public RangeOverflowException(TupleRange range, Tuple overflowValue, long inc) {
     super("Overflow Error: tried to increase " + inc + " to " + overflowValue + ", but the range " + range);

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/RangePartitionAlgorithm.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/RangePartitionAlgorithm.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/RangePartitionAlgorithm.java
index 4850fc0..570e416 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/RangePartitionAlgorithm.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/RangePartitionAlgorithm.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;
 
 import tajo.catalog.Column;
@@ -9,9 +27,6 @@ import tajo.storage.TupleRange;
 
 import java.math.BigDecimal;
 
-/**
- * @author Hyunsik Choi
- */
 public abstract class RangePartitionAlgorithm {
   protected Schema schema;
   protected TupleRange range;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/UniformRangePartition.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/UniformRangePartition.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/UniformRangePartition.java
index cec056b..bee8534 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/UniformRangePartition.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/UniformRangePartition.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/global/GlobalOptimizer.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/global/GlobalOptimizer.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/global/GlobalOptimizer.java
index 8ec5910..6ebcaef 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/global/GlobalOptimizer.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/global/GlobalOptimizer.java
@@ -1,4 +1,4 @@
-/*
+/**
  * 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/global/MasterPlan.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/global/MasterPlan.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/global/MasterPlan.java
index 78aab4b..3f78e5b 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/global/MasterPlan.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/planner/global/MasterPlan.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.global;


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

Posted by hy...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-algebra/src/main/java/tajo/algebra/Target.java
----------------------------------------------------------------------
diff --git a/tajo-algebra/src/main/java/tajo/algebra/Target.java b/tajo-algebra/src/main/java/tajo/algebra/Target.java
index 035ed7d..ad79484 100644
--- a/tajo-algebra/src/main/java/tajo/algebra/Target.java
+++ b/tajo-algebra/src/main/java/tajo/algebra/Target.java
@@ -1,7 +1,11 @@
-/*
- * 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-algebra/src/main/java/tajo/algebra/UnaryOperator.java
----------------------------------------------------------------------
diff --git a/tajo-algebra/src/main/java/tajo/algebra/UnaryOperator.java b/tajo-algebra/src/main/java/tajo/algebra/UnaryOperator.java
index d8fc9b9..9c38964 100644
--- a/tajo-algebra/src/main/java/tajo/algebra/UnaryOperator.java
+++ b/tajo-algebra/src/main/java/tajo/algebra/UnaryOperator.java
@@ -1,7 +1,11 @@
-/*
- * 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-algebra/src/test/java/tajo/algebra/AlgebraTestingUtil.java
----------------------------------------------------------------------
diff --git a/tajo-algebra/src/test/java/tajo/algebra/AlgebraTestingUtil.java b/tajo-algebra/src/test/java/tajo/algebra/AlgebraTestingUtil.java
index 281c87a..697e79d 100644
--- a/tajo-algebra/src/test/java/tajo/algebra/AlgebraTestingUtil.java
+++ b/tajo-algebra/src/test/java/tajo/algebra/AlgebraTestingUtil.java
@@ -1,7 +1,11 @@
-/*
- * 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-algebra/src/test/java/tajo/algebra/TestExpr.java
----------------------------------------------------------------------
diff --git a/tajo-algebra/src/test/java/tajo/algebra/TestExpr.java b/tajo-algebra/src/test/java/tajo/algebra/TestExpr.java
index a5dfc94..d44c2ca 100644
--- a/tajo-algebra/src/test/java/tajo/algebra/TestExpr.java
+++ b/tajo-algebra/src/test/java/tajo/algebra/TestExpr.java
@@ -1,7 +1,11 @@
-/*
- * 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-catalog/pom.xml
----------------------------------------------------------------------
diff --git a/tajo-catalog/pom.xml b/tajo-catalog/pom.xml
index 074a97d..abeb86d 100644
--- a/tajo-catalog/pom.xml
+++ b/tajo-catalog/pom.xml
@@ -1,10 +1,12 @@
 <?xml version="1.0" encoding="UTF-8"?>
 <!--
-  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-catalog/tajo-catalog-client/pom.xml
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-client/pom.xml b/tajo-catalog/tajo-catalog-client/pom.xml
index f55d2d1..72e1e20 100644
--- a/tajo-catalog/tajo-catalog-client/pom.xml
+++ b/tajo-catalog/tajo-catalog-client/pom.xml
@@ -1,10 +1,12 @@
 <?xml version="1.0" encoding="UTF-8"?>
 <!--
-  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-catalog/tajo-catalog-client/src/main/java/tajo/catalog/AbstractCatalogClient.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-client/src/main/java/tajo/catalog/AbstractCatalogClient.java b/tajo-catalog/tajo-catalog-client/src/main/java/tajo/catalog/AbstractCatalogClient.java
index c999305..ce0efcb 100644
--- a/tajo-catalog/tajo-catalog-client/src/main/java/tajo/catalog/AbstractCatalogClient.java
+++ b/tajo-catalog/tajo-catalog-client/src/main/java/tajo/catalog/AbstractCatalogClient.java
@@ -1,7 +1,11 @@
-/*
- * 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
  *
@@ -12,9 +16,6 @@
  * limitations under the License.
  */
 
-/**
- *
- */
 package tajo.catalog;
 
 import com.google.protobuf.ServiceException;
@@ -31,9 +32,6 @@ import java.util.List;
 
 /**
  * CatalogClient provides a client API to access the catalog server.
- *
- * @author Hyunsik Choi
- *
  */
 public abstract class AbstractCatalogClient implements CatalogService {
   private final Log LOG = LogFactory.getLog(AbstractCatalogClient.class);

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-client/src/main/java/tajo/catalog/AlreadyRegisteredURIException.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-client/src/main/java/tajo/catalog/AlreadyRegisteredURIException.java b/tajo-catalog/tajo-catalog-client/src/main/java/tajo/catalog/AlreadyRegisteredURIException.java
index db8fa20..69df366 100644
--- a/tajo-catalog/tajo-catalog-client/src/main/java/tajo/catalog/AlreadyRegisteredURIException.java
+++ b/tajo-catalog/tajo-catalog-client/src/main/java/tajo/catalog/AlreadyRegisteredURIException.java
@@ -1,14 +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.catalog;
 
 import java.net.URI;
 
-/**
- * @author Hyunsik Choi
- *
- */
 public class AlreadyRegisteredURIException extends RuntimeException {
 
 	private static final long serialVersionUID = 747390434221048348L;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-client/src/main/java/tajo/catalog/AttributeType.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-client/src/main/java/tajo/catalog/AttributeType.java b/tajo-catalog/tajo-catalog-client/src/main/java/tajo/catalog/AttributeType.java
index 6526a5e..49e757b 100644
--- a/tajo-catalog/tajo-catalog-client/src/main/java/tajo/catalog/AttributeType.java
+++ b/tajo-catalog/tajo-catalog-client/src/main/java/tajo/catalog/AttributeType.java
@@ -1,8 +1,23 @@
-package tajo.catalog;
-
 /**
- * @author Hyunsik Choi
+ * 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.catalog;
+
 public enum AttributeType {
 	GROUPBY,
 	AGGREGATION,

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-client/src/main/java/tajo/catalog/CatalogClient.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-client/src/main/java/tajo/catalog/CatalogClient.java b/tajo-catalog/tajo-catalog-client/src/main/java/tajo/catalog/CatalogClient.java
index 0ace753..6b2f183 100644
--- a/tajo-catalog/tajo-catalog-client/src/main/java/tajo/catalog/CatalogClient.java
+++ b/tajo-catalog/tajo-catalog-client/src/main/java/tajo/catalog/CatalogClient.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.catalog;
 
 import org.apache.commons.logging.Log;
@@ -32,9 +31,6 @@ import java.net.InetSocketAddress;
 
 /**
  * CatalogClient provides a client API to access the catalog server.
- *
- * @author Hyunsik Choi
- *
  */
 public class CatalogClient extends AbstractCatalogClient {
   private final Log LOG = LogFactory.getLog(CatalogClient.class);

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-client/src/main/java/tajo/catalog/CatalogReader.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-client/src/main/java/tajo/catalog/CatalogReader.java b/tajo-catalog/tajo-catalog-client/src/main/java/tajo/catalog/CatalogReader.java
index c17aa00..3c61772 100644
--- a/tajo-catalog/tajo-catalog-client/src/main/java/tajo/catalog/CatalogReader.java
+++ b/tajo-catalog/tajo-catalog-client/src/main/java/tajo/catalog/CatalogReader.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.catalog;
 
 import tajo.catalog.proto.CatalogProtos.DataType;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-client/src/main/java/tajo/catalog/CatalogService.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-client/src/main/java/tajo/catalog/CatalogService.java b/tajo-catalog/tajo-catalog-client/src/main/java/tajo/catalog/CatalogService.java
index e5f35f7..290daa0 100644
--- a/tajo-catalog/tajo-catalog-client/src/main/java/tajo/catalog/CatalogService.java
+++ b/tajo-catalog/tajo-catalog-client/src/main/java/tajo/catalog/CatalogService.java
@@ -1,14 +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.catalog;
 
 import tajo.catalog.proto.CatalogProtos.DataType;
 
 import java.util.Collection;
 
-/**
- *
- * @author Hyunsik Choi
- *
- */
 public interface CatalogService {
 
   /**

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-client/src/main/java/tajo/catalog/CatalogServiceProtocol.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-client/src/main/java/tajo/catalog/CatalogServiceProtocol.java b/tajo-catalog/tajo-catalog-client/src/main/java/tajo/catalog/CatalogServiceProtocol.java
index 67e6602..bdc7e1a 100644
--- a/tajo-catalog/tajo-catalog-client/src/main/java/tajo/catalog/CatalogServiceProtocol.java
+++ b/tajo-catalog/tajo-catalog-client/src/main/java/tajo/catalog/CatalogServiceProtocol.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.catalog;
 
 import tajo.catalog.proto.CatalogProtos.*;
@@ -5,11 +23,6 @@ import tajo.rpc.protocolrecords.PrimitiveProtos.BoolProto;
 import tajo.rpc.protocolrecords.PrimitiveProtos.NullProto;
 import tajo.rpc.protocolrecords.PrimitiveProtos.StringProto;
 
-/**
- * 
- * @author Hyunsik Choi
- *
- */
 public interface CatalogServiceProtocol {
   
   /**

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-client/src/main/proto/CatalogProtocol.proto
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-client/src/main/proto/CatalogProtocol.proto b/tajo-catalog/tajo-catalog-client/src/main/proto/CatalogProtocol.proto
index 51fde23..4853945 100644
--- a/tajo-catalog/tajo-catalog-client/src/main/proto/CatalogProtocol.proto
+++ b/tajo-catalog/tajo-catalog-client/src/main/proto/CatalogProtocol.proto
@@ -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-catalog/tajo-catalog-client/src/main/proto/CatalogProtos.proto
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-client/src/main/proto/CatalogProtos.proto b/tajo-catalog/tajo-catalog-client/src/main/proto/CatalogProtos.proto
index 5464139..dd1bf69 100644
--- a/tajo-catalog/tajo-catalog-client/src/main/proto/CatalogProtos.proto
+++ b/tajo-catalog/tajo-catalog-client/src/main/proto/CatalogProtos.proto
@@ -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.
+ */
+
 option java_package = "tajo.catalog.proto";
 option java_outer_classname = "CatalogProtos";
 option optimize_for = SPEED;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-client/src/main/proto/PrimitiveProtos.proto
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-client/src/main/proto/PrimitiveProtos.proto b/tajo-catalog/tajo-catalog-client/src/main/proto/PrimitiveProtos.proto
index 64893cb..5fa6903 100644
--- a/tajo-catalog/tajo-catalog-client/src/main/proto/PrimitiveProtos.proto
+++ b/tajo-catalog/tajo-catalog-client/src/main/proto/PrimitiveProtos.proto
@@ -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-catalog/tajo-catalog-client/src/main/resources/catalog-default.xml
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-client/src/main/resources/catalog-default.xml b/tajo-catalog/tajo-catalog-client/src/main/resources/catalog-default.xml
index 5342bba..98b7790 100644
--- a/tajo-catalog/tajo-catalog-client/src/main/resources/catalog-default.xml
+++ b/tajo-catalog/tajo-catalog-client/src/main/resources/catalog-default.xml
@@ -2,11 +2,13 @@
 <?xml-stylesheet type="text/xsl" href="configuration.xsl"?>
 
 <!--
-  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-catalog/tajo-catalog-common/pom.xml
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/pom.xml b/tajo-catalog/tajo-catalog-common/pom.xml
index 2413ef3..cd9b758 100644
--- a/tajo-catalog/tajo-catalog-common/pom.xml
+++ b/tajo-catalog/tajo-catalog-common/pom.xml
@@ -1,10 +1,12 @@
 <?xml version="1.0" encoding="UTF-8"?>
 <!--
-  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-catalog/tajo-catalog-common/src/main/java/tajo/catalog/AlreadyRegisteredURIException.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/AlreadyRegisteredURIException.java b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/AlreadyRegisteredURIException.java
index db8fa20..69df366 100644
--- a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/AlreadyRegisteredURIException.java
+++ b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/AlreadyRegisteredURIException.java
@@ -1,14 +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.catalog;
 
 import java.net.URI;
 
-/**
- * @author Hyunsik Choi
- *
- */
 public class AlreadyRegisteredURIException extends RuntimeException {
 
 	private static final long serialVersionUID = 747390434221048348L;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/AttributeType.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/AttributeType.java b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/AttributeType.java
index 6526a5e..49e757b 100644
--- a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/AttributeType.java
+++ b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/AttributeType.java
@@ -1,8 +1,23 @@
-package tajo.catalog;
-
 /**
- * @author Hyunsik Choi
+ * 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.catalog;
+
 public enum AttributeType {
 	GROUPBY,
 	AGGREGATION,

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/CatalogConstants.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/CatalogConstants.java b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/CatalogConstants.java
index 6f25f19..17f7bc4 100644
--- a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/CatalogConstants.java
+++ b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/CatalogConstants.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.catalog;
 
 public class CatalogConstants {

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/CatalogUtil.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/CatalogUtil.java b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/CatalogUtil.java
index 8ccf016..de193f3 100644
--- a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/CatalogUtil.java
+++ b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/CatalogUtil.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-catalog/tajo-catalog-common/src/main/java/tajo/catalog/Column.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/Column.java b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/Column.java
index ca771c6..0deff1f 100644
--- a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/Column.java
+++ b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/Column.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,9 +25,6 @@ import tajo.catalog.proto.CatalogProtos.ColumnProtoOrBuilder;
 import tajo.catalog.proto.CatalogProtos.DataType;
 import tajo.common.ProtoObject;
 
-/**
- * @author Hyunsik Choi
- */
 public class Column implements ProtoObject<ColumnProto>, Cloneable {
 	private ColumnProto proto = ColumnProto.getDefaultInstance();
 	private ColumnProto.Builder builder = null;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/FunctionDesc.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/FunctionDesc.java b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/FunctionDesc.java
index 4e94cea..f11da36 100644
--- a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/FunctionDesc.java
+++ b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/FunctionDesc.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,9 +33,6 @@ import tajo.exception.InternalException;
 import java.lang.reflect.Constructor;
 import java.util.Arrays;
 
-/**
- * @author Hyunsik Choi
- */
 public class FunctionDesc implements ProtoObject<FunctionDescProto>, Cloneable {
   private FunctionDescProto proto = FunctionDescProto.getDefaultInstance();
   private FunctionDescProto.Builder builder = null;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/IndexDesc.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/IndexDesc.java b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/IndexDesc.java
index 13536ab..9e7789b 100644
--- a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/IndexDesc.java
+++ b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/IndexDesc.java
@@ -1,6 +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.catalog;
 
 import com.google.common.base.Objects;
@@ -12,9 +27,6 @@ import tajo.catalog.proto.CatalogProtos.IndexDescProtoOrBuilder;
 import tajo.catalog.proto.CatalogProtos.IndexMethod;
 import tajo.common.ProtoObject;
 
-/**
- * @author Hyunsik Choi
- */
 public class IndexDesc implements ProtoObject<IndexDescProto>, Cloneable {
   private IndexDescProto proto;
   private IndexDescProto.Builder builder;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/Options.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/Options.java b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/Options.java
index 2120a26..9422d78 100644
--- a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/Options.java
+++ b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/Options.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.catalog;
 
 import com.google.common.collect.Maps;
@@ -32,10 +31,6 @@ import java.util.Iterator;
 import java.util.Map;
 import java.util.Map.Entry;
 
-/**
- * @author Hyunsik Choi
- *
- */
 public class Options implements ProtoObject<KeyValueSetProto>, Cloneable {
 	@Expose(serialize=false,deserialize=false)
 	private KeyValueSetProto proto = KeyValueSetProto.getDefaultInstance();

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/Schema.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/Schema.java b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/Schema.java
index d0eba1b..846bb36 100644
--- a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/Schema.java
+++ b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/Schema.java
@@ -1,7 +1,11 @@
-/*
- * 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-catalog/tajo-catalog-common/src/main/java/tajo/catalog/SchemaObject.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/SchemaObject.java b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/SchemaObject.java
index 714babb..dbf52c1 100644
--- a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/SchemaObject.java
+++ b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/SchemaObject.java
@@ -1,12 +1,23 @@
 /**
- * 
+ * 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.catalog;
 
-/**
- * @author Hyunsik Choi
- *
- */
 public interface SchemaObject {
 	public Schema getSchema();
 }

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/SortSpec.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/SortSpec.java b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/SortSpec.java
index 5a4b74a..bea4e34 100644
--- a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/SortSpec.java
+++ b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/SortSpec.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.catalog;
 
 import com.google.gson.annotations.Expose;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/TCatUtil.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/TCatUtil.java b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/TCatUtil.java
index fc1ab4e..5ce0e50 100644
--- a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/TCatUtil.java
+++ b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/TCatUtil.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-catalog/tajo-catalog-common/src/main/java/tajo/catalog/TableDesc.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/TableDesc.java b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/TableDesc.java
index 96f5be9..6692c21 100644
--- a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/TableDesc.java
+++ b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/TableDesc.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
  *
@@ -19,11 +21,6 @@ package tajo.catalog;
 import com.google.protobuf.Message;
 import org.apache.hadoop.fs.Path;
 
-/**
- * 
- * @author Hyunsik Choi
- *
- */
 public interface TableDesc extends Cloneable {
   void setId(String tableId);
   

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/TableDescImpl.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/TableDescImpl.java b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/TableDescImpl.java
index 068269b..fc776e2 100644
--- a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/TableDescImpl.java
+++ b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/TableDescImpl.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,10 +28,6 @@ import tajo.catalog.proto.CatalogProtos.TableDescProto;
 import tajo.catalog.proto.CatalogProtos.TableDescProtoOrBuilder;
 import tajo.common.ProtoObject;
 
-/**
- * @author Hyunsik Choi
- *
- */
 public class TableDescImpl implements TableDesc, ProtoObject<TableDescProto>,
     Cloneable {
   protected TableDescProto proto = TableDescProto.getDefaultInstance();

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/TableMeta.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/TableMeta.java b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/TableMeta.java
index 536c730..14938ae 100644
--- a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/TableMeta.java
+++ b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/TableMeta.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.catalog;
 
 import tajo.catalog.proto.CatalogProtos.StoreType;
@@ -8,11 +26,6 @@ import tajo.common.ProtoObject;
 import java.util.Iterator;
 import java.util.Map.Entry;
 
-/**
- * 
- * @author Hyunsik Choi
- *
- */
 public interface TableMeta extends ProtoObject<TableProto>, Cloneable {
   
   void setStorageType(StoreType storeType);

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/TableMetaImpl.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/TableMetaImpl.java b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/TableMetaImpl.java
index e5378b3..602ca6d 100644
--- a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/TableMetaImpl.java
+++ b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/TableMetaImpl.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.catalog;
 
 import com.google.common.base.Objects;
@@ -32,9 +31,6 @@ import tajo.catalog.statistics.TableStat;
 import java.util.Iterator;
 import java.util.Map.Entry;
 
-/**
- * @author Hyunsik Choi
- */
 public class TableMetaImpl implements TableMeta {
 	protected TableProto proto = TableProto.getDefaultInstance();
 	protected TableProto.Builder builder = null;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/TableUtil.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/TableUtil.java b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/TableUtil.java
index 7b14d4f..e79d59d 100644
--- a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/TableUtil.java
+++ b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/TableUtil.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.catalog;
 
 import org.apache.hadoop.conf.Configuration;
@@ -10,11 +28,6 @@ import tajo.util.FileUtil;
 import java.io.FileNotFoundException;
 import java.io.IOException;
 
-/**
- * 
- * @author Hyunsik Choi
- *
- */
 public class TableUtil {
   public static TableMeta getTableMeta(Configuration conf, Path tablePath) 
       throws IOException {

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/exception/AlreadyExistsFieldException.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/exception/AlreadyExistsFieldException.java b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/exception/AlreadyExistsFieldException.java
index c331dc2..9b33c2f 100644
--- a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/exception/AlreadyExistsFieldException.java
+++ b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/exception/AlreadyExistsFieldException.java
@@ -1,8 +1,23 @@
-package tajo.catalog.exception;
-
 /**
- * @author Hyunsik Choi
+ * 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.catalog.exception;
+
 public class AlreadyExistsFieldException extends CatalogException {
 	private static final long serialVersionUID = 6766228091940775275L;
 

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/exception/AlreadyExistsFunctionException.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/exception/AlreadyExistsFunctionException.java b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/exception/AlreadyExistsFunctionException.java
index f0f16b6..7b3b038 100644
--- a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/exception/AlreadyExistsFunctionException.java
+++ b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/exception/AlreadyExistsFunctionException.java
@@ -1,8 +1,23 @@
-package tajo.catalog.exception;
-
 /**
- * @author Hyunsik Choi
+ * 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.catalog.exception;
+
 public class AlreadyExistsFunctionException extends CatalogException {
 	private static final long serialVersionUID = 3224521585413794703L;
 

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/exception/AlreadyExistsIndexException.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/exception/AlreadyExistsIndexException.java b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/exception/AlreadyExistsIndexException.java
index 5ff9ee1..adb6eb2 100644
--- a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/exception/AlreadyExistsIndexException.java
+++ b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/exception/AlreadyExistsIndexException.java
@@ -1,11 +1,23 @@
 /**
- * 
+ * 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.catalog.exception;
 
-/**
- * @author Hyunsik Choi
- */
 public class AlreadyExistsIndexException extends CatalogException {
   private static final long serialVersionUID = 3705839985189534673L;
 

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/exception/AlreadyExistsTableException.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/exception/AlreadyExistsTableException.java b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/exception/AlreadyExistsTableException.java
index 28af4f3..5abbe0a 100644
--- a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/exception/AlreadyExistsTableException.java
+++ b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/exception/AlreadyExistsTableException.java
@@ -1,11 +1,24 @@
-package tajo.catalog.exception;
-
-
 /**
- * 
- * @author Hyunsik Choi
+ * 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.catalog.exception;
+
+
 public class AlreadyExistsTableException extends CatalogException {
 	private static final long serialVersionUID = -641623770742392865L;
 

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/exception/CatalogException.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/exception/CatalogException.java b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/exception/CatalogException.java
index 1070f19..c2725ce 100644
--- a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/exception/CatalogException.java
+++ b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/exception/CatalogException.java
@@ -1,13 +1,23 @@
 /**
- * 
+ * 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.catalog.exception;
 
+package tajo.catalog.exception;
 
-/**
- * @author Hyunsik Choi
- *
- */
 public class CatalogException extends RuntimeException {
   private static final long serialVersionUID = -26362412527118618L;
 

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/exception/InvalidTableException.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/exception/InvalidTableException.java b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/exception/InvalidTableException.java
index d7b14a1..90f81a1 100644
--- a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/exception/InvalidTableException.java
+++ b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/exception/InvalidTableException.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,17 +16,10 @@
  * limitations under the License.
  */
 
-/**
- * 
- */
 package tajo.catalog.exception;
 
 import tajo.exception.InternalException;
 
-/**
- * @author hyunsik
- *
- */
 public class InvalidTableException extends InternalException {
 
 	private static final long serialVersionUID = -6326266814969872171L;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/exception/NoSuchFunctionException.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/exception/NoSuchFunctionException.java b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/exception/NoSuchFunctionException.java
index c58e08e..8e360db 100644
--- a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/exception/NoSuchFunctionException.java
+++ b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/exception/NoSuchFunctionException.java
@@ -1,8 +1,23 @@
-package tajo.catalog.exception;
-
 /**
- * @author Hyunsik Choi
+ * 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.catalog.exception;
+
 public class NoSuchFunctionException extends RuntimeException {
 	private static final long serialVersionUID = 5062193018697228028L;
 

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/exception/NoSuchIndexException.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/exception/NoSuchIndexException.java b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/exception/NoSuchIndexException.java
index 44cd337..aebfd19 100644
--- a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/exception/NoSuchIndexException.java
+++ b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/exception/NoSuchIndexException.java
@@ -1,11 +1,23 @@
 /**
- * 
+ * 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.catalog.exception;
 
-/**
- * @author Hyunsik Choi
- */
 public class NoSuchIndexException extends CatalogException {
   private static final long serialVersionUID = 3705839985189534673L;
 

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/exception/NoSuchTableException.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/exception/NoSuchTableException.java b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/exception/NoSuchTableException.java
index e4d6616..9a6da40 100644
--- a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/exception/NoSuchTableException.java
+++ b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/exception/NoSuchTableException.java
@@ -1,9 +1,24 @@
+/**
+ * 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.catalog.exception;
 
 
-/**
- * @author Hyunsik Choi
- */
 public class NoSuchTableException extends CatalogException {
 	private static final long serialVersionUID = 277182608283894937L;
 

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/function/AggFunction.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/function/AggFunction.java b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/function/AggFunction.java
index 50b96fb..a337afb 100644
--- a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/function/AggFunction.java
+++ b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/function/AggFunction.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-catalog/tajo-catalog-common/src/main/java/tajo/catalog/function/Function.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/function/Function.java b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/function/Function.java
index c00aea2..2e49e34 100644
--- a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/function/Function.java
+++ b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/function/Function.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-catalog/tajo-catalog-common/src/main/java/tajo/catalog/function/FunctionContext.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/function/FunctionContext.java b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/function/FunctionContext.java
index 172bc7f..0517ca9 100644
--- a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/function/FunctionContext.java
+++ b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/function/FunctionContext.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-catalog/tajo-catalog-common/src/main/java/tajo/catalog/function/GeneralFunction.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/function/GeneralFunction.java b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/function/GeneralFunction.java
index 52f997e..8718e0e 100644
--- a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/function/GeneralFunction.java
+++ b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/function/GeneralFunction.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-catalog/tajo-catalog-common/src/main/java/tajo/catalog/json/FunctionAdapter.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/json/FunctionAdapter.java b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/json/FunctionAdapter.java
index 496cc03..9bd36ce 100644
--- a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/json/FunctionAdapter.java
+++ b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/json/FunctionAdapter.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.catalog.json;
 
 import com.google.gson.*;
@@ -24,10 +23,6 @@ import tajo.catalog.function.Function;
 
 import java.lang.reflect.Type;
 
-/**
- * @author jihoon
- *
- */
 public class FunctionAdapter implements JsonDeserializer<Function>, JsonSerializer<Function> {
 
   @Override

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/json/GsonCreator.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/json/GsonCreator.java b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/json/GsonCreator.java
index 13b27ba..24a817f 100644
--- a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/json/GsonCreator.java
+++ b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/json/GsonCreator.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.catalog.json;
 
 import com.google.gson.Gson;
@@ -32,10 +31,6 @@ import tajo.datum.json.DatumAdapter;
 import tajo.gson.ClassNameDeserializer;
 import tajo.gson.ClassNameSerializer;
 
-/**
- * @author jihoon
- *
- */
 public class GsonCreator {
 	private static GsonBuilder builder;
 	private static Gson gson;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/json/PathDeserializer.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/json/PathDeserializer.java b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/json/PathDeserializer.java
index 1a5026e..94787f0 100644
--- a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/json/PathDeserializer.java
+++ b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/json/PathDeserializer.java
@@ -1,6 +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.catalog.json;
 
 import com.google.gson.JsonDeserializationContext;
@@ -11,10 +26,6 @@ import org.apache.hadoop.fs.Path;
 
 import java.lang.reflect.Type;
 
-/**
- * @author jihoon
- *
- */
 public class PathDeserializer implements JsonDeserializer<Path> {
 
 	@Override

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/json/PathSerializer.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/json/PathSerializer.java b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/json/PathSerializer.java
index 0893cf4..e39bb9e 100644
--- a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/json/PathSerializer.java
+++ b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/json/PathSerializer.java
@@ -1,6 +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.catalog.json;
 
 import com.google.gson.JsonElement;
@@ -11,10 +26,6 @@ import org.apache.hadoop.fs.Path;
 
 import java.lang.reflect.Type;
 
-/**
- * @author jihoon
- *
- */
 public class PathSerializer implements JsonSerializer<Path> {
 
 	@Override

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/json/TableDescAdapter.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/json/TableDescAdapter.java b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/json/TableDescAdapter.java
index bf40838..8c7d309 100644
--- a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/json/TableDescAdapter.java
+++ b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/json/TableDescAdapter.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.catalog.json;
 
 import com.google.gson.*;
@@ -24,10 +23,6 @@ import tajo.catalog.TableDesc;
 
 import java.lang.reflect.Type;
 
-/**
- * @author jihoon
- *
- */
 public class TableDescAdapter implements JsonSerializer<TableDesc>, JsonDeserializer<TableDesc> {
 
 	@Override

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/json/TableMetaAdapter.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/json/TableMetaAdapter.java b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/json/TableMetaAdapter.java
index cbbcbd6..a93214f 100644
--- a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/json/TableMetaAdapter.java
+++ b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/json/TableMetaAdapter.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.catalog.json;
 
 import com.google.gson.*;
@@ -24,10 +23,6 @@ import tajo.catalog.TableMeta;
 
 import java.lang.reflect.Type;
 
-/**
- * @author jihoon
- *
- */
 public class TableMetaAdapter implements JsonSerializer<TableMeta>, JsonDeserializer<TableMeta> {
 
 	@Override

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/statistics/ColumnStat.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/statistics/ColumnStat.java b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/statistics/ColumnStat.java
index f2a34ee..99b51ce 100644
--- a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/statistics/ColumnStat.java
+++ b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/statistics/ColumnStat.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,9 +33,6 @@ import tajo.common.ProtoObject;
 import tajo.datum.Datum;
 import tajo.util.TUtil;
 
-/**
- * @author Hyunsik Choi
- */
 public class ColumnStat implements ProtoObject<ColumnStatProto>, Cloneable {
   private ColumnStatProto proto = ColumnStatProto.getDefaultInstance();
   private ColumnStatProto.Builder builder = null;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/statistics/Stat.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/statistics/Stat.java b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/statistics/Stat.java
index 7fefc21..d15c229 100644
--- a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/statistics/Stat.java
+++ b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/statistics/Stat.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-catalog/tajo-catalog-common/src/main/java/tajo/catalog/statistics/StatSet.java
----------------------------------------------------------------------
diff --git a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/statistics/StatSet.java b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/statistics/StatSet.java
index 1724218..4ab7375 100644
--- a/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/statistics/StatSet.java
+++ b/tajo-catalog/tajo-catalog-common/src/main/java/tajo/catalog/statistics/StatSet.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
  *
@@ -29,9 +31,6 @@ import java.util.Collection;
 import java.util.Map;
 import java.util.Map.Entry;
 
-/**
- * @author Hyunsik Choi
- */
 public class StatSet implements ProtoObject<StatSetProto>, Cloneable {
   private StatSetProto proto = StatSetProto.getDefaultInstance();
   private StatSetProto.Builder builder = null;


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

Posted by hy...@apache.org.
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;


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

Posted by hy...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-storage/src/main/java/tajo/storage/index/OrderIndexReader.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/index/OrderIndexReader.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/index/OrderIndexReader.java
index de093e9..38b4a4b 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/index/OrderIndexReader.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/index/OrderIndexReader.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.storage.index;
@@ -7,9 +25,6 @@ import tajo.storage.Tuple;
 
 import java.io.IOException;
 
-/**
- * @author Hyunsik Choi
- */
 public interface OrderIndexReader extends IndexReader {
   /**
    * Find the offset corresponding to key which is equal to or greater than 

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-storage/src/main/java/tajo/storage/index/bst/BSTIndex.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/index/bst/BSTIndex.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/index/bst/BSTIndex.java
index b60a2d2..2d6ae32 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/index/bst/BSTIndex.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/index/bst/BSTIndex.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
  *
@@ -41,15 +43,11 @@ import java.util.Set;
 import java.util.TreeMap;
 
 /**
- * @author Ryu Hyo Seok
- * @author Hyunsik Choi
- * 
  * This is two-level binary search tree index. This is one of the value-list 
  * index structure. Thus, it is inefficient in the case where 
  * the many of the values are same. Also, the BST shows the fast performance 
  * when the selectivity of rows to be retrieved is less than 5%.
  * BSTIndexWriter is not thread-safe, whereas BSTIndexReader is thread-safe.
- *
  */
 public class BSTIndex implements IndexMethod {
   private static final Log LOG = LogFactory.getLog(BSTIndex.class);

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-storage/src/main/java/tajo/storage/json/FragmentDeserializer.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/json/FragmentDeserializer.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/json/FragmentDeserializer.java
index d955473..d889500 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/json/FragmentDeserializer.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/json/FragmentDeserializer.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.storage.json;
@@ -13,10 +31,6 @@ import tajo.storage.Fragment;
 
 import java.lang.reflect.Type;
 
-/**
- * @author jihoon
- *
- */
 public class FragmentDeserializer implements JsonDeserializer<Fragment> {
 
 	@Override

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-storage/src/main/java/tajo/storage/json/GsonCreator.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/json/GsonCreator.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/json/GsonCreator.java
index 5200da2..db8b111 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/json/GsonCreator.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/json/GsonCreator.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-storage/src/main/java/tajo/storage/rcfile/CodecPool.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/rcfile/CodecPool.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/rcfile/CodecPool.java
index 2ecf87b..cac62c4 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/rcfile/CodecPool.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/rcfile/CodecPool.java
@@ -15,6 +15,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
+
 package tajo.storage.rcfile;
 
 import org.apache.commons.logging.Log;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-storage/src/main/java/tajo/storage/rcfile/NonSyncByteArrayInputStream.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/rcfile/NonSyncByteArrayInputStream.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/rcfile/NonSyncByteArrayInputStream.java
index 040d3ed..8520bd6 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/rcfile/NonSyncByteArrayInputStream.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/rcfile/NonSyncByteArrayInputStream.java
@@ -15,6 +15,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
+
 package tajo.storage.rcfile;
 
 import java.io.ByteArrayInputStream;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-storage/src/main/java/tajo/storage/rcfile/NonSyncByteArrayOutputStream.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/rcfile/NonSyncByteArrayOutputStream.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/rcfile/NonSyncByteArrayOutputStream.java
index 0889534..87744f1 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/rcfile/NonSyncByteArrayOutputStream.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/rcfile/NonSyncByteArrayOutputStream.java
@@ -15,6 +15,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
+
 package tajo.storage.rcfile;
 
 import java.io.ByteArrayOutputStream;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-storage/src/main/java/tajo/storage/rcfile/NonSyncDataOutputBuffer.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/rcfile/NonSyncDataOutputBuffer.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/rcfile/NonSyncDataOutputBuffer.java
index f60bf75..d7e69fa 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/rcfile/NonSyncDataOutputBuffer.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/rcfile/NonSyncDataOutputBuffer.java
@@ -15,6 +15,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
+
 package tajo.storage.rcfile;
 
 import java.io.DataInput;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-storage/src/main/java/tajo/storage/rcfile/RCFileWrapper.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/rcfile/RCFileWrapper.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/rcfile/RCFileWrapper.java
index aafdbbf..e04cd52 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/rcfile/RCFileWrapper.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/rcfile/RCFileWrapper.java
@@ -1,4 +1,4 @@
-/*
+/**
  * 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-storage/src/main/java/tajo/storage/trevni/TrevniAppender.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/trevni/TrevniAppender.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/trevni/TrevniAppender.java
index 493ad7e..e7b30df 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/trevni/TrevniAppender.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/trevni/TrevniAppender.java
@@ -1,7 +1,11 @@
-/*
- * 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-storage/src/main/java/tajo/storage/trevni/TrevniScanner.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/trevni/TrevniScanner.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/trevni/TrevniScanner.java
index 119658d..6fb05bd 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/trevni/TrevniScanner.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/trevni/TrevniScanner.java
@@ -1,7 +1,11 @@
-/*
- * 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-storage/src/main/proto/CatalogProtos.proto
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/proto/CatalogProtos.proto b/tajo-core/tajo-core-storage/src/main/proto/CatalogProtos.proto
index d48df74..3910520 100644
--- a/tajo-core/tajo-core-storage/src/main/proto/CatalogProtos.proto
+++ b/tajo-core/tajo-core-storage/src/main/proto/CatalogProtos.proto
@@ -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.
+ */
+
 option java_package = "tajo.catalog.proto";
 option java_outer_classname = "CatalogProtos";
 option optimize_for = SPEED;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-storage/src/main/proto/IndexProtos.proto
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/proto/IndexProtos.proto b/tajo-core/tajo-core-storage/src/main/proto/IndexProtos.proto
index f3dd120..c0be4bd 100644
--- a/tajo-core/tajo-core-storage/src/main/proto/IndexProtos.proto
+++ b/tajo-core/tajo-core-storage/src/main/proto/IndexProtos.proto
@@ -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-storage/src/main/proto/PrimitiveProtos.proto
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/proto/PrimitiveProtos.proto b/tajo-core/tajo-core-storage/src/main/proto/PrimitiveProtos.proto
index 64893cb..5fa6903 100644
--- a/tajo-core/tajo-core-storage/src/main/proto/PrimitiveProtos.proto
+++ b/tajo-core/tajo-core-storage/src/main/proto/PrimitiveProtos.proto
@@ -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-storage/src/main/resources/storage-default.xml
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/resources/storage-default.xml b/tajo-core/tajo-core-storage/src/main/resources/storage-default.xml
index fd4258a..8f78e3e 100644
--- a/tajo-core/tajo-core-storage/src/main/resources/storage-default.xml
+++ b/tajo-core/tajo-core-storage/src/main/resources/storage-default.xml
@@ -1,6 +1,24 @@
 <?xml version="1.0"?>
 <?xml-stylesheet type="text/xsl" href="configuration.xsl"?>
 
+<!--
+  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.
+  -->
+
 <configuration>
   <!--- Scanner Handler -->
   <property>

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-storage/src/test/java/tajo/storage/TestFrameTuple.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/test/java/tajo/storage/TestFrameTuple.java b/tajo-core/tajo-core-storage/src/test/java/tajo/storage/TestFrameTuple.java
index fd6024a..7287c6f 100644
--- a/tajo-core/tajo-core-storage/src/test/java/tajo/storage/TestFrameTuple.java
+++ b/tajo-core/tajo-core-storage/src/test/java/tajo/storage/TestFrameTuple.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.storage;
 
 import org.junit.After;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-storage/src/test/java/tajo/storage/TestMergeScanner.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/test/java/tajo/storage/TestMergeScanner.java b/tajo-core/tajo-core-storage/src/test/java/tajo/storage/TestMergeScanner.java
index 6d624f3..7688a1d 100644
--- a/tajo-core/tajo-core-storage/src/test/java/tajo/storage/TestMergeScanner.java
+++ b/tajo-core/tajo-core-storage/src/test/java/tajo/storage/TestMergeScanner.java
@@ -1,7 +1,11 @@
-/*
- * 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-storage/src/test/java/tajo/storage/TestStorageManager.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/test/java/tajo/storage/TestStorageManager.java b/tajo-core/tajo-core-storage/src/test/java/tajo/storage/TestStorageManager.java
index 13aeebf..00215a0 100644
--- a/tajo-core/tajo-core-storage/src/test/java/tajo/storage/TestStorageManager.java
+++ b/tajo-core/tajo-core-storage/src/test/java/tajo/storage/TestStorageManager.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.storage;
 
 import org.apache.hadoop.fs.FileSystem;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-storage/src/test/java/tajo/storage/TestStorages.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/test/java/tajo/storage/TestStorages.java b/tajo-core/tajo-core-storage/src/test/java/tajo/storage/TestStorages.java
index dd850a7..d351edf 100644
--- a/tajo-core/tajo-core-storage/src/test/java/tajo/storage/TestStorages.java
+++ b/tajo-core/tajo-core-storage/src/test/java/tajo/storage/TestStorages.java
@@ -1,7 +1,11 @@
-/*
- * 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-storage/src/test/java/tajo/storage/TestTupleComparator.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/test/java/tajo/storage/TestTupleComparator.java b/tajo-core/tajo-core-storage/src/test/java/tajo/storage/TestTupleComparator.java
index a8181d4..e37b3e5 100644
--- a/tajo-core/tajo-core-storage/src/test/java/tajo/storage/TestTupleComparator.java
+++ b/tajo-core/tajo-core-storage/src/test/java/tajo/storage/TestTupleComparator.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.storage;
 
 import org.junit.After;
@@ -11,9 +29,6 @@ import tajo.datum.DatumFactory;
 
 import static org.junit.Assert.assertEquals;
 
-/**
- * @author Hyunsik Choi
- */
 public class TestTupleComparator {
 
   @Before

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-storage/src/test/java/tajo/storage/TestVTuple.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/test/java/tajo/storage/TestVTuple.java b/tajo-core/tajo-core-storage/src/test/java/tajo/storage/TestVTuple.java
index ca0b7a6..cebbae7 100644
--- a/tajo-core/tajo-core-storage/src/test/java/tajo/storage/TestVTuple.java
+++ b/tajo-core/tajo-core-storage/src/test/java/tajo/storage/TestVTuple.java
@@ -1,6 +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.storage;
 
 
@@ -10,10 +25,6 @@ import tajo.datum.DatumFactory;
 
 import static org.junit.Assert.*;
 
-/**
- * @author Hyunsik Choi
- *
- */
 public class TestVTuple {
 
 	/**

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-storage/src/test/java/tajo/storage/hcfile/IndexTest.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/test/java/tajo/storage/hcfile/IndexTest.java b/tajo-core/tajo-core-storage/src/test/java/tajo/storage/hcfile/IndexTest.java
index 7f30fb7..0299a0e 100644
--- a/tajo-core/tajo-core-storage/src/test/java/tajo/storage/hcfile/IndexTest.java
+++ b/tajo-core/tajo-core-storage/src/test/java/tajo/storage/hcfile/IndexTest.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-storage/src/test/java/tajo/storage/index/TestBSTIndex.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/test/java/tajo/storage/index/TestBSTIndex.java b/tajo-core/tajo-core-storage/src/test/java/tajo/storage/index/TestBSTIndex.java
index 479f74a..85c7beb 100644
--- a/tajo-core/tajo-core-storage/src/test/java/tajo/storage/index/TestBSTIndex.java
+++ b/tajo-core/tajo-core-storage/src/test/java/tajo/storage/index/TestBSTIndex.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.storage.index;
 
 import org.apache.hadoop.fs.FileStatus;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-storage/src/test/java/tajo/storage/index/TestSingleCSVFileBSTIndex.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/test/java/tajo/storage/index/TestSingleCSVFileBSTIndex.java b/tajo-core/tajo-core-storage/src/test/java/tajo/storage/index/TestSingleCSVFileBSTIndex.java
index 3c2c442..e0ae7b3 100644
--- a/tajo-core/tajo-core-storage/src/test/java/tajo/storage/index/TestSingleCSVFileBSTIndex.java
+++ b/tajo-core/tajo-core-storage/src/test/java/tajo/storage/index/TestSingleCSVFileBSTIndex.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.storage.index;
 
 import org.apache.hadoop.fs.FileStatus;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-storage/src/test/java/tajo/storage/rcfile/TestRCFile.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/test/java/tajo/storage/rcfile/TestRCFile.java b/tajo-core/tajo-core-storage/src/test/java/tajo/storage/rcfile/TestRCFile.java
index c23f5c1..315b0ed 100644
--- a/tajo-core/tajo-core-storage/src/test/java/tajo/storage/rcfile/TestRCFile.java
+++ b/tajo-core/tajo-core-storage/src/test/java/tajo/storage/rcfile/TestRCFile.java
@@ -608,7 +608,7 @@ public class TestRCFile {
     Configuration conf = new Configuration();
     LocalFileSystem fs = FileSystem.getLocal(conf);
     // create an empty file (which is not a valid rcfile)
-    Path path = new Path(System.getProperty("test.build.data", ".")
+    Path path = new Path(System.getProperty("test.build.data", "target")
         + "/broken.rcfile");
     fs.create(path).close();
     // try to create RCFile.Reader

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-storage/src/test/resources/storage-default.xml
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/test/resources/storage-default.xml b/tajo-core/tajo-core-storage/src/test/resources/storage-default.xml
index fd4258a..8f78e3e 100644
--- a/tajo-core/tajo-core-storage/src/test/resources/storage-default.xml
+++ b/tajo-core/tajo-core-storage/src/test/resources/storage-default.xml
@@ -1,6 +1,24 @@
 <?xml version="1.0"?>
 <?xml-stylesheet type="text/xsl" href="configuration.xsl"?>
 
+<!--
+  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.
+  -->
+
 <configuration>
   <!--- Scanner Handler -->
   <property>

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-dist/pom.xml
----------------------------------------------------------------------
diff --git a/tajo-dist/pom.xml b/tajo-dist/pom.xml
index 4b4c5ed..2c329ce 100644
--- a/tajo-dist/pom.xml
+++ b/tajo-dist/pom.xml
@@ -1,10 +1,12 @@
 <?xml version="1.0" encoding="UTF-8"?>
 <!--
-  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-dist/src/main/bin/start-catalog.sh
----------------------------------------------------------------------
diff --git a/tajo-dist/src/main/bin/start-catalog.sh b/tajo-dist/src/main/bin/start-catalog.sh
index dd5c8bd..bdf46c0 100755
--- a/tajo-dist/src/main/bin/start-catalog.sh
+++ b/tajo-dist/src/main/bin/start-catalog.sh
@@ -1,11 +1,12 @@
 #!/usr/bin/env bash
 
-# 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
+# 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
 #
@@ -16,6 +17,7 @@
 # limitations under the License.
 
 
+
 # Start tajo map reduce daemons.  Run this on master node.
 
 bin=`dirname "$0"`

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-dist/src/main/bin/start-tajo.sh
----------------------------------------------------------------------
diff --git a/tajo-dist/src/main/bin/start-tajo.sh b/tajo-dist/src/main/bin/start-tajo.sh
index 0d45cad..a39ebf1 100755
--- a/tajo-dist/src/main/bin/start-tajo.sh
+++ b/tajo-dist/src/main/bin/start-tajo.sh
@@ -1,11 +1,12 @@
 #!/usr/bin/env bash
 
-# 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
+# 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-dist/src/main/bin/stop-tajo.sh
----------------------------------------------------------------------
diff --git a/tajo-dist/src/main/bin/stop-tajo.sh b/tajo-dist/src/main/bin/stop-tajo.sh
index f62c3ab..d22ca4a 100755
--- a/tajo-dist/src/main/bin/stop-tajo.sh
+++ b/tajo-dist/src/main/bin/stop-tajo.sh
@@ -1,11 +1,12 @@
 #!/usr/bin/env bash
 
-# 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
+# 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-dist/src/main/bin/tajo
----------------------------------------------------------------------
diff --git a/tajo-dist/src/main/bin/tajo b/tajo-dist/src/main/bin/tajo
index 9c6625c..9ab225a 100755
--- a/tajo-dist/src/main/bin/tajo
+++ b/tajo-dist/src/main/bin/tajo
@@ -1,11 +1,12 @@
 #!/usr/bin/env bash
 
-# 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
+# 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-dist/src/main/bin/tajo-config.sh
----------------------------------------------------------------------
diff --git a/tajo-dist/src/main/bin/tajo-config.sh b/tajo-dist/src/main/bin/tajo-config.sh
index 5c55260..36c20d8 100755
--- a/tajo-dist/src/main/bin/tajo-config.sh
+++ b/tajo-dist/src/main/bin/tajo-config.sh
@@ -1,9 +1,10 @@
-# 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
+# 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-dist/src/main/bin/tajo-daemon.sh
----------------------------------------------------------------------
diff --git a/tajo-dist/src/main/bin/tajo-daemon.sh b/tajo-dist/src/main/bin/tajo-daemon.sh
index 0d3571f..4a86c01 100755
--- a/tajo-dist/src/main/bin/tajo-daemon.sh
+++ b/tajo-dist/src/main/bin/tajo-daemon.sh
@@ -1,11 +1,12 @@
 #!/usr/bin/env bash
 
-# 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
+# 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-dist/src/main/conf/catalog-site.xml.template
----------------------------------------------------------------------
diff --git a/tajo-dist/src/main/conf/catalog-site.xml.template b/tajo-dist/src/main/conf/catalog-site.xml.template
index d57a965..2d5710e 100644
--- a/tajo-dist/src/main/conf/catalog-site.xml.template
+++ b/tajo-dist/src/main/conf/catalog-site.xml.template
@@ -1,4 +1,21 @@
 <?xml version="1.0"?>
+<!--
+  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.
+  -->
 <?xml-stylesheet type="text/xsl" href="configuration.xsl"?>
 
 <configuration>

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-dist/src/main/conf/configuration.xsl
----------------------------------------------------------------------
diff --git a/tajo-dist/src/main/conf/configuration.xsl b/tajo-dist/src/main/conf/configuration.xsl
index 377cdbe..01c1b3c 100644
--- a/tajo-dist/src/main/conf/configuration.xsl
+++ b/tajo-dist/src/main/conf/configuration.xsl
@@ -1,4 +1,22 @@
 <?xml version="1.0"?>
+<!--
+  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.
+  -->
+
 <xsl:stylesheet xmlns:xsl="http://www.w3.org/1999/XSL/Transform" version="1.0">
 <xsl:output method="html"/>
 <xsl:template match="configuration">

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-dist/src/main/conf/tajo-env.sh
----------------------------------------------------------------------
diff --git a/tajo-dist/src/main/conf/tajo-env.sh b/tajo-dist/src/main/conf/tajo-env.sh
index 3514f9b..72e520b 100755
--- a/tajo-dist/src/main/conf/tajo-env.sh
+++ b/tajo-dist/src/main/conf/tajo-env.sh
@@ -1,3 +1,19 @@
+# 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.
+
 # Set Tajo-specific environment variables here.
 
 # The only required environment variable is JAVA_HOME.  All others are

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-dist/src/main/conf/tajo-site.xml.template
----------------------------------------------------------------------
diff --git a/tajo-dist/src/main/conf/tajo-site.xml.template b/tajo-dist/src/main/conf/tajo-site.xml.template
index d57a965..084cc30 100644
--- a/tajo-dist/src/main/conf/tajo-site.xml.template
+++ b/tajo-dist/src/main/conf/tajo-site.xml.template
@@ -1,4 +1,22 @@
 <?xml version="1.0"?>
+<!--
+  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.
+  -->
+
 <?xml-stylesheet type="text/xsl" href="configuration.xsl"?>
 
 <configuration>

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-frontend/tajo-frontend-sql/src/main/antlr3/tajo/frontend/sql/SQLLexer.g
----------------------------------------------------------------------
diff --git a/tajo-frontend/tajo-frontend-sql/src/main/antlr3/tajo/frontend/sql/SQLLexer.g b/tajo-frontend/tajo-frontend-sql/src/main/antlr3/tajo/frontend/sql/SQLLexer.g
index 383c28d..1023778 100644
--- a/tajo-frontend/tajo-frontend-sql/src/main/antlr3/tajo/frontend/sql/SQLLexer.g
+++ b/tajo-frontend/tajo-frontend-sql/src/main/antlr3/tajo/frontend/sql/SQLLexer.g
@@ -1,16 +1,52 @@
 /*
-  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
+ This software is made available under the BSD License:
+
+ Copyright (c) 2011, Mage Systems
+ Portions Copyright (c)  Jonathan Leffler 2004-2009'
+ Portions Copyright (c) 2003, ISO - International Organization for Standardization
+ All rights reserved.
+
+ Redistribution and use in source and binary forms, with or without modification,
+ are permitted provided that the following conditions are met:
+
+     * Redistributions of source code must retain the above copyright notice, this
+       list of conditions and the following disclaimer.
+     * Redistributions in binary form must reproduce the above copyright notice,
+       this list of conditions and the following disclaimer in the documentation
+       and/or other materials provided with the distribution.
+     * Neither the name of the "Mage Systems" nor the names of its contributors
+       may be used to endorse or promote products derived from this software
+       without specific prior written permission.
+
+ THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" AND
+ ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED
+ WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE DISCLAIMED.
+ IN NO EVENT SHALL THE COPYRIGHT HOLDER OR CONTRIBUTORS BE LIABLE FOR ANY DIRECT,
+ INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING,
+ BUT NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES; LOSS OF USE,
+ DATA, OR PROFITS; OR BUSINESS INTERRUPTION) HOWEVER CAUSED AND ON ANY THEORY OF
+ LIABILITY, WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT (INCLUDING NEGLIGENCE
+ OR OTHERWISE) ARISING IN ANY WAY OUT OF THE USE OF THIS SOFTWARE, EVEN IF ADVISED
+ OF THE POSSIBILITY OF SUCH DAMAGE.
+ */
 
-      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.
-*/
+/*
+ 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.
+ */
 
 /*
 ==============================================================================================

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-frontend/tajo-frontend-sql/src/main/antlr3/tajo/frontend/sql/SQLParser.g
----------------------------------------------------------------------
diff --git a/tajo-frontend/tajo-frontend-sql/src/main/antlr3/tajo/frontend/sql/SQLParser.g b/tajo-frontend/tajo-frontend-sql/src/main/antlr3/tajo/frontend/sql/SQLParser.g
index ab0783d..4264f0b 100644
--- a/tajo-frontend/tajo-frontend-sql/src/main/antlr3/tajo/frontend/sql/SQLParser.g
+++ b/tajo-frontend/tajo-frontend-sql/src/main/antlr3/tajo/frontend/sql/SQLParser.g
@@ -1,16 +1,52 @@
 /*
-  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
+ This software is made available under the BSD License:
+
+ Copyright (c) 2011, Mage Systems
+ Portions Copyright (c)  Jonathan Leffler 2004-2009'
+ Portions Copyright (c) 2003, ISO - International Organization for Standardization
+ All rights reserved.
+
+ Redistribution and use in source and binary forms, with or without modification,
+ are permitted provided that the following conditions are met:
+
+     * Redistributions of source code must retain the above copyright notice, this
+       list of conditions and the following disclaimer.
+     * Redistributions in binary form must reproduce the above copyright notice,
+       this list of conditions and the following disclaimer in the documentation
+       and/or other materials provided with the distribution.
+     * Neither the name of the "Mage Systems" nor the names of its contributors
+       may be used to endorse or promote products derived from this software
+       without specific prior written permission.
+
+ THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" AND
+ ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED
+ WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE DISCLAIMED.
+ IN NO EVENT SHALL THE COPYRIGHT HOLDER OR CONTRIBUTORS BE LIABLE FOR ANY DIRECT,
+ INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING,
+ BUT NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES; LOSS OF USE,
+ DATA, OR PROFITS; OR BUSINESS INTERRUPTION) HOWEVER CAUSED AND ON ANY THEORY OF
+ LIABILITY, WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT (INCLUDING NEGLIGENCE
+ OR OTHERWISE) ARISING IN ANY WAY OUT OF THE USE OF THIS SOFTWARE, EVEN IF ADVISED
+ OF THE POSSIBILITY OF SUCH DAMAGE.
+ */
 
-      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.
-*/
+/*
+ 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.
+ */
 
 /*
 ==============================================================================================

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-frontend/tajo-frontend-sql/src/main/java/tajo/frontend/sql/QueryBlock.java
----------------------------------------------------------------------
diff --git a/tajo-frontend/tajo-frontend-sql/src/main/java/tajo/frontend/sql/QueryBlock.java b/tajo-frontend/tajo-frontend-sql/src/main/java/tajo/frontend/sql/QueryBlock.java
index e474c03..7566c20 100644
--- a/tajo-frontend/tajo-frontend-sql/src/main/java/tajo/frontend/sql/QueryBlock.java
+++ b/tajo-frontend/tajo-frontend-sql/src/main/java/tajo/frontend/sql/QueryBlock.java
@@ -1,7 +1,11 @@
-/*
- * 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-frontend/tajo-frontend-sql/src/main/java/tajo/frontend/sql/SQLAnalyzer.java
----------------------------------------------------------------------
diff --git a/tajo-frontend/tajo-frontend-sql/src/main/java/tajo/frontend/sql/SQLAnalyzer.java b/tajo-frontend/tajo-frontend-sql/src/main/java/tajo/frontend/sql/SQLAnalyzer.java
index eb2d88d..e962b93 100644
--- a/tajo-frontend/tajo-frontend-sql/src/main/java/tajo/frontend/sql/SQLAnalyzer.java
+++ b/tajo-frontend/tajo-frontend-sql/src/main/java/tajo/frontend/sql/SQLAnalyzer.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.frontend.sql;
 
 import com.google.common.base.Preconditions;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-frontend/tajo-frontend-sql/src/main/java/tajo/frontend/sql/SQLParseError.java
----------------------------------------------------------------------
diff --git a/tajo-frontend/tajo-frontend-sql/src/main/java/tajo/frontend/sql/SQLParseError.java b/tajo-frontend/tajo-frontend-sql/src/main/java/tajo/frontend/sql/SQLParseError.java
index 04e6bd1..3e6a78c 100644
--- a/tajo-frontend/tajo-frontend-sql/src/main/java/tajo/frontend/sql/SQLParseError.java
+++ b/tajo-frontend/tajo-frontend-sql/src/main/java/tajo/frontend/sql/SQLParseError.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-frontend/tajo-frontend-sql/src/main/java/tajo/frontend/sql/SQLSyntaxError.java
----------------------------------------------------------------------
diff --git a/tajo-frontend/tajo-frontend-sql/src/main/java/tajo/frontend/sql/SQLSyntaxError.java b/tajo-frontend/tajo-frontend-sql/src/main/java/tajo/frontend/sql/SQLSyntaxError.java
index 55b0ee4..eaff8ce 100644
--- a/tajo-frontend/tajo-frontend-sql/src/main/java/tajo/frontend/sql/SQLSyntaxError.java
+++ b/tajo-frontend/tajo-frontend-sql/src/main/java/tajo/frontend/sql/SQLSyntaxError.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-frontend/tajo-frontend-sql/src/test/java/tajo/frontend/sql/TestSQLAnalyzer.java
----------------------------------------------------------------------
diff --git a/tajo-frontend/tajo-frontend-sql/src/test/java/tajo/frontend/sql/TestSQLAnalyzer.java b/tajo-frontend/tajo-frontend-sql/src/test/java/tajo/frontend/sql/TestSQLAnalyzer.java
index f70d7d0..93e12b8 100644
--- a/tajo-frontend/tajo-frontend-sql/src/test/java/tajo/frontend/sql/TestSQLAnalyzer.java
+++ b/tajo-frontend/tajo-frontend-sql/src/test/java/tajo/frontend/sql/TestSQLAnalyzer.java
@@ -1,7 +1,11 @@
-/*
- * 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-frontend/tajo-frontend-sql/src/test/java/tajo/frontend/sql/TestSQLParser.java
----------------------------------------------------------------------
diff --git a/tajo-frontend/tajo-frontend-sql/src/test/java/tajo/frontend/sql/TestSQLParser.java b/tajo-frontend/tajo-frontend-sql/src/test/java/tajo/frontend/sql/TestSQLParser.java
index 6867dde..e038187 100644
--- a/tajo-frontend/tajo-frontend-sql/src/test/java/tajo/frontend/sql/TestSQLParser.java
+++ b/tajo-frontend/tajo-frontend-sql/src/test/java/tajo/frontend/sql/TestSQLParser.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.frontend.sql;
 
 import org.antlr.runtime.ANTLRStringStream;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-project/pom.xml
----------------------------------------------------------------------
diff --git a/tajo-project/pom.xml b/tajo-project/pom.xml
index 164b0fc..bf1ef47 100644
--- a/tajo-project/pom.xml
+++ b/tajo-project/pom.xml
@@ -1,9 +1,12 @@
+<?xml version="1.0" encoding="UTF-8"?>
 <!--
-  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
 
@@ -13,6 +16,7 @@
   See the License for the specific language governing permissions and
   limitations under the License.
   -->
+
 <project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
          xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
   <modelVersion>4.0.0</modelVersion>
@@ -202,6 +206,11 @@
           <version>2.8.1</version>
         </plugin>
         <plugin>
+          <groupId>org.apache.rat</groupId>
+          <artifactId>apache-rat-plugin</artifactId>
+          <version>0.8</version>
+        </plugin>
+        <plugin>
           <groupId>org.apache.maven.plugins</groupId>
           <artifactId>maven-checkstyle-plugin</artifactId>
           <version>2.6</version>

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-project/src/site/apt/build.apt
----------------------------------------------------------------------
diff --git a/tajo-project/src/site/apt/build.apt b/tajo-project/src/site/apt/build.apt
index 3fdd426..664fb47 100644
--- a/tajo-project/src/site/apt/build.apt
+++ b/tajo-project/src/site/apt/build.apt
@@ -1,3 +1,19 @@
+~~ 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.
+
             ------
             Tajo - Build Instruction
             ------

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-project/src/site/apt/configuration.apt
----------------------------------------------------------------------
diff --git a/tajo-project/src/site/apt/configuration.apt b/tajo-project/src/site/apt/configuration.apt
index 0555a47..26e518b 100644
--- a/tajo-project/src/site/apt/configuration.apt
+++ b/tajo-project/src/site/apt/configuration.apt
@@ -1,3 +1,19 @@
+~~ 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.
+
             ------
             Tajo - Configuration Guide
             ------

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-project/src/site/apt/getting_started.apt
----------------------------------------------------------------------
diff --git a/tajo-project/src/site/apt/getting_started.apt b/tajo-project/src/site/apt/getting_started.apt
index 3134262..f3c68a9 100644
--- a/tajo-project/src/site/apt/getting_started.apt
+++ b/tajo-project/src/site/apt/getting_started.apt
@@ -1,3 +1,19 @@
+~~ 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.
+
             ------
             Tajo - Getting Started
             ------

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-project/src/site/apt/index.apt
----------------------------------------------------------------------
diff --git a/tajo-project/src/site/apt/index.apt b/tajo-project/src/site/apt/index.apt
index 00af3c9..ed8cf98 100644
--- a/tajo-project/src/site/apt/index.apt
+++ b/tajo-project/src/site/apt/index.apt
@@ -1,3 +1,19 @@
+~~ 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.
+
             ------
             Tajo - Introduction
             ------

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-project/src/site/apt/query_language.apt
----------------------------------------------------------------------
diff --git a/tajo-project/src/site/apt/query_language.apt b/tajo-project/src/site/apt/query_language.apt
index 8a69cc6..66a6b0a 100644
--- a/tajo-project/src/site/apt/query_language.apt
+++ b/tajo-project/src/site/apt/query_language.apt
@@ -1,3 +1,19 @@
+~~ 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.
+
             ------------------------
             Tajo - Query Language
             ------------------------

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-project/src/site/fml/faq.fml
----------------------------------------------------------------------
diff --git a/tajo-project/src/site/fml/faq.fml b/tajo-project/src/site/fml/faq.fml
index 3f9509a..f6719b3 100644
--- a/tajo-project/src/site/fml/faq.fml
+++ b/tajo-project/src/site/fml/faq.fml
@@ -1,4 +1,22 @@
 <?xml version="1.0" encoding="UTF-8"?>
+<!--
+  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.
+  -->
+
 <faqs xmlns="http://maven.apache.org/FML/1.0.1" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
 	xsi:schemaLocation="http://maven.apache.org/FML/1.0.1 http://maven.apache.org/xsd/fml-1.0.1.xsd"
 	title="Frequently Asked Questions" toplink="true">

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-project/src/site/site.xml
----------------------------------------------------------------------
diff --git a/tajo-project/src/site/site.xml b/tajo-project/src/site/site.xml
index 37932b2..b6b7f9d 100644
--- a/tajo-project/src/site/site.xml
+++ b/tajo-project/src/site/site.xml
@@ -1,4 +1,22 @@
 <?xml version="1.0" encoding="UTF-8"?>
+<!--
+  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.
+  -->
+
 <project xmlns="http://maven.apache.org/DECORATION/1.3.0"
          xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
          xsi:schemaLocation="http://maven.apache.org/DECORATION/1.3.0

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-rpc/src/main/java/tajo/rpc/CallFuture.java
----------------------------------------------------------------------
diff --git a/tajo-rpc/src/main/java/tajo/rpc/CallFuture.java b/tajo-rpc/src/main/java/tajo/rpc/CallFuture.java
index 7d3838e..74bc01b 100644
--- a/tajo-rpc/src/main/java/tajo/rpc/CallFuture.java
+++ b/tajo-rpc/src/main/java/tajo/rpc/CallFuture.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-rpc/src/main/java/tajo/rpc/CallFuture2.java
----------------------------------------------------------------------
diff --git a/tajo-rpc/src/main/java/tajo/rpc/CallFuture2.java b/tajo-rpc/src/main/java/tajo/rpc/CallFuture2.java
index 838d4b9..526f511 100644
--- a/tajo-rpc/src/main/java/tajo/rpc/CallFuture2.java
+++ b/tajo-rpc/src/main/java/tajo/rpc/CallFuture2.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-rpc/src/main/java/tajo/rpc/Callback.java
----------------------------------------------------------------------
diff --git a/tajo-rpc/src/main/java/tajo/rpc/Callback.java b/tajo-rpc/src/main/java/tajo/rpc/Callback.java
index de9ebe0..6f0432a 100644
--- a/tajo-rpc/src/main/java/tajo/rpc/Callback.java
+++ b/tajo-rpc/src/main/java/tajo/rpc/Callback.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-rpc/src/main/java/tajo/rpc/NettyAsyncRpcProxy.java
----------------------------------------------------------------------
diff --git a/tajo-rpc/src/main/java/tajo/rpc/NettyAsyncRpcProxy.java b/tajo-rpc/src/main/java/tajo/rpc/NettyAsyncRpcProxy.java
index 4fe5793..2906056 100644
--- a/tajo-rpc/src/main/java/tajo/rpc/NettyAsyncRpcProxy.java
+++ b/tajo-rpc/src/main/java/tajo/rpc/NettyAsyncRpcProxy.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-rpc/src/main/java/tajo/rpc/NettyBlockingRpcProxy.java
----------------------------------------------------------------------
diff --git a/tajo-rpc/src/main/java/tajo/rpc/NettyBlockingRpcProxy.java b/tajo-rpc/src/main/java/tajo/rpc/NettyBlockingRpcProxy.java
index 72ce5cc..ceb6fb6 100644
--- a/tajo-rpc/src/main/java/tajo/rpc/NettyBlockingRpcProxy.java
+++ b/tajo-rpc/src/main/java/tajo/rpc/NettyBlockingRpcProxy.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-rpc/src/main/java/tajo/rpc/NettyClientBase.java
----------------------------------------------------------------------
diff --git a/tajo-rpc/src/main/java/tajo/rpc/NettyClientBase.java b/tajo-rpc/src/main/java/tajo/rpc/NettyClientBase.java
index 75639af..e139b1d 100644
--- a/tajo-rpc/src/main/java/tajo/rpc/NettyClientBase.java
+++ b/tajo-rpc/src/main/java/tajo/rpc/NettyClientBase.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-rpc/src/main/java/tajo/rpc/NettyRpc.java
----------------------------------------------------------------------
diff --git a/tajo-rpc/src/main/java/tajo/rpc/NettyRpc.java b/tajo-rpc/src/main/java/tajo/rpc/NettyRpc.java
index 41ca97b..54285b2 100644
--- a/tajo-rpc/src/main/java/tajo/rpc/NettyRpc.java
+++ b/tajo-rpc/src/main/java/tajo/rpc/NettyRpc.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-rpc/src/main/java/tajo/rpc/NettyRpcController.java
----------------------------------------------------------------------
diff --git a/tajo-rpc/src/main/java/tajo/rpc/NettyRpcController.java b/tajo-rpc/src/main/java/tajo/rpc/NettyRpcController.java
index 432747d..1d04a0f 100644
--- a/tajo-rpc/src/main/java/tajo/rpc/NettyRpcController.java
+++ b/tajo-rpc/src/main/java/tajo/rpc/NettyRpcController.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-rpc/src/main/java/tajo/rpc/NettyRpcServer.java
----------------------------------------------------------------------
diff --git a/tajo-rpc/src/main/java/tajo/rpc/NettyRpcServer.java b/tajo-rpc/src/main/java/tajo/rpc/NettyRpcServer.java
index 466789f..a276d7e 100644
--- a/tajo-rpc/src/main/java/tajo/rpc/NettyRpcServer.java
+++ b/tajo-rpc/src/main/java/tajo/rpc/NettyRpcServer.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-rpc/src/main/java/tajo/rpc/NettyServerBase.java
----------------------------------------------------------------------
diff --git a/tajo-rpc/src/main/java/tajo/rpc/NettyServerBase.java b/tajo-rpc/src/main/java/tajo/rpc/NettyServerBase.java
index 15bad95..19ffd60 100644
--- a/tajo-rpc/src/main/java/tajo/rpc/NettyServerBase.java
+++ b/tajo-rpc/src/main/java/tajo/rpc/NettyServerBase.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-rpc/src/main/java/tajo/rpc/NullCallback.java
----------------------------------------------------------------------
diff --git a/tajo-rpc/src/main/java/tajo/rpc/NullCallback.java b/tajo-rpc/src/main/java/tajo/rpc/NullCallback.java
index f11c866..859f748 100644
--- a/tajo-rpc/src/main/java/tajo/rpc/NullCallback.java
+++ b/tajo-rpc/src/main/java/tajo/rpc/NullCallback.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
  *


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

Posted by hy...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-storage/src/main/java/tajo/storage/FileScanner.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/FileScanner.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/FileScanner.java
index 44fc55a..5a27889 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/FileScanner.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/FileScanner.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.storage;
 
 import org.apache.hadoop.conf.Configuration;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-storage/src/main/java/tajo/storage/Fragment.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/Fragment.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/Fragment.java
index bcb10c0..1122b7b 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/Fragment.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/Fragment.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-storage/src/main/java/tajo/storage/FrameTuple.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/FrameTuple.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/FrameTuple.java
index 42067a6..946a799 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/FrameTuple.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/FrameTuple.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.storage;
@@ -14,9 +32,6 @@ import java.net.InetAddress;
  * An instance of FrameTuple is an immutable tuple.
  * It contains two tuples and pretends to be one instance of Tuple for
  * join qual evaluatations.
- * 
- * @author Hyunsik Choi
- *
  */
 public class FrameTuple implements Tuple {
   private int size;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-storage/src/main/java/tajo/storage/MergeScanner.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/MergeScanner.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/MergeScanner.java
index 87d2d83..c8cd7d3 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/MergeScanner.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/MergeScanner.java
@@ -1,7 +1,11 @@
-/*
- * 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-storage/src/main/java/tajo/storage/NumericPathComparator.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/NumericPathComparator.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/NumericPathComparator.java
index 67f34b4..34f70a2 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/NumericPathComparator.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/NumericPathComparator.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-storage/src/main/java/tajo/storage/RawFile.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/RawFile.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/RawFile.java
index 9434ab2..74994b5 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/RawFile.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/RawFile.java
@@ -1,7 +1,11 @@
-/*
- * 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-storage/src/main/java/tajo/storage/RowFile.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/RowFile.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/RowFile.java
index ce2fad2..4ee8cec 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/RowFile.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/RowFile.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-storage/src/main/java/tajo/storage/RowStoreUtil.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/RowStoreUtil.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/RowStoreUtil.java
index 4cfe228..88766a7 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/RowStoreUtil.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/RowStoreUtil.java
@@ -1,4 +1,4 @@
-/*
+/**
  * 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-storage/src/main/java/tajo/storage/Scanner.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/Scanner.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/Scanner.java
index 5f263b2..42b9798 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/Scanner.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/Scanner.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.storage;
 
 import tajo.catalog.Column;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-storage/src/main/java/tajo/storage/SeekableScanner.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/SeekableScanner.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/SeekableScanner.java
index 4f62b07..d0e95a2 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/SeekableScanner.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/SeekableScanner.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.storage;
 
 import java.io.IOException;
 
-/**
- * @author Hyunsik Choi
- */
 public interface SeekableScanner extends Scanner {
 
   public abstract long getNextOffset() throws IOException;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-storage/src/main/java/tajo/storage/Storage.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/Storage.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/Storage.java
index b90702c..fb005d6 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/Storage.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/Storage.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.storage;
 
 import org.apache.hadoop.conf.Configuration;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-storage/src/main/java/tajo/storage/StorageManager.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/StorageManager.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/StorageManager.java
index efe2d4a..712cfad 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/StorageManager.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/StorageManager.java
@@ -1,7 +1,11 @@
-/*
- * 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-storage/src/main/java/tajo/storage/StorageUtil.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/StorageUtil.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/StorageUtil.java
index 8d704bd..293148e 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/StorageUtil.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/StorageUtil.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.storage;
 
 import org.apache.hadoop.conf.Configuration;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-storage/src/main/java/tajo/storage/TableStatistics.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/TableStatistics.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/TableStatistics.java
index 9ab727a..5d93af1 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/TableStatistics.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/TableStatistics.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 tajo.datum.DatumType;
 
 /**
  * This class is not thread-safe.
- *
- * @author Hyunsik Choi
  */
 public class TableStatistics {
   private Schema schema;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-storage/src/main/java/tajo/storage/Tuple.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/Tuple.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/Tuple.java
index bddbb0f..e96c524 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/Tuple.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/Tuple.java
@@ -1,16 +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.storage;
 
 import tajo.datum.*;
 
 import java.net.InetAddress;
 
-/** 
- * 
- * @author jimin
- * @author Hyunsik Choi
- * 
- */
-
 public interface Tuple {
   
 	public int size();

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-storage/src/main/java/tajo/storage/TupleComparator.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/TupleComparator.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/TupleComparator.java
index adcec5a..bbd0cc6 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/TupleComparator.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/TupleComparator.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-storage/src/main/java/tajo/storage/TupleRange.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/TupleRange.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/TupleRange.java
index c30bd0a..ce4acea 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/TupleRange.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/TupleRange.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.storage;
 
 import com.google.common.base.Objects;
@@ -7,9 +25,6 @@ import tajo.catalog.SortSpec;
 
 import java.util.Comparator;
 
-/**
- * @author Hyunsik Choi
- */
 public class TupleRange implements Comparable<TupleRange> {
   private final Schema schema;
   private final Tuple start;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-storage/src/main/java/tajo/storage/VTuple.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/VTuple.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/VTuple.java
index fce9396..89f1230 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/VTuple.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/VTuple.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.datum.exception.InvalidCastException;
 import java.net.InetAddress;
 import java.util.Arrays;
 
-/**
- * @author Hyunsik Choi
- * 
- */
 public class VTuple implements Tuple {
 	@Expose public Datum [] values;
 	@Expose private long offset;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-storage/src/main/java/tajo/storage/exception/AlreadyExistsStorageException.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/exception/AlreadyExistsStorageException.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/exception/AlreadyExistsStorageException.java
index c5852c2..c375f7b 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/exception/AlreadyExistsStorageException.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/exception/AlreadyExistsStorageException.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.storage.exception;
@@ -7,10 +25,6 @@ import org.apache.hadoop.fs.Path;
 
 import java.io.IOException;
 
-/**
- * @author hyunsik
- *
- */
 public class AlreadyExistsStorageException extends IOException {
   private static final long serialVersionUID = 965518916144019032L;
 

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-storage/src/main/java/tajo/storage/exception/UnknownCodecException.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/exception/UnknownCodecException.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/exception/UnknownCodecException.java
index 4765f8b..b17aa34 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/exception/UnknownCodecException.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/exception/UnknownCodecException.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-storage/src/main/java/tajo/storage/exception/UnknownDataTypeException.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/exception/UnknownDataTypeException.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/exception/UnknownDataTypeException.java
index 115fb66..67a63d7 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/exception/UnknownDataTypeException.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/exception/UnknownDataTypeException.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-storage/src/main/java/tajo/storage/exception/UnsupportedFileTypeException.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/exception/UnsupportedFileTypeException.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/exception/UnsupportedFileTypeException.java
index 88036d3..3ea0731 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/exception/UnsupportedFileTypeException.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/exception/UnsupportedFileTypeException.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.storage.exception;
 
 /**
- * @author Hyunsik Choi
- *
+ * 
  */
+package tajo.storage.exception;
+
 public class UnsupportedFileTypeException extends RuntimeException {
 	private static final long serialVersionUID = -8160289695849000342L;
 

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/BasicBlock.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/BasicBlock.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/BasicBlock.java
index cc39caf..56b376a 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/BasicBlock.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/BasicBlock.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-storage/src/main/java/tajo/storage/hcfile/Block.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/Block.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/Block.java
index 09aeec3..a4180e0 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/Block.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/Block.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-storage/src/main/java/tajo/storage/hcfile/BlockMeta.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/BlockMeta.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/BlockMeta.java
index 22b2f76..fa7c718 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/BlockMeta.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/BlockMeta.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-storage/src/main/java/tajo/storage/hcfile/BlockReader.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/BlockReader.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/BlockReader.java
index bc1a68e..762c7dc 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/BlockReader.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/BlockReader.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-storage/src/main/java/tajo/storage/hcfile/BlockWriter.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/BlockWriter.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/BlockWriter.java
index 88eac8a..a4e9691 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/BlockWriter.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/BlockWriter.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-storage/src/main/java/tajo/storage/hcfile/ColumnAppender.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/ColumnAppender.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/ColumnAppender.java
index 29ebeda..f6b9488 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/ColumnAppender.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/ColumnAppender.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-storage/src/main/java/tajo/storage/hcfile/ColumnFileAppender.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/ColumnFileAppender.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/ColumnFileAppender.java
index 385d69e..1799b25 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/ColumnFileAppender.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/ColumnFileAppender.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-storage/src/main/java/tajo/storage/hcfile/ColumnFileScanner.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/ColumnFileScanner.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/ColumnFileScanner.java
index a23c1bf..5aedab1 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/ColumnFileScanner.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/ColumnFileScanner.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-storage/src/main/java/tajo/storage/hcfile/ColumnMeta.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/ColumnMeta.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/ColumnMeta.java
index 9171fdb..8cdc07c 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/ColumnMeta.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/ColumnMeta.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-storage/src/main/java/tajo/storage/hcfile/ColumnReader.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/ColumnReader.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/ColumnReader.java
index 31cb1aa..fbe8757 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/ColumnReader.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/ColumnReader.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-storage/src/main/java/tajo/storage/hcfile/ColumnScanner.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/ColumnScanner.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/ColumnScanner.java
index b01dca8..1c70422 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/ColumnScanner.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/ColumnScanner.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-storage/src/main/java/tajo/storage/hcfile/ColumnStoreUtil.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/ColumnStoreUtil.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/ColumnStoreUtil.java
index 17861e0..d40c49e 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/ColumnStoreUtil.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/ColumnStoreUtil.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-storage/src/main/java/tajo/storage/hcfile/CompressedBlock.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/CompressedBlock.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/CompressedBlock.java
index 3c3c34d..73f7998 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/CompressedBlock.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/CompressedBlock.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.storage.hcfile;
 
 import tajo.storage.hcfile.compress.Codec;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/CompressedBlockReader.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/CompressedBlockReader.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/CompressedBlockReader.java
index 8198464..c128ce6 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/CompressedBlockReader.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/CompressedBlockReader.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-storage/src/main/java/tajo/storage/hcfile/CompressedBlockWriter.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/CompressedBlockWriter.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/CompressedBlockWriter.java
index 168aa63..22a8c91 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/CompressedBlockWriter.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/CompressedBlockWriter.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-storage/src/main/java/tajo/storage/hcfile/HBlockMetaImpl.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/HBlockMetaImpl.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/HBlockMetaImpl.java
index bede85b..584d2ce 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/HBlockMetaImpl.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/HBlockMetaImpl.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-storage/src/main/java/tajo/storage/hcfile/HCFile.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/HCFile.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/HCFile.java
index f2d1be2..83df49e 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/HCFile.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/HCFile.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-storage/src/main/java/tajo/storage/hcfile/HCFileMetaImpl.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/HCFileMetaImpl.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/HCFileMetaImpl.java
index b7f0303..e06e944 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/HCFileMetaImpl.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/HCFileMetaImpl.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-storage/src/main/java/tajo/storage/hcfile/HCTupleAppender.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/HCTupleAppender.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/HCTupleAppender.java
index 2d2a963..5de66a5 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/HCTupleAppender.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/HCTupleAppender.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-storage/src/main/java/tajo/storage/hcfile/HColumnMetaWritable.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/HColumnMetaWritable.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/HColumnMetaWritable.java
index cf204e9..4a49f9e 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/HColumnMetaWritable.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/HColumnMetaWritable.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.storage.hcfile;
 
 import org.apache.hadoop.io.Writable;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/HColumnReader.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/HColumnReader.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/HColumnReader.java
index 791f0c8..9994c68 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/HColumnReader.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/HColumnReader.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-storage/src/main/java/tajo/storage/hcfile/Index.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/Index.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/Index.java
index e5fb924..7e6dbf8 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/Index.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/Index.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-storage/src/main/java/tajo/storage/hcfile/IndexItem.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/IndexItem.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/IndexItem.java
index 0e59554..8ce62c3 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/IndexItem.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/IndexItem.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-storage/src/main/java/tajo/storage/hcfile/Seekable.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/Seekable.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/Seekable.java
index 6659876..1a82270 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/Seekable.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/Seekable.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-storage/src/main/java/tajo/storage/hcfile/TupleAppender.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/TupleAppender.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/TupleAppender.java
index a9be792..bf19a50 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/TupleAppender.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/TupleAppender.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-storage/src/main/java/tajo/storage/hcfile/Updatable.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/Updatable.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/Updatable.java
index 0948775..5952d3d 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/Updatable.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/Updatable.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-storage/src/main/java/tajo/storage/hcfile/UpdatableBlock.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/UpdatableBlock.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/UpdatableBlock.java
index f1e82c8..8321075 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/UpdatableBlock.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/UpdatableBlock.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-storage/src/main/java/tajo/storage/hcfile/UpdatableSeekableBlock.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/UpdatableSeekableBlock.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/UpdatableSeekableBlock.java
index 5f047d1..b2d6ea6 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/UpdatableSeekableBlock.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/UpdatableSeekableBlock.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-storage/src/main/java/tajo/storage/hcfile/compress/BitVector.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/compress/BitVector.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/compress/BitVector.java
index ecc6b08..15944dd 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/compress/BitVector.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/compress/BitVector.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-storage/src/main/java/tajo/storage/hcfile/compress/Codec.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/compress/Codec.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/compress/Codec.java
index 7915dbe..2fe019b 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/compress/Codec.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/compress/Codec.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-storage/src/main/java/tajo/storage/hcfile/compress/Dictionary.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/compress/Dictionary.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/compress/Dictionary.java
index 85c6262..681b855 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/compress/Dictionary.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/compress/Dictionary.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-storage/src/main/java/tajo/storage/hcfile/compress/LZ.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/compress/LZ.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/compress/LZ.java
index ad49b3c..ad1f9c8 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/compress/LZ.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/compress/LZ.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-storage/src/main/java/tajo/storage/hcfile/compress/NullSuppress.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/compress/NullSuppress.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/compress/NullSuppress.java
index a980bb7..18dc09f 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/compress/NullSuppress.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/compress/NullSuppress.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-storage/src/main/java/tajo/storage/hcfile/compress/RunLength.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/compress/RunLength.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/compress/RunLength.java
index 79c46a0..9402181 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/compress/RunLength.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/compress/RunLength.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-storage/src/main/java/tajo/storage/hcfile/compress/Snappy.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/compress/Snappy.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/compress/Snappy.java
index edece98..33cd64b 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/compress/Snappy.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/compress/Snappy.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-storage/src/main/java/tajo/storage/hcfile/reader/ArrayReader.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/reader/ArrayReader.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/reader/ArrayReader.java
index 34f5d35..a7215b0 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/reader/ArrayReader.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/reader/ArrayReader.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-storage/src/main/java/tajo/storage/hcfile/reader/ByteReader.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/reader/ByteReader.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/reader/ByteReader.java
index 8c0b807..3a37fd7 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/reader/ByteReader.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/reader/ByteReader.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-storage/src/main/java/tajo/storage/hcfile/reader/BytesReader.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/reader/BytesReader.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/reader/BytesReader.java
index 256bc8b..6a22904 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/reader/BytesReader.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/reader/BytesReader.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-storage/src/main/java/tajo/storage/hcfile/reader/CharReader.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/reader/CharReader.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/reader/CharReader.java
index aaabdf4..19dd59c 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/reader/CharReader.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/reader/CharReader.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-storage/src/main/java/tajo/storage/hcfile/reader/DoubleReader.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/reader/DoubleReader.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/reader/DoubleReader.java
index 5951bdc..021a42d 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/reader/DoubleReader.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/reader/DoubleReader.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-storage/src/main/java/tajo/storage/hcfile/reader/FloatReader.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/reader/FloatReader.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/reader/FloatReader.java
index 97341e0..e5f0e03 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/reader/FloatReader.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/reader/FloatReader.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-storage/src/main/java/tajo/storage/hcfile/reader/IPv4Reader.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/reader/IPv4Reader.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/reader/IPv4Reader.java
index 97ce4f5..d9094c7 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/reader/IPv4Reader.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/reader/IPv4Reader.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-storage/src/main/java/tajo/storage/hcfile/reader/IntReader.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/reader/IntReader.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/reader/IntReader.java
index 9f266d7..fa6ad62 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/reader/IntReader.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/reader/IntReader.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-storage/src/main/java/tajo/storage/hcfile/reader/LongReader.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/reader/LongReader.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/reader/LongReader.java
index 51e7176..3c4b96e 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/reader/LongReader.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/reader/LongReader.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-storage/src/main/java/tajo/storage/hcfile/reader/Reader.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/reader/Reader.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/reader/Reader.java
index c7a8f67..a9ab3aa 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/reader/Reader.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/reader/Reader.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-storage/src/main/java/tajo/storage/hcfile/reader/ShortReader.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/reader/ShortReader.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/reader/ShortReader.java
index 648a57b..7c1bf98 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/reader/ShortReader.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/reader/ShortReader.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-storage/src/main/java/tajo/storage/hcfile/reader/String2Reader.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/reader/String2Reader.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/reader/String2Reader.java
index b3d27c4..7407d49 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/reader/String2Reader.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/reader/String2Reader.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-storage/src/main/java/tajo/storage/hcfile/reader/StringReader.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/reader/StringReader.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/reader/StringReader.java
index 6360896..5043018 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/reader/StringReader.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/reader/StringReader.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-storage/src/main/java/tajo/storage/hcfile/reader/TypeReader.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/reader/TypeReader.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/reader/TypeReader.java
index 521cd2a..e9cf356 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/reader/TypeReader.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/reader/TypeReader.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-storage/src/main/java/tajo/storage/hcfile/writer/ArrayWriter.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/writer/ArrayWriter.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/writer/ArrayWriter.java
index 2a3b841..526f746 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/writer/ArrayWriter.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/writer/ArrayWriter.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-storage/src/main/java/tajo/storage/hcfile/writer/ByteWriter.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/writer/ByteWriter.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/writer/ByteWriter.java
index 4e0b228..e7b84e4 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/writer/ByteWriter.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/writer/ByteWriter.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-storage/src/main/java/tajo/storage/hcfile/writer/BytesWriter.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/writer/BytesWriter.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/writer/BytesWriter.java
index dd0a8de..3835a3f 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/writer/BytesWriter.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/writer/BytesWriter.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-storage/src/main/java/tajo/storage/hcfile/writer/CharWriter.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/writer/CharWriter.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/writer/CharWriter.java
index 017d49b..b1b365c 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/writer/CharWriter.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/writer/CharWriter.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-storage/src/main/java/tajo/storage/hcfile/writer/DoubleWriter.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/writer/DoubleWriter.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/writer/DoubleWriter.java
index f0b5275..13c4dff 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/writer/DoubleWriter.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/writer/DoubleWriter.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-storage/src/main/java/tajo/storage/hcfile/writer/FloatWriter.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/writer/FloatWriter.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/writer/FloatWriter.java
index 5073f0f..72fc77f 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/writer/FloatWriter.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/writer/FloatWriter.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-storage/src/main/java/tajo/storage/hcfile/writer/IntWriter.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/writer/IntWriter.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/writer/IntWriter.java
index 7c8d772..676e815 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/writer/IntWriter.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/writer/IntWriter.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-storage/src/main/java/tajo/storage/hcfile/writer/LongWriter.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/writer/LongWriter.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/writer/LongWriter.java
index c631f3d..2e1c3f2 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/writer/LongWriter.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/writer/LongWriter.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-storage/src/main/java/tajo/storage/hcfile/writer/ShortWriter.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/writer/ShortWriter.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/writer/ShortWriter.java
index 31211a2..5868456 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/writer/ShortWriter.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/writer/ShortWriter.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-storage/src/main/java/tajo/storage/hcfile/writer/TypeWriter.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/writer/TypeWriter.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/writer/TypeWriter.java
index d14308f..4f1f20a 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/writer/TypeWriter.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/writer/TypeWriter.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-storage/src/main/java/tajo/storage/hcfile/writer/Writer.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/writer/Writer.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/writer/Writer.java
index 5e0359e..ed0bb3e 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/writer/Writer.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/hcfile/writer/Writer.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-storage/src/main/java/tajo/storage/index/IndexMethod.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/index/IndexMethod.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/index/IndexMethod.java
index ce35385..b24e72e 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/index/IndexMethod.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/index/IndexMethod.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.storage.index;
 
 import org.apache.hadoop.fs.Path;
@@ -6,9 +24,6 @@ import tajo.storage.TupleComparator;
 
 import java.io.IOException;
 
-/**
- * @author Hyunsik Choi
- */
 public interface IndexMethod {
   IndexWriter getIndexWriter(final Path fileName, int level, Schema keySchema,
       TupleComparator comparator) throws IOException;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-storage/src/main/java/tajo/storage/index/IndexProtos.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/index/IndexProtos.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/index/IndexProtos.java
index bb13f43..5f9152f 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/index/IndexProtos.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/index/IndexProtos.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.
+ */
+
 // Generated by the protocol buffer compiler.  DO NOT EDIT!
 // source: IndexProtos.proto
 

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-storage/src/main/java/tajo/storage/index/IndexReader.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/index/IndexReader.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/index/IndexReader.java
index a9df011..3c4fcad 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/index/IndexReader.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/index/IndexReader.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.storage.index;
 
 import tajo.storage.Tuple;
 
 import java.io.IOException;
 
-/**
- * @author Hyunsik Choi
- */
 public interface IndexReader {
   
   /**

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-storage/src/main/java/tajo/storage/index/IndexWriter.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/index/IndexWriter.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/index/IndexWriter.java
index 2adcbb1..df8ae1a 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/index/IndexWriter.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/index/IndexWriter.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.storage.index;
@@ -7,9 +25,6 @@ import tajo.storage.Tuple;
 
 import java.io.IOException;
 
-/**
- * @author Hyunsik Choi
- */
 public abstract class IndexWriter {
   
   public abstract void write(Tuple key, long offset) throws IOException;


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

Posted by hy...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/test/java/tajo/engine/parser/TestQueryAnalyzer.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/parser/TestQueryAnalyzer.java b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/parser/TestQueryAnalyzer.java
index c6d4b21..dbfe71b 100644
--- a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/parser/TestQueryAnalyzer.java
+++ b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/parser/TestQueryAnalyzer.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/test/java/tajo/engine/plan/global/TestGlobalQueryPlanner.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/plan/global/TestGlobalQueryPlanner.java b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/plan/global/TestGlobalQueryPlanner.java
index f78ca89..2af74bb 100644
--- a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/plan/global/TestGlobalQueryPlanner.java
+++ b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/plan/global/TestGlobalQueryPlanner.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/test/java/tajo/engine/planner/TestLogicalNode.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/TestLogicalNode.java b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/TestLogicalNode.java
index 618963c..8149e4d 100644
--- a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/TestLogicalNode.java
+++ b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/TestLogicalNode.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;
 
 import tajo.engine.planner.logical.LogicalNode;
 
 import static org.junit.Assert.assertEquals;
 
-/**
- * @author Hyunsik Choi
- */
-public class TestLogicalNode {  
+public class TestLogicalNode {
   public static final void testCloneLogicalNode(LogicalNode n1) 
       throws CloneNotSupportedException {
     LogicalNode copy = (LogicalNode) n1.clone();

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/TestLogicalOptimizer.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/TestLogicalOptimizer.java b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/TestLogicalOptimizer.java
index 8e105b2..1b5fd19 100644
--- a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/TestLogicalOptimizer.java
+++ b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/TestLogicalOptimizer.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;
 
 import org.apache.hadoop.fs.Path;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/TestLogicalPlanner.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/TestLogicalPlanner.java b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/TestLogicalPlanner.java
index ac7b25a..0c8ec4f 100644
--- a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/TestLogicalPlanner.java
+++ b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/TestLogicalPlanner.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
@@ -49,9 +47,6 @@ import java.util.*;
 import static org.junit.Assert.assertEquals;
 import static org.junit.Assert.assertTrue;
 
-/**
- * @author Hyunsik Choi
- */
 public class TestLogicalPlanner {
   private static TajoTestingCluster util;
   private static CatalogService catalog;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/TestPlannerUtil.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/TestPlannerUtil.java b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/TestPlannerUtil.java
index 176b99f..1b311ab 100644
--- a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/TestPlannerUtil.java
+++ b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/TestPlannerUtil.java
@@ -1,21 +1,19 @@
-/*
- *  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
+ * 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
  *
- *  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://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.
+ * 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;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/TestUniformRangePartition.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/TestUniformRangePartition.java b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/TestUniformRangePartition.java
index 7dc77e4..e436c7b 100644
--- a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/TestUniformRangePartition.java
+++ b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/TestUniformRangePartition.java
@@ -1,7 +1,11 @@
-/*
- * 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/test/java/tajo/engine/planner/global/TestGlobalQueryOptimizer.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/global/TestGlobalQueryOptimizer.java b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/global/TestGlobalQueryOptimizer.java
index 9be7ae4..fae28f7 100644
--- a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/global/TestGlobalQueryOptimizer.java
+++ b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/global/TestGlobalQueryOptimizer.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/test/java/tajo/engine/planner/logical/extended/TestReceiveNode.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/logical/extended/TestReceiveNode.java b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/logical/extended/TestReceiveNode.java
index 513868d..7557bc9 100644
--- a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/logical/extended/TestReceiveNode.java
+++ b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/logical/extended/TestReceiveNode.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;
 
 import com.google.common.collect.Lists;
@@ -9,9 +27,6 @@ import java.util.List;
 
 import static org.junit.Assert.assertEquals;
 
-/**
- * @author Hyunsik Choi
- */
 public class TestReceiveNode {
   @Test
   public final void testReceiveNode() throws CloneNotSupportedException {

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/logical/extended/TestSendNode.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/logical/extended/TestSendNode.java b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/logical/extended/TestSendNode.java
index 6946efe..d154896 100644
--- a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/logical/extended/TestSendNode.java
+++ b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/logical/extended/TestSendNode.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;
 
 import org.junit.Test;
@@ -7,9 +25,6 @@ import java.net.URI;
 
 import static org.junit.Assert.assertEquals;
 
-/**
- * @author Hyunsik Choi
- */
 public class TestSendNode {
   @Test
   public final void testSendNode() throws CloneNotSupportedException {

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/physical/TestBNLJoinExec.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/physical/TestBNLJoinExec.java b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/physical/TestBNLJoinExec.java
index e93caa0..ea74a8c 100644
--- a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/physical/TestBNLJoinExec.java
+++ b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/physical/TestBNLJoinExec.java
@@ -1,7 +1,11 @@
-/*
- * 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/test/java/tajo/engine/planner/physical/TestBSTIndexExec.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/physical/TestBSTIndexExec.java b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/physical/TestBSTIndexExec.java
index 659f979..cff7f7f 100644
--- a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/physical/TestBSTIndexExec.java
+++ b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/physical/TestBSTIndexExec.java
@@ -1,7 +1,11 @@
-/*
- * 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/test/java/tajo/engine/planner/physical/TestExternalSortExec.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/physical/TestExternalSortExec.java b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/physical/TestExternalSortExec.java
index 5fff2d9..b43c80a 100644
--- a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/physical/TestExternalSortExec.java
+++ b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/physical/TestExternalSortExec.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/test/java/tajo/engine/planner/physical/TestHashJoinExec.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/physical/TestHashJoinExec.java b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/physical/TestHashJoinExec.java
index 206fc5f..47f743c 100644
--- a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/physical/TestHashJoinExec.java
+++ b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/physical/TestHashJoinExec.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/test/java/tajo/engine/planner/physical/TestHashPartitioner.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/physical/TestHashPartitioner.java b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/physical/TestHashPartitioner.java
index 514d1e9..dd2f53b 100644
--- a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/physical/TestHashPartitioner.java
+++ b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/physical/TestHashPartitioner.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 org.junit.After;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/physical/TestMergeJoinExec.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/physical/TestMergeJoinExec.java b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/physical/TestMergeJoinExec.java
index 0a4dafb..46d264b 100644
--- a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/physical/TestMergeJoinExec.java
+++ b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/physical/TestMergeJoinExec.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/test/java/tajo/engine/planner/physical/TestNLJoinExec.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/physical/TestNLJoinExec.java b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/physical/TestNLJoinExec.java
index 61f2c86..f8b8877 100644
--- a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/physical/TestNLJoinExec.java
+++ b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/physical/TestNLJoinExec.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/test/java/tajo/engine/planner/physical/TestPhysicalPlanner.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/physical/TestPhysicalPlanner.java b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/physical/TestPhysicalPlanner.java
index 84a383b..6b8496a 100644
--- a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/physical/TestPhysicalPlanner.java
+++ b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/physical/TestPhysicalPlanner.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/test/java/tajo/engine/planner/physical/TestSortExec.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/physical/TestSortExec.java b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/physical/TestSortExec.java
index a9a6b0d..694875f 100644
--- a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/physical/TestSortExec.java
+++ b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/planner/physical/TestSortExec.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/test/java/tajo/engine/query/TestGroupByQuery.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/query/TestGroupByQuery.java b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/query/TestGroupByQuery.java
index bce1abd..f1655bc 100644
--- a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/query/TestGroupByQuery.java
+++ b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/query/TestGroupByQuery.java
@@ -1,21 +1,19 @@
-/*
- * 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
+ * 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
  *
- *  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://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.
+ * 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;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/test/java/tajo/engine/query/TestJoinQuery.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/query/TestJoinQuery.java b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/query/TestJoinQuery.java
index d683315..64c4ccb 100644
--- a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/query/TestJoinQuery.java
+++ b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/query/TestJoinQuery.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.query;
 
 import com.google.common.collect.Maps;
@@ -17,9 +35,6 @@ import java.util.Map;
 import static org.junit.Assert.assertEquals;
 import static org.junit.Assert.assertFalse;
 
-/**
- * @author Hyunsik Choi
- */
 @Category(IntegrationTest.class)
 public class TestJoinQuery {
   static TpchTestBase tpch;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/test/java/tajo/engine/query/TestNullValues.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/query/TestNullValues.java b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/query/TestNullValues.java
index d6a4981..167b15e 100644
--- a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/query/TestNullValues.java
+++ b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/query/TestNullValues.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/test/java/tajo/engine/query/TestResultSetImpl.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/query/TestResultSetImpl.java b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/query/TestResultSetImpl.java
index 0f020af..f1f09ef 100644
--- a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/query/TestResultSetImpl.java
+++ b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/query/TestResultSetImpl.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/test/java/tajo/engine/query/TestSelectQuery.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/query/TestSelectQuery.java b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/query/TestSelectQuery.java
index 5fb25c5..fb60751 100644
--- a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/query/TestSelectQuery.java
+++ b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/query/TestSelectQuery.java
@@ -1,21 +1,19 @@
-/*
- *  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
+ * 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
  *
- *  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://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.
+ * 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;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/test/java/tajo/engine/query/TestSortQuery.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/query/TestSortQuery.java b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/query/TestSortQuery.java
index 4f1c3a5..81a9fe7 100644
--- a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/query/TestSortQuery.java
+++ b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/query/TestSortQuery.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 java.sql.ResultSet;
 
 import static org.junit.Assert.*;
 
-/**
- * @author Hyunsik Choi
- */
 @Category(IntegrationTest.class)
 public class TestSortQuery {
   static TpchTestBase tpch;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/test/java/tajo/engine/util/TestTupleUtil.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/util/TestTupleUtil.java b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/util/TestTupleUtil.java
index 8133b3d..9a23083 100644
--- a/tajo-core/tajo-core-backend/src/test/java/tajo/engine/util/TestTupleUtil.java
+++ b/tajo-core/tajo-core-backend/src/test/java/tajo/engine/util/TestTupleUtil.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.util;
 
 import org.junit.Test;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/test/java/tajo/master/TestRepartitioner.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/java/tajo/master/TestRepartitioner.java b/tajo-core/tajo-core-backend/src/test/java/tajo/master/TestRepartitioner.java
index fc641f7..ca3e870 100644
--- a/tajo-core/tajo-core-backend/src/test/java/tajo/master/TestRepartitioner.java
+++ b/tajo-core/tajo-core-backend/src/test/java/tajo/master/TestRepartitioner.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/test/java/tajo/storage/TestFragment.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/java/tajo/storage/TestFragment.java b/tajo-core/tajo-core-backend/src/test/java/tajo/storage/TestFragment.java
index 11ab9be..87a45ed 100644
--- a/tajo-core/tajo-core-backend/src/test/java/tajo/storage/TestFragment.java
+++ b/tajo-core/tajo-core-backend/src/test/java/tajo/storage/TestFragment.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.storage;
 
 import com.google.common.collect.Sets;
@@ -11,7 +29,6 @@ import tajo.catalog.TableMeta;
 import tajo.catalog.proto.CatalogProtos.DataType;
 import tajo.catalog.proto.CatalogProtos.StoreType;
 import tajo.engine.json.GsonCreator;
-import tajo.storage.Fragment;
 
 import java.util.Arrays;
 import java.util.SortedSet;
@@ -19,11 +36,6 @@ import java.util.SortedSet;
 import static org.junit.Assert.assertEquals;
 import static org.junit.Assert.assertTrue;
 
-/**
- * 
- * @author Hyunsik Choi
- *
- */
 public class TestFragment {
   private Schema schema1;
   private TableMeta meta1;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/test/java/tajo/storage/TestHCFile.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/java/tajo/storage/TestHCFile.java b/tajo-core/tajo-core-backend/src/test/java/tajo/storage/TestHCFile.java
index cde1aef..aa4e9f0 100644
--- a/tajo-core/tajo-core-backend/src/test/java/tajo/storage/TestHCFile.java
+++ b/tajo-core/tajo-core-backend/src/test/java/tajo/storage/TestHCFile.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/test/java/tajo/storage/TestHColumnReader.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/java/tajo/storage/TestHColumnReader.java b/tajo-core/tajo-core-backend/src/test/java/tajo/storage/TestHColumnReader.java
index 0a85ceb..df72f39 100644
--- a/tajo-core/tajo-core-backend/src/test/java/tajo/storage/TestHColumnReader.java
+++ b/tajo-core/tajo-core-backend/src/test/java/tajo/storage/TestHColumnReader.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/test/java/tajo/storage/TestRowFile.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/java/tajo/storage/TestRowFile.java b/tajo-core/tajo-core-backend/src/test/java/tajo/storage/TestRowFile.java
index 61abe24..4e98d8b 100644
--- a/tajo-core/tajo-core-backend/src/test/java/tajo/storage/TestRowFile.java
+++ b/tajo-core/tajo-core-backend/src/test/java/tajo/storage/TestRowFile.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/test/java/tajo/webapp/TestHttpServer.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/java/tajo/webapp/TestHttpServer.java b/tajo-core/tajo-core-backend/src/test/java/tajo/webapp/TestHttpServer.java
index 2afbcc1..2ec589b 100644
--- a/tajo-core/tajo-core-backend/src/test/java/tajo/webapp/TestHttpServer.java
+++ b/tajo-core/tajo-core-backend/src/test/java/tajo/webapp/TestHttpServer.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
  *
@@ -34,9 +36,6 @@ import java.util.Random;
 
 import static org.junit.Assert.assertTrue;
 
-/**
- * @author Hyunsik Choi
- */
 public class TestHttpServer {
   private static HttpServer server;  
   private final static Random rnd = new Random();

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/test/java/tajo/worker/SlowFunc.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/java/tajo/worker/SlowFunc.java b/tajo-core/tajo-core-backend/src/test/java/tajo/worker/SlowFunc.java
index 049a562..a6f2a3a 100644
--- a/tajo-core/tajo-core-backend/src/test/java/tajo/worker/SlowFunc.java
+++ b/tajo-core/tajo-core-backend/src/test/java/tajo/worker/SlowFunc.java
@@ -1,6 +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.worker;
 
 import org.mortbay.log.Log;
@@ -11,10 +26,6 @@ import tajo.catalog.proto.CatalogProtos.DataType;
 import tajo.datum.Datum;
 import tajo.storage.Tuple;
 
-/**
- * @author hyunsik
- * 
- */
 public class SlowFunc extends AggFunction {
   private Datum param;
 

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/test/java/tajo/worker/TaskRunnerTest.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/java/tajo/worker/TaskRunnerTest.java b/tajo-core/tajo-core-backend/src/test/java/tajo/worker/TaskRunnerTest.java
index 28c5079..131e797 100644
--- a/tajo-core/tajo-core-backend/src/test/java/tajo/worker/TaskRunnerTest.java
+++ b/tajo-core/tajo-core-backend/src/test/java/tajo/worker/TaskRunnerTest.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/test/java/tajo/worker/TestFetcher.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/java/tajo/worker/TestFetcher.java b/tajo-core/tajo-core-backend/src/test/java/tajo/worker/TestFetcher.java
index 87bb166..9037e10 100644
--- a/tajo-core/tajo-core-backend/src/test/java/tajo/worker/TestFetcher.java
+++ b/tajo-core/tajo-core-backend/src/test/java/tajo/worker/TestFetcher.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.worker;
 
 import org.apache.hadoop.fs.FileStatus;
@@ -21,9 +39,6 @@ import java.util.Random;
 
 import static org.junit.Assert.assertEquals;
 
-/** 
- * @author Hyunsik Choi
- */
 public class TestFetcher {
   private String TEST_DATA = "target/test-data/TestFetcher";
   private String INPUT_DIR = TEST_DATA+"/in/";

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/test/java/tajo/worker/TestRangeRetrieverHandler.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/java/tajo/worker/TestRangeRetrieverHandler.java b/tajo-core/tajo-core-backend/src/test/java/tajo/worker/TestRangeRetrieverHandler.java
index f3d87b2..f32f756 100644
--- a/tajo-core/tajo-core-backend/src/test/java/tajo/worker/TestRangeRetrieverHandler.java
+++ b/tajo-core/tajo-core-backend/src/test/java/tajo/worker/TestRangeRetrieverHandler.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/test/java/tajo/worker/dataserver/TestHttpDataServer.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/java/tajo/worker/dataserver/TestHttpDataServer.java b/tajo-core/tajo-core-backend/src/test/java/tajo/worker/dataserver/TestHttpDataServer.java
index 4f6af00..7261534 100644
--- a/tajo-core/tajo-core-backend/src/test/java/tajo/worker/dataserver/TestHttpDataServer.java
+++ b/tajo-core/tajo-core-backend/src/test/java/tajo/worker/dataserver/TestHttpDataServer.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.worker.dataserver;
 
 import org.apache.hadoop.net.NetUtils;
@@ -18,9 +36,6 @@ import java.util.Random;
 
 import static org.junit.Assert.assertTrue;
 
-/**
- * @author Hyunsik Choi
- */
 public class TestHttpDataServer {
   private String TEST_DATA = "target/test-data/TestHttpDataServer";
   

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/test/java/tajo/worker/dataserver/TestHttpUtil.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/java/tajo/worker/dataserver/TestHttpUtil.java b/tajo-core/tajo-core-backend/src/test/java/tajo/worker/dataserver/TestHttpUtil.java
index 72edae0..e32630c 100644
--- a/tajo-core/tajo-core-backend/src/test/java/tajo/worker/dataserver/TestHttpUtil.java
+++ b/tajo-core/tajo-core-backend/src/test/java/tajo/worker/dataserver/TestHttpUtil.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.worker.dataserver;
 
 import com.google.common.collect.Maps;
@@ -9,9 +27,6 @@ import java.util.Map;
 
 import static org.junit.Assert.assertEquals;
 
-/**
- * @author Hyunsik Choi
- */
 public class TestHttpUtil {
   private URI uri = URI.create("http://127.0.0.1:80/?key1=val1&key2=val2");
 

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/test/resources/catalog-default.xml
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/resources/catalog-default.xml b/tajo-core/tajo-core-backend/src/test/resources/catalog-default.xml
index 8fffea7..e7e46b1 100644
--- a/tajo-core/tajo-core-backend/src/test/resources/catalog-default.xml
+++ b/tajo-core/tajo-core-backend/src/test/resources/catalog-default.xml
@@ -2,11 +2,13 @@
 <?xml-stylesheet type="text/xsl" href="configuration.xsl"?>
 
 <!--
-  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/test/resources/log4j.properties
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/resources/log4j.properties b/tajo-core/tajo-core-backend/src/test/resources/log4j.properties
index 86f7ff9..ad07100 100644
--- a/tajo-core/tajo-core-backend/src/test/resources/log4j.properties
+++ b/tajo-core/tajo-core-backend/src/test/resources/log4j.properties
@@ -1,14 +1,20 @@
-#   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://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.
 #
-#   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.
 
 # log4j configuration used during build and unit tests
 

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/test/resources/tajo-default.xml
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/resources/tajo-default.xml b/tajo-core/tajo-core-backend/src/test/resources/tajo-default.xml
index 21f47a3..c003637 100644
--- a/tajo-core/tajo-core-backend/src/test/resources/tajo-default.xml
+++ b/tajo-core/tajo-core-backend/src/test/resources/tajo-default.xml
@@ -1,6 +1,24 @@
 <?xml version="1.0"?>
 <?xml-stylesheet type="text/xsl" href="configuration.xsl"?>
 
+<!--
+  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.
+  -->
+
 <configuration>
   <property>
     <name>tajo.cluster.distributed</name>

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/test/resources/webapps/TestHttpServer/WEB-INF/web.xml
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/resources/webapps/TestHttpServer/WEB-INF/web.xml b/tajo-core/tajo-core-backend/src/test/resources/webapps/TestHttpServer/WEB-INF/web.xml
index b8f6fac..748947d 100644
--- a/tajo-core/tajo-core-backend/src/test/resources/webapps/TestHttpServer/WEB-INF/web.xml
+++ b/tajo-core/tajo-core-backend/src/test/resources/webapps/TestHttpServer/WEB-INF/web.xml
@@ -1,4 +1,22 @@
 <?xml version="1.0" encoding="UTF-8"?>
+<!--
+  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.
+  -->
+
 <web-app>
   <display-name>TestHttpServer</display-name>
 

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/test/resources/webapps/TestHttpServer/index.html
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/resources/webapps/TestHttpServer/index.html b/tajo-core/tajo-core-backend/src/test/resources/webapps/TestHttpServer/index.html
index 08430ef..fc79d65 100644
--- a/tajo-core/tajo-core-backend/src/test/resources/webapps/TestHttpServer/index.html
+++ b/tajo-core/tajo-core-backend/src/test/resources/webapps/TestHttpServer/index.html
@@ -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.
+  -->
+
 <html>
 <body>
 TestHttpServlet-120221

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/test/resources/yarn-site.xml
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/test/resources/yarn-site.xml b/tajo-core/tajo-core-backend/src/test/resources/yarn-site.xml
index 26a12bd..440d315 100644
--- a/tajo-core/tajo-core-backend/src/test/resources/yarn-site.xml
+++ b/tajo-core/tajo-core-backend/src/test/resources/yarn-site.xml
@@ -1,9 +1,13 @@
 <?xml version="1.0" encoding="UTF-8"?>
 <?xml-stylesheet type="text/xsl" href="configuration.xsl"?>
 <!--
-  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-pullserver/pom.xml
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-pullserver/pom.xml b/tajo-core/tajo-core-pullserver/pom.xml
index 48a44cb..c10fee9 100644
--- a/tajo-core/tajo-core-pullserver/pom.xml
+++ b/tajo-core/tajo-core-pullserver/pom.xml
@@ -1,10 +1,12 @@
 <?xml version="1.0" encoding="UTF-8"?>
 <!--
-  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-pullserver/src/main/java/tajo/pullserver/FadvisedFileRegion.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-pullserver/src/main/java/tajo/pullserver/FadvisedFileRegion.java b/tajo-core/tajo-core-pullserver/src/main/java/tajo/pullserver/FadvisedFileRegion.java
index abf8d40..6c25115 100644
--- a/tajo-core/tajo-core-pullserver/src/main/java/tajo/pullserver/FadvisedFileRegion.java
+++ b/tajo-core/tajo-core-pullserver/src/main/java/tajo/pullserver/FadvisedFileRegion.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-pullserver/src/main/java/tajo/pullserver/FileAccessForbiddenException.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-pullserver/src/main/java/tajo/pullserver/FileAccessForbiddenException.java b/tajo-core/tajo-core-pullserver/src/main/java/tajo/pullserver/FileAccessForbiddenException.java
index d1e8e95..4410214 100644
--- a/tajo-core/tajo-core-pullserver/src/main/java/tajo/pullserver/FileAccessForbiddenException.java
+++ b/tajo-core/tajo-core-pullserver/src/main/java/tajo/pullserver/FileAccessForbiddenException.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.pullserver;
 
 import java.io.IOException;
 
-/**
- * @author Hyunsik Choi
- */
 public class FileAccessForbiddenException extends IOException {
   private static final long serialVersionUID = -3383272565826389213L;
 

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-pullserver/src/main/java/tajo/pullserver/HttpDataServerHandler.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-pullserver/src/main/java/tajo/pullserver/HttpDataServerHandler.java b/tajo-core/tajo-core-pullserver/src/main/java/tajo/pullserver/HttpDataServerHandler.java
index f067862..4a6af87 100644
--- a/tajo-core/tajo-core-pullserver/src/main/java/tajo/pullserver/HttpDataServerHandler.java
+++ b/tajo-core/tajo-core-pullserver/src/main/java/tajo/pullserver/HttpDataServerHandler.java
@@ -1,7 +1,11 @@
-/*
- * 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
  *
@@ -44,9 +48,6 @@ import static org.jboss.netty.handler.codec.http.HttpMethod.GET;
 import static org.jboss.netty.handler.codec.http.HttpResponseStatus.*;
 import static org.jboss.netty.handler.codec.http.HttpVersion.HTTP_1_1;
 
-/**
- * @author Hyunsik Choi
- */
 public class HttpDataServerHandler extends SimpleChannelUpstreamHandler {
   private final static Log LOG = LogFactory.getLog(HttpDataServerHandler.class);
 

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-pullserver/src/main/java/tajo/pullserver/HttpDataServerPipelineFactory.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-pullserver/src/main/java/tajo/pullserver/HttpDataServerPipelineFactory.java b/tajo-core/tajo-core-pullserver/src/main/java/tajo/pullserver/HttpDataServerPipelineFactory.java
index 109516b..6527fe5 100644
--- a/tajo-core/tajo-core-pullserver/src/main/java/tajo/pullserver/HttpDataServerPipelineFactory.java
+++ b/tajo-core/tajo-core-pullserver/src/main/java/tajo/pullserver/HttpDataServerPipelineFactory.java
@@ -1,7 +1,11 @@
-/*
- * 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,9 +27,6 @@ import org.jboss.netty.handler.stream.ChunkedWriteHandler;
 
 import static org.jboss.netty.channel.Channels.pipeline;
 
-/**
- * @author Hyunsik Choi
- */
 public class HttpDataServerPipelineFactory implements ChannelPipelineFactory {
   private String userName;
   private String appId;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-pullserver/src/main/java/tajo/pullserver/HttpUtil.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-pullserver/src/main/java/tajo/pullserver/HttpUtil.java b/tajo-core/tajo-core-pullserver/src/main/java/tajo/pullserver/HttpUtil.java
index dd1485d..677e37d 100644
--- a/tajo-core/tajo-core-pullserver/src/main/java/tajo/pullserver/HttpUtil.java
+++ b/tajo-core/tajo-core-pullserver/src/main/java/tajo/pullserver/HttpUtil.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.pullserver;
 
 import com.google.common.collect.Maps;
@@ -7,9 +25,6 @@ import java.net.URI;
 import java.net.URLEncoder;
 import java.util.Map;
 
-/**
- * @author  Hyunsik Choi
- */
 public class HttpUtil {
   public static Map<String,String> getParams(URI uri) throws UnsupportedEncodingException {
     return getParamsFromQuery(uri.getQuery());

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-pullserver/src/main/java/tajo/pullserver/PullServerAuxService.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-pullserver/src/main/java/tajo/pullserver/PullServerAuxService.java b/tajo-core/tajo-core-pullserver/src/main/java/tajo/pullserver/PullServerAuxService.java
index a817418..63d3568 100644
--- a/tajo-core/tajo-core-pullserver/src/main/java/tajo/pullserver/PullServerAuxService.java
+++ b/tajo-core/tajo-core-pullserver/src/main/java/tajo/pullserver/PullServerAuxService.java
@@ -1,7 +1,11 @@
-/*
- * 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-pullserver/src/main/java/tajo/pullserver/retriever/AdvancedDataRetriever.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-pullserver/src/main/java/tajo/pullserver/retriever/AdvancedDataRetriever.java b/tajo-core/tajo-core-pullserver/src/main/java/tajo/pullserver/retriever/AdvancedDataRetriever.java
index e68708a..409ce79 100644
--- a/tajo-core/tajo-core-pullserver/src/main/java/tajo/pullserver/retriever/AdvancedDataRetriever.java
+++ b/tajo-core/tajo-core-pullserver/src/main/java/tajo/pullserver/retriever/AdvancedDataRetriever.java
@@ -1,6 +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.pullserver.retriever;
 
 import com.google.common.collect.Lists;
@@ -24,9 +39,6 @@ import java.util.Collections;
 import java.util.List;
 import java.util.Map;
 
-/**
- * @author Hyunsik Choi
- */
 public class AdvancedDataRetriever implements DataRetriever {
   private final Log LOG = LogFactory.getLog(AdvancedDataRetriever.class);
   private final Map<String, RetrieverHandler> handlerMap = Maps.newConcurrentMap();

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-pullserver/src/main/java/tajo/pullserver/retriever/DataRetriever.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-pullserver/src/main/java/tajo/pullserver/retriever/DataRetriever.java b/tajo-core/tajo-core-pullserver/src/main/java/tajo/pullserver/retriever/DataRetriever.java
index 6752eab..0f6e705 100644
--- a/tajo-core/tajo-core-pullserver/src/main/java/tajo/pullserver/retriever/DataRetriever.java
+++ b/tajo-core/tajo-core-pullserver/src/main/java/tajo/pullserver/retriever/DataRetriever.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.pullserver.retriever;
 
 import org.jboss.netty.channel.ChannelHandlerContext;
@@ -5,10 +23,7 @@ import org.jboss.netty.handler.codec.http.HttpRequest;
 
 import java.io.IOException;
 
-/**
- * @author Hyunsik Choi
- */
-public interface DataRetriever {  
+public interface DataRetriever {
   FileChunk [] handle(ChannelHandlerContext ctx, HttpRequest request)
       throws IOException;
 }

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-pullserver/src/main/java/tajo/pullserver/retriever/DirectoryRetriever.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-pullserver/src/main/java/tajo/pullserver/retriever/DirectoryRetriever.java b/tajo-core/tajo-core-pullserver/src/main/java/tajo/pullserver/retriever/DirectoryRetriever.java
index 54bfddd..6ca0b0b 100644
--- a/tajo-core/tajo-core-pullserver/src/main/java/tajo/pullserver/retriever/DirectoryRetriever.java
+++ b/tajo-core/tajo-core-pullserver/src/main/java/tajo/pullserver/retriever/DirectoryRetriever.java
@@ -1,6 +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.pullserver.retriever;
 
 import org.jboss.netty.channel.ChannelHandlerContext;
@@ -12,9 +27,6 @@ import java.io.File;
 import java.io.FileNotFoundException;
 import java.io.IOException;
 
-/**
- * @author Hyunsik Choi
- */
 public class DirectoryRetriever implements DataRetriever {
   public String baseDir;
   

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-pullserver/src/main/java/tajo/pullserver/retriever/FileChunk.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-pullserver/src/main/java/tajo/pullserver/retriever/FileChunk.java b/tajo-core/tajo-core-pullserver/src/main/java/tajo/pullserver/retriever/FileChunk.java
index 9342084..c52c8d1 100644
--- a/tajo-core/tajo-core-pullserver/src/main/java/tajo/pullserver/retriever/FileChunk.java
+++ b/tajo-core/tajo-core-pullserver/src/main/java/tajo/pullserver/retriever/FileChunk.java
@@ -1,11 +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.pullserver.retriever;
 
 import java.io.File;
 import java.io.FileNotFoundException;
 
-/**
- * @author Hyunsik Choi
- */
 public class FileChunk {
   private final File file;
   public final long startOffset;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-pullserver/src/main/java/tajo/pullserver/retriever/RetrieverHandler.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-pullserver/src/main/java/tajo/pullserver/retriever/RetrieverHandler.java b/tajo-core/tajo-core-pullserver/src/main/java/tajo/pullserver/retriever/RetrieverHandler.java
index 196e80f..bfef270 100644
--- a/tajo-core/tajo-core-pullserver/src/main/java/tajo/pullserver/retriever/RetrieverHandler.java
+++ b/tajo-core/tajo-core-pullserver/src/main/java/tajo/pullserver/retriever/RetrieverHandler.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.pullserver.retriever;
 
 import java.io.IOException;
 import java.util.List;
 import java.util.Map;
 
-/**
- * @author Hyunsik Choi
- */
 public interface RetrieverHandler {
   /**
    *

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-pullserver/src/main/resources/tajo-default.xml
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-pullserver/src/main/resources/tajo-default.xml b/tajo-core/tajo-core-pullserver/src/main/resources/tajo-default.xml
index 21f47a3..c003637 100644
--- a/tajo-core/tajo-core-pullserver/src/main/resources/tajo-default.xml
+++ b/tajo-core/tajo-core-pullserver/src/main/resources/tajo-default.xml
@@ -1,6 +1,24 @@
 <?xml version="1.0"?>
 <?xml-stylesheet type="text/xsl" href="configuration.xsl"?>
 
+<!--
+  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.
+  -->
+
 <configuration>
   <property>
     <name>tajo.cluster.distributed</name>

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-storage/src/main/java/tajo/storage/Appender.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/Appender.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/Appender.java
index 8a32841..e701e3f 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/Appender.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/Appender.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.storage;
 
 import tajo.catalog.statistics.TableStat;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-storage/src/main/java/tajo/storage/CSVFile.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/CSVFile.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/CSVFile.java
index 31bee3e..1311f7f 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/CSVFile.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/CSVFile.java
@@ -1,19 +1,19 @@
-/*
+/**
  * 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
+ * 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://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.
+ * 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.storage;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-storage/src/main/java/tajo/storage/FileAppender.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/FileAppender.java b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/FileAppender.java
index bc362b1..9c2a84c 100644
--- a/tajo-core/tajo-core-storage/src/main/java/tajo/storage/FileAppender.java
+++ b/tajo-core/tajo-core-storage/src/main/java/tajo/storage/FileAppender.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


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

Posted by hy...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-common/src/main/java/tajo/gson/ClassNameDeserializer.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/java/tajo/gson/ClassNameDeserializer.java b/tajo-common/src/main/java/tajo/gson/ClassNameDeserializer.java
index 0310f04..edf8f48 100644
--- a/tajo-common/src/main/java/tajo/gson/ClassNameDeserializer.java
+++ b/tajo-common/src/main/java/tajo/gson/ClassNameDeserializer.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.gson;
@@ -10,10 +28,6 @@ import com.google.gson.JsonParseException;
 
 import java.lang.reflect.Type;
 
-/**
- * @author jihoon
- *
- */
 public class ClassNameDeserializer implements JsonDeserializer<Class> {
 
 	@Override

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-common/src/main/java/tajo/gson/ClassNameSerializer.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/java/tajo/gson/ClassNameSerializer.java b/tajo-common/src/main/java/tajo/gson/ClassNameSerializer.java
index 34e415a..672d064 100644
--- a/tajo-common/src/main/java/tajo/gson/ClassNameSerializer.java
+++ b/tajo-common/src/main/java/tajo/gson/ClassNameSerializer.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.gson;
@@ -10,10 +28,6 @@ import com.google.gson.JsonSerializer;
 
 import java.lang.reflect.Type;
 
-/**
- * @author jihoon
- *
- */
 public class ClassNameSerializer implements JsonSerializer<Class> {
 
 	@Override

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-common/src/main/java/tajo/gson/DatumTypeAdapter.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/java/tajo/gson/DatumTypeAdapter.java b/tajo-common/src/main/java/tajo/gson/DatumTypeAdapter.java
index 2ace09e..96e5064 100644
--- a/tajo-common/src/main/java/tajo/gson/DatumTypeAdapter.java
+++ b/tajo-common/src/main/java/tajo/gson/DatumTypeAdapter.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.gson;
 
 import com.google.gson.*;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-common/src/main/java/tajo/gson/PathDeserializer.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/java/tajo/gson/PathDeserializer.java b/tajo-common/src/main/java/tajo/gson/PathDeserializer.java
index de28bd5..b03d6a8 100644
--- a/tajo-common/src/main/java/tajo/gson/PathDeserializer.java
+++ b/tajo-common/src/main/java/tajo/gson/PathDeserializer.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.gson;
@@ -11,10 +29,6 @@ import org.apache.hadoop.fs.Path;
 
 import java.lang.reflect.Type;
 
-/**
- * @author jihoon
- *
- */
 public class PathDeserializer implements JsonDeserializer<Path> {
 
 	@Override

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-common/src/main/java/tajo/gson/PathSerializer.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/java/tajo/gson/PathSerializer.java b/tajo-common/src/main/java/tajo/gson/PathSerializer.java
index b8d85c5..b699cd8 100644
--- a/tajo-common/src/main/java/tajo/gson/PathSerializer.java
+++ b/tajo-common/src/main/java/tajo/gson/PathSerializer.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.gson;
@@ -11,10 +29,6 @@ import org.apache.hadoop.fs.Path;
 
 import java.lang.reflect.Type;
 
-/**
- * @author jihoon
- *
- */
 public class PathSerializer implements JsonSerializer<Path> {
 
 	@Override

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-common/src/main/java/tajo/storage/Tuple.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/java/tajo/storage/Tuple.java b/tajo-common/src/main/java/tajo/storage/Tuple.java
index ce71cd3..d13d388 100644
--- a/tajo-common/src/main/java/tajo/storage/Tuple.java
+++ b/tajo-common/src/main/java/tajo/storage/Tuple.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-common/src/main/java/tajo/unit/StorageUnit.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/java/tajo/unit/StorageUnit.java b/tajo-common/src/main/java/tajo/unit/StorageUnit.java
index 3c9d070..d44bec2 100644
--- a/tajo-common/src/main/java/tajo/unit/StorageUnit.java
+++ b/tajo-common/src/main/java/tajo/unit/StorageUnit.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-common/src/main/java/tajo/unit/TimeUnit.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/java/tajo/unit/TimeUnit.java b/tajo-common/src/main/java/tajo/unit/TimeUnit.java
index d185c92..7f2101b 100644
--- a/tajo-common/src/main/java/tajo/unit/TimeUnit.java
+++ b/tajo-common/src/main/java/tajo/unit/TimeUnit.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-common/src/main/java/tajo/util/BitArray.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/java/tajo/util/BitArray.java b/tajo-common/src/main/java/tajo/util/BitArray.java
index 38b7f43..20b9e55 100644
--- a/tajo-common/src/main/java/tajo/util/BitArray.java
+++ b/tajo-common/src/main/java/tajo/util/BitArray.java
@@ -1,7 +1,11 @@
-/*
- * 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-common/src/main/java/tajo/util/Bytes.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/java/tajo/util/Bytes.java b/tajo-common/src/main/java/tajo/util/Bytes.java
index c1e505b..e21cf31 100644
--- a/tajo-common/src/main/java/tajo/util/Bytes.java
+++ b/tajo-common/src/main/java/tajo/util/Bytes.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-common/src/main/java/tajo/util/CommonTestingUtil.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/java/tajo/util/CommonTestingUtil.java b/tajo-common/src/main/java/tajo/util/CommonTestingUtil.java
index 0c15626..ab573a5 100644
--- a/tajo-common/src/main/java/tajo/util/CommonTestingUtil.java
+++ b/tajo-common/src/main/java/tajo/util/CommonTestingUtil.java
@@ -1,7 +1,11 @@
-/*
- * 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-common/src/main/java/tajo/util/FileUtil.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/java/tajo/util/FileUtil.java b/tajo-common/src/main/java/tajo/util/FileUtil.java
index eb8e1da..199c266 100644
--- a/tajo-common/src/main/java/tajo/util/FileUtil.java
+++ b/tajo-common/src/main/java/tajo/util/FileUtil.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-common/src/main/java/tajo/util/JarUtil.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/java/tajo/util/JarUtil.java b/tajo-common/src/main/java/tajo/util/JarUtil.java
index 5d55610..7ae7b2d 100644
--- a/tajo-common/src/main/java/tajo/util/JarUtil.java
+++ b/tajo-common/src/main/java/tajo/util/JarUtil.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.util;
 
 import java.io.IOException;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-common/src/main/java/tajo/util/NumberUtil.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/java/tajo/util/NumberUtil.java b/tajo-common/src/main/java/tajo/util/NumberUtil.java
index c987139..600d8bc 100644
--- a/tajo-common/src/main/java/tajo/util/NumberUtil.java
+++ b/tajo-common/src/main/java/tajo/util/NumberUtil.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-common/src/main/java/tajo/util/ReflectionUtil.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/java/tajo/util/ReflectionUtil.java b/tajo-common/src/main/java/tajo/util/ReflectionUtil.java
index 9db4c23..563035b 100644
--- a/tajo-common/src/main/java/tajo/util/ReflectionUtil.java
+++ b/tajo-common/src/main/java/tajo/util/ReflectionUtil.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-common/src/main/java/tajo/util/TUtil.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/java/tajo/util/TUtil.java b/tajo-common/src/main/java/tajo/util/TUtil.java
index d738bfa..c028244 100644
--- a/tajo-common/src/main/java/tajo/util/TUtil.java
+++ b/tajo-common/src/main/java/tajo/util/TUtil.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,8 +25,6 @@ import java.util.*;
 
 /**
  * It provides miscellaneous and useful util methods.
- * 
- * @author Hyunsik Choi
  */
 public class TUtil {
   /**

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-common/src/main/java/tajo/util/TajoIdUtils.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/java/tajo/util/TajoIdUtils.java b/tajo-common/src/main/java/tajo/util/TajoIdUtils.java
index 34f63af..5fd5a18 100644
--- a/tajo-common/src/main/java/tajo/util/TajoIdUtils.java
+++ b/tajo-common/src/main/java/tajo/util/TajoIdUtils.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,9 +25,6 @@ import tajo.QueryId;
 import tajo.SubQueryId;
 import tajo.TajoIdProtos.SubQueryIdProto;
 
-/**
- * @author Hyunsik Choi
- */
 public class TajoIdUtils {
   /** It is mainly for DDL statements which don's have any query id. */
   public static final QueryId NullQueryId =

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-common/src/main/proto/TajoIdProtos.proto
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/proto/TajoIdProtos.proto b/tajo-common/src/main/proto/TajoIdProtos.proto
index 6ab0b09..abd47c0 100644
--- a/tajo-common/src/main/proto/TajoIdProtos.proto
+++ b/tajo-common/src/main/proto/TajoIdProtos.proto
@@ -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.
+ */
+
 option java_package = "tajo";
 option java_outer_classname = "TajoIdProtos";
 option java_generic_services = false;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-common/src/main/proto/TestProtos.proto
----------------------------------------------------------------------
diff --git a/tajo-common/src/main/proto/TestProtos.proto b/tajo-common/src/main/proto/TestProtos.proto
index c370251..868b6f1 100644
--- a/tajo-common/src/main/proto/TestProtos.proto
+++ b/tajo-common/src/main/proto/TestProtos.proto
@@ -1,4 +1,4 @@
-/*
+/**
  * 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-common/src/test/java/log4j.properties
----------------------------------------------------------------------
diff --git a/tajo-common/src/test/java/log4j.properties b/tajo-common/src/test/java/log4j.properties
index 0941b49..c1ac487 100644
--- a/tajo-common/src/test/java/log4j.properties
+++ b/tajo-common/src/test/java/log4j.properties
@@ -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
@@ -18,18 +16,6 @@
 # limitations under the License.
 #
 
-#   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
-#
-#       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.
-
 # log4j configuration used during build and unit tests
 
 log4j.rootLogger=info,stdout

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-common/src/test/java/tajo/common/type/TestIPv4.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/test/java/tajo/common/type/TestIPv4.java b/tajo-common/src/test/java/tajo/common/type/TestIPv4.java
index 0a733ba..8d4bf68 100644
--- a/tajo-common/src/test/java/tajo/common/type/TestIPv4.java
+++ b/tajo-common/src/test/java/tajo/common/type/TestIPv4.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-common/src/test/java/tajo/common/type/TestTimeRange.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/test/java/tajo/common/type/TestTimeRange.java b/tajo-common/src/test/java/tajo/common/type/TestTimeRange.java
index e173026..be74f4a 100644
--- a/tajo-common/src/test/java/tajo/common/type/TestTimeRange.java
+++ b/tajo-common/src/test/java/tajo/common/type/TestTimeRange.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-common/src/test/java/tajo/datum/TestBoolDatum.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/test/java/tajo/datum/TestBoolDatum.java b/tajo-common/src/test/java/tajo/datum/TestBoolDatum.java
index 70f5eaf..f73fb98 100644
--- a/tajo-common/src/test/java/tajo/datum/TestBoolDatum.java
+++ b/tajo-common/src/test/java/tajo/datum/TestBoolDatum.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-common/src/test/java/tajo/datum/TestByteDatum.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/test/java/tajo/datum/TestByteDatum.java b/tajo-common/src/test/java/tajo/datum/TestByteDatum.java
index ad7d921..9c8dd6a 100644
--- a/tajo-common/src/test/java/tajo/datum/TestByteDatum.java
+++ b/tajo-common/src/test/java/tajo/datum/TestByteDatum.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-common/src/test/java/tajo/datum/TestBytesDatum.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/test/java/tajo/datum/TestBytesDatum.java b/tajo-common/src/test/java/tajo/datum/TestBytesDatum.java
index b26b32c..962a793 100644
--- a/tajo-common/src/test/java/tajo/datum/TestBytesDatum.java
+++ b/tajo-common/src/test/java/tajo/datum/TestBytesDatum.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-common/src/test/java/tajo/datum/TestCharDatum.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/test/java/tajo/datum/TestCharDatum.java b/tajo-common/src/test/java/tajo/datum/TestCharDatum.java
index 925e5cb..c9272dd 100644
--- a/tajo-common/src/test/java/tajo/datum/TestCharDatum.java
+++ b/tajo-common/src/test/java/tajo/datum/TestCharDatum.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-common/src/test/java/tajo/datum/TestDatum.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/test/java/tajo/datum/TestDatum.java b/tajo-common/src/test/java/tajo/datum/TestDatum.java
index 2fb87fb..361ab9d 100644
--- a/tajo-common/src/test/java/tajo/datum/TestDatum.java
+++ b/tajo-common/src/test/java/tajo/datum/TestDatum.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-common/src/test/java/tajo/datum/TestDatumFactory.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/test/java/tajo/datum/TestDatumFactory.java b/tajo-common/src/test/java/tajo/datum/TestDatumFactory.java
index 3a5dcf4..4370bf8 100644
--- a/tajo-common/src/test/java/tajo/datum/TestDatumFactory.java
+++ b/tajo-common/src/test/java/tajo/datum/TestDatumFactory.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-common/src/test/java/tajo/datum/TestDoubleDatum.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/test/java/tajo/datum/TestDoubleDatum.java b/tajo-common/src/test/java/tajo/datum/TestDoubleDatum.java
index c879ae5..178ce01 100644
--- a/tajo-common/src/test/java/tajo/datum/TestDoubleDatum.java
+++ b/tajo-common/src/test/java/tajo/datum/TestDoubleDatum.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-common/src/test/java/tajo/datum/TestFloatDatum.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/test/java/tajo/datum/TestFloatDatum.java b/tajo-common/src/test/java/tajo/datum/TestFloatDatum.java
index 9d66f1b..bfc45bc 100644
--- a/tajo-common/src/test/java/tajo/datum/TestFloatDatum.java
+++ b/tajo-common/src/test/java/tajo/datum/TestFloatDatum.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-common/src/test/java/tajo/datum/TestIPv4Datum.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/test/java/tajo/datum/TestIPv4Datum.java b/tajo-common/src/test/java/tajo/datum/TestIPv4Datum.java
index eea43e7..e60a33b 100644
--- a/tajo-common/src/test/java/tajo/datum/TestIPv4Datum.java
+++ b/tajo-common/src/test/java/tajo/datum/TestIPv4Datum.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-common/src/test/java/tajo/datum/TestIntDatum.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/test/java/tajo/datum/TestIntDatum.java b/tajo-common/src/test/java/tajo/datum/TestIntDatum.java
index f31a5d9..faca9d8 100644
--- a/tajo-common/src/test/java/tajo/datum/TestIntDatum.java
+++ b/tajo-common/src/test/java/tajo/datum/TestIntDatum.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-common/src/test/java/tajo/datum/TestLongDatum.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/test/java/tajo/datum/TestLongDatum.java b/tajo-common/src/test/java/tajo/datum/TestLongDatum.java
index c842f70..00170f7 100644
--- a/tajo-common/src/test/java/tajo/datum/TestLongDatum.java
+++ b/tajo-common/src/test/java/tajo/datum/TestLongDatum.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-common/src/test/java/tajo/datum/TestShortDatum.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/test/java/tajo/datum/TestShortDatum.java b/tajo-common/src/test/java/tajo/datum/TestShortDatum.java
index 2ff9f35..83da6a5 100644
--- a/tajo-common/src/test/java/tajo/datum/TestShortDatum.java
+++ b/tajo-common/src/test/java/tajo/datum/TestShortDatum.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-common/src/test/java/tajo/datum/TestStringDatum.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/test/java/tajo/datum/TestStringDatum.java b/tajo-common/src/test/java/tajo/datum/TestStringDatum.java
index 367f8e7..a5f975b 100644
--- a/tajo-common/src/test/java/tajo/datum/TestStringDatum.java
+++ b/tajo-common/src/test/java/tajo/datum/TestStringDatum.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-common/src/test/java/tajo/util/TestBitArrayTest.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/test/java/tajo/util/TestBitArrayTest.java b/tajo-common/src/test/java/tajo/util/TestBitArrayTest.java
index f0abb3f..3839409 100644
--- a/tajo-common/src/test/java/tajo/util/TestBitArrayTest.java
+++ b/tajo-common/src/test/java/tajo/util/TestBitArrayTest.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.util;
 
 import org.junit.Test;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-common/src/test/java/tajo/util/TestFileUtils.java
----------------------------------------------------------------------
diff --git a/tajo-common/src/test/java/tajo/util/TestFileUtils.java b/tajo-common/src/test/java/tajo/util/TestFileUtils.java
index c4bf64e..d0e84b7 100644
--- a/tajo-common/src/test/java/tajo/util/TestFileUtils.java
+++ b/tajo-common/src/test/java/tajo/util/TestFileUtils.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/pom.xml
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/pom.xml b/tajo-core/tajo-core-backend/pom.xml
index 1dd5b7d..071b7d5 100644
--- a/tajo-core/tajo-core-backend/pom.xml
+++ b/tajo-core/tajo-core-backend/pom.xml
@@ -1,10 +1,12 @@
 <?xml version="1.0" encoding="UTF-8"?>
 <!--
-  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/antlr3/tajo/engine/parser/NQL.g
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/antlr3/tajo/engine/parser/NQL.g b/tajo-core/tajo-core-backend/src/main/antlr3/tajo/engine/parser/NQL.g
index ec3ec95..725941c 100644
--- a/tajo-core/tajo-core-backend/src/main/antlr3/tajo/engine/parser/NQL.g
+++ b/tajo-core/tajo-core-backend/src/main/antlr3/tajo/engine/parser/NQL.g
@@ -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/findbugs/findbugs-exclude.xml
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/findbugs/findbugs-exclude.xml b/tajo-core/tajo-core-backend/src/main/findbugs/findbugs-exclude.xml
index e3cf54c..255fb23 100644
--- a/tajo-core/tajo-core-backend/src/main/findbugs/findbugs-exclude.xml
+++ b/tajo-core/tajo-core-backend/src/main/findbugs/findbugs-exclude.xml
@@ -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.
+  -->
+
 <FindBugsFilter>
      <Match>
 		<Package name="~nta\.engine\.parser" />

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/log4j.properties
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/log4j.properties b/tajo-core/tajo-core-backend/src/main/java/log4j.properties
index c557d8f..c1ac487 100644
--- a/tajo-core/tajo-core-backend/src/main/java/log4j.properties
+++ b/tajo-core/tajo-core-backend/src/main/java/log4j.properties
@@ -1,14 +1,20 @@
-#   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://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.
 #
-#   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.
 
 # log4j configuration used during build and unit tests
 

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/QueryConf.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/QueryConf.java b/tajo-core/tajo-core-backend/src/main/java/tajo/QueryConf.java
index 1b33eb4..a1e5179 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/QueryConf.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/QueryConf.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/TaskAttemptContext.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/TaskAttemptContext.java b/tajo-core/tajo-core-backend/src/main/java/tajo/TaskAttemptContext.java
index 9918d8e..fa3c24a 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/TaskAttemptContext.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/TaskAttemptContext.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/benchmark/BenchmarkSet.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/benchmark/BenchmarkSet.java b/tajo-core/tajo-core-backend/src/main/java/tajo/benchmark/BenchmarkSet.java
index 68f77b4..9deea32 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/benchmark/BenchmarkSet.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/benchmark/BenchmarkSet.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.benchmark;
 
 import com.google.protobuf.ServiceException;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/benchmark/Driver.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/benchmark/Driver.java b/tajo-core/tajo-core-backend/src/main/java/tajo/benchmark/Driver.java
index c271fe1..69b9a18 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/benchmark/Driver.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/benchmark/Driver.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.benchmark;
 
 import tajo.conf.TajoConf;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/benchmark/SimpleQuery.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/benchmark/SimpleQuery.java b/tajo-core/tajo-core-backend/src/main/java/tajo/benchmark/SimpleQuery.java
index c8cc8db..9feae05 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/benchmark/SimpleQuery.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/benchmark/SimpleQuery.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.benchmark;
 
 import java.io.IOException;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/benchmark/TPCH.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/benchmark/TPCH.java b/tajo-core/tajo-core-backend/src/main/java/tajo/benchmark/TPCH.java
index cd7f3a2..c4ce6d4 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/benchmark/TPCH.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/benchmark/TPCH.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.benchmark;
 
 import com.google.protobuf.ServiceException;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/cli/TajoCli.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/cli/TajoCli.java b/tajo-core/tajo-core-backend/src/main/java/tajo/cli/TajoCli.java
index 1270449..07742fb 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/cli/TajoCli.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/cli/TajoCli.java
@@ -1,7 +1,11 @@
-/*
- * 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
  *
@@ -36,9 +40,6 @@ import java.sql.ResultSet;
 import java.sql.ResultSetMetaData;
 import java.util.List;
 
-/**
- * @author Hyunsik Choi
- */
 public class TajoCli {
   private final TajoConf conf;
   private static final Options options;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/client/QueryStatus.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/client/QueryStatus.java b/tajo-core/tajo-core-backend/src/main/java/tajo/client/QueryStatus.java
index 8d02b82..27895c5 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/client/QueryStatus.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/client/QueryStatus.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/client/ResultSetUtil.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/client/ResultSetUtil.java b/tajo-core/tajo-core-backend/src/main/java/tajo/client/ResultSetUtil.java
index a61ddcf..d79181f 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/client/ResultSetUtil.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/client/ResultSetUtil.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.client;
 
 import java.sql.ResultSet;
 import java.sql.ResultSetMetaData;
 import java.sql.SQLException;
 
-/**
- * @author Hyunsik Choi
- */
 public class ResultSetUtil {
   public static String prettyFormat(ResultSet res) throws SQLException {
     StringBuilder sb = new StringBuilder();

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/client/TajoClient.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/client/TajoClient.java b/tajo-core/tajo-core-backend/src/main/java/tajo/client/TajoClient.java
index 4acc6c8..32eed96 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/client/TajoClient.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/client/TajoClient.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
  *
@@ -39,9 +41,6 @@ import java.net.InetSocketAddress;
 import java.sql.ResultSet;
 import java.util.List;
 
-/**
- * @author Hyunsik Choi
- */
 public class TajoClient {
   private final Log LOG = LogFactory.getLog(TajoClient.class);
 

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/AggFuncCallEval.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/AggFuncCallEval.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/AggFuncCallEval.java
index 2150430..55237e7 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/AggFuncCallEval.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/AggFuncCallEval.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/eval/AlgebraicException.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/AlgebraicException.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/AlgebraicException.java
index 0c87dc3..d97afe7 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/AlgebraicException.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/AlgebraicException.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/eval/AlgebraicUtil.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/AlgebraicUtil.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/AlgebraicUtil.java
index 6a532c5..b886e2a 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/AlgebraicUtil.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/AlgebraicUtil.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,9 +22,6 @@ import tajo.catalog.Column;
 
 import java.util.Map;
 
-/**
- * @author Hyunsik Choi
- */
 public class AlgebraicUtil {
   
   /**

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/BinaryEval.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/BinaryEval.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/BinaryEval.java
index 0d79da1..7468eec 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/BinaryEval.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/BinaryEval.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
@@ -18,9 +16,6 @@
  * limitations under the License.
  */
 
-/**
- * 
- */
 package tajo.engine.eval;
 
 import com.google.common.base.Objects;
@@ -35,10 +30,6 @@ import tajo.engine.json.GsonCreator;
 import tajo.engine.utils.SchemaUtil;
 import tajo.storage.Tuple;
 
-/**
- * @author Hyunsik Choi
- *
- */
 public class BinaryEval extends EvalNode implements Cloneable {
 	@Expose private DataType [] returnType = null;
 

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/CaseWhenEval.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/CaseWhenEval.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/CaseWhenEval.java
index d6488d9..07fec9c 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/CaseWhenEval.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/CaseWhenEval.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
@@ -32,9 +30,6 @@ import tajo.storage.Tuple;
 
 import java.util.List;
 
-/**
- * @author Hyunsik Choi
- */
 public class CaseWhenEval extends EvalNode {
   @Expose private List<WhenEval> whens = Lists.newArrayList();
   @Expose private EvalNode elseResult;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/ConstEval.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/ConstEval.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/ConstEval.java
index 0db76fe..3e61632 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/ConstEval.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/ConstEval.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
@@ -18,9 +16,6 @@
  * limitations under the License.
  */
 
-/**
- * 
- */
 package tajo.engine.eval;
 
 import com.google.common.base.Objects;
@@ -30,10 +25,6 @@ import tajo.catalog.proto.CatalogProtos.DataType;
 import tajo.datum.Datum;
 import tajo.engine.json.GsonCreator;
 
-/**
- * @author Hyunsik Choi
- *
- */
 public class ConstEval extends EvalNode implements Comparable<ConstEval>, Cloneable {
 	@Expose Datum datum = null;
 	

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/EvalContext.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/EvalContext.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/EvalContext.java
index 76f242d..541e854 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/EvalContext.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/EvalContext.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
@@ -20,8 +18,5 @@
 
 package tajo.engine.eval;
 
-/**
- * @author Hyunsik Choi
- */
 public interface EvalContext {
 }

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/EvalNode.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/EvalNode.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/EvalNode.java
index 6a6f06b..8c31add 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/EvalNode.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/EvalNode.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
@@ -28,11 +26,6 @@ import tajo.datum.Datum;
 import tajo.engine.json.GsonCreator;
 import tajo.storage.Tuple;
 
-/**
- * 
- * @author Hyunsik Choi
- *
- */
 public abstract class EvalNode implements Cloneable {
 	@Expose
 	protected Type type;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/EvalNodeVisitor.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/EvalNodeVisitor.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/EvalNodeVisitor.java
index 9abbc05..e6f36a6 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/EvalNodeVisitor.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/EvalNodeVisitor.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
@@ -20,9 +18,6 @@
 
 package tajo.engine.eval;
 
-/**
- * @author Hyunsik Choi
- */
 public interface EvalNodeVisitor {
   public void visit(EvalNode node);
 }

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/EvalTreeFactory.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/EvalTreeFactory.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/EvalTreeFactory.java
index e21fa35..9face87 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/EvalTreeFactory.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/EvalTreeFactory.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
@@ -18,17 +16,10 @@
  * limitations under the License.
  */
 
-/**
- * 
- */
 package tajo.engine.eval;
 
 import tajo.datum.Datum;
 
-/**
- * @author Hyunsik Choi
- *
- */
 public class EvalTreeFactory {
 	public static ConstEval newConst(Datum datum) {
 		return new ConstEval(datum);

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/EvalTreeUtil.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/EvalTreeUtil.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/EvalTreeUtil.java
index 7ba0dac..e8afb65 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/EvalTreeUtil.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/EvalTreeUtil.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
@@ -33,9 +31,6 @@ import tajo.exception.InternalException;
 
 import java.util.*;
 
-/**
- * @author Hyunsik Choi
- */
 public class EvalTreeUtil {
   public static void changeColumnRef(EvalNode node, Column oldName, 
       Column newName) {

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/FieldEval.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/FieldEval.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/FieldEval.java
index 05a92dc..e258b93 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/FieldEval.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/FieldEval.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
@@ -30,9 +28,6 @@ import tajo.engine.json.GsonCreator;
 import tajo.engine.utils.SchemaUtil;
 import tajo.storage.Tuple;
 
-/**
- * @author Hyunsik Choi 
- */
 public class FieldEval extends EvalNode implements Cloneable {
 	@Expose private Column column;
 	@Expose	private int fieldId = -1;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/FuncCallEval.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/FuncCallEval.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/FuncCallEval.java
index 4932d76..2dce9e6 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/FuncCallEval.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/FuncCallEval.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
@@ -32,9 +30,6 @@ import tajo.storage.Tuple;
 import tajo.storage.VTuple;
 import tajo.util.TUtil;
 
-/**
- * @author Hyunsik Choi
- */
 public class FuncCallEval extends FuncEval {
 	@Expose protected GeneralFunction instance;
   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/eval/FuncEval.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/FuncEval.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/FuncEval.java
index 7ca4b29..da7df36 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/FuncEval.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/FuncEval.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
@@ -18,9 +16,6 @@
  * limitations under the License.
  */
 
-/**
- * 
- */
 package tajo.engine.eval;
 
 import com.google.common.base.Objects;
@@ -34,9 +29,6 @@ import tajo.engine.json.GsonCreator;
 import tajo.storage.Tuple;
 import tajo.util.TUtil;
 
-/**
- * @author Hyunsik Choi
- */
 public abstract class FuncEval extends EvalNode implements Cloneable {
 	@Expose protected FunctionDesc funcDesc;
 	@Expose protected EvalNode [] argEvals;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/InvalidCastException.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/InvalidCastException.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/InvalidCastException.java
index ba91db0..1ad444e 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/InvalidCastException.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/InvalidCastException.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
@@ -23,10 +21,6 @@
  */
 package tajo.engine.eval;
 
-/**
- * @author Hyunsik Choi
- *
- */
 public class InvalidCastException extends RuntimeException {
 	private static final long serialVersionUID = -5090530469575858320L;
 

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/InvalidEvalException.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/InvalidEvalException.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/InvalidEvalException.java
index 904131f..5ff28cc 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/InvalidEvalException.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/InvalidEvalException.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
@@ -23,10 +21,6 @@
  */
 package tajo.engine.eval;
 
-/**
- * @author Hyunsik Choi
- *
- */
 public class InvalidEvalException extends RuntimeException {
 	private static final long serialVersionUID = -2897003028483298256L;
 

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/IsNullEval.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/IsNullEval.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/IsNullEval.java
index 765a49a..a236426 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/IsNullEval.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/IsNullEval.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
@@ -30,9 +28,6 @@ import tajo.datum.DatumFactory;
 import tajo.engine.utils.SchemaUtil;
 import tajo.storage.Tuple;
 
-/**
- * @author Hyunsik Choi
- */
 public class IsNullEval extends BinaryEval {
   private final static ConstEval NULL_EVAL = new ConstEval(DatumFactory.createNullDatum());
   private static final CatalogProtos.DataType[] RES_TYPE = SchemaUtil.newNoNameSchema(CatalogProtos.DataType.BOOLEAN);

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/LikeEval.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/LikeEval.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/LikeEval.java
index 0f57349..a963335 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/LikeEval.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/LikeEval.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
@@ -18,9 +16,6 @@
  * limitations under the License.
  */
 
-/**
- * 
- */
 package tajo.engine.eval;
 
 import com.google.gson.annotations.Expose;
@@ -36,9 +31,6 @@ import tajo.storage.Tuple;
 
 import java.util.regex.Pattern;
 
-/**
- * @author Hyunsik Choi
- */
 public class LikeEval extends BinaryEval {
   @Expose private boolean not;
   @Expose private Column column;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/NotEval.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/NotEval.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/NotEval.java
index 8d3fd0a..aaa1fee 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/NotEval.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/NotEval.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
@@ -18,9 +16,6 @@
  * limitations under the License.
  */
 
-/**
- * 
- */
 package tajo.engine.eval;
 
 import com.google.common.base.Preconditions;
@@ -32,9 +27,6 @@ import tajo.datum.DatumFactory;
 import tajo.engine.utils.SchemaUtil;
 import tajo.storage.Tuple;
 
-/**
- * @author Hyunsik Choi
- */
 public class NotEval extends EvalNode implements Cloneable {
   @Expose private EvalNode subExpr;
   private static final DataType [] RES_TYPE = SchemaUtil

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/PartialBinaryExpr.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/PartialBinaryExpr.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/PartialBinaryExpr.java
index 6acea93..7e92274 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/PartialBinaryExpr.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/eval/PartialBinaryExpr.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
@@ -18,9 +16,6 @@
  * limitations under the License.
  */
 
-/**
- * 
- */
 package tajo.engine.eval;
 
 import tajo.catalog.Schema;
@@ -28,9 +23,6 @@ import tajo.catalog.proto.CatalogProtos.DataType;
 import tajo.datum.Datum;
 import tajo.storage.Tuple;
 
-/**
- * @author Hyunsik Choi
- */
 public class PartialBinaryExpr extends EvalNode {
   
   public PartialBinaryExpr(Type type) {

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/exception/EmptyClusterException.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/exception/EmptyClusterException.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/exception/EmptyClusterException.java
index 2af7f02..b6e44ff 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/exception/EmptyClusterException.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/exception/EmptyClusterException.java
@@ -1,8 +1,23 @@
-package tajo.engine.exception;
-
 /**
- * @author jihoon
+ * 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.exception;
+
 public class EmptyClusterException extends Exception {
 
   public EmptyClusterException() {

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/exception/IllegalQueryStatusException.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/exception/IllegalQueryStatusException.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/exception/IllegalQueryStatusException.java
index 52c3d2d..e462ae0 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/exception/IllegalQueryStatusException.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/exception/IllegalQueryStatusException.java
@@ -1,8 +1,23 @@
-package tajo.engine.exception;
-
 /**
- * @author jihoon
+ * 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.exception;
+
 public class IllegalQueryStatusException extends Exception {
 
   public IllegalQueryStatusException() {

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/exception/NTAQueryException.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/exception/NTAQueryException.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/exception/NTAQueryException.java
index 22191c4..bad2c57 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/exception/NTAQueryException.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/exception/NTAQueryException.java
@@ -1,14 +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.exception;
 
 import java.io.IOException;
 
-/**
- * @author Hyunsik Choi
- *
- */
 public class NTAQueryException extends IOException {
 	private static final long serialVersionUID = -5012296598261064705L;
 

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/exception/NoSuchQueryIdException.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/exception/NoSuchQueryIdException.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/exception/NoSuchQueryIdException.java
index 6d6cfba..d29992a 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/exception/NoSuchQueryIdException.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/exception/NoSuchQueryIdException.java
@@ -1,17 +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.exception;
 
 /**
- * @author jihoon
- *
+ * 
  */
+package tajo.engine.exception;
+
 public class NoSuchQueryIdException extends Exception {
 
-  /**
-   * 
-   */
   private static final long serialVersionUID = -4425982532461186746L;
 
   public NoSuchQueryIdException() {

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/exception/UnfinishedTaskException.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/exception/UnfinishedTaskException.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/exception/UnfinishedTaskException.java
index a2b3458..f50b434 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/exception/UnfinishedTaskException.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/exception/UnfinishedTaskException.java
@@ -1,17 +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.exception;
 
 /**
- * @author jihoon
- *
+ * 
  */
+package tajo.engine.exception;
+
 public class UnfinishedTaskException extends Exception {
 
-  /**
-   * 
-   */
   private static final long serialVersionUID = -3229141373378209229L;
   
   public UnfinishedTaskException() {

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-core/tajo-core-backend/src/main/java/tajo/engine/exception/UnknownWorkerException.java
----------------------------------------------------------------------
diff --git a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/exception/UnknownWorkerException.java b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/exception/UnknownWorkerException.java
index eaa21e4..becb589 100644
--- a/tajo-core/tajo-core-backend/src/main/java/tajo/engine/exception/UnknownWorkerException.java
+++ b/tajo-core/tajo-core-backend/src/main/java/tajo/engine/exception/UnknownWorkerException.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.exception;
 
 /**
- * @author jihoon
- *
+ * 
  */
+package tajo.engine.exception;
+
 public class UnknownWorkerException extends Exception {
 
   /**


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

Posted by hy...@apache.org.
TAJO-2: remove all @author tags and update license header (hyunsik)


Project: http://git-wip-us.apache.org/repos/asf/incubator-tajo/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-tajo/commit/457fea18
Tree: http://git-wip-us.apache.org/repos/asf/incubator-tajo/tree/457fea18
Diff: http://git-wip-us.apache.org/repos/asf/incubator-tajo/diff/457fea18

Branch: refs/heads/master
Commit: 457fea185f881cf3ee69b81159d01e372815edff
Parents: ab60e74
Author: Hyunsik Choi <hy...@apache.org>
Authored: Mon Mar 25 18:19:41 2013 +0900
Committer: hyunsik <hy...@gmail.com>
Committed: Mon Mar 25 18:21:48 2013 +0900

----------------------------------------------------------------------
 CHANGES.txt                                        |    1 +
 LICENSE.txt                                        |  244 ++++++++++++++-
 NOTICE.txt                                         |    7 +-
 pom.xml                                            |   51 +++-
 .../src/main/java/tajo/algebra/Aggregation.java    |   12 +-
 .../src/main/java/tajo/algebra/BinaryOperator.java |   12 +-
 .../src/main/java/tajo/algebra/CaseWhenExpr.java   |   12 +-
 .../java/tajo/algebra/ColumnReferenceExpr.java     |   12 +-
 .../src/main/java/tajo/algebra/CreateTable.java    |   12 +-
 tajo-algebra/src/main/java/tajo/algebra/Expr.java  |   18 +
 .../src/main/java/tajo/algebra/ExprType.java       |   12 +-
 .../src/main/java/tajo/algebra/FunctionExpr.java   |   12 +-
 tajo-algebra/src/main/java/tajo/algebra/Join.java  |   12 +-
 .../src/main/java/tajo/algebra/JoinType.java       |   12 +-
 .../src/main/java/tajo/algebra/JsonHelper.java     |   12 +-
 .../main/java/tajo/algebra/JsonSerializable.java   |   12 +-
 .../src/main/java/tajo/algebra/LikeExpr.java       |   12 +-
 tajo-algebra/src/main/java/tajo/algebra/Limit.java |   12 +-
 .../src/main/java/tajo/algebra/LiteralExpr.java    |   12 +-
 .../src/main/java/tajo/algebra/Projection.java     |   12 +-
 .../src/main/java/tajo/algebra/Relation.java       |   18 +
 .../src/main/java/tajo/algebra/ScalarSubQuery.java |   12 +-
 .../src/main/java/tajo/algebra/Selection.java      |    4 +-
 .../src/main/java/tajo/algebra/SetOperation.java   |   12 +-
 tajo-algebra/src/main/java/tajo/algebra/Sort.java  |   12 +-
 .../src/main/java/tajo/algebra/TableSubQuery.java  |   12 +-
 .../src/main/java/tajo/algebra/Target.java         |   12 +-
 .../src/main/java/tajo/algebra/UnaryOperator.java  |   12 +-
 .../test/java/tajo/algebra/AlgebraTestingUtil.java |   12 +-
 .../src/test/java/tajo/algebra/TestExpr.java       |   12 +-
 tajo-catalog/pom.xml                               |   12 +-
 tajo-catalog/tajo-catalog-client/pom.xml           |   12 +-
 .../java/tajo/catalog/AbstractCatalogClient.java   |   18 +-
 .../catalog/AlreadyRegisteredURIException.java     |   21 +-
 .../src/main/java/tajo/catalog/AttributeType.java  |   21 +-
 .../src/main/java/tajo/catalog/CatalogClient.java  |   20 +-
 .../src/main/java/tajo/catalog/CatalogReader.java  |   18 +
 .../src/main/java/tajo/catalog/CatalogService.java |   23 +-
 .../java/tajo/catalog/CatalogServiceProtocol.java  |   23 +-
 .../src/main/proto/CatalogProtocol.proto           |   14 +-
 .../src/main/proto/CatalogProtos.proto             |   18 +
 .../src/main/proto/PrimitiveProtos.proto           |   14 +-
 .../src/main/resources/catalog-default.xml         |   12 +-
 tajo-catalog/tajo-catalog-common/pom.xml           |   12 +-
 .../catalog/AlreadyRegisteredURIException.java     |   21 +-
 .../src/main/java/tajo/catalog/AttributeType.java  |   21 +-
 .../main/java/tajo/catalog/CatalogConstants.java   |   17 +-
 .../src/main/java/tajo/catalog/CatalogUtil.java    |   14 +-
 .../src/main/java/tajo/catalog/Column.java         |   17 +-
 .../src/main/java/tajo/catalog/FunctionDesc.java   |   17 +-
 .../src/main/java/tajo/catalog/IndexDesc.java      |   20 +-
 .../src/main/java/tajo/catalog/Options.java        |   21 +-
 .../src/main/java/tajo/catalog/Schema.java         |   12 +-
 .../src/main/java/tajo/catalog/SchemaObject.java   |   21 +-
 .../src/main/java/tajo/catalog/SortSpec.java       |   18 +
 .../src/main/java/tajo/catalog/TCatUtil.java       |   14 +-
 .../src/main/java/tajo/catalog/TableDesc.java      |   19 +-
 .../src/main/java/tajo/catalog/TableDescImpl.java  |   18 +-
 .../src/main/java/tajo/catalog/TableMeta.java      |   23 +-
 .../src/main/java/tajo/catalog/TableMetaImpl.java  |   20 +-
 .../src/main/java/tajo/catalog/TableUtil.java      |   23 +-
 .../exception/AlreadyExistsFieldException.java     |   21 +-
 .../exception/AlreadyExistsFunctionException.java  |   21 +-
 .../exception/AlreadyExistsIndexException.java     |   20 +-
 .../exception/AlreadyExistsTableException.java     |   23 +-
 .../tajo/catalog/exception/CatalogException.java   |   22 +-
 .../catalog/exception/InvalidTableException.java   |   21 +-
 .../catalog/exception/NoSuchFunctionException.java |   21 +-
 .../catalog/exception/NoSuchIndexException.java    |   20 +-
 .../catalog/exception/NoSuchTableException.java    |   21 +-
 .../java/tajo/catalog/function/AggFunction.java    |   14 +-
 .../main/java/tajo/catalog/function/Function.java  |   14 +-
 .../tajo/catalog/function/FunctionContext.java     |    4 +-
 .../tajo/catalog/function/GeneralFunction.java     |   14 +-
 .../java/tajo/catalog/json/FunctionAdapter.java    |   21 +-
 .../main/java/tajo/catalog/json/GsonCreator.java   |   21 +-
 .../java/tajo/catalog/json/PathDeserializer.java   |   21 +-
 .../java/tajo/catalog/json/PathSerializer.java     |   21 +-
 .../java/tajo/catalog/json/TableDescAdapter.java   |   21 +-
 .../java/tajo/catalog/json/TableMetaAdapter.java   |   21 +-
 .../java/tajo/catalog/statistics/ColumnStat.java   |   17 +-
 .../main/java/tajo/catalog/statistics/Stat.java    |   14 +-
 .../main/java/tajo/catalog/statistics/StatSet.java |   17 +-
 .../tajo/catalog/statistics/StatisticsUtil.java    |   17 +-
 .../java/tajo/catalog/statistics/TableStat.java    |   17 +-
 .../java/tajo/catalog/statistics/TupleUtil.java    |   14 +-
 .../src/main/proto/CatalogProtos.proto             |   18 +
 .../test/java/tajo/catalog/TestCatalogUtil.java    |   14 +-
 .../src/test/java/tajo/catalog/TestColumn.java     |   21 +-
 .../test/java/tajo/catalog/TestFunctionDesc.java   |   14 +-
 .../src/test/java/tajo/catalog/TestIndexDesc.java  |   18 +
 .../src/test/java/tajo/catalog/TestOptions.java    |   18 +
 .../src/test/java/tajo/catalog/TestSchema.java     |   14 +-
 .../src/test/java/tajo/catalog/TestTableDesc.java  |   14 +-
 .../src/test/java/tajo/catalog/TestTableInfo.java  |   18 +
 .../src/test/java/tajo/catalog/TestTableMeta.java  |   18 +
 .../tajo/catalog/statistics/TestColumnStat.java    |   21 +-
 .../java/tajo/catalog/statistics/TestStatSet.java  |   14 +-
 .../catalog/statistics/TestStatisticsUtil.java     |   14 +-
 .../tajo/catalog/statistics/TestTableStat.java     |   17 +-
 tajo-catalog/tajo-catalog-server/pom.xml           |   12 +-
 .../catalog/AlreadyRegisteredURIException.java     |   22 +-
 .../src/main/java/tajo/catalog/CatalogServer.java  |   16 +-
 .../src/main/java/tajo/catalog/LocalCatalog.java   |   17 +-
 .../main/java/tajo/catalog/MiniCatalogServer.java  |   21 +-
 .../main/java/tajo/catalog/store/CatalogStore.java |   23 ++-
 .../src/main/java/tajo/catalog/store/DBStore.java  |   17 +-
 .../src/main/java/tajo/catalog/store/MemStore.java |   21 +-
 .../src/main/resources/catalog-default.xml         |   12 +-
 .../src/test/java/tajo/catalog/TestCatalog.java    |   21 +-
 .../src/test/java/tajo/catalog/TestDBStore.java    |   17 +-
 .../tajo/catalog/statistics/TestColumnStat.java    |   21 +-
 .../java/tajo/catalog/statistics/TestStatSet.java  |   14 +-
 .../catalog/statistics/TestStatisticsUtil.java     |   14 +-
 .../tajo/catalog/statistics/TestTableStat.java     |   17 +-
 .../src/test/resources/catalog-default.xml         |   12 +-
 .../src/test/resources/log4j.properties            |   24 +-
 tajo-common/src/main/java/log4j.properties         |   22 +--
 tajo-common/src/main/java/tajo/QueryId.java        |   14 +-
 tajo-common/src/main/java/tajo/QueryIdFactory.java |   15 +-
 .../src/main/java/tajo/QueryUnitAttemptId.java     |   14 +-
 tajo-common/src/main/java/tajo/QueryUnitId.java    |   19 +-
 tajo-common/src/main/java/tajo/SubQueryId.java     |   14 +-
 tajo-common/src/main/java/tajo/TajoConstants.java  |   18 +
 .../src/main/java/tajo/common/ProtoObject.java     |    4 +-
 tajo-common/src/main/java/tajo/common/Sleeper.java |    4 +-
 .../common/exception/InvalidAddressException.java  |    4 +-
 .../common/exception/NotImplementedException.java  |   10 +-
 .../src/main/java/tajo/common/type/IPv4.java       |    4 +-
 .../src/main/java/tajo/common/type/TimeRange.java  |    4 +-
 tajo-common/src/main/java/tajo/conf/TajoConf.java  |   14 +-
 .../src/main/java/tajo/datum/ArrayDatum.java       |    4 +-
 .../src/main/java/tajo/datum/BoolDatum.java        |    4 +-
 .../src/main/java/tajo/datum/ByteDatum.java        |    4 +-
 .../src/main/java/tajo/datum/BytesDatum.java       |    8 +-
 .../src/main/java/tajo/datum/CharDatum.java        |    4 +-
 tajo-common/src/main/java/tajo/datum/Datum.java    |    4 +-
 .../src/main/java/tajo/datum/DatumFactory.java     |    4 +-
 .../src/main/java/tajo/datum/DatumType.java        |    4 +-
 .../src/main/java/tajo/datum/DoubleDatum.java      |    4 +-
 .../src/main/java/tajo/datum/FloatDatum.java       |    4 +-
 .../src/main/java/tajo/datum/IPv4Datum.java        |    4 +-
 tajo-common/src/main/java/tajo/datum/IntDatum.java |    4 +-
 .../src/main/java/tajo/datum/LongDatum.java        |    4 +-
 .../src/main/java/tajo/datum/NullDatum.java        |    4 +-
 .../src/main/java/tajo/datum/NumericDatum.java     |    4 +-
 .../src/main/java/tajo/datum/ShortDatum.java       |    4 +-
 .../src/main/java/tajo/datum/StringDatum.java      |    4 +-
 .../src/main/java/tajo/datum/StringDatum2.java     |    4 +-
 .../tajo/datum/exception/InvalidCastException.java |    7 +-
 .../datum/exception/InvalidOperationException.java |    4 +-
 .../main/java/tajo/datum/json/DatumAdapter.java    |    4 +-
 .../src/main/java/tajo/datum/json/GsonCreator.java |    4 +-
 .../java/tajo/exception/InternalException.java     |   22 +-
 .../tajo/exception/UnimplementedException.java     |   21 +-
 .../java/tajo/exception/UnsupportedException.java  |   21 +-
 .../main/java/tajo/gson/ClassNameDeserializer.java |   22 +-
 .../main/java/tajo/gson/ClassNameSerializer.java   |   22 +-
 .../src/main/java/tajo/gson/DatumTypeAdapter.java  |   18 +
 .../src/main/java/tajo/gson/PathDeserializer.java  |   22 +-
 .../src/main/java/tajo/gson/PathSerializer.java    |   22 +-
 tajo-common/src/main/java/tajo/storage/Tuple.java  |   14 +-
 .../src/main/java/tajo/unit/StorageUnit.java       |    4 +-
 tajo-common/src/main/java/tajo/unit/TimeUnit.java  |    4 +-
 tajo-common/src/main/java/tajo/util/BitArray.java  |   12 +-
 tajo-common/src/main/java/tajo/util/Bytes.java     |    4 +-
 .../src/main/java/tajo/util/CommonTestingUtil.java |   12 +-
 tajo-common/src/main/java/tajo/util/FileUtil.java  |    4 +-
 tajo-common/src/main/java/tajo/util/JarUtil.java   |   18 +
 .../src/main/java/tajo/util/NumberUtil.java        |    4 +-
 .../src/main/java/tajo/util/ReflectionUtil.java    |    4 +-
 tajo-common/src/main/java/tajo/util/TUtil.java     |   16 +-
 .../src/main/java/tajo/util/TajoIdUtils.java       |   17 +-
 tajo-common/src/main/proto/TajoIdProtos.proto      |   18 +
 tajo-common/src/main/proto/TestProtos.proto        |    2 +-
 tajo-common/src/test/java/log4j.properties         |   16 +-
 .../src/test/java/tajo/common/type/TestIPv4.java   |    4 +-
 .../test/java/tajo/common/type/TestTimeRange.java  |    4 +-
 .../src/test/java/tajo/datum/TestBoolDatum.java    |    4 +-
 .../src/test/java/tajo/datum/TestByteDatum.java    |    4 +-
 .../src/test/java/tajo/datum/TestBytesDatum.java   |    4 +-
 .../src/test/java/tajo/datum/TestCharDatum.java    |    4 +-
 .../src/test/java/tajo/datum/TestDatum.java        |    4 +-
 .../src/test/java/tajo/datum/TestDatumFactory.java |    4 +-
 .../src/test/java/tajo/datum/TestDoubleDatum.java  |    4 +-
 .../src/test/java/tajo/datum/TestFloatDatum.java   |    4 +-
 .../src/test/java/tajo/datum/TestIPv4Datum.java    |    4 +-
 .../src/test/java/tajo/datum/TestIntDatum.java     |    4 +-
 .../src/test/java/tajo/datum/TestLongDatum.java    |    4 +-
 .../src/test/java/tajo/datum/TestShortDatum.java   |    4 +-
 .../src/test/java/tajo/datum/TestStringDatum.java  |    4 +-
 .../src/test/java/tajo/util/TestBitArrayTest.java  |   18 +
 .../src/test/java/tajo/util/TestFileUtils.java     |    4 +-
 tajo-core/tajo-core-backend/pom.xml                |   12 +-
 .../src/main/antlr3/tajo/engine/parser/NQL.g       |    4 +-
 .../src/main/findbugs/findbugs-exclude.xml         |   18 +
 .../src/main/java/log4j.properties                 |   24 +-
 .../src/main/java/tajo/QueryConf.java              |   14 +-
 .../src/main/java/tajo/TaskAttemptContext.java     |   14 +-
 .../src/main/java/tajo/benchmark/BenchmarkSet.java |   18 +
 .../src/main/java/tajo/benchmark/Driver.java       |   18 +
 .../src/main/java/tajo/benchmark/SimpleQuery.java  |   18 +
 .../src/main/java/tajo/benchmark/TPCH.java         |   18 +
 .../src/main/java/tajo/cli/TajoCli.java            |   15 +-
 .../src/main/java/tajo/client/QueryStatus.java     |   14 +-
 .../src/main/java/tajo/client/ResultSetUtil.java   |   21 +-
 .../src/main/java/tajo/client/TajoClient.java      |   17 +-
 .../java/tajo/engine/eval/AggFuncCallEval.java     |    4 +-
 .../java/tajo/engine/eval/AlgebraicException.java  |    4 +-
 .../main/java/tajo/engine/eval/AlgebraicUtil.java  |    7 +-
 .../src/main/java/tajo/engine/eval/BinaryEval.java |   11 +-
 .../main/java/tajo/engine/eval/CaseWhenEval.java   |    7 +-
 .../src/main/java/tajo/engine/eval/ConstEval.java  |   11 +-
 .../main/java/tajo/engine/eval/EvalContext.java    |    7 +-
 .../src/main/java/tajo/engine/eval/EvalNode.java   |    9 +-
 .../java/tajo/engine/eval/EvalNodeVisitor.java     |    7 +-
 .../java/tajo/engine/eval/EvalTreeFactory.java     |   11 +-
 .../main/java/tajo/engine/eval/EvalTreeUtil.java   |    7 +-
 .../src/main/java/tajo/engine/eval/FieldEval.java  |    7 +-
 .../main/java/tajo/engine/eval/FuncCallEval.java   |    7 +-
 .../src/main/java/tajo/engine/eval/FuncEval.java   |   10 +-
 .../tajo/engine/eval/InvalidCastException.java     |    8 +-
 .../tajo/engine/eval/InvalidEvalException.java     |    8 +-
 .../src/main/java/tajo/engine/eval/IsNullEval.java |    7 +-
 .../src/main/java/tajo/engine/eval/LikeEval.java   |   10 +-
 .../src/main/java/tajo/engine/eval/NotEval.java    |   10 +-
 .../java/tajo/engine/eval/PartialBinaryExpr.java   |   10 +-
 .../engine/exception/EmptyClusterException.java    |   21 +-
 .../exception/IllegalQueryStatusException.java     |   21 +-
 .../tajo/engine/exception/NTAQueryException.java   |   22 +-
 .../engine/exception/NoSuchQueryIdException.java   |   25 +-
 .../engine/exception/UnfinishedTaskException.java  |   25 +-
 .../engine/exception/UnknownWorkerException.java   |   22 +-
 .../main/java/tajo/engine/function/Country.java    |   18 +
 .../main/java/tajo/engine/function/InCountry.java  |   18 +
 .../tajo/engine/function/builtin/AvgDouble.java    |   17 +-
 .../tajo/engine/function/builtin/AvgFloat.java     |   21 +-
 .../java/tajo/engine/function/builtin/AvgInt.java  |   17 +-
 .../java/tajo/engine/function/builtin/AvgLong.java |   17 +-
 .../tajo/engine/function/builtin/CountRows.java    |   21 +-
 .../tajo/engine/function/builtin/CountValue.java   |   21 +-
 .../java/tajo/engine/function/builtin/Date.java    |   21 +-
 .../tajo/engine/function/builtin/MaxDouble.java    |   21 +-
 .../tajo/engine/function/builtin/MaxFloat.java     |   21 +-
 .../java/tajo/engine/function/builtin/MaxInt.java  |   21 +-
 .../java/tajo/engine/function/builtin/MaxLong.java |   21 +-
 .../tajo/engine/function/builtin/MinDouble.java    |   21 +-
 .../tajo/engine/function/builtin/MinFloat.java     |   21 +-
 .../java/tajo/engine/function/builtin/MinInt.java  |   21 +-
 .../java/tajo/engine/function/builtin/MinLong.java |   21 +-
 .../tajo/engine/function/builtin/MinString.java    |   21 +-
 .../tajo/engine/function/builtin/RandomInt.java    |   21 +-
 .../tajo/engine/function/builtin/SumDouble.java    |   21 +-
 .../tajo/engine/function/builtin/SumFloat.java     |   21 +-
 .../java/tajo/engine/function/builtin/SumInt.java  |   21 +-
 .../java/tajo/engine/function/builtin/SumLong.java |   21 +-
 .../java/tajo/engine/function/builtin/Today.java   |   21 +-
 .../java/tajo/engine/json/EvalNodeAdapter.java     |    8 +-
 .../tajo/engine/json/FragmentDeserializer.java     |   22 +-
 .../tajo/engine/json/FromTableDeserializer.java    |   18 +
 .../main/java/tajo/engine/json/GsonCreator.java    |    4 +-
 .../java/tajo/engine/json/LogicalNodeAdapter.java  |   18 +
 .../main/java/tajo/engine/parser/CommandType.java  |   22 +-
 .../src/main/java/tajo/engine/parser/CopyStmt.java |   12 +-
 .../java/tajo/engine/parser/CreateIndexStmt.java   |   21 +-
 .../java/tajo/engine/parser/CreateTableStmt.java   |   21 +-
 .../main/java/tajo/engine/parser/EvalTreeBin.java  |   23 +-
 .../main/java/tajo/engine/parser/ParseTree.java    |   30 +-
 .../main/java/tajo/engine/parser/ParseUtil.java    |    7 +-
 .../java/tajo/engine/parser/ParserException.java   |   21 +-
 .../java/tajo/engine/parser/QueryAnalyzer.java     |    8 +-
 .../main/java/tajo/engine/parser/QueryBlock.java   |    9 +-
 .../src/main/java/tajo/engine/parser/SetStmt.java  |   12 +-
 .../java/tajo/engine/parser/StatementType.java     |   22 +-
 .../src/main/java/tajo/engine/parser/TableMap.java |    2 +-
 .../java/tajo/engine/plan/global/Annotation.java   |   21 +-
 .../java/tajo/engine/plan/global/GenericTask.java  |   18 +
 .../tajo/engine/plan/global/GenericTaskGraph.java  |   18 +
 .../main/java/tajo/engine/planner/JoinType.java    |   21 +-
 .../java/tajo/engine/planner/LogicalOptimizer.java |    7 +-
 .../java/tajo/engine/planner/LogicalPlanner.java   |    4 +-
 .../java/tajo/engine/planner/PhysicalPlanner.java  |   15 +-
 .../tajo/engine/planner/PhysicalPlannerImpl.java   |   12 +-
 .../main/java/tajo/engine/planner/PlannerUtil.java |    4 +-
 .../java/tajo/engine/planner/PlanningContext.java  |    5 +-
 .../tajo/engine/planner/PlanningContextImpl.java   |    5 +-
 .../main/java/tajo/engine/planner/Projector.java   |    7 +-
 .../engine/planner/RangeOverflowException.java     |   21 +-
 .../engine/planner/RangePartitionAlgorithm.java    |   21 +-
 .../tajo/engine/planner/UniformRangePartition.java |   14 +-
 .../engine/planner/global/GlobalOptimizer.java     |    2 +-
 .../tajo/engine/planner/global/MasterPlan.java     |   18 +
 .../tajo/engine/planner/logical/BinaryNode.java    |   22 +-
 .../engine/planner/logical/CreateTableNode.java    |   21 +-
 .../tajo/engine/planner/logical/EvalExprNode.java  |   26 ++-
 .../tajo/engine/planner/logical/ExceptNode.java    |   21 +-
 .../java/tajo/engine/planner/logical/ExprType.java |   22 +-
 .../tajo/engine/planner/logical/GroupbyNode.java   |    7 +-
 .../tajo/engine/planner/logical/IndexScanNode.java |   18 +
 .../engine/planner/logical/IndexWriteNode.java     |   21 +-
 .../tajo/engine/planner/logical/IntersectNode.java |   21 +-
 .../java/tajo/engine/planner/logical/JoinNode.java |    8 +-
 .../tajo/engine/planner/logical/LimitNode.java     |   18 +-
 .../tajo/engine/planner/logical/LogicalNode.java   |   22 +-
 .../engine/planner/logical/LogicalNodeVisitor.java |   23 ++-
 .../engine/planner/logical/LogicalRootNode.java    |   21 +-
 .../engine/planner/logical/ProjectionNode.java     |   23 +-
 .../java/tajo/engine/planner/logical/ScanNode.java |    4 +-
 .../tajo/engine/planner/logical/SelectionNode.java |    9 +-
 .../java/tajo/engine/planner/logical/SortNode.java |   18 +-
 .../engine/planner/logical/StoreIndexNode.java     |   18 +
 .../engine/planner/logical/StoreTableNode.java     |   22 +-
 .../tajo/engine/planner/logical/UnaryNode.java     |   22 +-
 .../tajo/engine/planner/logical/UnionNode.java     |   21 +-
 .../engine/planner/logical/extended/PipeType.java  |   18 +
 .../planner/logical/extended/ReceiveNode.java      |   21 +-
 .../planner/logical/extended/RepartitionType.java  |   18 +
 .../engine/planner/logical/extended/SendNode.java  |   20 +-
 .../tajo/engine/planner/logical/join/Edge.java     |    7 +-
 .../tajo/engine/planner/logical/join/JoinTree.java |    7 +-
 .../engine/planner/physical/AggregationExec.java   |   14 +-
 .../tajo/engine/planner/physical/BNLJoinExec.java  |   14 +-
 .../engine/planner/physical/BSTIndexScanExec.java  |   14 +-
 .../planner/physical/BinaryPhysicalExec.java       |   14 +-
 .../tajo/engine/planner/physical/EvalExprExec.java |   25 +-
 .../engine/planner/physical/ExternalSortExec.java  |   14 +-
 .../engine/planner/physical/HashAggregateExec.java |   14 +-
 .../tajo/engine/planner/physical/HashJoinExec.java |   14 +-
 .../engine/planner/physical/HashPartitioner.java   |   17 +-
 .../engine/planner/physical/IndexWriteExec.java    |   17 +-
 .../engine/planner/physical/IndexedStoreExec.java  |   18 +-
 .../planner/physical/JoinTupleComparator.java      |   23 ++-
 .../tajo/engine/planner/physical/LimitExec.java    |   14 +-
 .../tajo/engine/planner/physical/MemSortExec.java  |   14 +-
 .../engine/planner/physical/MergeJoinExec.java     |   14 +-
 .../tajo/engine/planner/physical/NLJoinExec.java   |   14 +-
 .../planner/physical/PartitionedStoreExec.java     |   14 +-
 .../tajo/engine/planner/physical/Partitioner.java  |   21 +-
 .../tajo/engine/planner/physical/PhysicalExec.java |   14 +-
 .../engine/planner/physical/ProjectionExec.java    |   17 +-
 .../engine/planner/physical/SelectionExec.java     |   17 +-
 .../tajo/engine/planner/physical/SeqScanExec.java  |   14 +-
 .../engine/planner/physical/SortAggregateExec.java |   16 +-
 .../tajo/engine/planner/physical/SortExec.java     |   14 +-
 .../engine/planner/physical/StoreTableExec.java    |   17 +-
 .../tajo/engine/planner/physical/TunnelExec.java   |   14 +-
 .../engine/planner/physical/UnaryPhysicalExec.java |   17 +-
 .../tajo/engine/planner/physical/UnionExec.java    |   18 +-
 .../tajo/engine/query/QueryUnitRequestImpl.java    |    4 +-
 .../main/java/tajo/engine/query/ResultSetImpl.java |   18 +
 .../tajo/engine/query/ResultSetMetaDataImpl.java   |   22 +-
 .../query/exception/AmbiguousFieldException.java   |   22 +-
 .../query/exception/InvalidCastException.java      |   22 +-
 .../query/exception/InvalidEvalException.java      |   21 +-
 .../query/exception/InvalidQueryException.java     |   18 +
 .../query/exception/NotSupportQueryException.java  |   22 +-
 .../tajo/engine/query/exception/TQLParseError.java |   14 +-
 .../engine/query/exception/TQLSyntaxError.java     |   14 +-
 .../exception/UndefinedFunctionException.java      |   22 +-
 .../src/main/java/tajo/engine/utils/ProtoUtil.java |   18 +
 .../main/java/tajo/engine/utils/SchemaUtil.java    |   14 +-
 .../main/java/tajo/engine/utils/ThreadUtil.java    |   18 +
 .../src/main/java/tajo/engine/utils/TupleUtil.java |   18 +
 .../tajo/ipc/protocolrecords/QueryUnitRequest.java |    4 +-
 .../src/main/java/tajo/master/ClientService.java   |   12 +-
 .../src/main/java/tajo/master/GlobalEngine.java    |    4 +-
 .../src/main/java/tajo/master/GlobalPlanner.java   |   17 +-
 .../main/java/tajo/master/GlobalPlannerUtils.java  |    7 +-
 .../src/main/java/tajo/master/Priority.java        |   21 +-
 .../src/main/java/tajo/master/Query.java           |    4 +-
 .../src/main/java/tajo/master/QueryMaster.java     |   14 +-
 .../src/main/java/tajo/master/QueryUnit.java       |   14 +-
 .../main/java/tajo/master/QueryUnitAttempt.java    |   12 +-
 .../src/main/java/tajo/master/Repartitioner.java   |   12 +-
 .../src/main/java/tajo/master/SchedulerUtils.java  |   21 +-
 .../src/main/java/tajo/master/SubQuery.java        |    4 +-
 .../src/main/java/tajo/master/SubQueryState.java   |   12 +-
 .../src/main/java/tajo/master/TajoMaster.java      |    4 +-
 .../java/tajo/master/TaskContainerManager.java     |   14 +-
 .../src/main/java/tajo/master/TaskRunnerEvent.java |   14 +-
 .../main/java/tajo/master/TaskRunnerLauncher.java  |   14 +-
 .../java/tajo/master/TaskRunnerLauncherImpl.java   |   14 +-
 .../main/java/tajo/master/TaskRunnerListener.java  |   14 +-
 .../src/main/java/tajo/master/TaskScheduler.java   |   14 +-
 .../main/java/tajo/master/TaskSchedulerImpl.java   |   14 +-
 .../src/main/java/tajo/master/TaskState.java       |   12 +-
 .../main/java/tajo/master/cluster/ServerName.java  |   18 +
 .../java/tajo/master/cluster/WorkerListener.java   |    4 +-
 .../tajo/master/cluster/event/WorkerEvent.java     |   12 +-
 .../tajo/master/cluster/event/WorkerEventType.java |   12 +-
 .../master/event/ContainerAllocationEvent.java     |   14 +-
 .../master/event/ContainerAllocatorEventType.java  |   14 +-
 .../java/tajo/master/event/ContainerEvent.java     |   14 +-
 .../event/GrouppedContainerAllocatorEvent.java     |   14 +-
 .../master/event/QueryDiagnosticsUpdateEvent.java  |   14 +-
 .../main/java/tajo/master/event/QueryEvent.java    |    2 +-
 .../java/tajo/master/event/QueryEventType.java     |    2 +-
 .../java/tajo/master/event/QueryFinishEvent.java   |   14 +-
 .../java/tajo/master/event/QuerySubQueryEvent.java |    2 +-
 .../tajo/master/event/SubQueryCompletedEvent.java  |    2 +-
 .../event/SubQueryContainerAllocationEvent.java    |   14 +-
 .../main/java/tajo/master/event/SubQueryEvent.java |    2 +-
 .../java/tajo/master/event/SubQueryEventType.java  |    2 +-
 .../tajo/master/event/SubQuerySucceeEvent.java     |   14 +-
 .../java/tajo/master/event/SubQueryTaskEvent.java  |    2 +-
 .../master/event/TaskAttemptAssignedEvent.java     |   14 +-
 .../java/tajo/master/event/TaskAttemptEvent.java   |    2 +-
 .../tajo/master/event/TaskAttemptEventType.java    |    2 +-
 .../master/event/TaskAttemptStatusUpdateEvent.java |    2 +-
 .../tajo/master/event/TaskCompletionEvent.java     |   14 +-
 .../src/main/java/tajo/master/event/TaskEvent.java |    2 +-
 .../main/java/tajo/master/event/TaskEventType.java |    2 +-
 .../tajo/master/event/TaskFatalErrorEvent.java     |   14 +-
 .../java/tajo/master/event/TaskRequestEvent.java   |   14 +-
 .../tajo/master/event/TaskRunnerLaunchEvent.java   |   14 +-
 .../tajo/master/event/TaskRunnerStopEvent.java     |   14 +-
 .../java/tajo/master/event/TaskScheduleEvent.java  |   14 +-
 .../java/tajo/master/event/TaskSchedulerEvent.java |   14 +-
 .../java/tajo/master/event/TaskTAttemptEvent.java  |    2 +-
 .../main/java/tajo/master/rm/RMCommunicator.java   |   12 +-
 .../java/tajo/master/rm/RMContainerAllocator.java  |   12 +-
 .../src/main/java/tajo/net/CachedDNSResolver.java  |   14 +-
 .../tajo/scheduler/event/ScheduleTaskEvent.java    |    2 +-
 .../java/tajo/scheduler/event/SchedulerEvent.java  |    2 +-
 .../tajo/scheduler/event/SchedulerEventType.java   |    2 +-
 .../src/main/java/tajo/util/GeoUtil.java           |   18 +
 .../src/main/java/tajo/util/IndexUtil.java         |    4 +-
 .../src/main/java/tajo/webapp/HttpServer.java      |   29 +-
 .../main/java/tajo/webapp/StaticHttpServer.java    |   18 +
 .../src/main/java/tajo/worker/Fetcher.java         |   20 +-
 .../main/java/tajo/worker/InterDataRetriever.java  |   21 +-
 .../tajo/worker/PartitionRetrieverHandler.java     |   21 +-
 .../java/tajo/worker/RangeRetrieverHandler.java    |   19 +-
 .../src/main/java/tajo/worker/TajoQueryEngine.java |   17 +-
 .../src/main/java/tajo/worker/Task.java            |   12 +-
 .../src/main/java/tajo/worker/TaskRunner.java      |   14 +-
 .../dataserver/FileAccessForbiddenException.java   |   21 +-
 .../tajo/worker/dataserver/HttpDataServer.java     |   21 +-
 .../worker/dataserver/HttpDataServerHandler.java   |   21 +-
 .../dataserver/HttpDataServerPipelineFactory.java  |   21 +-
 .../main/java/tajo/worker/dataserver/HttpUtil.java |   21 +-
 .../retriever/AdvancedDataRetriever.java           |   20 +-
 .../worker/dataserver/retriever/DataRetriever.java |   23 ++-
 .../dataserver/retriever/DirectoryRetriever.java   |   20 +-
 .../worker/dataserver/retriever/FileChunk.java     |   21 +-
 .../dataserver/retriever/RetrieverHandler.java     |   21 +-
 .../src/main/proto/CatalogProtocol.proto           |   14 +-
 .../src/main/proto/CatalogProtos.proto             |   18 +
 .../src/main/proto/ClientProtocol.proto            |   14 +-
 .../src/main/proto/MasterWorkerProtocol.proto      |   14 +-
 .../src/main/proto/MasterWorkerProtos.proto        |   18 +
 .../src/main/proto/PrimitiveProtos.proto           |   14 +-
 .../src/main/proto/TajoIdProtos.proto              |   18 +
 .../src/main/proto/tajo_protos.proto               |   18 +
 .../src/main/resources/log4j.properties            |   24 +-
 .../src/main/resources/tajo-default.xml            |   18 +
 .../main/resources/webapps/admin/catalogview.jsp   |   19 +-
 .../src/main/resources/webapps/admin/index.jsp     |   19 +-
 .../main/resources/webapps/admin/nodedetail.jsp    |   19 +-
 .../src/main/resources/webapps/admin/nodeview.jsp  |   19 +-
 .../src/main/resources/webapps/admin/queryview.jsp |   19 +-
 .../src/main/resources/webapps/admin/style.css     |   20 ++-
 .../src/test/java/log4j.properties                 |   24 +-
 .../src/test/java/tajo/BackendTestingUtil.java     |    4 +-
 .../src/test/java/tajo/IntegrationTest.java        |   18 +
 .../test/java/tajo/LocalTajoTestingUtility.java    |   21 +-
 .../src/test/java/tajo/MiniTajoYarnCluster.java    |   14 +-
 .../src/test/java/tajo/TajoTestingCluster.java     |   14 +-
 .../src/test/java/tajo/TestQueryIdFactory.java     |   21 +-
 .../src/test/java/tajo/TestQueryUnitId.java        |    5 +-
 .../src/test/java/tajo/TpchTestBase.java           |   12 +-
 .../src/test/java/tajo/benchmark/TestTPCH.java     |   14 +-
 .../src/test/java/tajo/client/TestTajoClient.java  |   18 +
 .../src/test/java/tajo/cluster/TestServerName.java |   18 +
 .../test/java/tajo/engine/eval/TestEvalTree.java   |    4 +-
 .../java/tajo/engine/eval/TestEvalTreeUtil.java    |    7 +-
 .../java/tajo/engine/function/TestAggFunction.java |   17 +-
 .../tajo/engine/function/TestBuiltinFunctions.java |   21 +-
 .../tajo/engine/function/TestGeneralFunction.java  |   21 +-
 .../java/tajo/engine/parser/TestNQLParser.java     |   25 +-
 .../java/tajo/engine/parser/TestQueryAnalyzer.java |    4 +-
 .../engine/plan/global/TestGlobalQueryPlanner.java |    4 +-
 .../java/tajo/engine/planner/TestLogicalNode.java  |   23 ++-
 .../tajo/engine/planner/TestLogicalOptimizer.java  |   18 +
 .../tajo/engine/planner/TestLogicalPlanner.java    |    7 +-
 .../java/tajo/engine/planner/TestPlannerUtil.java  |   30 +-
 .../engine/planner/TestUniformRangePartition.java  |   12 +-
 .../planner/global/TestGlobalQueryOptimizer.java   |    4 +-
 .../planner/logical/extended/TestReceiveNode.java  |   21 +-
 .../planner/logical/extended/TestSendNode.java     |   21 +-
 .../engine/planner/physical/TestBNLJoinExec.java   |   12 +-
 .../engine/planner/physical/TestBSTIndexExec.java  |   12 +-
 .../planner/physical/TestExternalSortExec.java     |    4 +-
 .../engine/planner/physical/TestHashJoinExec.java  |    4 +-
 .../planner/physical/TestHashPartitioner.java      |   18 +
 .../engine/planner/physical/TestMergeJoinExec.java |    4 +-
 .../engine/planner/physical/TestNLJoinExec.java    |    4 +-
 .../planner/physical/TestPhysicalPlanner.java      |    4 +-
 .../tajo/engine/planner/physical/TestSortExec.java |    4 +-
 .../java/tajo/engine/query/TestGroupByQuery.java   |   30 +-
 .../test/java/tajo/engine/query/TestJoinQuery.java |   21 +-
 .../java/tajo/engine/query/TestNullValues.java     |   14 +-
 .../java/tajo/engine/query/TestResultSetImpl.java  |   14 +-
 .../java/tajo/engine/query/TestSelectQuery.java    |   30 +-
 .../test/java/tajo/engine/query/TestSortQuery.java |   17 +-
 .../test/java/tajo/engine/util/TestTupleUtil.java  |   18 +
 .../test/java/tajo/master/TestRepartitioner.java   |   14 +-
 .../src/test/java/tajo/storage/TestFragment.java   |   24 +-
 .../src/test/java/tajo/storage/TestHCFile.java     |    4 +-
 .../test/java/tajo/storage/TestHColumnReader.java  |    4 +-
 .../src/test/java/tajo/storage/TestRowFile.java    |    4 +-
 .../src/test/java/tajo/webapp/TestHttpServer.java  |   17 +-
 .../src/test/java/tajo/worker/SlowFunc.java        |   21 +-
 .../src/test/java/tajo/worker/TaskRunnerTest.java  |   14 +-
 .../src/test/java/tajo/worker/TestFetcher.java     |   21 +-
 .../tajo/worker/TestRangeRetrieverHandler.java     |   14 +-
 .../tajo/worker/dataserver/TestHttpDataServer.java |   21 +-
 .../java/tajo/worker/dataserver/TestHttpUtil.java  |   21 +-
 .../src/test/resources/catalog-default.xml         |   12 +-
 .../src/test/resources/log4j.properties            |   24 +-
 .../src/test/resources/tajo-default.xml            |   18 +
 .../webapps/TestHttpServer/WEB-INF/web.xml         |   18 +
 .../resources/webapps/TestHttpServer/index.html    |   18 +
 .../src/test/resources/yarn-site.xml               |   10 +-
 tajo-core/tajo-core-pullserver/pom.xml             |   12 +-
 .../java/tajo/pullserver/FadvisedFileRegion.java   |   14 +-
 .../pullserver/FileAccessForbiddenException.java   |   21 +-
 .../tajo/pullserver/HttpDataServerHandler.java     |   15 +-
 .../pullserver/HttpDataServerPipelineFactory.java  |   15 +-
 .../src/main/java/tajo/pullserver/HttpUtil.java    |   21 +-
 .../java/tajo/pullserver/PullServerAuxService.java |   12 +-
 .../retriever/AdvancedDataRetriever.java           |   20 +-
 .../tajo/pullserver/retriever/DataRetriever.java   |   23 ++-
 .../pullserver/retriever/DirectoryRetriever.java   |   20 +-
 .../java/tajo/pullserver/retriever/FileChunk.java  |   21 +-
 .../pullserver/retriever/RetrieverHandler.java     |   21 +-
 .../src/main/resources/tajo-default.xml            |   18 +
 .../src/main/java/tajo/storage/Appender.java       |   18 +
 .../src/main/java/tajo/storage/CSVFile.java        |   26 +-
 .../src/main/java/tajo/storage/FileAppender.java   |    4 +-
 .../src/main/java/tajo/storage/FileScanner.java    |   18 +
 .../src/main/java/tajo/storage/Fragment.java       |    4 +-
 .../src/main/java/tajo/storage/FrameTuple.java     |   21 +-
 .../src/main/java/tajo/storage/MergeScanner.java   |   12 +-
 .../java/tajo/storage/NumericPathComparator.java   |    4 +-
 .../src/main/java/tajo/storage/RawFile.java        |   12 +-
 .../src/main/java/tajo/storage/RowFile.java        |    4 +-
 .../src/main/java/tajo/storage/RowStoreUtil.java   |    2 +-
 .../src/main/java/tajo/storage/Scanner.java        |   18 +
 .../main/java/tajo/storage/SeekableScanner.java    |   21 +-
 .../src/main/java/tajo/storage/Storage.java        |   18 +
 .../src/main/java/tajo/storage/StorageManager.java |   12 +-
 .../src/main/java/tajo/storage/StorageUtil.java    |   18 +
 .../main/java/tajo/storage/TableStatistics.java    |   16 +-
 .../src/main/java/tajo/storage/Tuple.java          |   25 +-
 .../main/java/tajo/storage/TupleComparator.java    |    4 +-
 .../src/main/java/tajo/storage/TupleRange.java     |   21 +-
 .../src/main/java/tajo/storage/VTuple.java         |   18 +-
 .../exception/AlreadyExistsStorageException.java   |   22 +-
 .../storage/exception/UnknownCodecException.java   |    4 +-
 .../exception/UnknownDataTypeException.java        |    4 +-
 .../exception/UnsupportedFileTypeException.java    |   22 +-
 .../main/java/tajo/storage/hcfile/BasicBlock.java  |    4 +-
 .../src/main/java/tajo/storage/hcfile/Block.java   |    4 +-
 .../main/java/tajo/storage/hcfile/BlockMeta.java   |    4 +-
 .../main/java/tajo/storage/hcfile/BlockReader.java |    4 +-
 .../main/java/tajo/storage/hcfile/BlockWriter.java |    4 +-
 .../java/tajo/storage/hcfile/ColumnAppender.java   |    4 +-
 .../tajo/storage/hcfile/ColumnFileAppender.java    |    4 +-
 .../tajo/storage/hcfile/ColumnFileScanner.java     |    4 +-
 .../main/java/tajo/storage/hcfile/ColumnMeta.java  |    4 +-
 .../java/tajo/storage/hcfile/ColumnReader.java     |    4 +-
 .../java/tajo/storage/hcfile/ColumnScanner.java    |    4 +-
 .../java/tajo/storage/hcfile/ColumnStoreUtil.java  |    4 +-
 .../java/tajo/storage/hcfile/CompressedBlock.java  |   18 +
 .../tajo/storage/hcfile/CompressedBlockReader.java |    4 +-
 .../tajo/storage/hcfile/CompressedBlockWriter.java |    4 +-
 .../java/tajo/storage/hcfile/HBlockMetaImpl.java   |    4 +-
 .../src/main/java/tajo/storage/hcfile/HCFile.java  |    4 +-
 .../java/tajo/storage/hcfile/HCFileMetaImpl.java   |    4 +-
 .../java/tajo/storage/hcfile/HCTupleAppender.java  |    4 +-
 .../tajo/storage/hcfile/HColumnMetaWritable.java   |   18 +
 .../java/tajo/storage/hcfile/HColumnReader.java    |    4 +-
 .../src/main/java/tajo/storage/hcfile/Index.java   |    4 +-
 .../main/java/tajo/storage/hcfile/IndexItem.java   |    4 +-
 .../main/java/tajo/storage/hcfile/Seekable.java    |    4 +-
 .../java/tajo/storage/hcfile/TupleAppender.java    |    4 +-
 .../main/java/tajo/storage/hcfile/Updatable.java   |    4 +-
 .../java/tajo/storage/hcfile/UpdatableBlock.java   |    4 +-
 .../storage/hcfile/UpdatableSeekableBlock.java     |    4 +-
 .../tajo/storage/hcfile/compress/BitVector.java    |    4 +-
 .../java/tajo/storage/hcfile/compress/Codec.java   |    4 +-
 .../tajo/storage/hcfile/compress/Dictionary.java   |    4 +-
 .../main/java/tajo/storage/hcfile/compress/LZ.java |    4 +-
 .../tajo/storage/hcfile/compress/NullSuppress.java |    4 +-
 .../tajo/storage/hcfile/compress/RunLength.java    |    4 +-
 .../java/tajo/storage/hcfile/compress/Snappy.java  |    4 +-
 .../tajo/storage/hcfile/reader/ArrayReader.java    |    4 +-
 .../tajo/storage/hcfile/reader/ByteReader.java     |    4 +-
 .../tajo/storage/hcfile/reader/BytesReader.java    |    4 +-
 .../tajo/storage/hcfile/reader/CharReader.java     |    4 +-
 .../tajo/storage/hcfile/reader/DoubleReader.java   |    4 +-
 .../tajo/storage/hcfile/reader/FloatReader.java    |    4 +-
 .../tajo/storage/hcfile/reader/IPv4Reader.java     |    4 +-
 .../java/tajo/storage/hcfile/reader/IntReader.java |    4 +-
 .../tajo/storage/hcfile/reader/LongReader.java     |    4 +-
 .../java/tajo/storage/hcfile/reader/Reader.java    |    4 +-
 .../tajo/storage/hcfile/reader/ShortReader.java    |    4 +-
 .../tajo/storage/hcfile/reader/String2Reader.java  |    4 +-
 .../tajo/storage/hcfile/reader/StringReader.java   |    4 +-
 .../tajo/storage/hcfile/reader/TypeReader.java     |    4 +-
 .../tajo/storage/hcfile/writer/ArrayWriter.java    |    4 +-
 .../tajo/storage/hcfile/writer/ByteWriter.java     |    4 +-
 .../tajo/storage/hcfile/writer/BytesWriter.java    |    4 +-
 .../tajo/storage/hcfile/writer/CharWriter.java     |    4 +-
 .../tajo/storage/hcfile/writer/DoubleWriter.java   |    4 +-
 .../tajo/storage/hcfile/writer/FloatWriter.java    |    4 +-
 .../java/tajo/storage/hcfile/writer/IntWriter.java |    4 +-
 .../tajo/storage/hcfile/writer/LongWriter.java     |    4 +-
 .../tajo/storage/hcfile/writer/ShortWriter.java    |    4 +-
 .../tajo/storage/hcfile/writer/TypeWriter.java     |    4 +-
 .../java/tajo/storage/hcfile/writer/Writer.java    |    4 +-
 .../main/java/tajo/storage/index/IndexMethod.java  |   21 +-
 .../main/java/tajo/storage/index/IndexProtos.java  |   18 +
 .../main/java/tajo/storage/index/IndexReader.java  |   21 +-
 .../main/java/tajo/storage/index/IndexWriter.java  |   21 +-
 .../java/tajo/storage/index/OrderIndexReader.java  |   21 +-
 .../main/java/tajo/storage/index/bst/BSTIndex.java |   18 +-
 .../tajo/storage/json/FragmentDeserializer.java    |   22 +-
 .../main/java/tajo/storage/json/GsonCreator.java   |    4 +-
 .../main/java/tajo/storage/rcfile/CodecPool.java   |    1 +
 .../rcfile/NonSyncByteArrayInputStream.java        |    1 +
 .../rcfile/NonSyncByteArrayOutputStream.java       |    1 +
 .../storage/rcfile/NonSyncDataOutputBuffer.java    |    1 +
 .../java/tajo/storage/rcfile/RCFileWrapper.java    |    2 +-
 .../java/tajo/storage/trevni/TrevniAppender.java   |   12 +-
 .../java/tajo/storage/trevni/TrevniScanner.java    |   12 +-
 .../src/main/proto/CatalogProtos.proto             |   18 +
 .../src/main/proto/IndexProtos.proto               |   14 +-
 .../src/main/proto/PrimitiveProtos.proto           |   14 +-
 .../src/main/resources/storage-default.xml         |   18 +
 .../src/test/java/tajo/storage/TestFrameTuple.java |   18 +
 .../test/java/tajo/storage/TestMergeScanner.java   |   12 +-
 .../test/java/tajo/storage/TestStorageManager.java |   18 +
 .../src/test/java/tajo/storage/TestStorages.java   |   12 +-
 .../java/tajo/storage/TestTupleComparator.java     |   21 +-
 .../src/test/java/tajo/storage/TestVTuple.java     |   21 +-
 .../test/java/tajo/storage/hcfile/IndexTest.java   |    4 +-
 .../test/java/tajo/storage/index/TestBSTIndex.java |   18 +
 .../storage/index/TestSingleCSVFileBSTIndex.java   |   18 +
 .../test/java/tajo/storage/rcfile/TestRCFile.java  |    2 +-
 .../src/test/resources/storage-default.xml         |   18 +
 tajo-dist/pom.xml                                  |   12 +-
 tajo-dist/src/main/bin/start-catalog.sh            |   14 +-
 tajo-dist/src/main/bin/start-tajo.sh               |   13 +-
 tajo-dist/src/main/bin/stop-tajo.sh                |   13 +-
 tajo-dist/src/main/bin/tajo                        |   13 +-
 tajo-dist/src/main/bin/tajo-config.sh              |   13 +-
 tajo-dist/src/main/bin/tajo-daemon.sh              |   13 +-
 tajo-dist/src/main/conf/catalog-site.xml.template  |   17 +
 tajo-dist/src/main/conf/configuration.xsl          |   18 +
 tajo-dist/src/main/conf/tajo-env.sh                |   16 +
 tajo-dist/src/main/conf/tajo-site.xml.template     |   18 +
 .../src/main/antlr3/tajo/frontend/sql/SQLLexer.g   |   58 +++-
 .../src/main/antlr3/tajo/frontend/sql/SQLParser.g  |   58 +++-
 .../main/java/tajo/frontend/sql/QueryBlock.java    |   12 +-
 .../main/java/tajo/frontend/sql/SQLAnalyzer.java   |   18 +
 .../main/java/tajo/frontend/sql/SQLParseError.java |   14 +-
 .../java/tajo/frontend/sql/SQLSyntaxError.java     |   14 +-
 .../java/tajo/frontend/sql/TestSQLAnalyzer.java    |   12 +-
 .../test/java/tajo/frontend/sql/TestSQLParser.java |   18 +
 tajo-project/pom.xml                               |   19 +-
 tajo-project/src/site/apt/build.apt                |   16 +
 tajo-project/src/site/apt/configuration.apt        |   16 +
 tajo-project/src/site/apt/getting_started.apt      |   16 +
 tajo-project/src/site/apt/index.apt                |   16 +
 tajo-project/src/site/apt/query_language.apt       |   16 +
 tajo-project/src/site/fml/faq.fml                  |   18 +
 tajo-project/src/site/site.xml                     |   18 +
 tajo-rpc/src/main/java/tajo/rpc/CallFuture.java    |   14 +-
 tajo-rpc/src/main/java/tajo/rpc/CallFuture2.java   |   14 +-
 tajo-rpc/src/main/java/tajo/rpc/Callback.java      |   14 +-
 .../src/main/java/tajo/rpc/NettyAsyncRpcProxy.java |   14 +-
 .../main/java/tajo/rpc/NettyBlockingRpcProxy.java  |   14 +-
 .../src/main/java/tajo/rpc/NettyClientBase.java    |   14 +-
 tajo-rpc/src/main/java/tajo/rpc/NettyRpc.java      |   14 +-
 .../src/main/java/tajo/rpc/NettyRpcController.java |   14 +-
 .../src/main/java/tajo/rpc/NettyRpcServer.java     |   14 +-
 .../src/main/java/tajo/rpc/NettyServerBase.java    |   14 +-
 tajo-rpc/src/main/java/tajo/rpc/NullCallback.java  |   14 +-
 .../main/java/tajo/rpc/ProtoAsyncRpcClient.java    |   17 +-
 .../main/java/tajo/rpc/ProtoAsyncRpcServer.java    |   17 +-
 .../main/java/tajo/rpc/ProtoBlockingRpcClient.java |   17 +-
 .../main/java/tajo/rpc/ProtoBlockingRpcServer.java |   14 +-
 .../main/java/tajo/rpc/ProtoPipelineFactory.java   |   14 +-
 .../main/java/tajo/rpc/RemoteCallException.java    |   14 +-
 .../src/main/java/tajo/rpc/RemoteException.java    |   14 +-
 .../java/tajo/rpc/benchmark/BenchmarkAsyncRPC.java |   14 +-
 .../tajo/rpc/benchmark/BenchmarkBlockingRPC.java   |   14 +-
 .../tajo/rpc/benchmark/BenchmarkHadoopRPC.java     |   14 +-
 tajo-rpc/src/main/java/tajo/util/NetUtils.java     |   14 +-
 tajo-rpc/src/test/java/log4j.properties            |   12 +-
 .../src/test/java/tajo/rpc/TestNettyAsyncRpc.java  |   14 +-
 .../test/java/tajo/rpc/TestNettyBlockingRpc.java   |   14 +-
 .../src/test/java/tajo/rpc/TestProtoAsyncRpc.java  |   14 +-
 .../test/java/tajo/rpc/TestProtoBlockingRpc.java   |   14 +-
 .../tajo/rpc/test/impl/DummyProtocolAsyncImpl.java |   14 +-
 .../rpc/test/impl/DummyProtocolBlockingImpl.java   |   14 +-
 708 files changed, 6840 insertions(+), 3070 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/CHANGES.txt
----------------------------------------------------------------------
diff --git a/CHANGES.txt b/CHANGES.txt
index 1064f8b..b366684 100644
--- a/CHANGES.txt
+++ b/CHANGES.txt
@@ -5,6 +5,7 @@ Release 0.2.0 - unreleased
   NEW FEATURES
 
   IMPROVEMENTS
+    TAJO-2: remove all @author tags and update license header (hyunsik)
 
   BUG FIXES
 

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/LICENSE.txt
----------------------------------------------------------------------
diff --git a/LICENSE.txt b/LICENSE.txt
index ba37d8d..d8287ab 100644
--- a/LICENSE.txt
+++ b/LICENSE.txt
@@ -1,16 +1,205 @@
-Copyright (c) 2012 Database Lab., Korea University.
 
-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
+                                 Apache License
+                           Version 2.0, January 2004
+                        http://www.apache.org/licenses/
 
-    http://www.apache.org/licenses/LICENSE-2.0
+   TERMS AND CONDITIONS FOR USE, REPRODUCTION, AND DISTRIBUTION
 
-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.
+   1. Definitions.
+
+      "License" shall mean the terms and conditions for use, reproduction,
+      and distribution as defined by Sections 1 through 9 of this document.
+
+      "Licensor" shall mean the copyright owner or entity authorized by
+      the copyright owner that is granting the License.
+
+      "Legal Entity" shall mean the union of the acting entity and all
+      other entities that control, are controlled by, or are under common
+      control with that entity. For the purposes of this definition,
+      "control" means (i) the power, direct or indirect, to cause the
+      direction or management of such entity, whether by contract or
+      otherwise, or (ii) ownership of fifty percent (50%) or more of the
+      outstanding shares, or (iii) beneficial ownership of such entity.
+
+      "You" (or "Your") shall mean an individual or Legal Entity
+      exercising permissions granted by this License.
+
+      "Source" form shall mean the preferred form for making modifications,
+      including but not limited to software source code, documentation
+      source, and configuration files.
+
+      "Object" form shall mean any form resulting from mechanical
+      transformation or translation of a Source form, including but
+      not limited to compiled object code, generated documentation,
+      and conversions to other media types.
+
+      "Work" shall mean the work of authorship, whether in Source or
+      Object form, made available under the License, as indicated by a
+      copyright notice that is included in or attached to the work
+      (an example is provided in the Appendix below).
+
+      "Derivative Works" shall mean any work, whether in Source or Object
+      form, that is based on (or derived from) the Work and for which the
+      editorial revisions, annotations, elaborations, or other modifications
+      represent, as a whole, an original work of authorship. For the purposes
+      of this License, Derivative Works shall not include works that remain
+      separable from, or merely link (or bind by name) to the interfaces of,
+      the Work and Derivative Works thereof.
+
+      "Contribution" shall mean any work of authorship, including
+      the original version of the Work and any modifications or additions
+      to that Work or Derivative Works thereof, that is intentionally
+      submitted to Licensor for inclusion in the Work by the copyright owner
+      or by an individual or Legal Entity authorized to submit on behalf of
+      the copyright owner. For the purposes of this definition, "submitted"
+      means any form of electronic, verbal, or written communication sent
+      to the Licensor or its representatives, including but not limited to
+      communication on electronic mailing lists, source code control systems,
+      and issue tracking systems that are managed by, or on behalf of, the
+      Licensor for the purpose of discussing and improving the Work, but
+      excluding communication that is conspicuously marked or otherwise
+      designated in writing by the copyright owner as "Not a Contribution."
+
+      "Contributor" shall mean Licensor and any individual or Legal Entity
+      on behalf of whom a Contribution has been received by Licensor and
+      subsequently incorporated within the Work.
+
+   2. Grant of Copyright License. Subject to the terms and conditions of
+      this License, each Contributor hereby grants to You a perpetual,
+      worldwide, non-exclusive, no-charge, royalty-free, irrevocable
+      copyright license to reproduce, prepare Derivative Works of,
+      publicly display, publicly perform, sublicense, and distribute the
+      Work and such Derivative Works in Source or Object form.
+
+   3. Grant of Patent License. Subject to the terms and conditions of
+      this License, each Contributor hereby grants to You a perpetual,
+      worldwide, non-exclusive, no-charge, royalty-free, irrevocable
+      (except as stated in this section) patent license to make, have made,
+      use, offer to sell, sell, import, and otherwise transfer the Work,
+      where such license applies only to those patent claims licensable
+      by such Contributor that are necessarily infringed by their
+      Contribution(s) alone or by combination of their Contribution(s)
+      with the Work to which such Contribution(s) was submitted. If You
+      institute patent litigation against any entity (including a
+      cross-claim or counterclaim in a lawsuit) alleging that the Work
+      or a Contribution incorporated within the Work constitutes direct
+      or contributory patent infringement, then any patent licenses
+      granted to You under this License for that Work shall terminate
+      as of the date such litigation is filed.
+
+   4. Redistribution. You may reproduce and distribute copies of the
+      Work or Derivative Works thereof in any medium, with or without
+      modifications, and in Source or Object form, provided that You
+      meet the following conditions:
+
+      (a) You must give any other recipients of the Work or
+          Derivative Works a copy of this License; and
+
+      (b) You must cause any modified files to carry prominent notices
+          stating that You changed the files; and
+
+      (c) You must retain, in the Source form of any Derivative Works
+          that You distribute, all copyright, patent, trademark, and
+          attribution notices from the Source form of the Work,
+          excluding those notices that do not pertain to any part of
+          the Derivative Works; and
+
+      (d) If the Work includes a "NOTICE" text file as part of its
+          distribution, then any Derivative Works that You distribute must
+          include a readable copy of the attribution notices contained
+          within such NOTICE file, excluding those notices that do not
+          pertain to any part of the Derivative Works, in at least one
+          of the following places: within a NOTICE text file distributed
+          as part of the Derivative Works; within the Source form or
+          documentation, if provided along with the Derivative Works; or,
+          within a display generated by the Derivative Works, if and
+          wherever such third-party notices normally appear. The contents
+          of the NOTICE file are for informational purposes only and
+          do not modify the License. You may add Your own attribution
+          notices within Derivative Works that You distribute, alongside
+          or as an addendum to the NOTICE text from the Work, provided
+          that such additional attribution notices cannot be construed
+          as modifying the License.
+
+      You may add Your own copyright statement to Your modifications and
+      may provide additional or different license terms and conditions
+      for use, reproduction, or distribution of Your modifications, or
+      for any such Derivative Works as a whole, provided Your use,
+      reproduction, and distribution of the Work otherwise complies with
+      the conditions stated in this License.
+
+   5. Submission of Contributions. Unless You explicitly state otherwise,
+      any Contribution intentionally submitted for inclusion in the Work
+      by You to the Licensor shall be under the terms and conditions of
+      this License, without any additional terms or conditions.
+      Notwithstanding the above, nothing herein shall supersede or modify
+      the terms of any separate license agreement you may have executed
+      with Licensor regarding such Contributions.
+
+   6. Trademarks. This License does not grant permission to use the trade
+      names, trademarks, service marks, or product names of the Licensor,
+      except as required for reasonable and customary use in describing the
+      origin of the Work and reproducing the content of the NOTICE file.
+
+   7. Disclaimer of Warranty. Unless required by applicable law or
+      agreed to in writing, Licensor provides the Work (and each
+      Contributor provides its Contributions) on an "AS IS" BASIS,
+      WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or
+      implied, including, without limitation, any warranties or conditions
+      of TITLE, NON-INFRINGEMENT, MERCHANTABILITY, or FITNESS FOR A
+      PARTICULAR PURPOSE. You are solely responsible for determining the
+      appropriateness of using or redistributing the Work and assume any
+      risks associated with Your exercise of permissions under this License.
+
+   8. Limitation of Liability. In no event and under no legal theory,
+      whether in tort (including negligence), contract, or otherwise,
+      unless required by applicable law (such as deliberate and grossly
+      negligent acts) or agreed to in writing, shall any Contributor be
+      liable to You for damages, including any direct, indirect, special,
+      incidental, or consequential damages of any character arising as a
+      result of this License or out of the use or inability to use the
+      Work (including but not limited to damages for loss of goodwill,
+      work stoppage, computer failure or malfunction, or any and all
+      other commercial damages or losses), even if such Contributor
+      has been advised of the possibility of such damages.
+
+   9. Accepting Warranty or Additional Liability. While redistributing
+      the Work or Derivative Works thereof, You may choose to offer,
+      and charge a fee for, acceptance of support, warranty, indemnity,
+      or other liability obligations and/or rights consistent with this
+      License. However, in accepting such obligations, You may act only
+      on Your own behalf and on Your sole responsibility, not on behalf
+      of any other Contributor, and only if You agree to indemnify,
+      defend, and hold each Contributor harmless for any liability
+      incurred by, or claims asserted against, such Contributor by reason
+      of your accepting any such warranty or additional liability.
+
+   END OF TERMS AND CONDITIONS
+
+   APPENDIX: How to apply the Apache License to your work.
+
+      To apply the Apache License to your work, attach the following
+      boilerplate notice, with the fields enclosed by brackets "[]"
+      replaced with your own identifying information. (Don't include
+      the brackets!)  The text should be enclosed in the appropriate
+      comment syntax for the file format. We also recommend that a
+      file or class name and description of purpose be included on the
+      same "printed page" as the copyright notice for easier
+      identification within third-party archives.
+
+   Copyright [yyyy] [name of copyright owner]
+
+   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
+
+       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.
 
 TAJO SUBCOMPONENTS:
 
@@ -147,4 +336,37 @@ OF THIS SOFTWARE, EVEN IF ADVISED OF THE POSSIBILITY OF SUCH DAMAGE.
 Code generated by the Protocol Buffer compiler is owned by the owner
 of the input file used when generating it.  This code is not
 standalone and requires a support library to be linked with it.  This
-support library is itself covered by the above license.
\ No newline at end of file
+support library is itself covered by the above license.
+
+------------------------------------------------------------------------------
+For SQL BNF Grammar (http://www.antlr3.org/grammar/1304304798093/SQL2003_Grammar.zip)
+
+This software is made available under the BSD License:
+
+Copyright (c) 2011, Mage Systems
+Portions Copyright (c)  Jonathan Leffler 2004-2009'
+Portions Copyright (c) 2003, ISO - International Organization for Standardization
+All rights reserved.
+
+Redistribution and use in source and binary forms, with or without modification,
+are permitted provided that the following conditions are met:
+
+    * Redistributions of source code must retain the above copyright notice, this
+      list of conditions and the following disclaimer.
+    * Redistributions in binary form must reproduce the above copyright notice,
+      this list of conditions and the following disclaimer in the documentation
+      and/or other materials provided with the distribution.
+    * Neither the name of the "Mage Systems" nor the names of its contributors
+      may be used to endorse or promote products derived from this software
+      without specific prior written permission.
+
+THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" AND
+ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE IMPLIED
+WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE ARE DISCLAIMED.
+IN NO EVENT SHALL THE COPYRIGHT HOLDER OR CONTRIBUTORS BE LIABLE FOR ANY DIRECT,
+INDIRECT, INCIDENTAL, SPECIAL, EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING,
+BUT NOT LIMITED TO, PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES; LOSS OF USE,
+DATA, OR PROFITS; OR BUSINESS INTERRUPTION) HOWEVER CAUSED AND ON ANY THEORY OF
+LIABILITY, WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT (INCLUDING NEGLIGENCE
+OR OTHERWISE) ARISING IN ANY WAY OUT OF THE USE OF THIS SOFTWARE, EVEN IF ADVISED
+OF THE POSSIBILITY OF SUCH DAMAGE.
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/NOTICE.txt
----------------------------------------------------------------------
diff --git a/NOTICE.txt b/NOTICE.txt
index c52e77b..9fdded2 100644
--- a/NOTICE.txt
+++ b/NOTICE.txt
@@ -20,4 +20,9 @@ This product includes/uses Guava (http://code.google.com/p/guava-libraries/)
 Copyright (c) 2006-2012 Google Inc.
 
 This product includes/uses Protocol Buffers (http://code.google.com/p/protobuf/)
-Copyright (c) 2008, Google Inc.
\ No newline at end of file
+Copyright (c) 2008, Google Inc.
+
+This product includes/uses SQL BNF Grammer (http://www.antlr3.org/grammar/1304304798093/SQL2003_Grammar.zip)
+Copyright (c) 2011, Mage Systems
+Portions Copyright (c)  Jonathan Leffler 2004-2009'
+Portions Copyright (c) 2003, ISO - International Organization for Standardization
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/pom.xml
----------------------------------------------------------------------
diff --git a/pom.xml b/pom.xml
index bd67673..4cad5e3 100644
--- a/pom.xml
+++ b/pom.xml
@@ -1,9 +1,12 @@
+<?xml version="1.0" encoding="UTF-8"?>
 <!--
-  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
 
@@ -13,6 +16,7 @@
   See the License for the specific language governing permissions and
   limitations under the License.
   -->
+
 <project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
   xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
   <modelVersion>4.0.0</modelVersion>
@@ -282,6 +286,43 @@
           </execution>
         </executions>
       </plugin>
+      <plugin>
+        <groupId>org.apache.rat</groupId>
+        <artifactId>apache-rat-plugin</artifactId>
+        <version>0.8</version>
+        <executions>
+          <execution>
+            <phase>verify</phase>
+            <goals>
+              <goal>check</goal>
+            </goals>
+          </execution>
+        </executions>
+        <configuration>
+          <excludeSubProjects>false</excludeSubProjects>
+          <numUnapprovedLicenses>0</numUnapprovedLicenses>
+          <excludes>
+            <exclude>CHANGES.txt</exclude>
+            <exclude>**/*.tql</exclude>
+            <exclude>**/*.schema</exclude>
+            <exclude>**/*.tbl</exclude>
+            <!-- generated content -->
+            <exclude>**/target/**</exclude>
+            <exclude>**/*.log</exclude>
+            <!-- source control and IDEs -->
+            <exclude>.git/**</exclude>
+            <exclude>.gitignore</exclude>
+            <exclude>*.patch</exclude>
+            <exclude>.idea/**</exclude>
+            <exclude>**/*.iml</exclude>
+            <exclude>**/*.ipr</exclude>
+            <exclude>**/.project</exclude>
+            <exclude>**/.classpath</exclude>
+            <exclude>**/.settings/**</exclude>
+            <exclude>atlassian-ide-plugin.xml</exclude>
+          </excludes>
+        </configuration>
+      </plugin>
     </plugins>
   </build>
 </project>

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-algebra/src/main/java/tajo/algebra/Aggregation.java
----------------------------------------------------------------------
diff --git a/tajo-algebra/src/main/java/tajo/algebra/Aggregation.java b/tajo-algebra/src/main/java/tajo/algebra/Aggregation.java
index 6d3e8fd..6571414 100644
--- a/tajo-algebra/src/main/java/tajo/algebra/Aggregation.java
+++ b/tajo-algebra/src/main/java/tajo/algebra/Aggregation.java
@@ -1,7 +1,11 @@
-/*
- * 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-algebra/src/main/java/tajo/algebra/BinaryOperator.java
----------------------------------------------------------------------
diff --git a/tajo-algebra/src/main/java/tajo/algebra/BinaryOperator.java b/tajo-algebra/src/main/java/tajo/algebra/BinaryOperator.java
index fe024b6..eb06402 100644
--- a/tajo-algebra/src/main/java/tajo/algebra/BinaryOperator.java
+++ b/tajo-algebra/src/main/java/tajo/algebra/BinaryOperator.java
@@ -1,7 +1,11 @@
-/*
- * 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-algebra/src/main/java/tajo/algebra/CaseWhenExpr.java
----------------------------------------------------------------------
diff --git a/tajo-algebra/src/main/java/tajo/algebra/CaseWhenExpr.java b/tajo-algebra/src/main/java/tajo/algebra/CaseWhenExpr.java
index 0eef54f..8dd2bed 100644
--- a/tajo-algebra/src/main/java/tajo/algebra/CaseWhenExpr.java
+++ b/tajo-algebra/src/main/java/tajo/algebra/CaseWhenExpr.java
@@ -1,7 +1,11 @@
-/*
- * 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-algebra/src/main/java/tajo/algebra/ColumnReferenceExpr.java
----------------------------------------------------------------------
diff --git a/tajo-algebra/src/main/java/tajo/algebra/ColumnReferenceExpr.java b/tajo-algebra/src/main/java/tajo/algebra/ColumnReferenceExpr.java
index ed1150f..dba02fd 100644
--- a/tajo-algebra/src/main/java/tajo/algebra/ColumnReferenceExpr.java
+++ b/tajo-algebra/src/main/java/tajo/algebra/ColumnReferenceExpr.java
@@ -1,7 +1,11 @@
-/*
- * 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-algebra/src/main/java/tajo/algebra/CreateTable.java
----------------------------------------------------------------------
diff --git a/tajo-algebra/src/main/java/tajo/algebra/CreateTable.java b/tajo-algebra/src/main/java/tajo/algebra/CreateTable.java
index dda5042..f6e4169 100644
--- a/tajo-algebra/src/main/java/tajo/algebra/CreateTable.java
+++ b/tajo-algebra/src/main/java/tajo/algebra/CreateTable.java
@@ -1,7 +1,11 @@
-/*
- * 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-algebra/src/main/java/tajo/algebra/Expr.java
----------------------------------------------------------------------
diff --git a/tajo-algebra/src/main/java/tajo/algebra/Expr.java b/tajo-algebra/src/main/java/tajo/algebra/Expr.java
index 808a628..db6e5fd 100644
--- a/tajo-algebra/src/main/java/tajo/algebra/Expr.java
+++ b/tajo-algebra/src/main/java/tajo/algebra/Expr.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.algebra;
 
 import com.google.gson.*;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-algebra/src/main/java/tajo/algebra/ExprType.java
----------------------------------------------------------------------
diff --git a/tajo-algebra/src/main/java/tajo/algebra/ExprType.java b/tajo-algebra/src/main/java/tajo/algebra/ExprType.java
index 1af7e4e..9a29d99 100644
--- a/tajo-algebra/src/main/java/tajo/algebra/ExprType.java
+++ b/tajo-algebra/src/main/java/tajo/algebra/ExprType.java
@@ -1,7 +1,11 @@
-/*
- * 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-algebra/src/main/java/tajo/algebra/FunctionExpr.java
----------------------------------------------------------------------
diff --git a/tajo-algebra/src/main/java/tajo/algebra/FunctionExpr.java b/tajo-algebra/src/main/java/tajo/algebra/FunctionExpr.java
index d55d6c6..5bd5d8d 100644
--- a/tajo-algebra/src/main/java/tajo/algebra/FunctionExpr.java
+++ b/tajo-algebra/src/main/java/tajo/algebra/FunctionExpr.java
@@ -1,7 +1,11 @@
-/*
- * 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-algebra/src/main/java/tajo/algebra/Join.java
----------------------------------------------------------------------
diff --git a/tajo-algebra/src/main/java/tajo/algebra/Join.java b/tajo-algebra/src/main/java/tajo/algebra/Join.java
index 7277048..6af12f9 100644
--- a/tajo-algebra/src/main/java/tajo/algebra/Join.java
+++ b/tajo-algebra/src/main/java/tajo/algebra/Join.java
@@ -1,7 +1,11 @@
-/*
- * 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-algebra/src/main/java/tajo/algebra/JoinType.java
----------------------------------------------------------------------
diff --git a/tajo-algebra/src/main/java/tajo/algebra/JoinType.java b/tajo-algebra/src/main/java/tajo/algebra/JoinType.java
index 0887804..5895324 100644
--- a/tajo-algebra/src/main/java/tajo/algebra/JoinType.java
+++ b/tajo-algebra/src/main/java/tajo/algebra/JoinType.java
@@ -1,7 +1,11 @@
-/*
- * 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-algebra/src/main/java/tajo/algebra/JsonHelper.java
----------------------------------------------------------------------
diff --git a/tajo-algebra/src/main/java/tajo/algebra/JsonHelper.java b/tajo-algebra/src/main/java/tajo/algebra/JsonHelper.java
index ac8b89d..29cddd4 100644
--- a/tajo-algebra/src/main/java/tajo/algebra/JsonHelper.java
+++ b/tajo-algebra/src/main/java/tajo/algebra/JsonHelper.java
@@ -1,7 +1,11 @@
-/*
- * 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-algebra/src/main/java/tajo/algebra/JsonSerializable.java
----------------------------------------------------------------------
diff --git a/tajo-algebra/src/main/java/tajo/algebra/JsonSerializable.java b/tajo-algebra/src/main/java/tajo/algebra/JsonSerializable.java
index d5fb7a5..f98c054 100644
--- a/tajo-algebra/src/main/java/tajo/algebra/JsonSerializable.java
+++ b/tajo-algebra/src/main/java/tajo/algebra/JsonSerializable.java
@@ -1,7 +1,11 @@
-/*
- * 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-algebra/src/main/java/tajo/algebra/LikeExpr.java
----------------------------------------------------------------------
diff --git a/tajo-algebra/src/main/java/tajo/algebra/LikeExpr.java b/tajo-algebra/src/main/java/tajo/algebra/LikeExpr.java
index f859832..2910c62 100644
--- a/tajo-algebra/src/main/java/tajo/algebra/LikeExpr.java
+++ b/tajo-algebra/src/main/java/tajo/algebra/LikeExpr.java
@@ -1,7 +1,11 @@
-/*
- * 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-algebra/src/main/java/tajo/algebra/Limit.java
----------------------------------------------------------------------
diff --git a/tajo-algebra/src/main/java/tajo/algebra/Limit.java b/tajo-algebra/src/main/java/tajo/algebra/Limit.java
index 3c5b4f4..84d88ce 100644
--- a/tajo-algebra/src/main/java/tajo/algebra/Limit.java
+++ b/tajo-algebra/src/main/java/tajo/algebra/Limit.java
@@ -1,7 +1,11 @@
-/*
- * 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-algebra/src/main/java/tajo/algebra/LiteralExpr.java
----------------------------------------------------------------------
diff --git a/tajo-algebra/src/main/java/tajo/algebra/LiteralExpr.java b/tajo-algebra/src/main/java/tajo/algebra/LiteralExpr.java
index 461a95a..eae0e1c 100644
--- a/tajo-algebra/src/main/java/tajo/algebra/LiteralExpr.java
+++ b/tajo-algebra/src/main/java/tajo/algebra/LiteralExpr.java
@@ -1,7 +1,11 @@
-/*
- * 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-algebra/src/main/java/tajo/algebra/Projection.java
----------------------------------------------------------------------
diff --git a/tajo-algebra/src/main/java/tajo/algebra/Projection.java b/tajo-algebra/src/main/java/tajo/algebra/Projection.java
index b16f417..c8b2d7f 100644
--- a/tajo-algebra/src/main/java/tajo/algebra/Projection.java
+++ b/tajo-algebra/src/main/java/tajo/algebra/Projection.java
@@ -1,7 +1,11 @@
-/*
- * 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-algebra/src/main/java/tajo/algebra/Relation.java
----------------------------------------------------------------------
diff --git a/tajo-algebra/src/main/java/tajo/algebra/Relation.java b/tajo-algebra/src/main/java/tajo/algebra/Relation.java
index 7ea1540..bb692c2 100644
--- a/tajo-algebra/src/main/java/tajo/algebra/Relation.java
+++ b/tajo-algebra/src/main/java/tajo/algebra/Relation.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.algebra;
 
 import tajo.util.TUtil;

http://git-wip-us.apache.org/repos/asf/incubator-tajo/blob/457fea18/tajo-algebra/src/main/java/tajo/algebra/ScalarSubQuery.java
----------------------------------------------------------------------
diff --git a/tajo-algebra/src/main/java/tajo/algebra/ScalarSubQuery.java b/tajo-algebra/src/main/java/tajo/algebra/ScalarSubQuery.java
index 9760242..35e2a49 100644
--- a/tajo-algebra/src/main/java/tajo/algebra/ScalarSubQuery.java
+++ b/tajo-algebra/src/main/java/tajo/algebra/ScalarSubQuery.java
@@ -1,7 +1,11 @@
-/*
- * 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-algebra/src/main/java/tajo/algebra/Selection.java
----------------------------------------------------------------------
diff --git a/tajo-algebra/src/main/java/tajo/algebra/Selection.java b/tajo-algebra/src/main/java/tajo/algebra/Selection.java
index b3539cb..8364801 100644
--- a/tajo-algebra/src/main/java/tajo/algebra/Selection.java
+++ b/tajo-algebra/src/main/java/tajo/algebra/Selection.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-algebra/src/main/java/tajo/algebra/SetOperation.java
----------------------------------------------------------------------
diff --git a/tajo-algebra/src/main/java/tajo/algebra/SetOperation.java b/tajo-algebra/src/main/java/tajo/algebra/SetOperation.java
index 4540699..eeff233 100644
--- a/tajo-algebra/src/main/java/tajo/algebra/SetOperation.java
+++ b/tajo-algebra/src/main/java/tajo/algebra/SetOperation.java
@@ -1,7 +1,11 @@
-/*
- * 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-algebra/src/main/java/tajo/algebra/Sort.java
----------------------------------------------------------------------
diff --git a/tajo-algebra/src/main/java/tajo/algebra/Sort.java b/tajo-algebra/src/main/java/tajo/algebra/Sort.java
index c5336db..fb0db45 100644
--- a/tajo-algebra/src/main/java/tajo/algebra/Sort.java
+++ b/tajo-algebra/src/main/java/tajo/algebra/Sort.java
@@ -1,7 +1,11 @@
-/*
- * 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-algebra/src/main/java/tajo/algebra/TableSubQuery.java
----------------------------------------------------------------------
diff --git a/tajo-algebra/src/main/java/tajo/algebra/TableSubQuery.java b/tajo-algebra/src/main/java/tajo/algebra/TableSubQuery.java
index 9f56196..e1881ae 100644
--- a/tajo-algebra/src/main/java/tajo/algebra/TableSubQuery.java
+++ b/tajo-algebra/src/main/java/tajo/algebra/TableSubQuery.java
@@ -1,7 +1,11 @@
-/*
- * 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
  *