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 2016/09/28 20:38:10 UTC

[06/11] storm git commit: SQE: Apply Apache license headers

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/IsIn.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/IsIn.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/IsIn.java
index 4d15504..9e27aa9 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/IsIn.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/IsIn.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 com.jwplayer.sqe.trident.function;
 
 import org.apache.storm.tuple.Values;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/MapField.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/MapField.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/MapField.java
index a2fe0b1..6d7ac09 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/MapField.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/MapField.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 com.jwplayer.sqe.trident.function;
 
 import org.apache.storm.trident.operation.BaseFunction;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/ParseDate.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/ParseDate.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/ParseDate.java
index e964c6f..2fb8ef7 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/ParseDate.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/ParseDate.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 com.jwplayer.sqe.trident.function;
 
 import org.apache.storm.tuple.Values;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/ProcessArithmeticOperator.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/ProcessArithmeticOperator.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/ProcessArithmeticOperator.java
index c86234e..507db31 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/ProcessArithmeticOperator.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/ProcessArithmeticOperator.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 com.jwplayer.sqe.trident.function;
 
 import clojure.lang.Numbers;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/ProcessLogicalOperator.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/ProcessLogicalOperator.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/ProcessLogicalOperator.java
index 395eb65..3f035bf 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/ProcessLogicalOperator.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/ProcessLogicalOperator.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 com.jwplayer.sqe.trident.function;
 
 import com.jwplayer.sqe.language.expression.transform.predicate.LogicalOperatorType;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/RoundDate.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/RoundDate.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/RoundDate.java
index 780efb3..18e0c9b 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/RoundDate.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/RoundDate.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 com.jwplayer.sqe.trident.function;
 
 import org.apache.storm.trident.operation.BaseFunction;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/spout/kafka/FilteredOpaqueTridentKafkaSpout.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/spout/kafka/FilteredOpaqueTridentKafkaSpout.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/spout/kafka/FilteredOpaqueTridentKafkaSpout.java
index 9f01628..c4f5cac 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/spout/kafka/FilteredOpaqueTridentKafkaSpout.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/spout/kafka/FilteredOpaqueTridentKafkaSpout.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 com.jwplayer.sqe.trident.spout.kafka;
 
 import org.apache.storm.kafka.Partition;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/spout/kafka/FilteredTransactionalTridentKafkaSpout.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/spout/kafka/FilteredTransactionalTridentKafkaSpout.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/spout/kafka/FilteredTransactionalTridentKafkaSpout.java
index 71e9cca..a908a5d 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/spout/kafka/FilteredTransactionalTridentKafkaSpout.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/spout/kafka/FilteredTransactionalTridentKafkaSpout.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 com.jwplayer.sqe.trident.spout.kafka;
 
 import org.apache.storm.kafka.Partition;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/spout/kafka/FilteredTridentCollector.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/spout/kafka/FilteredTridentCollector.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/spout/kafka/FilteredTridentCollector.java
index 6ad7174..3667052 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/spout/kafka/FilteredTridentCollector.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/spout/kafka/FilteredTridentCollector.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 com.jwplayer.sqe.trident.spout.kafka;
 
 import com.jwplayer.sqe.trident.StreamMetadata;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/spout/kafka/FilteredTridentKafkaEmitter.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/spout/kafka/FilteredTridentKafkaEmitter.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/spout/kafka/FilteredTridentKafkaEmitter.java
index d6c5a7a..ca50321 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/spout/kafka/FilteredTridentKafkaEmitter.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/spout/kafka/FilteredTridentKafkaEmitter.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 com.jwplayer.sqe.trident.spout.kafka;
 
 import org.apache.storm.kafka.Partition;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/spout/kafka/SqeRawFullScheme.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/spout/kafka/SqeRawFullScheme.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/spout/kafka/SqeRawFullScheme.java
index 538176c..0614773 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/spout/kafka/SqeRawFullScheme.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/spout/kafka/SqeRawFullScheme.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 com.jwplayer.sqe.trident.spout.kafka;
 
 import com.jwplayer.sqe.language.stream.StreamAdapter;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/state/BaseGsonSerializer.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/state/BaseGsonSerializer.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/state/BaseGsonSerializer.java
