You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@jena.apache.org by an...@apache.org on 2016/05/14 14:03:11 UTC

[12/42] jena git commit: Merge commit 'refs/pull/143/head' of github.com:apache/jena

http://git-wip-us.apache.org/repos/asf/jena/blob/4b5cd267/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/input/nquads/WholeFileNQuadsInputTest.java
----------------------------------------------------------------------
diff --cc jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/input/nquads/WholeFileNQuadsInputTest.java
index 50b8bcf,50b8bcf..da59dde
--- a/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/input/nquads/WholeFileNQuadsInputTest.java
+++ b/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/input/nquads/WholeFileNQuadsInputTest.java
@@@ -1,27 -1,27 +1,27 @@@
--/*
-- * 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.
-- */
--
++/*
++ * 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.jena.hadoop.rdf.io.input.nquads;
  
  import org.apache.hadoop.io.LongWritable;
  import org.apache.hadoop.mapreduce.InputFormat;
--import org.apache.jena.hadoop.rdf.io.input.AbstractWholeFileQuadInputFormatTests;
--import org.apache.jena.hadoop.rdf.types.QuadWritable;
++import org.apache.jena.hadoop.rdf.io.input.AbstractWholeFileQuadInputFormatTests;
++import org.apache.jena.hadoop.rdf.types.QuadWritable;
  import org.apache.jena.riot.Lang;
  
  

http://git-wip-us.apache.org/repos/asf/jena/blob/4b5cd267/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/input/ntriples/BlockedNTriplesInputTest.java
----------------------------------------------------------------------
diff --cc jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/input/ntriples/BlockedNTriplesInputTest.java
index ab92873,ab92873..de014c7
--- a/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/input/ntriples/BlockedNTriplesInputTest.java
+++ b/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/input/ntriples/BlockedNTriplesInputTest.java
@@@ -1,27 -1,27 +1,27 @@@
--/*
-- * 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.
-- */
--
++/*
++ * 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.jena.hadoop.rdf.io.input.ntriples;
  
  import org.apache.hadoop.io.LongWritable;
  import org.apache.hadoop.mapreduce.InputFormat;
--import org.apache.jena.hadoop.rdf.io.input.AbstractBlockedTripleInputFormatTests;
--import org.apache.jena.hadoop.rdf.types.TripleWritable;
++import org.apache.jena.hadoop.rdf.io.input.AbstractBlockedTripleInputFormatTests;
++import org.apache.jena.hadoop.rdf.types.TripleWritable;
  import org.apache.jena.riot.Lang;
  
  

http://git-wip-us.apache.org/repos/asf/jena/blob/4b5cd267/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/input/ntriples/NTriplesInputTest.java
----------------------------------------------------------------------
diff --cc jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/input/ntriples/NTriplesInputTest.java
index 24fb731,24fb731..d8d4af7
--- a/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/input/ntriples/NTriplesInputTest.java
+++ b/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/input/ntriples/NTriplesInputTest.java
@@@ -1,27 -1,27 +1,27 @@@
--/*
-- * 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.
-- */
--
++/*
++ * 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.jena.hadoop.rdf.io.input.ntriples;
  
  import org.apache.hadoop.io.LongWritable;
  import org.apache.hadoop.mapreduce.InputFormat;
--import org.apache.jena.hadoop.rdf.io.input.AbstractTriplesInputFormatTests;
--import org.apache.jena.hadoop.rdf.types.TripleWritable;
++import org.apache.jena.hadoop.rdf.io.input.AbstractTriplesInputFormatTests;
++import org.apache.jena.hadoop.rdf.types.TripleWritable;
  
  
  /**

http://git-wip-us.apache.org/repos/asf/jena/blob/4b5cd267/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/input/ntriples/WholeFileNTriplesInputTest.java
----------------------------------------------------------------------
diff --cc jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/input/ntriples/WholeFileNTriplesInputTest.java
index fcec570,fcec570..560fc01
--- a/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/input/ntriples/WholeFileNTriplesInputTest.java
+++ b/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/input/ntriples/WholeFileNTriplesInputTest.java
@@@ -1,27 -1,27 +1,27 @@@
--/*
-- * 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.
-- */
--
++/*
++ * 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.jena.hadoop.rdf.io.input.ntriples;
  
  import org.apache.hadoop.io.LongWritable;
  import org.apache.hadoop.mapreduce.InputFormat;
--import org.apache.jena.hadoop.rdf.io.input.AbstractWholeFileTripleInputFormatTests;
--import org.apache.jena.hadoop.rdf.types.TripleWritable;
++import org.apache.jena.hadoop.rdf.io.input.AbstractWholeFileTripleInputFormatTests;
++import org.apache.jena.hadoop.rdf.types.TripleWritable;
  import org.apache.jena.riot.Lang;
  
  

http://git-wip-us.apache.org/repos/asf/jena/blob/4b5cd267/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/input/rdfjson/RdfJsonInputTest.java
----------------------------------------------------------------------
diff --cc jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/input/rdfjson/RdfJsonInputTest.java
index 4731832,4731832..ee27a23
--- a/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/input/rdfjson/RdfJsonInputTest.java
+++ b/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/input/rdfjson/RdfJsonInputTest.java
@@@ -1,27 -1,27 +1,27 @@@
--/*
-- * 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.
-- */
--
++/*
++ * 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.jena.hadoop.rdf.io.input.rdfjson;
  
  import org.apache.hadoop.io.LongWritable;
  import org.apache.hadoop.mapreduce.InputFormat;
--import org.apache.jena.hadoop.rdf.io.input.AbstractWholeFileTripleInputFormatTests;
--import org.apache.jena.hadoop.rdf.types.TripleWritable;
++import org.apache.jena.hadoop.rdf.io.input.AbstractWholeFileTripleInputFormatTests;
++import org.apache.jena.hadoop.rdf.types.TripleWritable;
  import org.apache.jena.riot.Lang;
  
  

http://git-wip-us.apache.org/repos/asf/jena/blob/4b5cd267/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/input/rdfxml/RdfXmlInputTest.java
----------------------------------------------------------------------
diff --cc jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/input/rdfxml/RdfXmlInputTest.java
index f8edcc4,f8edcc4..cf4b362
--- a/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/input/rdfxml/RdfXmlInputTest.java
+++ b/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/input/rdfxml/RdfXmlInputTest.java
@@@ -1,27 -1,27 +1,27 @@@
--/*
-- * 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.
-- */
--
++/*
++ * 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.jena.hadoop.rdf.io.input.rdfxml;
  
  import org.apache.hadoop.io.LongWritable;
  import org.apache.hadoop.mapreduce.InputFormat;
--import org.apache.jena.hadoop.rdf.io.input.AbstractWholeFileTripleInputFormatTests;
--import org.apache.jena.hadoop.rdf.types.TripleWritable;
++import org.apache.jena.hadoop.rdf.io.input.AbstractWholeFileTripleInputFormatTests;
++import org.apache.jena.hadoop.rdf.types.TripleWritable;
  import org.apache.jena.riot.Lang;
  
  

http://git-wip-us.apache.org/repos/asf/jena/blob/4b5cd267/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/input/thrift/ThriftQuadInputTest.java
----------------------------------------------------------------------
diff --cc jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/input/thrift/ThriftQuadInputTest.java
index 8d79295,8d79295..414395b
--- a/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/input/thrift/ThriftQuadInputTest.java
+++ b/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/input/thrift/ThriftQuadInputTest.java
@@@ -1,29 -1,29 +1,29 @@@
--/*
-- * 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.
-- */
--
++/*
++ * 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.jena.hadoop.rdf.io.input.thrift;
  
  import org.apache.hadoop.io.LongWritable;
  import org.apache.hadoop.mapreduce.InputFormat;
--import org.apache.jena.hadoop.rdf.io.input.AbstractWholeFileQuadInputFormatTests;
--import org.apache.jena.hadoop.rdf.types.QuadWritable;
++import org.apache.jena.hadoop.rdf.io.input.AbstractWholeFileQuadInputFormatTests;
++import org.apache.jena.hadoop.rdf.types.QuadWritable;
  import org.apache.jena.riot.Lang;
--import org.apache.jena.riot.RDFLanguages;
++import org.apache.jena.riot.RDFLanguages;
  
  
  /**

http://git-wip-us.apache.org/repos/asf/jena/blob/4b5cd267/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/input/thrift/ThriftTripleInputTest.java
----------------------------------------------------------------------
diff --cc jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/input/thrift/ThriftTripleInputTest.java
index 6b5e0b7,6b5e0b7..7b968e3
--- a/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/input/thrift/ThriftTripleInputTest.java
+++ b/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/input/thrift/ThriftTripleInputTest.java
@@@ -1,29 -1,29 +1,29 @@@
--/*
-- * 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.
-- */
--
++/*
++ * 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.jena.hadoop.rdf.io.input.thrift;
  
  import org.apache.hadoop.io.LongWritable;
  import org.apache.hadoop.mapreduce.InputFormat;
--import org.apache.jena.hadoop.rdf.io.input.AbstractWholeFileTripleInputFormatTests;
--import org.apache.jena.hadoop.rdf.types.TripleWritable;
++import org.apache.jena.hadoop.rdf.io.input.AbstractWholeFileTripleInputFormatTests;
++import org.apache.jena.hadoop.rdf.types.TripleWritable;
  import org.apache.jena.riot.Lang;
--import org.apache.jena.riot.RDFLanguages;
++import org.apache.jena.riot.RDFLanguages;
  
  
  /**

http://git-wip-us.apache.org/repos/asf/jena/blob/4b5cd267/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/input/trig/TriGInputTest.java
----------------------------------------------------------------------
diff --cc jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/input/trig/TriGInputTest.java
index 1fad0dc,1fad0dc..6179055
--- a/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/input/trig/TriGInputTest.java
+++ b/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/input/trig/TriGInputTest.java
@@@ -1,27 -1,27 +1,27 @@@
--/*
-- * 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.
-- */
--
++/*
++ * 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.jena.hadoop.rdf.io.input.trig;
  
  import org.apache.hadoop.io.LongWritable;
  import org.apache.hadoop.mapreduce.InputFormat;
--import org.apache.jena.hadoop.rdf.io.input.AbstractWholeFileQuadInputFormatTests;
--import org.apache.jena.hadoop.rdf.types.QuadWritable;
++import org.apache.jena.hadoop.rdf.io.input.AbstractWholeFileQuadInputFormatTests;
++import org.apache.jena.hadoop.rdf.types.QuadWritable;
  import org.apache.jena.riot.Lang;
  
  

http://git-wip-us.apache.org/repos/asf/jena/blob/4b5cd267/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/input/trix/TriXInputTest.java
----------------------------------------------------------------------
diff --cc jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/input/trix/TriXInputTest.java
index 4a3a66a,4a3a66a..a816b28
--- a/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/input/trix/TriXInputTest.java
+++ b/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/input/trix/TriXInputTest.java
@@@ -1,27 -1,27 +1,27 @@@
--/*
-- * 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.
-- */
--
++/*
++ * 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.jena.hadoop.rdf.io.input.trix;
  
  import org.apache.hadoop.io.LongWritable;
  import org.apache.hadoop.mapreduce.InputFormat;
--import org.apache.jena.hadoop.rdf.io.input.AbstractWholeFileQuadInputFormatTests;
--import org.apache.jena.hadoop.rdf.types.QuadWritable;
++import org.apache.jena.hadoop.rdf.io.input.AbstractWholeFileQuadInputFormatTests;
++import org.apache.jena.hadoop.rdf.types.QuadWritable;
  import org.apache.jena.riot.Lang;
  
  

http://git-wip-us.apache.org/repos/asf/jena/blob/4b5cd267/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/input/turtle/TurtleInputTest.java
----------------------------------------------------------------------
diff --cc jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/input/turtle/TurtleInputTest.java
index b59102c,b59102c..b8a9462
--- a/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/input/turtle/TurtleInputTest.java
+++ b/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/input/turtle/TurtleInputTest.java
@@@ -1,35 -1,35 +1,35 @@@
--/*
-- * 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.
-- */
--
++/*
++ * 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.jena.hadoop.rdf.io.input.turtle;
  
--import java.io.File;
--import java.io.FileWriter;
--import java.io.IOException;
--
--import org.apache.hadoop.conf.Configuration;
++import java.io.File;
++import java.io.FileWriter;
++import java.io.IOException;
++
++import org.apache.hadoop.conf.Configuration;
  import org.apache.hadoop.io.LongWritable;
--import org.apache.hadoop.mapreduce.InputFormat;
--import org.apache.jena.atlas.lib.StrUtils;
--import org.apache.jena.hadoop.rdf.io.RdfIOConstants;
--import org.apache.jena.hadoop.rdf.io.input.AbstractWholeFileTripleInputFormatTests;
--import org.apache.jena.hadoop.rdf.types.TripleWritable;
--import org.apache.jena.riot.Lang;
++import org.apache.hadoop.mapreduce.InputFormat;
++import org.apache.jena.atlas.lib.StrUtils;
++import org.apache.jena.hadoop.rdf.io.RdfIOConstants;
++import org.apache.jena.hadoop.rdf.io.input.AbstractWholeFileTripleInputFormatTests;
++import org.apache.jena.hadoop.rdf.types.TripleWritable;
++import org.apache.jena.riot.Lang;
  import org.junit.Test;
  
  
@@@ -54,27 -54,27 +54,27 @@@ public class TurtleInputTest extends Ab
      @Override
      protected InputFormat<LongWritable, TripleWritable> getInputFormat() {
          return new TurtleInputFormat();
--    }
--    
--    @Test
--    public void turtle_with_prefixes_01() throws IOException, InterruptedException {
--        // Try to reproduce JENA-1075
--        
--        // Create test data
--        File f = new File("target/prefixes.ttl");
--        try (FileWriter writer = new FileWriter(f)) {
--            //@formatter:off
--            writer.write(StrUtils.strjoinNL("@prefix : <http://test/ns#> .",
--                                            ":s :p :o ."));
--            //@formatter:on
--            writer.close();
--        }
--        
--        Configuration config = this.prepareConfiguration();
--        config.setBoolean(RdfIOConstants.INPUT_IGNORE_BAD_TUPLES, false);
--        this.testSingleInput(config, f, 1, 1);
--        
--        // Clean up
--        if (f.exists()) f.delete();
++    }
++    
++    @Test
++    public void turtle_with_prefixes_01() throws IOException, InterruptedException {
++        // Try to reproduce JENA-1075
++        
++        // Create test data
++        File f = new File("target/prefixes.ttl");
++        try (FileWriter writer = new FileWriter(f)) {
++            //@formatter:off
++            writer.write(StrUtils.strjoinNL("@prefix : <http://test/ns#> .",
++                                            ":s :p :o ."));
++            //@formatter:on
++            writer.close();
++        }
++        
++        Configuration config = this.prepareConfiguration();
++        config.setBoolean(RdfIOConstants.INPUT_IGNORE_BAD_TUPLES, false);
++        this.testSingleInput(config, f, 1, 1);
++        
++        // Clean up
++        if (f.exists()) f.delete();
      }
  }

http://git-wip-us.apache.org/repos/asf/jena/blob/4b5cd267/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/input/util/AbstractTrackableInputStreamTests.java
----------------------------------------------------------------------
diff --cc jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/input/util/AbstractTrackableInputStreamTests.java
index 9532d56,9532d56..14c5e75
--- a/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/input/util/AbstractTrackableInputStreamTests.java
+++ b/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/input/util/AbstractTrackableInputStreamTests.java
@@@ -1,21 -1,21 +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.
-- */
--
++/*
++ * 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.jena.hadoop.rdf.io.input.util;
  
  import java.io.ByteArrayInputStream;
@@@ -23,7 -23,7 +23,7 @@@ import java.io.ByteArrayOutputStream
  import java.io.IOException;
  import java.io.InputStream;
  
--import org.apache.jena.hadoop.rdf.io.input.util.TrackableInputStream;
++import org.apache.jena.hadoop.rdf.io.input.util.TrackableInputStream;
  import org.junit.Assert;
  import org.junit.Test;
  

http://git-wip-us.apache.org/repos/asf/jena/blob/4b5cd267/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/input/util/BlockInputStreamTest.java
----------------------------------------------------------------------
diff --cc jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/input/util/BlockInputStreamTest.java
index f8819bc,f8819bc..55aeefa
--- a/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/input/util/BlockInputStreamTest.java
+++ b/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/input/util/BlockInputStreamTest.java
@@@ -1,28 -1,28 +1,28 @@@
--/*
-- * 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.
-- */
--
++/*
++ * 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.jena.hadoop.rdf.io.input.util;
  
  import java.io.IOException;
  import java.io.InputStream;
  
--import org.apache.jena.hadoop.rdf.io.input.util.BlockInputStream;
--import org.apache.jena.hadoop.rdf.io.input.util.TrackableInputStream;
++import org.apache.jena.hadoop.rdf.io.input.util.BlockInputStream;
++import org.apache.jena.hadoop.rdf.io.input.util.TrackableInputStream;
  import org.junit.Assert;
  import org.junit.Test;
  

http://git-wip-us.apache.org/repos/asf/jena/blob/4b5cd267/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/input/util/TrackedInputStreamTest.java
----------------------------------------------------------------------
diff --cc jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/input/util/TrackedInputStreamTest.java
index f453aa5,f453aa5..33d3958
--- a/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/input/util/TrackedInputStreamTest.java
+++ b/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/input/util/TrackedInputStreamTest.java
@@@ -1,27 -1,27 +1,27 @@@
--/*
-- * 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.
-- */
--
++/*
++ * 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.jena.hadoop.rdf.io.input.util;
  
  import java.io.InputStream;
--
--import org.apache.jena.hadoop.rdf.io.input.util.TrackableInputStream;
--import org.apache.jena.hadoop.rdf.io.input.util.TrackedInputStream;
++
++import org.apache.jena.hadoop.rdf.io.input.util.TrackableInputStream;
++import org.apache.jena.hadoop.rdf.io.input.util.TrackedInputStream;
  
  /**
   * Tests for the {@link TrackedInputStream}

http://git-wip-us.apache.org/repos/asf/jena/blob/4b5cd267/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/output/AbstractNodeTupleOutputFormatTests.java
----------------------------------------------------------------------
diff --cc jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/output/AbstractNodeTupleOutputFormatTests.java
index b5ea2d8,b5ea2d8..b6cad7c
--- a/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/output/AbstractNodeTupleOutputFormatTests.java
+++ b/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/output/AbstractNodeTupleOutputFormatTests.java
@@@ -1,255 -1,255 +1,255 @@@
--/*
-- * 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.jena.hadoop.rdf.io.output;
--
--import java.io.File;
--import java.io.FileNotFoundException;
--import java.io.IOException;
--import java.util.Iterator;
--
--import org.apache.hadoop.conf.Configuration;
--import org.apache.hadoop.fs.FileSystem;
--import org.apache.hadoop.fs.LocatedFileStatus;
--import org.apache.hadoop.fs.Path;
--import org.apache.hadoop.fs.RemoteIterator;
--import org.apache.hadoop.io.NullWritable;
--import org.apache.hadoop.mapreduce.Job;
--import org.apache.hadoop.mapreduce.JobContext;
--import org.apache.hadoop.mapreduce.OutputFormat;
--import org.apache.hadoop.mapreduce.RecordWriter;
--import org.apache.hadoop.mapreduce.TaskAttemptContext;
--import org.apache.hadoop.mapreduce.TaskAttemptID;
--import org.apache.hadoop.mapreduce.TaskType;
--import org.apache.hadoop.mapreduce.lib.output.FileOutputFormat;
--import org.apache.hadoop.mapreduce.task.JobContextImpl;
--import org.apache.hadoop.mapreduce.task.TaskAttemptContextImpl;
--import org.apache.jena.hadoop.rdf.types.AbstractNodeTupleWritable;
--import org.apache.jena.riot.Lang;
--import org.apache.jena.riot.RDFDataMgr;
--import org.apache.jena.riot.lang.StreamRDFCounting;
--import org.apache.jena.riot.system.StreamRDFLib;
--import org.junit.Assert;
--import org.junit.Rule;
--import org.junit.Test;
--import org.junit.rules.TemporaryFolder;
--import org.slf4j.Logger;
--import org.slf4j.LoggerFactory;
--
--/**
-- * Abstract node tuple output format tests
-- * 
-- * 
-- * @param <TValue>
-- *            Tuple type
-- * @param <T>
-- *            Writable tuple type
-- * 
-- */
--public abstract class AbstractNodeTupleOutputFormatTests<TValue, T extends AbstractNodeTupleWritable<TValue>> {
--
--    @SuppressWarnings("unused")
--    private static final Logger LOG = LoggerFactory.getLogger(AbstractNodeTupleOutputFormatTests.class);
--
--    protected static final int EMPTY_SIZE = 0, SMALL_SIZE = 100, LARGE_SIZE = 10000, VERY_LARGE_SIZE = 100000;
--
--    /**
--     * Temporary folder for the tests
--     */
--    @Rule
--    public TemporaryFolder folder = new TemporaryFolder();
--
--    /**
--     * Prepares a fresh configuration
--     * 
--     * @return Configuration
--     */
--    protected Configuration prepareConfiguration() {
--        Configuration config = new Configuration(true);
--        // Nothing else to do
--        return config;
--    }
--
--    /**
--     * Gets the extra file extension to add to the filenames
--     * 
--     * @return File extension
--     */
--    protected abstract String getFileExtension();
--
--    /**
--     * Generates tuples to be output for testing
--     * 
--     * @param num
--     *            Number of tuples to generate
--     * @return Iterator of tuples
--     */
--    protected abstract Iterator<T> generateTuples(int num);
--
--    /**
--     * Counts tuples in the output file
--     * 
--     * @param f
--     *            Output file
--     * @return Tuple count
--     */
--    protected final long countTuples(File f) {
--        StreamRDFCounting counter = StreamRDFLib.count();
--        RDFDataMgr.parse(counter, f.getAbsolutePath(), this.getRdfLanguage(), null);
--        return counter.count();
--    }
--
--    /**
--     * Checks that tuples are as expected
--     * 
--     * @param f
--     *            File
--     * @param expected
--     *            Expected number of tuples
--     */
--    protected void checkTuples(File f, long expected) {
--        Assert.assertEquals(expected, this.countTuples(f));
--    }
--
--    /**
--     * Gets the RDF language of the produced output which is used to parse back
--     * in the output to validate the correct amount of output was produced
--     * 
--     * @return RDF language
--     */
--    protected abstract Lang getRdfLanguage();
--
--    /**
--     * Gets the output format to test
--     * 
--     * @return Output format
--     */
--    protected abstract OutputFormat<NullWritable, T> getOutputFormat();
--
--    /**
--     * Adds an output path to the job configuration
--     * 
--     * @param f
--     *            File
--     * @param config
--     *            Configuration
--     * @param job
--     *            Job
--     * @throws IOException
--     */
--    protected void addOutputPath(File f, Configuration config, Job job) throws IOException {
--        FileSystem fs = FileSystem.getLocal(config);
--        Path outputPath = fs.makeQualified(new Path(f.getAbsolutePath()));
--        FileOutputFormat.setOutputPath(job, outputPath);
--    }
--
--    protected File findOutputFile(File dir, JobContext context) throws FileNotFoundException, IOException {
--        Path outputPath = FileOutputFormat.getOutputPath(context);
--        RemoteIterator<LocatedFileStatus> files = outputPath.getFileSystem(context.getConfiguration()).listFiles(
--                outputPath, true);
--        while (files.hasNext()) {
--            LocatedFileStatus status = files.next();
--            if (status.isFile() && !status.getPath().getName().startsWith("_")) {
--                return new File(status.getPath().toUri());
--            }
--        }
--        return null;
--    }
--
--    /**
--     * Tests output
--     * 
--     * @param f
--     *            File to output to
--     * @param num
--     *            Number of tuples to output
--     * @throws IOException
--     * @throws InterruptedException
--     */
--    protected final void testOutput(File f, int num) throws IOException, InterruptedException {
--        // Prepare configuration
--        Configuration config = this.prepareConfiguration();
--
--        // Set up fake job
--        OutputFormat<NullWritable, T> outputFormat = this.getOutputFormat();
--        Job job = Job.getInstance(config);
--        job.setOutputFormatClass(outputFormat.getClass());
--        this.addOutputPath(f, job.getConfiguration(), job);
--        JobContext context = new JobContextImpl(job.getConfiguration(), job.getJobID());
--        Assert.assertNotNull(FileOutputFormat.getOutputPath(context));
--
--        // Output the data
--        TaskAttemptID id = new TaskAttemptID("outputTest", 1, TaskType.MAP, 1, 1);
--        TaskAttemptContext taskContext = new TaskAttemptContextImpl(job.getConfiguration(), id);
--        RecordWriter<NullWritable, T> writer = outputFormat.getRecordWriter(taskContext);
--        Iterator<T> tuples = this.generateTuples(num);
--        while (tuples.hasNext()) {
--            writer.write(NullWritable.get(), tuples.next());
--        }
--        writer.close(taskContext);
--
--        // Check output
--        File outputFile = this.findOutputFile(this.folder.getRoot(), context);
--        Assert.assertNotNull(outputFile);
--        this.checkTuples(outputFile, num);
--    }
--
--    /**
--     * Basic output tests
--     * 
--     * @throws IOException
--     * @throws InterruptedException
--     */
--    @Test
--    public void output_01() throws IOException, InterruptedException {
--        this.testOutput(this.folder.getRoot(), EMPTY_SIZE);
--    }
--
--    /**
--     * Basic output tests
--     * 
--     * @throws IOException
--     * @throws InterruptedException
--     */
--    @Test
--    public void output_02() throws IOException, InterruptedException {
--        this.testOutput(this.folder.getRoot(), SMALL_SIZE);
--    }
--
--    /**
--     * Basic output tests
--     * 
--     * @throws IOException
--     * @throws InterruptedException
--     */
--    @Test
--    public void output_03() throws IOException, InterruptedException {
--        this.testOutput(this.folder.getRoot(), LARGE_SIZE);
--    }
--
--    /**
--     * Basic output tests
--     * 
--     * @throws IOException
--     * @throws InterruptedException
--     */
--    @Test
--    public void output_04() throws IOException, InterruptedException {
--        this.testOutput(this.folder.getRoot(), VERY_LARGE_SIZE);
--    }
--}
++/*
++ * 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.jena.hadoop.rdf.io.output;
++
++import java.io.File;
++import java.io.FileNotFoundException;
++import java.io.IOException;
++import java.util.Iterator;
++
++import org.apache.hadoop.conf.Configuration;
++import org.apache.hadoop.fs.FileSystem;
++import org.apache.hadoop.fs.LocatedFileStatus;
++import org.apache.hadoop.fs.Path;
++import org.apache.hadoop.fs.RemoteIterator;
++import org.apache.hadoop.io.NullWritable;
++import org.apache.hadoop.mapreduce.Job;
++import org.apache.hadoop.mapreduce.JobContext;
++import org.apache.hadoop.mapreduce.OutputFormat;
++import org.apache.hadoop.mapreduce.RecordWriter;
++import org.apache.hadoop.mapreduce.TaskAttemptContext;
++import org.apache.hadoop.mapreduce.TaskAttemptID;
++import org.apache.hadoop.mapreduce.TaskType;
++import org.apache.hadoop.mapreduce.lib.output.FileOutputFormat;
++import org.apache.hadoop.mapreduce.task.JobContextImpl;
++import org.apache.hadoop.mapreduce.task.TaskAttemptContextImpl;
++import org.apache.jena.hadoop.rdf.types.AbstractNodeTupleWritable;
++import org.apache.jena.riot.Lang;
++import org.apache.jena.riot.RDFDataMgr;
++import org.apache.jena.riot.lang.StreamRDFCounting;
++import org.apache.jena.riot.system.StreamRDFLib;
++import org.junit.Assert;
++import org.junit.Rule;
++import org.junit.Test;
++import org.junit.rules.TemporaryFolder;
++import org.slf4j.Logger;
++import org.slf4j.LoggerFactory;
++
++/**
++ * Abstract node tuple output format tests
++ * 
++ * 
++ * @param <TValue>
++ *            Tuple type
++ * @param <T>
++ *            Writable tuple type
++ * 
++ */
++public abstract class AbstractNodeTupleOutputFormatTests<TValue, T extends AbstractNodeTupleWritable<TValue>> {
++
++    @SuppressWarnings("unused")
++    private static final Logger LOG = LoggerFactory.getLogger(AbstractNodeTupleOutputFormatTests.class);
++
++    protected static final int EMPTY_SIZE = 0, SMALL_SIZE = 100, LARGE_SIZE = 10000, VERY_LARGE_SIZE = 100000;
++
++    /**
++     * Temporary folder for the tests
++     */
++    @Rule
++    public TemporaryFolder folder = new TemporaryFolder();
++
++    /**
++     * Prepares a fresh configuration
++     * 
++     * @return Configuration
++     */
++    protected Configuration prepareConfiguration() {
++        Configuration config = new Configuration(true);
++        // Nothing else to do
++        return config;
++    }
++
++    /**
++     * Gets the extra file extension to add to the filenames
++     * 
++     * @return File extension
++     */
++    protected abstract String getFileExtension();
++
++    /**
++     * Generates tuples to be output for testing
++     * 
++     * @param num
++     *            Number of tuples to generate
++     * @return Iterator of tuples
++     */
++    protected abstract Iterator<T> generateTuples(int num);
++
++    /**
++     * Counts tuples in the output file
++     * 
++     * @param f
++     *            Output file
++     * @return Tuple count
++     */
++    protected final long countTuples(File f) {
++        StreamRDFCounting counter = StreamRDFLib.count();
++        RDFDataMgr.parse(counter, f.getAbsolutePath(), this.getRdfLanguage(), null);
++        return counter.count();
++    }
++
++    /**
++     * Checks that tuples are as expected
++     * 
++     * @param f
++     *            File
++     * @param expected
++     *            Expected number of tuples
++     */
++    protected void checkTuples(File f, long expected) {
++        Assert.assertEquals(expected, this.countTuples(f));
++    }
++
++    /**
++     * Gets the RDF language of the produced output which is used to parse back
++     * in the output to validate the correct amount of output was produced
++     * 
++     * @return RDF language
++     */
++    protected abstract Lang getRdfLanguage();
++
++    /**
++     * Gets the output format to test
++     * 
++     * @return Output format
++     */
++    protected abstract OutputFormat<NullWritable, T> getOutputFormat();
++
++    /**
++     * Adds an output path to the job configuration
++     * 
++     * @param f
++     *            File
++     * @param config
++     *            Configuration
++     * @param job
++     *            Job
++     * @throws IOException
++     */
++    protected void addOutputPath(File f, Configuration config, Job job) throws IOException {
++        FileSystem fs = FileSystem.getLocal(config);
++        Path outputPath = fs.makeQualified(new Path(f.getAbsolutePath()));
++        FileOutputFormat.setOutputPath(job, outputPath);
++    }
++
++    protected File findOutputFile(File dir, JobContext context) throws FileNotFoundException, IOException {
++        Path outputPath = FileOutputFormat.getOutputPath(context);
++        RemoteIterator<LocatedFileStatus> files = outputPath.getFileSystem(context.getConfiguration()).listFiles(
++                outputPath, true);
++        while (files.hasNext()) {
++            LocatedFileStatus status = files.next();
++            if (status.isFile() && !status.getPath().getName().startsWith("_")) {
++                return new File(status.getPath().toUri());
++            }
++        }
++        return null;
++    }
++
++    /**
++     * Tests output
++     * 
++     * @param f
++     *            File to output to
++     * @param num
++     *            Number of tuples to output
++     * @throws IOException
++     * @throws InterruptedException
++     */
++    protected final void testOutput(File f, int num) throws IOException, InterruptedException {
++        // Prepare configuration
++        Configuration config = this.prepareConfiguration();
++
++        // Set up fake job
++        OutputFormat<NullWritable, T> outputFormat = this.getOutputFormat();
++        Job job = Job.getInstance(config);
++        job.setOutputFormatClass(outputFormat.getClass());
++        this.addOutputPath(f, job.getConfiguration(), job);
++        JobContext context = new JobContextImpl(job.getConfiguration(), job.getJobID());
++        Assert.assertNotNull(FileOutputFormat.getOutputPath(context));
++
++        // Output the data
++        TaskAttemptID id = new TaskAttemptID("outputTest", 1, TaskType.MAP, 1, 1);
++        TaskAttemptContext taskContext = new TaskAttemptContextImpl(job.getConfiguration(), id);
++        RecordWriter<NullWritable, T> writer = outputFormat.getRecordWriter(taskContext);
++        Iterator<T> tuples = this.generateTuples(num);
++        while (tuples.hasNext()) {
++            writer.write(NullWritable.get(), tuples.next());
++        }
++        writer.close(taskContext);
++
++        // Check output
++        File outputFile = this.findOutputFile(this.folder.getRoot(), context);
++        Assert.assertNotNull(outputFile);
++        this.checkTuples(outputFile, num);
++    }
++
++    /**
++     * Basic output tests
++     * 
++     * @throws IOException
++     * @throws InterruptedException
++     */
++    @Test
++    public void output_01() throws IOException, InterruptedException {
++        this.testOutput(this.folder.getRoot(), EMPTY_SIZE);
++    }
++
++    /**
++     * Basic output tests
++     * 
++     * @throws IOException
++     * @throws InterruptedException
++     */
++    @Test
++    public void output_02() throws IOException, InterruptedException {
++        this.testOutput(this.folder.getRoot(), SMALL_SIZE);
++    }
++
++    /**
++     * Basic output tests
++     * 
++     * @throws IOException
++     * @throws InterruptedException
++     */
++    @Test
++    public void output_03() throws IOException, InterruptedException {
++        this.testOutput(this.folder.getRoot(), LARGE_SIZE);
++    }
++
++    /**
++     * Basic output tests
++     * 
++     * @throws IOException
++     * @throws InterruptedException
++     */
++    @Test
++    public void output_04() throws IOException, InterruptedException {
++        this.testOutput(this.folder.getRoot(), VERY_LARGE_SIZE);
++    }
++}

