You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@kudu.apache.org by ab...@apache.org on 2018/10/09 22:06:52 UTC

kudu git commit: Fix RAT warnings

Repository: kudu
Updated Branches:
  refs/heads/master ab38f6825 -> 88edfc36a


Fix RAT warnings

Change-Id: If18dc7321ba0294d9d640064f25e5b3d3bca1914
Reviewed-on: http://gerrit.cloudera.org:8080/11632
Reviewed-by: Grant Henke <gr...@apache.org>
Tested-by: Grant Henke <gr...@apache.org>


Project: http://git-wip-us.apache.org/repos/asf/kudu/repo
Commit: http://git-wip-us.apache.org/repos/asf/kudu/commit/88edfc36
Tree: http://git-wip-us.apache.org/repos/asf/kudu/tree/88edfc36
Diff: http://git-wip-us.apache.org/repos/asf/kudu/diff/88edfc36

Branch: refs/heads/master
Commit: 88edfc36a888d53445b0e24159a10bf7de8b5213
Parents: ab38f68
Author: Attila Bukor <ab...@apache.org>
Authored: Wed Oct 10 00:04:27 2018 +0200
Committer: Attila Bukor <ab...@apache.org>
Committed: Tue Oct 9 22:06:28 2018 +0000

----------------------------------------------------------------------
 build-support/release/rat_exclude_files.txt        |  6 +++++-
 .../apache/kudu/examples/KuduCollectlExample.java  | 17 +++++++++++++++++
 .../apache/kudu/flume/sink/KuduSinkTestUtil.java   | 17 +++++++++++++++++
 ...RegexpKuduOperationsProducerParseErrorTest.java | 17 +++++++++++++++++
 .../org/apache/kudu/spark/kudu/SparkUtil.scala     | 17 +++++++++++++++++
 5 files changed, 73 insertions(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/kudu/blob/88edfc36/build-support/release/rat_exclude_files.txt
----------------------------------------------------------------------
diff --git a/build-support/release/rat_exclude_files.txt b/build-support/release/rat_exclude_files.txt
index 8680003..28a9132 100644
--- a/build-support/release/rat_exclude_files.txt
+++ b/build-support/release/rat_exclude_files.txt
@@ -16,7 +16,9 @@ build-support/iwyu/mappings/boost-all-private.imp
 build-support/iwyu/mappings/boost-all.imp
 build-support/release/rat_exclude_files.txt
 docs/support/doxygen/client_api.footer.in
-java/kudu-flume-sink/src/test/avro/testAvroKuduOperationsProducer.avsc
+examples/README.md
+examples/python/graphite-kudu/setup.cfg
+java/.scalafmt.conf
 java/kudu-client/src/main/java/org/apache/kudu/client/AsyncKuduClient.java
 java/kudu-client/src/main/java/org/apache/kudu/client/AsyncKuduScanner.java
 java/kudu-client/src/main/java/org/apache/kudu/client/Bytes.java
@@ -29,6 +31,8 @@ java/kudu-client/src/main/java/org/apache/kudu/client/PleaseThrottleException.ja
 java/kudu-client/src/main/java/org/apache/kudu/client/RecoverableException.java
 java/kudu-client/src/main/java/org/apache/kudu/client/RpcProxy.java
 java/kudu-client/src/test/resources/flags
+java/kudu-flume-sink/src/test/resources/testAvroKuduOperationsProducer.avsc
+java/kudu-spark-tools/src/test/resources/TestImportExportFiles.csv
 python/MANIFEST.in
 python/README.md
 python/pytest.ini

http://git-wip-us.apache.org/repos/asf/kudu/blob/88edfc36/examples/java/collectl/src/main/java/org/apache/kudu/examples/KuduCollectlExample.java
----------------------------------------------------------------------
diff --git a/examples/java/collectl/src/main/java/org/apache/kudu/examples/KuduCollectlExample.java b/examples/java/collectl/src/main/java/org/apache/kudu/examples/KuduCollectlExample.java
index 03ee92e..3dbfa27 100644
--- a/examples/java/collectl/src/main/java/org/apache/kudu/examples/KuduCollectlExample.java
+++ b/examples/java/collectl/src/main/java/org/apache/kudu/examples/KuduCollectlExample.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.kudu.examples;
 
 import java.io.BufferedReader;

http://git-wip-us.apache.org/repos/asf/kudu/blob/88edfc36/java/kudu-flume-sink/src/test/java/org/apache/kudu/flume/sink/KuduSinkTestUtil.java
----------------------------------------------------------------------
diff --git a/java/kudu-flume-sink/src/test/java/org/apache/kudu/flume/sink/KuduSinkTestUtil.java b/java/kudu-flume-sink/src/test/java/org/apache/kudu/flume/sink/KuduSinkTestUtil.java
index e24bfe0..3f5cfbf 100644
--- a/java/kudu-flume-sink/src/test/java/org/apache/kudu/flume/sink/KuduSinkTestUtil.java
+++ b/java/kudu-flume-sink/src/test/java/org/apache/kudu/flume/sink/KuduSinkTestUtil.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.kudu.flume.sink;
 
 import static org.apache.kudu.flume.sink.KuduSinkConfigurationConstants.KERBEROS_KEYTAB;

http://git-wip-us.apache.org/repos/asf/kudu/blob/88edfc36/java/kudu-flume-sink/src/test/java/org/apache/kudu/flume/sink/RegexpKuduOperationsProducerParseErrorTest.java
----------------------------------------------------------------------
diff --git a/java/kudu-flume-sink/src/test/java/org/apache/kudu/flume/sink/RegexpKuduOperationsProducerParseErrorTest.java b/java/kudu-flume-sink/src/test/java/org/apache/kudu/flume/sink/RegexpKuduOperationsProducerParseErrorTest.java
index fda478c..b2bf746 100644
--- a/java/kudu-flume-sink/src/test/java/org/apache/kudu/flume/sink/RegexpKuduOperationsProducerParseErrorTest.java
+++ b/java/kudu-flume-sink/src/test/java/org/apache/kudu/flume/sink/RegexpKuduOperationsProducerParseErrorTest.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.kudu.flume.sink;
 
 

http://git-wip-us.apache.org/repos/asf/kudu/blob/88edfc36/java/kudu-spark/src/main/scala/org/apache/kudu/spark/kudu/SparkUtil.scala
----------------------------------------------------------------------
diff --git a/java/kudu-spark/src/main/scala/org/apache/kudu/spark/kudu/SparkUtil.scala b/java/kudu-spark/src/main/scala/org/apache/kudu/spark/kudu/SparkUtil.scala
index aae386f..636b343 100644
--- a/java/kudu-spark/src/main/scala/org/apache/kudu/spark/kudu/SparkUtil.scala
+++ b/java/kudu-spark/src/main/scala/org/apache/kudu/spark/kudu/SparkUtil.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.kudu.spark.kudu
 
 import java.util