index 0a999f1..959f168 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/state/BaseGsonSerializer.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/state/BaseGsonSerializer.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 com.jwplayer.sqe.trident.state;
 
 

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/state/GsonOpaqueSerializer.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/state/GsonOpaqueSerializer.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/state/GsonOpaqueSerializer.java
index ae8863f..00b8f3e 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/state/GsonOpaqueSerializer.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/state/GsonOpaqueSerializer.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 com.jwplayer.sqe.trident.state;
 
 import com.google.gson.Gson;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/state/GsonTransactionalSerializer.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/state/GsonTransactionalSerializer.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/state/GsonTransactionalSerializer.java
index c522529..4fbbcdc 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/state/GsonTransactionalSerializer.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/state/GsonTransactionalSerializer.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 com.jwplayer.sqe.trident.state;
 
 import com.google.gson.*;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/state/mongodb/MongoDBState.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/state/mongodb/MongoDBState.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/state/mongodb/MongoDBState.java
index 3bd4e3c..76992a9 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/state/mongodb/MongoDBState.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/state/mongodb/MongoDBState.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 com.jwplayer.sqe.trident.state.mongodb;
 
 import com.clearspring.analytics.hash.MurmurHash;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/state/mongodb/MongoDBStateOptions.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/state/mongodb/MongoDBStateOptions.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/state/mongodb/MongoDBStateOptions.java
index ba6643d..5accde7 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/state/mongodb/MongoDBStateOptions.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/state/mongodb/MongoDBStateOptions.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 com.jwplayer.sqe.trident.state.mongodb;
 
 

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/state/redis/RedisKeyFactory.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/state/redis/RedisKeyFactory.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/state/redis/RedisKeyFactory.java
index 42881a9..88d95d7 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/state/redis/RedisKeyFactory.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/state/redis/RedisKeyFactory.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 com.jwplayer.sqe.trident.state.redis;
 
 import org.apache.storm.redis.trident.state.KeyFactory;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/util/FileHelper.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/util/FileHelper.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/util/FileHelper.java
index 6e8d7ec..359f478 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/util/FileHelper.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/util/FileHelper.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 com.jwplayer.sqe.util;
 
 import org.apache.commons.io.IOUtils;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/util/YamlConfig.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/util/YamlConfig.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/util/YamlConfig.java
index deaef02..1102373 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/util/YamlConfig.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/util/YamlConfig.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 com.jwplayer.sqe.util;
 
 import org.apache.log4j.Logger;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/util/file/resource/ResourceFileSystem.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/util/file/resource/ResourceFileSystem.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/util/file/resource/ResourceFileSystem.java
index 572ccd1..ca9239d 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/util/file/resource/ResourceFileSystem.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/util/file/resource/ResourceFileSystem.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 com.jwplayer.sqe.util.file.resource;
 
 import com.google.common.collect.ImmutableList;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/util/file/resource/ResourceFileSystemProvider.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/util/file/resource/ResourceFileSystemProvider.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/util/file/resource/ResourceFileSystemProvider.java
index b84f035..2a65606 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/util/file/resource/ResourceFileSystemProvider.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/util/file/resource/ResourceFileSystemProvider.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 com.jwplayer.sqe.util.file.resource;
 
 import java.io.IOException;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/util/file/resource/ResourcePath.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/util/file/resource/ResourcePath.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/util/file/resource/ResourcePath.java
index 0d5960a..16392a1 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/util/file/resource/ResourcePath.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/util/file/resource/ResourcePath.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 com.jwplayer.sqe.util.file.resource;
 
 

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/test/java/com/jwplayer/sqe/IntegrationTest.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/test/java/com/jwplayer/sqe/IntegrationTest.java b/external/storm-sqe/src/test/java/com/jwplayer/sqe/IntegrationTest.java
index 768a89f..d670088 100644
--- a/external/storm-sqe/src/test/java/com/jwplayer/sqe/IntegrationTest.java
+++ b/external/storm-sqe/src/test/java/com/jwplayer/sqe/IntegrationTest.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 com.jwplayer.sqe;
 
 import static org.junit.Assert.*;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/test/java/com/jwplayer/sqe/KafkaReplaysIntegrationTest.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/test/java/com/jwplayer/sqe/KafkaReplaysIntegrationTest.java b/external/storm-sqe/src/test/java/com/jwplayer/sqe/KafkaReplaysIntegrationTest.java
index 9942ace..ca57cd0 100644
--- a/external/storm-sqe/src/test/java/com/jwplayer/sqe/KafkaReplaysIntegrationTest.java
+++ b/external/storm-sqe/src/test/java/com/jwplayer/sqe/KafkaReplaysIntegrationTest.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 com.jwplayer.sqe;
 
 import com.jwplayer.sqe.trident.StreamMetadata;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/test/java/com/jwplayer/sqe/language/command/CommandDeserializationTest.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/test/java/com/jwplayer/sqe/language/command/CommandDeserializationTest.java b/external/storm-sqe/src/test/java/com/jwplayer/sqe/language/command/CommandDeserializationTest.java
