You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@apex.apache.org by da...@apache.org on 2015/09/25 19:47:44 UTC

[16/17] incubator-apex-core git commit: Automated license header format: mvn license:format -Dlicense.skip=false

Automated license header format:
mvn license:format -Dlicense.skip=false

Check:
mvn apache-rat:check


Project: http://git-wip-us.apache.org/repos/asf/incubator-apex-core/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-apex-core/commit/730e57f7
Tree: http://git-wip-us.apache.org/repos/asf/incubator-apex-core/tree/730e57f7
Diff: http://git-wip-us.apache.org/repos/asf/incubator-apex-core/diff/730e57f7

Branch: refs/heads/devel-3
Commit: 730e57f78d44874db7be7ecf89497cf0010e1c55
Parents: 6345be3
Author: MalharJenkins <je...@datatorrent.com>
Authored: Thu Sep 24 18:19:33 2015 -0700
Committer: MalharJenkins <je...@datatorrent.com>
Committed: Thu Sep 24 18:19:33 2015 -0700

----------------------------------------------------------------------
 apex-app-archetype/pom.xml                      | 20 +++++++++++++
 .../META-INF/maven/archetype-metadata.xml       | 20 +++++++++++++
 .../main/resources/META-INF/maven/archetype.xml | 20 +++++++++++++
 .../projects/basic/archetype.properties         | 19 ++++++++++++
 apex-conf-archetype/pom.xml                     | 20 +++++++++++++
 .../META-INF/maven/archetype-metadata.xml       | 20 +++++++++++++
 .../main/resources/META-INF/maven/archetype.xml | 20 +++++++++++++
 .../projects/basic/archetype.properties         | 19 ++++++++++++
 apex_checks.xml                                 | 20 +++++++++++++
 api/pom.xml                                     | 20 +++++++++++++
 .../java/com/datatorrent/api/Attribute.java     | 25 +++++++++-------
 .../java/com/datatorrent/api/AutoMetric.java    | 25 +++++++++-------
 .../java/com/datatorrent/api/Component.java     | 25 +++++++++-------
 .../main/java/com/datatorrent/api/Context.java  | 25 +++++++++-------
 api/src/main/java/com/datatorrent/api/DAG.java  | 25 +++++++++-------
 .../com/datatorrent/api/DefaultInputPort.java   | 25 +++++++++-------
 .../com/datatorrent/api/DefaultOutputPort.java  | 25 +++++++++-------
 .../com/datatorrent/api/DefaultPartition.java   | 25 +++++++++-------
 .../java/com/datatorrent/api/InputOperator.java | 25 +++++++++-------
 .../java/com/datatorrent/api/LocalMode.java     | 25 +++++++++-------
 .../main/java/com/datatorrent/api/Operator.java | 25 +++++++++-------
 .../java/com/datatorrent/api/Partitioner.java   | 25 +++++++++-------
 api/src/main/java/com/datatorrent/api/Sink.java | 25 +++++++++-------
 .../main/java/com/datatorrent/api/Stats.java    | 25 +++++++++-------
 .../java/com/datatorrent/api/StatsListener.java | 25 +++++++++-------
 .../java/com/datatorrent/api/StorageAgent.java  | 25 +++++++++-------
 .../java/com/datatorrent/api/StreamCodec.java   | 25 +++++++++-------
 .../datatorrent/api/StreamingApplication.java   | 25 +++++++++-------
 .../java/com/datatorrent/api/StringCodec.java   | 25 +++++++++-------
 .../api/annotation/ApplicationAnnotation.java   | 25 +++++++++-------
 .../annotation/InputPortFieldAnnotation.java    | 25 +++++++++-------
 .../com/datatorrent/api/annotation/Name.java    | 27 +++++++++--------
 .../api/annotation/OperatorAnnotation.java      | 25 +++++++++-------
 .../annotation/OutputPortFieldAnnotation.java   | 25 +++++++++-------
 .../datatorrent/api/annotation/RecordField.java | 25 +++++++++-------
 .../datatorrent/api/annotation/Stateless.java   | 25 +++++++++-------
 .../api/annotation/package-info.java            | 25 +++++++++-------
 .../java/com/datatorrent/api/package-info.java  | 25 +++++++++-------
 .../com/datatorrent/api/AttributeMapTest.java   | 25 +++++++++-------
 .../com/datatorrent/api/Object2StringTest.java  | 25 +++++++++-------
 api/src/test/resources/log4j.properties         | 19 ++++++++++++
 bufferserver/nbactions.xml                      | 20 +++++++++++++
 bufferserver/pom.xml                            | 20 +++++++++++++
 .../bufferserver/auth/AuthManager.java          | 25 +++++++++-------
 .../bufferserver/client/AuthClient.java         | 25 +++++++++-------
 .../bufferserver/client/Controller.java         | 25 +++++++++-------
 .../bufferserver/client/Publisher.java          | 25 +++++++++-------
 .../bufferserver/client/Subscriber.java         | 25 +++++++++-------
 .../bufferserver/internal/DataList.java         | 25 +++++++++-------
 .../bufferserver/internal/DataListener.java     | 25 +++++++++-------
 .../bufferserver/internal/FastDataList.java     | 25 +++++++++-------
 .../bufferserver/internal/LogicalNode.java      | 25 +++++++++-------
 .../bufferserver/internal/PhysicalNode.java     | 25 +++++++++-------
 .../bufferserver/internal/package-info.java     | 25 +++++++++-------
 .../bufferserver/packet/BeginWindowTuple.java   | 25 +++++++++-------
 .../bufferserver/packet/DataTuple.java          | 25 +++++++++-------
 .../bufferserver/packet/EmptyTuple.java         | 25 +++++++++-------
 .../bufferserver/packet/EndStreamTuple.java     | 25 +++++++++-------
 .../bufferserver/packet/EndWindowTuple.java     | 25 +++++++++-------
 .../packet/GenericRequestTuple.java             | 25 +++++++++-------
 .../bufferserver/packet/MessageType.java        | 25 +++++++++-------
 .../bufferserver/packet/NoMessageTuple.java     | 25 +++++++++-------
 .../bufferserver/packet/PayloadTuple.java       | 25 +++++++++-------
 .../packet/PublishRequestTuple.java             | 25 +++++++++-------
 .../bufferserver/packet/PurgeRequestTuple.java  | 25 +++++++++-------
 .../bufferserver/packet/RequestTuple.java       | 25 +++++++++-------
 .../bufferserver/packet/ResetRequestTuple.java  | 25 +++++++++-------
 .../bufferserver/packet/ResetWindowTuple.java   | 25 +++++++++-------
 .../packet/SubscribeRequestTuple.java           | 25 +++++++++-------
 .../datatorrent/bufferserver/packet/Tuple.java  | 25 +++++++++-------
 .../bufferserver/packet/WindowIdTuple.java      | 25 +++++++++-------
 .../bufferserver/policy/AbstractPolicy.java     | 25 +++++++++-------
 .../bufferserver/policy/GiveAll.java            | 25 +++++++++-------
 .../bufferserver/policy/LeastBusy.java          | 25 +++++++++-------
 .../datatorrent/bufferserver/policy/Policy.java | 25 +++++++++-------
 .../bufferserver/policy/RandomOne.java          | 25 +++++++++-------
 .../bufferserver/policy/RoundRobin.java         | 25 +++++++++-------
 .../bufferserver/policy/package-info.java       | 25 +++++++++-------
 .../datatorrent/bufferserver/server/Server.java | 25 +++++++++-------
 .../bufferserver/storage/DiskStorage.java       | 25 +++++++++-------
 .../bufferserver/storage/Storage.java           | 25 +++++++++-------
 .../bufferserver/util/BitVector.java            | 25 +++++++++-------
 .../datatorrent/bufferserver/util/Codec.java    | 25 +++++++++-------
 .../bufferserver/util/SerializedData.java       | 25 +++++++++-------
 .../datatorrent/bufferserver/util/System.java   | 25 +++++++++-------
 .../datatorrent/bufferserver/util/VarInt.java   | 27 +++++++++--------
 .../bufferserver/util/package-info.java         | 25 +++++++++-------
 .../bufferserver/client/SubscriberTest.java     | 25 +++++++++-------
 .../bufferserver/packet/NoMessageTupleTest.java | 25 +++++++++-------
 .../packet/PublishRequestTupleTest.java         | 25 +++++++++-------
 .../packet/ResetWindowTupleTest.java            | 25 +++++++++-------
 .../packet/SubscribeRequestTupleTest.java       | 25 +++++++++-------
 .../bufferserver/server/ServerTest.java         | 25 +++++++++-------
 .../bufferserver/storage/DiskStorageTest.java   | 25 +++++++++-------
 .../bufferserver/support/Controller.java        | 25 +++++++++-------
 .../bufferserver/support/Publisher.java         | 25 +++++++++-------
 .../bufferserver/support/Subscriber.java        | 25 +++++++++-------
 .../bufferserver/util/CodecTest.java            | 25 +++++++++-------
 .../src/test/resources/log4j.properties         | 19 ++++++++++++
 common/pom.xml                                  | 20 +++++++++++++
 .../common/codec/JsonStreamCodec.java           | 25 +++++++++-------
 .../common/experimental/AppData.java            | 25 +++++++++-------
 .../common/metric/MetricsAggregator.java        | 25 +++++++++-------
 .../common/metric/SingleMetricAggregator.java   | 27 +++++++++--------
 .../common/metric/sum/DoubleSumAggregator.java  | 27 +++++++++--------
 .../common/metric/sum/LongSumAggregator.java    | 27 +++++++++--------
 .../partitioner/StatelessPartitioner.java       | 25 +++++++++-------
 .../common/security/SecurityContext.java        | 25 +++++++++-------
 .../auth/callback/DefaultCallbackHandler.java   | 25 +++++++++-------
 .../common/util/AsyncFSStorageAgent.java        | 26 ++++++++--------
 .../datatorrent/common/util/BaseOperator.java   | 25 +++++++++-------
 .../util/BasicContainerOptConfigurator.java     | 25 +++++++++-------
 .../datatorrent/common/util/FSStorageAgent.java | 25 +++++++++-------
 .../util/JacksonObjectMapperProvider.java       | 25 +++++++++-------
 .../common/util/NameableThreadFactory.java      | 25 +++++++++-------
 .../common/util/NumberAggregate.java            | 25 +++++++++-------
 .../common/util/ObjectMapperString.java         | 25 +++++++++-------
 .../java/com/datatorrent/common/util/Pair.java  | 25 +++++++++-------
 .../datatorrent/common/util/PubSubMessage.java  | 25 +++++++++-------
 .../common/util/PubSubMessageCodec.java         | 25 +++++++++-------
 .../common/util/PubSubWebSocketClient.java      | 25 +++++++++-------
 .../common/util/ScheduledExecutorService.java   | 25 +++++++++-------
 .../util/ScheduledThreadPoolExecutor.java       | 25 +++++++++-------
 .../common/util/SerializableObject.java         | 25 +++++++++-------
 .../datatorrent/common/util/package-info.java   | 25 +++++++++-------
 .../common/codec/JsonStreamCodecTest.java       | 25 +++++++++-------
 .../partitioner/StatelessPartitionerTest.java   | 25 +++++++++-------
 .../common/util/AsyncFSStorageAgentTest.java    | 25 +++++++++-------
 .../common/util/FSStorageAgentTest.java         | 25 +++++++++-------
 .../common/util/SerializableObjectTest.java     | 25 +++++++++-------
 common/src/test/resources/log4j.properties      | 19 ++++++++++++
 engine/pom.xml                                  | 20 +++++++++++++
 .../stram/BufferServerController.java           | 25 +++++++++-------
 .../stram/ComponentConfigurationPair.java       | 25 +++++++++-------
 .../datatorrent/stram/ComponentContextPair.java | 25 +++++++++-------
 .../com/datatorrent/stram/EventRecorder.java    | 25 +++++++++-------
 .../com/datatorrent/stram/FSEventRecorder.java  | 25 +++++++++-------
 .../datatorrent/stram/FSRecoveryHandler.java    | 25 +++++++++-------
 .../com/datatorrent/stram/FSStatsRecorder.java  | 25 +++++++++-------
 .../java/com/datatorrent/stram/Journal.java     | 25 +++++++++-------
 .../stram/LaunchContainerRunnable.java          | 25 +++++++++-------
 .../datatorrent/stram/LicensingProtocol.java    | 25 +++++++++-------
 .../com/datatorrent/stram/LocalModeImpl.java    | 25 +++++++++-------
 .../stram/PhysicalMetricsContextImpl.java       | 25 +++++++++-------
 .../datatorrent/stram/RecoverableRpcProxy.java  | 25 +++++++++-------
 .../stram/ResourceRequestHandler.java           | 25 +++++++++-------
 .../com/datatorrent/stram/StatsRecorder.java    | 25 +++++++++-------
 .../com/datatorrent/stram/StramAppContext.java  | 25 +++++++++-------
 .../java/com/datatorrent/stram/StramClient.java | 25 +++++++++-------
 .../datatorrent/stram/StramLocalCluster.java    | 25 +++++++++-------
 .../java/com/datatorrent/stram/StramUtils.java  | 25 +++++++++-------
 .../datatorrent/stram/StreamingAppMaster.java   | 25 +++++++++-------
 .../stram/StreamingAppMasterService.java        | 25 +++++++++-------
 .../stram/StreamingContainerAgent.java          | 25 +++++++++-------
 .../stram/StreamingContainerManager.java        | 25 +++++++++-------
 .../stram/StreamingContainerParent.java         | 25 +++++++++-------
 .../stram/StreamingContainerSecurityInfo.java   | 25 +++++++++-------
 .../com/datatorrent/stram/StringCodecs.java     | 25 +++++++++-------
 .../stram/WebsocketAppDataPusher.java           | 25 +++++++++-------
 .../datatorrent/stram/api/AppDataPusher.java    | 25 +++++++++-------
 .../datatorrent/stram/api/AppDataSource.java    | 27 +++++++++--------
 .../com/datatorrent/stram/api/BaseContext.java  | 25 +++++++++-------
 .../com/datatorrent/stram/api/Checkpoint.java   | 25 +++++++++-------
 .../datatorrent/stram/api/ContainerContext.java | 25 +++++++++-------
 .../datatorrent/stram/api/ContainerEvent.java   | 25 +++++++++-------
 .../stram/api/NodeActivationListener.java       | 25 +++++++++-------
 .../stram/api/OperatorDeployInfo.java           | 25 +++++++++-------
 .../datatorrent/stram/api/RequestFactory.java   | 25 +++++++++-------
 .../com/datatorrent/stram/api/StramEvent.java   | 25 +++++++++-------
 .../api/StramToNodeChangeLoggersRequest.java    | 25 +++++++++-------
 .../api/StramToNodeGetPropertyRequest.java      | 25 +++++++++-------
 .../api/StramToNodeSetPropertyRequest.java      | 25 +++++++++-------
 .../api/StramToNodeStartRecordingRequest.java   | 25 +++++++++-------
 .../StreamingContainerUmbilicalProtocol.java    | 25 +++++++++-------
 .../stram/appdata/AppDataPushAgent.java         | 25 +++++++++-------
 .../java/com/datatorrent/stram/cli/DTCli.java   | 25 +++++++++-------
 .../com/datatorrent/stram/cli/package-info.java | 25 +++++++++-------
 .../datatorrent/stram/client/AppPackage.java    | 25 +++++++++-------
 .../stram/client/ClassPathResolvers.java        | 25 +++++++++-------
 .../datatorrent/stram/client/ConfigPackage.java | 25 +++++++++-------
 .../stram/client/DTConfiguration.java           | 25 +++++++++-------
 .../datatorrent/stram/client/EventsAgent.java   | 25 +++++++++-------
 .../com/datatorrent/stram/client/FSAgent.java   | 25 +++++++++-------
 .../stram/client/FSPartFileAgent.java           | 25 +++++++++-------
 .../stram/client/PermissionsInfo.java           | 25 +++++++++-------
 .../stram/client/RecordingsAgent.java           | 25 +++++++++-------
 .../datatorrent/stram/client/StatsAgent.java    | 25 +++++++++-------
 .../datatorrent/stram/client/StramAgent.java    | 25 +++++++++-------
 .../stram/client/StramAppLauncher.java          | 25 +++++++++-------
 .../stram/client/StramClientUtils.java          | 25 +++++++++-------
 .../client/WebServicesVersionConversion.java    | 25 +++++++++-------
 .../stram/codec/DefaultStatefulStreamCodec.java | 25 +++++++++-------
 .../stram/codec/LogicalPlanSerializer.java      | 25 +++++++++-------
 .../stram/codec/StatefulStreamCodec.java        | 25 +++++++++-------
 .../com/datatorrent/stram/debug/MuxSink.java    | 25 +++++++++-------
 .../stram/debug/OperatorIdPortNamePair.java     | 25 +++++++++-------
 .../datatorrent/stram/debug/StdOutErrLog.java   | 25 +++++++++-------
 .../stram/debug/TappedReservoir.java            | 25 +++++++++-------
 .../datatorrent/stram/debug/TupleRecorder.java  | 25 +++++++++-------
 .../stram/debug/TupleRecorderCollection.java    | 25 +++++++++-------
 .../engine/BufferServerStatsSubscriber.java     | 25 +++++++++-------
 .../stram/engine/ByteCounterStream.java         | 25 +++++++++-------
 .../stram/engine/DefaultReservoir.java          | 25 +++++++++-------
 .../stram/engine/DefaultUnifier.java            | 25 +++++++++-------
 .../datatorrent/stram/engine/GenericNode.java   | 25 +++++++++-------
 .../com/datatorrent/stram/engine/InputNode.java | 25 +++++++++-------
 .../datatorrent/stram/engine/MuxReservoir.java  | 25 +++++++++-------
 .../java/com/datatorrent/stram/engine/Node.java | 25 +++++++++-------
 .../com/datatorrent/stram/engine/OiONode.java   | 25 +++++++++-------
 .../stram/engine/OperatorContext.java           | 25 +++++++++-------
 .../stram/engine/OperatorResponse.java          | 25 +++++++++-------
 .../datatorrent/stram/engine/PortContext.java   | 25 +++++++++-------
 .../com/datatorrent/stram/engine/Reservoir.java | 25 +++++++++-------
 .../com/datatorrent/stram/engine/Slider.java    | 27 +++++++++--------
 .../com/datatorrent/stram/engine/Stream.java    | 25 +++++++++-------
 .../datatorrent/stram/engine/StreamContext.java | 25 +++++++++-------
 .../stram/engine/StreamingContainer.java        | 25 +++++++++-------
 .../stram/engine/SweepableReservoir.java        | 25 +++++++++-------
 .../datatorrent/stram/engine/UnifierNode.java   | 25 +++++++++-------
 .../stram/engine/WindowGenerator.java           | 25 +++++++++-------
 .../engine/WindowIdActivatedReservoir.java      | 25 +++++++++-------
 .../datatorrent/stram/engine/package-info.java  | 25 +++++++++-------
 .../com/datatorrent/stram/package-info.java     | 25 +++++++++-------
 .../plan/logical/DefaultKryoStreamCodec.java    | 25 +++++++++-------
 .../plan/logical/LogicalOperatorStatus.java     | 25 +++++++++-------
 .../stram/plan/logical/LogicalPlan.java         | 25 +++++++++-------
 .../plan/logical/LogicalPlanConfiguration.java  | 25 +++++++++-------
 .../stram/plan/logical/Operators.java           | 25 +++++++++-------
 .../StreamCodecWrapperForPersistance.java       | 18 ++++++++++++
 .../logical/requests/AddStreamSinkRequest.java  | 25 +++++++++-------
 .../logical/requests/CreateOperatorRequest.java | 25 +++++++++-------
 .../logical/requests/CreateStreamRequest.java   | 25 +++++++++-------
 .../logical/requests/LogicalPlanRequest.java    | 25 +++++++++-------
 .../logical/requests/RemoveOperatorRequest.java | 25 +++++++++-------
 .../logical/requests/RemoveStreamRequest.java   | 25 +++++++++-------
 .../requests/SetOperatorAttributeRequest.java   | 25 +++++++++-------
 .../requests/SetOperatorPropertyRequest.java    | 25 +++++++++-------
 .../requests/SetPortAttributeRequest.java       | 25 +++++++++-------
 .../requests/SetStreamAttributeRequest.java     | 25 +++++++++-------
 .../stram/plan/physical/OperatorStatus.java     | 25 +++++++++-------
 .../stram/plan/physical/PTContainer.java        | 25 +++++++++-------
 .../stram/plan/physical/PTOperator.java         | 25 +++++++++-------
 .../stram/plan/physical/PhysicalPlan.java       | 25 +++++++++-------
 .../stram/plan/physical/PlanModifier.java       | 25 +++++++++-------
 .../stram/plan/physical/StatsRevisions.java     | 25 +++++++++-------
 .../stram/plan/physical/StreamMapping.java      | 25 +++++++++-------
 .../stram/security/KerberosAuth.java            | 25 +++++++++-------
 .../StramDelegationTokenIdentifier.java         | 25 +++++++++-------
 .../security/StramDelegationTokenManager.java   | 25 +++++++++-------
 .../security/StramDelegationTokenSelector.java  | 25 +++++++++-------
 .../stram/security/StramUserLogin.java          | 25 +++++++++-------
 .../stram/security/StramWSFilter.java           | 25 +++++++++-------
 .../security/StramWSFilterInitializer.java      | 25 +++++++++-------
 .../stram/security/StramWSPrincipal.java        | 25 +++++++++-------
 .../security/StramWSServletRequestWrapper.java  | 25 +++++++++-------
 .../stram/stream/BufferServerPublisher.java     | 25 +++++++++-------
 .../stram/stream/BufferServerSubscriber.java    | 25 +++++++++-------
 .../datatorrent/stram/stream/FastPublisher.java | 25 +++++++++-------
 .../stram/stream/FastSubscriber.java            | 25 +++++++++-------
 .../datatorrent/stram/stream/InlineStream.java  | 25 +++++++++-------
 .../com/datatorrent/stram/stream/MuxStream.java | 25 +++++++++-------
 .../com/datatorrent/stram/stream/OiOStream.java | 25 +++++++++-------
 .../stram/stream/PartitionAwareSink.java        | 25 +++++++++-------
 .../PartitionAwareSinkForPersistence.java       | 18 ++++++++++++
 .../datatorrent/stram/stream/package-info.java  | 25 +++++++++-------
 .../stram/tuple/CheckpointTuple.java            | 25 +++++++++-------
 .../stram/tuple/CodecStateTuple.java            | 25 +++++++++-------
 .../datatorrent/stram/tuple/EndStreamTuple.java | 25 +++++++++-------
 .../datatorrent/stram/tuple/EndWindowTuple.java | 25 +++++++++-------
 .../stram/tuple/ResetWindowTuple.java           | 25 +++++++++-------
 .../java/com/datatorrent/stram/tuple/Tuple.java | 25 +++++++++-------
 .../stram/util/AbstractWritableAdapter.java     | 25 +++++++++-------
 .../com/datatorrent/stram/util/ConfigUtils.java | 25 +++++++++-------
 .../datatorrent/stram/util/ConfigValidator.java | 25 +++++++++-------
 .../stram/util/ExternalizableConf.java          | 25 +++++++++-------
 .../datatorrent/stram/util/FSJsonLineFile.java  | 25 +++++++++-------
 .../stram/util/FSPartFileCollection.java        | 25 +++++++++-------
 .../java/com/datatorrent/stram/util/FSUtil.java | 25 +++++++++-------
 .../stram/util/HeaderClientFilter.java          | 25 +++++++++-------
 .../stram/util/JSONSerializationProvider.java   | 25 +++++++++-------
 .../com/datatorrent/stram/util/LRUCache.java    | 25 +++++++++-------
 .../datatorrent/stram/util/MovingAverage.java   | 25 +++++++++-------
 .../stram/util/ObjectMapperFactory.java         | 25 +++++++++-------
 .../stram/util/PubSubWebSocketServlet.java      | 20 +++++++++++--
 .../datatorrent/stram/util/SecureExecutor.java  | 25 +++++++++-------
 .../stram/util/SharedPubSubWebSocketClient.java | 25 +++++++++-------
 .../stram/util/StablePriorityQueue.java         | 25 +++++++++-------
 .../datatorrent/stram/util/StableWrapper.java   | 25 +++++++++-------
 .../datatorrent/stram/util/StreamGobbler.java   | 25 +++++++++-------
 .../com/datatorrent/stram/util/VersionInfo.java | 25 +++++++++-------
 .../stram/util/WebServicesClient.java           | 25 +++++++++-------
 .../datatorrent/stram/util/package-info.java    | 25 +++++++++-------
 .../com/datatorrent/stram/webapp/AppInfo.java   | 25 +++++++++-------
 .../datatorrent/stram/webapp/ContainerInfo.java | 31 +++++++++-----------
 .../stram/webapp/ContainersInfo.java            | 25 +++++++++-------
 .../stram/webapp/LogicalOperatorInfo.java       | 25 +++++++++-------
 .../stram/webapp/LogicalOperatorsInfo.java      | 25 +++++++++-------
 .../stram/webapp/OperatorAggregationInfo.java   | 25 +++++++++-------
 .../stram/webapp/OperatorDiscoverer.java        | 25 +++++++++-------
 .../datatorrent/stram/webapp/OperatorInfo.java  | 25 +++++++++-------
 .../datatorrent/stram/webapp/OperatorsInfo.java | 25 +++++++++-------
 .../com/datatorrent/stram/webapp/PortInfo.java  | 25 +++++++++-------
 .../datatorrent/stram/webapp/StramWebApp.java   | 25 +++++++++-------
 .../stram/webapp/StramWebServices.java          | 25 +++++++++-------
 .../datatorrent/stram/webapp/StreamInfo.java    | 25 +++++++++-------
 .../datatorrent/stram/webapp/StreamsInfo.java   | 25 +++++++++-------
 .../stram/webapp/TypeDiscoverer.java            | 25 +++++++++-------
 .../com/datatorrent/stram/webapp/TypeGraph.java | 25 +++++++++-------
 .../stram/webapp/TypeGraphFactory.java          | 25 +++++++++-------
 .../datatorrent/stram/webapp/WebServices.java   | 25 +++++++++-------
 .../datatorrent/stram/webapp/asm/ASMUtil.java   | 25 +++++++++-------
 .../stram/webapp/asm/BaseSignatureVisitor.java  | 25 +++++++++-------
 .../stram/webapp/asm/ClassNodeType.java         | 25 +++++++++-------
 .../stram/webapp/asm/ClassSignatureVisitor.java | 25 +++++++++-------
 .../stram/webapp/asm/CompactAnnotationNode.java | 27 +++++++++--------
 .../stram/webapp/asm/CompactClassNode.java      | 25 +++++++++-------
 .../stram/webapp/asm/CompactFieldNode.java      | 27 +++++++++--------
 .../stram/webapp/asm/CompactMethodNode.java     | 25 +++++++++-------
 .../stram/webapp/asm/CompactUtil.java           | 25 +++++++++-------
 .../datatorrent/stram/webapp/asm/FieldNode.java | 25 +++++++++-------
 .../stram/webapp/asm/FieldSignatureVisitor.java | 27 +++++++++--------
 .../stram/webapp/asm/MethodNode.java            | 25 +++++++++-------
 .../webapp/asm/MethodSignatureVisitor.java      | 25 +++++++++-------
 .../com/datatorrent/stram/webapp/asm/Type.java  | 25 +++++++++-------
 .../datatorrent/stram/webapp/package-info.java  | 25 +++++++++-------
 .../java/org/apache/log4j/DTLoggerFactory.java  | 25 +++++++++-------
 engine/src/main/scripts/dtcli                   | 21 ++++++++++---
 .../com/datatorrent/stram/CheckpointTest.java   | 25 +++++++++-------
 .../stram/GenericOperatorPropertyCodecTest.java | 25 +++++++++-------
 .../com/datatorrent/stram/HostLocalTest.java    | 25 +++++++++-------
 .../java/com/datatorrent/stram/InlineAM.java    | 25 +++++++++-------
 .../com/datatorrent/stram/LocalityTest.java     | 25 +++++++++-------
 .../stram/LogicalPlanModificationTest.java      | 25 +++++++++-------
 .../com/datatorrent/stram/MockContainer.java    | 25 +++++++++-------
 .../datatorrent/stram/OutputUnifiedTest.java    | 25 +++++++++-------
 .../com/datatorrent/stram/PartitioningTest.java | 25 +++++++++-------
 .../stram/StramLocalClusterTest.java            | 25 +++++++++-------
 .../datatorrent/stram/StramMiniClusterTest.java | 25 +++++++++-------
 .../datatorrent/stram/StramRecoveryTest.java    | 25 +++++++++-------
 .../com/datatorrent/stram/StreamCodecTest.java  | 25 +++++++++-------
 .../stram/StreamingContainerManagerTest.java    | 25 +++++++++-------
 .../com/datatorrent/stram/cli/DTCliTest.java    | 25 +++++++++-------
 .../stram/client/AppPackageTest.java            | 25 +++++++++-------
 .../stram/client/ClassPathResolverTest.java     | 25 +++++++++-------
 .../stram/client/ConfigPackageTest.java         | 25 +++++++++-------
 .../stram/client/EvalPropertiesTest.java        | 25 +++++++++-------
 .../WebServicesVersionConversionTest.java       | 25 +++++++++-------
 .../codec/DefaultStatefulStreamCodecTest.java   | 25 +++++++++-------
 .../datatorrent/stram/debug/MuxSinkTest.java    | 25 +++++++++-------
 .../stram/debug/TupleRecorderTest.java          | 25 +++++++++-------
 .../stram/engine/AtLeastOnceTest.java           | 25 +++++++++-------
 .../stram/engine/AtMostOnceTest.java            | 25 +++++++++-------
 .../stram/engine/AutoMetricTest.java            | 25 +++++++++-------
 .../stram/engine/ExactlyOnceTest.java           | 25 +++++++++-------
 .../stram/engine/GenericNodeTest.java           | 25 +++++++++-------
 .../stram/engine/GenericOperatorProperty.java   | 25 +++++++++-------
 .../stram/engine/GenericTestOperator.java       | 25 +++++++++-------
 .../stram/engine/InputOperatorTest.java         | 25 +++++++++-------
 .../com/datatorrent/stram/engine/NodeTest.java  | 25 +++++++++-------
 .../stram/engine/ProcessingModeTests.java       | 25 +++++++++-------
 .../stram/engine/RecoverableInputOperator.java  | 25 +++++++++-------
 .../datatorrent/stram/engine/SliderTest.java    | 25 +++++++++-------
 .../com/datatorrent/stram/engine/StatsTest.java | 25 +++++++++-------
 .../stram/engine/StreamingContainerTest.java    | 25 +++++++++-------
 .../stram/engine/TestAppDataQueryOperator.java  | 25 +++++++++-------
 .../stram/engine/TestAppDataResultOperator.java | 25 +++++++++-------
 .../stram/engine/TestAppDataSourceOperator.java | 25 +++++++++-------
 .../engine/TestGeneratorInputOperator.java      | 25 +++++++++-------
 .../TestNonOptionalOutportInputOperator.java    | 25 +++++++++-------
 .../stram/engine/TestOutputOperator.java        | 25 +++++++++-------
 .../com/datatorrent/stram/engine/TestSink.java  | 25 +++++++++-------
 .../stram/engine/WindowGeneratorTest.java       | 25 +++++++++-------
 .../stram/moduleexperiment/InjectConfig.java    | 25 +++++++++-------
 .../moduleexperiment/InjectConfigTest.java      | 25 +++++++++-------
 .../stram/plan/SchemaTestOperator.java          | 25 +++++++++-------
 .../stram/plan/StreamPersistanceTests.java      | 18 ++++++++++++
 .../datatorrent/stram/plan/TestPlanContext.java | 25 +++++++++-------
 .../logical/LogicalPlanConfigurationTest.java   | 25 +++++++++-------
 .../stram/plan/logical/LogicalPlanTest.java     | 25 +++++++++-------
 .../stram/plan/logical/MockStorageAgent.java    | 26 ++++++++--------
 .../stram/plan/physical/PhysicalPlanTest.java   | 25 +++++++++-------
 .../stram/plan/physical/StatsRevisionsTest.java | 25 +++++++++-------
 .../stream/BufferServerSubscriberTest.java      | 25 +++++++++-------
 .../stram/stream/FastPublisherTest.java         | 25 +++++++++-------
 .../stram/stream/FastStreamTest.java            | 25 +++++++++-------
 .../stram/stream/InlineStreamTest.java          | 25 +++++++++-------
 .../stram/stream/OiOEndWindowTest.java          | 25 +++++++++-------
 .../datatorrent/stram/stream/OiOStreamTest.java | 25 +++++++++-------
 .../stram/stream/SocketStreamTest.java          | 25 +++++++++-------
 .../support/ManualScheduledExecutorService.java | 25 +++++++++-------
 .../stram/support/StramTestSupport.java         | 25 +++++++++-------
 .../stram/util/StablePriorityQueueTest.java     | 25 +++++++++-------
 .../datatorrent/stram/util/VersionInfoTest.java | 25 +++++++++-------
 .../stram/webapp/OperatorDiscoveryTest.java     | 25 +++++++++-------
 .../stram/webapp/StramWebServicesTest.java      | 25 +++++++++-------
 .../stram/webapp/TypeDiscoveryTest.java         | 25 +++++++++-------
 .../org/apache/log4j/DTLoggerFactoryTest.java   | 25 +++++++++-------
 .../test/resources/clusterTest.app.properties   | 19 ++++++++++++
 engine/src/test/resources/dt-site.xml           | 20 +++++++++++++
 engine/src/test/resources/log4j.properties      | 19 ++++++++++++
 .../resources/testAppPackage/.dt/dt-site.xml    | 20 +++++++++++++
 .../resources/testAppPackage/local-conf.xml     | 20 +++++++++++++
 .../resources/testAppPackage/mydtapp/pom.xml    | 20 +++++++++++++
 .../mydtapp/src/assemble/appPackage.xml         | 20 +++++++++++++
 .../java/com/example/mydtapp/Application.java   | 17 ++++++++++-
 .../example/mydtapp/RandomNumberGenerator.java  | 18 ++++++++++++
 .../com/example/mydtapp/StdoutOperator.java     | 18 ++++++++++++
 .../META-INF/properties-MyFirstApplication.xml  | 20 +++++++++++++
 .../src/main/resources/META-INF/properties.xml  | 20 +++++++++++++
 .../example/mydtapp/StdoutOperator/ExtRes.html  | 20 +++++++++++++
 .../mydtapp/src/site/conf/my-app-conf1.xml      | 20 +++++++++++++
 .../com/example/mydtapp/ApplicationTest.java    | 17 ++++++++++-
 .../mydtapp/src/test/resources/log4j.properties | 19 ++++++++++++
 .../META-INF/properties-MyFirstApplication.xml  | 20 +++++++++++++
 .../META-INF/properties-app1.xml                | 20 +++++++++++++
 .../META-INF/properties.xml                     | 20 +++++++++++++
 .../classpath/xyz.properties                    | 19 ++++++++++++
 .../src/test/resources/testTopology.properties  | 19 ++++++++++++
 engine/src/test/resources/yarn-site.xml         | 20 +++++++++++++
 pom.xml                                         | 20 +++++++++++++
 420 files changed, 6116 insertions(+), 4162 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-apex-core/blob/730e57f7/apex-app-archetype/pom.xml
