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:46 UTC

[02/18] add Apache license headers to source files

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/multilang/py/storm.py
----------------------------------------------------------------------
diff --git a/storm-core/src/multilang/py/storm.py b/storm-core/src/multilang/py/storm.py
index f42e426..a0b9afb 100755
--- a/storm-core/src/multilang/py/storm.py
+++ b/storm-core/src/multilang/py/storm.py
@@ -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.
+
 import sys
 import os
 import traceback

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/multilang/rb/storm.rb
----------------------------------------------------------------------
diff --git a/storm-core/src/multilang/rb/storm.rb b/storm-core/src/multilang/rb/storm.rb
index f669a8f..0d79996 100644
--- a/storm-core/src/multilang/rb/storm.rb
+++ b/storm-core/src/multilang/rb/storm.rb
@@ -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.
+
 require "rubygems"
 require "json"
 

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/storm.thrift
----------------------------------------------------------------------
diff --git a/storm-core/src/storm.thrift b/storm-core/src/storm.thrift
index 475acd6..3c54d30 100644
--- a/storm-core/src/storm.thrift
+++ b/storm-core/src/storm.thrift
@@ -1,5 +1,28 @@
 #!/usr/local/bin/thrift --gen java:beans,nocamel,hashcode
 
+/*
+ * Licensed 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.
+ *
+ * Contains some contributions under the Thrift Software License.
+ * Please see doc/old-thrift-license.txt in the Thrift distribution for
+ * details.
+ */
+
 namespace java backtype.storm.generated
 
 union JavaObjectArg {

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/ui/public/css/style.css
----------------------------------------------------------------------
diff --git a/storm-core/src/ui/public/css/style.css b/storm-core/src/ui/public/css/style.css
index 4ba1bf5..d49231d 100644
--- a/storm-core/src/ui/public/css/style.css
+++ b/storm-core/src/ui/public/css/style.css
@@ -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.
+ */
 .js-only {
     display: none;
 }
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/ui/public/js/script.js
----------------------------------------------------------------------
diff --git a/storm-core/src/ui/public/js/script.js b/storm-core/src/ui/public/js/script.js
index fe7e9e3..cc0d116 100644
--- a/storm-core/src/ui/public/js/script.js
+++ b/storm-core/src/ui/public/js/script.js
@@ -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.
+ */
 $.tablesorter.addParser({
     id:'stormtimestr',
     is:function (s) {

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/test/clj/backtype/storm/clojure_test.clj
----------------------------------------------------------------------
diff --git a/storm-core/test/clj/backtype/storm/clojure_test.clj b/storm-core/test/clj/backtype/storm/clojure_test.clj
index 247bf95..7cd0da2 100644
--- a/storm-core/test/clj/backtype/storm/clojure_test.clj
+++ b/storm-core/test/clj/backtype/storm/clojure_test.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-test
   (:use [clojure test])
   (:import [backtype.storm.testing TestWordSpout])

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/test/clj/backtype/storm/cluster_test.clj
----------------------------------------------------------------------
diff --git a/storm-core/test/clj/backtype/storm/cluster_test.clj b/storm-core/test/clj/backtype/storm/cluster_test.clj
index 62b1739..281203c 100644
--- a/storm-core/test/clj/backtype/storm/cluster_test.clj
+++ b/storm-core/test/clj/backtype/storm/cluster_test.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-test
   (:import [java.util Arrays])
   (:import [backtype.storm.daemon.common Assignment StormBase SupervisorInfo])

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/test/clj/backtype/storm/config_test.clj
----------------------------------------------------------------------
diff --git a/storm-core/test/clj/backtype/storm/config_test.clj b/storm-core/test/clj/backtype/storm/config_test.clj
index 4e2074f..bebf5c0 100644
--- a/storm-core/test/clj/backtype/storm/config_test.clj
+++ b/storm-core/test/clj/backtype/storm/config_test.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-test
   (:import [backtype.storm Config ConfigValidation])
   (:import [backtype.storm.scheduler TopologyDetails])

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/test/clj/backtype/storm/drpc_test.clj
----------------------------------------------------------------------
diff --git a/storm-core/test/clj/backtype/storm/drpc_test.clj b/storm-core/test/clj/backtype/storm/drpc_test.clj
index c7d759c..a2286db 100644
--- a/storm-core/test/clj/backtype/storm/drpc_test.clj
+++ b/storm-core/test/clj/backtype/storm/drpc_test.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.drpc-test
   (:use [clojure test])
   (:import [backtype.storm.drpc ReturnResults DRPCSpout

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/test/clj/backtype/storm/fields_test.clj
----------------------------------------------------------------------
diff --git a/storm-core/test/clj/backtype/storm/fields_test.clj b/storm-core/test/clj/backtype/storm/fields_test.clj
index 0c9b520..e641fdc 100644
--- a/storm-core/test/clj/backtype/storm/fields_test.clj
+++ b/storm-core/test/clj/backtype/storm/fields_test.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.fields-test
   (:use [clojure test])
   (:import [backtype.storm.tuple Fields])

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/test/clj/backtype/storm/grouping_test.clj
----------------------------------------------------------------------
diff --git a/storm-core/test/clj/backtype/storm/grouping_test.clj b/storm-core/test/clj/backtype/storm/grouping_test.clj
index 1c44690..a5c40a2 100644
--- a/storm-core/test/clj/backtype/storm/grouping_test.clj
+++ b/storm-core/test/clj/backtype/storm/grouping_test.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.grouping-test
   (:use [clojure test])
   (:import [backtype.storm.testing TestWordCounter TestWordSpout TestGlobalCount TestAggregatesCounter NGrouping])

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/test/clj/backtype/storm/integration_test.clj
----------------------------------------------------------------------
diff --git a/storm-core/test/clj/backtype/storm/integration_test.clj b/storm-core/test/clj/backtype/storm/integration_test.clj
index 553d0f7..8629973 100644
--- a/storm-core/test/clj/backtype/storm/integration_test.clj
+++ b/storm-core/test/clj/backtype/storm/integration_test.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.integration-test
   (:use [clojure test])
   (:import [backtype.storm.topology TopologyBuilder])

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/test/clj/backtype/storm/local_state_test.clj
----------------------------------------------------------------------
diff --git a/storm-core/test/clj/backtype/storm/local_state_test.clj b/storm-core/test/clj/backtype/storm/local_state_test.clj
index 71e7363..4b00be7 100644
--- a/storm-core/test/clj/backtype/storm/local_state_test.clj
+++ b/storm-core/test/clj/backtype/storm/local_state_test.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.local-state-test
   (:use [clojure test])
   (:use [backtype.storm testing])

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/test/clj/backtype/storm/messaging_test.clj
----------------------------------------------------------------------
diff --git a/storm-core/test/clj/backtype/storm/messaging_test.clj b/storm-core/test/clj/backtype/storm/messaging_test.clj
index 6b44ea1..f255b24 100644
--- a/storm-core/test/clj/backtype/storm/messaging_test.clj
+++ b/storm-core/test/clj/backtype/storm/messaging_test.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.messaging-test
   (:use [clojure test])
   (:import [backtype.storm.testing TestWordCounter TestWordSpout TestGlobalCount])

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/test/clj/backtype/storm/metrics_test.clj
----------------------------------------------------------------------
diff --git a/storm-core/test/clj/backtype/storm/metrics_test.clj b/storm-core/test/clj/backtype/storm/metrics_test.clj
index e6a0e99..c4c81c0 100644
--- a/storm-core/test/clj/backtype/storm/metrics_test.clj
+++ b/storm-core/test/clj/backtype/storm/metrics_test.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.metrics-test
   (:use [clojure test])
   (:import [backtype.storm.topology TopologyBuilder])

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/test/clj/backtype/storm/multilang_test.clj
----------------------------------------------------------------------
diff --git a/storm-core/test/clj/backtype/storm/multilang_test.clj b/storm-core/test/clj/backtype/storm/multilang_test.clj
index adbcb0f..85a1da1 100644
--- a/storm-core/test/clj/backtype/storm/multilang_test.clj
+++ b/storm-core/test/clj/backtype/storm/multilang_test.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.multilang-test
   (:use [clojure test])
   (:use [backtype.storm bootstrap testing])

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/test/clj/backtype/storm/nimbus_test.clj
----------------------------------------------------------------------
diff --git a/storm-core/test/clj/backtype/storm/nimbus_test.clj b/storm-core/test/clj/backtype/storm/nimbus_test.clj
index 7493034..bdb2851 100644
--- a/storm-core/test/clj/backtype/storm/nimbus_test.clj
+++ b/storm-core/test/clj/backtype/storm/nimbus_test.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.nimbus-test
   (:use [clojure test])
   (:require [backtype.storm.daemon [nimbus :as nimbus]])

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/test/clj/backtype/storm/scheduler_test.clj
----------------------------------------------------------------------
diff --git a/storm-core/test/clj/backtype/storm/scheduler_test.clj b/storm-core/test/clj/backtype/storm/scheduler_test.clj
index cfa3efd..ac55c4b 100644
--- a/storm-core/test/clj/backtype/storm/scheduler_test.clj
+++ b/storm-core/test/clj/backtype/storm/scheduler_test.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.scheduler-test
   (:use [clojure test])
   (:use [backtype.storm bootstrap config testing])

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/test/clj/backtype/storm/security/auth/AuthUtils_test.clj
----------------------------------------------------------------------
diff --git a/storm-core/test/clj/backtype/storm/security/auth/AuthUtils_test.clj b/storm-core/test/clj/backtype/storm/security/auth/AuthUtils_test.clj
index 6552636..85fe603 100644
--- a/storm-core/test/clj/backtype/storm/security/auth/AuthUtils_test.clj
+++ b/storm-core/test/clj/backtype/storm/security/auth/AuthUtils_test.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.security.auth.AuthUtils-test
   (:import [backtype.storm.security.auth AuthUtils])
   (:import [java.io IOException])

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/test/clj/backtype/storm/security/auth/ReqContext_test.clj
----------------------------------------------------------------------
diff --git a/storm-core/test/clj/backtype/storm/security/auth/ReqContext_test.clj b/storm-core/test/clj/backtype/storm/security/auth/ReqContext_test.clj
index 136c9b9..3f71578 100644
--- a/storm-core/test/clj/backtype/storm/security/auth/ReqContext_test.clj
+++ b/storm-core/test/clj/backtype/storm/security/auth/ReqContext_test.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.security.auth.ReqContext-test
   (:import [backtype.storm.security.auth ReqContext])
   (:import [java.net InetAddress])