You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@tephra.apache.org by po...@apache.org on 2016/05/06 22:05:12 UTC

[6/6] incubator-tephra git commit: Update copyright

Update copyright


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

Branch: refs/heads/apache-update
Commit: a85b0135d8ea77e4b46b00b50456e4bb75b8ea18
Parents: 818d229
Author: poorna <po...@cask.co>
Authored: Fri May 6 15:04:51 2016 -0700
Committer: poorna <po...@cask.co>
Committed: Fri May 6 15:04:52 2016 -0700

----------------------------------------------------------------------
 .travis.yml                                     | 22 +++++----
 README.rst                                      | 24 +++++----
 bin/tephra                                      | 22 +++++----
 bin/tephra-env.sh                               | 22 +++++----
 checkstyle.xml                                  | 28 ++++++-----
 conf/logback.xml                                | 28 ++++++-----
 pom.xml                                         | 28 ++++++-----
 src/assemble/bin.xml                            | 28 ++++++-----
 suppressions.xml                                | 28 ++++++-----
 tephra-api/pom.xml                              | 28 ++++++-----
 .../main/java/co/cask/tephra/Transaction.java   | 22 +++++----
 .../java/co/cask/tephra/TransactionAware.java   | 22 +++++----
 .../java/co/cask/tephra/TransactionAwares.java  | 22 +++++----
 .../tephra/TransactionConflictException.java    | 22 +++++----
 .../tephra/TransactionFailureException.java     | 22 +++++----
 .../TransactionNotInProgressException.java      | 22 +++++----
 .../java/co/cask/tephra/TransactionType.java    | 22 +++++----
 tephra-core/pom.xml                             | 28 ++++++-----
 .../tephra/AbstractTransactionAwareTable.java   | 22 +++++----
 .../tephra/AbstractTransactionExecutor.java     | 22 +++++----
 .../src/main/java/co/cask/tephra/ChangeId.java  | 22 +++++----
 .../cask/tephra/DefaultTransactionExecutor.java | 22 +++++----
 .../tephra/InvalidTruncateTimeException.java    | 22 +++++----
 .../java/co/cask/tephra/NoRetryStrategy.java    | 22 +++++----
 .../co/cask/tephra/RetryOnConflictStrategy.java | 22 +++++----
 .../java/co/cask/tephra/RetryStrategies.java    | 22 +++++----
 .../main/java/co/cask/tephra/RetryStrategy.java | 22 +++++----
 .../java/co/cask/tephra/TransactionAdmin.java   | 22 +++++----
 .../java/co/cask/tephra/TransactionCodec.java   | 22 +++++----
 .../java/co/cask/tephra/TransactionContext.java | 22 +++++----
 ...ransactionCouldNotTakeSnapshotException.java | 22 +++++----
 .../co/cask/tephra/TransactionExecutor.java     | 22 +++++----
 .../cask/tephra/TransactionExecutorFactory.java | 22 +++++----
 .../java/co/cask/tephra/TransactionManager.java | 22 +++++----
 .../co/cask/tephra/TransactionServiceMain.java  | 22 +++++----
 .../co/cask/tephra/TransactionSystemClient.java | 22 +++++----
 .../main/java/co/cask/tephra/TxConstants.java   | 22 +++++----
 .../coprocessor/TransactionStateCache.java      | 22 +++++----
 .../TransactionStateCacheSupplier.java          | 22 +++++----
 .../cask/tephra/coprocessor/package-info.java   | 22 +++++----
 .../distributed/AbstractClientProvider.java     | 22 +++++----
 .../distributed/CloseableThriftClient.java      | 22 +++++----
 .../co/cask/tephra/distributed/ElasticPool.java | 22 +++++----
 .../distributed/PooledClientProvider.java       | 22 +++++----
 .../co/cask/tephra/distributed/RetryNTimes.java | 22 +++++----
 .../cask/tephra/distributed/RetryStrategy.java  | 22 +++++----
 .../distributed/RetryStrategyProvider.java      | 22 +++++----
 .../tephra/distributed/RetryWithBackoff.java    | 22 +++++----
 .../distributed/SingleUseClientProvider.java    | 22 +++++----
 .../distributed/ThreadLocalClientProvider.java  | 22 +++++----
 .../distributed/ThriftClientProvider.java       | 22 +++++----
 .../distributed/TransactionConverterUtils.java  | 22 +++++----
 .../tephra/distributed/TransactionService.java  | 22 +++++----
 .../distributed/TransactionServiceClient.java   | 25 +++++-----
 .../TransactionServiceThriftClient.java         | 22 +++++----
 .../TransactionServiceThriftHandler.java        | 22 +++++----
 .../cask/tephra/distributed/package-info.java   | 22 +++++----
 .../tephra/distributed/thrift/TBoolean.java     | 22 +++++----
 .../thrift/TInvalidTruncateTimeException.java   | 46 ++++++++----------
 .../tephra/distributed/thrift/TTransaction.java | 46 ++++++++----------
 ...ransactionCouldNotTakeSnapshotException.java | 22 +++++----
 .../TTransactionNotInProgressException.java     | 22 +++++----
 .../distributed/thrift/TTransactionServer.java  | 51 +++++++++-----------
 .../distributed/thrift/TTransactionType.java    | 22 +++++----
 .../distributed/thrift/TVisibilityLevel.java    | 22 +++++----
 .../tephra/inmemory/DetachedTxSystemClient.java | 22 +++++----
 .../inmemory/InMemoryTransactionService.java    | 22 +++++----
 .../tephra/inmemory/InMemoryTxSystemClient.java | 22 +++++----
 .../tephra/inmemory/MinimalTxSystemClient.java  | 22 +++++----
 .../co/cask/tephra/inmemory/package-info.java   | 22 +++++----
 .../tephra/metrics/DefaultMetricsCollector.java | 24 ++++-----
 .../cask/tephra/metrics/MetricsCollector.java   | 22 +++++----
 .../cask/tephra/metrics/TxMetricsCollector.java | 22 +++++----
 .../main/java/co/cask/tephra/package-info.java  | 22 +++++----
 .../tephra/persist/AbstractTransactionLog.java  | 22 +++++----
 .../AbstractTransactionStateStorage.java        | 22 +++++----
 .../cask/tephra/persist/CommitMarkerCodec.java  | 22 +++++----
 .../cask/tephra/persist/HDFSTransactionLog.java | 22 +++++----
 .../HDFSTransactionLogReaderSupplier.java       | 22 +++++----
 .../persist/HDFSTransactionLogReaderV1.java     | 22 +++++----
 .../persist/HDFSTransactionLogReaderV2.java     | 22 +++++----
 .../persist/HDFSTransactionStateStorage.java    | 22 +++++----
 .../tephra/persist/LocalFileTransactionLog.java | 22 +++++----
 .../LocalFileTransactionStateStorage.java       | 22 +++++----
 .../persist/NoOpTransactionStateStorage.java    | 22 +++++----
 .../co/cask/tephra/persist/TransactionEdit.java | 22 +++++----
 .../tephra/persist/TransactionEditCodecs.java   | 22 +++++----
 .../co/cask/tephra/persist/TransactionLog.java  | 22 +++++----
 .../tephra/persist/TransactionLogReader.java    | 22 +++++----
 .../tephra/persist/TransactionLogWriter.java    | 22 +++++----
 .../tephra/persist/TransactionSnapshot.java     | 22 +++++----
 .../tephra/persist/TransactionStateStorage.java | 22 +++++----
 .../persist/TransactionVisibilityState.java     | 22 +++++----
 .../co/cask/tephra/persist/package-info.java    | 22 +++++----
 .../co/cask/tephra/rpc/RPCServiceHandler.java   | 22 +++++----
 .../co/cask/tephra/rpc/ThriftRPCServer.java     | 22 +++++----
 .../java/co/cask/tephra/rpc/package-info.java   | 22 +++++----
 .../co/cask/tephra/runtime/ConfigModule.java    | 22 +++++----
 .../cask/tephra/runtime/DiscoveryModules.java   | 22 +++++----
 .../tephra/runtime/TransactionClientModule.java | 22 +++++----
 .../runtime/TransactionDistributedModule.java   | 22 +++++----
 .../runtime/TransactionInMemoryModule.java      | 22 +++++----
 .../tephra/runtime/TransactionLocalModule.java  | 23 ++++-----
 .../cask/tephra/runtime/TransactionModules.java | 22 +++++----
 .../TransactionStateStorageProvider.java        | 22 +++++----
 .../java/co/cask/tephra/runtime/ZKModule.java   | 22 +++++----
 .../co/cask/tephra/snapshot/BinaryDecoder.java  | 22 +++++----
 .../co/cask/tephra/snapshot/BinaryEncoder.java  | 22 +++++----
 .../tephra/snapshot/DefaultSnapshotCodec.java   | 22 +++++----
 .../co/cask/tephra/snapshot/SnapshotCodec.java  | 22 +++++----
 .../tephra/snapshot/SnapshotCodecProvider.java  | 22 +++++----
 .../cask/tephra/snapshot/SnapshotCodecV2.java   | 22 +++++----
 .../cask/tephra/snapshot/SnapshotCodecV3.java   | 22 +++++----
 .../cask/tephra/snapshot/SnapshotCodecV4.java   | 22 +++++----
 .../co/cask/tephra/snapshot/package-info.java   | 22 +++++----
 .../cask/tephra/util/ConfigurationFactory.java  | 22 +++++----
 .../cask/tephra/util/ConfigurationProvider.java | 22 +++++----
 .../java/co/cask/tephra/util/HBaseVersion.java  | 22 +++++----
 .../util/HBaseVersionSpecificFactory.java       | 22 +++++----
 .../main/java/co/cask/tephra/util/TxUtils.java  | 22 +++++----
 .../tephra/visibility/DefaultFenceWait.java     | 22 +++++----
 .../co/cask/tephra/visibility/FenceWait.java    | 22 +++++----
 .../co/cask/tephra/visibility/ReadFence.java    | 22 +++++----
 .../cask/tephra/visibility/VisibilityFence.java | 22 +++++----
 .../co/cask/tephra/visibility/WriteFence.java   | 22 +++++----
 .../co/cask/tephra/zookeeper/BasicACLData.java  | 22 +++++----
 .../tephra/zookeeper/BasicNodeChildren.java     | 22 +++++----
 .../co/cask/tephra/zookeeper/BasicNodeData.java | 22 +++++----
 .../tephra/zookeeper/TephraZKClientService.java | 22 +++++----
 .../server/TThreadedSelectorServerWithFix.java  | 22 +++++----
 tephra-core/src/main/thrift/README              | 22 +++++----
 tephra-core/src/main/thrift/transaction.thrift  | 22 +++++----
 .../tephra/ThriftTransactionSystemTest.java     | 26 +++++-----
 .../co/cask/tephra/TransactionAdminTest.java    | 26 +++++-----
 .../co/cask/tephra/TransactionContextTest.java  | 22 +++++----
 .../co/cask/tephra/TransactionExecutorTest.java | 22 +++++----
 .../co/cask/tephra/TransactionManagerTest.java  | 22 +++++----
 .../cask/tephra/TransactionServiceMainTest.java | 22 +++++----
 .../co/cask/tephra/TransactionSystemTest.java   | 22 +++++----
 .../java/co/cask/tephra/TransactionTest.java    | 22 +++++----
 .../tephra/distributed/ElasticPoolTest.java     | 22 +++++----
 .../distributed/PooledClientProviderTest.java   | 22 +++++----
 .../ThriftTransactionServerTest.java            | 22 +++++----
 ...AbstractTransactionVisibilityFilterTest.java | 22 +++++----
 .../AbstractTransactionStateStorageTest.java    | 22 +++++----
 .../tephra/persist/CommitMarkerCodecTest.java   | 22 +++++----
 .../tephra/persist/HDFSTransactionLogTest.java  | 22 +++++----
 .../HDFSTransactionStateStorageTest.java        | 22 +++++----
 .../InMemoryTransactionStateStorage.java        | 22 +++++----
 .../LocalTransactionStateStorageTest.java       | 22 +++++----
 .../tephra/persist/TransactionEditTest.java     | 22 +++++----
 .../cask/tephra/snapshot/SnapshotCodecTest.java | 22 +++++----
 .../util/AbstractConfigurationProviderTest.java | 22 +++++----
 .../co/cask/tephra/util/HBaseVersionTest.java   | 22 +++++----
 .../cask/tephra/util/TransactionEditUtil.java   | 22 +++++----
 .../java/co/cask/tephra/util/TxUtilsTest.java   | 22 +++++----
 .../tephra/visibility/VisibilityFenceTest.java  | 22 +++++----
 tephra-distribution/pom.xml                     | 28 ++++++-----
 tephra-examples/pom.xml                         | 28 ++++++-----
 .../co/cask/tephra/examples/BalanceBooks.java   | 22 +++++----
 .../co/cask/tephra/examples/package-info.java   | 22 +++++----
 .../cask/tephra/examples/BalanceBooksTest.java  | 22 +++++----
 tephra-hbase-compat-0.96/pom.xml                | 28 ++++++-----
 .../hbase96/HBase96ConfigurationProvider.java   | 22 +++++----
 .../tephra/hbase96/SecondaryIndexTable.java     | 22 +++++----
 .../tephra/hbase96/TransactionAwareHTable.java  | 22 +++++----
 .../hbase96/coprocessor/CellSkipFilter.java     | 22 +++++----
 .../hbase96/coprocessor/TransactionFilters.java | 22 +++++----
 .../coprocessor/TransactionProcessor.java       | 22 +++++----
 .../TransactionVisibilityFilter.java            | 22 +++++----
 .../HBase96ConfigurationProviderTest.java       | 22 +++++----
 .../hbase96/TransactionAwareHTableTest.java     | 22 +++++----
 .../hbase96/coprocessor/CellSkipFilterTest.java | 22 +++++----
 .../coprocessor/TransactionProcessorTest.java   | 22 +++++----
 .../TransactionVisibilityFilterTest.java        | 23 ++++-----
 tephra-hbase-compat-0.98/pom.xml                | 28 ++++++-----
 .../hbase98/HBase98ConfigurationProvider.java   | 22 +++++----
 .../tephra/hbase98/SecondaryIndexTable.java     | 22 +++++----
 .../tephra/hbase98/TransactionAwareHTable.java  | 22 +++++----
 .../hbase98/coprocessor/CellSkipFilter.java     | 22 +++++----
 .../hbase98/coprocessor/TransactionFilters.java | 22 +++++----
 .../coprocessor/TransactionProcessor.java       | 22 +++++----
 .../TransactionVisibilityFilter.java            | 22 +++++----
 .../HBase98ConfigurationProviderTest.java       | 22 +++++----
 .../hbase98/TransactionAwareHTableTest.java     | 22 +++++----
 .../hbase98/coprocessor/CellSkipFilterTest.java | 22 +++++----
 .../coprocessor/TransactionProcessorTest.java   | 22 +++++----
 .../TransactionVisibilityFilterTest.java        | 22 +++++----
 tephra-hbase-compat-1.0-cdh/pom.xml             | 28 ++++++-----
 .../HBase10ConfigurationProvider.java           | 22 +++++----
 .../tephra/hbase10cdh/SecondaryIndexTable.java  | 22 +++++----
 .../hbase10cdh/TransactionAwareHTable.java      | 22 +++++----
 .../hbase10cdh/coprocessor/CellSkipFilter.java  | 22 +++++----
 .../coprocessor/TransactionFilters.java         | 22 +++++----
 .../coprocessor/TransactionProcessor.java       | 22 +++++----
 .../TransactionVisibilityFilter.java            | 22 +++++----
 .../HBase10ConfigurationProviderTest.java       | 22 +++++----
 .../hbase10cdh/TransactionAwareHTableTest.java  | 22 +++++----
 .../coprocessor/CellSkipFilterTest.java         | 22 +++++----
 .../coprocessor/TransactionProcessorTest.java   | 22 +++++----
 .../TransactionVisibilityFilterTest.java        | 23 ++++-----
 tephra-hbase-compat-1.0/pom.xml                 | 28 ++++++-----
 .../hbase10/HBase10ConfigurationProvider.java   | 22 +++++----
 .../tephra/hbase10/SecondaryIndexTable.java     | 22 +++++----
 .../tephra/hbase10/TransactionAwareHTable.java  | 22 +++++----
 .../hbase10/coprocessor/CellSkipFilter.java     | 22 +++++----
 .../hbase10/coprocessor/TransactionFilters.java | 22 +++++----
 .../coprocessor/TransactionProcessor.java       | 22 +++++----
 .../TransactionVisibilityFilter.java            | 22 +++++----
 .../HBase10ConfigurationProviderTest.java       | 22 +++++----
 .../hbase10/TransactionAwareHTableTest.java     | 22 +++++----
 .../hbase10/coprocessor/CellSkipFilterTest.java | 22 +++++----
 .../coprocessor/TransactionProcessorTest.java   | 22 +++++----
 .../TransactionVisibilityFilterTest.java        | 23 ++++-----
 tephra-hbase-compat-1.1/pom.xml                 | 28 ++++++-----
 .../hbase11/HBase11ConfigurationProvider.java   | 22 +++++----
 .../tephra/hbase11/SecondaryIndexTable.java     | 22 +++++----
 .../tephra/hbase11/TransactionAwareHTable.java  | 22 +++++----
 .../hbase11/coprocessor/CellSkipFilter.java     | 22 +++++----
 .../hbase11/coprocessor/TransactionFilters.java | 22 +++++----
 .../coprocessor/TransactionProcessor.java       | 22 +++++----
 .../TransactionVisibilityFilter.java            | 22 +++++----
 .../HBase11ConfigurationProviderTest.java       | 22 +++++----
 .../hbase11/TransactionAwareHTableTest.java     | 22 +++++----
 .../hbase11/coprocessor/CellSkipFilterTest.java | 22 +++++----
 .../coprocessor/TransactionProcessorTest.java   | 22 +++++----
 .../TransactionVisibilityFilterTest.java        | 23 ++++-----
 227 files changed, 2802 insertions(+), 2373 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-tephra/blob/a85b0135/.travis.yml