----------------------------------------------------------------------
diff --git a/apex-app-archetype/pom.xml b/apex-app-archetype/pom.xml
index b0a7a15..7c9f332 100644
--- a/apex-app-archetype/pom.xml
+++ b/apex-app-archetype/pom.xml
@@ -1,4 +1,24 @@
 <?xml version="1.0" encoding="UTF-8"?>
+<!--
+
+    Licensed to the Apache Software Foundation (ASF) under one
+    or more contributor license agreements.  See the NOTICE file
+    distributed with this work for additional information
+    regarding copyright ownership.  The ASF licenses this file
+    to you under the Apache License, Version 2.0 (the
+    "License"); you may not use this file except in compliance
+    with the License.  You may obtain a copy of the License at
+
+      http://www.apache.org/licenses/LICENSE-2.0
+
+    Unless required by applicable law or agreed to in writing,
+    software distributed under the License is distributed on an
+    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+    KIND, either express or implied.  See the License for the
+    specific language governing permissions and limitations
+    under the License.
+
+-->
 <project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
   <modelVersion>4.0.0</modelVersion>
 

http://git-wip-us.apache.org/repos/asf/incubator-apex-core/blob/730e57f7/apex-app-archetype/src/main/resources/META-INF/maven/archetype-metadata.xml
----------------------------------------------------------------------
diff --git a/apex-app-archetype/src/main/resources/META-INF/maven/archetype-metadata.xml b/apex-app-archetype/src/main/resources/META-INF/maven/archetype-metadata.xml
index d60b35b..c93a8d9 100644
--- a/apex-app-archetype/src/main/resources/META-INF/maven/archetype-metadata.xml
+++ b/apex-app-archetype/src/main/resources/META-INF/maven/archetype-metadata.xml
@@ -1,4 +1,24 @@
 <?xml version="1.0" encoding="UTF-8"?>
