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

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

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/backtype/storm/scheduler/ISupervisor.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/scheduler/ISupervisor.java b/storm-core/src/jvm/backtype/storm/scheduler/ISupervisor.java
index fa53d21..64e1595 100644
--- a/storm-core/src/jvm/backtype/storm/scheduler/ISupervisor.java
+++ b/storm-core/src/jvm/backtype/storm/scheduler/ISupervisor.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 backtype.storm.scheduler;
 
 import java.util.Map;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/backtype/storm/scheduler/SchedulerAssignment.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/scheduler/SchedulerAssignment.java b/storm-core/src/jvm/backtype/storm/scheduler/SchedulerAssignment.java
index 6f249a6..0212e48 100644
--- a/storm-core/src/jvm/backtype/storm/scheduler/SchedulerAssignment.java
+++ b/storm-core/src/jvm/backtype/storm/scheduler/SchedulerAssignment.java
@@ -1,41 +1,58 @@
-package backtype.storm.scheduler;
-
-import java.util.Map;
-import java.util.Set;
-
-public interface SchedulerAssignment {
-    /**
-     * Does this slot occupied by this assignment?
-     * @param slot
-     * @return
-     */
-    public boolean isSlotOccupied(WorkerSlot slot);
-
-    /**
-     * is the executor assigned?
-     * 
-     * @param executor
-     * @return
-     */
-    public boolean isExecutorAssigned(ExecutorDetails executor);
-    
-    /**
-     * get the topology-id this assignment is for.
-     * @return
-     */
-    public String getTopologyId();
-
-    /**
-     * get the executor -> slot map.
-     * @return
-     */
-    public Map<ExecutorDetails, WorkerSlot> getExecutorToSlot();
-
-    /**
-     * Return the executors covered by this assignments
-     * @return
-     */
-    public Set<ExecutorDetails> getExecutors();
-    
-    public Set<WorkerSlot> getSlots();
+/**
+ * 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 backtype.storm.scheduler;
+
+import java.util.Map;
+import java.util.Set;
+
+public interface SchedulerAssignment {
+    /**
+     * Does this slot occupied by this assignment?
+     * @param slot
+     * @return
+     */
+    public boolean isSlotOccupied(WorkerSlot slot);
+
+    /**
+     * is the executor assigned?
+     * 
+     * @param executor
+     * @return
+     */
+    public boolean isExecutorAssigned(ExecutorDetails executor);
+    
+    /**
+     * get the topology-id this assignment is for.
+     * @return
+     */
+    public String getTopologyId();
+
+    /**
+     * get the executor -> slot map.
+     * @return
+     */
+    public Map<ExecutorDetails, WorkerSlot> getExecutorToSlot();
+
+    /**
+     * Return the executors covered by this assignments
+     * @return
+     */
+    public Set<ExecutorDetails> getExecutors();
+    
+    public Set<WorkerSlot> getSlots();
 }
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/backtype/storm/scheduler/SchedulerAssignmentImpl.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/scheduler/SchedulerAssignmentImpl.java b/storm-core/src/jvm/backtype/storm/scheduler/SchedulerAssignmentImpl.java
index cf2882b..08af4b7 100644
--- a/storm-core/src/jvm/backtype/storm/scheduler/SchedulerAssignmentImpl.java
+++ b/storm-core/src/jvm/backtype/storm/scheduler/SchedulerAssignmentImpl.java
@@ -1,93 +1,110 @@
-package backtype.storm.scheduler;
-
-import java.util.ArrayList;
-import java.util.Collection;
-import java.util.HashMap;
-import java.util.HashSet;
-import java.util.List;
-import java.util.Map;
-import java.util.Set;
-
-//TODO: improve this by maintaining slot -> executors as well for more efficient operations
-public class SchedulerAssignmentImpl implements SchedulerAssignment {
-    /**
-     * topology-id this assignment is for.
-     */
-    String topologyId;
-    /**
-     * assignment detail, a mapping from executor to <code>WorkerSlot</code>
-     */
-    Map<ExecutorDetails, WorkerSlot> executorToSlot;
-    
-    public SchedulerAssignmentImpl(String topologyId, Map<ExecutorDetails, WorkerSlot> executorToSlots) {
-        this.topologyId = topologyId;
-        this.executorToSlot = new HashMap<ExecutorDetails, WorkerSlot>(0);
-        if (executorToSlots != null) {
-            this.executorToSlot.putAll(executorToSlots);
-        }
-    }
-
-    @Override
-    public Set<WorkerSlot> getSlots() {
-        return new HashSet(executorToSlot.values());
-    }    
-    
-    /**
-     * Assign the slot to executors.
-     * @param slot
-     * @param executors
-     */
-    public void assign(WorkerSlot slot, Collection<ExecutorDetails> executors) {
-        for (ExecutorDetails executor : executors) {
-            this.executorToSlot.put(executor, slot);
-        }
-    }
-    
-    /**
-     * Release the slot occupied by this assignment.
-     * @param slot
-     */
-    public void unassignBySlot(WorkerSlot slot) {
-        List<ExecutorDetails> executors = new ArrayList<ExecutorDetails>();
-        for (ExecutorDetails executor : this.executorToSlot.keySet()) {
-            WorkerSlot ws = this.executorToSlot.get(executor);
-            if (ws.equals(slot)) {
-                executors.add(executor);
-            }
-        }
-        
-        // remove
-        for (ExecutorDetails executor : executors) {
-            this.executorToSlot.remove(executor);
-        }
-    }
-
-    /**
-     * Does this slot occupied by this assignment?
-     * @param slot
-     * @return
-     */
-    public boolean isSlotOccupied(WorkerSlot slot) {
-        return this.executorToSlot.containsValue(slot);
-    }
-
-    public boolean isExecutorAssigned(ExecutorDetails executor) {
-        return this.executorToSlot.containsKey(executor);
-    }
-    
-    public String getTopologyId() {
-        return this.topologyId;
-    }
-
-    public Map<ExecutorDetails, WorkerSlot> getExecutorToSlot() {
-        return this.executorToSlot;
-    }
-
-    /**
-     * Return the executors covered by this assignments
-     * @return
-     */
-    public Set<ExecutorDetails> getExecutors() {
-        return this.executorToSlot.keySet();
-    }
+/**
+ * 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 backtype.storm.scheduler;
+
+import java.util.ArrayList;
+import java.util.Collection;
+import java.util.HashMap;
+import java.util.HashSet;
+import java.util.List;
+import java.util.Map;
+import java.util.Set;
+
+//TODO: improve this by maintaining slot -> executors as well for more efficient operations
+public class SchedulerAssignmentImpl implements SchedulerAssignment {
+    /**
+     * topology-id this assignment is for.
+     */
+    String topologyId;
+    /**
+     * assignment detail, a mapping from executor to <code>WorkerSlot</code>
+     */
+    Map<ExecutorDetails, WorkerSlot> executorToSlot;
+    
+    public SchedulerAssignmentImpl(String topologyId, Map<ExecutorDetails, WorkerSlot> executorToSlots) {
+        this.topologyId = topologyId;
+        this.executorToSlot = new HashMap<ExecutorDetails, WorkerSlot>(0);
+        if (executorToSlots != null) {
+            this.executorToSlot.putAll(executorToSlots);
+        }
+    }
+
+    @Override
+    public Set<WorkerSlot> getSlots() {
+        return new HashSet(executorToSlot.values());
+    }    
+    
+    /**
+     * Assign the slot to executors.
+     * @param slot
+     * @param executors
+     */
+    public void assign(WorkerSlot slot, Collection<ExecutorDetails> executors) {
+        for (ExecutorDetails executor : executors) {
+            this.executorToSlot.put(executor, slot);
+        }
+    }
+    
+    /**
+     * Release the slot occupied by this assignment.
+     * @param slot
+     */
+    public void unassignBySlot(WorkerSlot slot) {
+        List<ExecutorDetails> executors = new ArrayList<ExecutorDetails>();
+        for (ExecutorDetails executor : this.executorToSlot.keySet()) {
+            WorkerSlot ws = this.executorToSlot.get(executor);
+            if (ws.equals(slot)) {
+                executors.add(executor);
+            }
+        }
+        
+        // remove
+        for (ExecutorDetails executor : executors) {
+            this.executorToSlot.remove(executor);
+        }
+    }
+
+    /**
+     * Does this slot occupied by this assignment?
+     * @param slot
+     * @return
+     */
+    public boolean isSlotOccupied(WorkerSlot slot) {
+        return this.executorToSlot.containsValue(slot);
+    }
+
+    public boolean isExecutorAssigned(ExecutorDetails executor) {
+        return this.executorToSlot.containsKey(executor);
+    }
+    
+    public String getTopologyId() {
+        return this.topologyId;
+    }
+
+    public Map<ExecutorDetails, WorkerSlot> getExecutorToSlot() {
+        return this.executorToSlot;
+    }
+
+    /**
+     * Return the executors covered by this assignments
+     * @return
+     */
+    public Set<ExecutorDetails> getExecutors() {
+        return this.executorToSlot.keySet();
+    }
 }
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/backtype/storm/scheduler/SupervisorDetails.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/scheduler/SupervisorDetails.java b/storm-core/src/jvm/backtype/storm/scheduler/SupervisorDetails.java
index e05084b..7497f26 100644
--- a/storm-core/src/jvm/backtype/storm/scheduler/SupervisorDetails.java
+++ b/storm-core/src/jvm/backtype/storm/scheduler/SupervisorDetails.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 backtype.storm.scheduler;
 
 import java.util.Collection;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/backtype/storm/scheduler/Topologies.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/scheduler/Topologies.java b/storm-core/src/jvm/backtype/storm/scheduler/Topologies.java