----------------------------------------------------------------------
diff --git a/.travis.yml b/.travis.yml
index 8c55545..bba8d8f 100644
--- a/.travis.yml
+++ b/.travis.yml
@@ -1,17 +1,19 @@
 #
-# Copyright � 2014 Cask Data, Inc.
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
 #
-# Licensed under the Apache License, Version 2.0 (the "License"); you may not
-# use this 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.
+# distributed under the License is distributed on an "AS IS" BASIS,
+# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+# See the License for the specific language governing permissions and
+# limitations under the License.
 #
 
 language: java

http://git-wip-us.apache.org/repos/asf/incubator-tephra/blob/a85b0135/README.rst
----------------------------------------------------------------------
diff --git a/README.rst b/README.rst
index 076cc3b..af2bde1 100644
--- a/README.rst
+++ b/README.rst
@@ -683,15 +683,21 @@ Thanks for helping to improve Tephra!
 License and Trademarks
 ----------------------
 
-Licensed under the Apache License, Version 2.0 (the "License"); you may not use this product except
-in compliance with the License. You may obtain a copy of the License at
-
-http://www.apache.org/licenses/LICENSE-2.0
-
-Unless required by applicable law or agreed to in writing, software distributed under the License
-is distributed on an "AS IS" BASIS, WITHOUT 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.
 
 Cask, Cask Tephra and Tephra are trademarks of Cask Data, Inc. All rights reserved.
 