+<!--
+
+    Licensed to the Apache Software Foundation (ASF) under one
+    or more contributor license agreements.  See the NOTICE file
+    distributed with this work for additional information
+    regarding copyright ownership.  The ASF licenses this file
+    to you under the Apache License, Version 2.0 (the
+    "License"); you may not use this file except in compliance
+    with the License.  You may obtain a copy of the License at
+
+      http://www.apache.org/licenses/LICENSE-2.0
+
+    Unless required by applicable law or agreed to in writing,
+    software distributed under the License is distributed on an
+    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+    KIND, either express or implied.  See the License for the
+    specific language governing permissions and limitations
+    under the License.
+
+-->
 <archetype-descriptor xsi:schemaLocation="http://maven.apache.org/plugins/maven-archetype-plugin/archetype-descriptor/1.0.0 http://maven.apache.org/xsd/archetype-descriptor-1.0.0.xsd" name="apex-app-archetype"
     xmlns="http://maven.apache.org/plugins/maven-archetype-plugin/archetype-descriptor/1.0.0"
     xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance">

http://git-wip-us.apache.org/repos/asf/incubator-apex-core/blob/730e57f7/apex-app-archetype/src/main/resources/META-INF/maven/archetype.xml
----------------------------------------------------------------------
diff --git a/apex-app-archetype/src/main/resources/META-INF/maven/archetype.xml b/apex-app-archetype/src/main/resources/META-INF/maven/archetype.xml
index 18a0ad8..757b6c1 100644
--- a/apex-app-archetype/src/main/resources/META-INF/maven/archetype.xml
+++ b/apex-app-archetype/src/main/resources/META-INF/maven/archetype.xml
@@ -1,3 +1,23 @@
+<!--
+
+    Licensed to the Apache Software Foundation (ASF) under one
+    or more contributor license agreements.  See the NOTICE file
+    distributed with this work for additional information
+    regarding copyright ownership.  The ASF licenses this file
+    to you under the Apache License, Version 2.0 (the
+    "License"); you may not use this file except in compliance
+    with the License.  You may obtain a copy of the License at
+
+      http://www.apache.org/licenses/LICENSE-2.0
+
+    Unless required by applicable law or agreed to in writing,
+    software distributed under the License is distributed on an
+    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+    KIND, either express or implied.  See the License for the
+    specific language governing permissions and limitations
+    under the License.
+
+-->
 #set( $symbol_pound = '#' )
 #set( $symbol_dollar = '$' )
 #set( $symbol_escape = '\' )