http://git-wip-us.apache.org/repos/asf/jena/blob/4b5cd267/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/output/AbstractQuadOutputFormatTests.java
----------------------------------------------------------------------
diff --cc jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/output/AbstractQuadOutputFormatTests.java
index 127f4f9,127f4f9..c59b3ca
--- a/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/output/AbstractQuadOutputFormatTests.java
+++ b/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/output/AbstractQuadOutputFormatTests.java
@@@ -1,31 -1,31 +1,31 @@@
--/*
-- * 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.
-- */
--
++/*
++ * 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.jena.hadoop.rdf.io.output;
  
  import java.util.ArrayList;
  import java.util.Iterator;
  import java.util.List;
--
--import org.apache.jena.datatypes.xsd.XSDDatatype ;
--import org.apache.jena.graph.NodeFactory ;
--import org.apache.jena.hadoop.rdf.types.QuadWritable;
--import org.apache.jena.sparql.core.Quad ;
++
++import org.apache.jena.datatypes.xsd.XSDDatatype ;
++import org.apache.jena.graph.NodeFactory ;
++import org.apache.jena.hadoop.rdf.types.QuadWritable;
++import org.apache.jena.sparql.core.Quad ;
  
  /**
   * Abstract tests for quad output formats

http://git-wip-us.apache.org/repos/asf/jena/blob/4b5cd267/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/output/AbstractTripleOutputFormatTests.java
----------------------------------------------------------------------
diff --cc jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/output/AbstractTripleOutputFormatTests.java
index 86ba4f8,86ba4f8..4353b50
--- a/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/output/AbstractTripleOutputFormatTests.java
+++ b/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/output/AbstractTripleOutputFormatTests.java
@@@ -1,31 -1,31 +1,31 @@@
--/*
-- * 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.
-- */
--
++/*
++ * 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.jena.hadoop.rdf.io.output;
  
  import java.util.ArrayList;
  import java.util.Iterator;
  import java.util.List;
--
--import org.apache.jena.datatypes.xsd.XSDDatatype ;
--import org.apache.jena.graph.NodeFactory ;
--import org.apache.jena.graph.Triple ;
--import org.apache.jena.hadoop.rdf.types.TripleWritable;
++
++import org.apache.jena.datatypes.xsd.XSDDatatype ;
++import org.apache.jena.graph.NodeFactory ;
++import org.apache.jena.graph.Triple ;
++import org.apache.jena.hadoop.rdf.types.TripleWritable;
  
  /**
   * Abstract tests for triple output formats

http://git-wip-us.apache.org/repos/asf/jena/blob/4b5cd267/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/output/jsonld/JsonLdQuadOutputTest.java
----------------------------------------------------------------------
diff --cc jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/output/jsonld/JsonLdQuadOutputTest.java
index c6784a5,c6784a5..9063725
--- a/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/output/jsonld/JsonLdQuadOutputTest.java
+++ b/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/output/jsonld/JsonLdQuadOutputTest.java
@@@ -1,47 -1,47 +1,47 @@@
--/*
-- * 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.jena.hadoop.rdf.io.output.jsonld;
--
--import org.apache.hadoop.io.NullWritable;
--import org.apache.hadoop.mapreduce.OutputFormat;
--import org.apache.jena.hadoop.rdf.io.output.AbstractQuadOutputFormatTests;
--import org.apache.jena.hadoop.rdf.types.QuadWritable;
--import org.apache.jena.riot.Lang;
--
--/**
-- * Tests for JSON-LD output format
-- */
--public class JsonLdQuadOutputTest extends AbstractQuadOutputFormatTests {
--
--    @Override
--    protected String getFileExtension() {
--        return ".jsonld";
--    }
--
--    @Override
--    protected Lang getRdfLanguage() {
--        return Lang.JSONLD;
--    }
--
--    @Override
--    protected OutputFormat<NullWritable, QuadWritable> getOutputFormat() {
--        return new JsonLDQuadOutputFormat<NullWritable>();
--    }
--
--}
++/*
++ * 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.jena.hadoop.rdf.io.output.jsonld;
++
++import org.apache.hadoop.io.NullWritable;
++import org.apache.hadoop.mapreduce.OutputFormat;
++import org.apache.jena.hadoop.rdf.io.output.AbstractQuadOutputFormatTests;
++import org.apache.jena.hadoop.rdf.types.QuadWritable;
++import org.apache.jena.riot.Lang;
++
++/**
++ * Tests for JSON-LD output format
++ */
++public class JsonLdQuadOutputTest extends AbstractQuadOutputFormatTests {
++
++    @Override
++    protected String getFileExtension() {
++        return ".jsonld";
++    }
++
++    @Override
++    protected Lang getRdfLanguage() {
++        return Lang.JSONLD;
++    }
++
++    @Override
++    protected OutputFormat<NullWritable, QuadWritable> getOutputFormat() {
++        return new JsonLDQuadOutputFormat<NullWritable>();
++    }
++
++}

