You are viewing a plain text version of this content. The canonical link for it is here.
Posted to s4-commits@incubator.apache.org by mm...@apache.org on 2012/07/25 21:15:25 UTC

[9/13] git commit: Update license headers in all java and gradle files

Update license headers in all java and gradle files


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

Branch: refs/heads/S4-88
Commit: 44e354642ff5af28174d44e16bb90f8902986f80
Parents: 704404f
Author: Matthieu Morel <mm...@apache.org>
Authored: Tue Jul 24 10:25:40 2012 +0200
Committer: Matthieu Morel <mm...@apache.org>
Committed: Tue Jul 24 18:53:59 2012 +0200

----------------------------------------------------------------------
 build.gradle                                       |   17 ++++---
 settings.gradle                                    |   33 ++++++++------
 subprojects/s4-base/s4-base.gradle                 |   33 ++++++++------
 .../src/main/java/org/apache/s4/base/Emitter.java  |   18 ++++++++
 .../src/main/java/org/apache/s4/base/Event.java    |   27 ++++++-----
 .../main/java/org/apache/s4/base/EventMessage.java |   18 ++++++++
 .../java/org/apache/s4/base/GenericKeyFinder.java  |   18 ++++++++
 .../src/main/java/org/apache/s4/base/Hasher.java   |   18 ++++++++
 .../src/main/java/org/apache/s4/base/Key.java      |   31 +++++++------
 .../main/java/org/apache/s4/base/KeyFinder.java    |   31 +++++++------
 .../src/main/java/org/apache/s4/base/Listener.java |   18 ++++++++
 .../java/org/apache/s4/base/RemoteEmitter.java     |   18 ++++++++
 .../org/apache/s4/base/SerializerDeserializer.java |   18 ++++++++
 .../org/apache/s4/base/util/JarClassLoader.java    |   18 ++++++++
 .../java/org/apache/s4/base/util/JarResources.java |   18 ++++++++
 .../org/apache/s4/base/util/MultiClassLoader.java  |   18 ++++++++
 .../java/org/apache/s4/base/util/S4RLoader.java    |   18 ++++++++
 .../org/apache/s4/base/util/S4RLoaderFactory.java  |   18 ++++++++
 .../org/apache/s4/base/util/TestClassLoader.java   |   18 ++++++++
 subprojects/s4-comm/s4-comm.gradle                 |   17 ++++---
 .../java/org/apache/s4/comm/DefaultCommModule.java |   18 ++++++++
 .../java/org/apache/s4/comm/DefaultHasher.java     |   18 ++++++++
 .../java/org/apache/s4/comm/QueueingEmitter.java   |   18 ++++++++
 .../java/org/apache/s4/comm/QueueingListener.java  |   18 ++++++++
 .../org/apache/s4/comm/RemoteEmitterFactory.java   |   18 ++++++++
 .../apache/s4/comm/loopback/LoopBackEmitter.java   |   18 ++++++++
 .../apache/s4/comm/loopback/LoopBackListener.java  |   18 ++++++++
 .../org/apache/s4/comm/serialize/KryoSerDeser.java |   18 ++++++++
 .../org/apache/s4/comm/tcp/RemoteEmitters.java     |   18 ++++++++
 .../java/org/apache/s4/comm/tcp/TCPEmitter.java    |   18 ++++++++
 .../java/org/apache/s4/comm/tcp/TCPListener.java   |   18 ++++++++
 .../org/apache/s4/comm/tcp/TCPRemoteEmitter.java   |   18 ++++++++
 .../java/org/apache/s4/comm/tools/TaskSetup.java   |   18 ++++++++
 .../org/apache/s4/comm/topology/Assignment.java    |   18 ++++++++
 .../apache/s4/comm/topology/AssignmentFromZK.java  |   18 ++++++++
 .../java/org/apache/s4/comm/topology/Cluster.java  |   18 ++++++++
 .../s4/comm/topology/ClusterChangeListener.java    |   18 ++++++++
 .../org/apache/s4/comm/topology/ClusterFromZK.java |   18 ++++++++
 .../org/apache/s4/comm/topology/ClusterNode.java   |   18 ++++++++
 .../java/org/apache/s4/comm/topology/Clusters.java |   18 ++++++++
 .../apache/s4/comm/topology/ClustersFromZK.java    |   18 ++++++++
 .../apache/s4/comm/topology/PhysicalCluster.java   |   18 ++++++++
 .../org/apache/s4/comm/topology/RemoteCluster.java |   18 ++++++++
 .../org/apache/s4/comm/topology/RemoteStreams.java |   18 ++++++++
 .../apache/s4/comm/topology/StreamConsumer.java    |   18 ++++++++
 .../java/org/apache/s4/comm/topology/ZNRecord.java |   18 ++++++++
 .../s4/comm/topology/ZNRecordSerializer.java       |   18 ++++++++
 .../java/org/apache/s4/comm/topology/ZkClient.java |   18 ++++++++
 .../java/org/apache/s4/comm/udp/UDPEmitter.java    |   18 ++++++++
 .../java/org/apache/s4/comm/udp/UDPListener.java   |   18 ++++++++
 .../org/apache/s4/comm/udp/UDPRemoteEmitter.java   |   18 ++++++++
 .../java/org/apache/s4/comm/DeliveryTestUtil.java  |   18 ++++++++
 .../s4/comm/tcp/MultiPartitionDeliveryTest.java    |   18 ++++++++
 .../org/apache/s4/comm/tcp/SimpleDeliveryTest.java |   18 ++++++++
 .../java/org/apache/s4/comm/tcp/TCPCommTest.java   |   18 ++++++++
 .../s4/comm/topology/AssignmentsFromZKTest1.java   |   18 ++++++++
 .../s4/comm/topology/AssignmentsFromZKTest2.java   |   18 ++++++++
 .../s4/comm/topology/ClustersFromZKTest.java       |   18 ++++++++
 .../org/apache/s4/comm/topology/ZKBaseTest.java    |   18 ++++++++
 .../s4/comm/topology/ZNRecordSerializerTest.java   |   18 ++++++++
 .../s4/comm/udp/MultiPartitionDeliveryTest.java    |   18 ++++++++
 .../org/apache/s4/comm/udp/SimpleDeliveryTest.java |   18 ++++++++
 .../java/org/apache/s4/comm/udp/UDPCommTest.java   |   18 ++++++++
 .../org/apache/s4/comm/util/PartitionInfo.java     |   18 ++++++++
 .../org/apache/s4/comm/util/ProtocolTestUtil.java  |   18 ++++++++
 .../java/org/apache/s4/fixtures/CommTestUtils.java |   18 ++++++++
 .../java/org/apache/s4/fixtures/ZkBasedTest.java   |   18 ++++++++
 subprojects/s4-core/s4-core.gradle                 |   35 ++++++++-------
 .../src/main/java/org/apache/s4/core/App.java      |   27 ++++++-----
 .../java/org/apache/s4/core/DefaultCoreModule.java |   18 ++++++++
 .../src/main/java/org/apache/s4/core/Key.java      |   31 +++++++------
 .../src/main/java/org/apache/s4/core/Main.java     |   18 ++++++++
 .../java/org/apache/s4/core/ProcessingElement.java |   18 ++++++++
 .../src/main/java/org/apache/s4/core/Receiver.java |   18 ++++++++
 .../main/java/org/apache/s4/core/RemoteSender.java |   18 ++++++++
 .../java/org/apache/s4/core/RemoteSenders.java     |   18 ++++++++
 .../main/java/org/apache/s4/core/RemoteStream.java |   18 ++++++++
 .../src/main/java/org/apache/s4/core/Sender.java   |   18 ++++++++
 .../src/main/java/org/apache/s4/core/Server.java   |   18 ++++++++
 .../src/main/java/org/apache/s4/core/Stream.java   |   18 ++++++++
 .../main/java/org/apache/s4/core/Streamable.java   |   18 ++++++++
 .../org/apache/s4/core/adapter/AdapterApp.java     |   18 ++++++++
 .../java/org/apache/s4/core/ft/CheckpointId.java   |    1 +
 .../org/apache/s4/core/ft/CheckpointingConfig.java |   18 ++++++++
 .../apache/s4/core/ft/CheckpointingFramework.java  |   18 ++++++++
 .../org/apache/s4/core/ft/CheckpointingTask.java   |   18 ++++++++
 .../s4/core/ft/DefaultFileSystemStateStorage.java  |    1 +
 .../main/java/org/apache/s4/core/ft/FetchTask.java |   18 ++++++++
 .../ft/FileSystemBackendCheckpointingModule.java   |   18 ++++++++
 .../s4/core/ft/LoggingStorageCallbackFactory.java  |    1 +
 .../s4/core/ft/NoOpCheckpointingFramework.java     |   18 ++++++++
 .../java/org/apache/s4/core/ft/SafeKeeper.java     |    1 +
 .../java/org/apache/s4/core/ft/SaveStateTask.java  |    1 +
 .../java/org/apache/s4/core/ft/SerializeTask.java  |    1 +
 .../java/org/apache/s4/core/ft/StateStorage.java   |    1 +
 .../org/apache/s4/core/ft/StorageCallback.java     |    1 +
 .../apache/s4/core/ft/StorageCallbackFactory.java  |    1 +
 .../org/apache/s4/core/gen/OverloadDispatcher.java |   18 ++++++++
 .../s4/core/gen/OverloadDispatcherGenerator.java   |   18 ++++++++
 .../s4/core/util/ParametersInjectionModule.java    |   18 ++++++++
 .../s4/deploy/DeploymentFailedException.java       |   18 ++++++++
 .../org/apache/s4/deploy/DeploymentManager.java    |   18 ++++++++
 .../s4/deploy/DistributedDeploymentManager.java    |   18 ++++++++
 .../org/apache/s4/deploy/FileSystemS4RFetcher.java |   18 ++++++++
 .../java/org/apache/s4/deploy/HttpS4RFetcher.java  |   18 ++++++++
 .../apache/s4/deploy/NoOpDeploymentManager.java    |   18 ++++++++
 .../main/java/org/apache/s4/deploy/S4RFetcher.java |   18 ++++++++
 .../org/apache/s4/base/EventAttributeTest.java     |   18 ++++++++
 .../test/java/org/apache/s4/base/SimpleEvent.java  |   18 ++++++++
 .../org/apache/s4/core/TestCircularFifoBuffer.java |   18 ++++++++
 .../test/java/org/apache/s4/core/TriggerTest.java  |   18 ++++++++
 ...duleWithUnrespondingFetchingStorageBackend.java |   18 ++++++++
 .../org/apache/s4/core/ft/CheckpointingTest.java   |   18 ++++++++
 .../java/org/apache/s4/core/ft/FTWordCountApp.java |   18 ++++++++
 .../org/apache/s4/core/ft/FTWordCountTest.java     |   18 ++++++++
 ...ndWithZKStorageCallbackCheckpointingModule.java |   18 ++++++++
 .../java/org/apache/s4/core/ft/RecoveryTest.java   |   18 ++++++++
 .../core/ft/S4AppWithCountBasedCheckpointing.java  |   18 ++++++++
 .../s4/core/ft/S4AppWithManualCheckpointing.java   |   18 ++++++++
 .../core/ft/S4AppWithTimeBasedCheckpointing.java   |   18 ++++++++
 .../java/org/apache/s4/core/ft/StatefulTestPE.java |   18 ++++++++
 .../core/ft/StorageWithUnrespondingFetching.java   |   18 ++++++++
 .../java/org/apache/s4/core/overloadgen/A.java     |   18 ++++++++
 .../java/org/apache/s4/core/overloadgen/B.java     |   18 ++++++++
 .../java/org/apache/s4/core/overloadgen/C.java     |   18 ++++++++
 .../java/org/apache/s4/core/overloadgen/D.java     |   18 ++++++++
 .../org/apache/s4/core/overloadgen/Event1.java     |   18 ++++++++
 .../org/apache/s4/core/overloadgen/Event1a.java    |   18 ++++++++
 .../org/apache/s4/core/overloadgen/Event2.java     |   18 ++++++++
 .../core/overloadgen/OverloadDispatcherTest.java   |   18 ++++++++
 .../apache/s4/core/timers/MultithreadingTest.java  |   18 ++++++++
 .../apache/s4/core/triggers/CountTriggerTest.java  |   18 ++++++++
 .../org/apache/s4/core/triggers/NoTriggerTest.java |   18 ++++++++
 .../apache/s4/core/triggers/TimeTriggerTest.java   |   18 ++++++++
 .../org/apache/s4/core/triggers/TriggerablePE.java |   18 ++++++++
 .../org/apache/s4/core/triggers/TriggeredApp.java  |   18 ++++++++
 .../java/org/apache/s4/deploy/AppConstants.java    |   18 ++++++++
 .../apache/s4/deploy/TestAutomaticDeployment.java  |   18 ++++++++
 .../test/java/org/apache/s4/deploy/TestModule.java |   18 ++++++++
 .../s4/deploy/prodcon/TestProducerConsumer.java    |   18 ++++++++
 .../s4/fixtures/AssignmentFromZKNoFailFast.java    |   18 ++++++++
 .../s4/fixtures/ClusterFromZKNoFailFast.java       |   18 ++++++++
 .../s4/fixtures/ClustersFromZKNoFailFast.java      |   18 ++++++++
 .../java/org/apache/s4/fixtures/CoreTestUtils.java |   18 ++++++++
 .../org/apache/s4/fixtures/MockCommModule.java     |   20 ++++++++-
 .../org/apache/s4/fixtures/MockCoreModule.java     |   18 ++++++++
 .../NonFailFastZookeeperClientsModule.java         |   18 ++++++++
 .../org/apache/s4/wordcount/KeyValueEvent.java     |   18 ++++++++
 .../org/apache/s4/wordcount/KeyValueKeyFinder.java |   18 ++++++++
 .../org/apache/s4/wordcount/SentenceKeyFinder.java |   18 ++++++++
 .../java/org/apache/s4/wordcount/StringEvent.java  |   18 ++++++++
 .../test/java/org/apache/s4/wordcount/Word.java    |   18 ++++++++
 .../org/apache/s4/wordcount/WordClassifierPE.java  |   18 ++++++++
 .../java/org/apache/s4/wordcount/WordCountApp.java |   18 ++++++++
 .../org/apache/s4/wordcount/WordCountEvent.java    |   18 ++++++++
 .../apache/s4/wordcount/WordCountKeyFinder.java    |   18 ++++++++
 .../org/apache/s4/wordcount/WordCountModule.java   |   18 ++++++++
 .../org/apache/s4/wordcount/WordCountTest.java     |   18 ++++++++
 .../org/apache/s4/wordcount/WordCounterPE.java     |   18 ++++++++
 .../org/apache/s4/wordcount/WordSeenEvent.java     |   18 ++++++++
 .../org/apache/s4/wordcount/WordSeenKeyFinder.java |   18 ++++++++
 .../org/apache/s4/wordcount/WordSplitterPE.java    |   18 ++++++++
 subprojects/s4-edsl/s4-edsl.gradle                 |   21 ++++++++-
 .../main/java/org/apache/s4/edsl/AppBuilder.java   |   18 ++++++++
 .../java/org/apache/s4/edsl/StreamBuilder.java     |   18 ++++++++
 .../java/org/apache/s4/edsl/DurationKeyFinder.java |   18 ++++++++
 .../src/test/java/org/apache/s4/edsl/EventA.java   |   18 ++++++++
 .../src/test/java/org/apache/s4/edsl/EventB.java   |   18 ++++++++
 .../java/org/apache/s4/edsl/HeightKeyFinder.java   |   18 ++++++++
 .../src/test/java/org/apache/s4/edsl/MyApp.java    |   18 ++++++++
 .../src/test/java/org/apache/s4/edsl/PEX.java      |   18 ++++++++
 .../src/test/java/org/apache/s4/edsl/PEY.java      |   18 ++++++++
 .../src/test/java/org/apache/s4/edsl/PEZ.java      |   18 ++++++++
 .../java/org/apache/s4/edsl/QueryKeyFinder.java    |   18 ++++++++
 .../src/test/java/org/apache/s4/edsl/TestEDSL.java |   18 ++++++++
 subprojects/s4-example/s4-example.gradle           |   33 ++++++++------
 .../apache/s4/example/counter/AgeKeyFinder.java    |   31 +++++++------
 .../org/apache/s4/example/counter/CountEvent.java  |   31 +++++++------
 .../apache/s4/example/counter/CountKeyFinder.java  |   31 +++++++------
 .../org/apache/s4/example/counter/CounterPE.java   |   31 +++++++------
 .../apache/s4/example/counter/GenderKeyFinder.java |   31 +++++++------
 .../s4/example/counter/GenerateUserEventPE.java    |   31 +++++++------
 .../java/org/apache/s4/example/counter/Module.java |   27 ++++++-----
 .../java/org/apache/s4/example/counter/MyApp.java  |   27 ++++++-----
 .../org/apache/s4/example/counter/PrintPE.java     |   31 +++++++------
 .../org/apache/s4/example/counter/UserEvent.java   |   31 +++++++------
 .../apache/s4/example/counter/UserIDKeyFinder.java |   31 +++++++------
 .../s4/example/edsl/counter/AgeKeyFinder.java      |   31 +++++++------
 .../apache/s4/example/edsl/counter/CountEvent.java |   31 +++++++------
 .../s4/example/edsl/counter/CountKeyFinder.java    |   31 +++++++------
 .../apache/s4/example/edsl/counter/CounterApp.java |   19 ++++++++-
 .../apache/s4/example/edsl/counter/CounterPE.java  |   31 +++++++------
 .../s4/example/edsl/counter/GenderKeyFinder.java   |   31 +++++++------
 .../example/edsl/counter/GenerateUserEventPE.java  |   31 +++++++------
 .../apache/s4/example/edsl/counter/PrintPE.java    |   31 +++++++------
 .../apache/s4/example/edsl/counter/UserEvent.java  |   31 +++++++------
 .../s4/example/edsl/counter/UserIDKeyFinder.java   |   31 +++++++------
 .../apache/s4/example/model/ClassIDKeyFinder.java  |   32 +++++++------
 .../org/apache/s4/example/model/Controller.java    |   32 +++++++------
 .../java/org/apache/s4/example/model/DataFile.java |   32 +++++++------
 .../apache/s4/example/model/HypIDKeyFinder.java    |   32 +++++++------
 .../java/org/apache/s4/example/model/Main.java     |   28 ++++++-----
 .../org/apache/s4/example/model/MaximizerPE.java   |   32 +++++++------
 .../org/apache/s4/example/model/MetricsPE.java     |   32 +++++++------
 .../java/org/apache/s4/example/model/ModelPE.java  |   32 +++++++------
 .../java/org/apache/s4/example/model/Module.java   |   33 ++++++++------
 .../java/org/apache/s4/example/model/MyApp.java    |   28 ++++++-----
 .../java/org/apache/s4/example/model/ObsEvent.java |   32 +++++++------
 .../apache/s4/example/model/ObsIndexKeyFinder.java |   18 ++++++++
 .../org/apache/s4/example/model/ResultEvent.java   |   32 +++++++------
 .../apache/s4/example/model/ResultKeyFinder.java   |   32 +++++++------
 .../main/java/org/apache/s4/model/Gaussian.java    |   32 +++++++------
 .../java/org/apache/s4/model/GaussianMixture.java  |   32 +++++++------
 .../org/apache/s4/model/GaussianMixtureModel.java  |   32 +++++++------
 .../java/org/apache/s4/model/GaussianModel.java    |   32 +++++++------
 .../src/main/java/org/apache/s4/model/Model.java   |   32 +++++++------
 .../main/java/org/apache/s4/util/MatrixOps.java    |   32 +++++++------
 .../src/test/io/s4/model/TestGaussianModel.java    |   18 ++++++++
 subprojects/s4-tools/s4-tools.gradle               |   33 ++++++++------
 .../main/java/org/apache/s4/tools/CreateApp.java   |   18 ++++++++
 .../java/org/apache/s4/tools/DefineCluster.java    |   18 ++++++++
 .../src/main/java/org/apache/s4/tools/Deploy.java  |   18 ++++++++
 .../org/apache/s4/tools/FileExistsValidator.java   |   18 ++++++++
 .../src/main/java/org/apache/s4/tools/Package.java |   18 ++++++++
 .../main/java/org/apache/s4/tools/S4ArgsBase.java  |   18 ++++++++
 .../src/main/java/org/apache/s4/tools/Status.java  |   18 ++++++++
 .../src/main/java/org/apache/s4/tools/Tools.java   |   18 ++++++++
 .../main/java/org/apache/s4/tools/ZKServer.java    |   18 ++++++++
 .../src/main/resources/templates/HelloApp.java.txt |   18 ++++++++
 .../resources/templates/HelloInputAdapter.java.txt |   18 ++++++++
 .../src/main/resources/templates/HelloPE.java.txt  |   18 ++++++++
 .../src/main/resources/templates/build.gradle      |   32 +++++++------
 .../src/main/resources/templates/settings.gradle   |   20 ++++++++-
 test-apps/consumer-app/build.gradle                |   33 ++++++++------
 .../src/main/java/s4app/ConsumerApp.java           |   18 ++++++++
 .../src/main/java/s4app/ConsumerPE.java            |   18 ++++++++
 test-apps/producer-app/build.gradle                |   33 ++++++++------
 .../src/main/java/s4app/ProducerApp.java           |   18 ++++++++
 .../src/main/java/s4app/ProducerPE.java            |   18 ++++++++
 test-apps/simple-deployable-app-1/build.gradle     |   33 ++++++++------
 .../src/main/java/org/apache/s4/deploy/A.java      |   18 ++++++++
 .../java/org/apache/s4/deploy/AppConstants.java    |   18 ++++++++
 .../main/java/org/apache/s4/deploy/SimplePE.java   |   18 ++++++++
 .../main/java/org/apache/s4/deploy/TestApp.java    |   18 ++++++++
 test-apps/simple-deployable-app-2/build.gradle     |   33 ++++++++------
 .../src/main/java/org/apache/s4/deploy/A.java      |   18 ++++++++
 .../java/org/apache/s4/deploy/AppConstants.java    |   18 ++++++++
 .../main/java/org/apache/s4/deploy/TestApp.java    |   18 ++++++++
 test-apps/twitter-adapter/build.gradle             |   33 ++++++++------
 .../s4/example/twitter/TwitterInputAdapter.java    |   18 ++++++++
 test-apps/twitter-counter/build.gradle             |   33 ++++++++------
 .../org/apache/s4/example/twitter/TopNTopicPE.java |   18 ++++++++
 .../s4/example/twitter/TopicCountAndReportPE.java  |   18 ++++++++
 .../org/apache/s4/example/twitter/TopicEvent.java  |   18 ++++++++
 .../s4/example/twitter/TopicExtractorPE.java       |   18 ++++++++
 .../s4/example/twitter/TwitterCounterApp.java      |   18 ++++++++
 256 files changed, 4386 insertions(+), 824 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-s4/blob/44e35464/build.gradle