http://git-wip-us.apache.org/repos/asf/incubator-apex-core/blob/730e57f7/apex-app-archetype/src/test/resources/projects/basic/archetype.properties
----------------------------------------------------------------------
diff --git a/apex-app-archetype/src/test/resources/projects/basic/archetype.properties b/apex-app-archetype/src/test/resources/projects/basic/archetype.properties
index a5faf73..7b03fd1 100644
--- a/apex-app-archetype/src/test/resources/projects/basic/archetype.properties
+++ b/apex-app-archetype/src/test/resources/projects/basic/archetype.properties
@@ -1,3 +1,22 @@
+#
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+#
+
 #Wed Jul 02 18:52:59 PDT 2014
 package=it.pkg
 version=0.1-SNAPSHOT

http://git-wip-us.apache.org/repos/asf/incubator-apex-core/blob/730e57f7/apex-conf-archetype/pom.xml
----------------------------------------------------------------------
diff --git a/apex-conf-archetype/pom.xml b/apex-conf-archetype/pom.xml
index 1bebb43..e5b4d3e 100644
--- a/apex-conf-archetype/pom.xml
+++ b/apex-conf-archetype/pom.xml
@@ -1,4 +1,24 @@
 <?xml version="1.0" encoding="UTF-8"?>
+<!--
+
+    Licensed to the Apache Software Foundation (ASF) under one
+    or more contributor license agreements.  See the NOTICE file
+    distributed with this work for additional information
+    regarding copyright ownership.  The ASF licenses this file
+    to you under the Apache License, Version 2.0 (the
+    "License"); you may not use this file except in compliance
+    with the License.  You may obtain a copy of the License at
+
+      http://www.apache.org/licenses/LICENSE-2.0
+
+    Unless required by applicable law or agreed to in writing,
+    software distributed under the License is distributed on an
+    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+    KIND, either express or implied.  See the License for the
+    specific language governing permissions and limitations
+    under the License.
+
+-->
 <project xmlns="http://maven.apache.org/POM/4.0.0" xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance" xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd">
   <modelVersion>4.0.0</modelVersion>
 