index 8b5ee25..ddfbd79 100644
--- a/external/storm-sqe/src/test/java/com/jwplayer/sqe/language/command/CommandDeserializationTest.java
+++ b/external/storm-sqe/src/test/java/com/jwplayer/sqe/language/command/CommandDeserializationTest.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 com.jwplayer.sqe.language.command;
 
 import static org.junit.Assert.*;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/test/java/com/jwplayer/sqe/language/expression/ExpressionDeserializationTest.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/test/java/com/jwplayer/sqe/language/expression/ExpressionDeserializationTest.java b/external/storm-sqe/src/test/java/com/jwplayer/sqe/language/expression/ExpressionDeserializationTest.java
index b483443..7f67b2e 100644
--- a/external/storm-sqe/src/test/java/com/jwplayer/sqe/language/expression/ExpressionDeserializationTest.java
+++ b/external/storm-sqe/src/test/java/com/jwplayer/sqe/language/expression/ExpressionDeserializationTest.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 com.jwplayer.sqe.language.expression;
 
 import com.google.gson.GsonBuilder;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/test/java/com/jwplayer/sqe/language/expression/FunctionExpressionTest.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/test/java/com/jwplayer/sqe/language/expression/FunctionExpressionTest.java b/external/storm-sqe/src/test/java/com/jwplayer/sqe/language/expression/FunctionExpressionTest.java
index 52ee8ef..9c2cbe9 100644
--- a/external/storm-sqe/src/test/java/com/jwplayer/sqe/language/expression/FunctionExpressionTest.java
+++ b/external/storm-sqe/src/test/java/com/jwplayer/sqe/language/expression/FunctionExpressionTest.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 com.jwplayer.sqe.language.expression;
 
 import java.util.ArrayList;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/GetTuplesFilter.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/GetTuplesFilter.java b/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/GetTuplesFilter.java
index 46361ae..906d6bd 100644
--- a/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/GetTuplesFilter.java
+++ b/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/GetTuplesFilter.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 com.jwplayer.sqe.trident;
 
 import org.apache.storm.trident.operation.BaseFilter;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/aggregator/GetMaximumAggregatorTest.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/aggregator/GetMaximumAggregatorTest.java b/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/aggregator/GetMaximumAggregatorTest.java
index 5dc7eb6..8f88adb 100644
--- a/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/aggregator/GetMaximumAggregatorTest.java
+++ b/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/aggregator/GetMaximumAggregatorTest.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 com.jwplayer.sqe.trident.aggregator;
 
 import static org.junit.Assert.*;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/aggregator/HllAggregatorTest.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/aggregator/HllAggregatorTest.java b/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/aggregator/HllAggregatorTest.java
index 7d8e826..fc74b98 100644
--- a/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/aggregator/HllAggregatorTest.java
+++ b/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/aggregator/HllAggregatorTest.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 com.jwplayer.sqe.trident.aggregator;
 
 import static org.junit.Assert.*;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/aggregator/HllCombinerAggregatorTest.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/aggregator/HllCombinerAggregatorTest.java b/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/aggregator/HllCombinerAggregatorTest.java
index c616a7a..2ba5663 100644
--- a/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/aggregator/HllCombinerAggregatorTest.java
+++ b/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/aggregator/HllCombinerAggregatorTest.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 com.jwplayer.sqe.trident.aggregator;
 
 import static org.junit.Assert.*;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/aggregator/HllpAggregatorTest.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/aggregator/HllpAggregatorTest.java b/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/aggregator/HllpAggregatorTest.java
index 03705b2..378fc57 100644
--- a/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/aggregator/HllpAggregatorTest.java
+++ b/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/aggregator/HllpAggregatorTest.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 com.jwplayer.sqe.trident.aggregator;
 
 import static org.junit.Assert.*;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/aggregator/HllpCombinerAggregatorTest.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/aggregator/HllpCombinerAggregatorTest.java b/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/aggregator/HllpCombinerAggregatorTest.java
index 5e59af5..daa42ee 100644
--- a/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/aggregator/HllpCombinerAggregatorTest.java
+++ b/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/aggregator/HllpCombinerAggregatorTest.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 com.jwplayer.sqe.trident.aggregator;
 
 import static org.junit.Assert.*;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/AddFieldTest.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/AddFieldTest.java b/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/AddFieldTest.java
