You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@storm.apache.org by pt...@apache.org on 2013/12/13 18:14:54 UTC

[10/18] git commit: add Apache license headers to source files

add Apache license headers to source files


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

Branch: refs/heads/master
Commit: 731a8e517eee130aed7648033e7726ee0025c91e
Parents: 1bcc169
Author: P. Taylor Goetz <pt...@gmail.com>
Authored: Mon Dec 9 16:45:13 2013 -0500
Committer: P. Taylor Goetz <pt...@gmail.com>
Committed: Mon Dec 9 16:45:13 2013 -0500

----------------------------------------------------------------------
 bin/build_modules.sh                            |  16 ++
 bin/build_release.sh                            |  17 ++
 bin/install_zmq.sh                              |  17 ++
 bin/javadoc.sh                                  |  16 ++
 bin/storm                                       |  16 ++
 bin/to_maven.sh                                 |  17 ++
 conf/defaults.yaml                              |  18 ++
 conf/jaas_digest.conf                           |  18 ++
 conf/logback.xml                                |  17 +-
 conf/storm.yaml.example                         |  16 ++
 logback/cluster.xml                             |  18 +-
 project.clj                                     |  15 ++
 storm-console-logging/project.clj               |  15 ++
 storm-core/project.clj                          |  15 ++
 .../src/clj/backtype/storm/LocalCluster.clj     |  15 ++
 storm-core/src/clj/backtype/storm/LocalDRPC.clj |  15 ++
 storm-core/src/clj/backtype/storm/bootstrap.clj |  15 ++
 storm-core/src/clj/backtype/storm/clojure.clj   |  15 ++
 storm-core/src/clj/backtype/storm/cluster.clj   |  15 ++
 .../src/clj/backtype/storm/command/activate.clj |  15 ++
 .../clj/backtype/storm/command/config_value.clj |  15 ++
 .../clj/backtype/storm/command/deactivate.clj   |  15 ++
 .../backtype/storm/command/dev_zookeeper.clj    |  15 ++
 .../backtype/storm/command/kill_topology.clj    |  15 ++
 .../src/clj/backtype/storm/command/list.clj     |  15 ++
 .../clj/backtype/storm/command/rebalance.clj    |  15 ++
 .../backtype/storm/command/shell_submission.clj |  15 ++
 storm-core/src/clj/backtype/storm/config.clj    |  15 ++
 .../src/clj/backtype/storm/daemon/acker.clj     |  15 ++
 .../backtype/storm/daemon/builtin_metrics.clj   |  15 ++
 .../src/clj/backtype/storm/daemon/common.clj    |  15 ++
 .../src/clj/backtype/storm/daemon/drpc.clj      |  19 +-
 .../src/clj/backtype/storm/daemon/executor.clj  |  15 ++
 .../src/clj/backtype/storm/daemon/logviewer.clj |  15 ++
 .../src/clj/backtype/storm/daemon/nimbus.clj    |  15 ++
 .../clj/backtype/storm/daemon/supervisor.clj    |  15 ++
 .../src/clj/backtype/storm/daemon/task.clj      |  15 ++
 .../src/clj/backtype/storm/daemon/worker.clj    |  15 ++
 storm-core/src/clj/backtype/storm/disruptor.clj |  15 ++
 storm-core/src/clj/backtype/storm/event.clj     |  15 ++
 storm-core/src/clj/backtype/storm/log.clj       |  15 ++
 .../src/clj/backtype/storm/messaging/loader.clj |  15 ++
 .../src/clj/backtype/storm/messaging/local.clj  |  15 ++
 .../src/clj/backtype/storm/messaging/zmq.clj    |  15 ++
 .../src/clj/backtype/storm/metric/testing.clj   |  15 ++
 .../clj/backtype/storm/process_simulator.clj    |  15 ++
 .../storm/scheduler/DefaultScheduler.clj        |  15 ++
 .../backtype/storm/scheduler/EvenScheduler.clj  |  15 ++
 .../storm/scheduler/IsolationScheduler.clj      |  15 ++
 storm-core/src/clj/backtype/storm/stats.clj     |  15 ++
 storm-core/src/clj/backtype/storm/testing.clj   |  15 ++
 storm-core/src/clj/backtype/storm/testing4j.clj |  15 ++
 storm-core/src/clj/backtype/storm/thrift.clj    |  15 ++
 storm-core/src/clj/backtype/storm/timer.clj     |  15 ++
 storm-core/src/clj/backtype/storm/tuple.clj     |  15 ++
 storm-core/src/clj/backtype/storm/ui/core.clj   |  15 ++
 .../src/clj/backtype/storm/ui/helpers.clj       |  15 ++
 storm-core/src/clj/backtype/storm/util.clj      |  15 ++
 storm-core/src/clj/backtype/storm/zookeeper.clj |  15 ++
 storm-core/src/clj/storm/trident/testing.clj    |  15 ++
 storm-core/src/clj/zilch/mq.clj                 |  15 ++
 storm-core/src/dev/resources/tester_bolt.py     |  16 ++
 storm-core/src/dev/resources/tester_bolt.rb     |  16 ++
 storm-core/src/dev/resources/tester_spout.py    |  16 ++
 storm-core/src/dev/resources/tester_spout.rb    |  16 ++
 storm-core/src/genthrift.sh                     |  16 ++
 storm-core/src/jvm/backtype/storm/Config.java   |  17 ++
 .../jvm/backtype/storm/ConfigValidation.java    |  17 ++
 .../src/jvm/backtype/storm/Constants.java       |  17 ++
 .../src/jvm/backtype/storm/ILocalCluster.java   |  17 ++
 .../src/jvm/backtype/storm/ILocalDRPC.java      |  17 ++
 .../src/jvm/backtype/storm/StormSubmitter.java  |  17 ++
 .../jvm/backtype/storm/clojure/ClojureBolt.java |  17 ++
 .../backtype/storm/clojure/ClojureSpout.java    |  17 ++
 .../backtype/storm/clojure/RichShellBolt.java   |  17 ++
 .../backtype/storm/clojure/RichShellSpout.java  |  17 ++
 .../storm/coordination/BatchBoltExecutor.java   |  17 ++
 .../coordination/BatchOutputCollector.java      |  17 ++
 .../coordination/BatchOutputCollectorImpl.java  |  17 ++
 .../coordination/BatchSubtopologyBuilder.java   |  17 ++
 .../storm/coordination/CoordinatedBolt.java     |  17 ++
 .../backtype/storm/coordination/IBatchBolt.java |  17 ++
 .../jvm/backtype/storm/daemon/Shutdownable.java |  17 ++
 .../storm/drpc/DRPCInvocationsClient.java       |  17 ++
 .../src/jvm/backtype/storm/drpc/DRPCSpout.java  |  17 ++
 .../src/jvm/backtype/storm/drpc/JoinResult.java |  17 ++
 .../jvm/backtype/storm/drpc/KeyedFairBolt.java  |  17 ++
 .../storm/drpc/LinearDRPCInputDeclarer.java     |  17 ++
 .../storm/drpc/LinearDRPCTopologyBuilder.java   |  17 ++
 .../jvm/backtype/storm/drpc/PrepareRequest.java |  17 ++
 .../jvm/backtype/storm/drpc/ReturnResults.java  |  17 ++
 .../storm/generated/AlreadyAliveException.java  |  17 ++
 .../src/jvm/backtype/storm/generated/Bolt.java  |  17 ++
 .../jvm/backtype/storm/generated/BoltStats.java |  17 ++
 .../storm/generated/ClusterSummary.java         |  17 ++
 .../storm/generated/ComponentCommon.java        |  17 ++
 .../storm/generated/ComponentObject.java        |  17 ++
 .../storm/generated/DRPCExecutionException.java |  17 ++
 .../backtype/storm/generated/DRPCRequest.java   |  17 ++
 .../storm/generated/DistributedRPC.java         |  17 ++
 .../generated/DistributedRPCInvocations.java    |  17 ++
 .../jvm/backtype/storm/generated/ErrorInfo.java |  17 ++
 .../backtype/storm/generated/ExecutorInfo.java  |  17 ++
 .../storm/generated/ExecutorSpecificStats.java  |  17 ++
 .../backtype/storm/generated/ExecutorStats.java |  17 ++
 .../storm/generated/ExecutorSummary.java        |  17 ++
 .../storm/generated/GlobalStreamId.java         |  17 ++
 .../jvm/backtype/storm/generated/Grouping.java  |  17 ++
 .../generated/InvalidTopologyException.java     |  17 ++
 .../backtype/storm/generated/JavaObject.java    |  17 ++
 .../backtype/storm/generated/JavaObjectArg.java |  17 ++
 .../backtype/storm/generated/KillOptions.java   |  17 ++
 .../jvm/backtype/storm/generated/Nimbus.java    |  17 ++
 .../storm/generated/NotAliveException.java      |  17 ++
 .../backtype/storm/generated/NullStruct.java    |  17 ++
 .../storm/generated/RebalanceOptions.java       |  17 ++
 .../storm/generated/ShellComponent.java         |  17 ++
 .../jvm/backtype/storm/generated/SpoutSpec.java |  17 ++
 .../backtype/storm/generated/SpoutStats.java    |  17 ++
 .../storm/generated/StateSpoutSpec.java         |  17 ++
 .../backtype/storm/generated/StormTopology.java |  17 ++
 .../backtype/storm/generated/StreamInfo.java    |  17 ++
 .../backtype/storm/generated/SubmitOptions.java |  17 ++
 .../storm/generated/SupervisorSummary.java      |  17 ++
 .../backtype/storm/generated/TopologyInfo.java  |  17 ++
 .../storm/generated/TopologyInitialStatus.java  |  17 ++
 .../storm/generated/TopologySummary.java        |  17 ++
 .../storm/grouping/CustomStreamGrouping.java    |  17 ++
 .../jvm/backtype/storm/hooks/BaseTaskHook.java  |  17 ++
 .../src/jvm/backtype/storm/hooks/ITaskHook.java |  17 ++
 .../backtype/storm/hooks/info/BoltAckInfo.java  |  17 ++
 .../storm/hooks/info/BoltExecuteInfo.java       |  17 ++
 .../backtype/storm/hooks/info/BoltFailInfo.java |  17 ++
 .../jvm/backtype/storm/hooks/info/EmitInfo.java |  17 ++
 .../backtype/storm/hooks/info/SpoutAckInfo.java |  17 ++
 .../storm/hooks/info/SpoutFailInfo.java         |  17 ++
 .../backtype/storm/messaging/IConnection.java   |  17 ++
 .../jvm/backtype/storm/messaging/IContext.java  |  17 ++
 .../backtype/storm/messaging/TaskMessage.java   |  17 ++
 .../storm/messaging/TransportFactory.java       |  17 ++
 .../storm/metric/LoggingMetricsConsumer.java    |  17 ++
 .../storm/metric/MetricsConsumerBolt.java       |  17 ++
 .../jvm/backtype/storm/metric/SystemBolt.java   |  17 ++
 .../storm/metric/api/AssignableMetric.java      |  17 ++
 .../storm/metric/api/CombinedMetric.java        |  17 ++
 .../backtype/storm/metric/api/CountMetric.java  |  17 ++
 .../backtype/storm/metric/api/ICombiner.java    |  17 ++
 .../jvm/backtype/storm/metric/api/IMetric.java  |  17 ++
 .../storm/metric/api/IMetricsConsumer.java      |  17 ++
 .../jvm/backtype/storm/metric/api/IReducer.java |  17 ++
 .../storm/metric/api/IStatefulObject.java       |  17 ++
 .../backtype/storm/metric/api/MeanReducer.java  |  17 ++
 .../storm/metric/api/MultiCountMetric.java      |  17 ++
 .../storm/metric/api/MultiReducedMetric.java    |  17 ++
 .../storm/metric/api/ReducedMetric.java         |  17 ++
 .../backtype/storm/metric/api/StateMetric.java  |  17 ++
 .../storm/nimbus/DefaultTopologyValidator.java  |  17 ++
 .../storm/nimbus/ITopologyValidator.java        |  17 ++
 .../backtype/storm/planner/CompoundSpout.java   |  17 ++
 .../backtype/storm/planner/CompoundTask.java    |  17 ++
 .../jvm/backtype/storm/planner/TaskBundle.java  |  17 ++
 .../jvm/backtype/storm/scheduler/Cluster.java   |  17 ++
 .../storm/scheduler/ExecutorDetails.java        |  91 +++++----
 .../jvm/backtype/storm/scheduler/INimbus.java   |  17 ++
 .../backtype/storm/scheduler/IScheduler.java    |  17 ++
 .../backtype/storm/scheduler/ISupervisor.java   |  17 ++
 .../storm/scheduler/SchedulerAssignment.java    |  97 +++++----
 .../scheduler/SchedulerAssignmentImpl.java      | 201 ++++++++++---------
 .../storm/scheduler/SupervisorDetails.java      |  17 ++
 .../backtype/storm/scheduler/Topologies.java    |  97 +++++----
 .../storm/scheduler/TopologyDetails.java        |  17 ++
 .../backtype/storm/scheduler/WorkerSlot.java    |  17 ++
 .../backtype/storm/security/auth/AuthUtils.java |  17 ++
 .../storm/security/auth/IAuthorizer.java        |  17 ++
 .../storm/security/auth/ITransportPlugin.java   |  17 ++
 .../storm/security/auth/ReqContext.java         |  17 ++
 .../security/auth/SaslTransportPlugin.java      |  17 ++
 .../security/auth/SimpleTransportPlugin.java    |  17 ++
 .../storm/security/auth/ThriftClient.java       |  17 ++
 .../storm/security/auth/ThriftServer.java       |  17 ++
 .../auth/authorizer/DenyAuthorizer.java         |  17 ++
 .../auth/authorizer/NoopAuthorizer.java         |  17 ++
 .../auth/digest/ClientCallbackHandler.java      |  17 ++
 .../auth/digest/DigestSaslTransportPlugin.java  |  17 ++
 .../auth/digest/ServerCallbackHandler.java      |  17 ++
 .../serialization/BlowfishTupleSerializer.java  |  17 ++
 .../storm/serialization/DefaultKryoFactory.java |  17 ++
 .../storm/serialization/IKryoDecorator.java     |  17 ++
 .../storm/serialization/IKryoFactory.java       |  17 ++
 .../storm/serialization/ITupleDeserializer.java |  17 ++
 .../storm/serialization/ITupleSerializer.java   |  17 ++
 .../serialization/KryoTupleDeserializer.java    |  17 ++
 .../serialization/KryoTupleSerializer.java      |  17 ++
 .../serialization/KryoValuesDeserializer.java   |  17 ++
 .../serialization/KryoValuesSerializer.java     |  17 ++
 .../serialization/SerializableSerializer.java   |  17 ++
 .../serialization/SerializationFactory.java     |  17 ++
 .../types/ArrayListSerializer.java              |  17 ++
 .../serialization/types/HashMapSerializer.java  |  17 ++
 .../serialization/types/HashSetSerializer.java  |  17 ++
 .../types/ListDelegateSerializer.java           |  17 ++
 .../storm/spout/IMultiSchemableSpout.java       |  17 ++
 .../backtype/storm/spout/ISchemableSpout.java   |  17 ++
 .../src/jvm/backtype/storm/spout/ISpout.java    |  17 ++
 .../storm/spout/ISpoutOutputCollector.java      |  17 ++
 .../storm/spout/ISpoutWaitStrategy.java         |  17 ++
 .../jvm/backtype/storm/spout/MultiScheme.java   |  17 ++
 .../storm/spout/NothingEmptyEmitStrategy.java   |  17 ++
 .../backtype/storm/spout/RawMultiScheme.java    |  17 ++
 .../src/jvm/backtype/storm/spout/RawScheme.java |  17 ++
 .../src/jvm/backtype/storm/spout/Scheme.java    |  17 ++
 .../storm/spout/SchemeAsMultiScheme.java        |  17 ++
 .../jvm/backtype/storm/spout/ShellSpout.java    |  17 ++
 .../storm/spout/SleepSpoutWaitStrategy.java     |  17 ++
 .../storm/spout/SpoutOutputCollector.java       |  17 ++
 .../jvm/backtype/storm/state/IStateSpout.java   |  17 ++
 .../storm/state/IStateSpoutOutputCollector.java |  17 ++
 .../backtype/storm/state/ISubscribedState.java  |  17 ++
 .../state/ISynchronizeOutputCollector.java      |  17 ++
 .../storm/state/StateSpoutOutputCollector.java  |  17 ++
 .../storm/state/SynchronizeOutputCollector.java |  17 ++
 .../storm/task/GeneralTopologyContext.java      |  17 ++
 .../src/jvm/backtype/storm/task/IBolt.java      |  17 ++
 .../jvm/backtype/storm/task/IErrorReporter.java |  17 ++
 .../backtype/storm/task/IMetricsContext.java    |  17 ++
 .../backtype/storm/task/IOutputCollector.java   |  17 ++
 .../backtype/storm/task/OutputCollector.java    |  17 ++
 .../src/jvm/backtype/storm/task/ShellBolt.java  |  17 ++
 .../backtype/storm/task/TopologyContext.java    |  17 ++
 .../storm/task/WorkerTopologyContext.java       |  17 ++
 .../backtype/storm/testing/AckFailDelegate.java |  17 ++
 .../storm/testing/AckFailMapTracker.java        |  17 ++
 .../jvm/backtype/storm/testing/AckTracker.java  |  17 ++
 .../backtype/storm/testing/BatchNumberList.java |  17 ++
 .../storm/testing/BatchProcessWord.java         |  17 ++
 .../backtype/storm/testing/BatchRepeatA.java    |  17 ++
 .../jvm/backtype/storm/testing/BoltTracker.java |  17 ++
 .../storm/testing/CompleteTopologyParam.java    | 117 ++++++-----
 .../storm/testing/CountingBatchBolt.java        |  17 ++
 .../storm/testing/CountingCommitBolt.java       |  17 ++
 .../jvm/backtype/storm/testing/FeederSpout.java |  17 ++
 .../jvm/backtype/storm/testing/FixedTuple.java  |  17 ++
 .../backtype/storm/testing/FixedTupleSpout.java |  17 ++
 .../backtype/storm/testing/IdentityBolt.java    |  17 ++
 .../storm/testing/KeyedCountingBatchBolt.java   |  17 ++
 .../testing/KeyedCountingCommitterBolt.java     |  17 ++
 .../storm/testing/KeyedSummingBatchBolt.java    |  17 ++
 .../storm/testing/MemoryTransactionalSpout.java |  17 ++
 .../testing/MemoryTransactionalSpoutMeta.java   |  17 ++
 .../backtype/storm/testing/MkClusterParam.java  |  97 +++++----
 .../backtype/storm/testing/MkTupleParam.java    |  85 ++++----
 .../backtype/storm/testing/MockedSources.java   | 103 ++++++----
 .../jvm/backtype/storm/testing/NGrouping.java   |  17 ++
 .../storm/testing/NonRichBoltTracker.java       |  17 ++
 .../testing/OpaqueMemoryTransactionalSpout.java |  17 ++
 .../storm/testing/PrepareBatchBolt.java         |  17 ++
 .../backtype/storm/testing/SpoutTracker.java    |  17 ++
 .../storm/testing/TestAggregatesCounter.java    |  17 ++
 .../backtype/storm/testing/TestConfBolt.java    |  17 ++
 .../backtype/storm/testing/TestGlobalCount.java |  17 ++
 .../src/jvm/backtype/storm/testing/TestJob.java |  65 +++---
 .../storm/testing/TestKryoDecorator.java        |  17 ++
 .../backtype/storm/testing/TestPlannerBolt.java |  17 ++
 .../storm/testing/TestPlannerSpout.java         |  17 ++
 .../backtype/storm/testing/TestSerObject.java   |  17 ++
 .../backtype/storm/testing/TestWordCounter.java |  17 ++
 .../backtype/storm/testing/TestWordSpout.java   |  17 ++
 .../backtype/storm/testing/TrackedTopology.java |  51 +++--
 .../storm/testing/TupleCaptureBolt.java         |  17 ++
 .../topology/BaseConfigurationDeclarer.java     |  17 ++
 .../storm/topology/BasicBoltExecutor.java       |  17 ++
 .../storm/topology/BasicOutputCollector.java    |  17 ++
 .../backtype/storm/topology/BoltDeclarer.java   |  17 ++
 .../ComponentConfigurationDeclarer.java         |  17 ++
 .../storm/topology/FailedException.java         |  17 ++
 .../jvm/backtype/storm/topology/IBasicBolt.java |  17 ++
 .../storm/topology/IBasicOutputCollector.java   |  17 ++
 .../jvm/backtype/storm/topology/IComponent.java |  17 ++
 .../jvm/backtype/storm/topology/IRichBolt.java  |  17 ++
 .../jvm/backtype/storm/topology/IRichSpout.java |  17 ++
 .../storm/topology/IRichStateSpout.java         |  17 ++
 .../backtype/storm/topology/InputDeclarer.java  |  17 ++
 .../storm/topology/OutputFieldsDeclarer.java    |  17 ++
 .../storm/topology/OutputFieldsGetter.java      |  17 ++
 .../storm/topology/ReportedFailedException.java |  17 ++
 .../backtype/storm/topology/SpoutDeclarer.java  |  17 ++
 .../storm/topology/TopologyBuilder.java         |  17 ++
 .../storm/topology/base/BaseBasicBolt.java      |  17 ++
 .../storm/topology/base/BaseBatchBolt.java      |  17 ++
 .../storm/topology/base/BaseComponent.java      |  17 ++
 ...BaseOpaquePartitionedTransactionalSpout.java |  17 ++
 .../base/BasePartitionedTransactionalSpout.java |  17 ++
 .../storm/topology/base/BaseRichBolt.java       |  17 ++
 .../storm/topology/base/BaseRichSpout.java      |  17 ++
 .../topology/base/BaseTransactionalBolt.java    |  17 ++
 .../topology/base/BaseTransactionalSpout.java   |  17 ++
 .../storm/transactional/ICommitter.java         |  17 ++
 .../ICommitterTransactionalSpout.java           |  17 ++
 .../transactional/ITransactionalSpout.java      |  17 ++
 .../storm/transactional/TransactionAttempt.java |  17 ++
 .../TransactionalSpoutBatchExecutor.java        |  17 ++
 .../TransactionalSpoutCoordinator.java          |  17 ++
 .../TransactionalTopologyBuilder.java           |  17 ++
 .../IOpaquePartitionedTransactionalSpout.java   |  17 ++
 .../IPartitionedTransactionalSpout.java         |  17 ++
 ...uePartitionedTransactionalSpoutExecutor.java |  17 ++
 .../PartitionedTransactionalSpoutExecutor.java  |  17 ++
 .../state/RotatingTransactionalState.java       |  17 ++
 .../transactional/state/TransactionalState.java |  17 ++
 .../src/jvm/backtype/storm/tuple/Fields.java    |  17 ++
 .../src/jvm/backtype/storm/tuple/MessageId.java |  17 ++
 .../src/jvm/backtype/storm/tuple/Tuple.java     |  17 ++
 .../src/jvm/backtype/storm/tuple/TupleImpl.java |  17 ++
 .../src/jvm/backtype/storm/tuple/Values.java    |  17 ++
 .../storm/utils/BufferFileInputStream.java      |  17 ++
 .../backtype/storm/utils/CRC32OutputStream.java |  17 ++
 .../backtype/storm/utils/ClojureTimerTask.java  |  17 ++
 .../src/jvm/backtype/storm/utils/Container.java |  17 ++
 .../jvm/backtype/storm/utils/DRPCClient.java    |  17 ++
 .../backtype/storm/utils/DisruptorQueue.java    |  17 ++
 .../storm/utils/IndifferentAccessMap.java       |  17 ++
 .../backtype/storm/utils/InprocMessaging.java   |  17 ++
 .../storm/utils/KeyedRoundRobinQueue.java       |  17 ++
 .../jvm/backtype/storm/utils/ListDelegate.java  |  17 ++
 .../jvm/backtype/storm/utils/LocalState.java    |  17 ++
 .../jvm/backtype/storm/utils/MutableInt.java    |  17 ++
 .../jvm/backtype/storm/utils/MutableLong.java   |  17 ++
 .../jvm/backtype/storm/utils/MutableObject.java |  17 ++
 .../jvm/backtype/storm/utils/NimbusClient.java  |  17 ++
 .../storm/utils/RegisteredGlobalState.java      |  17 ++
 .../jvm/backtype/storm/utils/RotatingMap.java   |  17 ++
 .../backtype/storm/utils/ServiceRegistry.java   |  17 ++
 .../jvm/backtype/storm/utils/ShellProcess.java  |  17 ++
 .../storm/utils/ThriftTopologyUtils.java        |  17 ++
 .../src/jvm/backtype/storm/utils/Time.java      |  17 ++
 .../jvm/backtype/storm/utils/TimeCacheMap.java  |  17 ++
 .../src/jvm/backtype/storm/utils/Utils.java     |  17 ++
 .../backtype/storm/utils/VersionedStore.java    |  17 ++
 .../storm/utils/WindowedTimeThrottler.java      |  17 ++
 .../jvm/backtype/storm/utils/WritableUtils.java |  17 ++
 .../backtype/storm/utils/ZookeeperAuthInfo.java |  17 ++
 storm-core/src/jvm/storm/trident/JoinType.java  |  17 ++
 storm-core/src/jvm/storm/trident/Stream.java    |  17 ++
 .../src/jvm/storm/trident/TridentState.java     |  17 ++
 .../src/jvm/storm/trident/TridentTopology.java  |  17 ++
 .../trident/drpc/ReturnResultsReducer.java      |  17 ++
 .../fluent/ChainedAggregatorDeclarer.java       |  17 ++
 .../fluent/ChainedFullAggregatorDeclarer.java   |  17 ++
 .../ChainedPartitionAggregatorDeclarer.java     |  17 ++
 .../trident/fluent/GlobalAggregationScheme.java |  17 ++
 .../jvm/storm/trident/fluent/GroupedStream.java |  17 ++
 .../trident/fluent/IAggregatableStream.java     |  17 ++
 .../fluent/IChainedAggregatorDeclarer.java      |  17 ++
 .../jvm/storm/trident/fluent/UniqueIdGen.java   |  17 ++
 .../jvm/storm/trident/graph/GraphGrouper.java   |  17 ++
 .../src/jvm/storm/trident/graph/Group.java      |  17 ++
 .../jvm/storm/trident/operation/Aggregator.java |  17 ++
 .../jvm/storm/trident/operation/Assembly.java   |  17 ++
 .../storm/trident/operation/BaseAggregator.java |  17 ++
 .../jvm/storm/trident/operation/BaseFilter.java |  17 ++
 .../storm/trident/operation/BaseFunction.java   |  17 ++
 .../trident/operation/BaseMultiReducer.java     |  17 ++
 .../storm/trident/operation/BaseOperation.java  |  17 ++
 .../trident/operation/CombinerAggregator.java   |  17 ++
 .../storm/trident/operation/EachOperation.java  |  17 ++
 .../src/jvm/storm/trident/operation/Filter.java |  17 ++
 .../jvm/storm/trident/operation/Function.java   |  17 ++
 .../trident/operation/GroupedMultiReducer.java  |  17 ++
 .../storm/trident/operation/MultiReducer.java   |  17 ++
 .../jvm/storm/trident/operation/Operation.java  |  17 ++
 .../trident/operation/ReducerAggregator.java    |  17 ++
 .../trident/operation/TridentCollector.java     |  17 ++
 .../operation/TridentMultiReducerContext.java   |  17 ++
 .../operation/TridentOperationContext.java      |  17 ++
 .../storm/trident/operation/builtin/Count.java  |  17 ++
 .../storm/trident/operation/builtin/Debug.java  |  17 ++
 .../storm/trident/operation/builtin/Equals.java |  17 ++
 .../trident/operation/builtin/FilterNull.java   |  17 ++
 .../storm/trident/operation/builtin/FirstN.java |  17 ++
 .../storm/trident/operation/builtin/MapGet.java |  17 ++
 .../storm/trident/operation/builtin/Negate.java |  17 ++
 .../trident/operation/builtin/SnapshotGet.java  |  17 ++
 .../storm/trident/operation/builtin/Sum.java    |  17 ++
 .../operation/builtin/TupleCollectionGet.java   |  17 ++
 .../operation/impl/CaptureCollector.java        |  17 ++
 .../operation/impl/ChainedAggregatorImpl.java   |  17 ++
 .../trident/operation/impl/ChainedResult.java   |  17 ++
 .../operation/impl/CombinerAggStateUpdater.java |  17 ++
 .../impl/CombinerAggregatorCombineImpl.java     |  17 ++
 .../impl/CombinerAggregatorInitImpl.java        |  17 ++
 .../trident/operation/impl/FilterExecutor.java  |  17 ++
 .../operation/impl/GlobalBatchToPartition.java  |  17 ++
 .../trident/operation/impl/GroupCollector.java  |  17 ++
 .../operation/impl/GroupedAggregator.java       |  17 ++
 .../impl/GroupedMultiReducerExecutor.java       |  17 ++
 .../operation/impl/IdentityMultiReducer.java    |  17 ++
 .../impl/IndexHashBatchToPartition.java         |  17 ++
 .../operation/impl/JoinerMultiReducer.java      |  17 ++
 .../operation/impl/ReducerAggStateUpdater.java  |  17 ++
 .../operation/impl/ReducerAggregatorImpl.java   |  17 ++
 .../storm/trident/operation/impl/Result.java    |  17 ++
 .../operation/impl/SingleEmitAggregator.java    |  17 ++
 .../trident/operation/impl/TrueFilter.java      |  17 ++
 .../storm/trident/partition/GlobalGrouping.java |  17 ++
 .../trident/partition/IdentityGrouping.java     |  17 ++
 .../trident/partition/IndexHashGrouping.java    |  17 ++
 .../storm/trident/planner/BridgeReceiver.java   |  17 ++
 .../src/jvm/storm/trident/planner/Node.java     |  17 ++
 .../storm/trident/planner/NodeStateInfo.java    |  17 ++
 .../storm/trident/planner/PartitionNode.java    |  17 ++
 .../storm/trident/planner/ProcessorContext.java |  17 ++
 .../storm/trident/planner/ProcessorNode.java    |  17 ++
 .../jvm/storm/trident/planner/SpoutNode.java    |  17 ++
 .../storm/trident/planner/SubtopologyBolt.java  |  17 ++
 .../storm/trident/planner/TridentProcessor.java |  17 ++
 .../storm/trident/planner/TupleReceiver.java    |  17 ++
 .../planner/processor/AggregateProcessor.java   |  17 ++
 .../planner/processor/AppendCollector.java      |  17 ++
 .../planner/processor/EachProcessor.java        |  17 ++
 .../planner/processor/FreshCollector.java       |  17 ++
 .../processor/MultiReducerProcessor.java        |  17 ++
 .../processor/PartitionPersistProcessor.java    |  17 ++
 .../planner/processor/ProjectedProcessor.java   |  17 ++
 .../planner/processor/StateQueryProcessor.java  |  17 ++
 .../planner/processor/TridentContext.java       |  17 ++
 .../storm/trident/spout/BatchSpoutExecutor.java |  17 ++
 .../src/jvm/storm/trident/spout/IBatchID.java   |  17 ++
 .../jvm/storm/trident/spout/IBatchSpout.java    |  17 ++
 .../trident/spout/ICommitterTridentSpout.java   |  17 ++
 .../spout/IOpaquePartitionedTridentSpout.java   |  17 ++
 .../trident/spout/IPartitionedTridentSpout.java |  17 ++
 .../storm/trident/spout/ISpoutPartition.java    |  17 ++
 .../jvm/storm/trident/spout/ITridentSpout.java  |  17 ++
 .../OpaquePartitionedTridentSpoutExecutor.java  |  17 ++
 .../spout/PartitionedTridentSpoutExecutor.java  |  17 ++
 .../trident/spout/RichSpoutBatchExecutor.java   |  17 ++
 .../storm/trident/spout/RichSpoutBatchId.java   |  17 ++
 .../spout/RichSpoutBatchIdSerializer.java       |  17 ++
 .../trident/spout/RichSpoutBatchTriggerer.java  |  17 ++
 .../trident/spout/TridentSpoutCoordinator.java  |  17 ++
 .../trident/spout/TridentSpoutExecutor.java     |  17 ++
 .../storm/trident/state/BaseQueryFunction.java  |  17 ++
 .../storm/trident/state/BaseStateUpdater.java   |  17 ++
 .../trident/state/CombinerValueUpdater.java     |  17 ++
 .../storm/trident/state/ITupleCollection.java   |  17 ++
 .../state/JSONNonTransactionalSerializer.java   |  17 ++
 .../trident/state/JSONOpaqueSerializer.java     |  17 ++
 .../state/JSONTransactionalSerializer.java      |  17 ++
 .../jvm/storm/trident/state/OpaqueValue.java    |  17 ++
 .../jvm/storm/trident/state/QueryFunction.java  |  17 ++
 .../jvm/storm/trident/state/ReadOnlyState.java  |  17 ++
 .../trident/state/ReducerValueUpdater.java      |  17 ++
 .../src/jvm/storm/trident/state/Serializer.java |  17 ++
 .../src/jvm/storm/trident/state/State.java      |  17 ++
 .../jvm/storm/trident/state/StateFactory.java   |  17 ++
 .../src/jvm/storm/trident/state/StateSpec.java  |  17 ++
 .../src/jvm/storm/trident/state/StateType.java  |  17 ++
 .../jvm/storm/trident/state/StateUpdater.java   |  17 ++
 .../storm/trident/state/TransactionalValue.java |  17 ++
 .../jvm/storm/trident/state/ValueUpdater.java   |  17 ++
 .../trident/state/map/CachedBatchReadsMap.java  |  17 ++
 .../jvm/storm/trident/state/map/CachedMap.java  |  17 ++
 .../storm/trident/state/map/IBackingMap.java    |  17 ++
 .../state/map/MapCombinerAggStateUpdater.java   |  17 ++
 .../state/map/MapReducerAggStateUpdater.java    |  17 ++
 .../jvm/storm/trident/state/map/MapState.java   |  17 ++
 .../state/map/MicroBatchIBackingMap.java        |  17 ++
 .../trident/state/map/NonTransactionalMap.java  |  17 ++
 .../jvm/storm/trident/state/map/OpaqueMap.java  |  17 ++
 .../trident/state/map/ReadOnlyMapState.java     |  17 ++
 .../trident/state/map/SnapshottableMap.java     |  17 ++
 .../trident/state/map/TransactionalMap.java     |  17 ++
 .../state/snapshot/ReadOnlySnapshottable.java   |  17 ++
 .../trident/state/snapshot/Snapshottable.java   |  17 ++
 .../trident/testing/CountAsAggregator.java      |  17 ++
 .../storm/trident/testing/FeederBatchSpout.java |  17 ++
 .../testing/FeederCommitterBatchSpout.java      |  17 ++
 .../storm/trident/testing/FixedBatchSpout.java  |  17 ++
 .../src/jvm/storm/trident/testing/IFeeder.java  |  17 ++
 .../trident/testing/LRUMemoryMapState.java      |  17 ++
 .../storm/trident/testing/MemoryBackingMap.java |  17 ++
 .../storm/trident/testing/MemoryMapState.java   |  17 ++
 .../storm/trident/testing/MockTridentTuple.java |  17 ++
 .../src/jvm/storm/trident/testing/Split.java    |  17 ++
 .../jvm/storm/trident/testing/StringLength.java |  17 ++
 .../jvm/storm/trident/testing/TrueFilter.java   |  17 ++
 .../jvm/storm/trident/testing/TuplifyArgs.java  |  17 ++
 .../jvm/storm/trident/topology/BatchInfo.java   |  17 ++
 .../trident/topology/ITridentBatchBolt.java     |  17 ++
 .../topology/MasterBatchCoordinator.java        |  17 ++
 .../trident/topology/TransactionAttempt.java    |  17 ++
 .../trident/topology/TridentBoltExecutor.java   |  17 ++
 .../topology/TridentTopologyBuilder.java        |  17 ++
 .../state/RotatingTransactionalState.java       |  17 ++
 .../topology/state/TransactionalState.java      |  17 ++
 .../src/jvm/storm/trident/tuple/ComboList.java  |  17 ++
 .../src/jvm/storm/trident/tuple/ConsList.java   |  17 ++
 .../jvm/storm/trident/tuple/TridentTuple.java   |  17 ++
 .../storm/trident/tuple/TridentTupleView.java   |  17 ++
 .../jvm/storm/trident/tuple/ValuePointer.java   |  17 ++
 .../storm/trident/util/ErrorEdgeFactory.java    |  17 ++
 .../src/jvm/storm/trident/util/IndexedEdge.java |  17 ++
 .../src/jvm/storm/trident/util/LRUMap.java      |  17 ++
 .../jvm/storm/trident/util/TridentUtils.java    |  17 ++
 storm-core/src/multilang/py/storm.py            |  16 ++
 storm-core/src/multilang/rb/storm.rb            |  16 ++
 storm-core/src/storm.thrift                     |  23 +++
 storm-core/src/ui/public/css/style.css          |  17 ++
 storm-core/src/ui/public/js/script.js           |  17 ++
 .../test/clj/backtype/storm/clojure_test.clj    |  15 ++
 .../test/clj/backtype/storm/cluster_test.clj    |  15 ++
 .../test/clj/backtype/storm/config_test.clj     |  15 ++
 .../test/clj/backtype/storm/drpc_test.clj       |  15 ++
 .../test/clj/backtype/storm/fields_test.clj     |  15 ++
 .../test/clj/backtype/storm/grouping_test.clj   |  15 ++
 .../clj/backtype/storm/integration_test.clj     |  15 ++
 .../clj/backtype/storm/local_state_test.clj     |  15 ++
 .../test/clj/backtype/storm/messaging_test.clj  |  15 ++
 .../test/clj/backtype/storm/metrics_test.clj    |  15 ++
 .../test/clj/backtype/storm/multilang_test.clj  |  15 ++
 .../test/clj/backtype/storm/nimbus_test.clj     |  15 ++
 .../test/clj/backtype/storm/scheduler_test.clj  |  15 ++
 .../storm/security/auth/AuthUtils_test.clj      |  15 ++
 .../storm/security/auth/ReqContext_test.clj     |  15 ++
 .../security/auth/SaslTransportPlugin_test.clj  |  15 ++
 .../storm/security/auth/ThriftClient_test.clj   |  15 ++
 .../storm/security/auth/ThriftServer_test.clj   |  15 ++
 .../backtype/storm/security/auth/auth_test.clj  |  15 ++
 .../BlowfishTupleSerializer_test.clj            |  15 ++
 .../serialization/SerializationFactory_test.clj |  15 ++
 .../clj/backtype/storm/serialization_test.clj   |  15 ++
 .../clj/backtype/storm/subtopology_test.clj     |  15 ++
 .../test/clj/backtype/storm/supervisor_test.clj |  15 ++
 .../test/clj/backtype/storm/testing4j_test.clj  |  15 ++
 .../test/clj/backtype/storm/tick_tuple_test.clj |  15 ++
 .../clj/backtype/storm/transactional_test.clj   |  15 ++
 .../test/clj/backtype/storm/tuple_test.clj      |  15 ++
 .../test/clj/backtype/storm/utils_test.clj      |  15 ++
 .../clj/backtype/storm/versioned_store_test.clj |  15 ++
 .../test/clj/storm/trident/integration_test.clj |  15 ++
 .../test/clj/storm/trident/state_test.clj       |  15 ++
 .../test/clj/storm/trident/tuple_test.clj       |  15 ++
 storm-core/test/clj/zilch/test/mq.clj           |  15 ++
 storm-lib/project.clj                           |  15 ++
 storm-netty/project.clj                         |  15 ++
 .../backtype/storm/messaging/netty/Client.java  |  17 ++
 .../backtype/storm/messaging/netty/Context.java |  17 ++
 .../storm/messaging/netty/ControlMessage.java   |  17 ++
 .../storm/messaging/netty/MessageBatch.java     |  17 ++
 .../storm/messaging/netty/MessageDecoder.java   |  17 ++
 .../storm/messaging/netty/MessageEncoder.java   |  17 ++
 .../backtype/storm/messaging/netty/Server.java  |  17 ++
 .../messaging/netty/StormClientHandler.java     |  17 ++
 .../netty/StormClientPipelineFactory.java       |  17 ++
 .../messaging/netty/StormServerHandler.java     |  17 ++
 .../netty/StormServerPipelineFactory.java       |  17 ++
 .../storm/messaging/netty_integration_test.clj  |  15 ++
 .../storm/messaging/netty_unit_test.clj         |  15 ++
 558 files changed, 9725 insertions(+), 421 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/bin/build_modules.sh