http://git-wip-us.apache.org/repos/asf/incubator-apex-core/blob/730e57f7/apex-conf-archetype/src/main/resources/META-INF/maven/archetype-metadata.xml
----------------------------------------------------------------------
diff --git a/apex-conf-archetype/src/main/resources/META-INF/maven/archetype-metadata.xml b/apex-conf-archetype/src/main/resources/META-INF/maven/archetype-metadata.xml
index b367bd6..d739c53 100644
--- a/apex-conf-archetype/src/main/resources/META-INF/maven/archetype-metadata.xml
+++ b/apex-conf-archetype/src/main/resources/META-INF/maven/archetype-metadata.xml
@@ -1,4 +1,24 @@
 <?xml version="1.0" encoding="UTF-8"?>
+<!--
+
+    Licensed to the Apache Software Foundation (ASF) under one
+    or more contributor license agreements.  See the NOTICE file
+    distributed with this work for additional information
+    regarding copyright ownership.  The ASF licenses this file
+    to you under the Apache License, Version 2.0 (the
+    "License"); you may not use this file except in compliance
+    with the License.  You may obtain a copy of the License at
+
+      http://www.apache.org/licenses/LICENSE-2.0
+
+    Unless required by applicable law or agreed to in writing,
+    software distributed under the License is distributed on an
+    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+    KIND, either express or implied.  See the License for the
+    specific language governing permissions and limitations
+    under the License.
+
+-->
 <archetype-descriptor xsi:schemaLocation="http://maven.apache.org/plugins/maven-archetype-plugin/archetype-descriptor/1.0.0 http://maven.apache.org/xsd/archetype-descriptor-1.0.0.xsd" name="apex-app-archetype"
     xmlns="http://maven.apache.org/plugins/maven-archetype-plugin/archetype-descriptor/1.0.0"
     xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance">