index 0767e55..ee7dad9 100644
--- a/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/AddFieldTest.java
+++ b/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/AddFieldTest.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 com.jwplayer.sqe.trident.function;
 
 import static org.junit.Assert.*;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/CompareNumbersTest.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/CompareNumbersTest.java b/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/CompareNumbersTest.java
index 137689d..3cdd2ea 100644
--- a/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/CompareNumbersTest.java
+++ b/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/CompareNumbersTest.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 com.jwplayer.sqe.trident.function;
 
 import static org.junit.Assert.*;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/CompareObjectsTest.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/CompareObjectsTest.java b/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/CompareObjectsTest.java
index 07c84ae..89b8853 100644
--- a/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/CompareObjectsTest.java
+++ b/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/CompareObjectsTest.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 com.jwplayer.sqe.trident.function;
 
 import static org.junit.Assert.*;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/EvaluateRegularExpressionTest.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/EvaluateRegularExpressionTest.java b/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/EvaluateRegularExpressionTest.java
index e081bce..69650ad 100644
--- a/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/EvaluateRegularExpressionTest.java
+++ b/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/EvaluateRegularExpressionTest.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 com.jwplayer.sqe.trident.function;
 
 import static org.junit.Assert.*;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/ExpandKeysTest.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/ExpandKeysTest.java b/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/ExpandKeysTest.java
index 3688b78..1cd4f9e 100644
--- a/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/ExpandKeysTest.java
+++ b/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/ExpandKeysTest.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 com.jwplayer.sqe.trident.function;
 
 import com.jwplayer.sqe.trident.ListValuesCollector;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/ExpandValuesTest.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/ExpandValuesTest.java b/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/ExpandValuesTest.java
index 45e374c..5604152 100644
--- a/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/ExpandValuesTest.java
+++ b/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/ExpandValuesTest.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 com.jwplayer.sqe.trident.function;
 
 import com.jwplayer.sqe.trident.ListValuesCollector;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/FormatDateTest.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/FormatDateTest.java b/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/FormatDateTest.java
index 776a9c2..e12ea4d 100644
--- a/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/FormatDateTest.java
+++ b/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/FormatDateTest.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 com.jwplayer.sqe.trident.function;
 
 import static org.junit.Assert.*;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/GetCardinalityEstimationTest.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/GetCardinalityEstimationTest.java b/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/GetCardinalityEstimationTest.java
index 73ab2d3..7984fdb 100644
--- a/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/GetCardinalityEstimationTest.java
+++ b/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/GetCardinalityEstimationTest.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 com.jwplayer.sqe.trident.function;
 
 import com.clearspring.analytics.stream.cardinality.HyperLogLog;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/GetIfTest.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/GetIfTest.java b/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/GetIfTest.java
index 730a8b8..8a408d8 100644
--- a/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/GetIfTest.java
+++ b/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/GetIfTest.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 com.jwplayer.sqe.trident.function;
 
 import com.jwplayer.sqe.trident.SingleValuesCollector;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/GetMapValueTest.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/GetMapValueTest.java b/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/GetMapValueTest.java
index e5420e4..bef57ac 100644
--- a/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/GetMapValueTest.java
+++ b/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/GetMapValueTest.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 com.jwplayer.sqe.trident.function;
 
 import static org.junit.Assert.assertEquals;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/GetTimeTest.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/GetTimeTest.java b/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/GetTimeTest.java
index 57dc090..007a20c 100644
--- a/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/GetTimeTest.java
+++ b/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/GetTimeTest.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 com.jwplayer.sqe.trident.function;
 
 import com.jwplayer.sqe.trident.SingleValuesCollector;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/HashTest.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/HashTest.java b/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/HashTest.java
index 98ff587..3c84d80 100644
--- a/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/HashTest.java
+++ b/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/HashTest.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 com.jwplayer.sqe.trident.function;
 
 import com.google.common.primitives.Longs;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/IsInTest.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/IsInTest.java b/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/IsInTest.java
index aecb919..0df18ea 100644
--- a/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/IsInTest.java
+++ b/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/IsInTest.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 com.jwplayer.sqe.trident.function;
 
 import com.jwplayer.sqe.trident.SingleValuesCollector;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/ParseDateTest.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/ParseDateTest.java b/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/ParseDateTest.java
