You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@jena.apache.org by rv...@apache.org on 2014/04/04 13:55:23 UTC

svn commit: r1584617 [6/6] - in /jena/Experimental/hadoop-rdf: hadoop-rdf-common/src/main/java/com/yarcdata/urika/hadoop/rdf/types/ hadoop-rdf-common/src/main/java/com/yarcdata/urika/hadoop/rdf/types/compators/ hadoop-rdf-common/src/test/java/com/yarcd...

Modified: jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/group/AbstractTripleGroupingTests.java
URL: http://svn.apache.org/viewvc/jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/group/AbstractTripleGroupingTests.java?rev=1584617&r1=1584616&r2=1584617&view=diff
==============================================================================
--- jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/group/AbstractTripleGroupingTests.java (original)
+++ jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/group/AbstractTripleGroupingTests.java Fri Apr  4 11:55:19 2014
@@ -1,7 +1,21 @@
-/*
- * Copyright 2013 YarcData LLC All Rights Reserved.
- */
+/*
+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.yarcdata.urika.hadoop.rdf.mapreduce.group;
 
 import com.hp.hpl.jena.datatypes.xsd.XSDDatatype;

Modified: jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/group/QuadGroupByGraphMapperTest.java
URL: http://svn.apache.org/viewvc/jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/group/QuadGroupByGraphMapperTest.java?rev=1584617&r1=1584616&r2=1584617&view=diff
==============================================================================
--- jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/group/QuadGroupByGraphMapperTest.java (original)
+++ jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/group/QuadGroupByGraphMapperTest.java Fri Apr  4 11:55:19 2014
@@ -1,7 +1,21 @@
-/*
- * Copyright 2013 YarcData LLC All Rights Reserved.
- */
-
+/*
+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.yarcdata.urika.hadoop.rdf.mapreduce.group;
 
 import org.apache.hadoop.io.LongWritable;

Modified: jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/group/QuadGroupByObjectMapperTest.java
URL: http://svn.apache.org/viewvc/jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/group/QuadGroupByObjectMapperTest.java?rev=1584617&r1=1584616&r2=1584617&view=diff
==============================================================================
--- jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/group/QuadGroupByObjectMapperTest.java (original)
+++ jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/group/QuadGroupByObjectMapperTest.java Fri Apr  4 11:55:19 2014
@@ -1,7 +1,21 @@
-/*
- * Copyright 2013 YarcData LLC All Rights Reserved.
- */
-
+/*
+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.yarcdata.urika.hadoop.rdf.mapreduce.group;
 
 import org.apache.hadoop.io.LongWritable;

Modified: jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/group/QuadGroupByPredicateMapperTest.java
URL: http://svn.apache.org/viewvc/jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/group/QuadGroupByPredicateMapperTest.java?rev=1584617&r1=1584616&r2=1584617&view=diff
==============================================================================
--- jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/group/QuadGroupByPredicateMapperTest.java (original)
+++ jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/group/QuadGroupByPredicateMapperTest.java Fri Apr  4 11:55:19 2014
@@ -1,7 +1,21 @@
-/*
- * Copyright 2013 YarcData LLC All Rights Reserved.
- */
-
+/*
+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.yarcdata.urika.hadoop.rdf.mapreduce.group;
 
 import org.apache.hadoop.io.LongWritable;

Modified: jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/group/QuadGroupBySubjectMapperTest.java
URL: http://svn.apache.org/viewvc/jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/group/QuadGroupBySubjectMapperTest.java?rev=1584617&r1=1584616&r2=1584617&view=diff
==============================================================================
--- jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/group/QuadGroupBySubjectMapperTest.java (original)
+++ jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/group/QuadGroupBySubjectMapperTest.java Fri Apr  4 11:55:19 2014
@@ -1,7 +1,21 @@
-/*
- * Copyright 2013 YarcData LLC All Rights Reserved.
- */
-
+/*
+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.yarcdata.urika.hadoop.rdf.mapreduce.group;
 
 import org.apache.hadoop.io.LongWritable;

Modified: jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/group/TripleGroupByObjectMapperTest.java
URL: http://svn.apache.org/viewvc/jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/group/TripleGroupByObjectMapperTest.java?rev=1584617&r1=1584616&r2=1584617&view=diff
==============================================================================
--- jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/group/TripleGroupByObjectMapperTest.java (original)
+++ jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/group/TripleGroupByObjectMapperTest.java Fri Apr  4 11:55:19 2014
@@ -1,7 +1,21 @@
-/*
- * Copyright 2013 YarcData LLC All Rights Reserved.
- */
-
+/*
+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.yarcdata.urika.hadoop.rdf.mapreduce.group;
 
 import org.apache.hadoop.io.LongWritable;

Modified: jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/group/TripleGroupByPredicateMapperTest.java
URL: http://svn.apache.org/viewvc/jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/group/TripleGroupByPredicateMapperTest.java?rev=1584617&r1=1584616&r2=1584617&view=diff
==============================================================================
--- jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/group/TripleGroupByPredicateMapperTest.java (original)
+++ jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/group/TripleGroupByPredicateMapperTest.java Fri Apr  4 11:55:19 2014
@@ -1,7 +1,21 @@
-/*
- * Copyright 2013 YarcData LLC All Rights Reserved.
- */
-
+/*
+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.yarcdata.urika.hadoop.rdf.mapreduce.group;
 
 import org.apache.hadoop.io.LongWritable;

Modified: jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/group/TripleGroupBySubjectMapperTest.java
URL: http://svn.apache.org/viewvc/jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/group/TripleGroupBySubjectMapperTest.java?rev=1584617&r1=1584616&r2=1584617&view=diff
==============================================================================
--- jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/group/TripleGroupBySubjectMapperTest.java (original)
+++ jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/group/TripleGroupBySubjectMapperTest.java Fri Apr  4 11:55:19 2014
@@ -1,7 +1,21 @@
-/*
- * Copyright 2013 YarcData LLC All Rights Reserved.
- */
-
+/*
+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.yarcdata.urika.hadoop.rdf.mapreduce.group;
 
 import org.apache.hadoop.io.LongWritable;

Modified: jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/split/AbstractNodeTupleSplitToNodesTests.java
URL: http://svn.apache.org/viewvc/jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/split/AbstractNodeTupleSplitToNodesTests.java?rev=1584617&r1=1584616&r2=1584617&view=diff
==============================================================================
--- jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/split/AbstractNodeTupleSplitToNodesTests.java (original)
+++ jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/split/AbstractNodeTupleSplitToNodesTests.java Fri Apr  4 11:55:19 2014
@@ -1,7 +1,21 @@
-/*
- * Copyright 2013 YarcData LLC All Rights Reserved.
- */
+/*
+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.yarcdata.urika.hadoop.rdf.mapreduce.split;
 
 import java.io.IOException;

Modified: jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/split/AbstractNodeTupleSplitWithNodesTests.java
URL: http://svn.apache.org/viewvc/jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/split/AbstractNodeTupleSplitWithNodesTests.java?rev=1584617&r1=1584616&r2=1584617&view=diff
==============================================================================
--- jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/split/AbstractNodeTupleSplitWithNodesTests.java (original)
+++ jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/split/AbstractNodeTupleSplitWithNodesTests.java Fri Apr  4 11:55:19 2014
@@ -1,7 +1,21 @@
-/*
- * Copyright 2013 YarcData LLC All Rights Reserved.
- */
+/*
+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.yarcdata.urika.hadoop.rdf.mapreduce.split;
 
 import java.io.IOException;

Modified: jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/split/AbstractQuadSplitToNodesTests.java
URL: http://svn.apache.org/viewvc/jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/split/AbstractQuadSplitToNodesTests.java?rev=1584617&r1=1584616&r2=1584617&view=diff
==============================================================================
--- jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/split/AbstractQuadSplitToNodesTests.java (original)
+++ jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/split/AbstractQuadSplitToNodesTests.java Fri Apr  4 11:55:19 2014
@@ -1,7 +1,21 @@
-/*
- * Copyright 2013 YarcData LLC All Rights Reserved.
- */
-
+/*
+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.yarcdata.urika.hadoop.rdf.mapreduce.split;
 
 import com.hp.hpl.jena.datatypes.xsd.XSDDatatype;

Modified: jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/split/AbstractQuadSplitWithNodesTests.java
URL: http://svn.apache.org/viewvc/jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/split/AbstractQuadSplitWithNodesTests.java?rev=1584617&r1=1584616&r2=1584617&view=diff
==============================================================================
--- jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/split/AbstractQuadSplitWithNodesTests.java (original)
+++ jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/split/AbstractQuadSplitWithNodesTests.java Fri Apr  4 11:55:19 2014
@@ -1,7 +1,21 @@
-/*
- * Copyright 2013 YarcData LLC All Rights Reserved.
- */
-
+/*
+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.yarcdata.urika.hadoop.rdf.mapreduce.split;
 
 import com.hp.hpl.jena.datatypes.xsd.XSDDatatype;

Modified: jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/split/AbstractTripleSplitToNodesTests.java
URL: http://svn.apache.org/viewvc/jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/split/AbstractTripleSplitToNodesTests.java?rev=1584617&r1=1584616&r2=1584617&view=diff
==============================================================================
--- jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/split/AbstractTripleSplitToNodesTests.java (original)
+++ jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/split/AbstractTripleSplitToNodesTests.java Fri Apr  4 11:55:19 2014
@@ -1,7 +1,21 @@
-/*
- * Copyright 2013 YarcData LLC All Rights Reserved.
- */
-
+/*
+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.yarcdata.urika.hadoop.rdf.mapreduce.split;
 
 import com.hp.hpl.jena.datatypes.xsd.XSDDatatype;

Modified: jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/split/AbstractTripleSplitWithNodesTests.java
URL: http://svn.apache.org/viewvc/jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/split/AbstractTripleSplitWithNodesTests.java?rev=1584617&r1=1584616&r2=1584617&view=diff
==============================================================================
--- jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/split/AbstractTripleSplitWithNodesTests.java (original)
+++ jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/split/AbstractTripleSplitWithNodesTests.java Fri Apr  4 11:55:19 2014
@@ -1,7 +1,21 @@
-/*
- * Copyright 2013 YarcData LLC All Rights Reserved.
- */
-
+/*
+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.yarcdata.urika.hadoop.rdf.mapreduce.split;
 
 import com.hp.hpl.jena.datatypes.xsd.XSDDatatype;

Modified: jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/split/QuadSplitToNodesMapperTest.java
URL: http://svn.apache.org/viewvc/jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/split/QuadSplitToNodesMapperTest.java?rev=1584617&r1=1584616&r2=1584617&view=diff
==============================================================================
--- jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/split/QuadSplitToNodesMapperTest.java (original)
+++ jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/split/QuadSplitToNodesMapperTest.java Fri Apr  4 11:55:19 2014
@@ -1,7 +1,21 @@
-/*
- * Copyright 2013 YarcData LLC All Rights Reserved.
- */
-
+/*
+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.yarcdata.urika.hadoop.rdf.mapreduce.split;
 
 import org.apache.hadoop.io.LongWritable;

Modified: jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/split/QuadSplitWithNodesMapperTest.java
URL: http://svn.apache.org/viewvc/jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/split/QuadSplitWithNodesMapperTest.java?rev=1584617&r1=1584616&r2=1584617&view=diff
==============================================================================
--- jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/split/QuadSplitWithNodesMapperTest.java (original)
+++ jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/split/QuadSplitWithNodesMapperTest.java Fri Apr  4 11:55:19 2014
@@ -1,7 +1,21 @@
-/*
- * Copyright 2013 YarcData LLC All Rights Reserved.
- */
-
+/*
+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.yarcdata.urika.hadoop.rdf.mapreduce.split;
 
 import org.apache.hadoop.io.LongWritable;

Modified: jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/split/TripleSplitToNodesMapperTest.java
URL: http://svn.apache.org/viewvc/jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/split/TripleSplitToNodesMapperTest.java?rev=1584617&r1=1584616&r2=1584617&view=diff
==============================================================================
--- jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/split/TripleSplitToNodesMapperTest.java (original)
+++ jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/split/TripleSplitToNodesMapperTest.java Fri Apr  4 11:55:19 2014
@@ -1,7 +1,21 @@
-/*
- * Copyright 2013 YarcData LLC All Rights Reserved.
- */
-
+/*
+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.yarcdata.urika.hadoop.rdf.mapreduce.split;
 
 import org.apache.hadoop.io.LongWritable;

Modified: jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/split/TripleSplitWithNodesMapperTest.java
URL: http://svn.apache.org/viewvc/jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/split/TripleSplitWithNodesMapperTest.java?rev=1584617&r1=1584616&r2=1584617&view=diff
==============================================================================
--- jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/split/TripleSplitWithNodesMapperTest.java (original)
+++ jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/split/TripleSplitWithNodesMapperTest.java Fri Apr  4 11:55:19 2014
@@ -1,7 +1,21 @@
-/*
- * Copyright 2013 YarcData LLC All Rights Reserved.
- */
-
+/*
+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.yarcdata.urika.hadoop.rdf.mapreduce.split;
 
 import org.apache.hadoop.io.LongWritable;

Modified: jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/transform/QuadsToTriplesMapperTest.java
URL: http://svn.apache.org/viewvc/jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/transform/QuadsToTriplesMapperTest.java?rev=1584617&r1=1584616&r2=1584617&view=diff
==============================================================================
--- jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/transform/QuadsToTriplesMapperTest.java (original)
+++ jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/transform/QuadsToTriplesMapperTest.java Fri Apr  4 11:55:19 2014
@@ -1,7 +1,21 @@
-/*
- * Copyright 2013 YarcData LLC All Rights Reserved.
- */
+/*
+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.yarcdata.urika.hadoop.rdf.mapreduce.transform;
 
 import java.io.IOException;

Modified: jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/transform/TriplesToQuadsBySubjectMapperTest.java
URL: http://svn.apache.org/viewvc/jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/transform/TriplesToQuadsBySubjectMapperTest.java?rev=1584617&r1=1584616&r2=1584617&view=diff
==============================================================================
--- jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/transform/TriplesToQuadsBySubjectMapperTest.java (original)
+++ jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/transform/TriplesToQuadsBySubjectMapperTest.java Fri Apr  4 11:55:19 2014
@@ -1,7 +1,21 @@
-/*
- * Copyright 2013 YarcData LLC All Rights Reserved.
- */
+/*
+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.yarcdata.urika.hadoop.rdf.mapreduce.transform;
 
 import java.io.IOException;

Modified: jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/transform/TriplesToQuadsConstantGraphMapperTest.java
URL: http://svn.apache.org/viewvc/jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/transform/TriplesToQuadsConstantGraphMapperTest.java?rev=1584617&r1=1584616&r2=1584617&view=diff
==============================================================================
--- jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/transform/TriplesToQuadsConstantGraphMapperTest.java (original)
+++ jena/Experimental/hadoop-rdf/hadoop-rdf-mapreduce/src/test/java/com/yarcdata/urika/hadoop/rdf/mapreduce/transform/TriplesToQuadsConstantGraphMapperTest.java Fri Apr  4 11:55:19 2014
@@ -1,7 +1,21 @@
-/*
- * Copyright 2013 YarcData LLC All Rights Reserved.
- */
+/*
+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.yarcdata.urika.hadoop.rdf.mapreduce.transform;
 
 import java.io.IOException;

Modified: jena/Experimental/hadoop-rdf/hadoop-rdf-stats/src/main/java/com/yarcdata/urika/hadoop/rdf/stats/RdfStats.java
URL: http://svn.apache.org/viewvc/jena/Experimental/hadoop-rdf/hadoop-rdf-stats/src/main/java/com/yarcdata/urika/hadoop/rdf/stats/RdfStats.java?rev=1584617&r1=1584616&r2=1584617&view=diff
==============================================================================
--- jena/Experimental/hadoop-rdf/hadoop-rdf-stats/src/main/java/com/yarcdata/urika/hadoop/rdf/stats/RdfStats.java (original)
+++ jena/Experimental/hadoop-rdf/hadoop-rdf-stats/src/main/java/com/yarcdata/urika/hadoop/rdf/stats/RdfStats.java Fri Apr  4 11:55:19 2014
@@ -1,7 +1,21 @@
-/*
- * Copyright 2013 YarcData LLC All Rights Reserved.
- */
-
+/*
+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.yarcdata.urika.hadoop.rdf.stats;
 
 import io.airlift.command.Arguments;

Modified: jena/Experimental/hadoop-rdf/hadoop-rdf-stats/src/main/java/com/yarcdata/urika/hadoop/rdf/stats/jobs/JobFactory.java
URL: http://svn.apache.org/viewvc/jena/Experimental/hadoop-rdf/hadoop-rdf-stats/src/main/java/com/yarcdata/urika/hadoop/rdf/stats/jobs/JobFactory.java?rev=1584617&r1=1584616&r2=1584617&view=diff
==============================================================================
--- jena/Experimental/hadoop-rdf/hadoop-rdf-stats/src/main/java/com/yarcdata/urika/hadoop/rdf/stats/jobs/JobFactory.java (original)
+++ jena/Experimental/hadoop-rdf/hadoop-rdf-stats/src/main/java/com/yarcdata/urika/hadoop/rdf/stats/jobs/JobFactory.java Fri Apr  4 11:55:19 2014
@@ -1,7 +1,21 @@
-/*
- * Copyright 2013 YarcData LLC All Rights Reserved.
- */
-
+/*
+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.yarcdata.urika.hadoop.rdf.stats.jobs;
 
 import java.io.IOException;