You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@phoenix.apache.org by mu...@apache.org on 2014/02/13 00:24:39 UTC

[7/8] Add missing ASF license headers to source and remove copyright https://issues.apache.org/jira/browse/PHOENIX-45

http://git-wip-us.apache.org/repos/asf/incubator-phoenix/blob/18ddce87/src/main/java/org/apache/hbase/index/parallel/TaskBatch.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/hbase/index/parallel/TaskBatch.java b/src/main/java/org/apache/hbase/index/parallel/TaskBatch.java
index e55429e..3e31ad1 100644
--- a/src/main/java/org/apache/hbase/index/parallel/TaskBatch.java
+++ b/src/main/java/org/apache/hbase/index/parallel/TaskBatch.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/hbase/index/parallel/TaskRunner.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/hbase/index/parallel/TaskRunner.java b/src/main/java/org/apache/hbase/index/parallel/TaskRunner.java
index 47d3933..90d594c 100644
--- a/src/main/java/org/apache/hbase/index/parallel/TaskRunner.java
+++ b/src/main/java/org/apache/hbase/index/parallel/TaskRunner.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/hbase/index/parallel/ThreadPoolBuilder.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/hbase/index/parallel/ThreadPoolBuilder.java b/src/main/java/org/apache/hbase/index/parallel/ThreadPoolBuilder.java
index 41d82d9..2227c97 100644
--- a/src/main/java/org/apache/hbase/index/parallel/ThreadPoolBuilder.java
+++ b/src/main/java/org/apache/hbase/index/parallel/ThreadPoolBuilder.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/hbase/index/parallel/ThreadPoolManager.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/hbase/index/parallel/ThreadPoolManager.java b/src/main/java/org/apache/hbase/index/parallel/ThreadPoolManager.java
index 7eea7bc..b8dc289 100644
--- a/src/main/java/org/apache/hbase/index/parallel/ThreadPoolManager.java
+++ b/src/main/java/org/apache/hbase/index/parallel/ThreadPoolManager.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/hbase/index/parallel/WaitForCompletionTaskRunner.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/hbase/index/parallel/WaitForCompletionTaskRunner.java b/src/main/java/org/apache/hbase/index/parallel/WaitForCompletionTaskRunner.java
index 8a8fc10..57f812d 100644
--- a/src/main/java/org/apache/hbase/index/parallel/WaitForCompletionTaskRunner.java
+++ b/src/main/java/org/apache/hbase/index/parallel/WaitForCompletionTaskRunner.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/hbase/index/scanner/EmptyScanner.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/hbase/index/scanner/EmptyScanner.java b/src/main/java/org/apache/hbase/index/scanner/EmptyScanner.java
index 140671e..b34128b 100644
--- a/src/main/java/org/apache/hbase/index/scanner/EmptyScanner.java
+++ b/src/main/java/org/apache/hbase/index/scanner/EmptyScanner.java
@@ -1,3 +1,20 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT 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 org.apache.hbase.index.scanner;
 
 import java.io.IOException;

http://git-wip-us.apache.org/repos/asf/incubator-phoenix/blob/18ddce87/src/main/java/org/apache/hbase/index/scanner/FilteredKeyValueScanner.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/hbase/index/scanner/FilteredKeyValueScanner.java b/src/main/java/org/apache/hbase/index/scanner/FilteredKeyValueScanner.java
index 0a13ba1..251d1e9 100644
--- a/src/main/java/org/apache/hbase/index/scanner/FilteredKeyValueScanner.java
+++ b/src/main/java/org/apache/hbase/index/scanner/FilteredKeyValueScanner.java
@@ -1,3 +1,20 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT 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 org.apache.hbase.index.scanner;
 
 import java.io.IOException;

http://git-wip-us.apache.org/repos/asf/incubator-phoenix/blob/18ddce87/src/main/java/org/apache/hbase/index/scanner/Scanner.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/hbase/index/scanner/Scanner.java b/src/main/java/org/apache/hbase/index/scanner/Scanner.java
index 75c053e..7740d01 100644
--- a/src/main/java/org/apache/hbase/index/scanner/Scanner.java
+++ b/src/main/java/org/apache/hbase/index/scanner/Scanner.java
@@ -1,3 +1,20 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT 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 org.apache.hbase.index.scanner;
 
 import java.io.Closeable;

http://git-wip-us.apache.org/repos/asf/incubator-phoenix/blob/18ddce87/src/main/java/org/apache/hbase/index/scanner/ScannerBuilder.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/hbase/index/scanner/ScannerBuilder.java b/src/main/java/org/apache/hbase/index/scanner/ScannerBuilder.java
index c6448d6..0963e04 100644
--- a/src/main/java/org/apache/hbase/index/scanner/ScannerBuilder.java
+++ b/src/main/java/org/apache/hbase/index/scanner/ScannerBuilder.java
@@ -1,3 +1,20 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT 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 org.apache.hbase.index.scanner;
 
 import java.io.IOException;