----------------------------------------------------------------------
diff --git a/bin/build_modules.sh b/bin/build_modules.sh
index 44d62ba..e507fb1 100644
--- a/bin/build_modules.sh
+++ b/bin/build_modules.sh
@@ -1,5 +1,21 @@
 #!/bin/bash
 
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+# http:# www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing, software
+# distributed under the License is distributed on an "AS IS" BASIS,
+# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+# See the License for the specific language governing permissions and
+# limitations under the License.
+
 LEIN=`which lein2 || which lein` 
 export LEIN_ROOT=1
 

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/bin/build_release.sh
----------------------------------------------------------------------
diff --git a/bin/build_release.sh b/bin/build_release.sh
index b6f3cab..d09649e 100644
--- a/bin/build_release.sh
+++ b/bin/build_release.sh
@@ -1,4 +1,21 @@
 #!/bin/bash
+
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+# http:# www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing, software
+# distributed under the License is distributed on an "AS IS" BASIS,
+# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+# See the License for the specific language governing permissions and
+# limitations under the License.
+
 function quit {
     exit 1
 }

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/bin/install_zmq.sh
----------------------------------------------------------------------
diff --git a/bin/install_zmq.sh b/bin/install_zmq.sh
index dc744f1..b06a3ae 100755
--- a/bin/install_zmq.sh
+++ b/bin/install_zmq.sh
@@ -1,4 +1,21 @@
 #!/bin/bash