http://git-wip-us.apache.org/repos/asf/incubator-apex-core/blob/730e57f7/apex-conf-archetype/src/main/resources/META-INF/maven/archetype.xml
----------------------------------------------------------------------
diff --git a/apex-conf-archetype/src/main/resources/META-INF/maven/archetype.xml b/apex-conf-archetype/src/main/resources/META-INF/maven/archetype.xml
index 208bc6f..728c76e 100644
--- a/apex-conf-archetype/src/main/resources/META-INF/maven/archetype.xml
+++ b/apex-conf-archetype/src/main/resources/META-INF/maven/archetype.xml
@@ -1,3 +1,23 @@
+<!--
+
+    Licensed to the Apache Software Foundation (ASF) under one
+    or more contributor license agreements.  See the NOTICE file
+    distributed with this work for additional information
+    regarding copyright ownership.  The ASF licenses this file
+    to you under the Apache License, Version 2.0 (the
+    "License"); you may not use this file except in compliance
+    with the License.  You may obtain a copy of the License at
+
+      http://www.apache.org/licenses/LICENSE-2.0
+
+    Unless required by applicable law or agreed to in writing,
+    software distributed under the License is distributed on an
+    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+    KIND, either express or implied.  See the License for the
+    specific language governing permissions and limitations
+    under the License.
+
+-->
 #set( $symbol_pound = '#' )
 #set( $symbol_dollar = '$' )
 #set( $symbol_escape = '\' )