http://git-wip-us.apache.org/repos/asf/incubator-phoenix/blob/18ddce87/src/main/java/org/apache/hbase/index/table/CachingHTableFactory.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/hbase/index/table/CachingHTableFactory.java b/src/main/java/org/apache/hbase/index/table/CachingHTableFactory.java
index e27cb13..f48e60f 100644
--- a/src/main/java/org/apache/hbase/index/table/CachingHTableFactory.java
+++ b/src/main/java/org/apache/hbase/index/table/CachingHTableFactory.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/hbase/index/table/CoprocessorHTableFactory.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/hbase/index/table/CoprocessorHTableFactory.java b/src/main/java/org/apache/hbase/index/table/CoprocessorHTableFactory.java
index e773105..1dd2020 100644
--- a/src/main/java/org/apache/hbase/index/table/CoprocessorHTableFactory.java
+++ b/src/main/java/org/apache/hbase/index/table/CoprocessorHTableFactory.java
@@ -1,3 +1,20 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT 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 org.apache.hbase.index.table;
 
 import java.io.IOException;

http://git-wip-us.apache.org/repos/asf/incubator-phoenix/blob/18ddce87/src/main/java/org/apache/hbase/index/table/HTableFactory.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/hbase/index/table/HTableFactory.java b/src/main/java/org/apache/hbase/index/table/HTableFactory.java
index f9e524f..c94d2ec 100644
--- a/src/main/java/org/apache/hbase/index/table/HTableFactory.java
+++ b/src/main/java/org/apache/hbase/index/table/HTableFactory.java
@@ -1,3 +1,20 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT 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 org.apache.hbase.index.table;
 
 import java.io.IOException;

http://git-wip-us.apache.org/repos/asf/incubator-phoenix/blob/18ddce87/src/main/java/org/apache/hbase/index/table/HTableInterfaceReference.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/hbase/index/table/HTableInterfaceReference.java b/src/main/java/org/apache/hbase/index/table/HTableInterfaceReference.java
index 6854003..e948e99 100644
--- a/src/main/java/org/apache/hbase/index/table/HTableInterfaceReference.java
+++ b/src/main/java/org/apache/hbase/index/table/HTableInterfaceReference.java
@@ -1,3 +1,20 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT 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 org.apache.hbase.index.table;
 
 import org.apache.hadoop.hbase.util.Bytes;

http://git-wip-us.apache.org/repos/asf/incubator-phoenix/blob/18ddce87/src/main/java/org/apache/hbase/index/util/ImmutableBytesPtr.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/hbase/index/util/ImmutableBytesPtr.java b/src/main/java/org/apache/hbase/index/util/ImmutableBytesPtr.java
index 24f1d45..871c5ec 100644
--- a/src/main/java/org/apache/hbase/index/util/ImmutableBytesPtr.java
+++ b/src/main/java/org/apache/hbase/index/util/ImmutableBytesPtr.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/hbase/index/util/IndexManagementUtil.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/hbase/index/util/IndexManagementUtil.java b/src/main/java/org/apache/hbase/index/util/IndexManagementUtil.java
index a5db775..8f75d17 100644
--- a/src/main/java/org/apache/hbase/index/util/IndexManagementUtil.java
+++ b/src/main/java/org/apache/hbase/index/util/IndexManagementUtil.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/hbase/index/wal/IndexedKeyValue.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/hbase/index/wal/IndexedKeyValue.java b/src/main/java/org/apache/hbase/index/wal/IndexedKeyValue.java
index ca46fce..3def0ba 100644
--- a/src/main/java/org/apache/hbase/index/wal/IndexedKeyValue.java
+++ b/src/main/java/org/apache/hbase/index/wal/IndexedKeyValue.java
@@ -1,3 +1,20 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT 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 org.apache.hbase.index.wal;
 
 import java.io.ByteArrayOutputStream;

http://git-wip-us.apache.org/repos/asf/incubator-phoenix/blob/18ddce87/src/main/java/org/apache/hbase/index/wal/KeyValueCodec.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/hbase/index/wal/KeyValueCodec.java b/src/main/java/org/apache/hbase/index/wal/KeyValueCodec.java
index 2cdb181..ee37e97 100644
--- a/src/main/java/org/apache/hbase/index/wal/KeyValueCodec.java
+++ b/src/main/java/org/apache/hbase/index/wal/KeyValueCodec.java
@@ -1,3 +1,20 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT 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 org.apache.hbase.index.wal;
 
 import java.io.DataInput;