+
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+# http:# www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing, software
+# distributed under the License is distributed on an "AS IS" BASIS,
+# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+# See the License for the specific language governing permissions and
+# limitations under the License.
+
 export JAVA_HOME=${JAVA_HOME:/usr/libexec/java_home}
 
 if [ ! -d "$JAVA_HOME/include" ]; then

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/bin/javadoc.sh
----------------------------------------------------------------------
diff --git a/bin/javadoc.sh b/bin/javadoc.sh
index f8b6c68..2c18899 100644
--- a/bin/javadoc.sh
+++ b/bin/javadoc.sh
@@ -1,2 +1,18 @@
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+# http:# www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing, software
+# distributed under the License is distributed on an "AS IS" BASIS,
+# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+# See the License for the specific language governing permissions and
+# limitations under the License.
+
 mkdir -p doc
 javadoc -d doc-$1/ `find . -name "*.java" | grep -v generated`

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/bin/storm
----------------------------------------------------------------------
diff --git a/bin/storm b/bin/storm
index fc08a45..053d600 100755
--- a/bin/storm
+++ b/bin/storm
@@ -1,5 +1,21 @@
 #!/usr/bin/python
 
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+# http:# www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing, software
+# distributed under the License is distributed on an "AS IS" BASIS,
+# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+# See the License for the specific language governing permissions and
+# limitations under the License.
+
 import os
 import sys
 import random

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/bin/to_maven.sh
----------------------------------------------------------------------
diff --git a/bin/to_maven.sh b/bin/to_maven.sh
index cd54858..9f1c02f 100644
--- a/bin/to_maven.sh
+++ b/bin/to_maven.sh
@@ -1,4 +1,21 @@
 #!/bin/bash 