----------------------------------------------------------------------
diff --git a/build.gradle b/build.gradle
index 149fa4c..292da4f 100644
--- a/build.gradle
+++ b/build.gradle
@@ -1,11 +1,13 @@
-/*
- * Copyright 2010 the original author or authors.
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this 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,
@@ -14,6 +16,7 @@
  * limitations under the License.
  */
 
+
 /**
  * The Apache Incubator S4 Project Build File
  *

http://git-wip-us.apache.org/repos/asf/incubator-s4/blob/44e35464/settings.gradle
----------------------------------------------------------------------
diff --git a/settings.gradle b/settings.gradle
index 588d254..48e63cf 100644
--- a/settings.gradle
+++ b/settings.gradle
@@ -1,18 +1,21 @@
-/*
- * Copyright 2010 the original author or authors.
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT 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.
+ */
+
 include 's4-base'
 include 's4-core'
 include 's4-comm'

http://git-wip-us.apache.org/repos/asf/incubator-s4/blob/44e35464/subprojects/s4-base/s4-base.gradle
----------------------------------------------------------------------
diff --git a/subprojects/s4-base/s4-base.gradle b/subprojects/s4-base/s4-base.gradle
index 11fff30..fffe198 100644
--- a/subprojects/s4-base/s4-base.gradle
+++ b/subprojects/s4-base/s4-base.gradle
@@ -1,18 +1,21 @@
-/*
- * Copyright 2010 the original author or authors.
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- *      http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT 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.
+ */
+
 
 description = 'Interfaces and most basic classes required by nultiple modules.'
  