http://git-wip-us.apache.org/repos/asf/incubator-phoenix/blob/18ddce87/src/main/java/org/apache/hbase/index/write/IndexCommitter.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/hbase/index/write/IndexCommitter.java b/src/main/java/org/apache/hbase/index/write/IndexCommitter.java
index c8ab287..d6bca35 100644
--- a/src/main/java/org/apache/hbase/index/write/IndexCommitter.java
+++ b/src/main/java/org/apache/hbase/index/write/IndexCommitter.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/hbase/index/write/IndexFailurePolicy.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/hbase/index/write/IndexFailurePolicy.java b/src/main/java/org/apache/hbase/index/write/IndexFailurePolicy.java
index f478618..5eeb3bb 100644
--- a/src/main/java/org/apache/hbase/index/write/IndexFailurePolicy.java
+++ b/src/main/java/org/apache/hbase/index/write/IndexFailurePolicy.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/hbase/index/write/IndexWriter.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/hbase/index/write/IndexWriter.java b/src/main/java/org/apache/hbase/index/write/IndexWriter.java
index 033177f..d821215 100644
--- a/src/main/java/org/apache/hbase/index/write/IndexWriter.java
+++ b/src/main/java/org/apache/hbase/index/write/IndexWriter.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/hbase/index/write/IndexWriterUtils.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/hbase/index/write/IndexWriterUtils.java b/src/main/java/org/apache/hbase/index/write/IndexWriterUtils.java
index 697cf4f..170e1c7 100644
--- a/src/main/java/org/apache/hbase/index/write/IndexWriterUtils.java
+++ b/src/main/java/org/apache/hbase/index/write/IndexWriterUtils.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/hbase/index/write/KillServerOnFailurePolicy.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/hbase/index/write/KillServerOnFailurePolicy.java b/src/main/java/org/apache/hbase/index/write/KillServerOnFailurePolicy.java
index 5b3c410..ae9b8da 100644
--- a/src/main/java/org/apache/hbase/index/write/KillServerOnFailurePolicy.java
+++ b/src/main/java/org/apache/hbase/index/write/KillServerOnFailurePolicy.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/hbase/index/write/ParallelWriterIndexCommitter.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/hbase/index/write/ParallelWriterIndexCommitter.java b/src/main/java/org/apache/hbase/index/write/ParallelWriterIndexCommitter.java
index 9d7dcaa..65ff078 100644
--- a/src/main/java/org/apache/hbase/index/write/ParallelWriterIndexCommitter.java
+++ b/src/main/java/org/apache/hbase/index/write/ParallelWriterIndexCommitter.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/hbase/index/write/recovery/PerRegionIndexWriteCache.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/hbase/index/write/recovery/PerRegionIndexWriteCache.java b/src/main/java/org/apache/hbase/index/write/recovery/PerRegionIndexWriteCache.java
index eecc981..e0ad29f 100644
--- a/src/main/java/org/apache/hbase/index/write/recovery/PerRegionIndexWriteCache.java
+++ b/src/main/java/org/apache/hbase/index/write/recovery/PerRegionIndexWriteCache.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/hbase/index/write/recovery/TrackingParallelWriterIndexCommitter.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/hbase/index/write/recovery/TrackingParallelWriterIndexCommitter.java b/src/main/java/org/apache/hbase/index/write/recovery/TrackingParallelWriterIndexCommitter.java
index 28fc832..4d67747 100644
--- a/src/main/java/org/apache/hbase/index/write/recovery/TrackingParallelWriterIndexCommitter.java
+++ b/src/main/java/org/apache/hbase/index/write/recovery/TrackingParallelWriterIndexCommitter.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/cache/GlobalCache.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/cache/GlobalCache.java b/src/main/java/org/apache/phoenix/cache/GlobalCache.java
index 7b762ef..d9df357 100644
--- a/src/main/java/org/apache/phoenix/cache/GlobalCache.java
+++ b/src/main/java/org/apache/phoenix/cache/GlobalCache.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/cache/HashCache.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/cache/HashCache.java b/src/main/java/org/apache/phoenix/cache/HashCache.java
index 00fbb39..6f4a320 100644
--- a/src/main/java/org/apache/phoenix/cache/HashCache.java
+++ b/src/main/java/org/apache/phoenix/cache/HashCache.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/cache/IndexMetaDataCache.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/cache/IndexMetaDataCache.java b/src/main/java/org/apache/phoenix/cache/IndexMetaDataCache.java
index fac78de..79c48f4 100644
--- a/src/main/java/org/apache/phoenix/cache/IndexMetaDataCache.java
+++ b/src/main/java/org/apache/phoenix/cache/IndexMetaDataCache.java
@@ -1,3 +1,20 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT 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 org.apache.phoenix.cache;
 
 import java.io.Closeable;