http://git-wip-us.apache.org/repos/asf/jena/blob/4b5cd267/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/output/jsonld/JsonLdTripleOutputTest.java
----------------------------------------------------------------------
diff --cc jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/output/jsonld/JsonLdTripleOutputTest.java
index d157409,d157409..588b353
--- a/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/output/jsonld/JsonLdTripleOutputTest.java
+++ b/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/output/jsonld/JsonLdTripleOutputTest.java
@@@ -1,47 -1,47 +1,47 @@@
--/*
-- * 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.jena.hadoop.rdf.io.output.jsonld;
--
--import org.apache.hadoop.io.NullWritable;
--import org.apache.hadoop.mapreduce.OutputFormat;
--import org.apache.jena.hadoop.rdf.io.output.AbstractTripleOutputFormatTests;
--import org.apache.jena.hadoop.rdf.types.TripleWritable;
--import org.apache.jena.riot.Lang;
--
--/**
-- * Tests for JSON-LD output format
-- */
--public class JsonLdTripleOutputTest extends AbstractTripleOutputFormatTests {
--
--    @Override
--    protected String getFileExtension() {
--        return ".jsonld";
--    }
--
--    @Override
--    protected Lang getRdfLanguage() {
--        return Lang.JSONLD;
--    }
--
--    @Override
--    protected OutputFormat<NullWritable, TripleWritable> getOutputFormat() {
--        return new JsonLDTripleOutputFormat<NullWritable>();
--    }
--
--}
++/*
++ * 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.jena.hadoop.rdf.io.output.jsonld;
++
++import org.apache.hadoop.io.NullWritable;
++import org.apache.hadoop.mapreduce.OutputFormat;
++import org.apache.jena.hadoop.rdf.io.output.AbstractTripleOutputFormatTests;
++import org.apache.jena.hadoop.rdf.types.TripleWritable;
++import org.apache.jena.riot.Lang;
++
++/**
++ * Tests for JSON-LD output format
++ */
++public class JsonLdTripleOutputTest extends AbstractTripleOutputFormatTests {
++
++    @Override
++    protected String getFileExtension() {
++        return ".jsonld";
++    }
++
++    @Override
++    protected Lang getRdfLanguage() {
++        return Lang.JSONLD;
++    }
++
++    @Override
++    protected OutputFormat<NullWritable, TripleWritable> getOutputFormat() {
++        return new JsonLDTripleOutputFormat<NullWritable>();
++    }
++
++}