http://git-wip-us.apache.org/repos/asf/incubator-tephra/blob/a85b0135/bin/tephra
----------------------------------------------------------------------
diff --git a/bin/tephra b/bin/tephra
index e45b4a6..834117b 100644
--- a/bin/tephra
+++ b/bin/tephra
@@ -1,19 +1,21 @@
 #!/bin/sh
 
 #
-# Copyright � 2014 Cask Data, Inc.
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
 #
-# Licensed under the Apache License, Version 2.0 (the "License"); you may not
-# use this 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.
+# distributed under the License is distributed on an "AS IS" BASIS,
+# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+# See the License for the specific language governing permissions and
+# limitations under the License.
 #
 
 # Source function library. used for "status" use case

http://git-wip-us.apache.org/repos/asf/incubator-tephra/blob/a85b0135/bin/tephra-env.sh
----------------------------------------------------------------------
diff --git a/bin/tephra-env.sh b/bin/tephra-env.sh
index 6906b44..5ea85b4 100644
--- a/bin/tephra-env.sh
+++ b/bin/tephra-env.sh
@@ -1,19 +1,21 @@
 #!/bin/sh
 
 #
-# Copyright � 2014 Cask Data, Inc.
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
 #
-# Licensed under the Apache License, Version 2.0 (the "License"); you may not
-# use this 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.
+# distributed under the License is distributed on an "AS IS" BASIS,
+# WITHOUT 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-tephra/blob/a85b0135/checkstyle.xml
----------------------------------------------------------------------
diff --git a/checkstyle.xml b/checkstyle.xml
index 55dae95..71480c8 100644
--- a/checkstyle.xml
+++ b/checkstyle.xml
@@ -1,18 +1,20 @@
 <?xml version="1.0" encoding="UTF-8"?>
 <!--