http://git-wip-us.apache.org/repos/asf/incubator-s4/blob/44e35464/subprojects/s4-base/src/main/java/org/apache/s4/base/Emitter.java
----------------------------------------------------------------------
diff --git a/subprojects/s4-base/src/main/java/org/apache/s4/base/Emitter.java b/subprojects/s4-base/src/main/java/org/apache/s4/base/Emitter.java
index 54c08df..0738d11 100644
--- a/subprojects/s4-base/src/main/java/org/apache/s4/base/Emitter.java
+++ b/subprojects/s4-base/src/main/java/org/apache/s4/base/Emitter.java
@@ -1,3 +1,21 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
 package org.apache.s4.base;
 
 public interface Emitter {

http://git-wip-us.apache.org/repos/asf/incubator-s4/blob/44e35464/subprojects/s4-base/src/main/java/org/apache/s4/base/Event.java
----------------------------------------------------------------------
diff --git a/subprojects/s4-base/src/main/java/org/apache/s4/base/Event.java b/subprojects/s4-base/src/main/java/org/apache/s4/base/Event.java
index 1f5d7e4..8cf180d 100644
--- a/subprojects/s4-base/src/main/java/org/apache/s4/base/Event.java
+++ b/subprojects/s4-base/src/main/java/org/apache/s4/base/Event.java
@@ -1,18 +1,21 @@
-/*
- * Copyright (c) 2011 Yahoo! Inc. All rights reserved.
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (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. See accompanying LICENSE file.
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES 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.s4.base;
 
 import java.util.Map;

http://git-wip-us.apache.org/repos/asf/incubator-s4/blob/44e35464/subprojects/s4-base/src/main/java/org/apache/s4/base/EventMessage.java
----------------------------------------------------------------------
diff --git a/subprojects/s4-base/src/main/java/org/apache/s4/base/EventMessage.java b/subprojects/s4-base/src/main/java/org/apache/s4/base/EventMessage.java
index 75cb3d3..2ae26f6 100644
--- a/subprojects/s4-base/src/main/java/org/apache/s4/base/EventMessage.java
+++ b/subprojects/s4-base/src/main/java/org/apache/s4/base/EventMessage.java
@@ -1,3 +1,21 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
 package org.apache.s4.base;
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-s4/blob/44e35464/subprojects/s4-base/src/main/java/org/apache/s4/base/GenericKeyFinder.java
----------------------------------------------------------------------
diff --git a/subprojects/s4-base/src/main/java/org/apache/s4/base/GenericKeyFinder.java b/subprojects/s4-base/src/main/java/org/apache/s4/base/GenericKeyFinder.java
index 725452b..56a5d47 100644
--- a/subprojects/s4-base/src/main/java/org/apache/s4/base/GenericKeyFinder.java
+++ b/subprojects/s4-base/src/main/java/org/apache/s4/base/GenericKeyFinder.java
@@ -1,3 +1,21 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
 package org.apache.s4.base;
 
 import java.lang.reflect.Field;

http://git-wip-us.apache.org/repos/asf/incubator-s4/blob/44e35464/subprojects/s4-base/src/main/java/org/apache/s4/base/Hasher.java
----------------------------------------------------------------------
diff --git a/subprojects/s4-base/src/main/java/org/apache/s4/base/Hasher.java b/subprojects/s4-base/src/main/java/org/apache/s4/base/Hasher.java
index c780ff1..7e3a914 100644
--- a/subprojects/s4-base/src/main/java/org/apache/s4/base/Hasher.java
+++ b/subprojects/s4-base/src/main/java/org/apache/s4/base/Hasher.java
@@ -1,3 +1,21 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
 package org.apache.s4.base;
 
 public interface Hasher {

http://git-wip-us.apache.org/repos/asf/incubator-s4/blob/44e35464/subprojects/s4-base/src/main/java/org/apache/s4/base/Key.java
----------------------------------------------------------------------
diff --git a/subprojects/s4-base/src/main/java/org/apache/s4/base/Key.java b/subprojects/s4-base/src/main/java/org/apache/s4/base/Key.java
index 8ce8f3e..19eb27f 100644
--- a/subprojects/s4-base/src/main/java/org/apache/s4/base/Key.java
+++ b/subprojects/s4-base/src/main/java/org/apache/s4/base/Key.java
@@ -1,18 +1,21 @@
-/*
- * Copyright (c) 2011 Yahoo! Inc. All rights reserved.
- * 
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *          http://www.apache.org/licenses/LICENSE-2.0
- * 
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND,
- * either express or implied. See the License for the specific
- * language governing permissions and limitations under the
- * License. See accompanying LICENSE file. 
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES 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.s4.base;
 
 import java.util.List;

http://git-wip-us.apache.org/repos/asf/incubator-s4/blob/44e35464/subprojects/s4-base/src/main/java/org/apache/s4/base/KeyFinder.java
----------------------------------------------------------------------
diff --git a/subprojects/s4-base/src/main/java/org/apache/s4/base/KeyFinder.java b/subprojects/s4-base/src/main/java/org/apache/s4/base/KeyFinder.java
index 48456e1..23cfe81 100644
--- a/subprojects/s4-base/src/main/java/org/apache/s4/base/KeyFinder.java
+++ b/subprojects/s4-base/src/main/java/org/apache/s4/base/KeyFinder.java
@@ -1,18 +1,21 @@
-/*
- * Copyright (c) 2011 Yahoo! Inc. All rights reserved.
- * 
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *          http://www.apache.org/licenses/LICENSE-2.0
- * 
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND,
- * either express or implied. See the License for the specific
- * language governing permissions and limitations under the
- * License. See accompanying LICENSE file. 
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES 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.s4.base;
 
 import java.util.List;

http://git-wip-us.apache.org/repos/asf/incubator-s4/blob/44e35464/subprojects/s4-base/src/main/java/org/apache/s4/base/Listener.java
----------------------------------------------------------------------
diff --git a/subprojects/s4-base/src/main/java/org/apache/s4/base/Listener.java b/subprojects/s4-base/src/main/java/org/apache/s4/base/Listener.java
index be60597..c4060b1 100644
--- a/subprojects/s4-base/src/main/java/org/apache/s4/base/Listener.java
+++ b/subprojects/s4-base/src/main/java/org/apache/s4/base/Listener.java
@@ -1,3 +1,21 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
 package org.apache.s4.base;
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-s4/blob/44e35464/subprojects/s4-base/src/main/java/org/apache/s4/base/RemoteEmitter.java
----------------------------------------------------------------------
diff --git a/subprojects/s4-base/src/main/java/org/apache/s4/base/RemoteEmitter.java b/subprojects/s4-base/src/main/java/org/apache/s4/base/RemoteEmitter.java
index 59d9164..f305bd6 100644
--- a/subprojects/s4-base/src/main/java/org/apache/s4/base/RemoteEmitter.java
+++ b/subprojects/s4-base/src/main/java/org/apache/s4/base/RemoteEmitter.java
@@ -1,3 +1,21 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
 package org.apache.s4.base;
 
 public interface RemoteEmitter extends Emitter {

http://git-wip-us.apache.org/repos/asf/incubator-s4/blob/44e35464/subprojects/s4-base/src/main/java/org/apache/s4/base/SerializerDeserializer.java
----------------------------------------------------------------------
diff --git a/subprojects/s4-base/src/main/java/org/apache/s4/base/SerializerDeserializer.java b/subprojects/s4-base/src/main/java/org/apache/s4/base/SerializerDeserializer.java
index 63e93b9..834cc6b 100644
--- a/subprojects/s4-base/src/main/java/org/apache/s4/base/SerializerDeserializer.java
+++ b/subprojects/s4-base/src/main/java/org/apache/s4/base/SerializerDeserializer.java
@@ -1,3 +1,21 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
 package org.apache.s4.base;
 
 public interface SerializerDeserializer {

http://git-wip-us.apache.org/repos/asf/incubator-s4/blob/44e35464/subprojects/s4-base/src/main/java/org/apache/s4/base/util/JarClassLoader.java
----------------------------------------------------------------------
diff --git a/subprojects/s4-base/src/main/java/org/apache/s4/base/util/JarClassLoader.java b/subprojects/s4-base/src/main/java/org/apache/s4/base/util/JarClassLoader.java
index 8301f62..41bcb00 100644
--- a/subprojects/s4-base/src/main/java/org/apache/s4/base/util/JarClassLoader.java
+++ b/subprojects/s4-base/src/main/java/org/apache/s4/base/util/JarClassLoader.java
@@ -1,3 +1,21 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
 package org.apache.s4.base.util;
 
 import java.io.Closeable;

http://git-wip-us.apache.org/repos/asf/incubator-s4/blob/44e35464/subprojects/s4-base/src/main/java/org/apache/s4/base/util/JarResources.java
----------------------------------------------------------------------
diff --git a/subprojects/s4-base/src/main/java/org/apache/s4/base/util/JarResources.java b/subprojects/s4-base/src/main/java/org/apache/s4/base/util/JarResources.java
index 3f45575..781fdb5 100644
--- a/subprojects/s4-base/src/main/java/org/apache/s4/base/util/JarResources.java
+++ b/subprojects/s4-base/src/main/java/org/apache/s4/base/util/JarResources.java
@@ -1,3 +1,21 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
 package org.apache.s4.base.util;
 
 import java.io.*;

http://git-wip-us.apache.org/repos/asf/incubator-s4/blob/44e35464/subprojects/s4-base/src/main/java/org/apache/s4/base/util/MultiClassLoader.java
----------------------------------------------------------------------
diff --git a/subprojects/s4-base/src/main/java/org/apache/s4/base/util/MultiClassLoader.java b/subprojects/s4-base/src/main/java/org/apache/s4/base/util/MultiClassLoader.java
index 0e942b6..47d9ba1 100644
--- a/subprojects/s4-base/src/main/java/org/apache/s4/base/util/MultiClassLoader.java
+++ b/subprojects/s4-base/src/main/java/org/apache/s4/base/util/MultiClassLoader.java
@@ -1,3 +1,21 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
 package org.apache.s4.base.util;
 
 import java.util.Map;

http://git-wip-us.apache.org/repos/asf/incubator-s4/blob/44e35464/subprojects/s4-base/src/main/java/org/apache/s4/base/util/S4RLoader.java
----------------------------------------------------------------------
diff --git a/subprojects/s4-base/src/main/java/org/apache/s4/base/util/S4RLoader.java b/subprojects/s4-base/src/main/java/org/apache/s4/base/util/S4RLoader.java
index 8d3e062..ca75722 100644
--- a/subprojects/s4-base/src/main/java/org/apache/s4/base/util/S4RLoader.java
+++ b/subprojects/s4-base/src/main/java/org/apache/s4/base/util/S4RLoader.java
@@ -1,3 +1,21 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
 package org.apache.s4.base.util;
 
 import java.net.URL;

http://git-wip-us.apache.org/repos/asf/incubator-s4/blob/44e35464/subprojects/s4-base/src/main/java/org/apache/s4/base/util/S4RLoaderFactory.java
----------------------------------------------------------------------
diff --git a/subprojects/s4-base/src/main/java/org/apache/s4/base/util/S4RLoaderFactory.java b/subprojects/s4-base/src/main/java/org/apache/s4/base/util/S4RLoaderFactory.java
index c829f1c..d33c3bf 100644
--- a/subprojects/s4-base/src/main/java/org/apache/s4/base/util/S4RLoaderFactory.java
+++ b/subprojects/s4-base/src/main/java/org/apache/s4/base/util/S4RLoaderFactory.java
@@ -1,3 +1,21 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
 package org.apache.s4.base.util;
 
 import java.io.File;

http://git-wip-us.apache.org/repos/asf/incubator-s4/blob/44e35464/subprojects/s4-base/src/main/java/org/apache/s4/base/util/TestClassLoader.java
----------------------------------------------------------------------
diff --git a/subprojects/s4-base/src/main/java/org/apache/s4/base/util/TestClassLoader.java b/subprojects/s4-base/src/main/java/org/apache/s4/base/util/TestClassLoader.java
index 2dfeeb4..6222ccf 100644
--- a/subprojects/s4-base/src/main/java/org/apache/s4/base/util/TestClassLoader.java
+++ b/subprojects/s4-base/src/main/java/org/apache/s4/base/util/TestClassLoader.java
@@ -1,3 +1,21 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
 package org.apache.s4.base.util;
 
 import java.io.FileInputStream;

http://git-wip-us.apache.org/repos/asf/incubator-s4/blob/44e35464/subprojects/s4-comm/s4-comm.gradle
----------------------------------------------------------------------
diff --git a/subprojects/s4-comm/s4-comm.gradle b/subprojects/s4-comm/s4-comm.gradle
index 7f3a628..2828fcc 100644
--- a/subprojects/s4-comm/s4-comm.gradle
+++ b/subprojects/s4-comm/s4-comm.gradle
@@ -1,11 +1,13 @@
-/*
- * Copyright 2010 the original author or authors.
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (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,
@@ -14,6 +16,7 @@
  * limitations under the License.
  */
 
+
 description = 'Implementation-specific components of the communication layer.'
 
 dependencies {

http://git-wip-us.apache.org/repos/asf/incubator-s4/blob/44e35464/subprojects/s4-comm/src/main/java/org/apache/s4/comm/DefaultCommModule.java
----------------------------------------------------------------------
diff --git a/subprojects/s4-comm/src/main/java/org/apache/s4/comm/DefaultCommModule.java b/subprojects/s4-comm/src/main/java/org/apache/s4/comm/DefaultCommModule.java
index 863bc29..49593ef 100644
--- a/subprojects/s4-comm/src/main/java/org/apache/s4/comm/DefaultCommModule.java
+++ b/subprojects/s4-comm/src/main/java/org/apache/s4/comm/DefaultCommModule.java
@@ -1,3 +1,21 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
 package org.apache.s4.comm;
 
 import java.io.IOException;

http://git-wip-us.apache.org/repos/asf/incubator-s4/blob/44e35464/subprojects/s4-comm/src/main/java/org/apache/s4/comm/DefaultHasher.java
----------------------------------------------------------------------
diff --git a/subprojects/s4-comm/src/main/java/org/apache/s4/comm/DefaultHasher.java b/subprojects/s4-comm/src/main/java/org/apache/s4/comm/DefaultHasher.java
index bf58c83..656bfa4 100644
--- a/subprojects/s4-comm/src/main/java/org/apache/s4/comm/DefaultHasher.java
+++ b/subprojects/s4-comm/src/main/java/org/apache/s4/comm/DefaultHasher.java
@@ -1,3 +1,21 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
 package org.apache.s4.comm;
 
 import org.apache.s4.base.Hasher;

http://git-wip-us.apache.org/repos/asf/incubator-s4/blob/44e35464/subprojects/s4-comm/src/main/java/org/apache/s4/comm/QueueingEmitter.java
----------------------------------------------------------------------
diff --git a/subprojects/s4-comm/src/main/java/org/apache/s4/comm/QueueingEmitter.java b/subprojects/s4-comm/src/main/java/org/apache/s4/comm/QueueingEmitter.java
index 3dd2955..e891f8d 100644
--- a/subprojects/s4-comm/src/main/java/org/apache/s4/comm/QueueingEmitter.java
+++ b/subprojects/s4-comm/src/main/java/org/apache/s4/comm/QueueingEmitter.java
@@ -1,3 +1,21 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
 package org.apache.s4.comm;
 
 import java.util.concurrent.BlockingQueue;

http://git-wip-us.apache.org/repos/asf/incubator-s4/blob/44e35464/subprojects/s4-comm/src/main/java/org/apache/s4/comm/QueueingListener.java
----------------------------------------------------------------------
diff --git a/subprojects/s4-comm/src/main/java/org/apache/s4/comm/QueueingListener.java b/subprojects/s4-comm/src/main/java/org/apache/s4/comm/QueueingListener.java
index 2a9dc5c..5751527 100644
--- a/subprojects/s4-comm/src/main/java/org/apache/s4/comm/QueueingListener.java
+++ b/subprojects/s4-comm/src/main/java/org/apache/s4/comm/QueueingListener.java
@@ -1,3 +1,21 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
 package org.apache.s4.comm;
 
 import java.util.concurrent.BlockingQueue;

http://git-wip-us.apache.org/repos/asf/incubator-s4/blob/44e35464/subprojects/s4-comm/src/main/java/org/apache/s4/comm/RemoteEmitterFactory.java
----------------------------------------------------------------------
diff --git a/subprojects/s4-comm/src/main/java/org/apache/s4/comm/RemoteEmitterFactory.java b/subprojects/s4-comm/src/main/java/org/apache/s4/comm/RemoteEmitterFactory.java
index 3da803d..72bbce7 100644
--- a/subprojects/s4-comm/src/main/java/org/apache/s4/comm/RemoteEmitterFactory.java
+++ b/subprojects/s4-comm/src/main/java/org/apache/s4/comm/RemoteEmitterFactory.java
@@ -1,3 +1,21 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
 package org.apache.s4.comm;
 
 import org.apache.s4.base.RemoteEmitter;

http://git-wip-us.apache.org/repos/asf/incubator-s4/blob/44e35464/subprojects/s4-comm/src/main/java/org/apache/s4/comm/loopback/LoopBackEmitter.java
----------------------------------------------------------------------
diff --git a/subprojects/s4-comm/src/main/java/org/apache/s4/comm/loopback/LoopBackEmitter.java b/subprojects/s4-comm/src/main/java/org/apache/s4/comm/loopback/LoopBackEmitter.java
index bb7aaa0..ffa1802 100644
--- a/subprojects/s4-comm/src/main/java/org/apache/s4/comm/loopback/LoopBackEmitter.java
+++ b/subprojects/s4-comm/src/main/java/org/apache/s4/comm/loopback/LoopBackEmitter.java
@@ -1,3 +1,21 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
 package org.apache.s4.comm.loopback;
 
 import org.apache.s4.base.Emitter;

http://git-wip-us.apache.org/repos/asf/incubator-s4/blob/44e35464/subprojects/s4-comm/src/main/java/org/apache/s4/comm/loopback/LoopBackListener.java
----------------------------------------------------------------------
diff --git a/subprojects/s4-comm/src/main/java/org/apache/s4/comm/loopback/LoopBackListener.java b/subprojects/s4-comm/src/main/java/org/apache/s4/comm/loopback/LoopBackListener.java
index 8077231..14331b4 100644
--- a/subprojects/s4-comm/src/main/java/org/apache/s4/comm/loopback/LoopBackListener.java
+++ b/subprojects/s4-comm/src/main/java/org/apache/s4/comm/loopback/LoopBackListener.java
@@ -1,3 +1,21 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
 package org.apache.s4.comm.loopback;
 
 import java.util.concurrent.BlockingQueue;

http://git-wip-us.apache.org/repos/asf/incubator-s4/blob/44e35464/subprojects/s4-comm/src/main/java/org/apache/s4/comm/serialize/KryoSerDeser.java
----------------------------------------------------------------------
diff --git a/subprojects/s4-comm/src/main/java/org/apache/s4/comm/serialize/KryoSerDeser.java b/subprojects/s4-comm/src/main/java/org/apache/s4/comm/serialize/KryoSerDeser.java
index 8dd53db..8c315d6 100644
--- a/subprojects/s4-comm/src/main/java/org/apache/s4/comm/serialize/KryoSerDeser.java
+++ b/subprojects/s4-comm/src/main/java/org/apache/s4/comm/serialize/KryoSerDeser.java
@@ -1,3 +1,21 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
 package org.apache.s4.comm.serialize;
 
 import java.nio.ByteBuffer;

http://git-wip-us.apache.org/repos/asf/incubator-s4/blob/44e35464/subprojects/s4-comm/src/main/java/org/apache/s4/comm/tcp/RemoteEmitters.java
----------------------------------------------------------------------
diff --git a/subprojects/s4-comm/src/main/java/org/apache/s4/comm/tcp/RemoteEmitters.java b/subprojects/s4-comm/src/main/java/org/apache/s4/comm/tcp/RemoteEmitters.java
index 7623d52..85dc86d 100644
--- a/subprojects/s4-comm/src/main/java/org/apache/s4/comm/tcp/RemoteEmitters.java
+++ b/subprojects/s4-comm/src/main/java/org/apache/s4/comm/tcp/RemoteEmitters.java
@@ -1,3 +1,21 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
 package org.apache.s4.comm.tcp;
 
 import java.util.HashMap;

http://git-wip-us.apache.org/repos/asf/incubator-s4/blob/44e35464/subprojects/s4-comm/src/main/java/org/apache/s4/comm/tcp/TCPEmitter.java
----------------------------------------------------------------------
diff --git a/subprojects/s4-comm/src/main/java/org/apache/s4/comm/tcp/TCPEmitter.java b/subprojects/s4-comm/src/main/java/org/apache/s4/comm/tcp/TCPEmitter.java
index d2aa64f..8192cdc 100644
--- a/subprojects/s4-comm/src/main/java/org/apache/s4/comm/tcp/TCPEmitter.java
+++ b/subprojects/s4-comm/src/main/java/org/apache/s4/comm/tcp/TCPEmitter.java
@@ -1,3 +1,21 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
 package org.apache.s4.comm.tcp;
 
 import java.net.ConnectException;

http://git-wip-us.apache.org/repos/asf/incubator-s4/blob/44e35464/subprojects/s4-comm/src/main/java/org/apache/s4/comm/tcp/TCPListener.java
----------------------------------------------------------------------
diff --git a/subprojects/s4-comm/src/main/java/org/apache/s4/comm/tcp/TCPListener.java b/subprojects/s4-comm/src/main/java/org/apache/s4/comm/tcp/TCPListener.java
index d7d49bd..d4d8b91 100644
--- a/subprojects/s4-comm/src/main/java/org/apache/s4/comm/tcp/TCPListener.java
+++ b/subprojects/s4-comm/src/main/java/org/apache/s4/comm/tcp/TCPListener.java
@@ -1,3 +1,21 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
 package org.apache.s4.comm.tcp;
 
 import java.net.InetSocketAddress;

http://git-wip-us.apache.org/repos/asf/incubator-s4/blob/44e35464/subprojects/s4-comm/src/main/java/org/apache/s4/comm/tcp/TCPRemoteEmitter.java
----------------------------------------------------------------------
diff --git a/subprojects/s4-comm/src/main/java/org/apache/s4/comm/tcp/TCPRemoteEmitter.java b/subprojects/s4-comm/src/main/java/org/apache/s4/comm/tcp/TCPRemoteEmitter.java
index b19d5be..a206906 100644
--- a/subprojects/s4-comm/src/main/java/org/apache/s4/comm/tcp/TCPRemoteEmitter.java
+++ b/subprojects/s4-comm/src/main/java/org/apache/s4/comm/tcp/TCPRemoteEmitter.java
@@ -1,3 +1,21 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
 package org.apache.s4.comm.tcp;
 
 import org.apache.s4.base.RemoteEmitter;

http://git-wip-us.apache.org/repos/asf/incubator-s4/blob/44e35464/subprojects/s4-comm/src/main/java/org/apache/s4/comm/tools/TaskSetup.java
----------------------------------------------------------------------
diff --git a/subprojects/s4-comm/src/main/java/org/apache/s4/comm/tools/TaskSetup.java b/subprojects/s4-comm/src/main/java/org/apache/s4/comm/tools/TaskSetup.java
index 010274a..ce5453c 100644
--- a/subprojects/s4-comm/src/main/java/org/apache/s4/comm/tools/TaskSetup.java
+++ b/subprojects/s4-comm/src/main/java/org/apache/s4/comm/tools/TaskSetup.java
@@ -1,3 +1,21 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
 package org.apache.s4.comm.tools;
 
 import java.util.concurrent.TimeUnit;

http://git-wip-us.apache.org/repos/asf/incubator-s4/blob/44e35464/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/Assignment.java
----------------------------------------------------------------------
diff --git a/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/Assignment.java b/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/Assignment.java
index 0cac238..4d9b85a 100644
--- a/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/Assignment.java
+++ b/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/Assignment.java
@@ -1,3 +1,21 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
 package org.apache.s4.comm.topology;
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-s4/blob/44e35464/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/AssignmentFromZK.java
----------------------------------------------------------------------
diff --git a/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/AssignmentFromZK.java b/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/AssignmentFromZK.java
index 66c2eca..215a1d7 100644
--- a/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/AssignmentFromZK.java
+++ b/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/AssignmentFromZK.java
@@ -1,3 +1,21 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
 package org.apache.s4.comm.topology;
 
 import java.net.InetAddress;

http://git-wip-us.apache.org/repos/asf/incubator-s4/blob/44e35464/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/Cluster.java
----------------------------------------------------------------------
diff --git a/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/Cluster.java b/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/Cluster.java
index a9066a4..2ff6e97 100644
--- a/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/Cluster.java
+++ b/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/Cluster.java
@@ -1,3 +1,21 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
 package org.apache.s4.comm.topology;
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-s4/blob/44e35464/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/ClusterChangeListener.java
----------------------------------------------------------------------
diff --git a/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/ClusterChangeListener.java b/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/ClusterChangeListener.java
index c53798a..441837b 100644
--- a/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/ClusterChangeListener.java
+++ b/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/ClusterChangeListener.java
@@ -1,3 +1,21 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
 package org.apache.s4.comm.topology;
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-s4/blob/44e35464/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/ClusterFromZK.java
----------------------------------------------------------------------
diff --git a/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/ClusterFromZK.java b/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/ClusterFromZK.java
index 1ec3cb5..724b1cd 100644
--- a/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/ClusterFromZK.java
+++ b/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/ClusterFromZK.java
@@ -1,3 +1,21 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
 package org.apache.s4.comm.topology;
 
 import java.net.InetAddress;

http://git-wip-us.apache.org/repos/asf/incubator-s4/blob/44e35464/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/ClusterNode.java
----------------------------------------------------------------------
diff --git a/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/ClusterNode.java b/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/ClusterNode.java
index 6a52663..00c403c 100644
--- a/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/ClusterNode.java
+++ b/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/ClusterNode.java
@@ -1,3 +1,21 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
 package org.apache.s4.comm.topology;
 
 public class ClusterNode {

http://git-wip-us.apache.org/repos/asf/incubator-s4/blob/44e35464/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/Clusters.java
----------------------------------------------------------------------
diff --git a/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/Clusters.java b/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/Clusters.java
index aa8b78f..c7ff5b3 100644
--- a/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/Clusters.java
+++ b/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/Clusters.java
@@ -1,3 +1,21 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
 package org.apache.s4.comm.topology;
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-s4/blob/44e35464/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/ClustersFromZK.java
----------------------------------------------------------------------
diff --git a/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/ClustersFromZK.java b/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/ClustersFromZK.java
index f177599..47fbacb 100644
--- a/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/ClustersFromZK.java
+++ b/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/ClustersFromZK.java
@@ -1,3 +1,21 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
 package org.apache.s4.comm.topology;
 
 import java.net.InetAddress;

http://git-wip-us.apache.org/repos/asf/incubator-s4/blob/44e35464/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/PhysicalCluster.java
----------------------------------------------------------------------
diff --git a/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/PhysicalCluster.java b/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/PhysicalCluster.java
index 32348df..f96a940 100644
--- a/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/PhysicalCluster.java
+++ b/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/PhysicalCluster.java
@@ -1,3 +1,21 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
 package org.apache.s4.comm.topology;
 
 import java.io.IOException;

http://git-wip-us.apache.org/repos/asf/incubator-s4/blob/44e35464/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/RemoteCluster.java
----------------------------------------------------------------------
diff --git a/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/RemoteCluster.java b/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/RemoteCluster.java
index 2b9d866..e8e298a 100644
--- a/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/RemoteCluster.java
+++ b/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/RemoteCluster.java
@@ -1,3 +1,21 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
 package org.apache.s4.comm.topology;
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-s4/blob/44e35464/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/RemoteStreams.java
----------------------------------------------------------------------
diff --git a/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/RemoteStreams.java b/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/RemoteStreams.java
index 587f823..c9d6e94 100644
--- a/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/RemoteStreams.java
+++ b/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/RemoteStreams.java
@@ -1,3 +1,21 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
 package org.apache.s4.comm.topology;
 
 import java.util.Collections;

http://git-wip-us.apache.org/repos/asf/incubator-s4/blob/44e35464/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/StreamConsumer.java
----------------------------------------------------------------------
diff --git a/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/StreamConsumer.java b/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/StreamConsumer.java
index ede16a3..1c17d50 100644
--- a/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/StreamConsumer.java
+++ b/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/StreamConsumer.java
@@ -1,3 +1,21 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
 package org.apache.s4.comm.topology;
 
 /**

http://git-wip-us.apache.org/repos/asf/incubator-s4/blob/44e35464/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/ZNRecord.java
----------------------------------------------------------------------
diff --git a/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/ZNRecord.java b/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/ZNRecord.java
index 4aa7639..aee7f6f 100644
--- a/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/ZNRecord.java
+++ b/subprojects/s4-comm/src/main/java/org/apache/s4/comm/topology/ZNRecord.java
@@ -1,3 +1,21 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
 package org.apache.s4.comm.topology;
 
 import java.util.List;