http://git-wip-us.apache.org/repos/asf/jena/blob/4b5cd267/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/output/nquads/NQuadsOutputTest.java
----------------------------------------------------------------------
diff --cc jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/output/nquads/NQuadsOutputTest.java
index 1a7ffa4,1a7ffa4..e647c2c
--- a/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/output/nquads/NQuadsOutputTest.java
+++ b/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/output/nquads/NQuadsOutputTest.java
@@@ -1,27 -1,27 +1,27 @@@
--/*
-- * 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.
-- */
--
++/*
++ * 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.jena.hadoop.rdf.io.output.nquads;
  
  import org.apache.hadoop.io.NullWritable;
  import org.apache.hadoop.mapreduce.OutputFormat;
--import org.apache.jena.hadoop.rdf.io.output.AbstractQuadOutputFormatTests;
--import org.apache.jena.hadoop.rdf.types.QuadWritable;
++import org.apache.jena.hadoop.rdf.io.output.AbstractQuadOutputFormatTests;
++import org.apache.jena.hadoop.rdf.types.QuadWritable;
  import org.apache.jena.riot.Lang;
  
  

http://git-wip-us.apache.org/repos/asf/jena/blob/4b5cd267/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/output/ntriples/NTriplesOutputTest.java
----------------------------------------------------------------------
diff --cc jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/output/ntriples/NTriplesOutputTest.java
index ad9be56,ad9be56..fef78b4
--- a/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/output/ntriples/NTriplesOutputTest.java
+++ b/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/output/ntriples/NTriplesOutputTest.java
@@@ -1,27 -1,27 +1,27 @@@
--/*
-- * 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.
-- */
--
++/*
++ * 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.jena.hadoop.rdf.io.output.ntriples;
  
  import org.apache.hadoop.io.NullWritable;
  import org.apache.hadoop.mapreduce.OutputFormat;
--import org.apache.jena.hadoop.rdf.io.output.AbstractTripleOutputFormatTests;
--import org.apache.jena.hadoop.rdf.types.TripleWritable;
++import org.apache.jena.hadoop.rdf.io.output.AbstractTripleOutputFormatTests;
++import org.apache.jena.hadoop.rdf.types.TripleWritable;
  import org.apache.jena.riot.Lang;
  
  

http://git-wip-us.apache.org/repos/asf/jena/blob/4b5cd267/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/output/rdfjson/RdfJsonOutputTest.java
----------------------------------------------------------------------
diff --cc jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/output/rdfjson/RdfJsonOutputTest.java
index 833f89b,833f89b..dcfe236
--- a/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/output/rdfjson/RdfJsonOutputTest.java
+++ b/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/output/rdfjson/RdfJsonOutputTest.java
@@@ -1,27 -1,27 +1,27 @@@
--/*
-- * 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.
-- */
--
++/*
++ * 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.jena.hadoop.rdf.io.output.rdfjson;
  
  import org.apache.hadoop.io.NullWritable;
  import org.apache.hadoop.mapreduce.OutputFormat;
--import org.apache.jena.hadoop.rdf.io.output.AbstractTripleOutputFormatTests;
--import org.apache.jena.hadoop.rdf.types.TripleWritable;
++import org.apache.jena.hadoop.rdf.io.output.AbstractTripleOutputFormatTests;
++import org.apache.jena.hadoop.rdf.types.TripleWritable;
  import org.apache.jena.riot.Lang;
  
  

http://git-wip-us.apache.org/repos/asf/jena/blob/4b5cd267/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/output/rdfxml/RdfXmlOutputTest.java
----------------------------------------------------------------------
diff --cc jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/output/rdfxml/RdfXmlOutputTest.java
index 40bc937,40bc937..55df69a
--- a/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/output/rdfxml/RdfXmlOutputTest.java
+++ b/jena-elephas/jena-elephas-io/src/test/java/org/apache/jena/hadoop/rdf/io/output/rdfxml/RdfXmlOutputTest.java
@@@ -1,27 -1,27 +1,27 @@@
--/*
-- * 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.
-- */
--
++/*
++ * 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.jena.hadoop.rdf.io.output.rdfxml;
  
  import org.apache.hadoop.io.NullWritable;
  import org.apache.hadoop.mapreduce.OutputFormat;
--import org.apache.jena.hadoop.rdf.io.output.AbstractTripleOutputFormatTests;
--import org.apache.jena.hadoop.rdf.types.TripleWritable;
++import org.apache.jena.hadoop.rdf.io.output.AbstractTripleOutputFormatTests;
++import org.apache.jena.hadoop.rdf.types.TripleWritable;
  import org.apache.jena.riot.Lang;