-  Copyright � 2014 Cask Data, Inc.
-
-  Licensed under the Apache License, Version 2.0 (the "License"); you may not
-  use this file except in compliance with the License. You may obtain a copy of
-  the License at
-
-  http://www.apache.org/licenses/LICENSE-2.0
-
-  Unless required by applicable law or agreed to in writing, software
-  distributed under the License is distributed on an "AS IS" BASIS, WITHOUT
-  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.
   -->
 
 <!DOCTYPE module PUBLIC

http://git-wip-us.apache.org/repos/asf/incubator-tephra/blob/a85b0135/conf/logback.xml
----------------------------------------------------------------------
diff --git a/conf/logback.xml b/conf/logback.xml
index aa1ba7f..6a0f5d5 100644
--- a/conf/logback.xml
+++ b/conf/logback.xml
@@ -1,19 +1,21 @@
 <?xml version="1.0" encoding="UTF-8"?>
 
 <!--
-  Copyright � 2015 Cask Data, Inc.
-
-  Licensed under the Apache License, Version 2.0 (the "License"); you may not
-  use this file except in compliance with the License. You may obtain a copy of
-  the License at
-
-  http://www.apache.org/licenses/LICENSE-2.0
-
-  Unless required by applicable law or agreed to in writing, software
-  distributed under the License is distributed on an "AS IS" BASIS, WITHOUT
-  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.
   -->
 
 <configuration>

http://git-wip-us.apache.org/repos/asf/incubator-tephra/blob/a85b0135/pom.xml
----------------------------------------------------------------------
diff --git a/pom.xml b/pom.xml
index 23f44cd..ca987c0 100644
--- a/pom.xml
+++ b/pom.xml
@@ -1,18 +1,20 @@
 <?xml version="1.0" encoding="UTF-8"?>
 <!--
-  Copyright � 2014 Cask Data, Inc.
-
-  Licensed under the Apache License, Version 2.0 (the "License"); you may not
-  use this file except in compliance with the License. You may obtain a copy of
-  the License at
-
-  http://www.apache.org/licenses/LICENSE-2.0
-
-  Unless required by applicable law or agreed to in writing, software
-  distributed under the License is distributed on an "AS IS" BASIS, WITHOUT
-  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.
   -->
 
 <project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"

http://git-wip-us.apache.org/repos/asf/incubator-tephra/blob/a85b0135/src/assemble/bin.xml
----------------------------------------------------------------------
diff --git a/src/assemble/bin.xml b/src/assemble/bin.xml
index a46d793..778df13 100644
--- a/src/assemble/bin.xml
+++ b/src/assemble/bin.xml
@@ -1,18 +1,20 @@
 <?xml version="1.0" encoding="UTF-8"?>
 <!--
-  Copyright � 2014 Cask Data, Inc.
-
-  Licensed under the Apache License, Version 2.0 (the "License"); you may not
-  use this file except in compliance with the License. You may obtain a copy of
-  the License at
-
-  http://www.apache.org/licenses/LICENSE-2.0
-
-  Unless required by applicable law or agreed to in writing, software
-  distributed under the License is distributed on an "AS IS" BASIS, WITHOUT
-  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.
   -->
 
 <assembly xmlns="http://maven.apache.org/plugins/maven-assembly-plugin/assembly/1.1.2"

http://git-wip-us.apache.org/repos/asf/incubator-tephra/blob/a85b0135/suppressions.xml
----------------------------------------------------------------------
diff --git a/suppressions.xml b/suppressions.xml
index d68dac3..5521e2b 100644
--- a/suppressions.xml
+++ b/suppressions.xml
@@ -1,19 +1,21 @@
 <?xml version="1.0"?>
 
 <!--