http://git-wip-us.apache.org/repos/asf/incubator-apex-core/blob/730e57f7/apex-conf-archetype/src/test/resources/projects/basic/archetype.properties
----------------------------------------------------------------------
diff --git a/apex-conf-archetype/src/test/resources/projects/basic/archetype.properties b/apex-conf-archetype/src/test/resources/projects/basic/archetype.properties
index a5faf73..7b03fd1 100644
--- a/apex-conf-archetype/src/test/resources/projects/basic/archetype.properties
+++ b/apex-conf-archetype/src/test/resources/projects/basic/archetype.properties
@@ -1,3 +1,22 @@
+#
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+#   http://www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing,
+# software distributed under the License is distributed on an
+# "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+# KIND, either express or implied.  See the License for the
+# specific language governing permissions and limitations
+# under the License.
+#
+
 #Wed Jul 02 18:52:59 PDT 2014
 package=it.pkg
 version=0.1-SNAPSHOT

http://git-wip-us.apache.org/repos/asf/incubator-apex-core/blob/730e57f7/apex_checks.xml
----------------------------------------------------------------------
diff --git a/apex_checks.xml b/apex_checks.xml
index f7967e6..b4b3277 100644
--- a/apex_checks.xml
+++ b/apex_checks.xml
@@ -1,4 +1,24 @@
 <?xml version="1.0"?>
+<!--
+
+    Licensed to the Apache Software Foundation (ASF) under one
+    or more contributor license agreements.  See the NOTICE file
+    distributed with this work for additional information
+    regarding copyright ownership.  The ASF licenses this file
+    to you under the Apache License, Version 2.0 (the
+    "License"); you may not use this file except in compliance
+    with the License.  You may obtain a copy of the License at
+
+      http://www.apache.org/licenses/LICENSE-2.0
+
+    Unless required by applicable law or agreed to in writing,
+    software distributed under the License is distributed on an
+    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+    KIND, either express or implied.  See the License for the
+    specific language governing permissions and limitations
+    under the License.
+
+-->
 <!DOCTYPE module PUBLIC
   "-//Puppy Crawl//DTD Check Configuration 1.3//EN"
   "http://www.puppycrawl.com/dtds/configuration_1_3.dtd">

http://git-wip-us.apache.org/repos/asf/incubator-apex-core/blob/730e57f7/api/pom.xml
----------------------------------------------------------------------
diff --git a/api/pom.xml b/api/pom.xml
index 70b3c65..52fc5a7 100644
--- a/api/pom.xml
+++ b/api/pom.xml
@@ -1,4 +1,24 @@
 <?xml version="1.0"?>
+<!--
+
+    Licensed to the Apache Software Foundation (ASF) under one
+    or more contributor license agreements.  See the NOTICE file
+    distributed with this work for additional information
+    regarding copyright ownership.  The ASF licenses this file
+    to you under the Apache License, Version 2.0 (the
+    "License"); you may not use this file except in compliance
+    with the License.  You may obtain a copy of the License at
+
+      http://www.apache.org/licenses/LICENSE-2.0
+
+    Unless required by applicable law or agreed to in writing,
+    software distributed under the License is distributed on an
+    "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+    KIND, either express or implied.  See the License for the
+    specific language governing permissions and limitations
+    under the License.
+
+-->
 <project xsi:schemaLocation="http://maven.apache.org/POM/4.0.0 http://maven.apache.org/xsd/maven-4.0.0.xsd" xmlns="http://maven.apache.org/POM/4.0.0"
          xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance">
   <modelVersion>4.0.0</modelVersion>

http://git-wip-us.apache.org/repos/asf/incubator-apex-core/blob/730e57f7/api/src/main/java/com/datatorrent/api/Attribute.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/com/datatorrent/api/Attribute.java b/api/src/main/java/com/datatorrent/api/Attribute.java
index a7492b5..459d719 100644
--- a/api/src/main/java/com/datatorrent/api/Attribute.java
+++ b/api/src/main/java/com/datatorrent/api/Attribute.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2015 DataTorrent, 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.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.datatorrent.api;
 

http://git-wip-us.apache.org/repos/asf/incubator-apex-core/blob/730e57f7/api/src/main/java/com/datatorrent/api/AutoMetric.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/com/datatorrent/api/AutoMetric.java b/api/src/main/java/com/datatorrent/api/AutoMetric.java
index 61e8dd0..ddf99c6 100644
--- a/api/src/main/java/com/datatorrent/api/AutoMetric.java
+++ b/api/src/main/java/com/datatorrent/api/AutoMetric.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2015 DataTorrent, 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.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.datatorrent.api;
 

http://git-wip-us.apache.org/repos/asf/incubator-apex-core/blob/730e57f7/api/src/main/java/com/datatorrent/api/Component.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/com/datatorrent/api/Component.java b/api/src/main/java/com/datatorrent/api/Component.java
index 137b737..f15d6de 100644
--- a/api/src/main/java/com/datatorrent/api/Component.java
+++ b/api/src/main/java/com/datatorrent/api/Component.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2015 DataTorrent, 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.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.datatorrent.api;
 

http://git-wip-us.apache.org/repos/asf/incubator-apex-core/blob/730e57f7/api/src/main/java/com/datatorrent/api/Context.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/com/datatorrent/api/Context.java b/api/src/main/java/com/datatorrent/api/Context.java
index cd10398..2054920 100644
--- a/api/src/main/java/com/datatorrent/api/Context.java
+++ b/api/src/main/java/com/datatorrent/api/Context.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2015 DataTorrent, 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.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.datatorrent.api;
 

http://git-wip-us.apache.org/repos/asf/incubator-apex-core/blob/730e57f7/api/src/main/java/com/datatorrent/api/DAG.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/com/datatorrent/api/DAG.java b/api/src/main/java/com/datatorrent/api/DAG.java
index 9c6c492..6b1d1b2 100644
--- a/api/src/main/java/com/datatorrent/api/DAG.java
+++ b/api/src/main/java/com/datatorrent/api/DAG.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2015 DataTorrent, 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.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.datatorrent.api;
 

http://git-wip-us.apache.org/repos/asf/incubator-apex-core/blob/730e57f7/api/src/main/java/com/datatorrent/api/DefaultInputPort.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/com/datatorrent/api/DefaultInputPort.java b/api/src/main/java/com/datatorrent/api/DefaultInputPort.java
index 25fe596..e3998f0 100644
--- a/api/src/main/java/com/datatorrent/api/DefaultInputPort.java
+++ b/api/src/main/java/com/datatorrent/api/DefaultInputPort.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2015 DataTorrent, 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.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.datatorrent.api;
 

http://git-wip-us.apache.org/repos/asf/incubator-apex-core/blob/730e57f7/api/src/main/java/com/datatorrent/api/DefaultOutputPort.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/com/datatorrent/api/DefaultOutputPort.java b/api/src/main/java/com/datatorrent/api/DefaultOutputPort.java
index b5eebd1..d145657 100644
--- a/api/src/main/java/com/datatorrent/api/DefaultOutputPort.java
+++ b/api/src/main/java/com/datatorrent/api/DefaultOutputPort.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2015 DataTorrent, 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.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.datatorrent.api;
 

http://git-wip-us.apache.org/repos/asf/incubator-apex-core/blob/730e57f7/api/src/main/java/com/datatorrent/api/DefaultPartition.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/com/datatorrent/api/DefaultPartition.java b/api/src/main/java/com/datatorrent/api/DefaultPartition.java
index d149d85..222f44e 100644
--- a/api/src/main/java/com/datatorrent/api/DefaultPartition.java
+++ b/api/src/main/java/com/datatorrent/api/DefaultPartition.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2015 DataTorrent, 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.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.datatorrent.api;
 