index 9f8b351..36991ce 100644
--- a/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/ParseDateTest.java
+++ b/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/ParseDateTest.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 com.jwplayer.sqe.trident.function;
 
 import static org.junit.Assert.*;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/ProcessArithmeticOperatorTest.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/ProcessArithmeticOperatorTest.java b/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/ProcessArithmeticOperatorTest.java
index c480dea..f432e76 100644
--- a/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/ProcessArithmeticOperatorTest.java
+++ b/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/ProcessArithmeticOperatorTest.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 com.jwplayer.sqe.trident.function;
 
 import static org.junit.Assert.*;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/ProcessLogicalOperatorTest.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/ProcessLogicalOperatorTest.java b/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/ProcessLogicalOperatorTest.java
index bfd641d..2411bac 100644
--- a/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/ProcessLogicalOperatorTest.java
+++ b/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/ProcessLogicalOperatorTest.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 com.jwplayer.sqe.trident.function;
 
 import static org.junit.Assert.*;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/RoundDateTest.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/RoundDateTest.java b/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/RoundDateTest.java
index 2914b89..e7bcd10 100644
--- a/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/RoundDateTest.java
+++ b/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/function/RoundDateTest.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 com.jwplayer.sqe.trident.function;
 
 import static org.junit.Assert.*;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/spout/kafka/FilteredTridentCollectorTest.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/spout/kafka/FilteredTridentCollectorTest.java b/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/spout/kafka/FilteredTridentCollectorTest.java
index ff9b466..2218339 100644
--- a/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/spout/kafka/FilteredTridentCollectorTest.java
+++ b/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/spout/kafka/FilteredTridentCollectorTest.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 com.jwplayer.sqe.trident.spout.kafka;
 
 import static org.junit.Assert.*;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/spout/kafka/SqeRawFullSchemeTest.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/spout/kafka/SqeRawFullSchemeTest.java b/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/spout/kafka/SqeRawFullSchemeTest.java
index 0ddb1f3..a67d02b 100644
--- a/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/spout/kafka/SqeRawFullSchemeTest.java
+++ b/external/storm-sqe/src/test/java/com/jwplayer/sqe/trident/spout/kafka/SqeRawFullSchemeTest.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 com.jwplayer.sqe.trident.spout.kafka;
 
 

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/test/java/com/jwplayer/sqe/util/FileHelperTest.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/test/java/com/jwplayer/sqe/util/FileHelperTest.java b/external/storm-sqe/src/test/java/com/jwplayer/sqe/util/FileHelperTest.java
index bca7ec8..bb88214 100644
--- a/external/storm-sqe/src/test/java/com/jwplayer/sqe/util/FileHelperTest.java
+++ b/external/storm-sqe/src/test/java/com/jwplayer/sqe/util/FileHelperTest.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 com.jwplayer.sqe.util;
 
 import org.junit.Test;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/test/java/com/jwplayer/sqe/util/KafkaTestServer.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/test/java/com/jwplayer/sqe/util/KafkaTestServer.java b/external/storm-sqe/src/test/java/com/jwplayer/sqe/util/KafkaTestServer.java
index e7bd2ac..e065cc9 100644
--- a/external/storm-sqe/src/test/java/com/jwplayer/sqe/util/KafkaTestServer.java
+++ b/external/storm-sqe/src/test/java/com/jwplayer/sqe/util/KafkaTestServer.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 com.jwplayer.sqe.util;
 
 import kafka.admin.AdminUtils;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/test/java/com/jwplayer/sqe/util/YamlConfigTest.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/test/java/com/jwplayer/sqe/util/YamlConfigTest.java b/external/storm-sqe/src/test/java/com/jwplayer/sqe/util/YamlConfigTest.java
index 2da8086..6dec769 100644
--- a/external/storm-sqe/src/test/java/com/jwplayer/sqe/util/YamlConfigTest.java
+++ b/external/storm-sqe/src/test/java/com/jwplayer/sqe/util/YamlConfigTest.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 com.jwplayer.sqe.util;
 
 import org.junit.Before;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/test/java/com/jwplayer/sqe/util/ZookeeperTestServer.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/test/java/com/jwplayer/sqe/util/ZookeeperTestServer.java b/external/storm-sqe/src/test/java/com/jwplayer/sqe/util/ZookeeperTestServer.java
index b532686..8d6e30e 100644
--- a/external/storm-sqe/src/test/java/com/jwplayer/sqe/util/ZookeeperTestServer.java
+++ b/external/storm-sqe/src/test/java/com/jwplayer/sqe/util/ZookeeperTestServer.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 com.jwplayer.sqe.util;
 
 import kafka.utils.ZkUtils;