-  Copyright � 2014 Cask Data, Inc.
-
-  Licensed under the Apache License, Version 2.0 (the "License"); you may not
-  use this file except in compliance with the License. You may obtain a copy of
-  the License at
-
-  http://www.apache.org/licenses/LICENSE-2.0
-
-  Unless required by applicable law or agreed to in writing, software
-  distributed under the License is distributed on an "AS IS" BASIS, WITHOUT
-  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.
   -->
 
 <!DOCTYPE suppressions PUBLIC

http://git-wip-us.apache.org/repos/asf/incubator-tephra/blob/a85b0135/tephra-api/pom.xml
----------------------------------------------------------------------
diff --git a/tephra-api/pom.xml b/tephra-api/pom.xml
index 04e9909..cb67207 100644
--- a/tephra-api/pom.xml
+++ b/tephra-api/pom.xml
@@ -1,18 +1,20 @@
 <?xml version="1.0" encoding="UTF-8"?>
 <!--
-  Copyright � 2014 Cask Data, Inc.
-
-  Licensed under the Apache License, Version 2.0 (the "License"); you may not
-  use this file except in compliance with the License. You may obtain a copy of
-  the License at
-
-  http://www.apache.org/licenses/LICENSE-2.0
-
-  Unless required by applicable law or agreed to in writing, software
-  distributed under the License is distributed on an "AS IS" BASIS, WITHOUT
-  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.
   -->
 
 <project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"

