You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@commonsrdf.apache.org by st...@apache.org on 2016/06/20 08:57:55 UTC

[01/50] incubator-commonsrdf git commit: COMMONSRDF-8 Update test: internalIdentifier -> uniqueReference

Repository: incubator-commonsrdf
Updated Branches:
  refs/heads/parser-with-quads defdbd916 -> ddc545e51


COMMONSRDF-8 Update test: internalIdentifier -> uniqueReference


Project: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/commit/a79ff94a
Tree: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/tree/a79ff94a
Diff: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/diff/a79ff94a

Branch: refs/heads/parser-with-quads
Commit: a79ff94a07fe03a78149c81b5a8cbffa898bc922
Parents: d0ae0ca
Author: Stian Soiland-Reyes <st...@apache.org>
Authored: Sat Mar 12 18:33:47 2016 +0000
Committer: Stian Soiland-Reyes <st...@apache.org>
Committed: Sat Mar 12 18:34:07 2016 +0000

----------------------------------------------------------------------
 .../org/apache/commons/rdf/api/AbstractRDFTermFactoryTest.java   | 4 ++--
 1 file changed, 2 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/a79ff94a/api/src/test/java/org/apache/commons/rdf/api/AbstractRDFTermFactoryTest.java
----------------------------------------------------------------------
diff --git a/api/src/test/java/org/apache/commons/rdf/api/AbstractRDFTermFactoryTest.java b/api/src/test/java/org/apache/commons/rdf/api/AbstractRDFTermFactoryTest.java
index 4f5de6b..5056c9d 100644
--- a/api/src/test/java/org/apache/commons/rdf/api/AbstractRDFTermFactoryTest.java
+++ b/api/src/test/java/org/apache/commons/rdf/api/AbstractRDFTermFactoryTest.java
@@ -126,8 +126,8 @@ public abstract class AbstractRDFTermFactoryTest {
         }
         //
         assertNotEquals(bnode1, differentFactory);
-        assertNotEquals(bnode1.internalIdentifier(),
-                differentFactory.internalIdentifier());
+        assertNotEquals(bnode1.uniqueReference(),
+                differentFactory.uniqueReference());
         // but not
         //assertNotEquals(bnode1.ntriplesString(), differentFactory.ntriplesString());
     }


[13/50] incubator-commonsrdf git commit: Updated developer list

Posted by st...@apache.org.
Updated developer list


Project: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/commit/8f059421
Tree: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/tree/8f059421
Diff: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/diff/8f059421

Branch: refs/heads/parser-with-quads
Commit: 8f059421b0d0ffaaa6b21538e3ba3a8f9376d16f
Parents: c1514e5
Author: Stian Soiland-Reyes <st...@apache.org>
Authored: Thu Apr 21 10:13:27 2016 +0100
Committer: Stian Soiland-Reyes <st...@apache.org>
Committed: Thu Apr 21 10:13:27 2016 +0100

----------------------------------------------------------------------
 pom.xml | 45 +++++++++++++++++++++++++--------------------
 1 file changed, 25 insertions(+), 20 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/8f059421/pom.xml
----------------------------------------------------------------------
diff --git a/pom.xml b/pom.xml
index 61342ee..81b24c9 100644
--- a/pom.xml
+++ b/pom.xml
@@ -104,7 +104,7 @@
             <email>lewismc[at]apache[dot]org</email>
             <roles>
                 <role>Committer</role>
-                <role>PMC Member</role>
+                <role>PPMC Member</role>
                 <role>Champion</role>
             </roles>
             <timezone>+1</timezone>
@@ -115,8 +115,8 @@
             <email>rvesse[at]apache[dot]org</email>
             <roles>
                 <role>Committer</role>
-                <role>PMC Member</role>
-                <role>Mentor</role>
+                <role>PPMC Member</role>
+                <role>Emeritus Mentor</role>
             </roles>
             <timezone>+0</timezone>
         </developer>
@@ -126,7 +126,7 @@
             <email>johndament[at]apache[dot]org</email>
             <roles>
                 <role>Committer</role>
-                <role>PMC Member</role>
+                <role>PPMC Member</role>
                 <role>Mentor</role>
             </roles>
             <timezone>+1</timezone>
@@ -137,7 +137,7 @@
             <email>ggregory[at]apache[dot]org</email>
             <roles>
                 <role>Committer</role>
-                <role>PMC Member</role>
+                <role>PPMC Member</role>
                 <role>Mentor</role>
             </roles>
             <timezone>+1</timezone>
@@ -149,7 +149,7 @@
             <url>http://www.wikier.org</url>
             <roles>
                 <role>Committer</role>
-                <role>PMC Member</role>
+                <role>PPMC Member</role>
             </roles>
             <timezone>+1</timezone>
         </developer>
@@ -159,7 +159,7 @@
             <email>andy[at]apache[dot]org</email>
             <roles>
                 <role>Committer</role>
-                <role>PMC Member</role>
+                <role>Emeritus PPPMC Member</role>
             </roles>
             <timezone>+0</timezone>
         </developer>
@@ -167,29 +167,20 @@
             <id>stain</id>
             <name>Stian Soiland-Reyes</name>
             <email>stain[at]apache[dot]org</email>
+            <url>http://orcid.org/0000-0001-9842-9718</url>
             <roles>
                 <role>Committer</role>
-                <role>PMC Member</role>
+                <role>PPMC Member</role>
             </roles>
             <timezone>+0</timezone>
         </developer>
         <developer>
-            <id>reto</id>
-            <name>Reto Gm�r</name>
-            <email>reto[at]apache[dot]org</email>
-            <roles>
-                <role>Committer</role>
-                <role>PMC Member</role>
-            </roles>
-            <timezone>+1</timezone>
-        </developer>
-        <developer>
             <id>enridaga</id>
             <name>Enrico Daga</name>
             <email>enridaga[at]apache[dot]org</email>
             <roles>
                 <role>Committer</role>
-                <role>PMC Member</role>
+                <role>PPMC Member</role>
             </roles>
             <timezone>+0</timezone>
         </developer>
@@ -199,7 +190,7 @@
             <email>britter[at]apache[dot]org</email>
             <roles>
                 <role>Committer</role>
-                <role>PMC Member</role>
+                <role>PPMC Member</role>
                 <role>Apache Commons Representative</role>
             </roles>
             <timezone>+1</timezone>
@@ -211,6 +202,20 @@
             <name>Peter Ansell</name>
             <email>ansell[at]apache[dot]org</email>
             <url>http://github.com/ansell</url>
+            <roles>
+                <role>Emeritus Committer</role>
+                <role>Emeritus PPMC Member</role>
+            </roles>
+        </contributor>
+        <contributor>
+            <id>reto</id>
+            <name>Reto Gm�r</name>
+            <email>reto[at]apache[dot]org</email>
+            <roles>
+                <role>Emeritus Committer</role>
+                <role>Emeritus PPMC Member</role>
+            </roles>
+            <timezone>+1</timezone>
         </contributor>
     </contributors>
 


[24/50] incubator-commonsrdf git commit: newer Apache Commons parent

Posted by st...@apache.org.
newer Apache Commons parent


Project: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/commit/20905e64
Tree: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/tree/20905e64
Diff: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/diff/20905e64

Branch: refs/heads/parser-with-quads
Commit: 20905e646df81e26e598fad613ccda67fd350a9d
Parents: 3bec6ed
Author: Stian Soiland-Reyes <st...@apache.org>
Authored: Mon May 2 17:47:32 2016 +0100
Committer: Stian Soiland-Reyes <st...@apache.org>
Committed: Mon May 2 17:47:32 2016 +0100

----------------------------------------------------------------------
 pom.xml | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/20905e64/pom.xml
----------------------------------------------------------------------
diff --git a/pom.xml b/pom.xml
index f1f28ba..5bf0180 100644
--- a/pom.xml
+++ b/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.commons</groupId>
         <artifactId>commons-parent</artifactId>
-        <version>39</version>
+        <version>40</version>
     </parent>
 
     <groupId>org.apache.commons</groupId>


[04/50] incubator-commonsrdf git commit: Create our own BlankNode for testing

Posted by st...@apache.org.
Create our own BlankNode for testing

The test was improved to make the g1 and g2 with its own BlankNode instances - each graph then having _:b1 and _:b2 - but with different uniqueReference().

This would also test that multiple graph.add(s,p,o) works with foreign BlankNode instances, but without taking a stance on COMMONSRDF-15 - we don't care how it does the mapping (if any) - and don't even require that they have the same uniqueReference() after adding.

Iterating g1 and g2 to add to g3 should not assume those BlankNodes are the same based on their triplesString() - but differ by their uniqueReference()


Project: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/commit/a06f6219
Tree: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/tree/a06f6219
Diff: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/diff/a06f6219

Branch: refs/heads/parser-with-quads
Commit: a06f6219a4458f5dda70cda3097b975b005db308
Parents: 6fa2b48
Author: Stian Soiland-Reyes <st...@apache.org>
Authored: Mon Apr 11 15:58:20 2016 +0100
Committer: Stian Soiland-Reyes <st...@apache.org>
Committed: Mon Apr 11 15:58:20 2016 +0100

----------------------------------------------------------------------
 .../commons/rdf/api/AbstractGraphTest.java      | 50 ++++++++++++++++++--
 1 file changed, 45 insertions(+), 5 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/a06f6219/api/src/test/java/org/apache/commons/rdf/api/AbstractGraphTest.java
----------------------------------------------------------------------
diff --git a/api/src/test/java/org/apache/commons/rdf/api/AbstractGraphTest.java b/api/src/test/java/org/apache/commons/rdf/api/AbstractGraphTest.java
index a6c4397..326e2ff 100644
--- a/api/src/test/java/org/apache/commons/rdf/api/AbstractGraphTest.java
+++ b/api/src/test/java/org/apache/commons/rdf/api/AbstractGraphTest.java
@@ -28,6 +28,8 @@ import java.util.Iterator;
 import java.util.List;
 import java.util.Map;
 import java.util.Optional;
+import java.util.Set;
+import java.util.UUID;
 import java.util.concurrent.ConcurrentHashMap;
 
 import org.junit.Assume;
@@ -362,15 +364,19 @@ public abstract class AbstractGraphTest {
         source.getTriples().unordered().sequential().forEach(t -> target.add(t));
     }
 
