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

[07/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/language/expression/transform/predicate/LessThanEqualCompareNumbers.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/expression/transform/predicate/LessThanEqualCompareNumbers.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/expression/transform/predicate/LessThanEqualCompareNumbers.java
index a8ce47c..8107c55 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/expression/transform/predicate/LessThanEqualCompareNumbers.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/expression/transform/predicate/LessThanEqualCompareNumbers.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.transform.predicate;
 
 

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

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/expression/transform/predicate/LogicalOperatorType.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/expression/transform/predicate/LogicalOperatorType.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/expression/transform/predicate/LogicalOperatorType.java
index cf3e20c..27ee172 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/expression/transform/predicate/LogicalOperatorType.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/expression/transform/predicate/LogicalOperatorType.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.transform.predicate;
 
 public enum LogicalOperatorType {

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/expression/transform/predicate/NotEqualCompareNumbers.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/expression/transform/predicate/NotEqualCompareNumbers.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/expression/transform/predicate/NotEqualCompareNumbers.java
index f4ca8c6..35f3550 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/expression/transform/predicate/NotEqualCompareNumbers.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/expression/transform/predicate/NotEqualCompareNumbers.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.transform.predicate;
 
 

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/expression/transform/predicate/NotLogicalOperator.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/expression/transform/predicate/NotLogicalOperator.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/expression/transform/predicate/NotLogicalOperator.java
index 0925144..85ab6ba 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/expression/transform/predicate/NotLogicalOperator.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/expression/transform/predicate/NotLogicalOperator.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.transform.predicate;
 
 

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/expression/transform/predicate/NumberComparisonType.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/expression/transform/predicate/NumberComparisonType.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/expression/transform/predicate/NumberComparisonType.java
index 581cf40..6f801ed 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/expression/transform/predicate/NumberComparisonType.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/expression/transform/predicate/NumberComparisonType.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.transform.predicate;
 
 public enum NumberComparisonType {

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/expression/transform/predicate/OrLogicalOperator.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/expression/transform/predicate/OrLogicalOperator.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/expression/transform/predicate/OrLogicalOperator.java
index 80e24d3..08d68dd 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/expression/transform/predicate/OrLogicalOperator.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/expression/transform/predicate/OrLogicalOperator.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.transform.predicate;
 
 

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/expression/transform/predicate/PredicateExpression.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/expression/transform/predicate/PredicateExpression.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/expression/transform/predicate/PredicateExpression.java
index 8523406..c04dcbe 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/expression/transform/predicate/PredicateExpression.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/expression/transform/predicate/PredicateExpression.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.transform.predicate;
 
 import com.jwplayer.sqe.language.expression.transform.TransformExpression;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/expression/transform/predicate/RLike.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/expression/transform/predicate/RLike.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/expression/transform/predicate/RLike.java
index a4debed..63b808b 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/expression/transform/predicate/RLike.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/expression/transform/predicate/RLike.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.transform.predicate;
 
 import com.jwplayer.sqe.trident.function.EvaluateRegularExpression;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/expression/transform/predicate/XorLogicalOperator.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/expression/transform/predicate/XorLogicalOperator.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/expression/transform/predicate/XorLogicalOperator.java
index ae722ce..fe0220e 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/expression/transform/predicate/XorLogicalOperator.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/expression/transform/predicate/XorLogicalOperator.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.transform.predicate;
 
 

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/serde/BaseDeserializer.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/serde/BaseDeserializer.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/serde/BaseDeserializer.java
index 720ce2d..83e50b5 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/serde/BaseDeserializer.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/serde/BaseDeserializer.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.serde;
 
 import com.jwplayer.sqe.language.serde.avro.AvroDeserializer;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/serde/IdentityDeserializer.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/serde/IdentityDeserializer.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/serde/IdentityDeserializer.java
index 76fc262..1c9a179 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/serde/IdentityDeserializer.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/serde/IdentityDeserializer.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.serde;
 
 

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/serde/avro/AvroDeserializer.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/serde/avro/AvroDeserializer.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/serde/avro/AvroDeserializer.java
index f5868f4..05e2300 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/serde/avro/AvroDeserializer.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/serde/avro/AvroDeserializer.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.serde.avro;
 
 import com.jwplayer.sqe.language.serde.BaseDeserializer;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/serde/avro/AvroDeserializerOptions.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/serde/avro/AvroDeserializerOptions.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/serde/avro/AvroDeserializerOptions.java
index 3abd155..0e4aa91 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/serde/avro/AvroDeserializerOptions.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/serde/avro/AvroDeserializerOptions.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.serde.avro;
 
 import java.util.Map;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/state/StateAdapter.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/state/StateAdapter.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/state/StateAdapter.java
index 0483a5b..2026629 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/state/StateAdapter.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/state/StateAdapter.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.state;
 
 import com.jwplayer.sqe.language.state.kafka.KafkaStateAdapter;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/state/StateOperationType.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/state/StateOperationType.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/state/StateOperationType.java
index 4b56fd2..881cbe3 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/state/StateOperationType.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/state/StateOperationType.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.state;
 
 public enum StateOperationType {

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/state/kafka/JwTridentKafkaStateFactory.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/state/kafka/JwTridentKafkaStateFactory.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/state/kafka/JwTridentKafkaStateFactory.java
index 9cc927e..24fd18f 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/state/kafka/JwTridentKafkaStateFactory.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/state/kafka/JwTridentKafkaStateFactory.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.state.kafka;
 
 import java.util.HashMap;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/state/kafka/KafkaStateAdapter.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/state/kafka/KafkaStateAdapter.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/state/kafka/KafkaStateAdapter.java
index 71ac874..237f1d3 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/state/kafka/KafkaStateAdapter.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/state/kafka/KafkaStateAdapter.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.state.kafka;
 
 import java.util.ArrayList;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/state/kafka/KafkaStateOptions.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/state/kafka/KafkaStateOptions.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/state/kafka/KafkaStateOptions.java
index 9093c11..5d10b77 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/state/kafka/KafkaStateOptions.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/state/kafka/KafkaStateOptions.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.state.kafka;
 
 import com.google.common.base.Joiner;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/state/kafka/SourcePartitionPartitioner.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/state/kafka/SourcePartitionPartitioner.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/state/kafka/SourcePartitionPartitioner.java
index 38074b2..395b661 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/state/kafka/SourcePartitionPartitioner.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/state/kafka/SourcePartitionPartitioner.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.state.kafka;
 
 

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/state/mongodb/MongoDBStateAdapter.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/state/mongodb/MongoDBStateAdapter.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/state/mongodb/MongoDBStateAdapter.java
index 6ef1c88..ce7daa7 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/state/mongodb/MongoDBStateAdapter.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/state/mongodb/MongoDBStateAdapter.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.state.mongodb;
 
 import com.jwplayer.sqe.language.state.StateAdapter;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/state/redis/RedisStateAdapter.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/state/redis/RedisStateAdapter.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/state/redis/RedisStateAdapter.java
index 986878b..45940cb 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/state/redis/RedisStateAdapter.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/state/redis/RedisStateAdapter.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.state.redis;
 
 import com.jwplayer.sqe.trident.state.GsonOpaqueSerializer;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/state/redis/RedisStateFactory.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/state/redis/RedisStateFactory.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/state/redis/RedisStateFactory.java
index 9faa980..b1bcd3b 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/state/redis/RedisStateFactory.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/state/redis/RedisStateFactory.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.state.redis;
 
 import java.util.List;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/state/redis/RedisStateOptions.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/state/redis/RedisStateOptions.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/state/redis/RedisStateOptions.java
index 3699480..793eacf 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/state/redis/RedisStateOptions.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/state/redis/RedisStateOptions.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.state.redis;
 
 import org.apache.storm.redis.trident.state.RedisDataTypeDescription.RedisDataType;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/stream/InputStreamType.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/stream/InputStreamType.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/stream/InputStreamType.java
index 7bebbd6..cd452d0 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/stream/InputStreamType.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/stream/InputStreamType.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.stream;
 
 public enum InputStreamType {

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/stream/StreamAdapter.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/stream/StreamAdapter.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/stream/StreamAdapter.java
index f43c35a..623b5bd 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/stream/StreamAdapter.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/stream/StreamAdapter.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.stream;
 
 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/language/stream/StreamContainer.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/stream/StreamContainer.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/stream/StreamContainer.java
index 8f15ac1..c3a0435 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/stream/StreamContainer.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/stream/StreamContainer.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.stream;
 
 import org.apache.storm.trident.Stream;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/stream/kafka/KafkaStreamAdapter.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/stream/kafka/KafkaStreamAdapter.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/stream/kafka/KafkaStreamAdapter.java
index e3e5c91..4e4ea0b 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/stream/kafka/KafkaStreamAdapter.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/stream/kafka/KafkaStreamAdapter.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.stream.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/language/stream/kafka/KafkaStreamAdapterOptions.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/stream/kafka/KafkaStreamAdapterOptions.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/stream/kafka/KafkaStreamAdapterOptions.java
index 2c70053..53b9471 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/stream/kafka/KafkaStreamAdapterOptions.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/stream/kafka/KafkaStreamAdapterOptions.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.stream.kafka;
 
 import com.google.common.base.Joiner;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/stream/testing/FixedBatchSpoutOptions.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/stream/testing/FixedBatchSpoutOptions.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/stream/testing/FixedBatchSpoutOptions.java
index defb4db..8a5f0da 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/stream/testing/FixedBatchSpoutOptions.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/stream/testing/FixedBatchSpoutOptions.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.stream.testing;
 
 import org.apache.storm.tuple.Fields;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/stream/testing/FixedBatchSpoutStreamAdapter.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/stream/testing/FixedBatchSpoutStreamAdapter.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/stream/testing/FixedBatchSpoutStreamAdapter.java
index 310763e..1233c4f 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/stream/testing/FixedBatchSpoutStreamAdapter.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/language/stream/testing/FixedBatchSpoutStreamAdapter.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.stream.testing;
 
 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/ListValuesCollector.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/ListValuesCollector.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/ListValuesCollector.java
index eb638a3..3b71339 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/ListValuesCollector.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/ListValuesCollector.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.TridentCollector;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/SingleValuesCollector.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/SingleValuesCollector.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/SingleValuesCollector.java
index 99b6ad3..39d97c7 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/SingleValuesCollector.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/SingleValuesCollector.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.TridentCollector;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/StreamMetadata.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/StreamMetadata.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/StreamMetadata.java
index 913ea63..4c10169 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/StreamMetadata.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/StreamMetadata.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 com.google.common.base.Preconditions;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/ValueFilter.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/ValueFilter.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/ValueFilter.java
index fad4651..dcbb3d0 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/ValueFilter.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/ValueFilter.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/main/java/com/jwplayer/sqe/trident/aggregator/CardinalityEstimatorAggregator.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/aggregator/CardinalityEstimatorAggregator.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/aggregator/CardinalityEstimatorAggregator.java
index e106aa4..1314f7a 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/aggregator/CardinalityEstimatorAggregator.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/aggregator/CardinalityEstimatorAggregator.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 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/aggregator/CardinalityEstimatorCombinerAggregator.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/aggregator/CardinalityEstimatorCombinerAggregator.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/aggregator/CardinalityEstimatorCombinerAggregator.java
index 32da432..1647ded 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/aggregator/CardinalityEstimatorCombinerAggregator.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/aggregator/CardinalityEstimatorCombinerAggregator.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 org.apache.storm.trident.operation.CombinerAggregator;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/aggregator/GetMaximumAggregator.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/aggregator/GetMaximumAggregator.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/aggregator/GetMaximumAggregator.java
index 7505b93..1300938 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/aggregator/GetMaximumAggregator.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/aggregator/GetMaximumAggregator.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 clojure.lang.Numbers;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/aggregator/HllAggregator.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/aggregator/HllAggregator.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/aggregator/HllAggregator.java
index 0b62dfc..40e3911 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/aggregator/HllAggregator.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/aggregator/HllAggregator.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 com.clearspring.analytics.stream.cardinality.HyperLogLog;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/aggregator/HllCombinerAggregator.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/aggregator/HllCombinerAggregator.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/aggregator/HllCombinerAggregator.java
index ae0ca59..4b2b1b0 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/aggregator/HllCombinerAggregator.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/aggregator/HllCombinerAggregator.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 com.clearspring.analytics.stream.cardinality.CardinalityMergeException;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/aggregator/HllpAggregator.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/aggregator/HllpAggregator.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/aggregator/HllpAggregator.java
index 5fbea2f..9b05b0a 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/aggregator/HllpAggregator.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/aggregator/HllpAggregator.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 com.clearspring.analytics.stream.cardinality.HyperLogLogPlus;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/aggregator/HllpCombinerAggregator.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/aggregator/HllpCombinerAggregator.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/aggregator/HllpCombinerAggregator.java
index 77078c6..e4b9703 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/aggregator/HllpCombinerAggregator.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/aggregator/HllpCombinerAggregator.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 com.clearspring.analytics.stream.cardinality.CardinalityMergeException;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/AddField.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/AddField.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/AddField.java
index fb598a2..4ebbf08 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/AddField.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/AddField.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/CompareNumbers.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/CompareNumbers.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/CompareNumbers.java
index 8ddb99a..f724372 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/CompareNumbers.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/CompareNumbers.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/CompareObjects.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/CompareObjects.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/CompareObjects.java
index 5625c7c..4f49503 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/CompareObjects.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/CompareObjects.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.NumberComparisonType;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/ConvertMetadataToBytes.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/ConvertMetadataToBytes.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/ConvertMetadataToBytes.java
index e5eb525..fd33a37 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/ConvertMetadataToBytes.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/ConvertMetadataToBytes.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.StreamMetadata;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/EvaluateRegularExpression.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/EvaluateRegularExpression.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/EvaluateRegularExpression.java
index 739879e..06acf03 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/EvaluateRegularExpression.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/EvaluateRegularExpression.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/ExpandKeys.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/ExpandKeys.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/ExpandKeys.java
index 4178679..0d0ac44 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/ExpandKeys.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/ExpandKeys.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.avro.util.Utf8;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/ExpandValues.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/ExpandValues.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/ExpandValues.java
index 4a26d4c..055c698 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/ExpandValues.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/ExpandValues.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.avro.util.Utf8;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/FormatDate.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/FormatDate.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/FormatDate.java
index 6b3762b..d298be5 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/FormatDate.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/FormatDate.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/GetCardinalityEstimation.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/GetCardinalityEstimation.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/GetCardinalityEstimation.java
index 9a5a41f..058128a 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/GetCardinalityEstimation.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/GetCardinalityEstimation.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/main/java/com/jwplayer/sqe/trident/function/GetIf.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/GetIf.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/GetIf.java
index a41d4cf..89c0929 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/GetIf.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/GetIf.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/GetMapValue.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/GetMapValue.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/GetMapValue.java
index 21e7eba..4f48276 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/GetMapValue.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/GetMapValue.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 java.util.Map;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/GetTime.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/GetTime.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/GetTime.java
index ddbb0a3..14e58b4 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/GetTime.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/GetTime.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.log4j.Logger;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/GetTupleFromAvro.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/GetTupleFromAvro.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/GetTupleFromAvro.java
index 94544e9..8a2b02a 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/GetTupleFromAvro.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/GetTupleFromAvro.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.avro.Schema;

http://git-wip-us.apache.org/repos/asf/storm/blob/a667c75d/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/Hash.java
----------------------------------------------------------------------
diff --git a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/Hash.java b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/Hash.java
index dfbd85e..71cf23e 100644
--- a/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/Hash.java
+++ b/external/storm-sqe/src/main/java/com/jwplayer/sqe/trident/function/Hash.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.hash.MurmurHash;