http://git-wip-us.apache.org/repos/asf/incubator-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/cache/ServerCacheClient.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/cache/ServerCacheClient.java b/src/main/java/org/apache/phoenix/cache/ServerCacheClient.java
index ecf02c7..a902cac 100644
--- a/src/main/java/org/apache/phoenix/cache/ServerCacheClient.java
+++ b/src/main/java/org/apache/phoenix/cache/ServerCacheClient.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/cache/TenantCache.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/cache/TenantCache.java b/src/main/java/org/apache/phoenix/cache/TenantCache.java
index b854f88..9ab6c29 100644
--- a/src/main/java/org/apache/phoenix/cache/TenantCache.java
+++ b/src/main/java/org/apache/phoenix/cache/TenantCache.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/cache/TenantCacheImpl.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/cache/TenantCacheImpl.java b/src/main/java/org/apache/phoenix/cache/TenantCacheImpl.java
index a8f6374..ac1f9e5 100644
--- a/src/main/java/org/apache/phoenix/cache/TenantCacheImpl.java
+++ b/src/main/java/org/apache/phoenix/cache/TenantCacheImpl.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/compile/AggregationManager.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/compile/AggregationManager.java b/src/main/java/org/apache/phoenix/compile/AggregationManager.java
index c37dd24..1c88485 100644
--- a/src/main/java/org/apache/phoenix/compile/AggregationManager.java
+++ b/src/main/java/org/apache/phoenix/compile/AggregationManager.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/compile/BindManager.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/compile/BindManager.java b/src/main/java/org/apache/phoenix/compile/BindManager.java
index 2bcad2c..e205be5 100644
--- a/src/main/java/org/apache/phoenix/compile/BindManager.java
+++ b/src/main/java/org/apache/phoenix/compile/BindManager.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/compile/ColumnProjector.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/compile/ColumnProjector.java b/src/main/java/org/apache/phoenix/compile/ColumnProjector.java
index daef3cf..de632b3 100644
--- a/src/main/java/org/apache/phoenix/compile/ColumnProjector.java
+++ b/src/main/java/org/apache/phoenix/compile/ColumnProjector.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/compile/ColumnResolver.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/compile/ColumnResolver.java b/src/main/java/org/apache/phoenix/compile/ColumnResolver.java
index 6c8abe7..b61a872 100644
--- a/src/main/java/org/apache/phoenix/compile/ColumnResolver.java
+++ b/src/main/java/org/apache/phoenix/compile/ColumnResolver.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/compile/CreateIndexCompiler.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/compile/CreateIndexCompiler.java b/src/main/java/org/apache/phoenix/compile/CreateIndexCompiler.java
index b4fe490..38011de 100644
--- a/src/main/java/org/apache/phoenix/compile/CreateIndexCompiler.java
+++ b/src/main/java/org/apache/phoenix/compile/CreateIndexCompiler.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/compile/CreateTableCompiler.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/compile/CreateTableCompiler.java b/src/main/java/org/apache/phoenix/compile/CreateTableCompiler.java
index de35be5..24fb03e 100644
--- a/src/main/java/org/apache/phoenix/compile/CreateTableCompiler.java
+++ b/src/main/java/org/apache/phoenix/compile/CreateTableCompiler.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/compile/DeleteCompiler.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/compile/DeleteCompiler.java b/src/main/java/org/apache/phoenix/compile/DeleteCompiler.java
index 1d83fc1..1fa6ef7 100644
--- a/src/main/java/org/apache/phoenix/compile/DeleteCompiler.java
+++ b/src/main/java/org/apache/phoenix/compile/DeleteCompiler.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/compile/ExplainPlan.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/compile/ExplainPlan.java b/src/main/java/org/apache/phoenix/compile/ExplainPlan.java
index dc6261d..2bc7809 100644
--- a/src/main/java/org/apache/phoenix/compile/ExplainPlan.java
+++ b/src/main/java/org/apache/phoenix/compile/ExplainPlan.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/compile/ExpressionCompiler.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/compile/ExpressionCompiler.java b/src/main/java/org/apache/phoenix/compile/ExpressionCompiler.java
index 70b1b4b..05d2e58 100644
--- a/src/main/java/org/apache/phoenix/compile/ExpressionCompiler.java
+++ b/src/main/java/org/apache/phoenix/compile/ExpressionCompiler.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/compile/ExpressionManager.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/compile/ExpressionManager.java b/src/main/java/org/apache/phoenix/compile/ExpressionManager.java
index 77d617d..224f168 100644
--- a/src/main/java/org/apache/phoenix/compile/ExpressionManager.java
+++ b/src/main/java/org/apache/phoenix/compile/ExpressionManager.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/compile/ExpressionProjector.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/compile/ExpressionProjector.java b/src/main/java/org/apache/phoenix/compile/ExpressionProjector.java
index aab13e2..a8d061d 100644
--- a/src/main/java/org/apache/phoenix/compile/ExpressionProjector.java
+++ b/src/main/java/org/apache/phoenix/compile/ExpressionProjector.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/compile/FromCompiler.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/compile/FromCompiler.java b/src/main/java/org/apache/phoenix/compile/FromCompiler.java
index 6d6d736..eb1e6cd 100644
--- a/src/main/java/org/apache/phoenix/compile/FromCompiler.java
+++ b/src/main/java/org/apache/phoenix/compile/FromCompiler.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/compile/GroupByCompiler.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/compile/GroupByCompiler.java b/src/main/java/org/apache/phoenix/compile/GroupByCompiler.java
index 1932653..8a1bef6 100644
--- a/src/main/java/org/apache/phoenix/compile/GroupByCompiler.java
+++ b/src/main/java/org/apache/phoenix/compile/GroupByCompiler.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/compile/HavingCompiler.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/compile/HavingCompiler.java b/src/main/java/org/apache/phoenix/compile/HavingCompiler.java
index d9413cd..e7e5960 100644
--- a/src/main/java/org/apache/phoenix/compile/HavingCompiler.java
+++ b/src/main/java/org/apache/phoenix/compile/HavingCompiler.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/compile/IndexStatementRewriter.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/compile/IndexStatementRewriter.java b/src/main/java/org/apache/phoenix/compile/IndexStatementRewriter.java
index d0fab83..3900336 100644
--- a/src/main/java/org/apache/phoenix/compile/IndexStatementRewriter.java
+++ b/src/main/java/org/apache/phoenix/compile/IndexStatementRewriter.java
@@ -1,3 +1,20 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT 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 org.apache.phoenix.compile;
 
 import java.sql.SQLException;