http://git-wip-us.apache.org/repos/asf/incubator-apex-core/blob/730e57f7/api/src/main/java/com/datatorrent/api/InputOperator.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/com/datatorrent/api/InputOperator.java b/api/src/main/java/com/datatorrent/api/InputOperator.java
index 43f48dc..e6a0a65 100644
--- a/api/src/main/java/com/datatorrent/api/InputOperator.java
+++ b/api/src/main/java/com/datatorrent/api/InputOperator.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2015 DataTorrent, 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.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.datatorrent.api;
 

http://git-wip-us.apache.org/repos/asf/incubator-apex-core/blob/730e57f7/api/src/main/java/com/datatorrent/api/LocalMode.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/com/datatorrent/api/LocalMode.java b/api/src/main/java/com/datatorrent/api/LocalMode.java
index 06f1277..0115f2a 100644
--- a/api/src/main/java/com/datatorrent/api/LocalMode.java
+++ b/api/src/main/java/com/datatorrent/api/LocalMode.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2015 DataTorrent, 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.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.datatorrent.api;
 

http://git-wip-us.apache.org/repos/asf/incubator-apex-core/blob/730e57f7/api/src/main/java/com/datatorrent/api/Operator.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/com/datatorrent/api/Operator.java b/api/src/main/java/com/datatorrent/api/Operator.java
index e26b37a..c362159 100644
--- a/api/src/main/java/com/datatorrent/api/Operator.java
+++ b/api/src/main/java/com/datatorrent/api/Operator.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2015 DataTorrent, 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.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.datatorrent.api;
 

http://git-wip-us.apache.org/repos/asf/incubator-apex-core/blob/730e57f7/api/src/main/java/com/datatorrent/api/Partitioner.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/com/datatorrent/api/Partitioner.java b/api/src/main/java/com/datatorrent/api/Partitioner.java
index 08fb0fd..1627c51 100644
--- a/api/src/main/java/com/datatorrent/api/Partitioner.java
+++ b/api/src/main/java/com/datatorrent/api/Partitioner.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2015 DataTorrent, 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.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.datatorrent.api;
 

http://git-wip-us.apache.org/repos/asf/incubator-apex-core/blob/730e57f7/api/src/main/java/com/datatorrent/api/Sink.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/com/datatorrent/api/Sink.java b/api/src/main/java/com/datatorrent/api/Sink.java
index 73ec666..1e7b1b3 100644
--- a/api/src/main/java/com/datatorrent/api/Sink.java
+++ b/api/src/main/java/com/datatorrent/api/Sink.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2015 DataTorrent, 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.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.datatorrent.api;
 

http://git-wip-us.apache.org/repos/asf/incubator-apex-core/blob/730e57f7/api/src/main/java/com/datatorrent/api/Stats.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/com/datatorrent/api/Stats.java b/api/src/main/java/com/datatorrent/api/Stats.java
index 1e7f3c1..3ba1402 100644
--- a/api/src/main/java/com/datatorrent/api/Stats.java
+++ b/api/src/main/java/com/datatorrent/api/Stats.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2015 DataTorrent, 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.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.datatorrent.api;
 

http://git-wip-us.apache.org/repos/asf/incubator-apex-core/blob/730e57f7/api/src/main/java/com/datatorrent/api/StatsListener.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/com/datatorrent/api/StatsListener.java b/api/src/main/java/com/datatorrent/api/StatsListener.java
index 1bc65a1..38b93cd 100644
--- a/api/src/main/java/com/datatorrent/api/StatsListener.java
+++ b/api/src/main/java/com/datatorrent/api/StatsListener.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2015 DataTorrent, 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.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.datatorrent.api;
 

http://git-wip-us.apache.org/repos/asf/incubator-apex-core/blob/730e57f7/api/src/main/java/com/datatorrent/api/StorageAgent.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/com/datatorrent/api/StorageAgent.java b/api/src/main/java/com/datatorrent/api/StorageAgent.java
index 10b8888..e155ed3 100644
--- a/api/src/main/java/com/datatorrent/api/StorageAgent.java
+++ b/api/src/main/java/com/datatorrent/api/StorageAgent.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2015 DataTorrent, 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.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.datatorrent.api;
 

http://git-wip-us.apache.org/repos/asf/incubator-apex-core/blob/730e57f7/api/src/main/java/com/datatorrent/api/StreamCodec.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/com/datatorrent/api/StreamCodec.java b/api/src/main/java/com/datatorrent/api/StreamCodec.java
index d85ec9f..a097dc9 100644
--- a/api/src/main/java/com/datatorrent/api/StreamCodec.java
+++ b/api/src/main/java/com/datatorrent/api/StreamCodec.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2015 DataTorrent, 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.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.datatorrent.api;
 

http://git-wip-us.apache.org/repos/asf/incubator-apex-core/blob/730e57f7/api/src/main/java/com/datatorrent/api/StreamingApplication.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/com/datatorrent/api/StreamingApplication.java b/api/src/main/java/com/datatorrent/api/StreamingApplication.java
index 6aa9a84..f4ecd4a 100644
--- a/api/src/main/java/com/datatorrent/api/StreamingApplication.java
+++ b/api/src/main/java/com/datatorrent/api/StreamingApplication.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2015 DataTorrent, 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.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.datatorrent.api;
 

http://git-wip-us.apache.org/repos/asf/incubator-apex-core/blob/730e57f7/api/src/main/java/com/datatorrent/api/StringCodec.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/com/datatorrent/api/StringCodec.java b/api/src/main/java/com/datatorrent/api/StringCodec.java
index 22e0a3e..b19d15e 100644
--- a/api/src/main/java/com/datatorrent/api/StringCodec.java
+++ b/api/src/main/java/com/datatorrent/api/StringCodec.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2015 DataTorrent, 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.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.datatorrent.api;
 

http://git-wip-us.apache.org/repos/asf/incubator-apex-core/blob/730e57f7/api/src/main/java/com/datatorrent/api/annotation/ApplicationAnnotation.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/com/datatorrent/api/annotation/ApplicationAnnotation.java b/api/src/main/java/com/datatorrent/api/annotation/ApplicationAnnotation.java
index 7d9e3fe..b568ade 100644
--- a/api/src/main/java/com/datatorrent/api/annotation/ApplicationAnnotation.java
+++ b/api/src/main/java/com/datatorrent/api/annotation/ApplicationAnnotation.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2015 DataTorrent, 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.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.datatorrent.api.annotation;
 

http://git-wip-us.apache.org/repos/asf/incubator-apex-core/blob/730e57f7/api/src/main/java/com/datatorrent/api/annotation/InputPortFieldAnnotation.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/com/datatorrent/api/annotation/InputPortFieldAnnotation.java b/api/src/main/java/com/datatorrent/api/annotation/InputPortFieldAnnotation.java
index 2734bf6..c247c82 100644
--- a/api/src/main/java/com/datatorrent/api/annotation/InputPortFieldAnnotation.java
+++ b/api/src/main/java/com/datatorrent/api/annotation/InputPortFieldAnnotation.java
@@ -1,17 +1,20 @@
 /**
- * Copyright (C) 2015 DataTorrent, 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.
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.datatorrent.api.annotation;
 

http://git-wip-us.apache.org/repos/asf/incubator-apex-core/blob/730e57f7/api/src/main/java/com/datatorrent/api/annotation/Name.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/com/datatorrent/api/annotation/Name.java b/api/src/main/java/com/datatorrent/api/annotation/Name.java
index 2ad7683..a93f59c 100644
--- a/api/src/main/java/com/datatorrent/api/annotation/Name.java
+++ b/api/src/main/java/com/datatorrent/api/annotation/Name.java
@@ -1,19 +1,20 @@
 /**
- * Copyright (C) 2015 DataTorrent, 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.
- *
- * @since 3.0.0
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
  */
 package com.datatorrent.api.annotation;