You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@avro.apache.org by cu...@apache.org on 2010/08/27 01:11:48 UTC

svn commit: r989971 - in /avro/trunk: lang/java/src/java/org/apache/avro/ipc/ lang/java/src/java/org/apache/avro/mapred/ lang/java/src/test/java/org/apache/avro/ipc/ lang/java/src/test/java/org/apache/avro/ipc/trace/ share/ share/schemas/org/apache/avr...

Author: cutting
Date: Thu Aug 26 23:11:47 2010
New Revision: 989971

URL: http://svn.apache.org/viewvc?rev=989971&view=rev
Log:
Add some missing licenses so that rat passes.  Also add .json files to excludes, since json doesn't permit comments.

Modified:
    avro/trunk/lang/java/src/java/org/apache/avro/ipc/NettyTransportCodec.java
    avro/trunk/lang/java/src/java/org/apache/avro/mapred/AvroUtf8InputFormat.java
    avro/trunk/lang/java/src/test/java/org/apache/avro/ipc/TestNettyServer.java
    avro/trunk/lang/java/src/test/java/org/apache/avro/ipc/trace/TestTraceCollection.java
    avro/trunk/share/rat-excludes.txt
    avro/trunk/share/schemas/org/apache/avro/ipc/trace/avroTrace.avdl

Modified: avro/trunk/lang/java/src/java/org/apache/avro/ipc/NettyTransportCodec.java
URL: http://svn.apache.org/viewvc/avro/trunk/lang/java/src/java/org/apache/avro/ipc/NettyTransportCodec.java?rev=989971&r1=989970&r2=989971&view=diff
==============================================================================
--- avro/trunk/lang/java/src/java/org/apache/avro/ipc/NettyTransportCodec.java (original)
+++ avro/trunk/lang/java/src/java/org/apache/avro/ipc/NettyTransportCodec.java Thu Aug 26 23:11:47 2010
@@ -1,3 +1,21 @@
+/**
+ * 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.avro.ipc;
 
 import java.nio.ByteBuffer;

Modified: avro/trunk/lang/java/src/java/org/apache/avro/mapred/AvroUtf8InputFormat.java
URL: http://svn.apache.org/viewvc/avro/trunk/lang/java/src/java/org/apache/avro/mapred/AvroUtf8InputFormat.java?rev=989971&r1=989970&r2=989971&view=diff
==============================================================================
--- avro/trunk/lang/java/src/java/org/apache/avro/mapred/AvroUtf8InputFormat.java (original)
+++ avro/trunk/lang/java/src/java/org/apache/avro/mapred/AvroUtf8InputFormat.java Thu Aug 26 23:11:47 2010
@@ -1,4 +1,23 @@
+/**
+ * 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.avro.mapred;
+
 import java.io.IOException;
 
 import org.apache.avro.util.Utf8;

Modified: avro/trunk/lang/java/src/test/java/org/apache/avro/ipc/TestNettyServer.java
URL: http://svn.apache.org/viewvc/avro/trunk/lang/java/src/test/java/org/apache/avro/ipc/TestNettyServer.java?rev=989971&r1=989970&r2=989971&view=diff
==============================================================================
--- avro/trunk/lang/java/src/test/java/org/apache/avro/ipc/TestNettyServer.java (original)
+++ avro/trunk/lang/java/src/test/java/org/apache/avro/ipc/TestNettyServer.java Thu Aug 26 23:11:47 2010
@@ -1,3 +1,21 @@
+/**
+ * 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.avro.ipc;
 
 import java.net.InetSocketAddress;

Modified: avro/trunk/lang/java/src/test/java/org/apache/avro/ipc/trace/TestTraceCollection.java
URL: http://svn.apache.org/viewvc/avro/trunk/lang/java/src/test/java/org/apache/avro/ipc/trace/TestTraceCollection.java?rev=989971&r1=989970&r2=989971&view=diff
==============================================================================
--- avro/trunk/lang/java/src/test/java/org/apache/avro/ipc/trace/TestTraceCollection.java (original)
+++ avro/trunk/lang/java/src/test/java/org/apache/avro/ipc/trace/TestTraceCollection.java Thu Aug 26 23:11:47 2010
@@ -1,3 +1,21 @@
+/**
+ * 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.avro.ipc.trace;
 
 import static org.junit.Assert.assertEquals;

Modified: avro/trunk/share/rat-excludes.txt
URL: http://svn.apache.org/viewvc/avro/trunk/share/rat-excludes.txt?rev=989971&r1=989970&r2=989971&view=diff
==============================================================================
--- avro/trunk/share/rat-excludes.txt (original)
+++ avro/trunk/share/rat-excludes.txt Thu Aug 26 23:11:47 2010
@@ -3,6 +3,7 @@
 **/*.avsc
 **/*.gperf
 **/*.html
+**/*.json
 **/*.js
 **/*.la
 **/*.m4

Modified: avro/trunk/share/schemas/org/apache/avro/ipc/trace/avroTrace.avdl
URL: http://svn.apache.org/viewvc/avro/trunk/share/schemas/org/apache/avro/ipc/trace/avroTrace.avdl?rev=989971&r1=989970&r2=989971&view=diff
==============================================================================
--- avro/trunk/share/schemas/org/apache/avro/ipc/trace/avroTrace.avdl (original)
+++ avro/trunk/share/schemas/org/apache/avro/ipc/trace/avroTrace.avdl Thu Aug 26 23:11:47 2010
@@ -1,4 +1,22 @@
 /**
+ * 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.
+ */
+
+/**
  * A Span is our basic unit of tracing. It tracks the critical points
  * of a single RPC call and records other call meta-data. It also
  * allows arbitrary string annotations. Both the client and server create