From 91168108cd9ffb9edae6f66837fee830f44d30e4 Mon Sep 17 00:00:00 2001 From: Lianhui Wang Date: Thu, 16 Jul 2015 00:47:29 +0800 Subject: [PATCH] add apache license header --- .../catalyst/expressions/UnsafeRowLocation.java | 17 +++++++++++++++++ .../sql/execution/UnsafeAppendOnlyMap.java | 17 +++++++++++++++++ .../UnsafeExternalAggregationSuite.scala | 17 +++++++++++++++++ 3 files changed, 51 insertions(+) diff --git a/sql/catalyst/src/main/java/org/apache/spark/sql/catalyst/expressions/UnsafeRowLocation.java b/sql/catalyst/src/main/java/org/apache/spark/sql/catalyst/expressions/UnsafeRowLocation.java index 56dacb7137b63..b77fae6b3e8cd 100644 --- a/sql/catalyst/src/main/java/org/apache/spark/sql/catalyst/expressions/UnsafeRowLocation.java +++ b/sql/catalyst/src/main/java/org/apache/spark/sql/catalyst/expressions/UnsafeRowLocation.java @@ -1,3 +1,20 @@ +/* + * Licensed to the Apache Software Foundation (ASF) under one or more + * contributor license agreements. See the NOTICE file distributed with + * this work for additional information regarding copyright ownership. + * The ASF licenses this file to You under the Apache License, Version 2.0 + * (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * http://www.apache.org/licenses/LICENSE-2.0 + * + * Unless required by applicable law or agreed to in writing, software + * distributed under the License is distributed on an "AS IS" BASIS, + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. + * See the License for the specific language governing permissions and + * limitations under the License. + */ + package org.apache.spark.sql.catalyst.expressions; import org.apache.spark.unsafe.PlatformDependent; diff --git a/sql/catalyst/src/main/java/org/apache/spark/sql/execution/UnsafeAppendOnlyMap.java b/sql/catalyst/src/main/java/org/apache/spark/sql/execution/UnsafeAppendOnlyMap.java index daed2e8b767d3..f265d73fcfa22 100644 --- a/sql/catalyst/src/main/java/org/apache/spark/sql/execution/UnsafeAppendOnlyMap.java +++ b/sql/catalyst/src/main/java/org/apache/spark/sql/execution/UnsafeAppendOnlyMap.java @@ -1,3 +1,20 @@ +/* + * Licensed to the Apache Software Foundation (ASF) under one or more + * contributor license agreements. See the NOTICE file distributed with + * this work for additional information regarding copyright ownership. + * The ASF licenses this file to You under the Apache License, Version 2.0 + * (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * http://www.apache.org/licenses/LICENSE-2.0 + * + * Unless required by applicable law or agreed to in writing, software + * distributed under the License is distributed on an "AS IS" BASIS, + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. + * See the License for the specific language governing permissions and + * limitations under the License. + */ + package org.apache.spark.sql.execution; import java.util.Comparator; diff --git a/sql/core/src/test/scala/org/apache/spark/sql/execution/UnsafeExternalAggregationSuite.scala b/sql/core/src/test/scala/org/apache/spark/sql/execution/UnsafeExternalAggregationSuite.scala index b73930ca3cb3f..e0bb96fcbbb43 100644 --- a/sql/core/src/test/scala/org/apache/spark/sql/execution/UnsafeExternalAggregationSuite.scala +++ b/sql/core/src/test/scala/org/apache/spark/sql/execution/UnsafeExternalAggregationSuite.scala @@ -1,3 +1,20 @@ +/* + * Licensed to the Apache Software Foundation (ASF) under one or more + * contributor license agreements. See the NOTICE file distributed with + * this work for additional information regarding copyright ownership. + * The ASF licenses this file to You under the Apache License, Version 2.0 + * (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * http://www.apache.org/licenses/LICENSE-2.0 + * + * Unless required by applicable law or agreed to in writing, software + * distributed under the License is distributed on an "AS IS" BASIS, + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. + * See the License for the specific language governing permissions and + * limitations under the License. + */ + package org.apache.spark.sql.execution import org.apache.spark.SparkEnv