http://git-wip-us.apache.org/repos/asf/incubator-tephra/blob/a85b0135/tephra-api/src/main/java/co/cask/tephra/Transaction.java
----------------------------------------------------------------------
diff --git a/tephra-api/src/main/java/co/cask/tephra/Transaction.java b/tephra-api/src/main/java/co/cask/tephra/Transaction.java
index e54f426..753a064 100644
--- a/tephra-api/src/main/java/co/cask/tephra/Transaction.java
+++ b/tephra-api/src/main/java/co/cask/tephra/Transaction.java
@@ -1,17 +1,19 @@
 /*
- * Copyright � 2014 Cask Data, Inc.
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License"); you may not
- * use this 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.
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT 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 co.cask.tephra;

http://git-wip-us.apache.org/repos/asf/incubator-tephra/blob/a85b0135/tephra-api/src/main/java/co/cask/tephra/TransactionAware.java
----------------------------------------------------------------------
diff --git a/tephra-api/src/main/java/co/cask/tephra/TransactionAware.java b/tephra-api/src/main/java/co/cask/tephra/TransactionAware.java
index de7c946..524d841 100644
--- a/tephra-api/src/main/java/co/cask/tephra/TransactionAware.java
+++ b/tephra-api/src/main/java/co/cask/tephra/TransactionAware.java
@@ -1,17 +1,19 @@
 /*
- * Copyright � 2014 Cask Data, Inc.
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License"); you may not
- * use this 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.
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT 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 co.cask.tephra;

http://git-wip-us.apache.org/repos/asf/incubator-tephra/blob/a85b0135/tephra-api/src/main/java/co/cask/tephra/TransactionAwares.java
----------------------------------------------------------------------
diff --git a/tephra-api/src/main/java/co/cask/tephra/TransactionAwares.java b/tephra-api/src/main/java/co/cask/tephra/TransactionAwares.java
index ab1654c..044efc1 100644
--- a/tephra-api/src/main/java/co/cask/tephra/TransactionAwares.java
+++ b/tephra-api/src/main/java/co/cask/tephra/TransactionAwares.java
@@ -1,17 +1,19 @@
 /*
- * Copyright � 2014 Cask Data, Inc.
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License"); you may not
- * use this 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.
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT 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 co.cask.tephra;

http://git-wip-us.apache.org/repos/asf/incubator-tephra/blob/a85b0135/tephra-api/src/main/java/co/cask/tephra/TransactionConflictException.java
----------------------------------------------------------------------
diff --git a/tephra-api/src/main/java/co/cask/tephra/TransactionConflictException.java b/tephra-api/src/main/java/co/cask/tephra/TransactionConflictException.java
index 7e2af45..4b0733d 100644
--- a/tephra-api/src/main/java/co/cask/tephra/TransactionConflictException.java
+++ b/tephra-api/src/main/java/co/cask/tephra/TransactionConflictException.java
@@ -1,17 +1,19 @@
 /*
- * Copyright � 2012-2014 Cask Data, Inc.
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License"); you may not
- * use this 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.
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT 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 co.cask.tephra;

http://git-wip-us.apache.org/repos/asf/incubator-tephra/blob/a85b0135/tephra-api/src/main/java/co/cask/tephra/TransactionFailureException.java
----------------------------------------------------------------------
diff --git a/tephra-api/src/main/java/co/cask/tephra/TransactionFailureException.java b/tephra-api/src/main/java/co/cask/tephra/TransactionFailureException.java
index b1f9ec6..1ce3071 100644
--- a/tephra-api/src/main/java/co/cask/tephra/TransactionFailureException.java
+++ b/tephra-api/src/main/java/co/cask/tephra/TransactionFailureException.java
@@ -1,17 +1,19 @@
 /*
- * Copyright � 2012-2014 Cask Data, Inc.
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License"); you may not
- * use this 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.
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT 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 co.cask.tephra;

http://git-wip-us.apache.org/repos/asf/incubator-tephra/blob/a85b0135/tephra-api/src/main/java/co/cask/tephra/TransactionNotInProgressException.java
----------------------------------------------------------------------
diff --git a/tephra-api/src/main/java/co/cask/tephra/TransactionNotInProgressException.java b/tephra-api/src/main/java/co/cask/tephra/TransactionNotInProgressException.java
index 33926fd..814421a 100644
--- a/tephra-api/src/main/java/co/cask/tephra/TransactionNotInProgressException.java
+++ b/tephra-api/src/main/java/co/cask/tephra/TransactionNotInProgressException.java
@@ -1,17 +1,19 @@
 /*
- * Copyright � 2012-2014 Cask Data, Inc.
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License"); you may not
- * use this 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.
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT 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 co.cask.tephra;

http://git-wip-us.apache.org/repos/asf/incubator-tephra/blob/a85b0135/tephra-api/src/main/java/co/cask/tephra/TransactionType.java
----------------------------------------------------------------------
diff --git a/tephra-api/src/main/java/co/cask/tephra/TransactionType.java b/tephra-api/src/main/java/co/cask/tephra/TransactionType.java
index 67473a5..1235525 100644
--- a/tephra-api/src/main/java/co/cask/tephra/TransactionType.java
+++ b/tephra-api/src/main/java/co/cask/tephra/TransactionType.java
@@ -1,17 +1,19 @@
 /*
- * Copyright � 2015 Cask Data, Inc.
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License"); you may not
- * use this 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.
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT 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 co.cask.tephra;

http://git-wip-us.apache.org/repos/asf/incubator-tephra/blob/a85b0135/tephra-core/pom.xml
----------------------------------------------------------------------
diff --git a/tephra-core/pom.xml b/tephra-core/pom.xml
index 69a6a03..dea8098 100644
--- a/tephra-core/pom.xml
+++ b/tephra-core/pom.xml
@@ -1,18 +1,20 @@
 <?xml version="1.0" encoding="UTF-8"?>
 <!--
-  Copyright � 2014 Cask Data, Inc.
-
-  Licensed under the Apache License, Version 2.0 (the "License"); you may not
-  use this file except in compliance with the License. You may obtain a copy of
-  the License at
-
-  http://www.apache.org/licenses/LICENSE-2.0
-
-  Unless required by applicable law or agreed to in writing, software
-  distributed under the License is distributed on an "AS IS" BASIS, WITHOUT
-  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.
   -->
 
 <project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"

http://git-wip-us.apache.org/repos/asf/incubator-tephra/blob/a85b0135/tephra-core/src/main/java/co/cask/tephra/AbstractTransactionAwareTable.java
----------------------------------------------------------------------
diff --git a/tephra-core/src/main/java/co/cask/tephra/AbstractTransactionAwareTable.java b/tephra-core/src/main/java/co/cask/tephra/AbstractTransactionAwareTable.java
index ea232ff..11a5b55 100644
--- a/tephra-core/src/main/java/co/cask/tephra/AbstractTransactionAwareTable.java
+++ b/tephra-core/src/main/java/co/cask/tephra/AbstractTransactionAwareTable.java
@@ -1,17 +1,19 @@
 /*
- * Copyright � 2015 Cask Data, Inc.
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License"); you may not
- * use this 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.
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT 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 co.cask.tephra;

http://git-wip-us.apache.org/repos/asf/incubator-tephra/blob/a85b0135/tephra-core/src/main/java/co/cask/tephra/AbstractTransactionExecutor.java
----------------------------------------------------------------------
diff --git a/tephra-core/src/main/java/co/cask/tephra/AbstractTransactionExecutor.java b/tephra-core/src/main/java/co/cask/tephra/AbstractTransactionExecutor.java
index f197aa4..f2a28a8 100644
--- a/tephra-core/src/main/java/co/cask/tephra/AbstractTransactionExecutor.java
+++ b/tephra-core/src/main/java/co/cask/tephra/AbstractTransactionExecutor.java
@@ -1,17 +1,19 @@
 /*
- * Copyright � 2012-2014 Cask Data, Inc.
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License"); you may not
- * use this 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.
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT 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 co.cask.tephra;

http://git-wip-us.apache.org/repos/asf/incubator-tephra/blob/a85b0135/tephra-core/src/main/java/co/cask/tephra/ChangeId.java
----------------------------------------------------------------------
diff --git a/tephra-core/src/main/java/co/cask/tephra/ChangeId.java b/tephra-core/src/main/java/co/cask/tephra/ChangeId.java
index 43e66a9..8413256 100644
--- a/tephra-core/src/main/java/co/cask/tephra/ChangeId.java
+++ b/tephra-core/src/main/java/co/cask/tephra/ChangeId.java
@@ -1,17 +1,19 @@
 /*
- * Copyright � 2012-2014 Cask Data, Inc.
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License"); you may not
- * use this 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.
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT 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 co.cask.tephra;

http://git-wip-us.apache.org/repos/asf/incubator-tephra/blob/a85b0135/tephra-core/src/main/java/co/cask/tephra/DefaultTransactionExecutor.java
----------------------------------------------------------------------
diff --git a/tephra-core/src/main/java/co/cask/tephra/DefaultTransactionExecutor.java b/tephra-core/src/main/java/co/cask/tephra/DefaultTransactionExecutor.java
index 3aef89b..f85dd6b 100644
--- a/tephra-core/src/main/java/co/cask/tephra/DefaultTransactionExecutor.java
+++ b/tephra-core/src/main/java/co/cask/tephra/DefaultTransactionExecutor.java
@@ -1,17 +1,19 @@
 /*
- * Copyright � 2012-2014 Cask Data, Inc.
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License"); you may not
- * use this 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.
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT 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 co.cask.tephra;

http://git-wip-us.apache.org/repos/asf/incubator-tephra/blob/a85b0135/tephra-core/src/main/java/co/cask/tephra/InvalidTruncateTimeException.java
----------------------------------------------------------------------
diff --git a/tephra-core/src/main/java/co/cask/tephra/InvalidTruncateTimeException.java b/tephra-core/src/main/java/co/cask/tephra/InvalidTruncateTimeException.java
index 509e480..b4576ee 100644
--- a/tephra-core/src/main/java/co/cask/tephra/InvalidTruncateTimeException.java
+++ b/tephra-core/src/main/java/co/cask/tephra/InvalidTruncateTimeException.java
@@ -1,17 +1,19 @@
 /*
- * Copyright � 2015 Cask Data, Inc.
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License"); you may not
- * use this 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.
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT 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 co.cask.tephra;

http://git-wip-us.apache.org/repos/asf/incubator-tephra/blob/a85b0135/tephra-core/src/main/java/co/cask/tephra/NoRetryStrategy.java
----------------------------------------------------------------------
diff --git a/tephra-core/src/main/java/co/cask/tephra/NoRetryStrategy.java b/tephra-core/src/main/java/co/cask/tephra/NoRetryStrategy.java
index d278ee3..30e9ceb 100644
--- a/tephra-core/src/main/java/co/cask/tephra/NoRetryStrategy.java
+++ b/tephra-core/src/main/java/co/cask/tephra/NoRetryStrategy.java
@@ -1,17 +1,19 @@
 /*
- * Copyright � 2012-2014 Cask Data, Inc.
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License"); you may not
- * use this 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.
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT 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 co.cask.tephra;

http://git-wip-us.apache.org/repos/asf/incubator-tephra/blob/a85b0135/tephra-core/src/main/java/co/cask/tephra/RetryOnConflictStrategy.java
----------------------------------------------------------------------
diff --git a/tephra-core/src/main/java/co/cask/tephra/RetryOnConflictStrategy.java b/tephra-core/src/main/java/co/cask/tephra/RetryOnConflictStrategy.java
index 5176497..04b9f75 100644
--- a/tephra-core/src/main/java/co/cask/tephra/RetryOnConflictStrategy.java
+++ b/tephra-core/src/main/java/co/cask/tephra/RetryOnConflictStrategy.java
@@ -1,17 +1,19 @@
 /*
- * Copyright � 2012-2014 Cask Data, Inc.
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License"); you may not
- * use this 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.
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT 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 co.cask.tephra;

http://git-wip-us.apache.org/repos/asf/incubator-tephra/blob/a85b0135/tephra-core/src/main/java/co/cask/tephra/RetryStrategies.java
----------------------------------------------------------------------
diff --git a/tephra-core/src/main/java/co/cask/tephra/RetryStrategies.java b/tephra-core/src/main/java/co/cask/tephra/RetryStrategies.java
index 63873a9..d1de0e5 100644
--- a/tephra-core/src/main/java/co/cask/tephra/RetryStrategies.java
+++ b/tephra-core/src/main/java/co/cask/tephra/RetryStrategies.java
@@ -1,17 +1,19 @@
 /*
- * Copyright � 2012-2014 Cask Data, Inc.
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License"); you may not
- * use this 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.
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT 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 co.cask.tephra;

http://git-wip-us.apache.org/repos/asf/incubator-tephra/blob/a85b0135/tephra-core/src/main/java/co/cask/tephra/RetryStrategy.java
----------------------------------------------------------------------
diff --git a/tephra-core/src/main/java/co/cask/tephra/RetryStrategy.java b/tephra-core/src/main/java/co/cask/tephra/RetryStrategy.java
index 7d2c4b7..e651d0e 100644
--- a/tephra-core/src/main/java/co/cask/tephra/RetryStrategy.java
+++ b/tephra-core/src/main/java/co/cask/tephra/RetryStrategy.java
@@ -1,17 +1,19 @@
 /*
- * Copyright � 2012-2014 Cask Data, Inc.
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License"); you may not
- * use this 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.
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT 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 co.cask.tephra;

http://git-wip-us.apache.org/repos/asf/incubator-tephra/blob/a85b0135/tephra-core/src/main/java/co/cask/tephra/TransactionAdmin.java
----------------------------------------------------------------------
diff --git a/tephra-core/src/main/java/co/cask/tephra/TransactionAdmin.java b/tephra-core/src/main/java/co/cask/tephra/TransactionAdmin.java
index bb87819..25ccbfb 100644
--- a/tephra-core/src/main/java/co/cask/tephra/TransactionAdmin.java
+++ b/tephra-core/src/main/java/co/cask/tephra/TransactionAdmin.java
@@ -1,17 +1,19 @@
 /*
- * Copyright � 2015 Cask Data, Inc.
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License"); you may not
- * use this 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.
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT 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 co.cask.tephra;

http://git-wip-us.apache.org/repos/asf/incubator-tephra/blob/a85b0135/tephra-core/src/main/java/co/cask/tephra/TransactionCodec.java
----------------------------------------------------------------------
diff --git a/tephra-core/src/main/java/co/cask/tephra/TransactionCodec.java b/tephra-core/src/main/java/co/cask/tephra/TransactionCodec.java
index 9973473..403b1ec 100644
--- a/tephra-core/src/main/java/co/cask/tephra/TransactionCodec.java
+++ b/tephra-core/src/main/java/co/cask/tephra/TransactionCodec.java
@@ -1,17 +1,19 @@
 /*
- * Copyright � 2014 Cask Data, Inc.
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License"); you may not
- * use this 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.
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT 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 co.cask.tephra;

http://git-wip-us.apache.org/repos/asf/incubator-tephra/blob/a85b0135/tephra-core/src/main/java/co/cask/tephra/TransactionContext.java
----------------------------------------------------------------------
diff --git a/tephra-core/src/main/java/co/cask/tephra/TransactionContext.java b/tephra-core/src/main/java/co/cask/tephra/TransactionContext.java
index c20e329..5b31ebe 100644
--- a/tephra-core/src/main/java/co/cask/tephra/TransactionContext.java
+++ b/tephra-core/src/main/java/co/cask/tephra/TransactionContext.java
@@ -1,17 +1,19 @@
 /*
- * Copyright � 2012-2014 Cask Data, Inc.
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License"); you may not
- * use this 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.
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT 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 co.cask.tephra;

http://git-wip-us.apache.org/repos/asf/incubator-tephra/blob/a85b0135/tephra-core/src/main/java/co/cask/tephra/TransactionCouldNotTakeSnapshotException.java
----------------------------------------------------------------------
diff --git a/tephra-core/src/main/java/co/cask/tephra/TransactionCouldNotTakeSnapshotException.java b/tephra-core/src/main/java/co/cask/tephra/TransactionCouldNotTakeSnapshotException.java
index cd47872..a98be14 100644
--- a/tephra-core/src/main/java/co/cask/tephra/TransactionCouldNotTakeSnapshotException.java
+++ b/tephra-core/src/main/java/co/cask/tephra/TransactionCouldNotTakeSnapshotException.java
@@ -1,17 +1,19 @@
 /*
- * Copyright � 2012-2014 Cask Data, Inc.
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License"); you may not
- * use this 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.
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT 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 co.cask.tephra;

http://git-wip-us.apache.org/repos/asf/incubator-tephra/blob/a85b0135/tephra-core/src/main/java/co/cask/tephra/TransactionExecutor.java
----------------------------------------------------------------------
diff --git a/tephra-core/src/main/java/co/cask/tephra/TransactionExecutor.java b/tephra-core/src/main/java/co/cask/tephra/TransactionExecutor.java
index 432ec8a..a1cb188 100644
--- a/tephra-core/src/main/java/co/cask/tephra/TransactionExecutor.java
+++ b/tephra-core/src/main/java/co/cask/tephra/TransactionExecutor.java
@@ -1,17 +1,19 @@
 /*
- * Copyright � 2012-2014 Cask Data, Inc.
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License"); you may not
- * use this 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.
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT 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 co.cask.tephra;

http://git-wip-us.apache.org/repos/asf/incubator-tephra/blob/a85b0135/tephra-core/src/main/java/co/cask/tephra/TransactionExecutorFactory.java
----------------------------------------------------------------------
diff --git a/tephra-core/src/main/java/co/cask/tephra/TransactionExecutorFactory.java b/tephra-core/src/main/java/co/cask/tephra/TransactionExecutorFactory.java
index 8e54e65..4f30478 100644
--- a/tephra-core/src/main/java/co/cask/tephra/TransactionExecutorFactory.java
+++ b/tephra-core/src/main/java/co/cask/tephra/TransactionExecutorFactory.java
@@ -1,17 +1,19 @@
 /*
- * Copyright � 2012-2014 Cask Data, Inc.
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License"); you may not
- * use this 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.
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT 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 co.cask.tephra;

http://git-wip-us.apache.org/repos/asf/incubator-tephra/blob/a85b0135/tephra-core/src/main/java/co/cask/tephra/TransactionManager.java
----------------------------------------------------------------------
diff --git a/tephra-core/src/main/java/co/cask/tephra/TransactionManager.java b/tephra-core/src/main/java/co/cask/tephra/TransactionManager.java
index 9d7e4b3..3f51956 100644
--- a/tephra-core/src/main/java/co/cask/tephra/TransactionManager.java
+++ b/tephra-core/src/main/java/co/cask/tephra/TransactionManager.java
@@ -1,17 +1,19 @@
 /*
- * Copyright � 2012-2015 Cask Data, Inc.
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License"); you may not
- * use this 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.
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT 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 co.cask.tephra;

http://git-wip-us.apache.org/repos/asf/incubator-tephra/blob/a85b0135/tephra-core/src/main/java/co/cask/tephra/TransactionServiceMain.java
----------------------------------------------------------------------
diff --git a/tephra-core/src/main/java/co/cask/tephra/TransactionServiceMain.java b/tephra-core/src/main/java/co/cask/tephra/TransactionServiceMain.java
index 0d1c6db..8437017 100644
--- a/tephra-core/src/main/java/co/cask/tephra/TransactionServiceMain.java
+++ b/tephra-core/src/main/java/co/cask/tephra/TransactionServiceMain.java
@@ -1,17 +1,19 @@
 /*
- * Copyright � 2014 Cask Data, Inc.
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License"); you may not
- * use this 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.
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT 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 co.cask.tephra;

http://git-wip-us.apache.org/repos/asf/incubator-tephra/blob/a85b0135/tephra-core/src/main/java/co/cask/tephra/TransactionSystemClient.java
----------------------------------------------------------------------
diff --git a/tephra-core/src/main/java/co/cask/tephra/TransactionSystemClient.java b/tephra-core/src/main/java/co/cask/tephra/TransactionSystemClient.java
index 2d7d3db..ca68143 100644
--- a/tephra-core/src/main/java/co/cask/tephra/TransactionSystemClient.java
+++ b/tephra-core/src/main/java/co/cask/tephra/TransactionSystemClient.java
@@ -1,17 +1,19 @@
 /*
- * Copyright � 2012-2014 Cask Data, Inc.
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License"); you may not
- * use this 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.
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT 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 co.cask.tephra;

http://git-wip-us.apache.org/repos/asf/incubator-tephra/blob/a85b0135/tephra-core/src/main/java/co/cask/tephra/TxConstants.java
----------------------------------------------------------------------
diff --git a/tephra-core/src/main/java/co/cask/tephra/TxConstants.java b/tephra-core/src/main/java/co/cask/tephra/TxConstants.java
index 920dac3..7c96c85 100644
--- a/tephra-core/src/main/java/co/cask/tephra/TxConstants.java
+++ b/tephra-core/src/main/java/co/cask/tephra/TxConstants.java
@@ -1,17 +1,19 @@
 /*
- * Copyright � 2012-2014 Cask Data, Inc.
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License"); you may not
- * use this 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.
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT 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 co.cask.tephra;

http://git-wip-us.apache.org/repos/asf/incubator-tephra/blob/a85b0135/tephra-core/src/main/java/co/cask/tephra/coprocessor/TransactionStateCache.java
----------------------------------------------------------------------
diff --git a/tephra-core/src/main/java/co/cask/tephra/coprocessor/TransactionStateCache.java b/tephra-core/src/main/java/co/cask/tephra/coprocessor/TransactionStateCache.java
index 055a49c..2745c76 100644
--- a/tephra-core/src/main/java/co/cask/tephra/coprocessor/TransactionStateCache.java
+++ b/tephra-core/src/main/java/co/cask/tephra/coprocessor/TransactionStateCache.java
@@ -1,17 +1,19 @@
 /*
- * Copyright � 2012-2014 Cask Data, Inc.
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License"); you may not
- * use this 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.
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT 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 co.cask.tephra.coprocessor;

http://git-wip-us.apache.org/repos/asf/incubator-tephra/blob/a85b0135/tephra-core/src/main/java/co/cask/tephra/coprocessor/TransactionStateCacheSupplier.java
----------------------------------------------------------------------
diff --git a/tephra-core/src/main/java/co/cask/tephra/coprocessor/TransactionStateCacheSupplier.java b/tephra-core/src/main/java/co/cask/tephra/coprocessor/TransactionStateCacheSupplier.java
index 27630c4..9f4a778 100644
--- a/tephra-core/src/main/java/co/cask/tephra/coprocessor/TransactionStateCacheSupplier.java
+++ b/tephra-core/src/main/java/co/cask/tephra/coprocessor/TransactionStateCacheSupplier.java
@@ -1,17 +1,19 @@
 /*
- * Copyright � 2012-2014 Cask Data, Inc.
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
  *
- * Licensed under the Apache License, Version 2.0 (the "License"); you may not
- * use this 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.
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT 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 co.cask.tephra.coprocessor;