http://git-wip-us.apache.org/repos/asf/incubator-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/compile/KeyPart.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/compile/KeyPart.java b/src/main/java/org/apache/phoenix/compile/KeyPart.java
index d584417..4eb53d3 100644
--- a/src/main/java/org/apache/phoenix/compile/KeyPart.java
+++ b/src/main/java/org/apache/phoenix/compile/KeyPart.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/compile/LimitCompiler.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/compile/LimitCompiler.java b/src/main/java/org/apache/phoenix/compile/LimitCompiler.java
index 732128d..ae3b4e9 100644
--- a/src/main/java/org/apache/phoenix/compile/LimitCompiler.java
+++ b/src/main/java/org/apache/phoenix/compile/LimitCompiler.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/compile/MutatingParallelIteratorFactory.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/compile/MutatingParallelIteratorFactory.java b/src/main/java/org/apache/phoenix/compile/MutatingParallelIteratorFactory.java
index 7befaaa..ad14a8d 100644
--- a/src/main/java/org/apache/phoenix/compile/MutatingParallelIteratorFactory.java
+++ b/src/main/java/org/apache/phoenix/compile/MutatingParallelIteratorFactory.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/compile/MutationPlan.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/compile/MutationPlan.java b/src/main/java/org/apache/phoenix/compile/MutationPlan.java
index 267dd1c..277b5a2 100644
--- a/src/main/java/org/apache/phoenix/compile/MutationPlan.java
+++ b/src/main/java/org/apache/phoenix/compile/MutationPlan.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/compile/OrderByCompiler.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/compile/OrderByCompiler.java b/src/main/java/org/apache/phoenix/compile/OrderByCompiler.java
index 25cbe15..f9240ed 100644
--- a/src/main/java/org/apache/phoenix/compile/OrderByCompiler.java
+++ b/src/main/java/org/apache/phoenix/compile/OrderByCompiler.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/compile/PostDDLCompiler.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/compile/PostDDLCompiler.java b/src/main/java/org/apache/phoenix/compile/PostDDLCompiler.java
index bc1d746..384ec6a 100644
--- a/src/main/java/org/apache/phoenix/compile/PostDDLCompiler.java
+++ b/src/main/java/org/apache/phoenix/compile/PostDDLCompiler.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/compile/PostIndexDDLCompiler.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/compile/PostIndexDDLCompiler.java b/src/main/java/org/apache/phoenix/compile/PostIndexDDLCompiler.java
index 08dbdb3..d337fc5 100644
--- a/src/main/java/org/apache/phoenix/compile/PostIndexDDLCompiler.java
+++ b/src/main/java/org/apache/phoenix/compile/PostIndexDDLCompiler.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/compile/ProjectionCompiler.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/compile/ProjectionCompiler.java b/src/main/java/org/apache/phoenix/compile/ProjectionCompiler.java
index 59ee842..85ea559 100644
--- a/src/main/java/org/apache/phoenix/compile/ProjectionCompiler.java
+++ b/src/main/java/org/apache/phoenix/compile/ProjectionCompiler.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/compile/QueryCompiler.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/compile/QueryCompiler.java b/src/main/java/org/apache/phoenix/compile/QueryCompiler.java
index 0d90b90..8d86798 100644
--- a/src/main/java/org/apache/phoenix/compile/QueryCompiler.java
+++ b/src/main/java/org/apache/phoenix/compile/QueryCompiler.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/compile/QueryPlan.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/compile/QueryPlan.java b/src/main/java/org/apache/phoenix/compile/QueryPlan.java
index 359db42..21ba69e 100644
--- a/src/main/java/org/apache/phoenix/compile/QueryPlan.java
+++ b/src/main/java/org/apache/phoenix/compile/QueryPlan.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/compile/RowProjector.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/compile/RowProjector.java b/src/main/java/org/apache/phoenix/compile/RowProjector.java
index 46a2af6..288c78b 100644
--- a/src/main/java/org/apache/phoenix/compile/RowProjector.java
+++ b/src/main/java/org/apache/phoenix/compile/RowProjector.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/compile/ScanRanges.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/compile/ScanRanges.java b/src/main/java/org/apache/phoenix/compile/ScanRanges.java
index ce4bbab..4245a97 100644
--- a/src/main/java/org/apache/phoenix/compile/ScanRanges.java
+++ b/src/main/java/org/apache/phoenix/compile/ScanRanges.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/compile/StatementContext.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/compile/StatementContext.java b/src/main/java/org/apache/phoenix/compile/StatementContext.java
index 1fa6d5a..0500482 100644
--- a/src/main/java/org/apache/phoenix/compile/StatementContext.java
+++ b/src/main/java/org/apache/phoenix/compile/StatementContext.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/compile/StatementNormalizer.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/compile/StatementNormalizer.java b/src/main/java/org/apache/phoenix/compile/StatementNormalizer.java
index 57d5d03..dba01d5 100644
--- a/src/main/java/org/apache/phoenix/compile/StatementNormalizer.java
+++ b/src/main/java/org/apache/phoenix/compile/StatementNormalizer.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/compile/StatementPlan.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/compile/StatementPlan.java b/src/main/java/org/apache/phoenix/compile/StatementPlan.java
index 52b1116..cccc9e6 100644
--- a/src/main/java/org/apache/phoenix/compile/StatementPlan.java
+++ b/src/main/java/org/apache/phoenix/compile/StatementPlan.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/compile/TrackOrderPreservingExpressionCompiler.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/compile/TrackOrderPreservingExpressionCompiler.java b/src/main/java/org/apache/phoenix/compile/TrackOrderPreservingExpressionCompiler.java
index 8a7a221..0dbc350 100644
--- a/src/main/java/org/apache/phoenix/compile/TrackOrderPreservingExpressionCompiler.java
+++ b/src/main/java/org/apache/phoenix/compile/TrackOrderPreservingExpressionCompiler.java
@@ -1,3 +1,20 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT 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 org.apache.phoenix.compile;
 
 import java.sql.SQLException;