+
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+# http:# www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing, software
+# distributed under the License is distributed on an "AS IS" BASIS,
+# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+# See the License for the specific language governing permissions and
+# limitations under the License.
+
 function quit {
     exit 1
 }

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/conf/defaults.yaml
----------------------------------------------------------------------
diff --git a/conf/defaults.yaml b/conf/defaults.yaml
index a5b31f4..95e3366 100644
--- a/conf/defaults.yaml
+++ b/conf/defaults.yaml
@@ -1,3 +1,20 @@
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+# http:# www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing, software
+# distributed under the License is distributed on an "AS IS" BASIS,
+# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+# See the License for the specific language governing permissions and
+# limitations under the License.
+
+
 ########### These all have default values as shown
 ########### Additional configuration goes into storm.yaml
 
@@ -83,6 +100,7 @@ zmq.threads: 1
 zmq.linger.millis: 5000
 zmq.hwm: 0
 
+
 storm.messaging.netty.server_worker_threads: 1
 storm.messaging.netty.client_worker_threads: 1
 storm.messaging.netty.buffer_size: 5242880 #5MB buffer

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/conf/jaas_digest.conf
----------------------------------------------------------------------
diff --git a/conf/jaas_digest.conf b/conf/jaas_digest.conf
index 74f9650..06dd7aa 100644
--- a/conf/jaas_digest.conf
+++ b/conf/jaas_digest.conf
@@ -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.
+ */
+
 /* This is example of JAAS Login configuration for digest authentication
 */
 

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/conf/logback.xml
----------------------------------------------------------------------
diff --git a/conf/logback.xml b/conf/logback.xml
index 2a28d87..7ccaae6 100644
--- a/conf/logback.xml
+++ b/conf/logback.xml
@@ -1,5 +1,20 @@
-<?xml version="1.0" encoding="UTF-8"?>
+<?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.
+-->
 <configuration scan="true" scanPeriod="30 seconds">
   <appender name="A1" class="ch.qos.logback.core.ConsoleAppender">
     <encoder>

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/conf/storm.yaml.example
----------------------------------------------------------------------
diff --git a/conf/storm.yaml.example b/conf/storm.yaml.example
index 1f1acaa..b11aba9 100644
--- a/conf/storm.yaml.example
+++ b/conf/storm.yaml.example
@@ -1,3 +1,19 @@
+# Licensed to the Apache Software Foundation (ASF) under one
+# or more contributor license agreements.  See the NOTICE file
+# distributed with this work for additional information
+# regarding copyright ownership.  The ASF licenses this file
+# to you under the Apache License, Version 2.0 (the
+# "License"); you may not use this file except in compliance
+# with the License.  You may obtain a copy of the License at
+#
+# http:# www.apache.org/licenses/LICENSE-2.0
+#
+# Unless required by applicable law or agreed to in writing, software
+# distributed under the License is distributed on an "AS IS" BASIS,
+# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+# See the License for the specific language governing permissions and
+# limitations under the License.
+
 ########### These MUST be filled in for a storm configuration
 # storm.zookeeper.servers:
 #     - "server1"

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/logback/cluster.xml
----------------------------------------------------------------------
diff --git a/logback/cluster.xml b/logback/cluster.xml
index d3d2b63..5ad6027 100644
--- a/logback/cluster.xml
+++ b/logback/cluster.xml
@@ -1,4 +1,20 @@
-<?xml version="1.0" encoding="UTF-8"?>
+<?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.
+-->
 
 <configuration scan="true" scanPeriod="60 seconds">
  <appender name="A1" class="ch.qos.logback.core.rolling.RollingFileAppender">

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/project.clj
----------------------------------------------------------------------
diff --git a/project.clj b/project.clj
index ed1fdbc..8f63cd6 100644
--- a/project.clj
+++ b/project.clj
@@ -1,3 +1,18 @@
+;; Licensed to the Apache Software Foundation (ASF) under one
+;; or more contributor license agreements.  See the NOTICE file
+;; distributed with this work for additional information
+;; regarding copyright ownership.  The ASF licenses this file
+;; to you under the Apache License, Version 2.0 (the
+;; "License"); you may not use this file except in compliance
+;; with the License.  You may obtain a copy of the License at
+;;
+;; http:;; www.apache.org/licenses/LICENSE-2.0
+;;
+;; Unless required by applicable law or agreed to in writing, software
+;; distributed under the License is distributed on an "AS IS" BASIS,
+;; WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+;; See the License for the specific language governing permissions and
+;; limitations under the License.
 (def VERSION (.trim (slurp "VERSION")))
 (def MODULES (-> "MODULES" slurp (.split "\n")))
 (def DEPENDENCIES (for [m MODULES] [(symbol (str "storm/" m)) VERSION]))

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-console-logging/project.clj
----------------------------------------------------------------------
diff --git a/storm-console-logging/project.clj b/storm-console-logging/project.clj
index 7b4322b..4464419 100644
--- a/storm-console-logging/project.clj
+++ b/storm-console-logging/project.clj
@@ -1,3 +1,18 @@
+;; Licensed to the Apache Software Foundation (ASF) under one
+;; or more contributor license agreements.  See the NOTICE file
+;; distributed with this work for additional information
+;; regarding copyright ownership.  The ASF licenses this file
+;; to you under the Apache License, Version 2.0 (the
+;; "License"); you may not use this file except in compliance
+;; with the License.  You may obtain a copy of the License at
+;;
+;; http:;; www.apache.org/licenses/LICENSE-2.0
+;;
+;; Unless required by applicable law or agreed to in writing, software
+;; distributed under the License is distributed on an "AS IS" BASIS,
+;; WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+;; See the License for the specific language governing permissions and
+;; limitations under the License.
 (def ROOT-DIR (subs *file* 0 (- (count *file*) (count "project.clj"))))
 (def VERSION (-> ROOT-DIR (str "/../VERSION") slurp (.trim)))
 

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/project.clj
----------------------------------------------------------------------
diff --git a/storm-core/project.clj b/storm-core/project.clj
index 0eaa6a3..1dc95b6 100644
--- a/storm-core/project.clj
+++ b/storm-core/project.clj
@@ -1,3 +1,18 @@
+;; Licensed to the Apache Software Foundation (ASF) under one
+;; or more contributor license agreements.  See the NOTICE file
+;; distributed with this work for additional information
+;; regarding copyright ownership.  The ASF licenses this file
+;; to you under the Apache License, Version 2.0 (the
+;; "License"); you may not use this file except in compliance
+;; with the License.  You may obtain a copy of the License at
+;;
+;; http:;; www.apache.org/licenses/LICENSE-2.0
+;;
+;; Unless required by applicable law or agreed to in writing, software
+;; distributed under the License is distributed on an "AS IS" BASIS,
+;; WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+;; See the License for the specific language governing permissions and
+;; limitations under the License.
 (def ROOT-DIR (subs *file* 0 (- (count *file*) (count "project.clj"))))
 (def VERSION (-> ROOT-DIR (str "/../VERSION") slurp (.trim)))
 

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/clj/backtype/storm/LocalCluster.clj
----------------------------------------------------------------------
diff --git a/storm-core/src/clj/backtype/storm/LocalCluster.clj b/storm-core/src/clj/backtype/storm/LocalCluster.clj
index ec8b6ff..1bd5007 100644
--- a/storm-core/src/clj/backtype/storm/LocalCluster.clj
+++ b/storm-core/src/clj/backtype/storm/LocalCluster.clj
@@ -1,3 +1,18 @@
+;; Licensed to the Apache Software Foundation (ASF) under one
+;; or more contributor license agreements.  See the NOTICE file
+;; distributed with this work for additional information
+;; regarding copyright ownership.  The ASF licenses this file
+;; to you under the Apache License, Version 2.0 (the
+;; "License"); you may not use this file except in compliance
+;; with the License.  You may obtain a copy of the License at
+;;
+;; http:;; www.apache.org/licenses/LICENSE-2.0
+;;
+;; Unless required by applicable law or agreed to in writing, software
+;; distributed under the License is distributed on an "AS IS" BASIS,
+;; WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+;; See the License for the specific language governing permissions and
+;; limitations under the License.
 (ns backtype.storm.LocalCluster
   (:use [backtype.storm testing config])
   (:import [java.util Map])

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/clj/backtype/storm/LocalDRPC.clj
----------------------------------------------------------------------
diff --git a/storm-core/src/clj/backtype/storm/LocalDRPC.clj b/storm-core/src/clj/backtype/storm/LocalDRPC.clj
index 681591e..ca46dfb 100644
--- a/storm-core/src/clj/backtype/storm/LocalDRPC.clj
+++ b/storm-core/src/clj/backtype/storm/LocalDRPC.clj
@@ -1,3 +1,18 @@
+;; Licensed to the Apache Software Foundation (ASF) under one
+;; or more contributor license agreements.  See the NOTICE file
+;; distributed with this work for additional information
+;; regarding copyright ownership.  The ASF licenses this file
+;; to you under the Apache License, Version 2.0 (the
+;; "License"); you may not use this file except in compliance
+;; with the License.  You may obtain a copy of the License at
+;;
+;; http:;; www.apache.org/licenses/LICENSE-2.0
+;;
+;; Unless required by applicable law or agreed to in writing, software
+;; distributed under the License is distributed on an "AS IS" BASIS,
+;; WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+;; See the License for the specific language governing permissions and
+;; limitations under the License.
 (ns backtype.storm.LocalDRPC
   (:require [backtype.storm.daemon [drpc :as drpc]])
   (:use [backtype.storm util])

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/clj/backtype/storm/bootstrap.clj
----------------------------------------------------------------------
diff --git a/storm-core/src/clj/backtype/storm/bootstrap.clj b/storm-core/src/clj/backtype/storm/bootstrap.clj
index 70b8005..0ecf7dd 100644
--- a/storm-core/src/clj/backtype/storm/bootstrap.clj
+++ b/storm-core/src/clj/backtype/storm/bootstrap.clj
@@ -1,3 +1,18 @@
+;; Licensed to the Apache Software Foundation (ASF) under one
+;; or more contributor license agreements.  See the NOTICE file
+;; distributed with this work for additional information
+;; regarding copyright ownership.  The ASF licenses this file
+;; to you under the Apache License, Version 2.0 (the
+;; "License"); you may not use this file except in compliance
+;; with the License.  You may obtain a copy of the License at
+;;
+;; http:;; www.apache.org/licenses/LICENSE-2.0
+;;
+;; Unless required by applicable law or agreed to in writing, software
+;; distributed under the License is distributed on an "AS IS" BASIS,
+;; WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+;; See the License for the specific language governing permissions and
+;; limitations under the License.
 (ns backtype.storm.bootstrap)
 
 (defmacro bootstrap []

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/clj/backtype/storm/clojure.clj
----------------------------------------------------------------------
diff --git a/storm-core/src/clj/backtype/storm/clojure.clj b/storm-core/src/clj/backtype/storm/clojure.clj
index 0cf8a80..919b4ae 100644
--- a/storm-core/src/clj/backtype/storm/clojure.clj
+++ b/storm-core/src/clj/backtype/storm/clojure.clj
@@ -1,3 +1,18 @@
+;; Licensed to the Apache Software Foundation (ASF) under one
+;; or more contributor license agreements.  See the NOTICE file
+;; distributed with this work for additional information
+;; regarding copyright ownership.  The ASF licenses this file
+;; to you under the Apache License, Version 2.0 (the
+;; "License"); you may not use this file except in compliance
+;; with the License.  You may obtain a copy of the License at
+;;
+;; http:;; www.apache.org/licenses/LICENSE-2.0
+;;
+;; Unless required by applicable law or agreed to in writing, software
+;; distributed under the License is distributed on an "AS IS" BASIS,
+;; WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+;; See the License for the specific language governing permissions and
+;; limitations under the License.
 (ns backtype.storm.clojure
   (:use [backtype.storm bootstrap util])
   (:import [backtype.storm StormSubmitter])

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/clj/backtype/storm/cluster.clj
----------------------------------------------------------------------
diff --git a/storm-core/src/clj/backtype/storm/cluster.clj b/storm-core/src/clj/backtype/storm/cluster.clj
index 7231b15..3d27224 100644
--- a/storm-core/src/clj/backtype/storm/cluster.clj
+++ b/storm-core/src/clj/backtype/storm/cluster.clj
@@ -1,3 +1,18 @@
+;; Licensed to the Apache Software Foundation (ASF) under one
+;; or more contributor license agreements.  See the NOTICE file
+;; distributed with this work for additional information
+;; regarding copyright ownership.  The ASF licenses this file
+;; to you under the Apache License, Version 2.0 (the
+;; "License"); you may not use this file except in compliance
+;; with the License.  You may obtain a copy of the License at
+;;
+;; http:;; www.apache.org/licenses/LICENSE-2.0
+;;
+;; Unless required by applicable law or agreed to in writing, software
+;; distributed under the License is distributed on an "AS IS" BASIS,
+;; WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+;; See the License for the specific language governing permissions and
+;; limitations under the License.
 (ns backtype.storm.cluster
   (:import [org.apache.zookeeper.data Stat])
   (:import [org.apache.zookeeper KeeperException KeeperException$NoNodeException])

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/clj/backtype/storm/command/activate.clj
----------------------------------------------------------------------
diff --git a/storm-core/src/clj/backtype/storm/command/activate.clj b/storm-core/src/clj/backtype/storm/command/activate.clj
index 33c9b8a..b7f2431 100644
--- a/storm-core/src/clj/backtype/storm/command/activate.clj
+++ b/storm-core/src/clj/backtype/storm/command/activate.clj
@@ -1,3 +1,18 @@
+;; Licensed to the Apache Software Foundation (ASF) under one
+;; or more contributor license agreements.  See the NOTICE file
+;; distributed with this work for additional information
+;; regarding copyright ownership.  The ASF licenses this file
+;; to you under the Apache License, Version 2.0 (the
+;; "License"); you may not use this file except in compliance
+;; with the License.  You may obtain a copy of the License at
+;;
+;; http:;; www.apache.org/licenses/LICENSE-2.0
+;;
+;; Unless required by applicable law or agreed to in writing, software
+;; distributed under the License is distributed on an "AS IS" BASIS,
+;; WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+;; See the License for the specific language governing permissions and
+;; limitations under the License.
 (ns backtype.storm.command.activate
   (:use [backtype.storm thrift log])
   (:gen-class))

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/clj/backtype/storm/command/config_value.clj
----------------------------------------------------------------------
diff --git a/storm-core/src/clj/backtype/storm/command/config_value.clj b/storm-core/src/clj/backtype/storm/command/config_value.clj
index 113a641..4e0cb66 100644
--- a/storm-core/src/clj/backtype/storm/command/config_value.clj
+++ b/storm-core/src/clj/backtype/storm/command/config_value.clj
@@ -1,3 +1,18 @@
+;; Licensed to the Apache Software Foundation (ASF) under one
+;; or more contributor license agreements.  See the NOTICE file
+;; distributed with this work for additional information
+;; regarding copyright ownership.  The ASF licenses this file
+;; to you under the Apache License, Version 2.0 (the
+;; "License"); you may not use this file except in compliance
+;; with the License.  You may obtain a copy of the License at
+;;
+;; http:;; www.apache.org/licenses/LICENSE-2.0
+;;
+;; Unless required by applicable law or agreed to in writing, software
+;; distributed under the License is distributed on an "AS IS" BASIS,
+;; WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+;; See the License for the specific language governing permissions and
+;; limitations under the License.
 (ns backtype.storm.command.config-value
   (:use [backtype.storm config log])
   (:gen-class))

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/clj/backtype/storm/command/deactivate.clj
----------------------------------------------------------------------
diff --git a/storm-core/src/clj/backtype/storm/command/deactivate.clj b/storm-core/src/clj/backtype/storm/command/deactivate.clj
index 52e328f..08f818e 100644
--- a/storm-core/src/clj/backtype/storm/command/deactivate.clj
+++ b/storm-core/src/clj/backtype/storm/command/deactivate.clj
@@ -1,3 +1,18 @@
+;; Licensed to the Apache Software Foundation (ASF) under one
+;; or more contributor license agreements.  See the NOTICE file
+;; distributed with this work for additional information
+;; regarding copyright ownership.  The ASF licenses this file
+;; to you under the Apache License, Version 2.0 (the
+;; "License"); you may not use this file except in compliance
+;; with the License.  You may obtain a copy of the License at
+;;
+;; http:;; www.apache.org/licenses/LICENSE-2.0
+;;
+;; Unless required by applicable law or agreed to in writing, software
+;; distributed under the License is distributed on an "AS IS" BASIS,
+;; WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+;; See the License for the specific language governing permissions and
+;; limitations under the License.
 (ns backtype.storm.command.deactivate
   (:use [backtype.storm thrift log])
   (:gen-class))

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/clj/backtype/storm/command/dev_zookeeper.clj
----------------------------------------------------------------------
diff --git a/storm-core/src/clj/backtype/storm/command/dev_zookeeper.clj b/storm-core/src/clj/backtype/storm/command/dev_zookeeper.clj
index 48f6540..58ea616 100644
--- a/storm-core/src/clj/backtype/storm/command/dev_zookeeper.clj
+++ b/storm-core/src/clj/backtype/storm/command/dev_zookeeper.clj
@@ -1,3 +1,18 @@
+;; Licensed to the Apache Software Foundation (ASF) under one
+;; or more contributor license agreements.  See the NOTICE file
+;; distributed with this work for additional information
+;; regarding copyright ownership.  The ASF licenses this file
+;; to you under the Apache License, Version 2.0 (the
+;; "License"); you may not use this file except in compliance
+;; with the License.  You may obtain a copy of the License at
+;;
+;; http:;; www.apache.org/licenses/LICENSE-2.0
+;;
+;; Unless required by applicable law or agreed to in writing, software
+;; distributed under the License is distributed on an "AS IS" BASIS,
+;; WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+;; See the License for the specific language governing permissions and
+;; limitations under the License.
 (ns backtype.storm.command.dev-zookeeper
   (:use [backtype.storm zookeeper util config])
   (:gen-class))

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/clj/backtype/storm/command/kill_topology.clj
----------------------------------------------------------------------
diff --git a/storm-core/src/clj/backtype/storm/command/kill_topology.clj b/storm-core/src/clj/backtype/storm/command/kill_topology.clj
index 11380d1..ac2f27d 100644
--- a/storm-core/src/clj/backtype/storm/command/kill_topology.clj
+++ b/storm-core/src/clj/backtype/storm/command/kill_topology.clj
@@ -1,3 +1,18 @@
+;; Licensed to the Apache Software Foundation (ASF) under one
+;; or more contributor license agreements.  See the NOTICE file
+;; distributed with this work for additional information
+;; regarding copyright ownership.  The ASF licenses this file
+;; to you under the Apache License, Version 2.0 (the
+;; "License"); you may not use this file except in compliance
+;; with the License.  You may obtain a copy of the License at
+;;
+;; http:;; www.apache.org/licenses/LICENSE-2.0
+;;
+;; Unless required by applicable law or agreed to in writing, software
+;; distributed under the License is distributed on an "AS IS" BASIS,
+;; WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+;; See the License for the specific language governing permissions and
+;; limitations under the License.
 (ns backtype.storm.command.kill-topology
   (:use [clojure.tools.cli :only [cli]])
   (:use [backtype.storm thrift config log])

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/clj/backtype/storm/command/list.clj
----------------------------------------------------------------------
diff --git a/storm-core/src/clj/backtype/storm/command/list.clj b/storm-core/src/clj/backtype/storm/command/list.clj
index 2b6f7a8..8d305b3 100644
--- a/storm-core/src/clj/backtype/storm/command/list.clj
+++ b/storm-core/src/clj/backtype/storm/command/list.clj
@@ -1,3 +1,18 @@
+;; Licensed to the Apache Software Foundation (ASF) under one
+;; or more contributor license agreements.  See the NOTICE file
+;; distributed with this work for additional information
+;; regarding copyright ownership.  The ASF licenses this file
+;; to you under the Apache License, Version 2.0 (the
+;; "License"); you may not use this file except in compliance
+;; with the License.  You may obtain a copy of the License at
+;;
+;; http:;; www.apache.org/licenses/LICENSE-2.0
+;;
+;; Unless required by applicable law or agreed to in writing, software
+;; distributed under the License is distributed on an "AS IS" BASIS,
+;; WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+;; See the License for the specific language governing permissions and
+;; limitations under the License.
 (ns backtype.storm.command.list
   (:use [backtype.storm thrift log])
   (:import [backtype.storm.generated TopologySummary])

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/clj/backtype/storm/command/rebalance.clj
----------------------------------------------------------------------
diff --git a/storm-core/src/clj/backtype/storm/command/rebalance.clj b/storm-core/src/clj/backtype/storm/command/rebalance.clj
index 2d38c77..d8e54d3 100644
--- a/storm-core/src/clj/backtype/storm/command/rebalance.clj
+++ b/storm-core/src/clj/backtype/storm/command/rebalance.clj
@@ -1,3 +1,18 @@
+;; Licensed to the Apache Software Foundation (ASF) under one
+;; or more contributor license agreements.  See the NOTICE file
+;; distributed with this work for additional information
+;; regarding copyright ownership.  The ASF licenses this file
+;; to you under the Apache License, Version 2.0 (the
+;; "License"); you may not use this file except in compliance
+;; with the License.  You may obtain a copy of the License at
+;;
+;; http:;; www.apache.org/licenses/LICENSE-2.0
+;;
+;; Unless required by applicable law or agreed to in writing, software
+;; distributed under the License is distributed on an "AS IS" BASIS,
+;; WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+;; See the License for the specific language governing permissions and
+;; limitations under the License.
 (ns backtype.storm.command.rebalance
   (:use [clojure.tools.cli :only [cli]])
   (:use [backtype.storm thrift config log])

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/clj/backtype/storm/command/shell_submission.clj
----------------------------------------------------------------------
diff --git a/storm-core/src/clj/backtype/storm/command/shell_submission.clj b/storm-core/src/clj/backtype/storm/command/shell_submission.clj
index 4a3a759..d572b85 100644
--- a/storm-core/src/clj/backtype/storm/command/shell_submission.clj
+++ b/storm-core/src/clj/backtype/storm/command/shell_submission.clj
@@ -1,3 +1,18 @@
+;; Licensed to the Apache Software Foundation (ASF) under one
+;; or more contributor license agreements.  See the NOTICE file
+;; distributed with this work for additional information
+;; regarding copyright ownership.  The ASF licenses this file
+;; to you under the Apache License, Version 2.0 (the
+;; "License"); you may not use this file except in compliance
+;; with the License.  You may obtain a copy of the License at
+;;
+;; http:;; www.apache.org/licenses/LICENSE-2.0
+;;
+;; Unless required by applicable law or agreed to in writing, software
+;; distributed under the License is distributed on an "AS IS" BASIS,
+;; WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+;; See the License for the specific language governing permissions and
+;; limitations under the License.
 (ns backtype.storm.command.shell-submission
   (:import [backtype.storm StormSubmitter])
   (:use [backtype.storm thrift util config log])

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/clj/backtype/storm/config.clj
----------------------------------------------------------------------
diff --git a/storm-core/src/clj/backtype/storm/config.clj b/storm-core/src/clj/backtype/storm/config.clj
index c11074e..7db986f 100644
--- a/storm-core/src/clj/backtype/storm/config.clj
+++ b/storm-core/src/clj/backtype/storm/config.clj
@@ -1,3 +1,18 @@
+;; Licensed to the Apache Software Foundation (ASF) under one
+;; or more contributor license agreements.  See the NOTICE file
+;; distributed with this work for additional information
+;; regarding copyright ownership.  The ASF licenses this file
+;; to you under the Apache License, Version 2.0 (the
+;; "License"); you may not use this file except in compliance
+;; with the License.  You may obtain a copy of the License at
+;;
+;; http:;; www.apache.org/licenses/LICENSE-2.0
+;;
+;; Unless required by applicable law or agreed to in writing, software
+;; distributed under the License is distributed on an "AS IS" BASIS,
+;; WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+;; See the License for the specific language governing permissions and
+;; limitations under the License.
 (ns backtype.storm.config
   (:import [java.io FileReader File])
   (:import [backtype.storm Config ConfigValidation$FieldValidator])

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/clj/backtype/storm/daemon/acker.clj
----------------------------------------------------------------------
diff --git a/storm-core/src/clj/backtype/storm/daemon/acker.clj b/storm-core/src/clj/backtype/storm/daemon/acker.clj
index d3336b7..74913a2 100644
--- a/storm-core/src/clj/backtype/storm/daemon/acker.clj
+++ b/storm-core/src/clj/backtype/storm/daemon/acker.clj
@@ -1,3 +1,18 @@
+;; Licensed to the Apache Software Foundation (ASF) under one
+;; or more contributor license agreements.  See the NOTICE file
+;; distributed with this work for additional information
+;; regarding copyright ownership.  The ASF licenses this file
+;; to you under the Apache License, Version 2.0 (the
+;; "License"); you may not use this file except in compliance
+;; with the License.  You may obtain a copy of the License at
+;;
+;; http:;; www.apache.org/licenses/LICENSE-2.0
+;;
+;; Unless required by applicable law or agreed to in writing, software
+;; distributed under the License is distributed on an "AS IS" BASIS,
+;; WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+;; See the License for the specific language governing permissions and
+;; limitations under the License.
 (ns backtype.storm.daemon.acker
   (:import [backtype.storm.task OutputCollector TopologyContext IBolt])
   (:import [backtype.storm.tuple Tuple Fields])

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/clj/backtype/storm/daemon/builtin_metrics.clj
----------------------------------------------------------------------
diff --git a/storm-core/src/clj/backtype/storm/daemon/builtin_metrics.clj b/storm-core/src/clj/backtype/storm/daemon/builtin_metrics.clj
index cf46632..02ca93d 100644
--- a/storm-core/src/clj/backtype/storm/daemon/builtin_metrics.clj
+++ b/storm-core/src/clj/backtype/storm/daemon/builtin_metrics.clj
@@ -1,3 +1,18 @@
+;; Licensed to the Apache Software Foundation (ASF) under one
+;; or more contributor license agreements.  See the NOTICE file
+;; distributed with this work for additional information
+;; regarding copyright ownership.  The ASF licenses this file
+;; to you under the Apache License, Version 2.0 (the
+;; "License"); you may not use this file except in compliance
+;; with the License.  You may obtain a copy of the License at
+;;
+;; http:;; www.apache.org/licenses/LICENSE-2.0
+;;
+;; Unless required by applicable law or agreed to in writing, software
+;; distributed under the License is distributed on an "AS IS" BASIS,
+;; WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+;; See the License for the specific language governing permissions and
+;; limitations under the License.
 (ns backtype.storm.daemon.builtin-metrics
   (:import [backtype.storm.metric.api MultiCountMetric MultiReducedMetric MeanReducer StateMetric])
   (:import [backtype.storm Config])

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/clj/backtype/storm/daemon/common.clj
----------------------------------------------------------------------
diff --git a/storm-core/src/clj/backtype/storm/daemon/common.clj b/storm-core/src/clj/backtype/storm/daemon/common.clj
index dd8b12f..5047848 100644
--- a/storm-core/src/clj/backtype/storm/daemon/common.clj
+++ b/storm-core/src/clj/backtype/storm/daemon/common.clj
@@ -1,3 +1,18 @@
+;; Licensed to the Apache Software Foundation (ASF) under one
+;; or more contributor license agreements.  See the NOTICE file
+;; distributed with this work for additional information
+;; regarding copyright ownership.  The ASF licenses this file
+;; to you under the Apache License, Version 2.0 (the
+;; "License"); you may not use this file except in compliance
+;; with the License.  You may obtain a copy of the License at
+;;
+;; http:;; www.apache.org/licenses/LICENSE-2.0
+;;
+;; Unless required by applicable law or agreed to in writing, software
+;; distributed under the License is distributed on an "AS IS" BASIS,
+;; WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+;; See the License for the specific language governing permissions and
+;; limitations under the License.
 (ns backtype.storm.daemon.common
   (:use [backtype.storm log config util])
   (:import [backtype.storm.generated StormTopology

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/clj/backtype/storm/daemon/drpc.clj
----------------------------------------------------------------------
diff --git a/storm-core/src/clj/backtype/storm/daemon/drpc.clj b/storm-core/src/clj/backtype/storm/daemon/drpc.clj
index f6c9073..97af4b1 100644
--- a/storm-core/src/clj/backtype/storm/daemon/drpc.clj
+++ b/storm-core/src/clj/backtype/storm/daemon/drpc.clj
@@ -1,3 +1,18 @@
+;; Licensed to the Apache Software Foundation (ASF) under one
+;; or more contributor license agreements.  See the NOTICE file
+;; distributed with this work for additional information
+;; regarding copyright ownership.  The ASF licenses this file
+;; to you under the Apache License, Version 2.0 (the
+;; "License"); you may not use this file except in compliance
+;; with the License.  You may obtain a copy of the License at
+;;
+;; http:;; www.apache.org/licenses/LICENSE-2.0
+;;
+;; Unless required by applicable law or agreed to in writing, software
+;; distributed under the License is distributed on an "AS IS" BASIS,
+;; WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+;; See the License for the specific language governing permissions and
+;; limitations under the License.
 (ns backtype.storm.daemon.drpc
   (:import [org.apache.thrift7.server THsHaServer THsHaServer$Args])
   (:import [org.apache.thrift7.protocol TBinaryProtocol TBinaryProtocol$Factory])
@@ -100,7 +115,7 @@
 (defn launch-server!
   ([]
     (let [conf (read-storm-config)
-          worker-threads (int (conf DRPC-WORKER-THREADS))
+          worker-threads (int (conf DRPC-WORKER-THREADS))
           queue-size (int (conf DRPC-QUEUE-SIZE))
           service-handler (service-handler)
           ;; requests and returns need to be on separate thread pools, since calls to
@@ -110,7 +125,7 @@
           handler-server (THsHaServer. (-> (TNonblockingServerSocket. (int (conf DRPC-PORT)))
                                              (THsHaServer$Args.)
                                              (.workerThreads 64)
-                                             (.executorService (ThreadPoolExecutor. worker-threads worker-threads 
+                                             (.executorService (ThreadPoolExecutor. worker-threads worker-threads 
                                                                  60 TimeUnit/SECONDS (ArrayBlockingQueue. queue-size)))
                                              (.protocolFactory (TBinaryProtocol$Factory.))
                                              (.processor (DistributedRPC$Processor. service-handler))

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/clj/backtype/storm/daemon/executor.clj
----------------------------------------------------------------------
diff --git a/storm-core/src/clj/backtype/storm/daemon/executor.clj b/storm-core/src/clj/backtype/storm/daemon/executor.clj
index 40f5561..892eb04 100644
--- a/storm-core/src/clj/backtype/storm/daemon/executor.clj
+++ b/storm-core/src/clj/backtype/storm/daemon/executor.clj
@@ -1,3 +1,18 @@
+;; Licensed to the Apache Software Foundation (ASF) under one
+;; or more contributor license agreements.  See the NOTICE file
+;; distributed with this work for additional information
+;; regarding copyright ownership.  The ASF licenses this file
+;; to you under the Apache License, Version 2.0 (the
+;; "License"); you may not use this file except in compliance
+;; with the License.  You may obtain a copy of the License at
+;;
+;; http:;; www.apache.org/licenses/LICENSE-2.0
+;;
+;; Unless required by applicable law or agreed to in writing, software
+;; distributed under the License is distributed on an "AS IS" BASIS,
+;; WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+;; See the License for the specific language governing permissions and
+;; limitations under the License.
 (ns backtype.storm.daemon.executor
   (:use [backtype.storm.daemon common])
   (:use [backtype.storm bootstrap])

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/clj/backtype/storm/daemon/logviewer.clj
----------------------------------------------------------------------
diff --git a/storm-core/src/clj/backtype/storm/daemon/logviewer.clj b/storm-core/src/clj/backtype/storm/daemon/logviewer.clj
index c116937..bc0e08c 100644
--- a/storm-core/src/clj/backtype/storm/daemon/logviewer.clj
+++ b/storm-core/src/clj/backtype/storm/daemon/logviewer.clj
@@ -1,3 +1,18 @@
+;; Licensed to the Apache Software Foundation (ASF) under one
+;; or more contributor license agreements.  See the NOTICE file
+;; distributed with this work for additional information
+;; regarding copyright ownership.  The ASF licenses this file
+;; to you under the Apache License, Version 2.0 (the
+;; "License"); you may not use this file except in compliance
+;; with the License.  You may obtain a copy of the License at
+;;
+;; http:;; www.apache.org/licenses/LICENSE-2.0
+;;
+;; Unless required by applicable law or agreed to in writing, software
+;; distributed under the License is distributed on an "AS IS" BASIS,
+;; WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+;; See the License for the specific language governing permissions and
+;; limitations under the License.
 (ns backtype.storm.daemon.logviewer
   (:use compojure.core)
   (:use [hiccup core page-helpers])

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/clj/backtype/storm/daemon/nimbus.clj
----------------------------------------------------------------------
diff --git a/storm-core/src/clj/backtype/storm/daemon/nimbus.clj b/storm-core/src/clj/backtype/storm/daemon/nimbus.clj
index caac996..13d4cef 100644
--- a/storm-core/src/clj/backtype/storm/daemon/nimbus.clj
+++ b/storm-core/src/clj/backtype/storm/daemon/nimbus.clj
@@ -1,3 +1,18 @@
+;; Licensed to the Apache Software Foundation (ASF) under one
+;; or more contributor license agreements.  See the NOTICE file
+;; distributed with this work for additional information
+;; regarding copyright ownership.  The ASF licenses this file
+;; to you under the Apache License, Version 2.0 (the
+;; "License"); you may not use this file except in compliance
+;; with the License.  You may obtain a copy of the License at
+;;
+;; http:;; www.apache.org/licenses/LICENSE-2.0
+;;
+;; Unless required by applicable law or agreed to in writing, software
+;; distributed under the License is distributed on an "AS IS" BASIS,
+;; WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+;; See the License for the specific language governing permissions and
+;; limitations under the License.
 (ns backtype.storm.daemon.nimbus
   (:import [org.apache.thrift7.server THsHaServer THsHaServer$Args])
   (:import [org.apache.thrift7.protocol TBinaryProtocol TBinaryProtocol$Factory])

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/clj/backtype/storm/daemon/supervisor.clj
----------------------------------------------------------------------
diff --git a/storm-core/src/clj/backtype/storm/daemon/supervisor.clj b/storm-core/src/clj/backtype/storm/daemon/supervisor.clj
index 1504431..af47c26 100644
--- a/storm-core/src/clj/backtype/storm/daemon/supervisor.clj
+++ b/storm-core/src/clj/backtype/storm/daemon/supervisor.clj
@@ -1,3 +1,18 @@
+;; Licensed to the Apache Software Foundation (ASF) under one
+;; or more contributor license agreements.  See the NOTICE file
+;; distributed with this work for additional information
+;; regarding copyright ownership.  The ASF licenses this file
+;; to you under the Apache License, Version 2.0 (the
+;; "License"); you may not use this file except in compliance
+;; with the License.  You may obtain a copy of the License at
+;;
+;; http:;; www.apache.org/licenses/LICENSE-2.0
+;;
+;; Unless required by applicable law or agreed to in writing, software
+;; distributed under the License is distributed on an "AS IS" BASIS,
+;; WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+;; See the License for the specific language governing permissions and
+;; limitations under the License.
 (ns backtype.storm.daemon.supervisor
   (:import [backtype.storm.scheduler ISupervisor])
   (:use [backtype.storm bootstrap])

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/clj/backtype/storm/daemon/task.clj
----------------------------------------------------------------------
diff --git a/storm-core/src/clj/backtype/storm/daemon/task.clj b/storm-core/src/clj/backtype/storm/daemon/task.clj
index a517e6f..0dfbb62 100644
--- a/storm-core/src/clj/backtype/storm/daemon/task.clj
+++ b/storm-core/src/clj/backtype/storm/daemon/task.clj
@@ -1,3 +1,18 @@
+;; Licensed to the Apache Software Foundation (ASF) under one
+;; or more contributor license agreements.  See the NOTICE file
+;; distributed with this work for additional information
+;; regarding copyright ownership.  The ASF licenses this file
+;; to you under the Apache License, Version 2.0 (the
+;; "License"); you may not use this file except in compliance
+;; with the License.  You may obtain a copy of the License at
+;;
+;; http:;; www.apache.org/licenses/LICENSE-2.0
+;;
+;; Unless required by applicable law or agreed to in writing, software
+;; distributed under the License is distributed on an "AS IS" BASIS,
+;; WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+;; See the License for the specific language governing permissions and
+;; limitations under the License.
 (ns backtype.storm.daemon.task
   (:use [backtype.storm.daemon common])
   (:use [backtype.storm bootstrap])

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/clj/backtype/storm/daemon/worker.clj
----------------------------------------------------------------------
diff --git a/storm-core/src/clj/backtype/storm/daemon/worker.clj b/storm-core/src/clj/backtype/storm/daemon/worker.clj
index 5182027..1473853 100644
--- a/storm-core/src/clj/backtype/storm/daemon/worker.clj
+++ b/storm-core/src/clj/backtype/storm/daemon/worker.clj
@@ -1,3 +1,18 @@
+;; Licensed to the Apache Software Foundation (ASF) under one
+;; or more contributor license agreements.  See the NOTICE file
+;; distributed with this work for additional information
+;; regarding copyright ownership.  The ASF licenses this file
+;; to you under the Apache License, Version 2.0 (the
+;; "License"); you may not use this file except in compliance
+;; with the License.  You may obtain a copy of the License at
+;;
+;; http:;; www.apache.org/licenses/LICENSE-2.0
+;;
+;; Unless required by applicable law or agreed to in writing, software
+;; distributed under the License is distributed on an "AS IS" BASIS,
+;; WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+;; See the License for the specific language governing permissions and
+;; limitations under the License.
 (ns backtype.storm.daemon.worker
   (:use [backtype.storm.daemon common])
   (:use [backtype.storm bootstrap])

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/clj/backtype/storm/disruptor.clj
----------------------------------------------------------------------
diff --git a/storm-core/src/clj/backtype/storm/disruptor.clj b/storm-core/src/clj/backtype/storm/disruptor.clj
index 5dc1757..9224c9e 100644
--- a/storm-core/src/clj/backtype/storm/disruptor.clj
+++ b/storm-core/src/clj/backtype/storm/disruptor.clj
@@ -1,3 +1,18 @@
+;; Licensed to the Apache Software Foundation (ASF) under one
+;; or more contributor license agreements.  See the NOTICE file
+;; distributed with this work for additional information
+;; regarding copyright ownership.  The ASF licenses this file
+;; to you under the Apache License, Version 2.0 (the
+;; "License"); you may not use this file except in compliance
+;; with the License.  You may obtain a copy of the License at
+;;
+;; http:;; www.apache.org/licenses/LICENSE-2.0
+;;
+;; Unless required by applicable law or agreed to in writing, software
+;; distributed under the License is distributed on an "AS IS" BASIS,
+;; WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+;; See the License for the specific language governing permissions and
+;; limitations under the License.
 (ns backtype.storm.disruptor
   (:import [backtype.storm.utils DisruptorQueue])
   (:import [com.lmax.disruptor MultiThreadedClaimStrategy SingleThreadedClaimStrategy

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/clj/backtype/storm/event.clj
----------------------------------------------------------------------
diff --git a/storm-core/src/clj/backtype/storm/event.clj b/storm-core/src/clj/backtype/storm/event.clj
index 5b37fc7..c3885aa 100644
--- a/storm-core/src/clj/backtype/storm/event.clj
+++ b/storm-core/src/clj/backtype/storm/event.clj
@@ -1,3 +1,18 @@
+;; Licensed to the Apache Software Foundation (ASF) under one
+;; or more contributor license agreements.  See the NOTICE file
+;; distributed with this work for additional information
+;; regarding copyright ownership.  The ASF licenses this file
+;; to you under the Apache License, Version 2.0 (the
+;; "License"); you may not use this file except in compliance
+;; with the License.  You may obtain a copy of the License at
+;;
+;; http:;; www.apache.org/licenses/LICENSE-2.0
+;;
+;; Unless required by applicable law or agreed to in writing, software
+;; distributed under the License is distributed on an "AS IS" BASIS,
+;; WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+;; See the License for the specific language governing permissions and
+;; limitations under the License.
 (ns backtype.storm.event
   (:use [backtype.storm log util])
   (:import [backtype.storm.utils Time Utils])

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/clj/backtype/storm/log.clj
----------------------------------------------------------------------
diff --git a/storm-core/src/clj/backtype/storm/log.clj b/storm-core/src/clj/backtype/storm/log.clj
index 1c5c035..a1483bf 100644
--- a/storm-core/src/clj/backtype/storm/log.clj
+++ b/storm-core/src/clj/backtype/storm/log.clj
@@ -1,3 +1,18 @@
+;; Licensed to the Apache Software Foundation (ASF) under one
+;; or more contributor license agreements.  See the NOTICE file
+;; distributed with this work for additional information
+;; regarding copyright ownership.  The ASF licenses this file
+;; to you under the Apache License, Version 2.0 (the
+;; "License"); you may not use this file except in compliance
+;; with the License.  You may obtain a copy of the License at
+;;
+;; http:;; www.apache.org/licenses/LICENSE-2.0
+;;
+;; Unless required by applicable law or agreed to in writing, software
+;; distributed under the License is distributed on an "AS IS" BASIS,
+;; WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+;; See the License for the specific language governing permissions and
+;; limitations under the License.
 (ns backtype.storm.log
   (:require [clojure.tools [logging :as log]]))