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

[04/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/utils/VersionedStore.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/utils/VersionedStore.java b/storm-core/src/jvm/backtype/storm/utils/VersionedStore.java
index f5ecd8e..b40aa60 100644
--- a/storm-core/src/jvm/backtype/storm/utils/VersionedStore.java
+++ b/storm-core/src/jvm/backtype/storm/utils/VersionedStore.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.utils;
 
 import java.io.IOException;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/backtype/storm/utils/WindowedTimeThrottler.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/backtype/storm/utils/WindowedTimeThrottler.java b/storm-core/src/jvm/backtype/storm/utils/WindowedTimeThrottler.java
index 9adb578..5a288a0 100644
--- a/storm-core/src/jvm/backtype/storm/utils/WindowedTimeThrottler.java
+++ b/storm-core/src/jvm/backtype/storm/utils/WindowedTimeThrottler.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.utils;
 
 public class WindowedTimeThrottler {

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

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

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/JoinType.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/JoinType.java b/storm-core/src/jvm/storm/trident/JoinType.java
index 30169d4..a90869a 100644
--- a/storm-core/src/jvm/storm/trident/JoinType.java
+++ b/storm-core/src/jvm/storm/trident/JoinType.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;
 
 import java.util.Arrays;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/Stream.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/Stream.java b/storm-core/src/jvm/storm/trident/Stream.java
index e30289b..e847eee 100644
--- a/storm-core/src/jvm/storm/trident/Stream.java
+++ b/storm-core/src/jvm/storm/trident/Stream.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;
 
 import backtype.storm.generated.Grouping;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/TridentState.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/TridentState.java b/storm-core/src/jvm/storm/trident/TridentState.java
index c6771d5..056622c 100644
--- a/storm-core/src/jvm/storm/trident/TridentState.java
+++ b/storm-core/src/jvm/storm/trident/TridentState.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;
 
 import storm.trident.planner.Node;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/TridentTopology.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/TridentTopology.java b/storm-core/src/jvm/storm/trident/TridentTopology.java
index 7b4b00d..8bf2c94 100644
--- a/storm-core/src/jvm/storm/trident/TridentTopology.java
+++ b/storm-core/src/jvm/storm/trident/TridentTopology.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;
 
 import backtype.storm.Config;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/drpc/ReturnResultsReducer.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/drpc/ReturnResultsReducer.java b/storm-core/src/jvm/storm/trident/drpc/ReturnResultsReducer.java
index a755abd..be5fa55 100644
--- a/storm-core/src/jvm/storm/trident/drpc/ReturnResultsReducer.java
+++ b/storm-core/src/jvm/storm/trident/drpc/ReturnResultsReducer.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.drpc;
 
 import backtype.storm.Config;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/fluent/ChainedAggregatorDeclarer.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/fluent/ChainedAggregatorDeclarer.java b/storm-core/src/jvm/storm/trident/fluent/ChainedAggregatorDeclarer.java
index de8fe9c..8040e8b 100644
--- a/storm-core/src/jvm/storm/trident/fluent/ChainedAggregatorDeclarer.java
+++ b/storm-core/src/jvm/storm/trident/fluent/ChainedAggregatorDeclarer.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.fluent;
 
 import backtype.storm.tuple.Fields;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/fluent/ChainedFullAggregatorDeclarer.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/fluent/ChainedFullAggregatorDeclarer.java b/storm-core/src/jvm/storm/trident/fluent/ChainedFullAggregatorDeclarer.java
index 84436a6..0631a6b 100644
--- a/storm-core/src/jvm/storm/trident/fluent/ChainedFullAggregatorDeclarer.java
+++ b/storm-core/src/jvm/storm/trident/fluent/ChainedFullAggregatorDeclarer.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.fluent;
 
 import backtype.storm.tuple.Fields;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/fluent/ChainedPartitionAggregatorDeclarer.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/fluent/ChainedPartitionAggregatorDeclarer.java b/storm-core/src/jvm/storm/trident/fluent/ChainedPartitionAggregatorDeclarer.java
index 00e2c5a..df8578d 100644
--- a/storm-core/src/jvm/storm/trident/fluent/ChainedPartitionAggregatorDeclarer.java
+++ b/storm-core/src/jvm/storm/trident/fluent/ChainedPartitionAggregatorDeclarer.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.fluent;
 
 import backtype.storm.tuple.Fields;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/fluent/GlobalAggregationScheme.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/fluent/GlobalAggregationScheme.java b/storm-core/src/jvm/storm/trident/fluent/GlobalAggregationScheme.java
index 96f15e9..6fb3660 100644
--- a/storm-core/src/jvm/storm/trident/fluent/GlobalAggregationScheme.java
+++ b/storm-core/src/jvm/storm/trident/fluent/GlobalAggregationScheme.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.fluent;
 
 import storm.trident.operation.impl.SingleEmitAggregator.BatchToPartition;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/fluent/GroupedStream.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/fluent/GroupedStream.java b/storm-core/src/jvm/storm/trident/fluent/GroupedStream.java
index ad1e121..2d223fb 100644
--- a/storm-core/src/jvm/storm/trident/fluent/GroupedStream.java
+++ b/storm-core/src/jvm/storm/trident/fluent/GroupedStream.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.fluent;
 
 import backtype.storm.tuple.Fields;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/fluent/IAggregatableStream.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/fluent/IAggregatableStream.java b/storm-core/src/jvm/storm/trident/fluent/IAggregatableStream.java
index e10852e..9308f05 100644
--- a/storm-core/src/jvm/storm/trident/fluent/IAggregatableStream.java
+++ b/storm-core/src/jvm/storm/trident/fluent/IAggregatableStream.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.fluent;
 
 import backtype.storm.tuple.Fields;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/fluent/IChainedAggregatorDeclarer.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/fluent/IChainedAggregatorDeclarer.java b/storm-core/src/jvm/storm/trident/fluent/IChainedAggregatorDeclarer.java
index a42dfbe..001ea68 100644
--- a/storm-core/src/jvm/storm/trident/fluent/IChainedAggregatorDeclarer.java
+++ b/storm-core/src/jvm/storm/trident/fluent/IChainedAggregatorDeclarer.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.fluent;
 
 import storm.trident.Stream;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/fluent/UniqueIdGen.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/fluent/UniqueIdGen.java b/storm-core/src/jvm/storm/trident/fluent/UniqueIdGen.java
index 64ad621..37bb0ad 100644
--- a/storm-core/src/jvm/storm/trident/fluent/UniqueIdGen.java
+++ b/storm-core/src/jvm/storm/trident/fluent/UniqueIdGen.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.fluent;
 
 public class UniqueIdGen {

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/graph/GraphGrouper.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/graph/GraphGrouper.java b/storm-core/src/jvm/storm/trident/graph/GraphGrouper.java
index b107269..94db077 100644
--- a/storm-core/src/jvm/storm/trident/graph/GraphGrouper.java
+++ b/storm-core/src/jvm/storm/trident/graph/GraphGrouper.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.graph;
 
 import java.util.Collection;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/graph/Group.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/graph/Group.java b/storm-core/src/jvm/storm/trident/graph/Group.java
index 8c3b685..8ed0023 100644
--- a/storm-core/src/jvm/storm/trident/graph/Group.java
+++ b/storm-core/src/jvm/storm/trident/graph/Group.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.graph;
 
 import java.util.Arrays;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/operation/Aggregator.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/operation/Aggregator.java b/storm-core/src/jvm/storm/trident/operation/Aggregator.java
index 5181703..7b49f02 100644
--- a/storm-core/src/jvm/storm/trident/operation/Aggregator.java
+++ b/storm-core/src/jvm/storm/trident/operation/Aggregator.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.operation;
 
 import storm.trident.tuple.TridentTuple;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/operation/Assembly.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/operation/Assembly.java b/storm-core/src/jvm/storm/trident/operation/Assembly.java
index 17aaca2..55fed8f 100644
--- a/storm-core/src/jvm/storm/trident/operation/Assembly.java
+++ b/storm-core/src/jvm/storm/trident/operation/Assembly.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.operation;
 
 import storm.trident.Stream;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/operation/BaseAggregator.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/operation/BaseAggregator.java b/storm-core/src/jvm/storm/trident/operation/BaseAggregator.java
index c97b84f..6d58278 100644
--- a/storm-core/src/jvm/storm/trident/operation/BaseAggregator.java
+++ b/storm-core/src/jvm/storm/trident/operation/BaseAggregator.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.operation;
 
 

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/operation/BaseFilter.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/operation/BaseFilter.java b/storm-core/src/jvm/storm/trident/operation/BaseFilter.java
index d629d0d..260cf61 100644
--- a/storm-core/src/jvm/storm/trident/operation/BaseFilter.java
+++ b/storm-core/src/jvm/storm/trident/operation/BaseFilter.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.operation;
 
 

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/operation/BaseFunction.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/operation/BaseFunction.java b/storm-core/src/jvm/storm/trident/operation/BaseFunction.java
index 8ff6b05..0d45450 100644
--- a/storm-core/src/jvm/storm/trident/operation/BaseFunction.java
+++ b/storm-core/src/jvm/storm/trident/operation/BaseFunction.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.operation;
 
 

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/operation/BaseMultiReducer.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/operation/BaseMultiReducer.java b/storm-core/src/jvm/storm/trident/operation/BaseMultiReducer.java
index 328205d..608c64b 100644
--- a/storm-core/src/jvm/storm/trident/operation/BaseMultiReducer.java
+++ b/storm-core/src/jvm/storm/trident/operation/BaseMultiReducer.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.operation;
 
 import java.util.Map;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/operation/BaseOperation.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/operation/BaseOperation.java b/storm-core/src/jvm/storm/trident/operation/BaseOperation.java
index df6166d..766d51d 100644
--- a/storm-core/src/jvm/storm/trident/operation/BaseOperation.java
+++ b/storm-core/src/jvm/storm/trident/operation/BaseOperation.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.operation;
 
 import java.util.Map;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/operation/CombinerAggregator.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/operation/CombinerAggregator.java b/storm-core/src/jvm/storm/trident/operation/CombinerAggregator.java
index 03933c9..1af43c5 100644
--- a/storm-core/src/jvm/storm/trident/operation/CombinerAggregator.java
+++ b/storm-core/src/jvm/storm/trident/operation/CombinerAggregator.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.operation;
 
 import java.io.Serializable;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/operation/EachOperation.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/operation/EachOperation.java b/storm-core/src/jvm/storm/trident/operation/EachOperation.java
index b56fe96..4315381 100644
--- a/storm-core/src/jvm/storm/trident/operation/EachOperation.java
+++ b/storm-core/src/jvm/storm/trident/operation/EachOperation.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.operation;
 
 public interface EachOperation extends Operation {

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/operation/Filter.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/operation/Filter.java b/storm-core/src/jvm/storm/trident/operation/Filter.java
index ea7cbb6..abda334 100644
--- a/storm-core/src/jvm/storm/trident/operation/Filter.java
+++ b/storm-core/src/jvm/storm/trident/operation/Filter.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.operation;
 
 import storm.trident.tuple.TridentTuple;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/operation/Function.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/operation/Function.java b/storm-core/src/jvm/storm/trident/operation/Function.java
index b58a29d..2532e00 100644
--- a/storm-core/src/jvm/storm/trident/operation/Function.java
+++ b/storm-core/src/jvm/storm/trident/operation/Function.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.operation;
 
 import storm.trident.tuple.TridentTuple;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/operation/GroupedMultiReducer.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/operation/GroupedMultiReducer.java b/storm-core/src/jvm/storm/trident/operation/GroupedMultiReducer.java
index 9223cf7..213bfca 100644
--- a/storm-core/src/jvm/storm/trident/operation/GroupedMultiReducer.java
+++ b/storm-core/src/jvm/storm/trident/operation/GroupedMultiReducer.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.operation;
 
 import java.io.Serializable;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/operation/MultiReducer.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/operation/MultiReducer.java b/storm-core/src/jvm/storm/trident/operation/MultiReducer.java
index 520f4b9..ecbd909 100644
--- a/storm-core/src/jvm/storm/trident/operation/MultiReducer.java
+++ b/storm-core/src/jvm/storm/trident/operation/MultiReducer.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.operation;
 
 import java.io.Serializable;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/operation/Operation.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/operation/Operation.java b/storm-core/src/jvm/storm/trident/operation/Operation.java
index f67281e..f945a4c 100644
--- a/storm-core/src/jvm/storm/trident/operation/Operation.java
+++ b/storm-core/src/jvm/storm/trident/operation/Operation.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.operation;
 
 import java.io.Serializable;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/operation/ReducerAggregator.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/operation/ReducerAggregator.java b/storm-core/src/jvm/storm/trident/operation/ReducerAggregator.java
index 3b4efca..5cd34b4 100644
--- a/storm-core/src/jvm/storm/trident/operation/ReducerAggregator.java
+++ b/storm-core/src/jvm/storm/trident/operation/ReducerAggregator.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.operation;
 
 import java.io.Serializable;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/operation/TridentCollector.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/operation/TridentCollector.java b/storm-core/src/jvm/storm/trident/operation/TridentCollector.java
index b1a74d1..120dca6 100644
--- a/storm-core/src/jvm/storm/trident/operation/TridentCollector.java
+++ b/storm-core/src/jvm/storm/trident/operation/TridentCollector.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.operation;
 
 import java.util.List;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/operation/TridentMultiReducerContext.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/operation/TridentMultiReducerContext.java b/storm-core/src/jvm/storm/trident/operation/TridentMultiReducerContext.java
index fe0ff04..14876d8 100644
--- a/storm-core/src/jvm/storm/trident/operation/TridentMultiReducerContext.java
+++ b/storm-core/src/jvm/storm/trident/operation/TridentMultiReducerContext.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.operation;
 
 import backtype.storm.tuple.Fields;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/operation/TridentOperationContext.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/operation/TridentOperationContext.java b/storm-core/src/jvm/storm/trident/operation/TridentOperationContext.java
index 3693125..36726b2 100644
--- a/storm-core/src/jvm/storm/trident/operation/TridentOperationContext.java
+++ b/storm-core/src/jvm/storm/trident/operation/TridentOperationContext.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.operation;
 
 import backtype.storm.metric.api.CombinedMetric;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/operation/builtin/Count.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/operation/builtin/Count.java b/storm-core/src/jvm/storm/trident/operation/builtin/Count.java
index e40177e..a7449fd 100644
--- a/storm-core/src/jvm/storm/trident/operation/builtin/Count.java
+++ b/storm-core/src/jvm/storm/trident/operation/builtin/Count.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.operation.builtin;
 
 import storm.trident.operation.CombinerAggregator;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/operation/builtin/Debug.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/operation/builtin/Debug.java b/storm-core/src/jvm/storm/trident/operation/builtin/Debug.java
index 34e905c..3bdeb3f 100644
--- a/storm-core/src/jvm/storm/trident/operation/builtin/Debug.java
+++ b/storm-core/src/jvm/storm/trident/operation/builtin/Debug.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.operation.builtin;
 
 import storm.trident.operation.BaseFilter;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/operation/builtin/Equals.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/operation/builtin/Equals.java b/storm-core/src/jvm/storm/trident/operation/builtin/Equals.java
index 512cf3f..6091227 100644
--- a/storm-core/src/jvm/storm/trident/operation/builtin/Equals.java
+++ b/storm-core/src/jvm/storm/trident/operation/builtin/Equals.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.operation.builtin;
 
 import storm.trident.operation.BaseFilter;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/operation/builtin/FilterNull.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/operation/builtin/FilterNull.java b/storm-core/src/jvm/storm/trident/operation/builtin/FilterNull.java
index bed2f1e..33da3f2 100644
--- a/storm-core/src/jvm/storm/trident/operation/builtin/FilterNull.java
+++ b/storm-core/src/jvm/storm/trident/operation/builtin/FilterNull.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.operation.builtin;
 
 import storm.trident.operation.BaseFilter;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/operation/builtin/FirstN.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/operation/builtin/FirstN.java b/storm-core/src/jvm/storm/trident/operation/builtin/FirstN.java
index 412badd..75b19bf 100644
--- a/storm-core/src/jvm/storm/trident/operation/builtin/FirstN.java
+++ b/storm-core/src/jvm/storm/trident/operation/builtin/FirstN.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.operation.builtin;
 
 import backtype.storm.tuple.Fields;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/operation/builtin/MapGet.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/operation/builtin/MapGet.java b/storm-core/src/jvm/storm/trident/operation/builtin/MapGet.java
index 17e12ee..5fd0bad 100644
--- a/storm-core/src/jvm/storm/trident/operation/builtin/MapGet.java
+++ b/storm-core/src/jvm/storm/trident/operation/builtin/MapGet.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.operation.builtin;
 
 import backtype.storm.tuple.Values;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/operation/builtin/Negate.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/operation/builtin/Negate.java b/storm-core/src/jvm/storm/trident/operation/builtin/Negate.java
index 7a48477..bd78279 100644
--- a/storm-core/src/jvm/storm/trident/operation/builtin/Negate.java
+++ b/storm-core/src/jvm/storm/trident/operation/builtin/Negate.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.operation.builtin;
 
 import java.util.Map;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/operation/builtin/SnapshotGet.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/operation/builtin/SnapshotGet.java b/storm-core/src/jvm/storm/trident/operation/builtin/SnapshotGet.java
index fbc3286..6d24ae6 100644
--- a/storm-core/src/jvm/storm/trident/operation/builtin/SnapshotGet.java
+++ b/storm-core/src/jvm/storm/trident/operation/builtin/SnapshotGet.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.operation.builtin;
 
 import backtype.storm.tuple.Values;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/operation/builtin/Sum.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/operation/builtin/Sum.java b/storm-core/src/jvm/storm/trident/operation/builtin/Sum.java
index d67ac66..9b26f00 100644
--- a/storm-core/src/jvm/storm/trident/operation/builtin/Sum.java
+++ b/storm-core/src/jvm/storm/trident/operation/builtin/Sum.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.operation.builtin;
 
 import clojure.lang.Numbers;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/operation/builtin/TupleCollectionGet.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/operation/builtin/TupleCollectionGet.java b/storm-core/src/jvm/storm/trident/operation/builtin/TupleCollectionGet.java
index 6302e02..52dd633 100644
--- a/storm-core/src/jvm/storm/trident/operation/builtin/TupleCollectionGet.java
+++ b/storm-core/src/jvm/storm/trident/operation/builtin/TupleCollectionGet.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.operation.builtin;
 
 import storm.trident.state.ITupleCollection;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/operation/impl/CaptureCollector.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/operation/impl/CaptureCollector.java b/storm-core/src/jvm/storm/trident/operation/impl/CaptureCollector.java
index 9fe4419..72d7e5d 100644
--- a/storm-core/src/jvm/storm/trident/operation/impl/CaptureCollector.java
+++ b/storm-core/src/jvm/storm/trident/operation/impl/CaptureCollector.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.operation.impl;
 
 import java.util.ArrayList;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/operation/impl/ChainedAggregatorImpl.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/operation/impl/ChainedAggregatorImpl.java b/storm-core/src/jvm/storm/trident/operation/impl/ChainedAggregatorImpl.java
index f8bd001..de58d64 100644
--- a/storm-core/src/jvm/storm/trident/operation/impl/ChainedAggregatorImpl.java
+++ b/storm-core/src/jvm/storm/trident/operation/impl/ChainedAggregatorImpl.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.operation.impl;
 
 import backtype.storm.tuple.Fields;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/operation/impl/ChainedResult.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/operation/impl/ChainedResult.java b/storm-core/src/jvm/storm/trident/operation/impl/ChainedResult.java
index a35df3a..29069b6 100644
--- a/storm-core/src/jvm/storm/trident/operation/impl/ChainedResult.java
+++ b/storm-core/src/jvm/storm/trident/operation/impl/ChainedResult.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.operation.impl;
 
 import org.apache.commons.lang.builder.ToStringBuilder;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/operation/impl/CombinerAggStateUpdater.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/operation/impl/CombinerAggStateUpdater.java b/storm-core/src/jvm/storm/trident/operation/impl/CombinerAggStateUpdater.java
index 97a9b9d..bfe9dc3 100644
--- a/storm-core/src/jvm/storm/trident/operation/impl/CombinerAggStateUpdater.java
+++ b/storm-core/src/jvm/storm/trident/operation/impl/CombinerAggStateUpdater.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.operation.impl;
 
 import backtype.storm.tuple.Values;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/operation/impl/CombinerAggregatorCombineImpl.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/operation/impl/CombinerAggregatorCombineImpl.java b/storm-core/src/jvm/storm/trident/operation/impl/CombinerAggregatorCombineImpl.java
index d9d00e5..76722c4 100644
--- a/storm-core/src/jvm/storm/trident/operation/impl/CombinerAggregatorCombineImpl.java
+++ b/storm-core/src/jvm/storm/trident/operation/impl/CombinerAggregatorCombineImpl.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.operation.impl;
 
 import backtype.storm.tuple.Values;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/operation/impl/CombinerAggregatorInitImpl.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/operation/impl/CombinerAggregatorInitImpl.java b/storm-core/src/jvm/storm/trident/operation/impl/CombinerAggregatorInitImpl.java
index 9020094..71f1178 100644
--- a/storm-core/src/jvm/storm/trident/operation/impl/CombinerAggregatorInitImpl.java
+++ b/storm-core/src/jvm/storm/trident/operation/impl/CombinerAggregatorInitImpl.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.operation.impl;
 
 import backtype.storm.tuple.Values;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/operation/impl/FilterExecutor.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/operation/impl/FilterExecutor.java b/storm-core/src/jvm/storm/trident/operation/impl/FilterExecutor.java
index 2b96834..5ed2883 100644
--- a/storm-core/src/jvm/storm/trident/operation/impl/FilterExecutor.java
+++ b/storm-core/src/jvm/storm/trident/operation/impl/FilterExecutor.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.operation.impl;
 
 import java.util.Map;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/operation/impl/GlobalBatchToPartition.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/operation/impl/GlobalBatchToPartition.java b/storm-core/src/jvm/storm/trident/operation/impl/GlobalBatchToPartition.java
index 3bf52b3..aa27b6d 100644
--- a/storm-core/src/jvm/storm/trident/operation/impl/GlobalBatchToPartition.java
+++ b/storm-core/src/jvm/storm/trident/operation/impl/GlobalBatchToPartition.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.operation.impl;
 
 

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/operation/impl/GroupCollector.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/operation/impl/GroupCollector.java b/storm-core/src/jvm/storm/trident/operation/impl/GroupCollector.java
index b997217..d549c59 100644
--- a/storm-core/src/jvm/storm/trident/operation/impl/GroupCollector.java
+++ b/storm-core/src/jvm/storm/trident/operation/impl/GroupCollector.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.operation.impl;
 
 import java.util.List;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/operation/impl/GroupedAggregator.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/operation/impl/GroupedAggregator.java b/storm-core/src/jvm/storm/trident/operation/impl/GroupedAggregator.java
index d78de70..caa5dc3 100644
--- a/storm-core/src/jvm/storm/trident/operation/impl/GroupedAggregator.java
+++ b/storm-core/src/jvm/storm/trident/operation/impl/GroupedAggregator.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.operation.impl;
 
 import backtype.storm.tuple.Fields;

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

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/operation/impl/IdentityMultiReducer.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/operation/impl/IdentityMultiReducer.java b/storm-core/src/jvm/storm/trident/operation/impl/IdentityMultiReducer.java
index f482ec4..b7ecc74 100644
--- a/storm-core/src/jvm/storm/trident/operation/impl/IdentityMultiReducer.java
+++ b/storm-core/src/jvm/storm/trident/operation/impl/IdentityMultiReducer.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.operation.impl;
 
 import java.util.Map;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/operation/impl/IndexHashBatchToPartition.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/operation/impl/IndexHashBatchToPartition.java b/storm-core/src/jvm/storm/trident/operation/impl/IndexHashBatchToPartition.java
index 779c4b8..ce054ba 100644
--- a/storm-core/src/jvm/storm/trident/operation/impl/IndexHashBatchToPartition.java
+++ b/storm-core/src/jvm/storm/trident/operation/impl/IndexHashBatchToPartition.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.operation.impl;
 
 import storm.trident.partition.IndexHashGrouping;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/operation/impl/JoinerMultiReducer.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/operation/impl/JoinerMultiReducer.java b/storm-core/src/jvm/storm/trident/operation/impl/JoinerMultiReducer.java
index 963751e..1561b1e 100644
--- a/storm-core/src/jvm/storm/trident/operation/impl/JoinerMultiReducer.java
+++ b/storm-core/src/jvm/storm/trident/operation/impl/JoinerMultiReducer.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.operation.impl;
 
 import backtype.storm.tuple.Fields;

http://git-wip-us.apache.org/repos/asf/incubator-storm/blob/731a8e51/storm-core/src/jvm/storm/trident/operation/impl/ReducerAggStateUpdater.java
----------------------------------------------------------------------
diff --git a/storm-core/src/jvm/storm/trident/operation/impl/ReducerAggStateUpdater.java b/storm-core/src/jvm/storm/trident/operation/impl/ReducerAggStateUpdater.java
index 647d30f..fd87b07 100644
--- a/storm-core/src/jvm/storm/trident/operation/impl/ReducerAggStateUpdater.java
+++ b/storm-core/src/jvm/storm/trident/operation/impl/ReducerAggStateUpdater.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.operation.impl;
 
 import backtype.storm.tuple.Values;