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 2011/10/30 14:13:01 UTC

svn commit: r1195156 - in /incubator/jena/Scratch/AFS/Jena-Dev/trunk: ./ src/dev/ src/reports/ src/reports/archive/

Author: andy
Date: Sun Oct 30 13:13:00 2011
New Revision: 1195156

URL: http://svn.apache.org/viewvc?rev=1195156&view=rev
Log: (empty)

Added:
    incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/ReportParsingDurations.java   (with props)
    incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/archive/ReportAnyURI.java   (with props)
    incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/archive/ReportDBPedia2.java
      - copied, changed from r1190423, incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/ReportDBPedia2.java
    incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/archive/ReportPathCycles.java
      - copied, changed from r1190423, incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/ReportPathCycles.java
    incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/archive/ReportReifierRemove.java
      - copied, changed from r1190423, incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/ReportReifierRemove.java
    incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/archive/ReportRemoteVirtuoso.java
      - copied, changed from r1190423, incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/ReportRemoteVirtuoso.java
Removed:
    incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/ReportDBPedia2.java
    incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/ReportDatasetGraphAddNPE.java
    incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/ReportFilterEquality.java
    incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/ReportOracle1.java
    incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/ReportPathCycles.java
    incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/ReportRIOT_UTF8.java
    incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/ReportReifierRemove.java
    incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/ReportRemoteUTF8.java
    incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/ReportRemoteVirtuoso.java
    incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/archive/ReportAddingFilter.java
    incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/archive/ReportCopySubstituteNoContext.java
    incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/archive/ReportEventUpdate.java
    incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/archive/ReportUnclosedIterator.java
    incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/archive/ReportUpdate1.java
Modified:
    incubator/jena/Scratch/AFS/Jena-Dev/trunk/U.ru
    incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/dev/ReportJena142.java
    incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/dev/Run.java
    incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/dev/RunARQ.java

Modified: incubator/jena/Scratch/AFS/Jena-Dev/trunk/U.ru
URL: http://svn.apache.org/viewvc/incubator/jena/Scratch/AFS/Jena-Dev/trunk/U.ru?rev=1195156&r1=1195155&r2=1195156&view=diff
==============================================================================
--- incubator/jena/Scratch/AFS/Jena-Dev/trunk/U.ru (original)
+++ incubator/jena/Scratch/AFS/Jena-Dev/trunk/U.ru Sun Oct 30 13:13:00 2011
@@ -1,2 +1 @@
-INSERT DATA { <s> <p> <o> . } ;
-CLEAR ALL ;
+LOAD <D.nq>