index 42de41e..70af1b4 100644
--- a/storm-core/src/jvm/backtype/storm/scheduler/Topologies.java
+++ b/storm-core/src/jvm/backtype/storm/scheduler/Topologies.java
@@ -1,40 +1,57 @@
-package backtype.storm.scheduler;
-
-import java.util.Collection;
-import java.util.HashMap;
-import java.util.Map;
-
-public class Topologies {
-    Map<String, TopologyDetails> topologies;
-    Map<String, String> nameToId;
-    
-    public Topologies(Map<String, TopologyDetails> topologies) {
-        if(topologies==null) topologies = new HashMap();
-        this.topologies = new HashMap<String, TopologyDetails>(topologies.size());
-        this.topologies.putAll(topologies);
-        this.nameToId = new HashMap<String, String>(topologies.size());
-        
-        for (String topologyId : topologies.keySet()) {
-            TopologyDetails topology = topologies.get(topologyId);
-            this.nameToId.put(topology.getName(), topologyId);
-        }
-    }
-    
-    public TopologyDetails getById(String topologyId) {
-        return this.topologies.get(topologyId);
-    }
-    
-    public TopologyDetails getByName(String topologyName) {
-        String topologyId = this.nameToId.get(topologyName);
-        
-        if (topologyId == null) {
-            return null;
-        } else {
-            return this.getById(topologyId);
-        }
-    }
-    
-    public Collection<TopologyDetails> getTopologies() {
-        return this.topologies.values();
-    }
-}
+/**
+ * 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 backtype.storm.scheduler;
+
+import java.util.Collection;
+import java.util.HashMap;
+import java.util.Map;
+
+public class Topologies {
+    Map<String, TopologyDetails> topologies;
+    Map<String, String> nameToId;
+    
+    public Topologies(Map<String, TopologyDetails> topologies) {
+        if(topologies==null) topologies = new HashMap();
+        this.topologies = new HashMap<String, TopologyDetails>(topologies.size());
+        this.topologies.putAll(topologies);
+        this.nameToId = new HashMap<String, String>(topologies.size());
+        
+        for (String topologyId : topologies.keySet()) {
+            TopologyDetails topology = topologies.get(topologyId);
+            this.nameToId.put(topology.getName(), topologyId);
+        }
+    }
+    
+    public TopologyDetails getById(String topologyId) {
+        return this.topologies.get(topologyId);
+    }
+    
+    public TopologyDetails getByName(String topologyName) {
+        String topologyId = this.nameToId.get(topologyName);
+        
+        if (topologyId == null) {
+            return null;
+        } else {
+            return this.getById(topologyId);
+        }
+    }
+    
+    public Collection<TopologyDetails> getTopologies() {
+        return this.topologies.values();
+    }
+}

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/backtype/storm/scheduler/TopologyDetails.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/scheduler/TopologyDetails.java b/storm-core/src/jvm/backtype/storm/scheduler/TopologyDetails.java
index b506309..6daf4ed 100644
--- a/storm-core/src/jvm/backtype/storm/scheduler/TopologyDetails.java
+++ b/storm-core/src/jvm/backtype/storm/scheduler/TopologyDetails.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 backtype.storm.scheduler;
 
 import java.util.Collection;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/backtype/storm/scheduler/WorkerSlot.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/scheduler/WorkerSlot.java b/storm-core/src/jvm/backtype/storm/scheduler/WorkerSlot.java
index 09fa820..c89b3bc 100644
--- a/storm-core/src/jvm/backtype/storm/scheduler/WorkerSlot.java
+++ b/storm-core/src/jvm/backtype/storm/scheduler/WorkerSlot.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 backtype.storm.scheduler;
 
 public class WorkerSlot {

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/backtype/storm/security/auth/AuthUtils.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/security/auth/AuthUtils.java b/storm-core/src/jvm/backtype/storm/security/auth/AuthUtils.java
index be26776..b0e48e5 100644
--- a/storm-core/src/jvm/backtype/storm/security/auth/AuthUtils.java
+++ b/storm-core/src/jvm/backtype/storm/security/auth/AuthUtils.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 backtype.storm.security.auth;
 
 import backtype.storm.Config;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/backtype/storm/security/auth/IAuthorizer.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/security/auth/IAuthorizer.java b/storm-core/src/jvm/backtype/storm/security/auth/IAuthorizer.java
index d3bd0bf..d592bb7 100644
--- a/storm-core/src/jvm/backtype/storm/security/auth/IAuthorizer.java
+++ b/storm-core/src/jvm/backtype/storm/security/auth/IAuthorizer.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 backtype.storm.security.auth;
 
 import java.util.Map;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/backtype/storm/security/auth/ITransportPlugin.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/security/auth/ITransportPlugin.java b/storm-core/src/jvm/backtype/storm/security/auth/ITransportPlugin.java
index 8cbe288..aa6c53d 100644
--- a/storm-core/src/jvm/backtype/storm/security/auth/ITransportPlugin.java
+++ b/storm-core/src/jvm/backtype/storm/security/auth/ITransportPlugin.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 backtype.storm.security.auth;
 
 import java.io.IOException;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/backtype/storm/security/auth/ReqContext.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/security/auth/ReqContext.java b/storm-core/src/jvm/backtype/storm/security/auth/ReqContext.java
index 72964c1..68d8493 100644
--- a/storm-core/src/jvm/backtype/storm/security/auth/ReqContext.java
+++ b/storm-core/src/jvm/backtype/storm/security/auth/ReqContext.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 backtype.storm.security.auth;
 
 import java.util.Map;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/backtype/storm/security/auth/SaslTransportPlugin.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/security/auth/SaslTransportPlugin.java b/storm-core/src/jvm/backtype/storm/security/auth/SaslTransportPlugin.java
index 070be59..e2d6179 100644
--- a/storm-core/src/jvm/backtype/storm/security/auth/SaslTransportPlugin.java
+++ b/storm-core/src/jvm/backtype/storm/security/auth/SaslTransportPlugin.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 backtype.storm.security.auth;
 
 import java.io.IOException;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/backtype/storm/security/auth/SimpleTransportPlugin.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/security/auth/SimpleTransportPlugin.java b/storm-core/src/jvm/backtype/storm/security/auth/SimpleTransportPlugin.java
index 674006f..099fe08 100644
--- a/storm-core/src/jvm/backtype/storm/security/auth/SimpleTransportPlugin.java
+++ b/storm-core/src/jvm/backtype/storm/security/auth/SimpleTransportPlugin.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 backtype.storm.security.auth;
 
 import java.io.IOException;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/backtype/storm/security/auth/ThriftClient.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/security/auth/ThriftClient.java b/storm-core/src/jvm/backtype/storm/security/auth/ThriftClient.java
index a1d385a..e1ee01b 100644
--- a/storm-core/src/jvm/backtype/storm/security/auth/ThriftClient.java
+++ b/storm-core/src/jvm/backtype/storm/security/auth/ThriftClient.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 backtype.storm.security.auth;
 
 import java.io.IOException;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/backtype/storm/security/auth/ThriftServer.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/security/auth/ThriftServer.java b/storm-core/src/jvm/backtype/storm/security/auth/ThriftServer.java
index b7697c9..6274bf5 100644
--- a/storm-core/src/jvm/backtype/storm/security/auth/ThriftServer.java
+++ b/storm-core/src/jvm/backtype/storm/security/auth/ThriftServer.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 backtype.storm.security.auth;
 
 import java.util.Map;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/backtype/storm/security/auth/authorizer/DenyAuthorizer.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/security/auth/authorizer/DenyAuthorizer.java b/storm-core/src/jvm/backtype/storm/security/auth/authorizer/DenyAuthorizer.java
index 120b2dc..3af5e3c 100644
--- a/storm-core/src/jvm/backtype/storm/security/auth/authorizer/DenyAuthorizer.java
+++ b/storm-core/src/jvm/backtype/storm/security/auth/authorizer/DenyAuthorizer.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 backtype.storm.security.auth.authorizer;
 
 import java.util.Map;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/backtype/storm/security/auth/authorizer/NoopAuthorizer.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/security/auth/authorizer/NoopAuthorizer.java b/storm-core/src/jvm/backtype/storm/security/auth/authorizer/NoopAuthorizer.java
index 65f9f21..ef95683 100644
--- a/storm-core/src/jvm/backtype/storm/security/auth/authorizer/NoopAuthorizer.java
+++ b/storm-core/src/jvm/backtype/storm/security/auth/authorizer/NoopAuthorizer.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 backtype.storm.security.auth.authorizer;
 
 import java.util.Map;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/backtype/storm/security/auth/digest/ClientCallbackHandler.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/security/auth/digest/ClientCallbackHandler.java b/storm-core/src/jvm/backtype/storm/security/auth/digest/ClientCallbackHandler.java
index e424ca1..3caacaa 100644
--- a/storm-core/src/jvm/backtype/storm/security/auth/digest/ClientCallbackHandler.java
+++ b/storm-core/src/jvm/backtype/storm/security/auth/digest/ClientCallbackHandler.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 backtype.storm.security.auth.digest;
 
 import java.io.IOException;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/backtype/storm/security/auth/digest/DigestSaslTransportPlugin.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/security/auth/digest/DigestSaslTransportPlugin.java b/storm-core/src/jvm/backtype/storm/security/auth/digest/DigestSaslTransportPlugin.java
index beb0a8a..0cd1a5a 100644
--- a/storm-core/src/jvm/backtype/storm/security/auth/digest/DigestSaslTransportPlugin.java
+++ b/storm-core/src/jvm/backtype/storm/security/auth/digest/DigestSaslTransportPlugin.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 backtype.storm.security.auth.digest;
 
 import java.io.IOException;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/backtype/storm/security/auth/digest/ServerCallbackHandler.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/security/auth/digest/ServerCallbackHandler.java b/storm-core/src/jvm/backtype/storm/security/auth/digest/ServerCallbackHandler.java
index d21f8be..a0e4839 100644
--- a/storm-core/src/jvm/backtype/storm/security/auth/digest/ServerCallbackHandler.java
+++ b/storm-core/src/jvm/backtype/storm/security/auth/digest/ServerCallbackHandler.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 backtype.storm.security.auth.digest;
 
 import java.io.IOException;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/backtype/storm/security/serialization/BlowfishTupleSerializer.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/security/serialization/BlowfishTupleSerializer.java b/storm-core/src/jvm/backtype/storm/security/serialization/BlowfishTupleSerializer.java
index 973d990..ae90f33 100644
--- a/storm-core/src/jvm/backtype/storm/security/serialization/BlowfishTupleSerializer.java
+++ b/storm-core/src/jvm/backtype/storm/security/serialization/BlowfishTupleSerializer.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 backtype.storm.security.serialization;
 
 import java.util.Map;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/backtype/storm/serialization/DefaultKryoFactory.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/serialization/DefaultKryoFactory.java b/storm-core/src/jvm/backtype/storm/serialization/DefaultKryoFactory.java
index 24d2e94..a055eb2 100644
--- a/storm-core/src/jvm/backtype/storm/serialization/DefaultKryoFactory.java
+++ b/storm-core/src/jvm/backtype/storm/serialization/DefaultKryoFactory.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 backtype.storm.serialization;
 
 import backtype.storm.Config;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/backtype/storm/serialization/IKryoDecorator.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/serialization/IKryoDecorator.java b/storm-core/src/jvm/backtype/storm/serialization/IKryoDecorator.java
index 0587d6f..b154a36 100644
--- a/storm-core/src/jvm/backtype/storm/serialization/IKryoDecorator.java
+++ b/storm-core/src/jvm/backtype/storm/serialization/IKryoDecorator.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 backtype.storm.serialization;
 import com.esotericsoftware.kryo.Kryo;
 

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/backtype/storm/serialization/IKryoFactory.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/serialization/IKryoFactory.java b/storm-core/src/jvm/backtype/storm/serialization/IKryoFactory.java
index 666d0df..60a847d 100644
--- a/storm-core/src/jvm/backtype/storm/serialization/IKryoFactory.java
+++ b/storm-core/src/jvm/backtype/storm/serialization/IKryoFactory.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 backtype.storm.serialization;
 
 import com.esotericsoftware.kryo.Kryo;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/backtype/storm/serialization/ITupleDeserializer.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/serialization/ITupleDeserializer.java b/storm-core/src/jvm/backtype/storm/serialization/ITupleDeserializer.java
index 5d35490..4e68658 100644
--- a/storm-core/src/jvm/backtype/storm/serialization/ITupleDeserializer.java
+++ b/storm-core/src/jvm/backtype/storm/serialization/ITupleDeserializer.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 backtype.storm.serialization;
 
 import backtype.storm.tuple.Tuple;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/backtype/storm/serialization/ITupleSerializer.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/serialization/ITupleSerializer.java b/storm-core/src/jvm/backtype/storm/serialization/ITupleSerializer.java
index 01f4799..90ad932 100644
--- a/storm-core/src/jvm/backtype/storm/serialization/ITupleSerializer.java
+++ b/storm-core/src/jvm/backtype/storm/serialization/ITupleSerializer.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 backtype.storm.serialization;
 
 import backtype.storm.tuple.Tuple;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/backtype/storm/serialization/KryoTupleDeserializer.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/serialization/KryoTupleDeserializer.java b/storm-core/src/jvm/backtype/storm/serialization/KryoTupleDeserializer.java
index 335dc3b..5a5e3a4 100644
--- a/storm-core/src/jvm/backtype/storm/serialization/KryoTupleDeserializer.java
+++ b/storm-core/src/jvm/backtype/storm/serialization/KryoTupleDeserializer.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 backtype.storm.serialization;
 
 import backtype.storm.task.GeneralTopologyContext;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/backtype/storm/serialization/KryoTupleSerializer.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/serialization/KryoTupleSerializer.java b/storm-core/src/jvm/backtype/storm/serialization/KryoTupleSerializer.java
index 1731054..af95cb0 100644
--- a/storm-core/src/jvm/backtype/storm/serialization/KryoTupleSerializer.java
+++ b/storm-core/src/jvm/backtype/storm/serialization/KryoTupleSerializer.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 backtype.storm.serialization;
 
 import backtype.storm.task.GeneralTopologyContext;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/backtype/storm/serialization/KryoValuesDeserializer.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/serialization/KryoValuesDeserializer.java b/storm-core/src/jvm/backtype/storm/serialization/KryoValuesDeserializer.java
index cf91d4d..209ae53 100644
--- a/storm-core/src/jvm/backtype/storm/serialization/KryoValuesDeserializer.java
+++ b/storm-core/src/jvm/backtype/storm/serialization/KryoValuesDeserializer.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 backtype.storm.serialization;
 
 import backtype.storm.utils.ListDelegate;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/backtype/storm/serialization/KryoValuesSerializer.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/serialization/KryoValuesSerializer.java b/storm-core/src/jvm/backtype/storm/serialization/KryoValuesSerializer.java
index 5790677..c4a2f71 100644
--- a/storm-core/src/jvm/backtype/storm/serialization/KryoValuesSerializer.java
+++ b/storm-core/src/jvm/backtype/storm/serialization/KryoValuesSerializer.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 backtype.storm.serialization;
 
 import backtype.storm.utils.ListDelegate;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/backtype/storm/serialization/SerializableSerializer.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/serialization/SerializableSerializer.java b/storm-core/src/jvm/backtype/storm/serialization/SerializableSerializer.java
index cb3d25a..56bbe29 100644
--- a/storm-core/src/jvm/backtype/storm/serialization/SerializableSerializer.java
+++ b/storm-core/src/jvm/backtype/storm/serialization/SerializableSerializer.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 backtype.storm.serialization;
 
 import com.esotericsoftware.kryo.Kryo;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/backtype/storm/serialization/SerializationFactory.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/serialization/SerializationFactory.java b/storm-core/src/jvm/backtype/storm/serialization/SerializationFactory.java
index 36e4046..5549b1d 100644
--- a/storm-core/src/jvm/backtype/storm/serialization/SerializationFactory.java
+++ b/storm-core/src/jvm/backtype/storm/serialization/SerializationFactory.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 backtype.storm.serialization;
 
 import backtype.storm.Config;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/backtype/storm/serialization/types/ArrayListSerializer.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/serialization/types/ArrayListSerializer.java b/storm-core/src/jvm/backtype/storm/serialization/types/ArrayListSerializer.java
index 19d3223..6b7e308 100644
--- a/storm-core/src/jvm/backtype/storm/serialization/types/ArrayListSerializer.java
+++ b/storm-core/src/jvm/backtype/storm/serialization/types/ArrayListSerializer.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 backtype.storm.serialization.types;
 
 import com.esotericsoftware.kryo.Kryo;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/backtype/storm/serialization/types/HashMapSerializer.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/serialization/types/HashMapSerializer.java b/storm-core/src/jvm/backtype/storm/serialization/types/HashMapSerializer.java
index ce62a1f..662211b 100644
--- a/storm-core/src/jvm/backtype/storm/serialization/types/HashMapSerializer.java
+++ b/storm-core/src/jvm/backtype/storm/serialization/types/HashMapSerializer.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 backtype.storm.serialization.types;
 
 import com.esotericsoftware.kryo.Kryo;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/backtype/storm/serialization/types/HashSetSerializer.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/serialization/types/HashSetSerializer.java b/storm-core/src/jvm/backtype/storm/serialization/types/HashSetSerializer.java
index bc53af9..77fc353 100644
--- a/storm-core/src/jvm/backtype/storm/serialization/types/HashSetSerializer.java
+++ b/storm-core/src/jvm/backtype/storm/serialization/types/HashSetSerializer.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 backtype.storm.serialization.types;
 
 import com.esotericsoftware.kryo.Kryo;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/backtype/storm/serialization/types/ListDelegateSerializer.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/serialization/types/ListDelegateSerializer.java b/storm-core/src/jvm/backtype/storm/serialization/types/ListDelegateSerializer.java
index 6f2184f..c71a19d 100644
--- a/storm-core/src/jvm/backtype/storm/serialization/types/ListDelegateSerializer.java
+++ b/storm-core/src/jvm/backtype/storm/serialization/types/ListDelegateSerializer.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 backtype.storm.serialization.types;
 
 import com.esotericsoftware.kryo.Kryo;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/backtype/storm/spout/IMultiSchemableSpout.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/spout/IMultiSchemableSpout.java b/storm-core/src/jvm/backtype/storm/spout/IMultiSchemableSpout.java
index 95e2564..5999fbb 100644
--- a/storm-core/src/jvm/backtype/storm/spout/IMultiSchemableSpout.java
+++ b/storm-core/src/jvm/backtype/storm/spout/IMultiSchemableSpout.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 backtype.storm.spout;
 
 public interface IMultiSchemableSpout {

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/backtype/storm/spout/ISchemableSpout.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/spout/ISchemableSpout.java b/storm-core/src/jvm/backtype/storm/spout/ISchemableSpout.java
index e54c2d1..df455d9 100644
--- a/storm-core/src/jvm/backtype/storm/spout/ISchemableSpout.java
+++ b/storm-core/src/jvm/backtype/storm/spout/ISchemableSpout.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 backtype.storm.spout;
 
 

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/backtype/storm/spout/ISpout.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/spout/ISpout.java b/storm-core/src/jvm/backtype/storm/spout/ISpout.java
index d7f962f..7851984 100644
--- a/storm-core/src/jvm/backtype/storm/spout/ISpout.java
+++ b/storm-core/src/jvm/backtype/storm/spout/ISpout.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 backtype.storm.spout;
 
 import backtype.storm.task.TopologyContext;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/backtype/storm/spout/ISpoutOutputCollector.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/spout/ISpoutOutputCollector.java b/storm-core/src/jvm/backtype/storm/spout/ISpoutOutputCollector.java
index 191dc8f..3cebe43 100644
--- a/storm-core/src/jvm/backtype/storm/spout/ISpoutOutputCollector.java
+++ b/storm-core/src/jvm/backtype/storm/spout/ISpoutOutputCollector.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 backtype.storm.spout;
 
 import java.util.List;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/backtype/storm/spout/ISpoutWaitStrategy.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/spout/ISpoutWaitStrategy.java b/storm-core/src/jvm/backtype/storm/spout/ISpoutWaitStrategy.java
index de6c790..d0bdfa8 100644
--- a/storm-core/src/jvm/backtype/storm/spout/ISpoutWaitStrategy.java
+++ b/storm-core/src/jvm/backtype/storm/spout/ISpoutWaitStrategy.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 backtype.storm.spout;
 
 import java.util.Map;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/backtype/storm/spout/MultiScheme.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/spout/MultiScheme.java b/storm-core/src/jvm/backtype/storm/spout/MultiScheme.java
index 424e79b..ca2ce91 100644
--- a/storm-core/src/jvm/backtype/storm/spout/MultiScheme.java
+++ b/storm-core/src/jvm/backtype/storm/spout/MultiScheme.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 backtype.storm.spout;
 
 import java.util.List;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/backtype/storm/spout/NothingEmptyEmitStrategy.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/spout/NothingEmptyEmitStrategy.java b/storm-core/src/jvm/backtype/storm/spout/NothingEmptyEmitStrategy.java
index fc05984..36bea94 100644
--- a/storm-core/src/jvm/backtype/storm/spout/NothingEmptyEmitStrategy.java
+++ b/storm-core/src/jvm/backtype/storm/spout/NothingEmptyEmitStrategy.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 backtype.storm.spout;
 
 import java.util.Map;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/backtype/storm/spout/RawMultiScheme.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/spout/RawMultiScheme.java b/storm-core/src/jvm/backtype/storm/spout/RawMultiScheme.java
index 4056d1b..7f73975 100644
--- a/storm-core/src/jvm/backtype/storm/spout/RawMultiScheme.java
+++ b/storm-core/src/jvm/backtype/storm/spout/RawMultiScheme.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 backtype.storm.spout;
 
 import java.util.List;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/backtype/storm/spout/RawScheme.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/spout/RawScheme.java b/storm-core/src/jvm/backtype/storm/spout/RawScheme.java
index 3d8dab3..7e26770 100644
--- a/storm-core/src/jvm/backtype/storm/spout/RawScheme.java
+++ b/storm-core/src/jvm/backtype/storm/spout/RawScheme.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 backtype.storm.spout;
 
 import backtype.storm.tuple.Fields;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/backtype/storm/spout/Scheme.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/spout/Scheme.java b/storm-core/src/jvm/backtype/storm/spout/Scheme.java
index e5a1cb9..ca68954 100644
--- a/storm-core/src/jvm/backtype/storm/spout/Scheme.java
+++ b/storm-core/src/jvm/backtype/storm/spout/Scheme.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 backtype.storm.spout;
 
 import backtype.storm.tuple.Fields;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/backtype/storm/spout/SchemeAsMultiScheme.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/spout/SchemeAsMultiScheme.java b/storm-core/src/jvm/backtype/storm/spout/SchemeAsMultiScheme.java
index dab4ff8..29f7fce 100644
--- a/storm-core/src/jvm/backtype/storm/spout/SchemeAsMultiScheme.java
+++ b/storm-core/src/jvm/backtype/storm/spout/SchemeAsMultiScheme.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 backtype.storm.spout;
 
 import java.util.Arrays;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/backtype/storm/spout/ShellSpout.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/spout/ShellSpout.java b/storm-core/src/jvm/backtype/storm/spout/ShellSpout.java
index ba7bb63..67cb66f 100644
--- a/storm-core/src/jvm/backtype/storm/spout/ShellSpout.java
+++ b/storm-core/src/jvm/backtype/storm/spout/ShellSpout.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 backtype.storm.spout;
 
 import backtype.storm.generated.ShellComponent;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/backtype/storm/spout/SleepSpoutWaitStrategy.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/spout/SleepSpoutWaitStrategy.java b/storm-core/src/jvm/backtype/storm/spout/SleepSpoutWaitStrategy.java
index d964884..3ccf4e1 100644
--- a/storm-core/src/jvm/backtype/storm/spout/SleepSpoutWaitStrategy.java
+++ b/storm-core/src/jvm/backtype/storm/spout/SleepSpoutWaitStrategy.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 backtype.storm.spout;
 
 import backtype.storm.Config;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/backtype/storm/spout/SpoutOutputCollector.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/spout/SpoutOutputCollector.java b/storm-core/src/jvm/backtype/storm/spout/SpoutOutputCollector.java
index 73432cf..7a33026 100644
--- a/storm-core/src/jvm/backtype/storm/spout/SpoutOutputCollector.java
+++ b/storm-core/src/jvm/backtype/storm/spout/SpoutOutputCollector.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 backtype.storm.spout;
 
 import backtype.storm.task.OutputCollector;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/backtype/storm/state/IStateSpout.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/state/IStateSpout.java b/storm-core/src/jvm/backtype/storm/state/IStateSpout.java
index f39fb56..f4aa14f 100644
--- a/storm-core/src/jvm/backtype/storm/state/IStateSpout.java
+++ b/storm-core/src/jvm/backtype/storm/state/IStateSpout.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 backtype.storm.state;
 
 import backtype.storm.task.TopologyContext;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/backtype/storm/state/IStateSpoutOutputCollector.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/state/IStateSpoutOutputCollector.java b/storm-core/src/jvm/backtype/storm/state/IStateSpoutOutputCollector.java
index 221c197..e394010 100644
--- a/storm-core/src/jvm/backtype/storm/state/IStateSpoutOutputCollector.java
+++ b/storm-core/src/jvm/backtype/storm/state/IStateSpoutOutputCollector.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 backtype.storm.state;
 
 public interface IStateSpoutOutputCollector extends ISynchronizeOutputCollector {

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/backtype/storm/state/ISubscribedState.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/state/ISubscribedState.java b/storm-core/src/jvm/backtype/storm/state/ISubscribedState.java
index 8ba7925..6eff72c 100644
--- a/storm-core/src/jvm/backtype/storm/state/ISubscribedState.java
+++ b/storm-core/src/jvm/backtype/storm/state/ISubscribedState.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 backtype.storm.state;
 
 import backtype.storm.tuple.Tuple;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/backtype/storm/state/ISynchronizeOutputCollector.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/state/ISynchronizeOutputCollector.java b/storm-core/src/jvm/backtype/storm/state/ISynchronizeOutputCollector.java
index 31a2a7f..9c80a75 100644
--- a/storm-core/src/jvm/backtype/storm/state/ISynchronizeOutputCollector.java
+++ b/storm-core/src/jvm/backtype/storm/state/ISynchronizeOutputCollector.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 backtype.storm.state;
 
 import java.util.List;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/backtype/storm/state/StateSpoutOutputCollector.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/state/StateSpoutOutputCollector.java b/storm-core/src/jvm/backtype/storm/state/StateSpoutOutputCollector.java
index 53a74ca..4bb10e0 100644
--- a/storm-core/src/jvm/backtype/storm/state/StateSpoutOutputCollector.java
+++ b/storm-core/src/jvm/backtype/storm/state/StateSpoutOutputCollector.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 backtype.storm.state;