http://git-wip-us.apache.org/repos/asf/incubator-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/compile/UpsertCompiler.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/compile/UpsertCompiler.java b/src/main/java/org/apache/phoenix/compile/UpsertCompiler.java
index 052807e..118595d 100644
--- a/src/main/java/org/apache/phoenix/compile/UpsertCompiler.java
+++ b/src/main/java/org/apache/phoenix/compile/UpsertCompiler.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/compile/WhereCompiler.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/compile/WhereCompiler.java b/src/main/java/org/apache/phoenix/compile/WhereCompiler.java
index 11713af..77c6381 100644
--- a/src/main/java/org/apache/phoenix/compile/WhereCompiler.java
+++ b/src/main/java/org/apache/phoenix/compile/WhereCompiler.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/compile/WhereOptimizer.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/compile/WhereOptimizer.java b/src/main/java/org/apache/phoenix/compile/WhereOptimizer.java
index a29bbc8..7b3d827 100644
--- a/src/main/java/org/apache/phoenix/compile/WhereOptimizer.java
+++ b/src/main/java/org/apache/phoenix/compile/WhereOptimizer.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/coprocessor/BaseRegionScanner.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/coprocessor/BaseRegionScanner.java b/src/main/java/org/apache/phoenix/coprocessor/BaseRegionScanner.java
index 2e12021..ee35526 100644
--- a/src/main/java/org/apache/phoenix/coprocessor/BaseRegionScanner.java
+++ b/src/main/java/org/apache/phoenix/coprocessor/BaseRegionScanner.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/coprocessor/BaseScannerRegionObserver.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/coprocessor/BaseScannerRegionObserver.java b/src/main/java/org/apache/phoenix/coprocessor/BaseScannerRegionObserver.java
index 9c8b941..01589fc 100644
--- a/src/main/java/org/apache/phoenix/coprocessor/BaseScannerRegionObserver.java
+++ b/src/main/java/org/apache/phoenix/coprocessor/BaseScannerRegionObserver.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/coprocessor/GroupedAggregateRegionObserver.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/coprocessor/GroupedAggregateRegionObserver.java b/src/main/java/org/apache/phoenix/coprocessor/GroupedAggregateRegionObserver.java
index 169d894..3201bc4 100644
--- a/src/main/java/org/apache/phoenix/coprocessor/GroupedAggregateRegionObserver.java
+++ b/src/main/java/org/apache/phoenix/coprocessor/GroupedAggregateRegionObserver.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/coprocessor/HashJoinRegionScanner.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/coprocessor/HashJoinRegionScanner.java b/src/main/java/org/apache/phoenix/coprocessor/HashJoinRegionScanner.java
index 49480e7..6bfd437 100644
--- a/src/main/java/org/apache/phoenix/coprocessor/HashJoinRegionScanner.java
+++ b/src/main/java/org/apache/phoenix/coprocessor/HashJoinRegionScanner.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/coprocessor/MetaDataEndpointImpl.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/coprocessor/MetaDataEndpointImpl.java b/src/main/java/org/apache/phoenix/coprocessor/MetaDataEndpointImpl.java
index 7129378..4f33ad4 100644
--- a/src/main/java/org/apache/phoenix/coprocessor/MetaDataEndpointImpl.java
+++ b/src/main/java/org/apache/phoenix/coprocessor/MetaDataEndpointImpl.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/coprocessor/MetaDataProtocol.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/coprocessor/MetaDataProtocol.java b/src/main/java/org/apache/phoenix/coprocessor/MetaDataProtocol.java
index b259865..4e29698 100644
--- a/src/main/java/org/apache/phoenix/coprocessor/MetaDataProtocol.java
+++ b/src/main/java/org/apache/phoenix/coprocessor/MetaDataProtocol.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/coprocessor/MetaDataRegionObserver.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/coprocessor/MetaDataRegionObserver.java b/src/main/java/org/apache/phoenix/coprocessor/MetaDataRegionObserver.java
index aa3bde3..e60a6a1 100644
--- a/src/main/java/org/apache/phoenix/coprocessor/MetaDataRegionObserver.java
+++ b/src/main/java/org/apache/phoenix/coprocessor/MetaDataRegionObserver.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/coprocessor/ScanProjector.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/coprocessor/ScanProjector.java b/src/main/java/org/apache/phoenix/coprocessor/ScanProjector.java
index 95bf828..d994b39 100644
--- a/src/main/java/org/apache/phoenix/coprocessor/ScanProjector.java
+++ b/src/main/java/org/apache/phoenix/coprocessor/ScanProjector.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/coprocessor/ScanRegionObserver.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/coprocessor/ScanRegionObserver.java b/src/main/java/org/apache/phoenix/coprocessor/ScanRegionObserver.java
index a79da7d..a42aaaf 100644
--- a/src/main/java/org/apache/phoenix/coprocessor/ScanRegionObserver.java
+++ b/src/main/java/org/apache/phoenix/coprocessor/ScanRegionObserver.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/coprocessor/ServerCachingEndpointImpl.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/coprocessor/ServerCachingEndpointImpl.java b/src/main/java/org/apache/phoenix/coprocessor/ServerCachingEndpointImpl.java
index 50abad4..4a17996 100644
--- a/src/main/java/org/apache/phoenix/coprocessor/ServerCachingEndpointImpl.java
+++ b/src/main/java/org/apache/phoenix/coprocessor/ServerCachingEndpointImpl.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/coprocessor/ServerCachingProtocol.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/coprocessor/ServerCachingProtocol.java b/src/main/java/org/apache/phoenix/coprocessor/ServerCachingProtocol.java
index 3c6123d..b957258 100644
--- a/src/main/java/org/apache/phoenix/coprocessor/ServerCachingProtocol.java
+++ b/src/main/java/org/apache/phoenix/coprocessor/ServerCachingProtocol.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/coprocessor/UngroupedAggregateRegionObserver.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/coprocessor/UngroupedAggregateRegionObserver.java b/src/main/java/org/apache/phoenix/coprocessor/UngroupedAggregateRegionObserver.java
index 4d95b14..dce3dc5 100644
--- a/src/main/java/org/apache/phoenix/coprocessor/UngroupedAggregateRegionObserver.java
+++ b/src/main/java/org/apache/phoenix/coprocessor/UngroupedAggregateRegionObserver.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/exception/PhoenixIOException.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/exception/PhoenixIOException.java b/src/main/java/org/apache/phoenix/exception/PhoenixIOException.java
index dfbdce5..a277a20 100644
--- a/src/main/java/org/apache/phoenix/exception/PhoenixIOException.java
+++ b/src/main/java/org/apache/phoenix/exception/PhoenixIOException.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/exception/PhoenixParserException.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/exception/PhoenixParserException.java b/src/main/java/org/apache/phoenix/exception/PhoenixParserException.java
index 8b8e4e0..b24871c 100644
--- a/src/main/java/org/apache/phoenix/exception/PhoenixParserException.java
+++ b/src/main/java/org/apache/phoenix/exception/PhoenixParserException.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/exception/SQLExceptionCode.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/exception/SQLExceptionCode.java b/src/main/java/org/apache/phoenix/exception/SQLExceptionCode.java
index 16478fa..35c9860 100644
--- a/src/main/java/org/apache/phoenix/exception/SQLExceptionCode.java
+++ b/src/main/java/org/apache/phoenix/exception/SQLExceptionCode.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/exception/SQLExceptionInfo.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/exception/SQLExceptionInfo.java b/src/main/java/org/apache/phoenix/exception/SQLExceptionInfo.java
index 694cd05..9b80400 100644
--- a/src/main/java/org/apache/phoenix/exception/SQLExceptionInfo.java
+++ b/src/main/java/org/apache/phoenix/exception/SQLExceptionInfo.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/exception/UnknownFunctionException.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/exception/UnknownFunctionException.java b/src/main/java/org/apache/phoenix/exception/UnknownFunctionException.java
index eda2cd5..4fc4b9b 100644
--- a/src/main/java/org/apache/phoenix/exception/UnknownFunctionException.java
+++ b/src/main/java/org/apache/phoenix/exception/UnknownFunctionException.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/exception/ValueTypeIncompatibleException.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/exception/ValueTypeIncompatibleException.java b/src/main/java/org/apache/phoenix/exception/ValueTypeIncompatibleException.java
index 9b93d74..3f2be50 100644
--- a/src/main/java/org/apache/phoenix/exception/ValueTypeIncompatibleException.java
+++ b/src/main/java/org/apache/phoenix/exception/ValueTypeIncompatibleException.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/execute/AggregatePlan.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/execute/AggregatePlan.java b/src/main/java/org/apache/phoenix/execute/AggregatePlan.java
index 135c767..8922507 100644
--- a/src/main/java/org/apache/phoenix/execute/AggregatePlan.java
+++ b/src/main/java/org/apache/phoenix/execute/AggregatePlan.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/execute/BasicQueryPlan.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/execute/BasicQueryPlan.java b/src/main/java/org/apache/phoenix/execute/BasicQueryPlan.java
index 1944d3d..d637720 100644
--- a/src/main/java/org/apache/phoenix/execute/BasicQueryPlan.java
+++ b/src/main/java/org/apache/phoenix/execute/BasicQueryPlan.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/execute/CommitException.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/execute/CommitException.java b/src/main/java/org/apache/phoenix/execute/CommitException.java
index 4563e22..63bf6a1 100644
--- a/src/main/java/org/apache/phoenix/execute/CommitException.java
+++ b/src/main/java/org/apache/phoenix/execute/CommitException.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/execute/DegenerateQueryPlan.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/execute/DegenerateQueryPlan.java b/src/main/java/org/apache/phoenix/execute/DegenerateQueryPlan.java
index 80467a0..1ebd150 100644
--- a/src/main/java/org/apache/phoenix/execute/DegenerateQueryPlan.java
+++ b/src/main/java/org/apache/phoenix/execute/DegenerateQueryPlan.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/execute/MutationState.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/execute/MutationState.java b/src/main/java/org/apache/phoenix/execute/MutationState.java
index d48c6e6..af5550b 100644
--- a/src/main/java/org/apache/phoenix/execute/MutationState.java
+++ b/src/main/java/org/apache/phoenix/execute/MutationState.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/execute/ScanPlan.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/execute/ScanPlan.java b/src/main/java/org/apache/phoenix/execute/ScanPlan.java
index 2878aa0..349c445 100644
--- a/src/main/java/org/apache/phoenix/execute/ScanPlan.java
+++ b/src/main/java/org/apache/phoenix/execute/ScanPlan.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/expression/AddExpression.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/expression/AddExpression.java b/src/main/java/org/apache/phoenix/expression/AddExpression.java
index 02229d3..247b86c 100644
--- a/src/main/java/org/apache/phoenix/expression/AddExpression.java
+++ b/src/main/java/org/apache/phoenix/expression/AddExpression.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/expression/AndExpression.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/expression/AndExpression.java b/src/main/java/org/apache/phoenix/expression/AndExpression.java
index 8318406..aa94b8e 100644
--- a/src/main/java/org/apache/phoenix/expression/AndExpression.java
+++ b/src/main/java/org/apache/phoenix/expression/AndExpression.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/expression/AndOrExpression.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/expression/AndOrExpression.java b/src/main/java/org/apache/phoenix/expression/AndOrExpression.java
index d3b4d31..eebcd34 100644
--- a/src/main/java/org/apache/phoenix/expression/AndOrExpression.java
+++ b/src/main/java/org/apache/phoenix/expression/AndOrExpression.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/expression/ArithmeticExpression.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/expression/ArithmeticExpression.java b/src/main/java/org/apache/phoenix/expression/ArithmeticExpression.java
index ae21131..5128d07 100644
--- a/src/main/java/org/apache/phoenix/expression/ArithmeticExpression.java
+++ b/src/main/java/org/apache/phoenix/expression/ArithmeticExpression.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/expression/BaseAddSubtractExpression.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/expression/BaseAddSubtractExpression.java b/src/main/java/org/apache/phoenix/expression/BaseAddSubtractExpression.java
index bad6f76..e3fcc9e 100644
--- a/src/main/java/org/apache/phoenix/expression/BaseAddSubtractExpression.java
+++ b/src/main/java/org/apache/phoenix/expression/BaseAddSubtractExpression.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/expression/BaseCompoundExpression.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/expression/BaseCompoundExpression.java b/src/main/java/org/apache/phoenix/expression/BaseCompoundExpression.java
index ca16979..b9c54bc 100644
--- a/src/main/java/org/apache/phoenix/expression/BaseCompoundExpression.java
+++ b/src/main/java/org/apache/phoenix/expression/BaseCompoundExpression.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/expression/BaseDecimalAddSubtractExpression.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/expression/BaseDecimalAddSubtractExpression.java b/src/main/java/org/apache/phoenix/expression/BaseDecimalAddSubtractExpression.java
index 4f641fe..9a413f7 100644
--- a/src/main/java/org/apache/phoenix/expression/BaseDecimalAddSubtractExpression.java
+++ b/src/main/java/org/apache/phoenix/expression/BaseDecimalAddSubtractExpression.java
@@ -1,3 +1,20 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT 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 org.apache.phoenix.expression;
 
 public class BaseDecimalAddSubtractExpression {

http://git-wip-us.apache.org/repos/asf/incubator-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/expression/BaseExpression.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/expression/BaseExpression.java b/src/main/java/org/apache/phoenix/expression/BaseExpression.java
index 8158d8b..845e1b6 100644
--- a/src/main/java/org/apache/phoenix/expression/BaseExpression.java
+++ b/src/main/java/org/apache/phoenix/expression/BaseExpression.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/expression/BaseSingleExpression.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/expression/BaseSingleExpression.java b/src/main/java/org/apache/phoenix/expression/BaseSingleExpression.java
index 7d8c64e..77789fa 100644
--- a/src/main/java/org/apache/phoenix/expression/BaseSingleExpression.java
+++ b/src/main/java/org/apache/phoenix/expression/BaseSingleExpression.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/expression/BaseTerminalExpression.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/expression/BaseTerminalExpression.java b/src/main/java/org/apache/phoenix/expression/BaseTerminalExpression.java
index 0f46d26..8d0d336 100644
--- a/src/main/java/org/apache/phoenix/expression/BaseTerminalExpression.java
+++ b/src/main/java/org/apache/phoenix/expression/BaseTerminalExpression.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/expression/CaseExpression.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/expression/CaseExpression.java b/src/main/java/org/apache/phoenix/expression/CaseExpression.java
index 76be256..4b61432 100644
--- a/src/main/java/org/apache/phoenix/expression/CaseExpression.java
+++ b/src/main/java/org/apache/phoenix/expression/CaseExpression.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/expression/CeilingDecimalExpression.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/expression/CeilingDecimalExpression.java b/src/main/java/org/apache/phoenix/expression/CeilingDecimalExpression.java
index eeb1f72..a684a75 100644
--- a/src/main/java/org/apache/phoenix/expression/CeilingDecimalExpression.java
+++ b/src/main/java/org/apache/phoenix/expression/CeilingDecimalExpression.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/expression/CeilingTimestampExpression.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/expression/CeilingTimestampExpression.java b/src/main/java/org/apache/phoenix/expression/CeilingTimestampExpression.java
index cc63246..d0e0913 100644
--- a/src/main/java/org/apache/phoenix/expression/CeilingTimestampExpression.java
+++ b/src/main/java/org/apache/phoenix/expression/CeilingTimestampExpression.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed 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-phoenix/blob/18ddce87/src/main/java/org/apache/phoenix/expression/CoerceExpression.java
----------------------------------------------------------------------
diff --git a/src/main/java/org/apache/phoenix/expression/CoerceExpression.java b/src/main/java/org/apache/phoenix/expression/CoerceExpression.java
index 0e4c208..8609bb9 100644
--- a/src/main/java/org/apache/phoenix/expression/CoerceExpression.java
+++ b/src/main/java/org/apache/phoenix/expression/CoerceExpression.java
@@ -1,6 +1,4 @@
 /*
- * Copyright 2014 The Apache Software Foundation
- *
  * Licensed to the Apache Software Foundation (ASF) under one
  * or more contributor license agreements.  See the NOTICE file
  * distributed with this work for additional information