+    /**
+     * Make a new graph with two BlankNodes - each with a different uniqueReference
+     */
     private Graph createGraph1() {
         RDFTermFactory factory1 = createFactory();
 
         IRI name = factory1.createIRI("http://xmlns.com/foaf/0.1/name");
         Graph g1 = factory1.createGraph();
-        BlankNode b1 = factory1.createBlankNode();
+        BlankNode b1 = createOwnBlankNode("b1");
         g1.add(b1, name, factory1.createLiteral("Alice"));
-
-        BlankNode b2 = factory1.createBlankNode();
+        
+        
+        BlankNode b2 = createOwnBlankNode("b2");
         g1.add(b2, name, factory1.createLiteral("Bob"));
 
         IRI hasChild = factory1.createIRI("http://example.com/hasChild");
@@ -379,16 +385,50 @@ public abstract class AbstractGraphTest {
         return g1;
     }
 
+    /** 
+     * Create a different implementation of BlankNode to be tested with
+     * graph.add(a,b,c);
+     * (the implementation may or may not then choose to translate such to 
+     * its own instances)
+     * 
+     * @param name
+     * @return
+     */
+	private BlankNode createOwnBlankNode(String name) {
+		return new BlankNode() {			
+			@Override
+			public String ntriplesString() {
+				return "_: " + name;
+			}
+			@Override
+			public String uniqueReference() {
+				return "urn:uuid:" + UUID.randomUUID().toString();
+			}
+			@Override
+			public int hashCode() {
+				return uniqueReference().hashCode();
+			}
+			@Override
+			public boolean equals(Object obj) {
+				if (!( obj instanceof BlankNode)) {
+					return false;
+				}
+				BlankNode other = (BlankNode)obj;
+				return uniqueReference().equals(other.uniqueReference());
+			}
+		};
+	}
+
     private Graph createGraph2() {
         RDFTermFactory factory2 = createFactory();
         IRI name = factory2.createIRI("http://xmlns.com/foaf/0.1/name");
 
         Graph g2 = factory2.createGraph();
 
-        BlankNode b1 = factory2.createBlankNode();
+        BlankNode b1 = createOwnBlankNode("b1");
         g2.add(b1, name, factory2.createLiteral("Charlie"));
 
-        BlankNode b2 = factory2.createBlankNode();
+        BlankNode b2 = createOwnBlankNode("b2");
         g2.add(b2, name, factory2.createLiteral("Dave"));
 
         IRI hasChild = factory2.createIRI("http://example.com/hasChild");


[41/50] incubator-commonsrdf git commit: Added GraphLike and renamed getTriples() -> stream()

Posted by st...@apache.org.
Added GraphLike and renamed getTriples() -> stream()


Project: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/commit/b25af136
Tree: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/tree/b25af136
Diff: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/diff/b25af136

Branch: refs/heads/parser-with-quads
Commit: b25af1363bac61ad0c088f92479ff6f44b821f82
Parents: bc639bb
Author: Stian Soiland-Reyes <st...@apache.org>
Authored: Thu Jun 2 12:10:13 2016 +0100
Committer: Stian Soiland-Reyes <st...@apache.org>
Committed: Thu Jun 2 12:10:13 2016 +0100

----------------------------------------------------------------------
 .../org/apache/commons/rdf/api/Dataset.java     | 12 +--
 .../java/org/apache/commons/rdf/api/Graph.java  | 10 +-
 .../org/apache/commons/rdf/api/GraphLike.java   | 97 ++++++++++++++++++++
 .../commons/rdf/api/AbstractGraphTest.java      | 20 ++--
 .../apache/commons/rdf/simple/DatasetImpl.java  | 17 ++--
 .../apache/commons/rdf/simple/GraphImpl.java    | 12 +--
 .../commons/rdf/simple/TestWritingGraph.java    |  8 +-
 7 files changed, 137 insertions(+), 39 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/b25af136/api/src/main/java/org/apache/commons/rdf/api/Dataset.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/org/apache/commons/rdf/api/Dataset.java b/api/src/main/java/org/apache/commons/rdf/api/Dataset.java
index 706366c..c809bc9 100644
--- a/api/src/main/java/org/apache/commons/rdf/api/Dataset.java
+++ b/api/src/main/java/org/apache/commons/rdf/api/Dataset.java
@@ -28,7 +28,7 @@ import java.util.stream.Stream;
  * <a href="http://www.w3.org/TR/rdf11-concepts/" >RDF-1.1 Concepts and Abstract
  * Syntax</a>, a W3C Recommendation published on 25 February 2014.
  */
-public interface Dataset extends AutoCloseable {
+public interface Dataset extends AutoCloseable, GraphLike<Quad, BlankNodeOrIRI, IRI, RDFTerm> {
 
 	/**
 	 * Add a quad to the dataset, possibly mapping any of the components of the
@@ -144,7 +144,7 @@ public interface Dataset extends AutoCloseable {
 	 * Get the graph names in this Dataset.
 	 * <p>
 	 * The set of returned graph names is equivalent to the set of unique
-	 * {@link Quad#getGraphName()} of all the {@link #getQuads()} of this
+	 * {@link Quad#getGraphName()} of all the {@link #stream()} of this
 	 * dataset (excluding the default graph).
 	 * <p>
 	 * The returned {@link Stream} SHOULD NOT contain duplicate graph names.
@@ -217,7 +217,7 @@ public interface Dataset extends AutoCloseable {
 	 *
 	 * @return A {@link Stream} over all of the quads in the dataset
 	 */
-	Stream<? extends Quad> getQuads();
+	Stream<? extends Quad> stream();
 
 	/**
 	 * Get all quads contained by the dataset matched with the pattern.
@@ -244,7 +244,7 @@ public interface Dataset extends AutoCloseable {
 	 *            The quad object (<code>null</code> is a wildcard)
 	 * @return A {@link Stream} over the matched quads.
 	 */
-	Stream<? extends Quad> getQuads(Optional<BlankNodeOrIRI> graphName, BlankNodeOrIRI subject, IRI predicate,
+	Stream<? extends Quad> stream(Optional<BlankNodeOrIRI> graphName, BlankNodeOrIRI subject, IRI predicate,
 			RDFTerm object);
 
 	/**
@@ -281,7 +281,7 @@ public interface Dataset extends AutoCloseable {
 	 */
 	@SuppressWarnings("unchecked")
 	default Iterable<Quad> iterate() throws ConcurrentModificationException, IllegalStateException {
-		return ((Stream<Quad>) getQuads())::iterator;
+		return ((Stream<Quad>) stream())::iterator;
 	}
 
 	/**
@@ -333,6 +333,6 @@ public interface Dataset extends AutoCloseable {
 	@SuppressWarnings("unchecked")
 	default Iterable<Quad> iterate(Optional<BlankNodeOrIRI> graphName, BlankNodeOrIRI subject, IRI predicate,
 			RDFTerm object) throws ConcurrentModificationException, IllegalStateException {
-		return ((Stream<Quad>) getQuads(graphName, subject, predicate, object))::iterator;
+		return ((Stream<Quad>) stream(graphName, subject, predicate, object))::iterator;
 	}
 }

http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/b25af136/api/src/main/java/org/apache/commons/rdf/api/Graph.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/org/apache/commons/rdf/api/Graph.java b/api/src/main/java/org/apache/commons/rdf/api/Graph.java
index c421226..42ced98 100644
--- a/api/src/main/java/org/apache/commons/rdf/api/Graph.java
+++ b/api/src/main/java/org/apache/commons/rdf/api/Graph.java
@@ -27,7 +27,7 @@ import java.util.stream.Stream;
  * href="http://www.w3.org/TR/rdf11-concepts/" >RDF-1.1 Concepts and Abstract
  * Syntax</a>, a W3C Recommendation published on 25 February 2014.
  */
-public interface Graph extends AutoCloseable {
+public interface Graph extends AutoCloseable,GraphLike<Triple, BlankNodeOrIRI, IRI, RDFTerm> {
 
     /**
      * Add a triple to the graph, possibly mapping any of the components of the
@@ -128,7 +128,7 @@ public interface Graph extends AutoCloseable {
      *
      * @return A {@link Stream} over all of the triples in the graph
      */
-    Stream<? extends Triple> getTriples();
+    Stream<? extends Triple> stream();
 
     /**
      * Get all triples contained by the graph matched with the pattern.
@@ -148,7 +148,7 @@ public interface Graph extends AutoCloseable {
      * @param object    The triple object (null is a wildcard)
      * @return A {@link Stream} over the matched triples.
      */
-    Stream<? extends Triple> getTriples(BlankNodeOrIRI subject, IRI predicate,
+    Stream<? extends Triple> stream(BlankNodeOrIRI subject, IRI predicate,
                                         RDFTerm object);
 
     /**
@@ -184,7 +184,7 @@ public interface Graph extends AutoCloseable {
     @SuppressWarnings("unchecked")
     default Iterable<Triple> iterate()
             throws ConcurrentModificationException, IllegalStateException {
-        return ((Stream<Triple>)getTriples())::iterator;
+        return ((Stream<Triple>)stream())::iterator;
     }
 
     /**
@@ -231,6 +231,6 @@ public interface Graph extends AutoCloseable {
     default Iterable<Triple> iterate(
             BlankNodeOrIRI subject, IRI predicate, RDFTerm object)
         throws ConcurrentModificationException, IllegalStateException {
-        return ((Stream<Triple>) getTriples(subject, predicate, object))::iterator;
+        return ((Stream<Triple>) stream(subject, predicate, object))::iterator;
     }
 }

http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/b25af136/api/src/main/java/org/apache/commons/rdf/api/GraphLike.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/org/apache/commons/rdf/api/GraphLike.java b/api/src/main/java/org/apache/commons/rdf/api/GraphLike.java
new file mode 100644
index 0000000..57b55cb
--- /dev/null
+++ b/api/src/main/java/org/apache/commons/rdf/api/GraphLike.java
@@ -0,0 +1,97 @@
+/**
+ * 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.commons.rdf.api;
+
+import java.util.ConcurrentModificationException;
+import java.util.stream.Stream;
+
+/**
+ * A "graph-like" interface that contains {@link TripleLike} statements.
+ * <p>
+ * Extended by {@link Graph} (for {@link Triple}) and {@link Dataset} (for
+ * {@link Quad}).
+ * <p>
+ * Unlike {@link Graph} and {@link Dataset}, this interface can support
+ * with generalised {@link TripleLike} or {@link QuadLike} statements, and
+ * does not include semantics like {@link #size()} or the requirement of
+ * mapping {@link RDFTerm} instances from different implementations.
+ * 
+ * @see Graph
+ * @see Dataset
+ * @see TripleLike
+ */
+public interface GraphLike<T extends TripleLike<S, P, O>, S extends RDFTerm, P extends RDFTerm, O extends RDFTerm> {
+
+	/**
+	 * Add a statement.
+	 * 
+	 * @param statement
+	 *            The TripleLike statement to add
+	 */
+	void add(T statement);
+
+	/**
+	 * Check if statement is contained.
+	 * 
+	 * @param statement
+	 *            The {@link TripleLike} statement to chec
+	 * @return True if the statement is contained
+	 */
+	boolean contains(T statement);
+
+	/**
+	 * Add a statement.
+	 * 
+	 * @param statement
+	 *            The TripleLike statement to add
+	 */
+	void remove(T statement);
+
+	/**
+	 * Remove all statements.
+	 */
+	void clear();
+
+	/**
+	 * Number of statements.
+	 * 
+	 * @return
+	 */
+	long size();
+
+	/**
+	 * Return a Stream of contained statements.
+	 * 
+	 * @return A {@link Stream} of {@link TripleLike} statements.
+	 */
+	Stream<? extends T> stream();
+
+	/**
+	 * Iterate over contained statements.
+	 *  
+	 * @return An {@link Iterable} of {@link TripleLike} statements.
+	 * 
+     * @throws IllegalStateException
+     *             if the {@link Iterable} has been reused
+     * @throws ConcurrentModificationException
+     *             if a concurrency conflict occurs while the Iterator is
+     *             active.
+	 */
+	Iterable<T> iterate() throws ConcurrentModificationException, IllegalStateException;
+
+}

http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/b25af136/api/src/test/java/org/apache/commons/rdf/api/AbstractGraphTest.java
----------------------------------------------------------------------
diff --git a/api/src/test/java/org/apache/commons/rdf/api/AbstractGraphTest.java b/api/src/test/java/org/apache/commons/rdf/api/AbstractGraphTest.java
index 9029cc4..15773df 100644
--- a/api/src/test/java/org/apache/commons/rdf/api/AbstractGraphTest.java
+++ b/api/src/test/java/org/apache/commons/rdf/api/AbstractGraphTest.java
@@ -177,7 +177,7 @@ public abstract class AbstractGraphTest {
 
         assertTrue(graph.contains(alice, knows, bob));
 
-        Optional<? extends Triple> first = graph.getTriples().skip(4)
+        Optional<? extends Triple> first = graph.stream().skip(4)
                 .findFirst();
         Assume.assumeTrue(first.isPresent());
         Triple existingTriple = first.get();
@@ -218,7 +218,7 @@ public abstract class AbstractGraphTest {
         graph.remove(alice, knows, bob);
         assertEquals(shrunkSize, graph.size());
 
-        Optional<? extends Triple> anyTriple = graph.getTriples().findAny();
+        Optional<? extends Triple> anyTriple = graph.stream().findAny();
         Assume.assumeTrue(anyTriple.isPresent());
 
         Triple otherTriple = anyTriple.get();
@@ -242,9 +242,9 @@ public abstract class AbstractGraphTest {
     @Test
     public void getTriples() throws Exception {
 
-        long tripleCount = graph.getTriples().count();
+        long tripleCount = graph.stream().count();
         assertTrue(tripleCount > 0);
-        assertTrue(graph.getTriples().allMatch(t -> graph.contains(t)));
+        assertTrue(graph.stream().allMatch(t -> graph.contains(t)));
         // Check exact count
         Assume.assumeNotNull(bnode1, bnode2, aliceName, bobName, secretClubName,
                 companyName, bobNameTriple);
@@ -254,15 +254,15 @@ public abstract class AbstractGraphTest {
     @Test
     public void getTriplesQuery() throws Exception {
 
-        long aliceCount = graph.getTriples(alice, null, null).count();
+        long aliceCount = graph.stream(alice, null, null).count();
         assertTrue(aliceCount > 0);
         Assume.assumeNotNull(aliceName);
         assertEquals(3, aliceCount);
 
         Assume.assumeNotNull(bnode1, bnode2, bobName, companyName, secretClubName);
-        assertEquals(4, graph.getTriples(null, name, null).count());
+        assertEquals(4, graph.stream(null, name, null).count());
         Assume.assumeNotNull(bnode1);
-        assertEquals(3, graph.getTriples(null, member, null).count());
+        assertEquals(3, graph.stream(null, member, null).count());
     }
 
     /**
@@ -287,14 +287,14 @@ public abstract class AbstractGraphTest {
         // Find a secret organizations
         assertEquals(
                 "\"The Secret Club\"",
-                graph.getTriples(null, knows, null)
+                graph.stream(null, knows, null)
                         // Find One-way "knows"
                         .filter(t -> !graph.contains(
                                 (BlankNodeOrIRI) t.getObject(), knows,
                                 t.getSubject()))
                         .map(knowsTriple -> graph
                                 // and those they know, what are they member of?
-                                .getTriples(
+                                .stream(
                                         (BlankNodeOrIRI) knowsTriple
                                                 .getObject(), member, null)
                                         // keep those which first-guy is a member of
@@ -305,7 +305,7 @@ public abstract class AbstractGraphTest {
                                 .get().getObject())
                                 // then look up the name of that org
                         .map(org -> graph
-                                .getTriples((BlankNodeOrIRI) org, name, null)
+                                .stream((BlankNodeOrIRI) org, name, null)
                                 .findFirst().get().getObject().ntriplesString())
                         .findFirst().get());
 

http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/b25af136/simple/src/main/java/org/apache/commons/rdf/simple/DatasetImpl.java
----------------------------------------------------------------------
diff --git a/simple/src/main/java/org/apache/commons/rdf/simple/DatasetImpl.java b/simple/src/main/java/org/apache/commons/rdf/simple/DatasetImpl.java
index af9b01d..9de358f 100644
--- a/simple/src/main/java/org/apache/commons/rdf/simple/DatasetImpl.java
+++ b/simple/src/main/java/org/apache/commons/rdf/simple/DatasetImpl.java
@@ -120,7 +120,7 @@ final class DatasetImpl implements Dataset {
 
 	@Override
 	public boolean contains(Optional<BlankNodeOrIRI> graphName, BlankNodeOrIRI subject, IRI predicate, RDFTerm object) {
-		return getQuads(graphName, subject, predicate, object).findAny().isPresent();
+		return stream(graphName, subject, predicate, object).findAny().isPresent();
 	}
     
     @Override
@@ -129,12 +129,12 @@ final class DatasetImpl implements Dataset {
     }
     
 	@Override
-	public Stream<Quad> getQuads() {
+	public Stream<Quad> stream() {
         return quads.parallelStream().unordered();
 	}
 
 	@Override
-	public Stream<Quad> getQuads(Optional<BlankNodeOrIRI> graphName, BlankNodeOrIRI subject, IRI predicate,
+	public Stream<Quad> stream(Optional<BlankNodeOrIRI> graphName, BlankNodeOrIRI subject, IRI predicate,
 			RDFTerm object) {
 		final Optional<BlankNodeOrIRI> newGraphName = graphName.map(g -> (BlankNodeOrIRI)internallyMap(g));
         final BlankNodeOrIRI newSubject = (BlankNodeOrIRI) internallyMap(subject);
@@ -160,12 +160,12 @@ final class DatasetImpl implements Dataset {
 	}    
 
     private Stream<Quad> getQuads(final Predicate<Quad> filter) {
-        return getQuads().filter(filter);
+        return stream().filter(filter);
     }
 
 	@Override
 	public void remove(Optional<BlankNodeOrIRI> graphName, BlankNodeOrIRI subject, IRI predicate, RDFTerm object) {
-        Stream<Quad> toRemove = getQuads(graphName, subject, predicate, object);
+        Stream<Quad> toRemove = stream(graphName, subject, predicate, object);
         for (Quad t : toRemove.collect(Collectors.toList())) {
             // Avoid ConcurrentModificationException in ArrayList
             remove(t);
@@ -184,7 +184,7 @@ final class DatasetImpl implements Dataset {
 
     @Override
     public String toString() {
-        String s = getQuads().limit(TO_STRING_MAX).map(Object::toString)
+        String s = stream().limit(TO_STRING_MAX).map(Object::toString)
                 .collect(Collectors.joining("\n"));
         if (size() > TO_STRING_MAX) {
             return s + "\n# ... +" + (size() - TO_STRING_MAX) + " more";
@@ -206,7 +206,7 @@ final class DatasetImpl implements Dataset {
 	public Optional<Graph> getGraph(BlankNodeOrIRI graphName) {
 		// NOTE: Always returns a new copy
 		Graph g = new GraphImpl(factory);
-		getQuads(Optional.ofNullable(graphName), null, null, null)
+		stream(Optional.ofNullable(graphName), null, null, null)
 			.map(Quad::asTriple)
 			.sequential()
 			.forEach(g::add);
@@ -216,11 +216,12 @@ final class DatasetImpl implements Dataset {
 	@Override
 	public Stream<BlankNodeOrIRI> getGraphNames() {
 		// Not very efficient..
-		return getQuads()
+		return stream()
 				.map(Quad::getGraphName)
 				.filter(Optional::isPresent).map(Optional::get)
 				.distinct();
 	}
 
 
+
 }

http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/b25af136/simple/src/main/java/org/apache/commons/rdf/simple/GraphImpl.java
----------------------------------------------------------------------
diff --git a/simple/src/main/java/org/apache/commons/rdf/simple/GraphImpl.java b/simple/src/main/java/org/apache/commons/rdf/simple/GraphImpl.java
index 024da21..1f19d57 100644
--- a/simple/src/main/java/org/apache/commons/rdf/simple/GraphImpl.java
+++ b/simple/src/main/java/org/apache/commons/rdf/simple/GraphImpl.java
@@ -111,7 +111,7 @@ final class GraphImpl implements Graph {
     @Override
     public boolean contains(BlankNodeOrIRI subject, IRI predicate,
                             RDFTerm object) {
-        return getTriples(subject, predicate, object).findFirst().isPresent();
+        return stream(subject, predicate, object).findFirst().isPresent();
     }
 
     @Override
@@ -120,12 +120,12 @@ final class GraphImpl implements Graph {
     }
 
     @Override
-    public Stream<Triple> getTriples() {
+    public Stream<Triple> stream() {
         return triples.parallelStream().unordered();
     }
 
     @Override
-    public Stream<Triple> getTriples(final BlankNodeOrIRI subject,
+    public Stream<Triple> stream(final BlankNodeOrIRI subject,
                                      final IRI predicate, final RDFTerm object) {
         final BlankNodeOrIRI newSubject = (BlankNodeOrIRI) internallyMap(subject);
         final IRI newPredicate = (IRI) internallyMap(predicate);
@@ -148,12 +148,12 @@ final class GraphImpl implements Graph {
     }
 
     private Stream<Triple> getTriples(final Predicate<Triple> filter) {
-        return getTriples().filter(filter);
+        return stream().filter(filter);
     }
 
     @Override
     public void remove(BlankNodeOrIRI subject, IRI predicate, RDFTerm object) {
-        Stream<Triple> toRemove = getTriples(subject, predicate, object);
+        Stream<Triple> toRemove = stream(subject, predicate, object);
         for (Triple t : toRemove.collect(Collectors.toList())) {
             // Avoid ConcurrentModificationException in ArrayList
             remove(t);
@@ -172,7 +172,7 @@ final class GraphImpl implements Graph {
 
     @Override
     public String toString() {
-        String s = getTriples().limit(TO_STRING_MAX).map(Object::toString)
+        String s = stream().limit(TO_STRING_MAX).map(Object::toString)
                 .collect(Collectors.joining("\n"));
         if (size() > TO_STRING_MAX) {
             return s + "\n# ... +" + (size() - TO_STRING_MAX) + " more";

http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/b25af136/simple/src/test/java/org/apache/commons/rdf/simple/TestWritingGraph.java
----------------------------------------------------------------------
diff --git a/simple/src/test/java/org/apache/commons/rdf/simple/TestWritingGraph.java b/simple/src/test/java/org/apache/commons/rdf/simple/TestWritingGraph.java
index 9862770..6cd8f52 100644
--- a/simple/src/test/java/org/apache/commons/rdf/simple/TestWritingGraph.java
+++ b/simple/src/test/java/org/apache/commons/rdf/simple/TestWritingGraph.java
@@ -102,7 +102,7 @@ public class TestWritingGraph {
     public void countQuery() {
         IRI subject = factory.createIRI("subj");
         IRI predicate = factory.createIRI("pred");
-        long count = graph.getTriples(subject, predicate, null).unordered()
+        long count = graph.stream(subject, predicate, null).unordered()
                 .parallel().count();
         //System.out.println("Counted - " + count);
         assertEquals(count, TRIPLES);
@@ -123,7 +123,7 @@ public class TestWritingGraph {
             graphFile.toFile().deleteOnExit();
         }
 
-        Stream<CharSequence> stream = graph.getTriples().map(TestWritingGraph::tripleAsString);
+        Stream<CharSequence> stream = graph.stream().map(TestWritingGraph::tripleAsString);
         Files.write(graphFile, stream::iterator, StandardCharsets.UTF_8);
     }
 
@@ -139,7 +139,7 @@ public class TestWritingGraph {
         IRI subject = factory.createIRI("subj");
         IRI predicate = factory.createIRI("pred");
         Stream<CharSequence> stream = graph
-                .getTriples(subject, predicate, null).map(TestWritingGraph::tripleAsString);
+                .stream(subject, predicate, null).map(TestWritingGraph::tripleAsString);
         Files.write(graphFile, stream::iterator, StandardCharsets.UTF_8);
 
     }
@@ -156,7 +156,7 @@ public class TestWritingGraph {
         IRI subject = factory.createIRI("nonexistent");
         IRI predicate = factory.createIRI("pred");
         Stream<CharSequence> stream = graph
-                .getTriples(subject, predicate, null).map(Object::toString);
+                .stream(subject, predicate, null).map(Object::toString);
         Files.write(graphFile, stream::iterator, StandardCharsets.UTF_8);
 
     }


[08/50] incubator-commonsrdf git commit: Re-enable tar.gz to be inline with Apache Commons

Posted by st...@apache.org.
Re-enable tar.gz to be inline with Apache Commons


Project: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/commit/3671b41c
Tree: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/tree/3671b41c
Diff: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/diff/3671b41c

Branch: refs/heads/parser-with-quads
Commit: 3671b41c43bf7e3d8272ebc48010794c9302b0bf
Parents: 190ff31
Author: Stian Soiland-Reyes <st...@apache.org>
Authored: Mon Apr 18 15:06:28 2016 +0100
Committer: Stian Soiland-Reyes <st...@apache.org>
Committed: Mon Apr 18 15:06:28 2016 +0100

----------------------------------------------------------------------
 src/assembly/src.xml | 1 +
 1 file changed, 1 insertion(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/3671b41c/src/assembly/src.xml
----------------------------------------------------------------------
diff --git a/src/assembly/src.xml b/src/assembly/src.xml
index 091b464..35e7077 100644
--- a/src/assembly/src.xml
+++ b/src/assembly/src.xml
@@ -19,6 +19,7 @@
     <id>src</id>
     <formats>
         <format>zip</format>
+        <format>tar.gz</format>
     </formats>
     <fileSets>
         <fileSet>


[48/50] incubator-commonsrdf git commit: target() in javadocs

Posted by st...@apache.org.
target() in javadocs


Project: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/commit/c0700de1
Tree: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/tree/c0700de1
Diff: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/diff/c0700de1

Branch: refs/heads/parser-with-quads
Commit: c0700de1f2adb83200f3443ef29e884a7ffae289
Parents: d153b4c
Author: Stian Soiland-Reyes <st...@apache.org>
Authored: Mon Jun 20 09:48:19 2016 +0100
Committer: Stian Soiland-Reyes <st...@apache.org>
Committed: Mon Jun 20 09:48:19 2016 +0100

----------------------------------------------------------------------
 .../org/apache/commons/rdf/api/RDFParserBuilder.java | 15 ++++++++++-----
 1 file changed, 10 insertions(+), 5 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/c0700de1/api/src/main/java/org/apache/commons/rdf/api/RDFParserBuilder.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/org/apache/commons/rdf/api/RDFParserBuilder.java b/api/src/main/java/org/apache/commons/rdf/api/RDFParserBuilder.java
index 1425263..b387406 100644
--- a/api/src/main/java/org/apache/commons/rdf/api/RDFParserBuilder.java
+++ b/api/src/main/java/org/apache/commons/rdf/api/RDFParserBuilder.java
@@ -22,6 +22,7 @@ import java.io.InputStream;
 import java.nio.charset.StandardCharsets;
 import java.nio.file.Path;
 import java.util.concurrent.Future;
+import java.util.function.Consumer;
 
 /**
  * Builder for parsing an RDF source into a Graph.
@@ -35,7 +36,7 @@ import java.util.concurrent.Future;
  * RDFParserBuilder - however methods can be called in any order.
  * <p>
  * The call to {@link #parse()} returns a {@link Future}, allowing asynchronous parse
- * operations. This can be combined with {@link #intoGraph(Graph)}
+ * operations. This can be combined with {@link #target(Graph)}
  * allowing access to the graph before parsing has completed,
  * however callers are still recommended to to check 
  * {@link Future#get()} for any exceptions thrown during parsing.
@@ -73,7 +74,7 @@ public interface RDFParserBuilder {
 	 * Specify which {@link RDFTermFactory} to use for generating
 	 * {@link RDFTerm}s.
 	 * <p>
-	 * This option may be used together with {@link #intoGraph(Graph)} to
+	 * This option may be used together with {@link #target(Graph)} to
 	 * override the implementation's default factory and graph.
 	 * <p>
 	 * <strong>Warning:</strong> Using the same {@link RDFTermFactory} for 
@@ -82,7 +83,7 @@ public interface RDFParserBuilder {
 	 * use the {@link RDFTermFactory#createBlankNode(String)} method
 	 * from the parsed blank node labels.
 	 * 
-	 * @see #intoGraph(Graph)
+	 * @see #target(Graph)
 	 * @param rdfTermFactory
 	 *            {@link RDFTermFactory} to use for generating RDFTerms.
 	 * @return An {@link RDFParserBuilder} that will use the specified
@@ -165,8 +166,12 @@ public interface RDFParserBuilder {
 	 * @return An {@link RDFParserBuilder} that will insert triples into the
 	 *         specified graph.
 	 */
-	RDFParserBuilder intoGraph(Graph graph);
+	default RDFParserBuilder target(Graph graph) {
+		return target(graph::add);
+	}
 
+	RDFParserBuilder target(Consumer<Triple> tripleConsumer);
+	
 	/**
 	 * Specify a base IRI to use for parsing any relative IRI references.
 	 * <p>
@@ -357,7 +362,7 @@ public interface RDFParserBuilder {
 	 * synchronous implementation MAY be blocking on the <code>parse()</code>
 	 * call and return a Future that is already {@link Future#isDone()}.
 	 * <p>
-	 * If {@link #intoGraph(Graph)} has been specified, this SHOULD be the same
+	 * If {@link #target(Graph)} has been specified, this SHOULD be the same
 	 * {@link Graph} instance returned from {@link Future#get()} once parsing has
 	 * completed successfully.
 	 * <p>


[37/50] incubator-commonsrdf git commit: Merge branch 'master' of https://git-wip-us.apache.org/repos/asf/incubator-commonsrdf

Posted by st...@apache.org.
Merge branch 'master' of https://git-wip-us.apache.org/repos/asf/incubator-commonsrdf


Project: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/commit/42089a8b
Tree: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/tree/42089a8b
Diff: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/diff/42089a8b

Branch: refs/heads/parser-with-quads
Commit: 42089a8b411bf8a8677a45c2a270ab4c185545f9
Parents: 658fc9b d6e610b
Author: Stian Soiland-Reyes <st...@apache.org>
Authored: Sun May 15 22:52:42 2016 +0100
Committer: Stian Soiland-Reyes <st...@apache.org>
Committed: Sun May 15 22:52:42 2016 +0100

----------------------------------------------------------------------

----------------------------------------------------------------------



[10/50] incubator-commonsrdf git commit: comments in pom.xml

Posted by st...@apache.org.
comments in pom.xml


Project: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/commit/f32e273e
Tree: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/tree/f32e273e
Diff: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/diff/f32e273e

Branch: refs/heads/parser-with-quads
Commit: f32e273e1355a62c5df37c28cddbaa26f566da3e
Parents: 2ef0af9
Author: Stian Soiland-Reyes <st...@apache.org>
Authored: Mon Apr 18 15:11:46 2016 +0100
Committer: Stian Soiland-Reyes <st...@apache.org>
Committed: Mon Apr 18 15:11:46 2016 +0100

----------------------------------------------------------------------
 pom.xml | 2 ++
 1 file changed, 2 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/f32e273e/pom.xml
----------------------------------------------------------------------
diff --git a/pom.xml b/pom.xml
index 923f9c5..61342ee 100644
--- a/pom.xml
+++ b/pom.xml
@@ -429,7 +429,9 @@
                             <exclude>examples/.settings/**</exclude>
                             <exclude>examples/.project</exclude>
                             <exclude>examples/.classpath</exclude>
+                            <!-- ServiceLoader file -->
                             <exclude>**/META-INF/services/*</exclude>
+                            <!-- Duplicates of NOTICE and LICENSE -->
                             <exclude>**/src/main/resources/NOTICE</exclude>
                             <exclude>**/src/main/resources/LICENSE</exclude>
                         </excludes>


[32/50] incubator-commonsrdf git commit: Use 0.2.0-incubating

Posted by st...@apache.org.
Use 0.2.0-incubating


Project: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/commit/5f9b27ce
Tree: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/tree/5f9b27ce
Diff: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/diff/5f9b27ce

Branch: refs/heads/parser-with-quads
Commit: 5f9b27ce872d3bd85df25b257c85eac0c999b867
Parents: 471b80c
Author: Stian Soiland-Reyes <st...@apache.org>
Authored: Fri May 13 14:21:39 2016 +0100
Committer: Stian Soiland-Reyes <st...@apache.org>
Committed: Fri May 13 14:21:39 2016 +0100

----------------------------------------------------------------------
 examples/pom.xml | 4 ++--
 1 file changed, 2 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/5f9b27ce/examples/pom.xml
----------------------------------------------------------------------
diff --git a/examples/pom.xml b/examples/pom.xml
index 9ed3b90..4b61cf7 100644
--- a/examples/pom.xml
+++ b/examples/pom.xml
@@ -50,13 +50,13 @@
     		<groupId>org.apache.commons</groupId>
     		<artifactId>commons-rdf-api</artifactId>
         <!-- update to latest version -->
-    		<version>0.1-incubating-SNAPSHOT</version>
+    		<version>0.2.0-incubating</version>
     	</dependency>
     	<dependency>
     		<groupId>org.apache.commons</groupId>
     		<artifactId>commons-rdf-simple</artifactId>
         <!-- update to latest version -->
-    		<version>0.1.0-incubating-SNAPSHOT</version>
+    		<version>0.2.0-incubating</version>
     	</dependency>
     	<dependency>
     		<groupId>junit</groupId>


[33/50] incubator-commonsrdf git commit: import StandardCharsets

Posted by st...@apache.org.
import StandardCharsets


Project: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/commit/297000aa
Tree: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/tree/297000aa
Diff: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/diff/297000aa

Branch: refs/heads/parser-with-quads
Commit: 297000aa58ef7d0fb218be50f27356eac7bcfa64
Parents: 5f9b27c
Author: Stian Soiland-Reyes <st...@apache.org>
Authored: Fri May 13 14:21:43 2016 +0100
Committer: Stian Soiland-Reyes <st...@apache.org>
Committed: Fri May 13 14:21:43 2016 +0100

----------------------------------------------------------------------
 examples/src/example/UserGuideTest.java | 1 +
 1 file changed, 1 insertion(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/297000aa/examples/src/example/UserGuideTest.java
----------------------------------------------------------------------
diff --git a/examples/src/example/UserGuideTest.java b/examples/src/example/UserGuideTest.java
index eab6b0d..44cf587 100644
--- a/examples/src/example/UserGuideTest.java
+++ b/examples/src/example/UserGuideTest.java
@@ -18,6 +18,7 @@
 package example;
 
 import java.nio.charset.Charset;
+import java.nio.charset.StandardCharsets;
 import java.nio.file.Files;
 import java.nio.file.Path;
 import java.util.Optional;


[47/50] incubator-commonsrdf git commit: added getTargetDataset()/getTargetGraph()

Posted by st...@apache.org.
added getTargetDataset()/getTargetGraph()


Project: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/commit/7c69d4fd
Tree: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/tree/7c69d4fd
Diff: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/diff/7c69d4fd

Branch: refs/heads/parser-with-quads
Commit: 7c69d4fdc1511fe9cbad1cf4abc00d661d2a7871
Parents: 036029b
Author: Stian Soiland-Reyes <st...@apache.org>
Authored: Fri Jun 17 21:18:47 2016 +0100
Committer: Stian Soiland-Reyes <st...@apache.org>
Committed: Fri Jun 17 21:18:47 2016 +0100

----------------------------------------------------------------------
 .../rdf/simple/AbstractRDFParserBuilder.java    | 78 ++++++++++++++++++++
 1 file changed, 78 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/7c69d4fd/simple/src/main/java/org/apache/commons/rdf/simple/AbstractRDFParserBuilder.java
----------------------------------------------------------------------
diff --git a/simple/src/main/java/org/apache/commons/rdf/simple/AbstractRDFParserBuilder.java b/simple/src/main/java/org/apache/commons/rdf/simple/AbstractRDFParserBuilder.java
index 9544928..cc5fad0 100644
--- a/simple/src/main/java/org/apache/commons/rdf/simple/AbstractRDFParserBuilder.java
+++ b/simple/src/main/java/org/apache/commons/rdf/simple/AbstractRDFParserBuilder.java
@@ -28,6 +28,8 @@ import java.util.concurrent.Executors;
 import java.util.concurrent.Future;
 import java.util.function.Consumer;
 
+import org.apache.commons.rdf.api.Dataset;
+import org.apache.commons.rdf.api.Graph;
 import org.apache.commons.rdf.api.IRI;
 import org.apache.commons.rdf.api.Quad;
 import org.apache.commons.rdf.api.RDFParserBuilder;
@@ -123,6 +125,40 @@ public abstract class AbstractRDFParserBuilder implements RDFParserBuilder, Clon
 	}
 
 	/**
+	 * Get the target dataset as set by {@link #target(Dataset)}.
+	 * <p>
+	 * The return value is {@link Optional#isPresent()} if and only if
+	 * {@link #target(Dataset)} has been set, meaning that the implementation
+	 * may choose to append parsed quads to the {@link Dataset} directly instead
+	 * of relying on the generated {@link #getTarget()} consumer.
+	 * <p>
+	 * If this value is present, then {@link #getTargetGraph()} MUST 
+	 * be {@link Optional#empty()}.
+	 * 
+	 * @return The target Dataset, or {@link Optional#empty()} if another kind of target has been set.
+	 */
+	public Optional<Dataset> getTargetDataset() {
+		return targetDataset;
+	}
+
+	/**
+	 * Get the target graph as set by {@link #target(Graph)}.
+	 * <p>
+	 * The return value is {@link Optional#isPresent()} if and only if
+	 * {@link #target(Graph)} has been set, meaning that the implementation
+	 * may choose to append parsed triples to the {@link Graph} directly instead
+	 * of relying on the generated {@link #getTarget()} consumer.
+	 * <p>
+	 * If this value is present, then {@link #getTargetDataset()} MUST 
+	 * be {@link Optional#empty()}.
+	 * 
+	 * @return The target Graph, or {@link Optional#empty()} if another kind of target has been set.
+	 */	
+	public Optional<Graph>  getTargetGraph() {
+		return targetGraph;
+	}
+	
+	/**
 	 * Get the set base {@link IRI}, if present.
 	 * <p>
 	 * 
@@ -164,6 +200,7 @@ public abstract class AbstractRDFParserBuilder implements RDFParserBuilder, Clon
 		return sourceIri;
 	}
 
+
 	private Optional<RDFTermFactory> rdfTermFactory = Optional.empty();
 	private Optional<RDFSyntax> contentTypeSyntax = Optional.empty();
 	private Optional<String> contentType = Optional.empty();
@@ -172,6 +209,8 @@ public abstract class AbstractRDFParserBuilder implements RDFParserBuilder, Clon
 	private Optional<Path> sourceFile = Optional.empty();
 	private Optional<IRI> sourceIri = Optional.empty();
 	private Consumer<Quad> target;
+	private Optional<Dataset> targetDataset;
+	private Optional<Graph> targetGraph;
 
 	@Override
 	public AbstractRDFParserBuilder clone() {
@@ -319,6 +358,22 @@ public abstract class AbstractRDFParserBuilder implements RDFParserBuilder, Clon
 		sourceFile = Optional.empty();
 	}
 
+
+	/**
+	 * Reset all optional target* fields to Optional.empty()</code>
+	 * <p>
+	 * Note that the consumer set for {@link #getTarget()} is
+	 * NOT reset.
+	 * <p>
+	 * Subclasses should override this and call <code>super.resetTarget()</code>
+	 * if they need to reset any additional target* fields.
+	 * 
+	 */
+	protected void resetTarget() {
+		targetDataset = Optional.empty();
+		targetGraph = Optional.empty();
+	}	
+	
 	/**
 	 * Parse {@link #sourceInputStream}, {@link #sourceFile} or
 	 * {@link #sourceIri}.
@@ -387,6 +442,10 @@ public abstract class AbstractRDFParserBuilder implements RDFParserBuilder, Clon
 		if (target == null) {
 			throw new IllegalStateException("target has not been set");
 		}
+		if (targetGraph.isPresent() && targetDataset.isPresent()) {
+			// This should not happen as each target(..) method resets the optionals
+			throw new IllegalStateException("targetGraph and targetDataset can't both be set");
+		}
 	}
 
 	/**
@@ -470,8 +529,27 @@ public abstract class AbstractRDFParserBuilder implements RDFParserBuilder, Clon
 	@Override
 	public RDFParserBuilder target(Consumer<Quad> consumer) {
 		AbstractRDFParserBuilder c = clone();
+		c.resetTarget();
 		c.target = consumer;
 		return c;
 	}
+	
+	@Override
+	public RDFParserBuilder target(Dataset dataset) {
+		AbstractRDFParserBuilder c = (AbstractRDFParserBuilder) RDFParserBuilder.super.target(dataset);
+		c.resetTarget();
+		c.targetDataset = Optional.of(dataset);
+		return c;
+	}
+	
+	@Override
+	public RDFParserBuilder target(Graph graph) {
+		AbstractRDFParserBuilder c = (AbstractRDFParserBuilder) RDFParserBuilder.super.target(graph);
+		c.resetTarget();
+		c.targetGraph = Optional.of(graph);
+		return c;
+	}
+	
+
 
 }


[23/50] incubator-commonsrdf git commit: Rob Vesse moved to emeritus

Posted by st...@apache.org.
Rob Vesse moved to emeritus <contributor>


Project: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/commit/3bec6ed5
Tree: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/tree/3bec6ed5
Diff: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/diff/3bec6ed5

Branch: refs/heads/parser-with-quads
Commit: 3bec6ed5676aeb78519d82221ea14d9abf7bbd6a
Parents: 0d92cec
Author: Stian Soiland-Reyes <st...@apache.org>
Authored: Mon May 2 17:46:42 2016 +0100
Committer: Stian Soiland-Reyes <st...@apache.org>
Committed: Mon May 2 17:47:07 2016 +0100

----------------------------------------------------------------------
 pom.xml | 19 ++++++++-----------
 1 file changed, 8 insertions(+), 11 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/3bec6ed5/pom.xml
----------------------------------------------------------------------
diff --git a/pom.xml b/pom.xml
index 31b80f1..f1f28ba 100644
--- a/pom.xml
+++ b/pom.xml
@@ -110,17 +110,6 @@
             <timezone>+1</timezone>
         </developer>
         <developer>
-            <id>rvesse</id>
-            <name>Rob Vesse</name>
-            <email>rvesse[at]apache[dot]org</email>
-            <roles>
-                <role>Committer</role>
-                <role>PPMC Member</role>
-                <role>Emeritus Mentor</role>
-            </roles>
-            <timezone>+0</timezone>
-        </developer>
-        <developer>
             <id>johndament</id>
             <name>John D Ament</name>
             <email>johndament[at]apache[dot]org</email>
@@ -215,6 +204,14 @@
             </roles>
             <timezone>+0</timezone>
         </contributor>
+        <contributor>
+            <name>Rob Vesse</name>
+            <email>rvesse[at]apache[dot]org</email>
+            <roles>
+                <role>Emeritus Mentor</role>
+            </roles>
+            <timezone>+0</timezone>
+        </contributor>
     </contributors>
 
     <modules>


[07/50] incubator-commonsrdf git commit: Move assembly to standard location (according to commons-parent-39.pom)

Posted by st...@apache.org.
Move assembly to standard location (according to commons-parent-39.pom)


Project: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/commit/190ff31e
Tree: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/tree/190ff31e
Diff: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/diff/190ff31e

Branch: refs/heads/parser-with-quads
Commit: 190ff31e6c344fccd585d3d9972347421d457674
Parents: e3ca301
Author: Stian Soiland-Reyes <st...@apache.org>
Authored: Mon Apr 18 14:57:15 2016 +0100
Committer: Stian Soiland-Reyes <st...@apache.org>
Committed: Mon Apr 18 14:57:15 2016 +0100

----------------------------------------------------------------------
 src/assembly/src.xml      | 44 ++++++++++++++++++++++++++++++++++++++++++
 src/main/assembly/src.xml | 44 ------------------------------------------
 2 files changed, 44 insertions(+), 44 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/190ff31e/src/assembly/src.xml
----------------------------------------------------------------------
diff --git a/src/assembly/src.xml b/src/assembly/src.xml
new file mode 100644
index 0000000..091b464
--- /dev/null
+++ b/src/assembly/src.xml
@@ -0,0 +1,44 @@
+<?xml version="1.0" encoding="UTF-8"?>
+<!--
+   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.
+-->
+<assembly>
+    <id>src</id>
+    <formats>
+        <format>zip</format>
+    </formats>
+    <fileSets>
+        <fileSet>
+            <directory>${project.basedir}</directory>
+            <outputDirectory></outputDirectory>
+            <excludes>
+                <exclude>**/*~</exclude>
+                <exclude>pom.xml.*</exclude>
+                <exclude>prelease.properties</exclude>
+                <exclude>examples/**</exclude>
+                <exclude>**/target/**</exclude>
+                <exclude>**/.*/**</exclude>
+                <exclude>**/*.iml</exclude>
+                <exclude>**/*.ipr</exclude>
+                <exclude>**/*.iws</exclude>
+                <exclude>.project</exclude>
+                <exclude>.classpath</exclude>
+                <exclude>.metadata</exclude>
+                <exclude>atlassian-ide-plugin.xml</exclude>
+            </excludes>
+        </fileSet>
+    </fileSets>
+</assembly>

http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/190ff31e/src/main/assembly/src.xml
----------------------------------------------------------------------
diff --git a/src/main/assembly/src.xml b/src/main/assembly/src.xml
deleted file mode 100644
index 091b464..0000000
--- a/src/main/assembly/src.xml
+++ /dev/null
@@ -1,44 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-   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.
--->
-<assembly>
-    <id>src</id>
-    <formats>
-        <format>zip</format>
-    </formats>
-    <fileSets>
-        <fileSet>
-            <directory>${project.basedir}</directory>
-            <outputDirectory></outputDirectory>
-            <excludes>
-                <exclude>**/*~</exclude>
-                <exclude>pom.xml.*</exclude>
-                <exclude>prelease.properties</exclude>
-                <exclude>examples/**</exclude>
-                <exclude>**/target/**</exclude>
-                <exclude>**/.*/**</exclude>
-                <exclude>**/*.iml</exclude>
-                <exclude>**/*.ipr</exclude>
-                <exclude>**/*.iws</exclude>
-                <exclude>.project</exclude>
-                <exclude>.classpath</exclude>
-                <exclude>.metadata</exclude>
-                <exclude>atlassian-ide-plugin.xml</exclude>
-            </excludes>
-        </fileSet>
-    </fileSets>
-</assembly>


[05/50] incubator-commonsrdf git commit: hand-coded UUIDs for testing

Posted by st...@apache.org.
hand-coded UUIDs for testing


Project: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/commit/9f94e2fb
Tree: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/tree/9f94e2fb
Diff: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/diff/9f94e2fb

Branch: refs/heads/parser-with-quads
Commit: 9f94e2fbb69458888366458c5f84e82d934159dd
Parents: a06f621
Author: Stian Soiland-Reyes <st...@apache.org>
Authored: Mon Apr 11 16:20:02 2016 +0100
Committer: Stian Soiland-Reyes <st...@apache.org>
Committed: Mon Apr 11 16:20:28 2016 +0100

----------------------------------------------------------------------
 .../apache/commons/rdf/api/AbstractGraphTest.java   | 16 ++++++++--------
 1 file changed, 8 insertions(+), 8 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/9f94e2fb/api/src/test/java/org/apache/commons/rdf/api/AbstractGraphTest.java
----------------------------------------------------------------------
diff --git a/api/src/test/java/org/apache/commons/rdf/api/AbstractGraphTest.java b/api/src/test/java/org/apache/commons/rdf/api/AbstractGraphTest.java
index 326e2ff..5986958 100644
--- a/api/src/test/java/org/apache/commons/rdf/api/AbstractGraphTest.java
+++ b/api/src/test/java/org/apache/commons/rdf/api/AbstractGraphTest.java
@@ -372,11 +372,11 @@ public abstract class AbstractGraphTest {
 
         IRI name = factory1.createIRI("http://xmlns.com/foaf/0.1/name");
         Graph g1 = factory1.createGraph();
-        BlankNode b1 = createOwnBlankNode("b1");
+        BlankNode b1 = createOwnBlankNode("b1", "0240eaaa-d33e-4fc0-a4f1-169d6ced3680");
         g1.add(b1, name, factory1.createLiteral("Alice"));
         
         
-        BlankNode b2 = createOwnBlankNode("b2");
+        BlankNode b2 = createOwnBlankNode("b2", "9de7db45-0ce7-4b0f-a1ce-c9680ffcfd9f");
         g1.add(b2, name, factory1.createLiteral("Bob"));
 
         IRI hasChild = factory1.createIRI("http://example.com/hasChild");
@@ -394,7 +394,7 @@ public abstract class AbstractGraphTest {
      * @param name
      * @return
      */
-	private BlankNode createOwnBlankNode(String name) {
+	private BlankNode createOwnBlankNode(String name, String uuid) {
 		return new BlankNode() {			
 			@Override
 			public String ntriplesString() {
@@ -402,11 +402,11 @@ public abstract class AbstractGraphTest {
 			}
 			@Override
 			public String uniqueReference() {
-				return "urn:uuid:" + UUID.randomUUID().toString();
+				return uuid;
 			}
 			@Override
 			public int hashCode() {
-				return uniqueReference().hashCode();
+				return uuid.hashCode();
 			}
 			@Override
 			public boolean equals(Object obj) {
@@ -414,7 +414,7 @@ public abstract class AbstractGraphTest {
 					return false;
 				}
 				BlankNode other = (BlankNode)obj;
-				return uniqueReference().equals(other.uniqueReference());
+				return uuid.equals(other.uniqueReference());
 			}
 		};
 	}
@@ -425,10 +425,10 @@ public abstract class AbstractGraphTest {
 
         Graph g2 = factory2.createGraph();
 
-        BlankNode b1 = createOwnBlankNode("b1");
+        BlankNode b1 = createOwnBlankNode("b1", "bc8d3e45-a08f-421d-85b3-c25b373abf87");
         g2.add(b1, name, factory2.createLiteral("Charlie"));
 
-        BlankNode b2 = createOwnBlankNode("b2");
+        BlankNode b2 = createOwnBlankNode("b2", "2209097a-5078-4b03-801a-6a2d2f50d739");
         g2.add(b2, name, factory2.createLiteral("Dave"));
 
         IRI hasChild = factory2.createIRI("http://example.com/hasChild");


[11/50] incubator-commonsrdf git commit: Some release notes

Posted by st...@apache.org.
Some release notes


Project: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/commit/ad92667d
Tree: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/tree/ad92667d
Diff: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/diff/ad92667d

Branch: refs/heads/parser-with-quads
Commit: ad92667d51f666652209ed56d063ca1869cebc38
Parents: f32e273
Author: Stian Soiland-Reyes <st...@apache.org>
Authored: Mon Apr 18 15:44:59 2016 +0100
Committer: Stian Soiland-Reyes <st...@apache.org>
Committed: Mon Apr 18 15:44:59 2016 +0100

----------------------------------------------------------------------
 RELEASE-NOTES.txt | 39 +++++++++++++++++++++++++++++++++++++++
 1 file changed, 39 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/ad92667d/RELEASE-NOTES.txt
----------------------------------------------------------------------
diff --git a/RELEASE-NOTES.txt b/RELEASE-NOTES.txt
new file mode 100644
index 0000000..e21aaa7
--- /dev/null
+++ b/RELEASE-NOTES.txt
@@ -0,0 +1,39 @@
+# Apache Commons RDF (incubating)
+
+## 0.2.0-incubating (TODO)
+
+This release clarifies .equals() and .hashCode() for RDFTerms so that they can
+be compared across graphs and implementations.
+
+* [COMMONSRDF-14] - Define value returned by hashCode()
+* [COMMONSRDF-20] - ServiceLoader mechanism to load RDFTermFactory
+* [COMMONSRDF-21] - Remove BlankNode requirements from RDFTermFactory.createGraph()
+* [COMMONSRDF-25] - Remove mentions of "local scope" in .equals()
+* Add RDFSyntax constants (e.g. TURTLE)
+* RDFTermFactory no longer require BlankNode mapping
+* Add internal SimpleRDFTerm marker interface
+
+## 0.1.0-incubating (2015-05-15)
+
+This is the first release after moving to Apache Incubator.
+
+* [COMMONSRDF-2] - Change to package name org.apache.commons.rdf.api
+* [COMMONSRDF-6] - Contract around the internal string of a blank node
+* [COMMONSRDF-8] - simple .GraphImpl.add() must clone BlankNode
+* [COMMONSRDF-11] - Simple should be extendable classes
+* [COMMONSRDF-12] - Graph to be Iterable
+* BlankNode.internalIdentifier() renamed to BlankNode.uniqueReference()
+* Add "simple" implementation and unit tests
+* Add RDFTermFactory
+* Added user guide to website
+
+
+## 0.0.2 (2014-08-04)
+
+* Change to package name com.github.commonsrdf.api
+* BlankNode.getLabel() renamed to BlankNode.internalIdentifier()
+* Removed Quad
+
+## 0.0.1 (2014-07-18)
+
+* First release


[16/50] incubator-commonsrdf git commit: pom typo

Posted by st...@apache.org.
pom typo


Project: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/commit/4d229d76
Tree: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/tree/4d229d76
Diff: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/diff/4d229d76

Branch: refs/heads/parser-with-quads
Commit: 4d229d767b2e871fbc7d7be53c9754b52a921177
Parents: 82b81e7
Author: Stian Soiland-Reyes <st...@apache.org>
Authored: Fri Apr 22 14:45:47 2016 +0100
Committer: Stian Soiland-Reyes <st...@apache.org>
Committed: Fri Apr 22 14:45:47 2016 +0100

----------------------------------------------------------------------
 pom.xml | 4 ++--
 1 file changed, 2 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/4d229d76/pom.xml
----------------------------------------------------------------------
diff --git a/pom.xml b/pom.xml
index 5ec2f94..269a39f 100644
--- a/pom.xml
+++ b/pom.xml
@@ -206,7 +206,7 @@
             </roles>
             <timezone>+1</timezone>
         </contributor>
-        <developer>
+        <contributor>
             <name>Andy Seaborne</name>
             <email>andy[at]apache[dot]org</email>
             <roles>
@@ -214,7 +214,7 @@
                 <role>Emeritus PPPMC Member</role>
             </roles>
             <timezone>+0</timezone>
-        </developer>
+        </contributor>
     </contributors>
 
     <modules>


[36/50] incubator-commonsrdf git commit: Release process: Remember to update docs

Posted by st...@apache.org.
Release process: Remember to update docs


Project: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/commit/658fc9bc
Tree: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/tree/658fc9bc
Diff: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/diff/658fc9bc

Branch: refs/heads/parser-with-quads
Commit: 658fc9bcbcdb42a7781d5d0199d16c0e857afd3b
Parents: 935cb7f
Author: Stian Soiland-Reyes <st...@apache.org>
Authored: Sun May 15 22:49:51 2016 +0100
Committer: Stian Soiland-Reyes <st...@apache.org>
Committed: Sun May 15 22:49:51 2016 +0100

----------------------------------------------------------------------
 RELEASE-PROCESS.md | 15 ++++++++-------
 1 file changed, 8 insertions(+), 7 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/658fc9bc/RELEASE-PROCESS.md
----------------------------------------------------------------------
diff --git a/RELEASE-PROCESS.md b/RELEASE-PROCESS.md
index 9a96c25..22ce224 100644
--- a/RELEASE-PROCESS.md
+++ b/RELEASE-PROCESS.md
@@ -1,12 +1,13 @@
 # Commons RDF (incubating) release process
 
-1. Clean build: `mvn clean install`
-2. RAT checking: `mvn apache-rat:check`
-3. Prepare the release: `mvn release:prepare -DreleaseVersion=0.2.0-incubating -DdevelopmentVersion=0.3.0-incubating-SNAPSHOT -DautoVersionSubmodules=true`
-4. Perform the release: `mvn release:perform -Prelease`
-5. Close the staging repository at https://repository.apache.org/#stagingRepositories
-6. Push the code: `git push` and tag `git push --tags`
-7. Cast the vote mail to dev@commonsrdf
+1. Update documentation (`RELEASE-NOTES.md`, `README.md`, version numbers in `src/site/`)
+2. Clean build: `mvn clean install`
+3. RAT checking: `mvn apache-rat:check`
+4. Prepare the release: `mvn release:prepare -DreleaseVersion=0.2.0-incubating -DdevelopmentVersion=0.3.0-incubating-SNAPSHOT -DautoVersionSubmodules=true`
+5. Perform the release: `mvn release:perform -Prelease`
+6. Close the staging repository at https://repository.apache.org/#stagingRepositories
+7. Push the code: `git push` and tag `git push --tags`
+8. Cast the vote mail to dev@commonsrdf
 
 Notice that the `maven-release-plugin` is configured to use the local git repository as well as not push changes 
 to `origin`. Therefore the process can be reverted (e.g., `git reset HEAD~1`) at any time before the sixth step.


[19/50] incubator-commonsrdf git commit: [maven-release-plugin] prepare release 0.2.0-incubating

Posted by st...@apache.org.
[maven-release-plugin] prepare release 0.2.0-incubating


Project: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/commit/f02b6bdd
Tree: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/tree/f02b6bdd
Diff: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/diff/f02b6bdd

Branch: refs/heads/parser-with-quads
Commit: f02b6bdd3ecd515542cd54c81f3639630ab85ff7
Parents: 476b030
Author: Lewis John McGibbney <le...@jpl.nasa.gov>
Authored: Thu Apr 28 16:04:46 2016 -0700
Committer: Lewis John McGibbney <le...@jpl.nasa.gov>
Committed: Thu Apr 28 16:04:46 2016 -0700

----------------------------------------------------------------------
 api/pom.xml    | 2 +-
 pom.xml        | 4 ++--
 simple/pom.xml | 2 +-
 3 files changed, 4 insertions(+), 4 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/f02b6bdd/api/pom.xml
----------------------------------------------------------------------
diff --git a/api/pom.xml b/api/pom.xml
index 31f4275..bc8e506 100644
--- a/api/pom.xml
+++ b/api/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.commons</groupId>
         <artifactId>commons-rdf-parent</artifactId>
-        <version>0.2.0-incubating-SNAPSHOT</version>
+        <version>0.2.0-incubating</version>
     </parent>
 
     <artifactId>commons-rdf-api</artifactId>

http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/f02b6bdd/pom.xml
----------------------------------------------------------------------
diff --git a/pom.xml b/pom.xml
index 6ed249b..b1ee489 100644
--- a/pom.xml
+++ b/pom.xml
@@ -29,7 +29,7 @@
 
     <groupId>org.apache.commons</groupId>
     <artifactId>commons-rdf-parent</artifactId>
-    <version>0.2.0-incubating-SNAPSHOT</version>
+    <version>0.2.0-incubating</version>
     <packaging>pom</packaging>
 
     <name>Commons RDF</name>
@@ -66,7 +66,7 @@
         <url>https://git-wip-us.apache.org/repos/asf/incubator-commonsrdf.git</url>
         <connection>scm:git:https://git-wip-us.apache.org/repos/asf/incubator-commonsrdf.git</connection>
         <developerConnection>scm:git:https://git-wip-us.apache.org/repos/asf/incubator-commonsrdf.git</developerConnection>
-        <tag>HEAD</tag>
+        <tag>0.2.0-incubating</tag>
     </scm>
 
     <issueManagement>

http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/f02b6bdd/simple/pom.xml
----------------------------------------------------------------------
diff --git a/simple/pom.xml b/simple/pom.xml
index ecd5cd3..170716a 100644
--- a/simple/pom.xml
+++ b/simple/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.commons</groupId>
         <artifactId>commons-rdf-parent</artifactId>
-        <version>0.2.0-incubating-SNAPSHOT</version>
+        <version>0.2.0-incubating</version>
     </parent>
 
     <artifactId>commons-rdf-simple</artifactId>


[45/50] incubator-commonsrdf git commit: Added DatasetGraphView

Posted by st...@apache.org.
Added DatasetGraphView


Project: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/commit/580484c9
Tree: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/tree/580484c9
Diff: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/diff/580484c9

Branch: refs/heads/parser-with-quads
Commit: 580484c9d7d02d34b64e5276744c1f644dbbd2f2
Parents: 14e505e
Author: Stian Soiland-Reyes <st...@apache.org>
Authored: Tue Jun 14 16:44:24 2016 +0100
Committer: Stian Soiland-Reyes <st...@apache.org>
Committed: Tue Jun 14 16:44:24 2016 +0100

----------------------------------------------------------------------
 .../commons/rdf/simple/DatasetGraphView.java    | 138 +++++++++++++++++++
 .../apache/commons/rdf/simple/DatasetImpl.java  |   8 +-
 2 files changed, 139 insertions(+), 7 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/580484c9/simple/src/main/java/org/apache/commons/rdf/simple/DatasetGraphView.java
----------------------------------------------------------------------
diff --git a/simple/src/main/java/org/apache/commons/rdf/simple/DatasetGraphView.java b/simple/src/main/java/org/apache/commons/rdf/simple/DatasetGraphView.java
new file mode 100644
index 0000000..a347c3e
--- /dev/null
+++ b/simple/src/main/java/org/apache/commons/rdf/simple/DatasetGraphView.java
@@ -0,0 +1,138 @@
+/**
+ * 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.commons.rdf.simple;
+
+import java.util.Optional;
+import java.util.stream.Stream;
+
+import org.apache.commons.rdf.api.BlankNode;
+import org.apache.commons.rdf.api.BlankNodeOrIRI;
+import org.apache.commons.rdf.api.Dataset;
+import org.apache.commons.rdf.api.Graph;
+import org.apache.commons.rdf.api.IRI;
+import org.apache.commons.rdf.api.Quad;
+import org.apache.commons.rdf.api.RDFTerm;
+import org.apache.commons.rdf.api.Triple;
+
+/**
+ * A {@link Graph} view on a {@link Dataset}.
+ * <p>
+ * This view is backed by a {@link Dataset}, and can be constructed in two ways:
+ * 
+ * <dl>
+ * <dt>{@link #DatasetGraphView(Dataset)}</dt>
+ * <dd>Expose a <em>union graph</em> view of the Dataset, where all the
+ * {@link Quad}s of the Dataset is represented as a {@link Triple}. Adding
+ * triples will add them to the <em>default graph</em>, while removing triples
+ * will remove from all graphs.</dd>
+* 
+ * <dt>{@link #DatasetGraphView(Dataset, IRI)}</dt>
+ * <dd>Expose a particular graph of the Dataset, either named by an {@link IRI}, a
+ * {@link BlankNode}, or  <code>null</code> for the <em>default graph</em>.</dd>
+ * </dl>
+ * <p>
+ * Changes in the Graph are reflected directly in the Dataset and vice versa.  
+ * This class is thread-safe is the underlying Dataset is thread-safe.
+ */
+public class DatasetGraphView implements Graph {
+
+	private final boolean unionGraph;
+	private final BlankNodeOrIRI namedGraph;
+	private final Dataset dataset;
+
+	public DatasetGraphView(Dataset dataset) {
+		this.dataset = dataset;
+		this.namedGraph = null;
+		this.unionGraph = true;
+	}
+
+	public DatasetGraphView(Dataset dataset, BlankNodeOrIRI namedGraph) {
+		this.dataset = dataset;
+		this.namedGraph = namedGraph;
+		this.unionGraph = false;
+	}
+
+	@Override
+	public void close() throws Exception {
+		dataset.close();
+
+	}
+
+	@Override
+	public void add(Triple triple) {
+		dataset.add(namedGraph, triple.getSubject(), triple.getPredicate(), triple.getObject());
+	}
+
+	@Override
+	public void add(BlankNodeOrIRI subject, IRI predicate, RDFTerm object) {
+		dataset.add(namedGraph, subject, predicate, object);
+	}
+
+	@Override
+	public boolean contains(Triple triple) {
+		return dataset.contains(unionOrNamedGraph(), triple.getSubject(), triple.getPredicate(), triple.getObject());
+	}
+
+	private Optional<BlankNodeOrIRI> unionOrNamedGraph() {
+		if (unionGraph) {
+			return null;
+		}
+		return Optional.ofNullable(namedGraph);
+	}
+
+	@Override
+	public boolean contains(BlankNodeOrIRI subject, IRI predicate, RDFTerm object) {
+		return dataset.contains(unionOrNamedGraph(), subject, predicate, object);
+	}
+
+	@Override
+	public void remove(Triple triple) {
+		dataset.remove(unionOrNamedGraph(), triple.getSubject(), triple.getPredicate(), triple.getObject());
+	}
+
+	@Override
+	public void remove(BlankNodeOrIRI subject, IRI predicate, RDFTerm object) {
+		dataset.remove(unionOrNamedGraph(), subject, predicate, object);
+	}
+
+	@Override
+	public void clear() {
+		dataset.remove(unionOrNamedGraph(), null, null, null);
+	}
+
+	@Override
+	public long size() {
+		return stream().count();
+	}
+
+	@Override
+	public Stream<? extends Triple> stream() {
+		return stream(null, null, null);
+	}
+
+	@Override
+	public Stream<? extends Triple> stream(BlankNodeOrIRI subject, IRI predicate, RDFTerm object) {
+		Stream<Triple> stream = dataset.stream(unionOrNamedGraph(), subject, predicate, object).map(Quad::asTriple);
+		if (unionGraph) {
+			// remove duplicates
+			return stream.distinct();
+		}
+		return stream;
+	}
+
+}

http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/580484c9/simple/src/main/java/org/apache/commons/rdf/simple/DatasetImpl.java
----------------------------------------------------------------------
diff --git a/simple/src/main/java/org/apache/commons/rdf/simple/DatasetImpl.java b/simple/src/main/java/org/apache/commons/rdf/simple/DatasetImpl.java
index 9de358f..c372012 100644
--- a/simple/src/main/java/org/apache/commons/rdf/simple/DatasetImpl.java
+++ b/simple/src/main/java/org/apache/commons/rdf/simple/DatasetImpl.java
@@ -204,13 +204,7 @@ final class DatasetImpl implements Dataset {
 
 	@Override
 	public Optional<Graph> getGraph(BlankNodeOrIRI graphName) {
-		// NOTE: Always returns a new copy
-		Graph g = new GraphImpl(factory);
-		stream(Optional.ofNullable(graphName), null, null, null)
-			.map(Quad::asTriple)
-			.sequential()
-			.forEach(g::add);
-		return Optional.of(g);
+		return Optional.of(new DatasetGraphView(this, graphName));
 	}
 
 	@Override


[06/50] incubator-commonsrdf git commit: apache-rat to ignore META-INF/services

Posted by st...@apache.org.
apache-rat to ignore META-INF/services

..and nested NOTICE/LICENSE files


Project: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/commit/e3ca3017
Tree: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/tree/e3ca3017
Diff: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/diff/e3ca3017

Branch: refs/heads/parser-with-quads
Commit: e3ca3017a9489b91ed9edcf27bc6b107da410742
Parents: 9f94e2f
Author: Stian Soiland-Reyes <st...@apache.org>
Authored: Mon Apr 18 14:52:18 2016 +0100
Committer: Stian Soiland-Reyes <st...@apache.org>
Committed: Mon Apr 18 14:54:14 2016 +0100

----------------------------------------------------------------------
 pom.xml | 5 ++++-
 1 file changed, 4 insertions(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/e3ca3017/pom.xml
----------------------------------------------------------------------
diff --git a/pom.xml b/pom.xml
index d3da45e..323d3d7 100644
--- a/pom.xml
+++ b/pom.xml
@@ -231,7 +231,7 @@
     </dependencyManagement>
 
     <build>
-        <finalName>apache-commons-rdf</finalName>
+        <!--<finalName>apache-${project.artifactId}-${project.version}</finalName>-->
         <plugins>
             <plugin>
                 <groupId>org.apache.maven.plugins</groupId>
@@ -429,6 +429,9 @@
                             <exclude>examples/.settings/**</exclude>
                             <exclude>examples/.project</exclude>
                             <exclude>examples/.classpath</exclude>
+                            <exclude>**/META-INF/services/*</exclude>
+                            <exclude>**/src/main/resources/NOTICE</exclude>
+                            <exclude>**/src/main/resources/LICENSE</exclude>
                         </excludes>
                     </configuration>
                 </plugin>


[38/50] incubator-commonsrdf git commit: adapted release urls

Posted by st...@apache.org.
adapted release urls


Project: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/commit/e20c41b4
Tree: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/tree/e20c41b4
Diff: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/diff/e20c41b4

Branch: refs/heads/parser-with-quads
Commit: e20c41b4c47970abf19cbc53d58cd377b849f8b1
Parents: 42089a8
Author: Sergio Fern�ndez <wi...@apache.org>
Authored: Tue May 24 09:58:47 2016 +0200
Committer: Sergio Fern�ndez <wi...@apache.org>
Committed: Tue May 24 09:58:57 2016 +0200

----------------------------------------------------------------------
 src/site/markdown/download.md | 12 ++++--------
 1 file changed, 4 insertions(+), 8 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/e20c41b4/src/site/markdown/download.md
----------------------------------------------------------------------
diff --git a/src/site/markdown/download.md b/src/site/markdown/download.md
index f2617cb..117797c 100644
--- a/src/site/markdown/download.md
+++ b/src/site/markdown/download.md
@@ -71,14 +71,10 @@ which is also [mirrored to GitHub](http://github.com/apache/incubator-commonsrdf
 from official mirrors of the
 ASF Distribution Directory [incubator/commonsrdf](https://www.apache.org/dyn/closer.lua/incubator/commonsrdf/0.2.0-incubating/):
 
-* [apache-commons-rdf-0.2.0-incubating-src.zip](https://www.apache.org/dyn/closer.lua/incubator/commonsrdf/0.2.0-incubating/apache-commons-rdf-0.2.0-incubating-src.zip)
-  ([asc](https://dist.apache.org/repos/dist/release/incubator/commonsrdf/0.2.0-incubating/apache-commons-rdf-0.2.0-incubating-src.zip.asc),
-  [md5](https://dist.apache.org/repos/dist/release/incubator/commonsrdf/0.2.0-incubating/apache-commons-rdf-0.2.0-incubating-src.zip.md5),
-  [sha1](https://dist.apache.org/repos/dist/release/incubator/commonsrdf/0.2.0-incubating/apache-commons-rdf-0.2.0-incubating-src.zip.sha1))
-* [apache-commons-rdf-0.2.0-incubating-src.tar.gz](https://www.apache.org/dyn/closer.lua/incubator/commonsrdf/0.2.0-incubating/apache-commons-rdf-0.2.0-incubating-src.tar.gz)
-  ([asc](https://dist.apache.org/repos/dist/release/incubator/commonsrdf/0.2.0-incubating/apache-commons-rdf-0.2.0-incubating-src.tar.gz.asc),
-  [md5](https://dist.apache.org/repos/dist/release/incubator/commonsrdf/0.2.0-incubating//apache-commons-rdf-0.2.0-incubating-src.tar.gz.md5),
-  [sha1](https://dist.apache.org/repos/dist/release/incubator/commonsrdf/0.2.0-incubating/apache-commons-rdf-0.2.0-incubating-src.tar.gz.sha1))
+* [apache-commonsrdf-0.2.0-incubating-source-release.zip](https://www.apache.org/dyn/closer.lua/incubator/commonsrdf/0.2.0-incubating/apache-commonsrdf-0.2.0-incubating-source-release.zip)
+  ([asc](https://dist.apache.org/repos/dist/release/incubator/commonsrdf/0.2.0-incubating/apache-commonsrdf-0.2.0-incubating-source-release.zip.asc),
+  [md5](https://dist.apache.org/repos/dist/release/incubator/commonsrdf/0.2.0-incubating/apache-commonsrdf-0.2.0-incubating-source-release.zip.md5),
+  [sha1](https://dist.apache.org/repos/dist/release/incubator/commonsrdf/0.2.0-incubating/apache-commonsrdf-0.2.0-incubating-source-release.zip.sha1))
 
 After downloading the files, check the signatures using the following [KEYS](https://dist.apache.org/repos/dist/release/incubator/commonsrdf/KEYS)
 file. The [changelog](https://s.apache.org/0.2.0-incubating)


[21/50] incubator-commonsrdf git commit: Update version numbers for commonsrdf for release 0.2.0-incubating

Posted by st...@apache.org.
Update version numbers for commonsrdf for release 0.2.0-incubating


Project: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/commit/733359b9
Tree: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/tree/733359b9
Diff: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/diff/733359b9

Branch: refs/heads/parser-with-quads
Commit: 733359b94b2f716a36c092e2fb05034ffdd0ba80
Parents: beaeea3
Author: Lewis John McGibbney <le...@jpl.nasa.gov>
Authored: Thu Apr 28 16:26:25 2016 -0700
Committer: Lewis John McGibbney <le...@jpl.nasa.gov>
Committed: Thu Apr 28 16:26:25 2016 -0700

----------------------------------------------------------------------
 api/pom.xml    | 2 +-
 pom.xml        | 2 +-
 simple/pom.xml | 2 +-
 3 files changed, 3 insertions(+), 3 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/733359b9/api/pom.xml
----------------------------------------------------------------------
diff --git a/api/pom.xml b/api/pom.xml
index 46564b6..bc8e506 100644
--- a/api/pom.xml
+++ b/api/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.commons</groupId>
         <artifactId>commons-rdf-parent</artifactId>
-        <version>0.2.1-incubating-SNAPSHOT</version>
+        <version>0.2.0-incubating</version>
     </parent>
 
     <artifactId>commons-rdf-api</artifactId>

http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/733359b9/pom.xml
----------------------------------------------------------------------
diff --git a/pom.xml b/pom.xml
index 3b17b0d..76a24bb 100644
--- a/pom.xml
+++ b/pom.xml
@@ -29,7 +29,7 @@
 
     <groupId>org.apache.commons</groupId>
     <artifactId>commons-rdf-parent</artifactId>
-    <version>0.2.1-incubating-SNAPSHOT</version>
+    <version>0.2.0-incubating</version>
     <packaging>pom</packaging>
 
     <name>Commons RDF</name>

http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/733359b9/simple/pom.xml
----------------------------------------------------------------------
diff --git a/simple/pom.xml b/simple/pom.xml
index e12c80a..170716a 100644
--- a/simple/pom.xml
+++ b/simple/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.commons</groupId>
         <artifactId>commons-rdf-parent</artifactId>
-        <version>0.2.1-incubating-SNAPSHOT</version>
+        <version>0.2.0-incubating</version>
     </parent>
 
     <artifactId>commons-rdf-simple</artifactId>


[02/50] incubator-commonsrdf git commit: Merge branch 'master' into COMMONSRDF-8-graph-add-blanknode

Posted by st...@apache.org.
Merge branch 'master' into COMMONSRDF-8-graph-add-blanknode


Project: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/commit/c8099bcd
Tree: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/tree/c8099bcd
Diff: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/diff/c8099bcd

Branch: refs/heads/parser-with-quads
Commit: c8099bcde882349030105568e39a9c1eadd72418
Parents: a79ff94 0a148cb
Author: Stian Soiland-Reyes <st...@apache.org>
Authored: Mon Apr 11 15:20:19 2016 +0100
Committer: Stian Soiland-Reyes <st...@apache.org>
Committed: Mon Apr 11 15:20:19 2016 +0100

----------------------------------------------------------------------
 .travis.yml                                     |   2 -
 .../org/apache/commons/rdf/api/RDFSyntax.java   | 183 +++++++++++++++++++
 .../apache/commons/rdf/api/RDFTermFactory.java  |  12 +-
 .../apache/commons/rdf/api/package-info.java    |   3 +
 api/src/main/resources/META-INF/NOTICE          |   2 +-
 .../commons/rdf/api/AbstractGraphTest.java      |  42 ++---
 .../apache/commons/rdf/api/RDFSyntaxTest.java   | 115 ++++++++++++
 .../commons/rdf/simple/BlankNodeImpl.java       |   3 +-
 .../apache/commons/rdf/simple/GraphImpl.java    |  18 +-
 .../org/apache/commons/rdf/simple/IRIImpl.java  |   2 +-
 .../apache/commons/rdf/simple/LiteralImpl.java  |   2 +-
 .../rdf/simple/SimpleRDFTermFactory.java        |  12 ++
 .../org/apache/commons/rdf/simple/Types.java    |   2 +-
 simple/src/main/resources/META-INF/NOTICE       |   2 +-
 .../commons/rdf/simple/SimpleGraphTest.java     |  17 ++
 15 files changed, 369 insertions(+), 48 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/c8099bcd/api/src/test/java/org/apache/commons/rdf/api/AbstractGraphTest.java
----------------------------------------------------------------------


[25/50] incubator-commonsrdf git commit: Add SNAPSHOT prepping for new 0.2.0-incubating release

Posted by st...@apache.org.
Add SNAPSHOT prepping for new 0.2.0-incubating release


Project: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/commit/1fdd553c
Tree: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/tree/1fdd553c
Diff: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/diff/1fdd553c

Branch: refs/heads/parser-with-quads
Commit: 1fdd553c470f1a1b87034643f5a0f2bd5883697f
Parents: 20905e6
Author: Lewis John McGibbney <le...@gmail.com>
Authored: Thu May 5 19:13:57 2016 -0700
Committer: Lewis John McGibbney <le...@gmail.com>
Committed: Thu May 5 19:13:57 2016 -0700

----------------------------------------------------------------------
 pom.xml | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/1fdd553c/pom.xml
----------------------------------------------------------------------
diff --git a/pom.xml b/pom.xml
index 5bf0180..c133d7c 100644
--- a/pom.xml
+++ b/pom.xml
@@ -29,7 +29,7 @@
 
     <groupId>org.apache.commons</groupId>
     <artifactId>commons-rdf-parent</artifactId>
-    <version>0.3.0-incubating</version>
+    <version>0.2.0-incubating-SNAPSHOT</version>
     <packaging>pom</packaging>
 
     <name>Commons RDF</name>


[42/50] incubator-commonsrdf git commit: GraphLike javadoc tweaks

Posted by st...@apache.org.
GraphLike javadoc tweaks


Project: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/commit/c7e1a5bd
Tree: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/tree/c7e1a5bd
Diff: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/diff/c7e1a5bd

Branch: refs/heads/parser-with-quads
Commit: c7e1a5bde5e3b8209cb15099a7ceaef6ced57e7f
Parents: b25af13
Author: Stian Soiland-Reyes <st...@apache.org>
Authored: Thu Jun 2 12:18:03 2016 +0100
Committer: Stian Soiland-Reyes <st...@apache.org>
Committed: Thu Jun 2 12:18:03 2016 +0100

----------------------------------------------------------------------
 .../org/apache/commons/rdf/api/GraphLike.java   | 20 +++----
 .../java/org/apache/commons/rdf/api/Quad.java   |  4 +-
 .../org/apache/commons/rdf/api/QuadLike.java    | 51 +++++++---------
 .../org/apache/commons/rdf/api/TripleLike.java  | 63 +++++++++-----------
 4 files changed, 63 insertions(+), 75 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/c7e1a5bd/api/src/main/java/org/apache/commons/rdf/api/GraphLike.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/org/apache/commons/rdf/api/GraphLike.java b/api/src/main/java/org/apache/commons/rdf/api/GraphLike.java
index 57b55cb..28c2f10 100644
--- a/api/src/main/java/org/apache/commons/rdf/api/GraphLike.java
+++ b/api/src/main/java/org/apache/commons/rdf/api/GraphLike.java
@@ -26,10 +26,10 @@ import java.util.stream.Stream;
  * Extended by {@link Graph} (for {@link Triple}) and {@link Dataset} (for
  * {@link Quad}).
  * <p>
- * Unlike {@link Graph} and {@link Dataset}, this interface can support
- * with generalised {@link TripleLike} or {@link QuadLike} statements, and
- * does not include semantics like {@link #size()} or the requirement of
- * mapping {@link RDFTerm} instances from different implementations.
+ * Unlike {@link Graph} and {@link Dataset}, this interface can support with
+ * generalised {@link TripleLike} or {@link QuadLike} statements, and does not
+ * include semantics like {@link #size()} or the requirement of mapping
+ * {@link RDFTerm} instances from different implementations.
  * 
  * @see Graph
  * @see Dataset
@@ -83,14 +83,14 @@ public interface GraphLike<T extends TripleLike<S, P, O>, S extends RDFTerm, P e
 
 	/**
 	 * Iterate over contained statements.
-	 *  
+	 * 
 	 * @return An {@link Iterable} of {@link TripleLike} statements.
 	 * 
-     * @throws IllegalStateException
-     *             if the {@link Iterable} has been reused
-     * @throws ConcurrentModificationException
-     *             if a concurrency conflict occurs while the Iterator is
-     *             active.
+	 * @throws IllegalStateException
+	 *             if the {@link Iterable} has been reused
+	 * @throws ConcurrentModificationException
+	 *             if a concurrency conflict occurs while the Iterator is
+	 *             active.
 	 */
 	Iterable<T> iterate() throws ConcurrentModificationException, IllegalStateException;
 

http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/c7e1a5bd/api/src/main/java/org/apache/commons/rdf/api/Quad.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/org/apache/commons/rdf/api/Quad.java b/api/src/main/java/org/apache/commons/rdf/api/Quad.java
index fa9298e..348595b 100644
--- a/api/src/main/java/org/apache/commons/rdf/api/Quad.java
+++ b/api/src/main/java/org/apache/commons/rdf/api/Quad.java
@@ -40,8 +40,8 @@ public interface Quad extends QuadLike<BlankNodeOrIRI,IRI,RDFTerm,BlankNodeOrIRI
 	 * If {@link Optional#isPresent()}, then the {@link Optional#get()} is
 	 * either a {@link BlankNode} or an {@link IRI}, indicating the
 	 * <a href="https://www.w3.org/TR/rdf11-concepts/#dfn-named-graph">graph
-	 * name of this Quad. If the graph name is not present (e.g. the value is
-	 * {@link Optional#empty()}), it indicates that this Quad is in the
+	 * name of this Quad. If the graph name is not present, e.g. the value is
+	 * {@link Optional#empty()}, it indicates that this Quad is in the
 	 * <a href="https://www.w3.org/TR/rdf11-concepts/#dfn-default-graph">default
 	 * graph.
 	 *

http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/c7e1a5bd/api/src/main/java/org/apache/commons/rdf/api/QuadLike.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/org/apache/commons/rdf/api/QuadLike.java b/api/src/main/java/org/apache/commons/rdf/api/QuadLike.java
index a47e32b..7ed7255 100644
--- a/api/src/main/java/org/apache/commons/rdf/api/QuadLike.java
+++ b/api/src/main/java/org/apache/commons/rdf/api/QuadLike.java
@@ -22,42 +22,35 @@ import java.util.Optional;
 /**
  * A generalised "quad-like" interface, extended by {@link Quad}.
  * <p>
- * A QuadLike has at least a 
- * {@link #getSubject()}, {@link #getPredicate()} and 
- * {@link #getObject()}, and a {@link #getGraphName()}, 
- * but unlike a {@link Quad} does not have a
- * formalised {@link Quad#equals(Object)} semantics, and allow
- * generalised quads (e.g. a BlankNode as predicate).
+ * A QuadLike statement has at least a {@link #getSubject()},
+ * {@link #getPredicate()}, {@link #getObject()} and {@link #getGraphName()},
+ * but unlike a {@link Quad} does not have a formalised
+ * {@link Quad#equals(Object)} semantics, and can allow generalised quads (e.g.
+ * a {@link BlankNode} as predicate).
  * <p>
- * Implementations should specialise which RDFTerm 
- * subclasses they return for subject {@link S}, 
- * predicate {@link P}, object {@link O} and graph name {@link G}.
+ * Implementations should specialise which {@link RDFTerm} subclasses they
+ * return for subject {@link S}, predicate {@link P}, object {@link O} and graph
+ * name {@link G}.
  * <p>
+ * 
  * @see Quad
  */
-public interface QuadLike <S extends RDFTerm, P extends RDFTerm, O extends RDFTerm, G extends RDFTerm> 
-	extends TripleLike<S,P,O> {
-
+public interface QuadLike<S extends RDFTerm, P extends RDFTerm, O extends RDFTerm, G extends RDFTerm>
+		extends TripleLike<S, P, O> {
 
 	/**
-	 * The graph name (graph label) of this quad, if present.
-	 * 
-	 * If {@link Optional#isPresent()}, then the {@link Optional#get()} 
-	 * indicate the
-	 * <a href="https://www.w3.org/TR/rdf11-concepts/#dfn-named-graph">graph
-	 * name of this Quad. If the graph name is not present (e.g. the value is
-	 * {@link Optional#empty()}), it indicates that this Quad is in the
-	 * <a href="https://www.w3.org/TR/rdf11-concepts/#dfn-default-graph">default
-	 * graph.
+	 * The graph name (graph label) of this statement, if present.
+	 * <p>
+	 * If {@link Optional#isPresent()}, then the {@link Optional#get()} indicate
+	 * the graph name of this statement. If the graph name is not present,e.g.
+	 * the value is {@link Optional#empty()}, it indicates that this Quad is in
+	 * the default graph.
 	 *
-	 * @return If {@link Optional#isPresent()}, the graph name
-	 *         of this quad, otherwise. The graph name is typically an
-	 *         {@link IRI} or {@link BlankNode}.
-	 *         {@link Optional#empty()}, indicating the default graph.
-	 * 
-	 * @see <a href="https://www.w3.org/TR/rdf11-concepts/#dfn-rdf-dataset">RDF-
-	 *      1.1 Dataset</a>
+	 * @return If {@link Optional#isPresent()}, the graph name of this quad,
+	 *         otherwise {@link Optional#empty()}, indicating the default
+	 *         graph. The graph name is typically an {@link IRI} or
+	 *         {@link BlankNode}.
 	 */
 	Optional<G> getGraphName();
-	
+
 }

http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/c7e1a5bd/api/src/main/java/org/apache/commons/rdf/api/TripleLike.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/org/apache/commons/rdf/api/TripleLike.java b/api/src/main/java/org/apache/commons/rdf/api/TripleLike.java
index 1ed75d0..c061cc7 100644
--- a/api/src/main/java/org/apache/commons/rdf/api/TripleLike.java
+++ b/api/src/main/java/org/apache/commons/rdf/api/TripleLike.java
@@ -18,48 +18,43 @@
 package org.apache.commons.rdf.api;
 
 /**
- * A generalised "triple-like" interface, extended by {@link Triple} and {@link Quad}.
+ * A generalised "triple-like" interface, extended by {@link Triple} and
+ * {@link Quad}.
  * <p>
- * A TripleLike has at least a 
- * {@link #getSubject()}, {@link #getPredicate()} and 
- * {@link #getObject()}, but unlike a {@link Triple} does not have a
- * formalised {@link Triple#equals(Object)} semantics, and allow
- * generalised triples (e.g. a BlankNode as predicate).
- * <p>
- * Implementations should specialise which RDFTerms subclasses 
- * they return for subject, predicate and object.
+ * A TripleLike statement has at least a {@link #getSubject()},
+ * {@link #getPredicate()} and {@link #getObject()}, but unlike a {@link Triple}
+ * does not have a formalised {@link Triple#equals(Object)} semantics, and can
+ * allow generalised triples (e.g. a {@link BlankNode} as predicate).
  * <p>
+ * Implementations should specialise which {@link RDFTerm} subclasses they
+ * return for subject {@link S}, predicate {@link P} and object {@link O}.
+ * 
  * @see Triple
  * @see Quad
  * @see QuadLike
  * 
  */
-public interface TripleLike <S extends RDFTerm, P extends RDFTerm, O extends RDFTerm> {
+public interface TripleLike<S extends RDFTerm, P extends RDFTerm, O extends RDFTerm> {
 
-    /**
-     * The subject of this statement.
-     *
-     * @return The subject, typically an {@link IRI} or {@link BlankNode}.
-     * @see <a href="http://www.w3.org/TR/rdf11-concepts/#dfn-subject">RDF-1.1
-     * Triple subject</a>
-     */
-    S getSubject();
+	/**
+	 * The subject of this statement.
+	 *
+	 * @return The subject, typically an {@link IRI} or {@link BlankNode}.
+	 */
+	S getSubject();
 
-    /**
-     * The predicate of this statement.
-     *
-     * @return The predicate, typically an {@link IRI}.
-     * @see <a href="http://www.w3.org/TR/rdf11-concepts/#dfn-predicate">RDF-1.1
-     * Triple predicate</a>
-     */
-    P getPredicate();
+	/**
+	 * The predicate of this statement.
+	 *
+	 * @return The predicate, typically an {@link IRI}.
+	 */
+	P getPredicate();
 
-    /**
-     * The object of this statement.
-     *
-     * @return The object, typically an {@link IRI}, {@link BlankNode} or {@link Literal}.
-     * @see <a href="http://www.w3.org/TR/rdf11-concepts/#dfn-object">RDF-1.1
-     * Triple object</a>
-     */
-    O getObject();
+	/**
+	 * The object of this statement.
+	 *
+	 * @return The object, typically an {@link IRI}, {@link BlankNode} or
+	 *         {@link Literal}.
+	 */
+	O getObject();
 }


[28/50] incubator-commonsrdf git commit: [maven-release-plugin] prepare for next development iteration

Posted by st...@apache.org.
[maven-release-plugin] prepare for next development iteration


Project: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/commit/b39f8001
Tree: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/tree/b39f8001
Diff: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/diff/b39f8001

Branch: refs/heads/parser-with-quads
Commit: b39f8001c3b06c08c461e7a81755761858779135
Parents: 433ffd9
Author: Sergio Fern�ndez <wi...@apache.org>
Authored: Thu May 12 15:13:03 2016 -0700
Committer: Sergio Fern�ndez <wi...@apache.org>
Committed: Thu May 12 15:13:03 2016 -0700

----------------------------------------------------------------------
 api/pom.xml    | 6 +-----
 pom.xml        | 4 ++--
 simple/pom.xml | 7 +------
 3 files changed, 4 insertions(+), 13 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/b39f8001/api/pom.xml
----------------------------------------------------------------------
diff --git a/api/pom.xml b/api/pom.xml
index b6e73ab..4b13406 100644
--- a/api/pom.xml
+++ b/api/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.commons</groupId>
         <artifactId>commons-rdf-parent</artifactId>
-        <version>0.2.0-incubating</version>
+        <version>0.3.0-incubating-SNAPSHOT</version>
     </parent>
 
     <artifactId>commons-rdf-api</artifactId>
@@ -58,8 +58,4 @@
             </plugin>
         </plugins>
     </build>
-
-  <scm>
-    <tag>0.2.0-incubating-RC3</tag>
-  </scm>
 </project>

http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/b39f8001/pom.xml
----------------------------------------------------------------------
diff --git a/pom.xml b/pom.xml
index 3c247a8..a782b5b 100644
--- a/pom.xml
+++ b/pom.xml
@@ -29,7 +29,7 @@
 
     <groupId>org.apache.commons</groupId>
     <artifactId>commons-rdf-parent</artifactId>
-    <version>0.2.0-incubating</version>
+    <version>0.3.0-incubating-SNAPSHOT</version>
     <packaging>pom</packaging>
 
     <name>Commons RDF</name>
@@ -66,7 +66,7 @@
         <url>https://git-wip-us.apache.org/repos/asf/incubator-commonsrdf.git</url>
         <connection>scm:git:https://git-wip-us.apache.org/repos/asf/incubator-commonsrdf.git</connection>
         <developerConnection>scm:git:https://git-wip-us.apache.org/repos/asf/incubator-commonsrdf.git</developerConnection>
-        <tag>0.2.0-incubating-RC3</tag>
+        <tag>HEAD</tag>
     </scm>
 
     <issueManagement>

http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/b39f8001/simple/pom.xml
----------------------------------------------------------------------
diff --git a/simple/pom.xml b/simple/pom.xml
index fea8e62..bc8a861 100644
--- a/simple/pom.xml
+++ b/simple/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.commons</groupId>
         <artifactId>commons-rdf-parent</artifactId>
-        <version>0.2.0-incubating</version>
+        <version>0.3.0-incubating-SNAPSHOT</version>
     </parent>
 
     <artifactId>commons-rdf-simple</artifactId>
@@ -52,9 +52,4 @@
             <scope>test</scope>
         </dependency>
     </dependencies>
-
-
-  <scm>
-    <tag>0.2.0-incubating-RC3</tag>
-  </scm>
 </project>


[17/50] incubator-commonsrdf git commit: Prepare Commons RDF for 0.2.0-incubating RC#1

Posted by st...@apache.org.
Prepare Commons RDF for 0.2.0-incubating RC#1


Project: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/commit/144c362f
Tree: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/tree/144c362f
Diff: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/diff/144c362f

Branch: refs/heads/parser-with-quads
Commit: 144c362fb696f79f68ded6cdec522c440e487366
Parents: 4d229d7
Author: Lewis John McGibbney <le...@jpl.nasa.gov>
Authored: Thu Apr 28 15:55:03 2016 -0700
Committer: Lewis John McGibbney <le...@jpl.nasa.gov>
Committed: Thu Apr 28 15:55:03 2016 -0700

----------------------------------------------------------------------
 pom.xml                       |  2 +-
 src/site/markdown/download.md | 32 ++++++++++++++++++--------------
 2 files changed, 19 insertions(+), 15 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/144c362f/pom.xml
----------------------------------------------------------------------
diff --git a/pom.xml b/pom.xml
index 269a39f..6ed249b 100644
--- a/pom.xml
+++ b/pom.xml
@@ -53,7 +53,7 @@
         <project.build.encoding>UTF-8</project.build.encoding>
         <commons.encoding>UTF-8</commons.encoding>
         <commons.componentid>rdf</commons.componentid>
-        <commons.release.version>0.1.0</commons.release.version>
+        <commons.release.version>0.2.0</commons.release.version>
         <commons.jira.id>COMMONSRDF</commons.jira.id>
         <commons.jira.pid>12316620</commons.jira.pid>
         <commons.site.path>rdf</commons.site.path>

http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/144c362f/src/site/markdown/download.md
----------------------------------------------------------------------
diff --git a/src/site/markdown/download.md b/src/site/markdown/download.md
index 792df3b..2eb2e32 100644
--- a/src/site/markdown/download.md
+++ b/src/site/markdown/download.md
@@ -39,13 +39,13 @@ To use Commons RDF with [Maven](https://maven.apache.org/), add to your `pom.xml
   <dependency>
       <groupId>org.apache.commons</groupId>
       <artifactId>commons-rdf-api</artifactId>
-      <version>0.1.0-incubating</version>
+      <version>0.2.0-incubating</version>
   </dependency>
   <!-- and optionally: -->
   <dependency>
       <groupId>org.apache.commons</groupId>
       <artifactId>commons-rdf-simple</artifactId>
-      <version>0.1.0-incubating</version>
+      <version>0.2.0-incubating</version>
       <optional>true</optional>
   </dependency>
 </dependencies>
@@ -65,21 +65,25 @@ For the latest developments
 you may also be interested in the [source code repository](source-repository.html),
 which is also [mirrored to GitHub](http://github.com/apache/incubator-commonsrdf).
 
-### 0.1.0-incubating
+### 0.2.0-incubating
 
-**Apache Commons RDF 0.1.0-incubating** was published on 2015-05-15, and is available for download
+**Apache Commons RDF 0.2.0-incubating** was published on 2016-04-28, and is available for download
 from official mirrors of the
-ASF Distribution Directory [incubator/commonsrdf](https://www.apache.org/dyn/closer.lua/incubator/commonsrdf/0.1.0-incubating/):
+ASF Distribution Directory [incubator/commonsrdf](https://www.apache.org/dyn/closer.lua/incubator/commonsrdf/0.2.0-incubating/):
 
-* [apache-commons-rdf-0.1.0-incubating-src.zip](https://www.apache.org/dyn/closer.lua/incubator/commonsrdf/0.1.0-incubating/apache-commons-rdf-0.1.0-incubating-src.zip)
-  ([asc](https://dist.apache.org/repos/dist/release/incubator/commonsrdf/0.1.0-incubating/apache-commons-rdf-0.1.0-incubating-src.zip.asc),
-  [md5](https://dist.apache.org/repos/dist/release/incubator/commonsrdf/0.1.0-incubating/apache-commons-rdf-0.1.0-incubating-src.zip.md5),
-  [sha1](https://dist.apache.org/repos/dist/release/incubator/commonsrdf/0.1.0-incubating/apache-commons-rdf-0.1.0-incubating-src.zip.sha1))
-* [apache-commons-rdf-0.1.0-incubating-src.tar.gz](https://www.apache.org/dyn/closer.lua/incubator/commonsrdf/0.1.0-incubating/apache-commons-rdf-0.1.0-incubating-src.tar.gz)
-  ([asc](https://dist.apache.org/repos/dist/release/incubator/commonsrdf/0.1.0-incubating/apache-commons-rdf-0.1.0-incubating-src.tar.gz.asc),
-  [md5](https://dist.apache.org/repos/dist/release/incubator/commonsrdf/0.1.0-incubating//apache-commons-rdf-0.1.0-incubating-src.tar.gz.md5),
-  [sha1](https://dist.apache.org/repos/dist/release/incubator/commonsrdf/0.1.0-incubating/apache-commons-rdf-0.1.0-incubating-src.tar.gz.sha1))
+* [apache-commons-rdf-0.2.0-incubating-src.zip](https://www.apache.org/dyn/closer.lua/incubator/commonsrdf/0.2.0-incubating/apache-commons-rdf-0.2.0-incubating-src.zip)
+  ([asc](https://dist.apache.org/repos/dist/release/incubator/commonsrdf/0.2.0-incubating/apache-commons-rdf-0.2.0-incubating-src.zip.asc),
+  [md5](https://dist.apache.org/repos/dist/release/incubator/commonsrdf/0.2.0-incubating/apache-commons-rdf-0.2.0-incubating-src.zip.md5),
+  [sha1](https://dist.apache.org/repos/dist/release/incubator/commonsrdf/0.2.0-incubating/apache-commons-rdf-0.2.0-incubating-src.zip.sha1))
+* [apache-commons-rdf-0.2.0-incubating-src.tar.gz](https://www.apache.org/dyn/closer.lua/incubator/commonsrdf/0.2.0-incubating/apache-commons-rdf-0.2.0-incubating-src.tar.gz)
+  ([asc](https://dist.apache.org/repos/dist/release/incubator/commonsrdf/0.2.0-incubating/apache-commons-rdf-0.2.0-incubating-src.tar.gz.asc),
+  [md5](https://dist.apache.org/repos/dist/release/incubator/commonsrdf/0.2.0-incubating//apache-commons-rdf-0.2.0-incubating-src.tar.gz.md5),
+  [sha1](https://dist.apache.org/repos/dist/release/incubator/commonsrdf/0.2.0-incubating/apache-commons-rdf-0.2.0-incubating-src.tar.gz.sha1))
 
 After downloading the files, check the signatures using the following [KEYS](https://dist.apache.org/repos/dist/release/incubator/commonsrdf/KEYS)
-file. The [changelog](https://issues.apache.org/jira/secure/ReleaseNote.jspa?projectId=12316620&amp;version=12332056)
+file. The [changelog](https://issues.apache.org/jira/secure/ReleaseNote.jspa?projectId=12316620&version=12332057)
 is available from the [Apache Commons RDF Jira](https://issues.apache.org/jira/browse/COMMONSRDF).
+
+### Previous Releases
+
+Previous release are available from [archive.apache.org](http://archive.apache.org/dist/incubator/commonsrdf/).


[44/50] incubator-commonsrdf git commit: Include @Deprecated getTriples()

Posted by st...@apache.org.
Include @Deprecated getTriples()

The default implementation calls .stream()

.. and @since for new Quad features


Project: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/commit/14e505e3
Tree: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/tree/14e505e3
Diff: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/diff/14e505e3

Branch: refs/heads/parser-with-quads
Commit: 14e505e33d10b72fc22efd5c7952ad63f16f2393
Parents: 14f246e
Author: Stian Soiland-Reyes <st...@apache.org>
Authored: Thu Jun 2 17:30:50 2016 +0100
Committer: Stian Soiland-Reyes <st...@apache.org>
Committed: Thu Jun 2 17:31:05 2016 +0100

----------------------------------------------------------------------
 .../java/org/apache/commons/rdf/api/Graph.java  | 30 ++++++++++++++++++--
 .../org/apache/commons/rdf/api/GraphLike.java   |  1 +
 .../java/org/apache/commons/rdf/api/Quad.java   |  1 +
 .../org/apache/commons/rdf/api/QuadLike.java    |  1 +
 .../org/apache/commons/rdf/api/TripleLike.java  |  1 +
 .../commons/rdf/api/AbstractGraphTest.java      |  4 +--
 6 files changed, 33 insertions(+), 5 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/14e505e3/api/src/main/java/org/apache/commons/rdf/api/Graph.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/org/apache/commons/rdf/api/Graph.java b/api/src/main/java/org/apache/commons/rdf/api/Graph.java
index 42ced98..6106bab 100644
--- a/api/src/main/java/org/apache/commons/rdf/api/Graph.java
+++ b/api/src/main/java/org/apache/commons/rdf/api/Graph.java
@@ -125,11 +125,12 @@ public interface Graph extends AutoCloseable,GraphLike<Triple, BlankNodeOrIRI, I
      * <p>
      * Implementations may throw {@link ConcurrentModificationException} from Stream
      * methods if they detect a conflict while the Stream is active.
-     *
+     * 
+     * @since 0.3.0-incubating
      * @return A {@link Stream} over all of the triples in the graph
      */
     Stream<? extends Triple> stream();
-
+    
     /**
      * Get all triples contained by the graph matched with the pattern.
      * <p>
@@ -142,7 +143,9 @@ public interface Graph extends AutoCloseable,GraphLike<Triple, BlankNodeOrIRI, I
      * <p>
      * Implementations may throw {@link ConcurrentModificationException} from Stream
      * methods if they detect a conflict while the Stream is active.
-     *
+     * <p>
+     * 
+     * @since 0.3.0-incubating
      * @param subject   The triple subject (null is a wildcard)
      * @param predicate The triple predicate (null is a wildcard)
      * @param object    The triple object (null is a wildcard)
@@ -152,6 +155,27 @@ public interface Graph extends AutoCloseable,GraphLike<Triple, BlankNodeOrIRI, I
                                         RDFTerm object);
 
     /**
+     * This method is deprecated, use the equivalent method 
+     * {@link #stream()} instead. 
+     * 
+     */
+    @Deprecated
+    default Stream<? extends Triple> getTriples() {
+    	return stream();
+    }
+
+    /**
+     * This method is deprecated, use the equivalent method 
+     * {@link #stream(BlankNodeOrIRI, IRI, RDFTerm)} instead.
+     * 
+     */
+    @Deprecated    
+    default Stream<? extends Triple> getTriples(BlankNodeOrIRI subject, IRI predicate,
+            RDFTerm object) {
+    	return stream(subject, predicate, object);
+    }
+    
+    /**
      * Get an Iterable for iterating over all triples in the graph.
      * <p>
      * This method is meant to be used with a Java for-each loop, e.g.:

http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/14e505e3/api/src/main/java/org/apache/commons/rdf/api/GraphLike.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/org/apache/commons/rdf/api/GraphLike.java b/api/src/main/java/org/apache/commons/rdf/api/GraphLike.java
index 28c2f10..c68278e 100644
--- a/api/src/main/java/org/apache/commons/rdf/api/GraphLike.java
+++ b/api/src/main/java/org/apache/commons/rdf/api/GraphLike.java
@@ -31,6 +31,7 @@ import java.util.stream.Stream;
  * include semantics like {@link #size()} or the requirement of mapping
  * {@link RDFTerm} instances from different implementations.
  * 
+ * @since 0.3.0-incubating
  * @see Graph
  * @see Dataset
  * @see TripleLike

http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/14e505e3/api/src/main/java/org/apache/commons/rdf/api/Quad.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/org/apache/commons/rdf/api/Quad.java b/api/src/main/java/org/apache/commons/rdf/api/Quad.java
index 348595b..5a67571 100644
--- a/api/src/main/java/org/apache/commons/rdf/api/Quad.java
+++ b/api/src/main/java/org/apache/commons/rdf/api/Quad.java
@@ -28,6 +28,7 @@ import java.util.Optional;
  * Concepts and Abstract Syntax</a>, a W3C Working Group Note published on 25
  * February 2014.
  * 
+ * @since 0.3.0-incubating
  * @see <a href="http://www.w3.org/TR/2014/NOTE-rdf11-datasets-20140225/">RDF
  *      1.1: On Semantics of RDF Datasets</a>
  * @see <a href="http://www.w3.org/TR/rdf11-concepts/#section-dataset"> </a>

http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/14e505e3/api/src/main/java/org/apache/commons/rdf/api/QuadLike.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/org/apache/commons/rdf/api/QuadLike.java b/api/src/main/java/org/apache/commons/rdf/api/QuadLike.java
index 7ed7255..9c42465 100644
--- a/api/src/main/java/org/apache/commons/rdf/api/QuadLike.java
+++ b/api/src/main/java/org/apache/commons/rdf/api/QuadLike.java
@@ -33,6 +33,7 @@ import java.util.Optional;
  * name {@link G}.
  * <p>
  * 
+ * @since 0.3.0-incubating
  * @see Quad
  */
 public interface QuadLike<S extends RDFTerm, P extends RDFTerm, O extends RDFTerm, G extends RDFTerm>

http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/14e505e3/api/src/main/java/org/apache/commons/rdf/api/TripleLike.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/org/apache/commons/rdf/api/TripleLike.java b/api/src/main/java/org/apache/commons/rdf/api/TripleLike.java
index c061cc7..2fbeb11 100644
--- a/api/src/main/java/org/apache/commons/rdf/api/TripleLike.java
+++ b/api/src/main/java/org/apache/commons/rdf/api/TripleLike.java
@@ -29,6 +29,7 @@ package org.apache.commons.rdf.api;
  * Implementations should specialise which {@link RDFTerm} subclasses they
  * return for subject {@link S}, predicate {@link P} and object {@link O}.
  * 
+ * @since 0.3.0-incubating
  * @see Triple
  * @see Quad
  * @see QuadLike

http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/14e505e3/api/src/test/java/org/apache/commons/rdf/api/AbstractGraphTest.java
----------------------------------------------------------------------
diff --git a/api/src/test/java/org/apache/commons/rdf/api/AbstractGraphTest.java b/api/src/test/java/org/apache/commons/rdf/api/AbstractGraphTest.java
index 27b9ff4..67191de 100644
--- a/api/src/test/java/org/apache/commons/rdf/api/AbstractGraphTest.java
+++ b/api/src/test/java/org/apache/commons/rdf/api/AbstractGraphTest.java
@@ -296,7 +296,7 @@ public abstract class AbstractGraphTest {
             
             // look up BlankNodes by name
             IRI name = factory.createIRI("http://xmlns.com/foaf/0.1/name");
-            g3.getTriples(null, name, null).parallel().forEach( t ->
+            g3.stream(null, name, null).parallel().forEach( t ->
                 whoIsWho.put( t.getObject().ntriplesString(), t.getSubject()));
                         
             assertEquals(4, whoIsWho.size());
@@ -361,7 +361,7 @@ public abstract class AbstractGraphTest {
 
         // unordered() as we don't need to preserve triple order
         // sequential() as we don't (currently) require target Graph to be thread-safe
-        source.getTriples().unordered().sequential().forEach(t -> target.add(t));
+        source.stream().unordered().sequential().forEach(t -> target.add(t));
     }
 
     /**


[27/50] incubator-commonsrdf git commit: [maven-release-plugin] prepare release 0.2.0-incubating-RC3

Posted by st...@apache.org.
[maven-release-plugin] prepare release 0.2.0-incubating-RC3


Project: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/commit/433ffd9d
Tree: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/tree/433ffd9d
Diff: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/diff/433ffd9d

Branch: refs/heads/parser-with-quads
Commit: 433ffd9da203a86dfceba95765dbf90dc039ef24
Parents: 35d4422
Author: Sergio Fern�ndez <wi...@apache.org>
Authored: Thu May 12 15:12:53 2016 -0700
Committer: Sergio Fern�ndez <wi...@apache.org>
Committed: Thu May 12 15:12:53 2016 -0700

----------------------------------------------------------------------
 api/pom.xml    | 6 +++++-
 pom.xml        | 4 ++--
 simple/pom.xml | 6 +++++-
 3 files changed, 12 insertions(+), 4 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/433ffd9d/api/pom.xml
----------------------------------------------------------------------
diff --git a/api/pom.xml b/api/pom.xml
index 42ad43b..b6e73ab 100644
--- a/api/pom.xml
+++ b/api/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.commons</groupId>
         <artifactId>commons-rdf-parent</artifactId>
-        <version>0.3.0-incubating</version>
+        <version>0.2.0-incubating</version>
     </parent>
 
     <artifactId>commons-rdf-api</artifactId>
@@ -58,4 +58,8 @@
             </plugin>
         </plugins>
     </build>
+
+  <scm>
+    <tag>0.2.0-incubating-RC3</tag>
+  </scm>
 </project>

http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/433ffd9d/pom.xml
----------------------------------------------------------------------
diff --git a/pom.xml b/pom.xml
index 0703995..3c247a8 100644
--- a/pom.xml
+++ b/pom.xml
@@ -29,7 +29,7 @@
 
     <groupId>org.apache.commons</groupId>
     <artifactId>commons-rdf-parent</artifactId>
-    <version>0.2.0-incubating-SNAPSHOT</version>
+    <version>0.2.0-incubating</version>
     <packaging>pom</packaging>
 
     <name>Commons RDF</name>
@@ -66,7 +66,7 @@
         <url>https://git-wip-us.apache.org/repos/asf/incubator-commonsrdf.git</url>
         <connection>scm:git:https://git-wip-us.apache.org/repos/asf/incubator-commonsrdf.git</connection>
         <developerConnection>scm:git:https://git-wip-us.apache.org/repos/asf/incubator-commonsrdf.git</developerConnection>
-        <tag>HEAD</tag>
+        <tag>0.2.0-incubating-RC3</tag>
     </scm>
 
     <issueManagement>

http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/433ffd9d/simple/pom.xml
----------------------------------------------------------------------
diff --git a/simple/pom.xml b/simple/pom.xml
index 773580d..fea8e62 100644
--- a/simple/pom.xml
+++ b/simple/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.commons</groupId>
         <artifactId>commons-rdf-parent</artifactId>
-        <version>0.3.0-incubating</version>
+        <version>0.2.0-incubating</version>
     </parent>
 
     <artifactId>commons-rdf-simple</artifactId>
@@ -53,4 +53,8 @@
         </dependency>
     </dependencies>
 
+
+  <scm>
+    <tag>0.2.0-incubating-RC3</tag>
+  </scm>
 </project>


[18/50] incubator-commonsrdf git commit: Prepare Commons RDF for 0.2.0-incubating RC#1

Posted by st...@apache.org.
Prepare Commons RDF for 0.2.0-incubating RC#1


Project: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/commit/476b030d
Tree: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/tree/476b030d
Diff: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/diff/476b030d

Branch: refs/heads/parser-with-quads
Commit: 476b030da801c273dc659fc39acececba1afe0dd
Parents: 144c362
Author: Lewis John McGibbney <le...@jpl.nasa.gov>
Authored: Thu Apr 28 15:58:33 2016 -0700
Committer: Lewis John McGibbney <le...@jpl.nasa.gov>
Committed: Thu Apr 28 15:58:33 2016 -0700

----------------------------------------------------------------------
 src/site/markdown/download.md | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/476b030d/src/site/markdown/download.md
----------------------------------------------------------------------
diff --git a/src/site/markdown/download.md b/src/site/markdown/download.md
index 2eb2e32..f2617cb 100644
--- a/src/site/markdown/download.md
+++ b/src/site/markdown/download.md
@@ -81,7 +81,7 @@ ASF Distribution Directory [incubator/commonsrdf](https://www.apache.org/dyn/clo
   [sha1](https://dist.apache.org/repos/dist/release/incubator/commonsrdf/0.2.0-incubating/apache-commons-rdf-0.2.0-incubating-src.tar.gz.sha1))
 
 After downloading the files, check the signatures using the following [KEYS](https://dist.apache.org/repos/dist/release/incubator/commonsrdf/KEYS)
-file. The [changelog](https://issues.apache.org/jira/secure/ReleaseNote.jspa?projectId=12316620&version=12332057)
+file. The [changelog](https://s.apache.org/0.2.0-incubating)
 is available from the [Apache Commons RDF Jira](https://issues.apache.org/jira/browse/COMMONSRDF).
 
 ### Previous Releases


[20/50] incubator-commonsrdf git commit: [maven-release-plugin] prepare for next development iteration

Posted by st...@apache.org.
[maven-release-plugin] prepare for next development iteration


Project: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/commit/beaeea36
Tree: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/tree/beaeea36
Diff: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/diff/beaeea36

Branch: refs/heads/parser-with-quads
Commit: beaeea362c707035f23e8673892f95040f9873b9
Parents: f02b6bd
Author: Lewis John McGibbney <le...@jpl.nasa.gov>
Authored: Thu Apr 28 16:04:56 2016 -0700
Committer: Lewis John McGibbney <le...@jpl.nasa.gov>
Committed: Thu Apr 28 16:04:56 2016 -0700

----------------------------------------------------------------------
 api/pom.xml    | 2 +-
 pom.xml        | 4 ++--
 simple/pom.xml | 2 +-
 3 files changed, 4 insertions(+), 4 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/beaeea36/api/pom.xml
----------------------------------------------------------------------
diff --git a/api/pom.xml b/api/pom.xml
index bc8e506..46564b6 100644
--- a/api/pom.xml
+++ b/api/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.commons</groupId>
         <artifactId>commons-rdf-parent</artifactId>
-        <version>0.2.0-incubating</version>
+        <version>0.2.1-incubating-SNAPSHOT</version>
     </parent>
 
     <artifactId>commons-rdf-api</artifactId>

http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/beaeea36/pom.xml
----------------------------------------------------------------------
diff --git a/pom.xml b/pom.xml
index b1ee489..3b17b0d 100644
--- a/pom.xml
+++ b/pom.xml
@@ -29,7 +29,7 @@
 
     <groupId>org.apache.commons</groupId>
     <artifactId>commons-rdf-parent</artifactId>
-    <version>0.2.0-incubating</version>
+    <version>0.2.1-incubating-SNAPSHOT</version>
     <packaging>pom</packaging>
 
     <name>Commons RDF</name>
@@ -66,7 +66,7 @@
         <url>https://git-wip-us.apache.org/repos/asf/incubator-commonsrdf.git</url>
         <connection>scm:git:https://git-wip-us.apache.org/repos/asf/incubator-commonsrdf.git</connection>
         <developerConnection>scm:git:https://git-wip-us.apache.org/repos/asf/incubator-commonsrdf.git</developerConnection>
-        <tag>0.2.0-incubating</tag>
+        <tag>HEAD</tag>
     </scm>
 
     <issueManagement>

http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/beaeea36/simple/pom.xml
----------------------------------------------------------------------
diff --git a/simple/pom.xml b/simple/pom.xml
index 170716a..e12c80a 100644
--- a/simple/pom.xml
+++ b/simple/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.commons</groupId>
         <artifactId>commons-rdf-parent</artifactId>
-        <version>0.2.0-incubating</version>
+        <version>0.2.1-incubating-SNAPSHOT</version>
     </parent>
 
     <artifactId>commons-rdf-simple</artifactId>


[09/50] incubator-commonsrdf git commit: src/assembly

Posted by st...@apache.org.
src/assembly


Project: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/commit/2ef0af94
Tree: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/tree/2ef0af94
Diff: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/diff/2ef0af94

Branch: refs/heads/parser-with-quads
Commit: 2ef0af94f423cc7faeee774ae3497699824da497
Parents: 3671b41
Author: Stian Soiland-Reyes <st...@apache.org>
Authored: Mon Apr 18 15:06:43 2016 +0100
Committer: Stian Soiland-Reyes <st...@apache.org>
Committed: Mon Apr 18 15:06:43 2016 +0100

----------------------------------------------------------------------
 pom.xml | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/2ef0af94/pom.xml
----------------------------------------------------------------------
diff --git a/pom.xml b/pom.xml
index 323d3d7..923f9c5 100644
--- a/pom.xml
+++ b/pom.xml
@@ -264,7 +264,7 @@
                 <executions>
                     <execution>
                         <configuration>
-                            <descriptor>src/main/assembly/src.xml</descriptor>
+                            <descriptor>src/assembly/src.xml</descriptor>
                             <finalName>apache-commons-rdf-${project.version}</finalName>
                             <tarLongFileMode>gnu</tarLongFileMode>
                         </configuration>


[22/50] incubator-commonsrdf git commit: Set new development version to 0.3.0-incubating

Posted by st...@apache.org.
Set new development version to 0.3.0-incubating


Project: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/commit/0d92cecb
Tree: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/tree/0d92cecb
Diff: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/diff/0d92cecb

Branch: refs/heads/parser-with-quads
Commit: 0d92cecb383a1191f6e4eca4d292e3795d989273
Parents: 733359b
Author: Lewis John McGibbney <le...@gmail.com>
Authored: Thu Apr 28 16:39:18 2016 -0700
Committer: Lewis John McGibbney <le...@gmail.com>
Committed: Thu Apr 28 16:39:18 2016 -0700

----------------------------------------------------------------------
 api/pom.xml    | 2 +-
 pom.xml        | 2 +-
 simple/pom.xml | 2 +-
 3 files changed, 3 insertions(+), 3 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/0d92cecb/api/pom.xml
----------------------------------------------------------------------
diff --git a/api/pom.xml b/api/pom.xml
index bc8e506..42ad43b 100644
--- a/api/pom.xml
+++ b/api/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.commons</groupId>
         <artifactId>commons-rdf-parent</artifactId>
-        <version>0.2.0-incubating</version>
+        <version>0.3.0-incubating</version>
     </parent>
 
     <artifactId>commons-rdf-api</artifactId>

http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/0d92cecb/pom.xml
----------------------------------------------------------------------
diff --git a/pom.xml b/pom.xml
index 76a24bb..31b80f1 100644
--- a/pom.xml
+++ b/pom.xml
@@ -29,7 +29,7 @@
 
     <groupId>org.apache.commons</groupId>
     <artifactId>commons-rdf-parent</artifactId>
-    <version>0.2.0-incubating</version>
+    <version>0.3.0-incubating</version>
     <packaging>pom</packaging>
 
     <name>Commons RDF</name>

http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/0d92cecb/simple/pom.xml
----------------------------------------------------------------------
diff --git a/simple/pom.xml b/simple/pom.xml
index 170716a..773580d 100644
--- a/simple/pom.xml
+++ b/simple/pom.xml
@@ -24,7 +24,7 @@
     <parent>
         <groupId>org.apache.commons</groupId>
         <artifactId>commons-rdf-parent</artifactId>
-        <version>0.2.0-incubating</version>
+        <version>0.3.0-incubating</version>
     </parent>
 
     <artifactId>commons-rdf-simple</artifactId>


[03/50] incubator-commonsrdf git commit: Remove req f1.createBlankNode("a") differ f2.createBlankNode("b")

Posted by st...@apache.org.
Remove req f1.createBlankNode("a") differ f2.createBlankNode("b")

.. but still test we can add blank nodes from two fresh graphs/factories into a third graph.


Project: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/commit/6fa2b48c
Tree: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/tree/6fa2b48c
Diff: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/diff/6fa2b48c

Branch: refs/heads/parser-with-quads
Commit: 6fa2b48c92aea04ac41b3136f9f3a162293139e1
Parents: c8099bc
Author: Stian Soiland-Reyes <st...@apache.org>
Authored: Mon Apr 11 15:33:26 2016 +0100
Committer: Stian Soiland-Reyes <st...@apache.org>
Committed: Mon Apr 11 15:33:26 2016 +0100

----------------------------------------------------------------------
 .../commons/rdf/api/AbstractGraphTest.java      | 31 ++++++++++++--------
 .../rdf/api/AbstractRDFTermFactoryTest.java     | 17 ++++++++---
 2 files changed, 31 insertions(+), 17 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/6fa2b48c/api/src/test/java/org/apache/commons/rdf/api/AbstractGraphTest.java
----------------------------------------------------------------------
diff --git a/api/src/test/java/org/apache/commons/rdf/api/AbstractGraphTest.java b/api/src/test/java/org/apache/commons/rdf/api/AbstractGraphTest.java
index 8b1d2f9..a6c4397 100644
--- a/api/src/test/java/org/apache/commons/rdf/api/AbstractGraphTest.java
+++ b/api/src/test/java/org/apache/commons/rdf/api/AbstractGraphTest.java
@@ -273,21 +273,30 @@ public abstract class AbstractGraphTest {
     public void addBlankNodesFromMultipleGraphs() {
 
         try {
+        	// Create two separate Graph instances
             Graph g1 = createGraph1();
             Graph g2 = createGraph2();
-            Graph g3 = factory.createGraph();
 
+            // and add them to a new Graph g3
+            Graph g3 = factory.createGraph();  
             addAllTriples(g1, g3);
             addAllTriples(g2, g3);
 
-            IRI name = factory.createIRI("http://xmlns.com/foaf/0.1/name");
+            
+            // Let's make a map to find all those blank nodes after insertion
+            // (The Graph implementation is not currently required to 
+            // keep supporting those BlankNodes with contains() - see COMMONSRDF-15)
 
             final Map<String, BlankNodeOrIRI> whoIsWho = new ConcurrentHashMap<>();
             // ConcurrentHashMap as we will try parallel forEach below,
             // which should not give inconsistent results (it does with a
             // HashMap!)
+            
+            // look up BlankNodes by name
+            IRI name = factory.createIRI("http://xmlns.com/foaf/0.1/name");
             g3.getTriples(null, name, null).parallel().forEach( t ->
                 whoIsWho.put( t.getObject().ntriplesString(), t.getSubject()));
+                        
             assertEquals(4, whoIsWho.size());
             // and contains 4 unique values
             assertEquals(4, new HashSet<BlankNodeOrIRI>(whoIsWho.values()).size());
@@ -301,6 +310,7 @@ public abstract class AbstractGraphTest {
             BlankNodeOrIRI b2Dave = whoIsWho.get("\"Dave\"");
             assertNotNull(b2Dave);
 
+            // All blank nodes should differ
             notEquals(b1Alice, b2Bob);
             notEquals(b1Alice, b1Charlie);
             notEquals(b1Alice, b2Dave);
@@ -308,6 +318,8 @@ public abstract class AbstractGraphTest {
             notEquals(b2Bob, b2Dave);
             notEquals(b1Charlie, b2Dave);
 
+            // And we should be able to query with them again
+            // as we got them back from g3
             IRI hasChild = factory.createIRI("http://example.com/hasChild");
             assertTrue(g3.contains(b1Alice, hasChild, b2Bob));
             assertTrue(g3.contains(b2Dave, hasChild, b1Charlie));
@@ -352,16 +364,13 @@ public abstract class AbstractGraphTest {
 
     private Graph createGraph1() {
         RDFTermFactory factory1 = createFactory();
-        // Let's assume this is parsed from
-        // a Turtle file <g1.ttl>, and faithfully keeps its
-        // internal blank node identifiers _:b1 and _:b2
 
         IRI name = factory1.createIRI("http://xmlns.com/foaf/0.1/name");
         Graph g1 = factory1.createGraph();
-        BlankNode b1 = factory1.createBlankNode("b1");
+        BlankNode b1 = factory1.createBlankNode();
         g1.add(b1, name, factory1.createLiteral("Alice"));
 
-        BlankNode b2 = factory1.createBlankNode("b2");
+        BlankNode b2 = factory1.createBlankNode();
         g1.add(b2, name, factory1.createLiteral("Bob"));
 
         IRI hasChild = factory1.createIRI("http://example.com/hasChild");
@@ -371,19 +380,15 @@ public abstract class AbstractGraphTest {
     }
 
     private Graph createGraph2() {
-        // Let's assume this is parsed from
-        // a Turtle file <g2.ttl>, which also uses the
-        // internal blank node identifiers _:b1 and _:b2,
-        // but is describing someone else.
         RDFTermFactory factory2 = createFactory();
         IRI name = factory2.createIRI("http://xmlns.com/foaf/0.1/name");
 
         Graph g2 = factory2.createGraph();
 
-        BlankNode b1 = factory2.createBlankNode("b1");
+        BlankNode b1 = factory2.createBlankNode();
         g2.add(b1, name, factory2.createLiteral("Charlie"));
 
-        BlankNode b2 = factory2.createBlankNode("b2");
+        BlankNode b2 = factory2.createBlankNode();
         g2.add(b2, name, factory2.createLiteral("Dave"));
 
         IRI hasChild = factory2.createIRI("http://example.com/hasChild");

http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/6fa2b48c/api/src/test/java/org/apache/commons/rdf/api/AbstractRDFTermFactoryTest.java
----------------------------------------------------------------------
diff --git a/api/src/test/java/org/apache/commons/rdf/api/AbstractRDFTermFactoryTest.java b/api/src/test/java/org/apache/commons/rdf/api/AbstractRDFTermFactoryTest.java
index 5056c9d..17dd05f 100644
--- a/api/src/test/java/org/apache/commons/rdf/api/AbstractRDFTermFactoryTest.java
+++ b/api/src/test/java/org/apache/commons/rdf/api/AbstractRDFTermFactoryTest.java
@@ -117,9 +117,18 @@ public abstract class AbstractRDFTermFactoryTest {
     public void testCreateBlankNodeIdentifierTwiceDifferentFactories() throws Exception {
         BlankNode bnode1, differentFactory;
         try {
-            bnode1 = factory.createBlankNode("example1");
-            // it should differ from a second factory
-            differentFactory = createFactory().createBlankNode("example1");
+            bnode1 = factory.createBlankNode();
+            // it MUST differ from a second factory
+            differentFactory = createFactory().createBlankNode();
+            
+            // NOTE: We can't make similar assumption if we provide a 
+            // name to createBlankNode(String) as its documentation
+            // only says:
+            // 
+            // * BlankNodes created using this method with the same parameter, for
+            // * different instances of RDFTermFactory, SHOULD NOT be equivalent.
+            //
+            // https://github.com/apache/incubator-commonsrdf/pull/7#issuecomment-92312779
         } catch (UnsupportedOperationException ex) {
             Assume.assumeNoException(ex);
             return;
@@ -128,7 +137,7 @@ public abstract class AbstractRDFTermFactoryTest {
         assertNotEquals(bnode1, differentFactory);
         assertNotEquals(bnode1.uniqueReference(),
                 differentFactory.uniqueReference());
-        // but not
+        // but we can't require:
         //assertNotEquals(bnode1.ntriplesString(), differentFactory.ntriplesString());
     }
 


[14/50] incubator-commonsrdf git commit: pom.xml typo

Posted by st...@apache.org.
pom.xml typo


Project: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/commit/ea910786
Tree: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/tree/ea910786
Diff: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/diff/ea910786

Branch: refs/heads/parser-with-quads
Commit: ea910786a18d0b47242f3c3253a4e253acb69702
Parents: 8f05942
Author: Stian Soiland-Reyes <st...@apache.org>
Authored: Thu Apr 21 10:47:02 2016 +0100
Committer: Stian Soiland-Reyes <st...@apache.org>
Committed: Thu Apr 21 10:47:02 2016 +0100

----------------------------------------------------------------------
 pom.xml | 1 -
 1 file changed, 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/ea910786/pom.xml
----------------------------------------------------------------------
diff --git a/pom.xml b/pom.xml
index 81b24c9..f5f15fe 100644
--- a/pom.xml
+++ b/pom.xml
@@ -208,7 +208,6 @@
             </roles>
         </contributor>
         <contributor>
-            <id>reto</id>
             <name>Reto Gm�r</name>
             <email>reto[at]apache[dot]org</email>
             <roles>


[29/50] incubator-commonsrdf git commit: added some notes of the release process

Posted by st...@apache.org.
added some notes of the release process


Project: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/commit/71e5855d
Tree: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/tree/71e5855d
Diff: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/diff/71e5855d

Branch: refs/heads/parser-with-quads
Commit: 71e5855daee417e6211b7c6ccff79dcfb0468b8d
Parents: b39f800
Author: Sergio Fern�ndez <wi...@apache.org>
Authored: Thu May 12 15:22:18 2016 -0700
Committer: Sergio Fern�ndez <wi...@apache.org>
Committed: Thu May 12 15:22:18 2016 -0700

----------------------------------------------------------------------
 RELEASE-PROCESS.md | 9 +++++++++
 1 file changed, 9 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/71e5855d/RELEASE-PROCESS.md
----------------------------------------------------------------------
diff --git a/RELEASE-PROCESS.md b/RELEASE-PROCESS.md
new file mode 100644
index 0000000..1aa08b1
--- /dev/null
+++ b/RELEASE-PROCESS.md
@@ -0,0 +1,9 @@
+# Commons RDF (incubating) release process
+
+1. Clean build: `mvn clean install`
+2. RAT checking: `mvn apache-rat:check`
+3. Prepare the release: `mvn release:prepare -DreleaseVersion=0.2.0-incubating -DdevelopmentVersion=0.3.0-incubating-SNAPSHOT -DautoVersionSubmodules=true`
+4. Perform the release: `mvn release:perform`
+5. Close the staging repository at https://repository.apache.org/#stagingRepositories
+6. Push the code: `git push` and tag `git push --tags`
+6. Cast the vote mail to dev@commonsrdf


[40/50] incubator-commonsrdf git commit: TripleOrQuad -> TripleLike, GraphLike

Posted by st...@apache.org.
TripleOrQuad -> TripleLike, GraphLike

TripleLike is a generalized Triple (e.g. as seen in Jena), supporting
any RDFTerm in any of the subject/predicate/object positions.
This can be useful for parsers, and also serves as a common
super-type for Quad and Triple.

Equivalently, QuadLike extends TripleLike as a generalized Quad, supporting
any RDFTerm as its graphName.


Project: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/commit/bc639bbd
Tree: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/tree/bc639bbd
Diff: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/diff/bc639bbd

Branch: refs/heads/parser-with-quads
Commit: bc639bbd3b65ed6802dfdac14a53c9f96162bf32
Parents: 839a642
Author: Stian Soiland-Reyes <st...@apache.org>
Authored: Thu Jun 2 11:41:04 2016 +0100
Committer: Stian Soiland-Reyes <st...@apache.org>
Committed: Thu Jun 2 11:41:04 2016 +0100

----------------------------------------------------------------------
 .../java/org/apache/commons/rdf/api/Quad.java   |  2 +-
 .../org/apache/commons/rdf/api/QuadLike.java    | 63 +++++++++++++++++++
 .../java/org/apache/commons/rdf/api/Triple.java |  2 +-
 .../org/apache/commons/rdf/api/TripleLike.java  | 65 ++++++++++++++++++++
 .../apache/commons/rdf/api/TripleOrQuad.java    | 64 -------------------
 5 files changed, 130 insertions(+), 66 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/bc639bbd/api/src/main/java/org/apache/commons/rdf/api/Quad.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/org/apache/commons/rdf/api/Quad.java b/api/src/main/java/org/apache/commons/rdf/api/Quad.java
index 7ccd0d1..fa9298e 100644
--- a/api/src/main/java/org/apache/commons/rdf/api/Quad.java
+++ b/api/src/main/java/org/apache/commons/rdf/api/Quad.java
@@ -32,7 +32,7 @@ import java.util.Optional;
  *      1.1: On Semantics of RDF Datasets</a>
  * @see <a href="http://www.w3.org/TR/rdf11-concepts/#section-dataset"> </a>
  */
-public interface Quad extends TripleOrQuad {
+public interface Quad extends QuadLike<BlankNodeOrIRI,IRI,RDFTerm,BlankNodeOrIRI> {
 
 	/**
 	 * The graph name (graph label) of this quad, if present.

http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/bc639bbd/api/src/main/java/org/apache/commons/rdf/api/QuadLike.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/org/apache/commons/rdf/api/QuadLike.java b/api/src/main/java/org/apache/commons/rdf/api/QuadLike.java
new file mode 100644
index 0000000..a47e32b
--- /dev/null
+++ b/api/src/main/java/org/apache/commons/rdf/api/QuadLike.java
@@ -0,0 +1,63 @@
+/**
+ * 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.commons.rdf.api;
+
+import java.util.Optional;
+
+/**
+ * A generalised "quad-like" interface, extended by {@link Quad}.
+ * <p>
+ * A QuadLike has at least a 
+ * {@link #getSubject()}, {@link #getPredicate()} and 
+ * {@link #getObject()}, and a {@link #getGraphName()}, 
+ * but unlike a {@link Quad} does not have a
+ * formalised {@link Quad#equals(Object)} semantics, and allow
+ * generalised quads (e.g. a BlankNode as predicate).
+ * <p>
+ * Implementations should specialise which RDFTerm 
+ * subclasses they return for subject {@link S}, 
+ * predicate {@link P}, object {@link O} and graph name {@link G}.
+ * <p>
+ * @see Quad
+ */
+public interface QuadLike <S extends RDFTerm, P extends RDFTerm, O extends RDFTerm, G extends RDFTerm> 
+	extends TripleLike<S,P,O> {
+
+
+	/**
+	 * The graph name (graph label) of this quad, if present.
+	 * 
+	 * If {@link Optional#isPresent()}, then the {@link Optional#get()} 
+	 * indicate the
+	 * <a href="https://www.w3.org/TR/rdf11-concepts/#dfn-named-graph">graph
+	 * name of this Quad. If the graph name is not present (e.g. the value is
+	 * {@link Optional#empty()}), it indicates that this Quad is in the
+	 * <a href="https://www.w3.org/TR/rdf11-concepts/#dfn-default-graph">default
+	 * graph.
+	 *
+	 * @return If {@link Optional#isPresent()}, the graph name
+	 *         of this quad, otherwise. The graph name is typically an
+	 *         {@link IRI} or {@link BlankNode}.
+	 *         {@link Optional#empty()}, indicating the default graph.
+	 * 
+	 * @see <a href="https://www.w3.org/TR/rdf11-concepts/#dfn-rdf-dataset">RDF-
+	 *      1.1 Dataset</a>
+	 */
+	Optional<G> getGraphName();
+	
+}

http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/bc639bbd/api/src/main/java/org/apache/commons/rdf/api/Triple.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/org/apache/commons/rdf/api/Triple.java b/api/src/main/java/org/apache/commons/rdf/api/Triple.java
index 0725913..dcbb509 100644
--- a/api/src/main/java/org/apache/commons/rdf/api/Triple.java
+++ b/api/src/main/java/org/apache/commons/rdf/api/Triple.java
@@ -28,7 +28,7 @@ import java.util.Objects;
  * @see <a href= "http://www.w3.org/TR/rdf11-concepts/#dfn-rdf-triple" >RDF-1.1
  * Triple</a>
  */
-public interface Triple extends TripleOrQuad {
+public interface Triple extends TripleLike<BlankNodeOrIRI, IRI, RDFTerm> {
 
     /**
      * The subject of this triple, which may be either a {@link BlankNode} or an

http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/bc639bbd/api/src/main/java/org/apache/commons/rdf/api/TripleLike.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/org/apache/commons/rdf/api/TripleLike.java b/api/src/main/java/org/apache/commons/rdf/api/TripleLike.java
new file mode 100644
index 0000000..1ed75d0
--- /dev/null
+++ b/api/src/main/java/org/apache/commons/rdf/api/TripleLike.java
@@ -0,0 +1,65 @@
+/**
+ * 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.commons.rdf.api;
+
+/**
+ * A generalised "triple-like" interface, extended by {@link Triple} and {@link Quad}.
+ * <p>
+ * A TripleLike has at least a 
+ * {@link #getSubject()}, {@link #getPredicate()} and 
+ * {@link #getObject()}, but unlike a {@link Triple} does not have a
+ * formalised {@link Triple#equals(Object)} semantics, and allow
+ * generalised triples (e.g. a BlankNode as predicate).
+ * <p>
+ * Implementations should specialise which RDFTerms subclasses 
+ * they return for subject, predicate and object.
+ * <p>
+ * @see Triple
+ * @see Quad
+ * @see QuadLike
+ * 
+ */
+public interface TripleLike <S extends RDFTerm, P extends RDFTerm, O extends RDFTerm> {
+
+    /**
+     * The subject of this statement.
+     *
+     * @return The subject, typically an {@link IRI} or {@link BlankNode}.
+     * @see <a href="http://www.w3.org/TR/rdf11-concepts/#dfn-subject">RDF-1.1
+     * Triple subject</a>
+     */
+    S getSubject();
+
+    /**
+     * The predicate of this statement.
+     *
+     * @return The predicate, typically an {@link IRI}.
+     * @see <a href="http://www.w3.org/TR/rdf11-concepts/#dfn-predicate">RDF-1.1
+     * Triple predicate</a>
+     */
+    P getPredicate();
+
+    /**
+     * The object of this statement.
+     *
+     * @return The object, typically an {@link IRI}, {@link BlankNode} or {@link Literal}.
+     * @see <a href="http://www.w3.org/TR/rdf11-concepts/#dfn-object">RDF-1.1
+     * Triple object</a>
+     */
+    O getObject();
+}

http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/bc639bbd/api/src/main/java/org/apache/commons/rdf/api/TripleOrQuad.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/org/apache/commons/rdf/api/TripleOrQuad.java b/api/src/main/java/org/apache/commons/rdf/api/TripleOrQuad.java
deleted file mode 100644
index 6a86447..0000000
--- a/api/src/main/java/org/apache/commons/rdf/api/TripleOrQuad.java
+++ /dev/null
@@ -1,64 +0,0 @@
-/**
- * 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.commons.rdf.api;
-
-/**
- * Common "triple-like" interface for {@link Triple} and {@link Quad}
- * <p>
- * A TripleOrQuad has at least a 
- * {@link #getSubject()}, {@link #getPredicate()} and 
- * {@link #getObject()}, but unlike a {@link Triple} does not have a
- * formalised {@link Triple#equals(Object)} semantics, and does not 
- * necessarily have a {@link Quad#getGraphName()}
- * <p>
- * Implementations of this interface SHOULD also implement {@link Triple}
- * or {@link Quad}, but MUST NOT implement both interfaces.
- */
-public interface TripleOrQuad {
-
-    /**
-     * The subject of this triple/quad, which may be either a {@link BlankNode} or an
-     * {@link IRI}, which are represented in Commons RDF by the interface
-     * {@link BlankNodeOrIRI}.
-     *
-     * @return The subject {@link BlankNodeOrIRI} of this triple/quad.
-     * @see <a href="http://www.w3.org/TR/rdf11-concepts/#dfn-subject">RDF-1.1
-     * Triple subject</a>
-     */
-    BlankNodeOrIRI getSubject();
-
-    /**
-     * The predicate {@link IRI} of this triple/quad.
-     *
-     * @return The predicate {@link IRI} of this triple/quad.
-     * @see <a href="http://www.w3.org/TR/rdf11-concepts/#dfn-predicate">RDF-1.1
-     * Triple predicate</a>
-     */
-    IRI getPredicate();
-
-    /**
-     * The object of this triple/quad, which may be either a {@link BlankNode}, an
-     * {@link IRI}, or a {@link Literal}, which are represented in Commons RDF
-     * by the interface {@link RDFTerm}.
-     *
-     * @return The object {@link RDFTerm} of this triple/quad.
-     * @see <a href="http://www.w3.org/TR/rdf11-concepts/#dfn-object">RDF-1.1
-     * Triple object</a>
-     */
-    RDFTerm getObject();
-}


[15/50] incubator-commonsrdf git commit: Andy Seaborne now Emeritus

Posted by st...@apache.org.
Andy Seaborne now Emeritus


Project: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/commit/82b81e70
Tree: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/tree/82b81e70
Diff: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/diff/82b81e70

Branch: refs/heads/parser-with-quads
Commit: 82b81e709f6efc30108d44170b313816cf60a232
Parents: ea91078
Author: Stian Soiland-Reyes <st...@apache.org>
Authored: Fri Apr 22 14:45:13 2016 +0100
Committer: Stian Soiland-Reyes <st...@apache.org>
Committed: Fri Apr 22 14:45:13 2016 +0100

----------------------------------------------------------------------
 pom.xml | 19 +++++++++----------
 1 file changed, 9 insertions(+), 10 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/82b81e70/pom.xml
----------------------------------------------------------------------
diff --git a/pom.xml b/pom.xml
index f5f15fe..5ec2f94 100644
--- a/pom.xml
+++ b/pom.xml
@@ -154,16 +154,6 @@
             <timezone>+1</timezone>
         </developer>
         <developer>
-            <id>andy</id>
-            <name>Andy Seaborne</name>
-            <email>andy[at]apache[dot]org</email>
-            <roles>
-                <role>Committer</role>
-                <role>Emeritus PPPMC Member</role>
-            </roles>
-            <timezone>+0</timezone>
-        </developer>
-        <developer>
             <id>stain</id>
             <name>Stian Soiland-Reyes</name>
             <email>stain[at]apache[dot]org</email>
@@ -216,6 +206,15 @@
             </roles>
             <timezone>+1</timezone>
         </contributor>
+        <developer>
+            <name>Andy Seaborne</name>
+            <email>andy[at]apache[dot]org</email>
+            <roles>
+                <role>Emeritus Committer</role>
+                <role>Emeritus PPPMC Member</role>
+            </roles>
+            <timezone>+0</timezone>
+        </developer>
     </contributors>
 
     <modules>


[35/50] incubator-commonsrdf git commit: Updated userguide for 0.2.0-incubating

Posted by st...@apache.org.
Updated userguide for 0.2.0-incubating


Project: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/commit/935cb7f8
Tree: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/tree/935cb7f8
Diff: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/diff/935cb7f8

Branch: refs/heads/parser-with-quads
Commit: 935cb7f850c8776da974c4c611509161a12a657a
Parents: 297000a
Author: Stian Soiland-Reyes <st...@apache.org>
Authored: Sun May 15 22:49:32 2016 +0100
Committer: Stian Soiland-Reyes <st...@apache.org>
Committed: Sun May 15 22:49:32 2016 +0100

----------------------------------------------------------------------
 src/site/markdown/userguide.md | 60 +++++++++++++++++++++++++------------
 1 file changed, 41 insertions(+), 19 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/935cb7f8/src/site/markdown/userguide.md
----------------------------------------------------------------------
diff --git a/src/site/markdown/userguide.md b/src/site/markdown/userguide.md
index 2a7a73d..df8a277 100644
--- a/src/site/markdown/userguide.md
+++ b/src/site/markdown/userguide.md
@@ -21,13 +21,15 @@
 # User Guide
 
 This page shows some examples of a client using the Commons RDF API.
-It was last updated for version `0.1.0-incubating` of the
+It was last updated for version `0.2.0-incubating` of the
 Commons RDF [API](apidocs/).
 
 * [Introduction](#Introduction)
     * [RDF concepts](#RDF_concepts)
 * [Using Commons RDF from Maven](#Using_Commons_RDF_from_Maven)
 * [Creating Commons RDF instances](#Creating_Commons_RDF_instances)
+  * [Creating a RDFTermFactory](#Creating_a_RDFTermFactory)
+  * [Using a RDFTermFactory](#Using_a_RDFTermFactory)
 * [RDF terms](#RDF_terms)
     * [N-Triples string](#N-Triples_string)
     * [IRI](#IRI)
@@ -84,7 +86,7 @@ add the following dependency to your `pom.xml`:
     <dependency>
         <groupId>org.apache.commons</groupId>
         <artifactId>commons-rdf-api</artifactId>
-        <version>0.1.0-incubating</version>
+        <version>0.2.0-incubating</version>
     </dependency>
 </dependencies>
 ```
@@ -128,7 +130,7 @@ _simple_ implementation, add to your `<dependencies>`:
     <dependency>
         <groupId>org.apache.commons</groupId>
         <artifactId>commons-rdf-simple</artifactId>
-        <version>0.1.0-incubating</version>
+        <version>0.2.0-incubating</version>
     </dependency>
 ```
 
@@ -143,7 +145,9 @@ To create instances of Commons RDF interfaces like
 [`IRI`](apidocs/org/apache/commons/rdf/api/IRI.html) you will need a
 [RDFTermFactory](apidocs/org/apache/commons/rdf/api/RDFTermFactory.html).
 
-How to get an instance of this factory is implementation specific, for the
+### Creating a RDFTermFactory
+
+How to get an instance of this factory is implementation-specific, for the
 _simple_ implementation, you can construct the
 [SimpleRDFTermFactory](apidocs/org/apache/commons/rdf/simple/SimpleRDFTermFactory.html):
 
@@ -170,6 +174,12 @@ Iterator<RDFTermFactory> iterator = loader.iterator();
 RDFTermFactory factory = iterator.next();
 ```
 
+Note that the `ServiceLoader` approach above might not work well within
+split classloader systems like OSGi.
+
+
+### Using a RDFTermFactory
+
 Using the factory you can construct
 any [RDFTerm](apidocs/org/apache/commons/rdf/api/RDFTerm.html), e.g. to create a
 [BlankNode](apidocs/org/apache/commons/rdf/api/BlankNode.html),
@@ -331,7 +341,7 @@ System.out.println(iri.equals(factory.createLiteral("http://example.com/alice"))
 
 A [blank node](http://www.w3.org/TR/rdf11-concepts/#section-blank-nodes) is a
 resource which, unlike an IRI, is not directly identified. Blank nodes can be
-used as _subject_ or _object_ of a `Triple`
+used as _subject_ or _object_ of a
 [Triple](apidocs/org/apache/commons/rdf/api/Triple.html).
 
 To create a new
@@ -395,6 +405,7 @@ System.out.println(b1.equals(new SimpleRDFTermFactory().createBlankNode("b1")));
 >
 > `false`
 
+
 #### Blank node reference
 
 While blank nodes are distinct from IRIs, and don't have inherent
@@ -688,7 +699,7 @@ graph.add(triple);
 ```
 As an alternative to creating the `Triple` first, you can use the expanded
 _subject/predicate/object_ form of
-[Graph.add](apidocs/org/apache/commons/rdf/api/Graph.html#add-org.apache.commons.rdf.api.BlankNodeOrIRI-org.apache.commons.rdf.api.IRI-org.apache.commons.rdf.api.RDFTerm-()):
+[Graph.add](apidocs/org/apache/commons/rdf/api/Graph.html#add-org.apache.commons.rdf.api.BlankNodeOrIRI-org.apache.commons.rdf.api.IRI-org.apache.commons.rdf.api.RDFTerm-):
 
 ```java
 IRI bob = factory.createIRI("http://example.com/bob");
@@ -803,6 +814,8 @@ graph.remove(triple);
 System.out.println(graph.contains(triple));
 ```
 
+> `false`
+
 The expanded _subject/predicate/object_ form of
 [remove()](apidocs/org/apache/commons/rdf/api/Graph.html#remove-org.apache.commons.rdf.api.BlankNodeOrIRI-org.apache.commons.rdf.api.IRI-org.apache.commons.rdf.api.RDFTerm-)
 can be used without needing to construct a `Triple` first. It also
@@ -818,7 +831,7 @@ To remove all triples, use [clear](apidocs/org/apache/commons/rdf/api/Graph.html
 graph.clear();
 System.out.println(graph.contains(null, null, null));
 ```
-> false
+> `false`
 
 ## Mutability and thread safety
 
@@ -830,15 +843,22 @@ not change, and so calling a method like
 [IRI.getIRIString](apidocs/org/apache/commons/rdf/api/IRI.html#getIRIString--)
 or
 [Literal.getDatatype](apidocs/org/apache/commons/rdf/api/Literal.html#getDatatype--)
-will always have return values that are `.equal()` to any earlier return
+will have a return value which `.equals()` any earlier return
 values. Being immutable, the `Triple` and `RDFTerm` types should be
-considered thread-safe.
+considered thread-safe. Similarly their `hashCode()` should be
+considered stable, so any `RDFTerm` or `Triple` can be used
+in hashing collections like
+[HashMap](https://docs.oracle.com/javase/8/docs/api/java/util/HashMap.html).
 
 A `Graph` may be _mutable_, particular if it supports methods like
 [Graph.add](apidocs/org/apache/commons/rdf/api/Graph.html#add-org.apache.commons.rdf.api.BlankNodeOrIRI-org.apache.commons.rdf.api.IRI-org.apache.commons.rdf.api.RDFTerm-)
-and [Graph.remove](apidocs/org/apache/commons/rdf/api/Graph.html#remove-org.apache.commons.rdf.api.Triple-). That means that responses to methods like [size](apidocs/org/apache/commons/rdf/api/Graph.html#size--) and [contains](apidocs/org/apache/commons/rdf/api/Graph.html#contains-org.apache.commons.rdf.api.Triple-) might change during its lifetime.
+and [Graph.remove](apidocs/org/apache/commons/rdf/api/Graph.html#remove-org.apache.commons.rdf.api.Triple-). That means that responses to methods like [size](apidocs/org/apache/commons/rdf/api/Graph.html#size--) and [contains](apidocs/org/apache/commons/rdf/api/Graph.html#contains-org.apache.commons.rdf.api.Triple-) might change during its lifetime. A mutable `Graph`
+might also be modified by operations outside Commons RDF, e.g. because it is
+backed by a shared datastore with multiple clients.
 
-Implementations of Commons RDF may specify the (im)mutability of `Graph` in further details. If a graph is immutable, the methods `add` and `remove` may throw a `UnsupportedOperationException`.
+Implementations of Commons RDF may specify the (im)mutability of `Graph` in further details
+in their documentation. If a graph is immutable, the methods `add` and `remove`
+may throw a `UnsupportedOperationException`.
 
 Commons RDF does not specify if methods on a `Graph` are thread-safe. Iterator
 methods like [iterate](apidocs/org/apache/commons/rdf/api/Graph.html#iterate--)
@@ -868,7 +888,7 @@ synchronized(graph) {
 ## Implementations
 
 The [Commons RDF API](apidocs/org/apache/commons/rdf/api/package-summary.html)
-is a set of Java interfaces, with implementations provided by several Java RDF
+is a set of Java interfaces, which can be implemented by several Java RDF
 frameworks.  See the [implementations](implementations.html) page for an
 updated list of providers.
 
@@ -913,8 +933,14 @@ for (Triple t1: g1.getTriples(null, iri1, null)) {
 ```
 
 _Note: Special care might need to be taken for cross-interoperability of
-`BlankNode` instances. This is currently under discussion. See
-[COMMONSRDF-15](https://issues.apache.org/jira/browse/COMMONSRDF-15)_
+`BlankNode` instances. While multiple triples with the same
+"foreign" `BlankNode` can be added without breaking their
+connections, the `Graph` is not required to
+return blank node instances that `.equals()` those
+inserted - specifically it is **not** required to persist the
+blank node [uniqueReference](apidocs/org/apache/commons/rdf/api/BlankNode.html#uniqueReference--).
+ See
+[COMMONSRDF-15](https://issues.apache.org/jira/browse/COMMONSRDF-15)._
 
 The `.equals()` methods of `RDFTerm` interfaces are explicitly defined, so
 their instances can be compared across implementations.
@@ -922,13 +948,9 @@ their instances can be compared across implementations.
 _Note: The `Graph` implementation is not required to keep the JVM object
 reference, e.g. after  `g2.add(subj1, pred, obj)` it is not required to later
 return the same `subj1` implementation in `g2.getTriples()`. Special care
-should be taken if returned values are needs to be casted to implementation
+should be taken if returned values needs to be casted to implementation
 specific types._
 
-The `.hashCode()` is not currently explicitly defined, hence
-special care should be taken for cross-interoperability within hashing data
-structures like `HashMap`. See
-[COMMONSRDF-14](https://issues.apache.org/jira/browse/COMMONSRDF-14)
 
 ## Complete example
 


[31/50] incubator-commonsrdf git commit: complemented release process

Posted by st...@apache.org.
complemented release process


Project: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/commit/471b80c2
Tree: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/tree/471b80c2
Diff: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/diff/471b80c2

Branch: refs/heads/parser-with-quads
Commit: 471b80c232ef8aa52df691c8c7744be070c8844b
Parents: ae3103a
Author: Sergio Fern�ndez <wi...@apache.org>
Authored: Thu May 12 17:20:49 2016 -0700
Committer: Sergio Fern�ndez <wi...@apache.org>
Committed: Thu May 12 17:20:49 2016 -0700

----------------------------------------------------------------------
 RELEASE-PROCESS.md | 10 ++++++++--
 1 file changed, 8 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/471b80c2/RELEASE-PROCESS.md
----------------------------------------------------------------------
diff --git a/RELEASE-PROCESS.md b/RELEASE-PROCESS.md
index 1aa08b1..9a96c25 100644
--- a/RELEASE-PROCESS.md
+++ b/RELEASE-PROCESS.md
@@ -3,7 +3,13 @@
 1. Clean build: `mvn clean install`
 2. RAT checking: `mvn apache-rat:check`
 3. Prepare the release: `mvn release:prepare -DreleaseVersion=0.2.0-incubating -DdevelopmentVersion=0.3.0-incubating-SNAPSHOT -DautoVersionSubmodules=true`
-4. Perform the release: `mvn release:perform`
+4. Perform the release: `mvn release:perform -Prelease`
 5. Close the staging repository at https://repository.apache.org/#stagingRepositories
 6. Push the code: `git push` and tag `git push --tags`
-6. Cast the vote mail to dev@commonsrdf
+7. Cast the vote mail to dev@commonsrdf
+
+Notice that the `maven-release-plugin` is configured to use the local git repository as well as not push changes 
+to `origin`. Therefore the process can be reverted (e.g., `git reset HEAD~1`) at any time before the sixth step.
+
+Acknowledgements to the [Marmotta's release process](https://wiki.apache.org/marmotta/ReleaseProcess) that heavily 
+inspired this one.


[49/50] incubator-commonsrdf git commit: Merge branch 'parser-writer-interface' into parser-with-quads

Posted by st...@apache.org.
Merge branch 'parser-writer-interface' into parser-with-quads


Project: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/commit/953e9b89
Tree: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/tree/953e9b89
Diff: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/diff/953e9b89

Branch: refs/heads/parser-with-quads
Commit: 953e9b8915fd7d42f8beac6fac8cabc39d5351e1
Parents: 7c69d4f c0700de
Author: Stian Soiland-Reyes <st...@apache.org>
Authored: Mon Jun 20 09:52:59 2016 +0100
Committer: Stian Soiland-Reyes <st...@apache.org>
Committed: Mon Jun 20 09:52:59 2016 +0100

----------------------------------------------------------------------
 api/src/main/java/org/apache/commons/rdf/api/RDFParserBuilder.java | 2 ++
 1 file changed, 2 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/953e9b89/api/src/main/java/org/apache/commons/rdf/api/RDFParserBuilder.java
----------------------------------------------------------------------
diff --cc api/src/main/java/org/apache/commons/rdf/api/RDFParserBuilder.java
index 0494502,b387406..5e8ee33
--- a/api/src/main/java/org/apache/commons/rdf/api/RDFParserBuilder.java
+++ b/api/src/main/java/org/apache/commons/rdf/api/RDFParserBuilder.java
@@@ -183,71 -166,13 +183,73 @@@ public interface RDFParserBuilder 
  	 * @return An {@link RDFParserBuilder} that will insert triples into the
  	 *         specified graph.
  	 */
 -	default RDFParserBuilder target(Graph graph) {
 -		return target(graph::add);
 +	default RDFParserBuilder target(Graph graph) {		
 +		return target(q -> { 
 +			if (! q.getGraphName().isPresent()) { 
 +				graph.add(q.asTriple());
 +			}
 +		});
  	}
  
+ 	RDFParserBuilder target(Consumer<Triple> tripleConsumer);
+ 	
  	/**
 +	 * Specify a {@link Dataset} to add parsed quads to.
 +	 * <p>
 +	 * It is undefined if any quads are added to the specified
 +	 * {@link Dataset} if {@link #parse()} throws any exceptions. 
 +	 * (However implementations are free to prevent this using transaction 
 +	 * mechanisms or similar).  On the other hand, if {@link #parse()}
 +	 * does not indicate an exception, the 
 +	 * implementation SHOULD have inserted all parsed quads 
 +	 * to the specified dataset.
 +	 * <p>
 +	 * Calling this method will override any earlier targets set with 
 +	 * {@link #target(Graph)}, {@link #target(Consumer)} or {@link #target(Dataset)}.
 +	 * <p>
 +	 * The default implementation of this method calls {@link #target(Consumer)}
 +	 * with a {@link Consumer} that does {@link Dataset#add(Quad)}.
 +	 * 
 +	 * @param dataset
 +	 *            The {@link Dataset} to add quads to.
 +	 * @return An {@link RDFParserBuilder} that will insert triples into the
 +	 *         specified dataset.
 +	 */
 +	default RDFParserBuilder target(Dataset dataset) {
 +		return target(dataset::add);
 +	}
 +
 +	/**
 +	 * Specify a consumer for parsed quads.
 +	 * <p>
 +	 * It is undefined if any quads are consumed if {@link #parse()} throws any
 +	 * exceptions. On the other hand, if {@link #parse()} does not indicate an
 +	 * exception, the implementation SHOULD have produced all parsed quads to
 +	 * the specified consumer.
 +	 * <p>
 +	 * Calling this method will override any earlier targets set with
 +	 * {@link #target(Graph)}, {@link #target(Consumer)} or
 +	 * {@link #target(Dataset)}.
 +	 * <p>
 +	 * The consumer is not assumed to be thread safe - only one
 +	 * {@link Consumer#accept(Object)} is delivered at a time for a given
 +	 * {@link RDFParserBuilder#parse()} call.
 +	 * <p>
 +	 * This method is typically called with a functional consumer, for example:
 +	 * <pre>
 +	 * List<Quad> quads = new ArrayList<Quad>;
 +	 * parserBuilder.target(quads::add).parse();
 +	 * </pre>
 +	 * 
 +	 * @param consumer
 +	 *            A {@link Consumer} of {@link Quad}s
 +	 * @return An {@link RDFParserBuilder} that will call the consumer for into
 +	 *         the specified dataset.
 +	 * @return
 +	 */
 +	RDFParserBuilder target(Consumer<Quad> consumer);
 +	
 +	/**
  	 * Specify a base IRI to use for parsing any relative IRI references.
  	 * <p>
  	 * Setting this option will override any protocol-specific base IRI (e.g.


[50/50] incubator-commonsrdf git commit: Only Quad consumer, not Triple consumer

Posted by st...@apache.org.
Only Quad consumer, not Triple consumer


Project: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/commit/ddc545e5
Tree: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/tree/ddc545e5
Diff: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/diff/ddc545e5

Branch: refs/heads/parser-with-quads
Commit: ddc545e511ef9c8459ea5ce81fab750b4cd0a3b0
Parents: 953e9b8
Author: Stian Soiland-Reyes <st...@apache.org>
Authored: Mon Jun 20 09:56:51 2016 +0100
Committer: Stian Soiland-Reyes <st...@apache.org>
Committed: Mon Jun 20 09:56:51 2016 +0100

----------------------------------------------------------------------
 api/src/main/java/org/apache/commons/rdf/api/RDFParserBuilder.java | 2 --
 1 file changed, 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/ddc545e5/api/src/main/java/org/apache/commons/rdf/api/RDFParserBuilder.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/org/apache/commons/rdf/api/RDFParserBuilder.java b/api/src/main/java/org/apache/commons/rdf/api/RDFParserBuilder.java
index 5e8ee33..0494502 100644
--- a/api/src/main/java/org/apache/commons/rdf/api/RDFParserBuilder.java
+++ b/api/src/main/java/org/apache/commons/rdf/api/RDFParserBuilder.java
@@ -191,8 +191,6 @@ public interface RDFParserBuilder {
 		});
 	}
 
-	RDFParserBuilder target(Consumer<Triple> tripleConsumer);
-	
 	/**
 	 * Specify a {@link Dataset} to add parsed quads to.
 	 * <p>


[43/50] incubator-commonsrdf git commit: Merge branch 'master' into quad

Posted by st...@apache.org.
Merge branch 'master' into quad


Project: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/commit/14f246e7
Tree: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/tree/14f246e7
Diff: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/diff/14f246e7

Branch: refs/heads/parser-with-quads
Commit: 14f246e74cf89ca37efad1360b2bcd142cb60759
Parents: c7e1a5b 058f781
Author: Stian Soiland-Reyes <st...@apache.org>
Authored: Thu Jun 2 17:24:33 2016 +0100
Committer: Stian Soiland-Reyes <st...@apache.org>
Committed: Thu Jun 2 17:24:33 2016 +0100

----------------------------------------------------------------------
 RELEASE-NOTES.txt                               |  39 +++++
 RELEASE-PROCESS.md                              |  16 ++
 api/pom.xml                                     |   2 +-
 .../commons/rdf/api/AbstractGraphTest.java      | 172 +++++++++++++++++++
 .../rdf/api/AbstractRDFTermFactoryTest.java     |  29 ++++
 examples/pom.xml                                |   4 +-
 examples/src/example/UserGuideTest.java         |   1 +
 pom.xml                                         |  95 +++++-----
 simple/pom.xml                                  |   3 +-
 src/assembly/src.xml                            |  45 +++++
 src/main/assembly/src.xml                       |  44 -----
 src/site/markdown/download.md                   |  34 ++--
 src/site/markdown/userguide.md                  |  60 +++++--
 13 files changed, 414 insertions(+), 130 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/14f246e7/api/src/test/java/org/apache/commons/rdf/api/AbstractGraphTest.java
----------------------------------------------------------------------
diff --cc api/src/test/java/org/apache/commons/rdf/api/AbstractGraphTest.java
index 15773df,5986958..27b9ff4
--- a/api/src/test/java/org/apache/commons/rdf/api/AbstractGraphTest.java
+++ b/api/src/test/java/org/apache/commons/rdf/api/AbstractGraphTest.java
@@@ -260,11 -266,177 +266,177 @@@ public abstract class AbstractGraphTes
          assertEquals(3, aliceCount);
  
          Assume.assumeNotNull(bnode1, bnode2, bobName, companyName, secretClubName);
 -        assertEquals(4, graph.getTriples(null, name, null).count());
 +        assertEquals(4, graph.stream(null, name, null).count());
          Assume.assumeNotNull(bnode1);
 -        assertEquals(3, graph.getTriples(null, member, null).count());
 +        assertEquals(3, graph.stream(null, member, null).count());
      }
  
+     @Test
+     public void addBlankNodesFromMultipleGraphs() {
+ 
+         try {
+         	// Create two separate Graph instances
+             Graph g1 = createGraph1();
+             Graph g2 = createGraph2();
+ 
+             // and add them to a new Graph g3
+             Graph g3 = factory.createGraph();  
+             addAllTriples(g1, g3);
+             addAllTriples(g2, g3);
+ 
+             
+             // Let's make a map to find all those blank nodes after insertion
+             // (The Graph implementation is not currently required to 
+             // keep supporting those BlankNodes with contains() - see COMMONSRDF-15)
+ 
+             final Map<String, BlankNodeOrIRI> whoIsWho = new ConcurrentHashMap<>();
+             // ConcurrentHashMap as we will try parallel forEach below,
+             // which should not give inconsistent results (it does with a
+             // HashMap!)
+             
+             // look up BlankNodes by name
+             IRI name = factory.createIRI("http://xmlns.com/foaf/0.1/name");
+             g3.getTriples(null, name, null).parallel().forEach( t ->
+                 whoIsWho.put( t.getObject().ntriplesString(), t.getSubject()));
+                         
+             assertEquals(4, whoIsWho.size());
+             // and contains 4 unique values
+             assertEquals(4, new HashSet<BlankNodeOrIRI>(whoIsWho.values()).size());
+ 
+             BlankNodeOrIRI b1Alice = whoIsWho.get("\"Alice\"");
+             assertNotNull(b1Alice);
+             BlankNodeOrIRI b2Bob = whoIsWho.get("\"Bob\"");
+             assertNotNull(b2Bob);
+             BlankNodeOrIRI b1Charlie = whoIsWho.get("\"Charlie\"");
+             assertNotNull(b1Charlie);
+             BlankNodeOrIRI b2Dave = whoIsWho.get("\"Dave\"");
+             assertNotNull(b2Dave);
+ 
+             // All blank nodes should differ
+             notEquals(b1Alice, b2Bob);
+             notEquals(b1Alice, b1Charlie);
+             notEquals(b1Alice, b2Dave);
+             notEquals(b2Bob, b1Charlie);
+             notEquals(b2Bob, b2Dave);
+             notEquals(b1Charlie, b2Dave);
+ 
+             // And we should be able to query with them again
+             // as we got them back from g3
+             IRI hasChild = factory.createIRI("http://example.com/hasChild");
+             assertTrue(g3.contains(b1Alice, hasChild, b2Bob));
+             assertTrue(g3.contains(b2Dave, hasChild, b1Charlie));
+             // But not
+             assertFalse(g3.contains(b1Alice, hasChild, b1Alice));
+             assertFalse(g3.contains(b1Alice, hasChild, b1Charlie));
+             assertFalse(g3.contains(b1Alice, hasChild, b2Dave));
+             // nor
+             assertFalse(g3.contains(b2Dave, hasChild, b1Alice));
+             assertFalse(g3.contains(b2Dave, hasChild, b1Alice));
+ 
+             // and these don't have any children (as far as we know)
+             assertFalse(g3.contains(b2Bob, hasChild, null));
+             assertFalse(g3.contains(b1Charlie, hasChild, null));
+         } catch (UnsupportedOperationException ex) {
+             Assume.assumeNoException(ex);
+         }
+     }
+ 
+     private void notEquals(BlankNodeOrIRI node1, BlankNodeOrIRI node2) {
+         assertFalse(node1.equals(node2));
+         // in which case we should be able to assume
+         // (as they are in the same graph)
+         assertFalse(node1.ntriplesString().equals(node2.ntriplesString()));
+     }
+ 
+     /**
+      * Add all triples from the source to the target.
+      * <p>
+      * The triples may be copied in any order.
+      * No special conversion or adaptation of {@link BlankNode}s are performed.
+      *
+      * @param source Source Graph to copy triples from
+      * @param target Target Graph where triples will be added
+      */
+     private void addAllTriples(Graph source, Graph target) {
+ 
+         // unordered() as we don't need to preserve triple order
+         // sequential() as we don't (currently) require target Graph to be thread-safe
+         source.getTriples().unordered().sequential().forEach(t -> target.add(t));
+     }
+ 
+     /**
+      * Make a new graph with two BlankNodes - each with a different uniqueReference
+      */
+     private Graph createGraph1() {
+         RDFTermFactory factory1 = createFactory();
+ 
+         IRI name = factory1.createIRI("http://xmlns.com/foaf/0.1/name");
+         Graph g1 = factory1.createGraph();
+         BlankNode b1 = createOwnBlankNode("b1", "0240eaaa-d33e-4fc0-a4f1-169d6ced3680");
+         g1.add(b1, name, factory1.createLiteral("Alice"));
+         
+         
+         BlankNode b2 = createOwnBlankNode("b2", "9de7db45-0ce7-4b0f-a1ce-c9680ffcfd9f");
+         g1.add(b2, name, factory1.createLiteral("Bob"));
+ 
+         IRI hasChild = factory1.createIRI("http://example.com/hasChild");
+         g1.add(b1, hasChild,  b2);
+ 
+         return g1;
+     }
+ 
+     /** 
+      * Create a different implementation of BlankNode to be tested with
+      * graph.add(a,b,c);
+      * (the implementation may or may not then choose to translate such to 
+      * its own instances)
+      * 
+      * @param name
+      * @return
+      */
+ 	private BlankNode createOwnBlankNode(String name, String uuid) {
+ 		return new BlankNode() {			
+ 			@Override
+ 			public String ntriplesString() {
+ 				return "_: " + name;
+ 			}
+ 			@Override
+ 			public String uniqueReference() {
+ 				return uuid;
+ 			}
+ 			@Override
+ 			public int hashCode() {
+ 				return uuid.hashCode();
+ 			}
+ 			@Override
+ 			public boolean equals(Object obj) {
+ 				if (!( obj instanceof BlankNode)) {
+ 					return false;
+ 				}
+ 				BlankNode other = (BlankNode)obj;
+ 				return uuid.equals(other.uniqueReference());
+ 			}
+ 		};
+ 	}
+ 
+     private Graph createGraph2() {
+         RDFTermFactory factory2 = createFactory();
+         IRI name = factory2.createIRI("http://xmlns.com/foaf/0.1/name");
+ 
+         Graph g2 = factory2.createGraph();
+ 
+         BlankNode b1 = createOwnBlankNode("b1", "bc8d3e45-a08f-421d-85b3-c25b373abf87");
+         g2.add(b1, name, factory2.createLiteral("Charlie"));
+ 
+         BlankNode b2 = createOwnBlankNode("b2", "2209097a-5078-4b03-801a-6a2d2f50d739");
+         g2.add(b2, name, factory2.createLiteral("Dave"));
+ 
+         IRI hasChild = factory2.createIRI("http://example.com/hasChild");
+         // NOTE: Opposite direction of loadGraph1
+         g2.add(b2, hasChild,  b1);
+         return g2;
+     }
+ 
      /**
       * An attempt to use the Java 8 streams to look up a more complicated query.
       * <p>


[34/50] incubator-commonsrdf git commit: fixed typo about the .equals() method

Posted by st...@apache.org.
fixed typo about the .equals() method


Project: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/commit/d6e610b7
Tree: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/tree/d6e610b7
Diff: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/diff/d6e610b7

Branch: refs/heads/parser-with-quads
Commit: d6e610b70c8f4e05c60c328c694ce7c730998b87
Parents: 297000a
Author: Sergio Fern�ndez <wi...@apache.org>
Authored: Sun May 15 14:17:27 2016 -0700
Committer: Sergio Fern�ndez <wi...@apache.org>
Committed: Sun May 15 14:17:27 2016 -0700

----------------------------------------------------------------------
 src/site/markdown/userguide.md | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/d6e610b7/src/site/markdown/userguide.md
----------------------------------------------------------------------
diff --git a/src/site/markdown/userguide.md b/src/site/markdown/userguide.md
index 2a7a73d..a84fee3 100644
--- a/src/site/markdown/userguide.md
+++ b/src/site/markdown/userguide.md
@@ -830,7 +830,7 @@ not change, and so calling a method like
 [IRI.getIRIString](apidocs/org/apache/commons/rdf/api/IRI.html#getIRIString--)
 or
 [Literal.getDatatype](apidocs/org/apache/commons/rdf/api/Literal.html#getDatatype--)
-will always have return values that are `.equal()` to any earlier return
+will always have return values that are `.equals()` to any earlier return
 values. Being immutable, the `Triple` and `RDFTerm` types should be
 considered thread-safe.
 


[12/50] incubator-commonsrdf git commit: Added missing Jira numbers

Posted by st...@apache.org.
Added missing Jira numbers


Project: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/commit/c1514e52
Tree: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/tree/c1514e52
Diff: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/diff/c1514e52

Branch: refs/heads/parser-with-quads
Commit: c1514e521c35225f9ce773d2a66a84da2ff4eb3e
Parents: ad92667
Author: Stian Soiland-Reyes <st...@apache.org>
Authored: Thu Apr 21 10:03:13 2016 +0100
Committer: Stian Soiland-Reyes <st...@apache.org>
Committed: Thu Apr 21 10:03:13 2016 +0100

----------------------------------------------------------------------
 RELEASE-NOTES.txt | 16 ++++++++--------
 1 file changed, 8 insertions(+), 8 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/c1514e52/RELEASE-NOTES.txt
----------------------------------------------------------------------
diff --git a/RELEASE-NOTES.txt b/RELEASE-NOTES.txt
index e21aaa7..e99babd 100644
--- a/RELEASE-NOTES.txt
+++ b/RELEASE-NOTES.txt
@@ -1,6 +1,6 @@
 # Apache Commons RDF (incubating)
 
-## 0.2.0-incubating (TODO)
+## 0.2.0-incubating (2016-04)
 
 This release clarifies .equals() and .hashCode() for RDFTerms so that they can
 be compared across graphs and implementations.
@@ -9,11 +9,11 @@ be compared across graphs and implementations.
 * [COMMONSRDF-20] - ServiceLoader mechanism to load RDFTermFactory
 * [COMMONSRDF-21] - Remove BlankNode requirements from RDFTermFactory.createGraph()
 * [COMMONSRDF-25] - Remove mentions of "local scope" in .equals()
-* Add RDFSyntax constants (e.g. TURTLE)
-* RDFTermFactory no longer require BlankNode mapping
-* Add internal SimpleRDFTerm marker interface
+* [COMMONSRDF-26] - Add RDFSyntax constants (e.g. TURTLE)
+* [COMMONSRDF-27] - RDFTermFactory no longer require BlankNode mapping
+* [COMMONSRDF-28] - Add internal SimpleRDFTerm marker interface
 
-## 0.1.0-incubating (2015-05-15)
+## 0.1.0-incubating (2015-05)
 
 This is the first release after moving to Apache Incubator.
 
@@ -22,9 +22,9 @@ This is the first release after moving to Apache Incubator.
 * [COMMONSRDF-8] - simple .GraphImpl.add() must clone BlankNode
 * [COMMONSRDF-11] - Simple should be extendable classes
 * [COMMONSRDF-12] - Graph to be Iterable
-* BlankNode.internalIdentifier() renamed to BlankNode.uniqueReference()
-* Add "simple" implementation and unit tests
-* Add RDFTermFactory
+* [COMMONSRDF-29] - BlankNode.internalIdentifier() renamed to BlankNode.uniqueReference()
+* [COMMONSRDF-30] - Add "simple" implementation and unit tests
+* [COMMONSRDF-31] - Add RDFTermFactory
 * Added user guide to website
 
 


[46/50] incubator-commonsrdf git commit: Merge branch 'quad' into parser-with-quads

Posted by st...@apache.org.
Merge branch 'quad' into parser-with-quads


Project: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/commit/036029bb
Tree: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/tree/036029bb
Diff: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/diff/036029bb

Branch: refs/heads/parser-with-quads
Commit: 036029bb50676fa65f873421b4cec556b14867fb
Parents: defdbd9 580484c
Author: Stian Soiland-Reyes <st...@apache.org>
Authored: Fri Jun 17 21:17:10 2016 +0100
Committer: Stian Soiland-Reyes <st...@apache.org>
Committed: Fri Jun 17 21:17:10 2016 +0100

----------------------------------------------------------------------
 RELEASE-NOTES.txt                               |  39 ++++
 RELEASE-PROCESS.md                              |  16 ++
 api/pom.xml                                     |   2 +-
 .../org/apache/commons/rdf/api/Dataset.java     |  12 +-
 .../java/org/apache/commons/rdf/api/Graph.java  |  40 +++-
 .../org/apache/commons/rdf/api/GraphLike.java   |  98 ++++++++++
 .../java/org/apache/commons/rdf/api/Quad.java   |   7 +-
 .../org/apache/commons/rdf/api/QuadLike.java    |  57 ++++++
 .../java/org/apache/commons/rdf/api/Triple.java |   2 +-
 .../org/apache/commons/rdf/api/TripleLike.java  |  61 ++++++
 .../apache/commons/rdf/api/TripleOrQuad.java    |  64 -------
 .../commons/rdf/api/AbstractGraphTest.java      | 192 ++++++++++++++++++-
 .../rdf/api/AbstractRDFTermFactoryTest.java     |  29 +++
 examples/pom.xml                                |   4 +-
 examples/src/example/UserGuideTest.java         |   1 +
 pom.xml                                         |  95 ++++-----
 simple/pom.xml                                  |   3 +-
 .../commons/rdf/simple/DatasetGraphView.java    | 138 +++++++++++++
 .../apache/commons/rdf/simple/DatasetImpl.java  |  23 +--
 .../apache/commons/rdf/simple/GraphImpl.java    |  12 +-
 .../commons/rdf/simple/TestWritingGraph.java    |   8 +-
 src/assembly/src.xml                            |  45 +++++
 src/main/assembly/src.xml                       |  44 -----
 src/site/markdown/download.md                   |  34 ++--
 src/site/markdown/userguide.md                  |  60 ++++--
 25 files changed, 840 insertions(+), 246 deletions(-)
----------------------------------------------------------------------



[39/50] incubator-commonsrdf git commit: Avoid links to dist.apache.org for *.asc etc.

Posted by st...@apache.org.
Avoid links to dist.apache.org for *.asc etc.

we should rather use https://www.apache.org/dist/incubator/commonsrdf/
(except for

See https://www.apache.org/dev/release.html


Project: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/commit/058f7812
Tree: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/tree/058f7812
Diff: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/diff/058f7812

Branch: refs/heads/parser-with-quads
Commit: 058f781231ccb00c12861e39b05a3d1b5c805f95
Parents: e20c41b
Author: Stian Soiland-Reyes <st...@apache.org>
Authored: Wed Jun 1 01:20:46 2016 +0100
Committer: Stian Soiland-Reyes <st...@apache.org>
Committed: Wed Jun 1 01:20:46 2016 +0100

----------------------------------------------------------------------
 src/site/markdown/download.md | 10 +++++-----
 1 file changed, 5 insertions(+), 5 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/058f7812/src/site/markdown/download.md
----------------------------------------------------------------------
diff --git a/src/site/markdown/download.md b/src/site/markdown/download.md
index 117797c..931d2ac 100644
--- a/src/site/markdown/download.md
+++ b/src/site/markdown/download.md
@@ -72,14 +72,14 @@ from official mirrors of the
 ASF Distribution Directory [incubator/commonsrdf](https://www.apache.org/dyn/closer.lua/incubator/commonsrdf/0.2.0-incubating/):
 
 * [apache-commonsrdf-0.2.0-incubating-source-release.zip](https://www.apache.org/dyn/closer.lua/incubator/commonsrdf/0.2.0-incubating/apache-commonsrdf-0.2.0-incubating-source-release.zip)
-  ([asc](https://dist.apache.org/repos/dist/release/incubator/commonsrdf/0.2.0-incubating/apache-commonsrdf-0.2.0-incubating-source-release.zip.asc),
-  [md5](https://dist.apache.org/repos/dist/release/incubator/commonsrdf/0.2.0-incubating/apache-commonsrdf-0.2.0-incubating-source-release.zip.md5),
-  [sha1](https://dist.apache.org/repos/dist/release/incubator/commonsrdf/0.2.0-incubating/apache-commonsrdf-0.2.0-incubating-source-release.zip.sha1))
+  ([asc](https://www.apache.org/dist/incubator/commonsrdf/0.2.0-incubating/apache-commonsrdf-0.2.0-incubating-source-release.zip.asc),
+  [md5](https://www.apache.org/dist/incubator/commonsrdf/0.2.0-incubating/apache-commonsrdf-0.2.0-incubating-source-release.zip.md5),
+  [sha1](https://www.apache.org/dist/incubator/commonsrdf/0.2.0-incubating/apache-commonsrdf-0.2.0-incubating-source-release.zip.sha1))
 
-After downloading the files, check the signatures using the following [KEYS](https://dist.apache.org/repos/dist/release/incubator/commonsrdf/KEYS)
+After downloading the files, check the signatures using the following [KEYS](https://www.apache.org/dist/incubator/commonsrdf/KEYS)
 file. The [changelog](https://s.apache.org/0.2.0-incubating)
 is available from the [Apache Commons RDF Jira](https://issues.apache.org/jira/browse/COMMONSRDF).
 
 ### Previous Releases
 
-Previous release are available from [archive.apache.org](http://archive.apache.org/dist/incubator/commonsrdf/).
+Previous release are available from [archive.apache.org](https://archive.apache.org/dist/incubator/commonsrdf/).


[26/50] incubator-commonsrdf git commit: fixed package name

Posted by st...@apache.org.
fixed package name


Project: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/commit/35d44228
Tree: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/tree/35d44228
Diff: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/diff/35d44228

Branch: refs/heads/parser-with-quads
Commit: 35d442285dd9e229cb2dab8764c0b6bf789d101f
Parents: 1fdd553
Author: Sergio Fern�ndez <wi...@apache.org>
Authored: Thu May 12 15:09:56 2016 -0700
Committer: Sergio Fern�ndez <wi...@apache.org>
Committed: Thu May 12 15:09:56 2016 -0700

----------------------------------------------------------------------
 pom.xml | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/35d44228/pom.xml
----------------------------------------------------------------------
diff --git a/pom.xml b/pom.xml
index c133d7c..0703995 100644
--- a/pom.xml
+++ b/pom.xml
@@ -231,7 +231,7 @@
     </dependencyManagement>
 
     <build>
-        <!--<finalName>apache-${project.artifactId}-${project.version}</finalName>-->
+        <finalName>apache-commonsrdf-${project.version}</finalName>
         <plugins>
             <plugin>
                 <groupId>org.apache.maven.plugins</groupId>


[30/50] incubator-commonsrdf git commit: switched to the new lists.apache.org

Posted by st...@apache.org.
switched to the new lists.apache.org


Project: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/commit/ae3103a2
Tree: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/tree/ae3103a2
Diff: http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/diff/ae3103a2

Branch: refs/heads/parser-with-quads
Commit: ae3103a2e90116ed36b45f6751e94e31b7920496
Parents: 71e5855
Author: Sergio Fern�ndez <wi...@apache.org>
Authored: Thu May 12 17:15:58 2016 -0700
Committer: Sergio Fern�ndez <wi...@apache.org>
Committed: Thu May 12 17:15:58 2016 -0700

----------------------------------------------------------------------
 pom.xml | 4 ++--
 1 file changed, 2 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-commonsrdf/blob/ae3103a2/pom.xml
----------------------------------------------------------------------
diff --git a/pom.xml b/pom.xml
index a782b5b..5353db3 100644
--- a/pom.xml
+++ b/pom.xml
@@ -80,7 +80,7 @@
             <post>dev@commonsrdf.incubator.apache.org</post>
             <subscribe>dev-subscribe@commonsrdf.incubator.apache.org</subscribe>
             <unsubscribe>dev-unsubscribe@commonsrdf.incubator.apache.org</unsubscribe>
-            <archive>http://mail-archives.apache.org/mod_mbox/commonsrdf-dev/</archive>
+            <archive>https://lists.apache.org/list.html?dev@commonsrdf.apache.org</archive>
             <otherArchives>
                 <otherArchive>http://markmail.org/search/?q=list%3Aorg.apache.commonsrdf.dev</otherArchive>
             </otherArchives>
@@ -90,7 +90,7 @@
             <post>commits@commonsrdf.incubator.apache.org</post>
             <subscribe>commits-subscribe@commonsrdf.incubator.apache.org</subscribe>
             <unsubscribe>commits-unsubscribe@commonsrdf.incubator.apache.org</unsubscribe>
-            <archive>http://mail-archives.apache.org/mod_mbox/commonsrdf-commits/</archive>
+            <archive>https://lists.apache.org/list.html?commits@commonsrdf.apache.org</archive>
             <otherArchives>
                 <otherArchive>http://markmail.org/search/?q=list%3Aorg.apache.commonsrdf.commits</otherArchive>
             </otherArchives>