Modified: incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/dev/ReportJena142.java
URL: http://svn.apache.org/viewvc/incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/dev/ReportJena142.java?rev=1195156&r1=1195155&r2=1195156&view=diff
==============================================================================
--- incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/dev/ReportJena142.java (original)
+++ incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/dev/ReportJena142.java Sun Oct 30 13:13:00 2011
@@ -32,9 +32,9 @@ public class ReportJena142
     
     public static void main(String[] argv) throws Exception
     {
-        //JENA-142
-        String x = "SELECT * WHERE { { ?s ?p ?o} UNION { BIND('default' AS ?s) } }" ;
-        //String x = "SELECT * WHERE { { ?s ?p ?o}  { BIND('default' AS ?s) } }" ;
+        //JENA-142 : Scoping
+        //String x = "SELECT * WHERE { { ?s ?p ?o} UNION { BIND('default' AS ?s) } }" ;
+        String x = "SELECT * WHERE { { ?s ?p ?o}  { BIND('default' AS ?s) } }" ;
         arq.qparse.main(x) ;
         System.out.println("DONE") ;
         System.exit(0) ;

Modified: incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/dev/Run.java
URL: http://svn.apache.org/viewvc/incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/dev/Run.java?rev=1195156&r1=1195155&r2=1195156&view=diff
==============================================================================
--- incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/dev/Run.java (original)
+++ incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/dev/Run.java Sun Oct 30 13:13:00 2011
@@ -26,6 +26,8 @@ import org.openjena.atlas.lib.FileOps ;
 import org.openjena.atlas.lib.Lib ;
 import org.openjena.atlas.logging.Log ;
 
+import arq.update ;
+
 import com.hp.hpl.jena.query.Dataset ;
 import com.hp.hpl.jena.query.Query ;
 import com.hp.hpl.jena.query.QueryCancelledException ;
@@ -51,14 +53,8 @@ public class Run
     
     public static void main(String[] argv) throws Exception
     {
-        // JENA-102 : tdbstats handling.
-        if ( false ) jena102() ;
-       
-        // JENA-142 : Var scoping and 
-        if ( false ) jena142() ;
-
-        // JENA-143
-        jena143() ;
+        //UpdateEngineWorker L167
+        update.main("--file=U.ru") ;
     }
     
     private static void jena143() throws Exception

Modified: incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/dev/RunARQ.java
URL: http://svn.apache.org/viewvc/incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/dev/RunARQ.java?rev=1195156&r1=1195155&r2=1195156&view=diff
==============================================================================
--- incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/dev/RunARQ.java (original)
+++ incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/dev/RunARQ.java Sun Oct 30 13:13:00 2011
@@ -18,82 +18,64 @@
 
 package dev;
 
-import java.io.FileInputStream ;
-import java.io.InputStream ;
-import java.util.Iterator ;
-import java.util.NoSuchElementException ;
-import java.util.concurrent.ArrayBlockingQueue ;
-import java.util.concurrent.BlockingQueue ;
-import java.util.concurrent.ExecutorService ;
-import java.util.concurrent.Executors ;
-
-import org.openjena.atlas.io.IndentedWriter ;
-import org.openjena.atlas.json.JSON ;
-import org.openjena.atlas.json.JsonValue ;
-import org.openjena.atlas.lib.Lib ;
-import org.openjena.atlas.lib.Sink ;
-import org.openjena.atlas.lib.StrUtils ;
-import org.openjena.atlas.logging.Log ;
-import org.openjena.riot.ErrorHandlerFactory ;
-import org.openjena.riot.RiotReader ;
-import org.openjena.riot.checker.CheckerIRI ;
-import org.openjena.riot.pipeline.normalize.CanonicalizeLiteral ;
-import org.openjena.riot.tokens.Token ;
-import org.openjena.riot.tokens.Tokenizer ;
-import org.openjena.riot.tokens.TokenizerFactory ;
-
-import com.hp.hpl.jena.datatypes.xsd.XSDDatatype ;
-import com.hp.hpl.jena.datatypes.xsd.XSDDuration ;
-import com.hp.hpl.jena.graph.Node ;
-import com.hp.hpl.jena.graph.Triple ;
-import com.hp.hpl.jena.iri.IRI ;
-import com.hp.hpl.jena.iri.IRIFactory ;
-import com.hp.hpl.jena.iri.Violation ;
-import com.hp.hpl.jena.query.ARQ ;
-import com.hp.hpl.jena.query.Dataset ;
-import com.hp.hpl.jena.query.Query ;
-import com.hp.hpl.jena.query.QueryCancelledException ;
-import com.hp.hpl.jena.query.QueryExecution ;
-import com.hp.hpl.jena.query.QueryExecutionFactory ;
-import com.hp.hpl.jena.query.QueryFactory ;
-import com.hp.hpl.jena.query.QuerySolutionMap ;
-import com.hp.hpl.jena.query.ResultSet ;
-import com.hp.hpl.jena.query.ResultSetFormatter ;
-import com.hp.hpl.jena.rdf.model.Model ;
-import com.hp.hpl.jena.rdf.model.ModelFactory ;
-import com.hp.hpl.jena.shared.PrefixMapping ;
-import com.hp.hpl.jena.sparql.ARQConstants ;
-import com.hp.hpl.jena.sparql.ARQException ;
-import com.hp.hpl.jena.sparql.algebra.Algebra ;
-import com.hp.hpl.jena.sparql.algebra.Op ;
-import com.hp.hpl.jena.sparql.core.DatasetGraph ;
-import com.hp.hpl.jena.sparql.core.DatasetGraphFactory ;
-import com.hp.hpl.jena.sparql.core.assembler.AssemblerUtils ;
-import com.hp.hpl.jena.sparql.core.assembler.DatasetAssemblerVocab ;
-import com.hp.hpl.jena.sparql.engine.ExecutionContext ;
-import com.hp.hpl.jena.sparql.engine.QueryExecutionBase ;
-import com.hp.hpl.jena.sparql.engine.binding.BindingInputStream ;
-import com.hp.hpl.jena.sparql.engine.binding.BindingOutputStream ;
-import com.hp.hpl.jena.sparql.expr.Expr ;
-import com.hp.hpl.jena.sparql.expr.ExprEvalException ;
-import com.hp.hpl.jena.sparql.expr.NodeValue ;
-import com.hp.hpl.jena.sparql.function.FunctionBase1 ;
-import com.hp.hpl.jena.sparql.function.FunctionEnv ;
-import com.hp.hpl.jena.sparql.function.FunctionEnvBase ;
-import com.hp.hpl.jena.sparql.function.FunctionRegistry ;
-import com.hp.hpl.jena.sparql.graph.NodeTransform ;
-import com.hp.hpl.jena.sparql.sse.SSE ;
-import com.hp.hpl.jena.sparql.util.ExprUtils ;
-import com.hp.hpl.jena.sparql.util.FmtUtils ;
-import com.hp.hpl.jena.sparql.util.NodeFactory ;
-import com.hp.hpl.jena.sparql.util.QueryExecUtils ;
-import com.hp.hpl.jena.sparql.util.Timer ;
-import com.hp.hpl.jena.update.GraphStore ;
-import com.hp.hpl.jena.update.GraphStoreFactory ;
-import com.hp.hpl.jena.update.UpdateAction ;
-import com.hp.hpl.jena.update.UpdateFactory ;
-import com.hp.hpl.jena.update.UpdateRequest ;
-import com.hp.hpl.jena.util.FileManager ;
+import java.io.FileInputStream ;
+import java.io.InputStream ;
+import java.util.Iterator ;
+import java.util.NoSuchElementException ;
+import java.util.concurrent.ArrayBlockingQueue ;
+import java.util.concurrent.BlockingQueue ;
+import java.util.concurrent.ExecutorService ;
+import java.util.concurrent.Executors ;
+
+import org.openjena.atlas.io.IndentedWriter ;
+import org.openjena.atlas.json.JSON ;
+import org.openjena.atlas.json.JsonValue ;
+import org.openjena.atlas.lib.Lib ;
+import org.openjena.atlas.lib.Sink ;
+import org.openjena.atlas.lib.StrUtils ;
+import org.openjena.atlas.logging.Log ;
+import org.openjena.riot.ErrorHandlerFactory ;
+import org.openjena.riot.RiotReader ;
+import org.openjena.riot.checker.CheckerIRI ;
+import org.openjena.riot.pipeline.normalize.CanonicalizeLiteral ;
+import org.openjena.riot.tokens.Token ;
+import org.openjena.riot.tokens.Tokenizer ;
+import org.openjena.riot.tokens.TokenizerFactory ;
+
+import com.hp.hpl.jena.datatypes.xsd.XSDDatatype ;
+import com.hp.hpl.jena.graph.Node ;
+import com.hp.hpl.jena.graph.Triple ;
+import com.hp.hpl.jena.iri.IRI ;
+import com.hp.hpl.jena.iri.IRIFactory ;
+import com.hp.hpl.jena.iri.Violation ;
+import com.hp.hpl.jena.query.* ;
+import com.hp.hpl.jena.rdf.model.Model ;
+import com.hp.hpl.jena.rdf.model.ModelFactory ;
+import com.hp.hpl.jena.shared.PrefixMapping ;
+import com.hp.hpl.jena.sparql.ARQConstants ;
+import com.hp.hpl.jena.sparql.ARQException ;
+import com.hp.hpl.jena.sparql.algebra.Algebra ;
+import com.hp.hpl.jena.sparql.algebra.Op ;
+import com.hp.hpl.jena.sparql.core.DatasetGraph ;
+import com.hp.hpl.jena.sparql.core.DatasetGraphFactory ;
+import com.hp.hpl.jena.sparql.core.assembler.AssemblerUtils ;
+import com.hp.hpl.jena.sparql.core.assembler.DatasetAssemblerVocab ;
+import com.hp.hpl.jena.sparql.engine.ExecutionContext ;
+import com.hp.hpl.jena.sparql.engine.QueryExecutionBase ;
+import com.hp.hpl.jena.sparql.engine.binding.BindingInputStream ;
+import com.hp.hpl.jena.sparql.engine.binding.BindingOutputStream ;
+import com.hp.hpl.jena.sparql.expr.Expr ;
+import com.hp.hpl.jena.sparql.expr.ExprEvalException ;
+import com.hp.hpl.jena.sparql.expr.NodeValue ;
+import com.hp.hpl.jena.sparql.function.FunctionBase1 ;
+import com.hp.hpl.jena.sparql.function.FunctionEnv ;
+import com.hp.hpl.jena.sparql.function.FunctionEnvBase ;
+import com.hp.hpl.jena.sparql.function.FunctionRegistry ;
+import com.hp.hpl.jena.sparql.graph.NodeTransform ;
+import com.hp.hpl.jena.sparql.sse.SSE ;
+import com.hp.hpl.jena.sparql.util.* ;
+import com.hp.hpl.jena.update.* ;
+import com.hp.hpl.jena.util.FileManager ;
 
 public class RunARQ
 {
@@ -108,17 +90,6 @@ public class RunARQ
     
     static { Log.setLog4j() ; }
     
-    public static void testXSDDurationBug() {
-        Node d1 = Node.createLiteral("PT110S", null, XSDDatatype.XSDduration);
-        Node d2 = Node.createLiteral("PT1M50S", null, XSDDatatype.XSDduration);
-        System.out.println(d1.getLiteral().isWellFormed());
-        System.out.println(d2.getLiteral().isWellFormed());
-        XSDDuration dur1 = (XSDDuration) d1.getLiteralValue();
-        XSDDuration dur2 = (XSDDuration) d2.getLiteralValue();
-        int cmp = dur1.compare(dur2);
-        System.out.println("Compare = " + cmp);
-    }
-
     public static void exit(int code)
     {
         System.out.flush() ;

Added: incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/ReportParsingDurations.java
URL: http://svn.apache.org/viewvc/incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/ReportParsingDurations.java?rev=1195156&view=auto
==============================================================================
--- incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/ReportParsingDurations.java (added)
+++ incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/ReportParsingDurations.java Sun Oct 30 13:13:00 2011
@@ -0,0 +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 reports;
+
+import org.junit.Test ;
+import org.openjena.atlas.junit.BaseTest ;
+
+import com.hp.hpl.jena.datatypes.xsd.XSDDatatype ;
+import com.hp.hpl.jena.datatypes.xsd.XSDDuration ;
+import com.hp.hpl.jena.graph.Node ;
+
+public class ReportParsingDurations extends BaseTest
+{
+    @Test public void testXSDDurationBug() {
+        // Two ways to write 110 seconds = 1min 50sec
+        Node d1 = Node.createLiteral("PT110S", null, XSDDatatype.XSDduration);
+        Node d2 = Node.createLiteral("PT1M50S", null, XSDDatatype.XSDduration);
+
+        assertTrue(d1.getLiteral().isWellFormed());
+        assertTrue(d2.getLiteral().isWellFormed());
+
+        XSDDuration dur1 = (XSDDuration) d1.getLiteralValue();
+        XSDDuration dur2 = (XSDDuration) d2.getLiteralValue();
+        int cmp = dur1.compare(dur2) ;
+        // cmp is -1, should be 0 
+
+        assertTrue(d1.sameValueAs(d2)) ;
+        
+    }
+}
+

Propchange: incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/ReportParsingDurations.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Added: incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/archive/ReportAnyURI.java
URL: http://svn.apache.org/viewvc/incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/archive/ReportAnyURI.java?rev=1195156&view=auto
==============================================================================
--- incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/archive/ReportAnyURI.java (added)
+++ incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/archive/ReportAnyURI.java Sun Oct 30 13:13:00 2011
@@ -0,0 +1,121 @@
+/**
+ * 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 reports.archive;
+
+import com.hp.hpl.jena.datatypes.xsd.XSDDatatype ;
+import com.hp.hpl.jena.graph.Node ;
+import com.hp.hpl.jena.graph.impl.LiteralLabel ;
+import com.hp.hpl.jena.query.QueryExecution ;
+import com.hp.hpl.jena.query.QueryExecutionFactory ;
+import com.hp.hpl.jena.query.ResultSetFormatter ;
+import com.hp.hpl.jena.rdf.model.Model ;
+import com.hp.hpl.jena.rdf.model.ModelFactory ;
+import com.hp.hpl.jena.sparql.sse.SSE ;
+
+public class ReportAnyURI
+{
+    /** A datatype that does not use the Xerces machinary for isEqual */  
+    static class XSDplainDatatype extends XSDDatatype
+    {
+        public XSDplainDatatype(String typeName)
+        {
+            super(typeName) ;
+        }
+        /**
+         * Compares two instances of values of the given datatype.
+         * This default requires value and datatype equality.
+         */
+        @Override
+        public boolean isEqual(LiteralLabel value1, LiteralLabel value2) {
+            // This is the function from BaseDatatype!
+            return value1.getDatatype() == value2.getDatatype()
+                 && value1.getValue().equals(value2.getValue());
+        }
+    }
+
+    public static void main(String[] args) {
+        // anyURI, QName, [boolean], IDREF, NOTATION, 
+        
+        Node node1 = SSE.parseNode("'http://example/'^^xsd:anyURI") ;
+        Node node2 = SSE.parseNode("'http://example/'^^xsd:string") ;
+        
+        LiteralLabel ll1 = node1.getLiteral() ;
+        LiteralLabel ll2 = node2.getLiteral() ;
+        
+        // problem : Xerces value of an XSD anyURI is a string.
+        System.out.println("XSDDatatype.XSDanyURI.isEqual("+node1+","+node2+") ==> "+XSDDatatype.XSDanyURI.isEqual(ll1, ll2)) ;
+
+        // ***** Fix - use this in XSDDatatype.
+        XSDDatatype newXSDanyURI = new XSDplainDatatype("anyURI") ; // QName, IDREF, NOTATION, 
+        
+        System.out.println(newXSDanyURI.isEqual(ll1, ll2)) ;
+        
+        Node[] nodes = { node1, node2 } ;
+        for ( Node n1 : nodes )
+            for ( Node n2 : nodes )
+            {
+                //if ( n1 == n2 ) continue ;
+                System.out.println("("+n1+","+n2+")") ;
+                System.out.println("   "+newXSDanyURI.isEqual(n1.getLiteral(), n2.getLiteral() ) ) ;
+            }
+        
+        
+        System.exit(0) ;
+        
+        String[] triples = { 
+            "(:s1 :p 'http://example/'^^xsd:anyURI)" ,
+            "(:s2 :p 'http://example/')" ,
+            "(:s3 :p 'http://example/'^^xsd:string)"
+            } ;
+
+        Model m = 
+            ModelFactory.createDefaultModel() ;     // xsd:anyURI matches string
+            //ModelFactory.createModelForGraph(GraphFactory.createGraphMem()) ;  // xsd:anyURI matches string
+            //ModelFactory.createModelForGraph(GraphFactory.createPlainGraph()) ;  // xsd:anyURI does not match string
+        
+        for ( String s : triples)
+            m.getGraph().add(SSE.parseTriple(s)) ;
+        //m.write(System.out, "TTL") ;
+        
+        String preamble = "PREFIX : <http://example/>\nPREFIX xsd:  <http://www.w3.org/2001/XMLSchema#>\n SELECT * " ;
+        String[] queries = { 
+            "{?s :p 'http://example/'^^xsd:anyURI }",
+            "{?s :p 'http://example/'^^xsd:string }",
+            "{?s :p 'http://example/' }"
+        } ;
+
+        for ( String qs : queries )
+        {
+            System.out.println(qs) ;
+            QueryExecution qExec = QueryExecutionFactory.create(preamble+qs, m) ;
+            ResultSetFormatter.out(qExec.execSelect()) ;
+            System.out.println() ;
+        }
+        
+        
+        for ( Node n1 : nodes )
+            for ( Node n2 : nodes )
+            {
+                if ( n1 == n2 ) continue ;
+                System.out.println("("+n1+","+n2+")") ;
+                System.out.println("    n1.sameValueAs(n2) => "+n1.sameValueAs(n2)) ;
+            }
+    }
+}
+

Propchange: incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/archive/ReportAnyURI.java
------------------------------------------------------------------------------
    svn:mime-type = text/plain

Copied: incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/archive/ReportDBPedia2.java (from r1190423, incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/ReportDBPedia2.java)
URL: http://svn.apache.org/viewvc/incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/archive/ReportDBPedia2.java?p2=incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/archive/ReportDBPedia2.java&p1=incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/ReportDBPedia2.java&r1=1190423&r2=1195156&rev=1195156&view=diff
==============================================================================
--- incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/ReportDBPedia2.java (original)
+++ incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/archive/ReportDBPedia2.java Sun Oct 30 13:13:00 2011
@@ -16,7 +16,7 @@
  * limitations under the License.
  */
 
-package reports;
+package reports.archive;
 
 import com.hp.hpl.jena.query.Query;
 import com.hp.hpl.jena.query.QueryExecution;

Copied: incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/archive/ReportPathCycles.java (from r1190423, incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/ReportPathCycles.java)
URL: http://svn.apache.org/viewvc/incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/archive/ReportPathCycles.java?p2=incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/archive/ReportPathCycles.java&p1=incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/ReportPathCycles.java&r1=1190423&r2=1195156&rev=1195156&view=diff
==============================================================================
--- incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/ReportPathCycles.java (original)
+++ incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/archive/ReportPathCycles.java Sun Oct 30 13:13:00 2011
@@ -16,7 +16,7 @@
  * limitations under the License.
  */
 
-package reports;
+package reports.archive;
 
 import com.hp.hpl.jena.query.Query ;
 import com.hp.hpl.jena.query.QueryExecution ;

Copied: incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/archive/ReportReifierRemove.java (from r1190423, incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/ReportReifierRemove.java)
URL: http://svn.apache.org/viewvc/incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/archive/ReportReifierRemove.java?p2=incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/archive/ReportReifierRemove.java&p1=incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/ReportReifierRemove.java&r1=1190423&r2=1195156&rev=1195156&view=diff
==============================================================================
--- incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/ReportReifierRemove.java (original)
+++ incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/archive/ReportReifierRemove.java Sun Oct 30 13:13:00 2011
@@ -16,7 +16,7 @@
  * limitations under the License.
  */
 
-package reports;
+package reports.archive;
 
 import org.junit.Test ;
 import static org.junit.Assert.* ;

Copied: incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/archive/ReportRemoteVirtuoso.java (from r1190423, incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/ReportRemoteVirtuoso.java)
URL: http://svn.apache.org/viewvc/incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/archive/ReportRemoteVirtuoso.java?p2=incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/archive/ReportRemoteVirtuoso.java&p1=incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/ReportRemoteVirtuoso.java&r1=1190423&r2=1195156&rev=1195156&view=diff
==============================================================================
--- incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/ReportRemoteVirtuoso.java (original)
+++ incubator/jena/Scratch/AFS/Jena-Dev/trunk/src/reports/archive/ReportRemoteVirtuoso.java Sun Oct 30 13:13:00 2011
@@ -16,7 +16,7 @@
  * limitations under the License.
  */
 
-package reports;
+package reports.archive;
 
 import org.openjena.atlas.logging.Log ;