You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@clerezza.apache.org by bb...@apache.org on 2011/06/30 11:11:04 UTC

svn commit: r1141453 - in /incubator/clerezza/trunk/parent: platform.accountcontrolpanel/platform.accountcontrolpanel.core/src/main/scala/org/apache/clerezza/platform/accountcontrolpanel/ platform.security.foafssl/test/src/main/scala/org/apache/clerezz...

Author: bblfish
Date: Thu Jun 30 09:11:04 2011
New Revision: 1141453

URL: http://svn.apache.org/viewvc?rev=1141453&view=rev
Log:
CLEREZZA-510 renamed EasyGraph to EzGraph. Made it possible to create graphs without using the new keyword (as with List), and renamed apply() to node(), as apply should really be used for construction of objects = to go with unapply

Added:
    incubator/clerezza/trunk/parent/rdf.scala.utils/src/main/scala/org/apache/clerezza/rdf/scala/utils/EzGraph.scala
      - copied, changed from r1141311, incubator/clerezza/trunk/parent/rdf.scala.utils/src/main/scala/org/apache/clerezza/rdf/scala/utils/EasyGraph.scala
    incubator/clerezza/trunk/parent/rdf.scala.utils/src/test/scala/org/apache/clerezza/rdf/scala/utils/EzGraphTest.scala
      - copied, changed from r1141311, incubator/clerezza/trunk/parent/rdf.scala.utils/src/test/scala/org/apache/clerezza/rdf/scala/utils/EasyGraphTest.scala
Removed:
    incubator/clerezza/trunk/parent/rdf.scala.utils/src/main/scala/org/apache/clerezza/rdf/scala/utils/EasyGraph.scala
    incubator/clerezza/trunk/parent/rdf.scala.utils/src/test/scala/org/apache/clerezza/rdf/scala/utils/EasyGraphTest.scala
Modified:
    incubator/clerezza/trunk/parent/platform.accountcontrolpanel/platform.accountcontrolpanel.core/src/main/scala/org/apache/clerezza/platform/accountcontrolpanel/FoafBrowser.scala
    incubator/clerezza/trunk/parent/platform.accountcontrolpanel/platform.accountcontrolpanel.core/src/main/scala/org/apache/clerezza/platform/accountcontrolpanel/PingBack.scala
    incubator/clerezza/trunk/parent/platform.accountcontrolpanel/platform.accountcontrolpanel.core/src/main/scala/org/apache/clerezza/platform/accountcontrolpanel/ProfilePanel.scala
    incubator/clerezza/trunk/parent/platform.security.foafssl/test/src/main/scala/org/apache/clerezza/foafssl/test/WebIDTester.scala

Modified: incubator/clerezza/trunk/parent/platform.accountcontrolpanel/platform.accountcontrolpanel.core/src/main/scala/org/apache/clerezza/platform/accountcontrolpanel/FoafBrowser.scala
URL: http://svn.apache.org/viewvc/incubator/clerezza/trunk/parent/platform.accountcontrolpanel/platform.accountcontrolpanel.core/src/main/scala/org/apache/clerezza/platform/accountcontrolpanel/FoafBrowser.scala?rev=1141453&r1=1141452&r2=1141453&view=diff
==============================================================================
--- incubator/clerezza/trunk/parent/platform.accountcontrolpanel/platform.accountcontrolpanel.core/src/main/scala/org/apache/clerezza/platform/accountcontrolpanel/FoafBrowser.scala (original)
+++ incubator/clerezza/trunk/parent/platform.accountcontrolpanel/platform.accountcontrolpanel.core/src/main/scala/org/apache/clerezza/platform/accountcontrolpanel/FoafBrowser.scala Thu Jun 30 09:11:04 2011
@@ -24,7 +24,6 @@ import org.osgi.service.component.Compon
 import javax.ws.rs._
 import javax.ws.rs.core.Context
 import javax.ws.rs.core.UriInfo
-import org.apache.clerezza.rdf.scala.utils.EasyGraph
 import collection.JavaConversions._
 import org.slf4j.scala._
 import org.apache.clerezza.rdf.ontologies._
@@ -33,6 +32,7 @@ import java.security.{PrivilegedAction, 
 import org.apache.clerezza.rdf.core._
 import access.TcManager
 import impl.SimpleMGraph
+import org.apache.clerezza.rdf.scala.utils.{EzStyleChoice, EzGraph}
 
 object FoafBrowser {
 	def removeHash(uri: UriRef) = {
@@ -52,8 +52,9 @@ object FoafBrowser {
  */
 @Path("/browse")
 class FoafBrowser extends Logging {
-	import org.apache.clerezza.rdf.scala.utils.EasyGraph._
+	import org.apache.clerezza.rdf.scala.utils.EzGraph._
 	import org.apache.clerezza.platform.accountcontrolpanel.FoafBrowser._
+	import EzStyleChoice.unicode
 
 	protected def activate(componentContext: ComponentContext): Unit = {
 //		this.componentContext = componentContext
@@ -77,7 +78,7 @@ class FoafBrowser extends Logging {
 			 def run() = tcManager.getGraph(removeHash (uri))
 		 });
 
-		val inference = new EasyGraph(new UnionMGraph(new SimpleMGraph(),profile))
+		val inference = new EzGraph(new UnionMGraph(new SimpleMGraph(),profile))
 
 		//add a bit of inferencing for persons, until we have some reasoning
 		for (kn: Triple <- profile.filter(null,FOAF.knows,null)) {
@@ -89,7 +90,7 @@ class FoafBrowser extends Logging {
 		//todo: if possible get a bit more info about remote profiles, if these are in the db
 
 		//Here we make a BNode the subject of the properties as a workaround to CLEREZZA-447
-		return ( inference(uriInfo.getRequestUri()) ∈  PLATFORM.HeadedPage
+		return ( inference.node(uriInfo.getRequestUri()) ∈  PLATFORM.HeadedPage
 					∈  CONTROLPANEL.ProfileViewerPage
 		         ⟝ FOAF.primaryTopic ⟶ uri )
 	}

Modified: incubator/clerezza/trunk/parent/platform.accountcontrolpanel/platform.accountcontrolpanel.core/src/main/scala/org/apache/clerezza/platform/accountcontrolpanel/PingBack.scala
URL: http://svn.apache.org/viewvc/incubator/clerezza/trunk/parent/platform.accountcontrolpanel/platform.accountcontrolpanel.core/src/main/scala/org/apache/clerezza/platform/accountcontrolpanel/PingBack.scala?rev=1141453&r1=1141452&r2=1141453&view=diff
==============================================================================
--- incubator/clerezza/trunk/parent/platform.accountcontrolpanel/platform.accountcontrolpanel.core/src/main/scala/org/apache/clerezza/platform/accountcontrolpanel/PingBack.scala (original)
+++ incubator/clerezza/trunk/parent/platform.accountcontrolpanel/platform.accountcontrolpanel.core/src/main/scala/org/apache/clerezza/platform/accountcontrolpanel/PingBack.scala Thu Jun 30 09:11:04 2011
@@ -34,7 +34,7 @@ import org.apache.clerezza.rdf.ontologie
 import org.apache.clerezza.rdf.core.{UriRef, MGraph}
 import org.apache.clerezza.rdf.utils.{UnionMGraph, GraphNode}
 import org.apache.clerezza.rdf.core.impl.SimpleMGraph
-import org.apache.clerezza.rdf.scala.utils.{EzGraphNodeU, EzStyleChoice, EzGraphNode, EasyGraph}
+import org.apache.clerezza.rdf.scala.utils.{EzGraphNodeU, EzStyleChoice, EzGraphNode, EzGraph}
 
 object PingBack {
 	private val log: Logger = Logger(classOf[PingBack])
@@ -101,8 +101,8 @@ class PingBack {
 	 */
 	def  pingCollection(id: String, uriInfo: UriInfo): EzGraphNodeU = {
 		val pingRef = new UriRef(pingCollUri(id, uriInfo))
-		val pingCollG: EasyGraph = pingColl(pingRef)
-		pingCollG(pingRef)
+		val pingCollG: EzGraph = pingColl(pingRef)
+		pingCollG.node(pingRef)
 	}
 
 	@GET
@@ -119,7 +119,7 @@ class PingBack {
 	/**
 	 * get Ping Collection
 	 */
-	def pingColl(pingCollRef: UriRef): EasyGraph = {
+	def pingColl(pingCollRef: UriRef): EzGraph = {
 		val tcgraph =AccessController.doPrivileged(new PrivilegedAction[MGraph] {
 			def run: MGraph = try {
 				tcManager.getMGraph(pingCollRef)
@@ -133,7 +133,7 @@ class PingBack {
 				}
 			}
 		})
-		new EasyGraph(tcgraph)
+		new EzGraph(tcgraph)
 	}
 
 	/**
@@ -228,7 +228,7 @@ class PingBack {
 		//build the graph and add to the store if ok
 		val pingColGr = pingColl(new UriRef(pingCollUriStr))
 		val item = (
-			pingColGr(pingItem) ∈ PINGBACK.Item
+			pingColGr.node(pingItem) ∈ PINGBACK.Item
 		         ⟝ PINGBACK.source ⟶  source
 		         ⟝ PINGBACK.target ⟶  target
 		         ⟝ SIOC.content ⟶  comment
@@ -282,7 +282,7 @@ class PingBack {
 	   //get the source graph
 		 val targetGrph = tcManager.getMGraph(target)
 		(
-			new EasyGraph(new UnionMGraph(new SimpleMGraph(),targetGrph)).bnode ∈ PLATFORM.HeadedPage
+			new EzGraph(new UnionMGraph(new SimpleMGraph(),targetGrph)).bnode ∈ PLATFORM.HeadedPage
 			                          ∈ ProxyForm
 				⟝ PINGBACK.source ⟶ { if (source == null) ProfilePanel.webID(id,uriInfo) else source }
 				⟝ PINGBACK.target ⟶ target
@@ -316,7 +316,7 @@ class PingBack {
 		//ITS the wrong ping collection!!!
 
 		val pinG = pingColl(new UriRef(pingCollUri(id, uriInfo)))
-		( pinG(new UriRef(uriInfo.getAbsolutePath.toString)) ∈ PLATFORM.HeadedPage
+		( pinG.node(new UriRef(uriInfo.getAbsolutePath.toString)) ∈ PLATFORM.HeadedPage
 								∈ PINGBACK.Item
 			)
 	}

Modified: incubator/clerezza/trunk/parent/platform.accountcontrolpanel/platform.accountcontrolpanel.core/src/main/scala/org/apache/clerezza/platform/accountcontrolpanel/ProfilePanel.scala
URL: http://svn.apache.org/viewvc/incubator/clerezza/trunk/parent/platform.accountcontrolpanel/platform.accountcontrolpanel.core/src/main/scala/org/apache/clerezza/platform/accountcontrolpanel/ProfilePanel.scala?rev=1141453&r1=1141452&r2=1141453&view=diff
==============================================================================
--- incubator/clerezza/trunk/parent/platform.accountcontrolpanel/platform.accountcontrolpanel.core/src/main/scala/org/apache/clerezza/platform/accountcontrolpanel/ProfilePanel.scala (original)
+++ incubator/clerezza/trunk/parent/platform.accountcontrolpanel/platform.accountcontrolpanel.core/src/main/scala/org/apache/clerezza/platform/accountcontrolpanel/ProfilePanel.scala Thu Jun 30 09:11:04 2011
@@ -82,7 +82,7 @@ object ProfilePanel {
 class ProfilePanel extends Logging {
 
 	import collection.JavaConversions._
-	import EasyGraph._
+	import EzGraph._
 	import EzStyleChoice.unicode
 
 
@@ -106,7 +106,7 @@ class ProfilePanel extends Logging {
 				val profile = userInSysGraph.getNode match {
 					case blank: BNode => {
 						//user does not have a webId yet
-						val g = new EasyGraph()
+						val g = EzGraph()
 						(
 							g.bnode ⟝ CONTROLPANEL.isLocalProfile ⟶ true
 								⟝ CONTROLPANEL.suggestedPPDUri ⟶ profileDocUri
@@ -136,7 +136,7 @@ class ProfilePanel extends Logging {
 					} catch {
 						case e => {
 							logger.warn("cought exception trying to fetch graph - these graphs should already be in store " + friend, e)
-							new EasyGraph().add(friend, SKOS.note, "problem with fetching this node: " + e)
+							EzGraph().add(friend, SKOS.note, "problem with fetching this node: " + e)
 						}
 					}
 				}
@@ -289,7 +289,7 @@ class ProfilePanel extends Logging {
 		     val webIdInfo = webIdGraphsService.getWebIdInfo(webidRef);
 		     if (webIdInfo.isLocal)
 		) {
-			val certNode = new EasyGraph(webIdInfo.localPublicUserData).bnode
+			val certNode = new EzGraph(webIdInfo.localPublicUserData).bnode
 			( certNode ∈  RSA.RSAPublicKey
 			   ⟝ CERT.identity ⟶  webidRef
 			   ⟝ RSA.modulus ⟶  modulus

Modified: incubator/clerezza/trunk/parent/platform.security.foafssl/test/src/main/scala/org/apache/clerezza/foafssl/test/WebIDTester.scala
URL: http://svn.apache.org/viewvc/incubator/clerezza/trunk/parent/platform.security.foafssl/test/src/main/scala/org/apache/clerezza/foafssl/test/WebIDTester.scala?rev=1141453&r1=1141452&r2=1141453&view=diff
==============================================================================
--- incubator/clerezza/trunk/parent/platform.security.foafssl/test/src/main/scala/org/apache/clerezza/foafssl/test/WebIDTester.scala (original)
+++ incubator/clerezza/trunk/parent/platform.security.foafssl/test/src/main/scala/org/apache/clerezza/foafssl/test/WebIDTester.scala Thu Jun 30 09:11:04 2011
@@ -36,7 +36,7 @@ import java.util.Date
 import org.apache.clerezza.rdf.scala.utils.Preamble.{toRichGraphNode,toFirstElement}
 import serializedform.Serializer
 import java.io.ByteArrayOutputStream
-import org.apache.clerezza.rdf.scala.utils.EasyGraph._
+import org.apache.clerezza.rdf.scala.utils.EzGraph._
 import java.math.BigInteger
 import collection.mutable.{Queue, LinkedList}
 import javax.security.auth.Subject
@@ -676,7 +676,7 @@ class CertTester(subj: Subject, webIdGra
   */
 class Assertor {
 
-	val g = new EasyGraph(new SimpleMGraph)
+	val g = new EzGraph(new SimpleMGraph)
 
 	var assertions: List[Assertion] = Nil
 

Copied: incubator/clerezza/trunk/parent/rdf.scala.utils/src/main/scala/org/apache/clerezza/rdf/scala/utils/EzGraph.scala (from r1141311, incubator/clerezza/trunk/parent/rdf.scala.utils/src/main/scala/org/apache/clerezza/rdf/scala/utils/EasyGraph.scala)
URL: http://svn.apache.org/viewvc/incubator/clerezza/trunk/parent/rdf.scala.utils/src/main/scala/org/apache/clerezza/rdf/scala/utils/EzGraph.scala?p2=incubator/clerezza/trunk/parent/rdf.scala.utils/src/main/scala/org/apache/clerezza/rdf/scala/utils/EzGraph.scala&p1=incubator/clerezza/trunk/parent/rdf.scala.utils/src/main/scala/org/apache/clerezza/rdf/scala/utils/EasyGraph.scala&r1=1141311&r2=1141453&rev=1141453&view=diff
==============================================================================
--- incubator/clerezza/trunk/parent/rdf.scala.utils/src/main/scala/org/apache/clerezza/rdf/scala/utils/EasyGraph.scala (original)
+++ incubator/clerezza/trunk/parent/rdf.scala.utils/src/main/scala/org/apache/clerezza/rdf/scala/utils/EzGraph.scala Thu Jun 30 09:11:04 2011
@@ -29,7 +29,10 @@ import org.apache.clerezza.rdf.utils.{Gr
 import org.apache.clerezza.rdf.core._
 import org.apache.clerezza.rdf.core.impl._
 
-object EasyGraph {
+object EzGraph {
+
+	def apply(graph: HashSet[Triple]) = new EzGraph(graph)
+	def apply() = new EzGraph()
 
 	private val litFactory = LiteralFactory.getInstance
 
@@ -124,7 +127,7 @@ object EzStyleChoice {
  * @created: 20/04/2011
  */
 
-class EasyGraph(val graph: HashSet[Triple]) extends SimpleMGraph(graph) {
+class EzGraph(val graph: HashSet[Triple]) extends SimpleMGraph(graph) {
 
 	/*
 	* because we can't jump straight to super constructor in Scala we need to
@@ -145,7 +148,7 @@ class EasyGraph(val graph: HashSet[Tripl
 	}
 
 	def bnode[T<: EzGraphNode](implicit writingStyle: EzStyle[T]=EzStyleChoice.unicode ): T = {
-		apply(new BNode)(writingStyle)
+		node(new BNode)(writingStyle)
 	}
 
 	val namedBnodes = new HashMap[String,BNode]
@@ -161,10 +164,10 @@ class EasyGraph(val graph: HashSet[Tripl
 	}
 
 	def u[T<: EzGraphNode](url: String)(implicit writingStyle: EzStyle[T]=EzStyleChoice.unicode): T = {
-		apply(new UriRef(url))(writingStyle)
+		node(new UriRef(url))(writingStyle)
 	}
 
-	def apply[T<: EzGraphNode](subj: NonLiteral)(implicit writingStyle: EzStyle[T]=EzStyleChoice.unicode ): T = {
+	def node[T<: EzGraphNode](subj: NonLiteral)(implicit writingStyle: EzStyle[T]=EzStyleChoice.unicode ): T = {
 	 	writingStyle.preferred(subj,this)
 	}
 
@@ -410,13 +413,13 @@ object EzGraphNode {
 }
 
 /**
- * EzGraphNode. Create instances from an EasyGraph object. Differnt notations implementations can be used.
+ * EzGraphNode. Create instances from an EzGraph object. Differnt notations implementations can be used.
  */
 abstract class EzGraphNode(val ref: NonLiteral, val graph: TripleCollection) extends GraphNode(ref, graph) {
 
 //	lazy val easyGraph = graph match {
-//		case eg: EasyGraph => eg
-//		case other: TripleCollection => new EasyGraph(graph)
+//		case eg: EzGraph => eg
+//		case other: TripleCollection => new EzGraph(graph)
 //	}
 
 	def +(sub: EzGraphNode) = {

Copied: incubator/clerezza/trunk/parent/rdf.scala.utils/src/test/scala/org/apache/clerezza/rdf/scala/utils/EzGraphTest.scala (from r1141311, incubator/clerezza/trunk/parent/rdf.scala.utils/src/test/scala/org/apache/clerezza/rdf/scala/utils/EasyGraphTest.scala)
URL: http://svn.apache.org/viewvc/incubator/clerezza/trunk/parent/rdf.scala.utils/src/test/scala/org/apache/clerezza/rdf/scala/utils/EzGraphTest.scala?p2=incubator/clerezza/trunk/parent/rdf.scala.utils/src/test/scala/org/apache/clerezza/rdf/scala/utils/EzGraphTest.scala&p1=incubator/clerezza/trunk/parent/rdf.scala.utils/src/test/scala/org/apache/clerezza/rdf/scala/utils/EasyGraphTest.scala&r1=1141311&r2=1141453&rev=1141453&view=diff
==============================================================================
--- incubator/clerezza/trunk/parent/rdf.scala.utils/src/test/scala/org/apache/clerezza/rdf/scala/utils/EasyGraphTest.scala (original)
+++ incubator/clerezza/trunk/parent/rdf.scala.utils/src/test/scala/org/apache/clerezza/rdf/scala/utils/EzGraphTest.scala Thu Jun 30 09:11:04 2011
@@ -23,7 +23,7 @@ import org.junit._
 import org.apache.clerezza.rdf.core._
 import impl._
 
-class EasyGraphTest {
+class EzGraphTest {
 
 	val bblfishModulus = """
 	9D ☮ 79 ☮ BF ☮ E2 ☮ F4 ☮ 98 ☮ BC ☮ 79 ☮ 6D ☮ AB ☮ 73 ☮ E2 ☮ 8B ☮ 39 ☮ 4D ☮ B5 26 ✜ 68 ✜ 49 ✜ EE ✜ 71 ✜ 87 ✜
@@ -88,7 +88,7 @@ class EasyGraphTest {
 		val reto= new BNode()
 		gr.add(new TripleImpl(reto,RDF.`type`, FOAF.Person))
 
-		val ez = new EasyGraph()
+		val ez = EzGraph()
 		ez.bnode ∈ FOAF.Person
 
 		Assert.assertEquals("the two graphs should be of same size",gr.size(),ez.size())
@@ -116,9 +116,9 @@ class EasyGraphTest {
 		gr.add(new TripleImpl(list3,RDF.rest,RDF.nil))
 		gr.add(new TripleImpl(reto,RDF.`type`, FOAF.Person))
 
-		val ez = new EasyGraph()
+		val ez = EzGraph()
 
-		import org.apache.clerezza.rdf.scala.utils.EasyGraph._
+		import org.apache.clerezza.rdf.scala.utils.EzGraph._
 		import org.apache.clerezza.rdf.scala.utils.Lang._
 		( ez.u(retoUri) ∈ FOAF.Person
 			    ⟝ todoRef ⟶ List[Resource]("SPARQL update support".lang(en),"XSPARQL support".lang(en),holiday.uri))
@@ -135,14 +135,14 @@ class EasyGraphTest {
 		gr.add(new TripleImpl(reto,FOAF.knows,new UriRef(henryUri)))
 		gr.add(new TripleImpl(reto,FOAF.knows,new UriRef(danbriUri)))
 
-		val ez = new EasyGraph()
-		import org.apache.clerezza.rdf.scala.utils.EasyGraph._
+		val ez = EzGraph()
+		import org.apache.clerezza.rdf.scala.utils.EzGraph._
 		(ez.u(retoUri)(EzStyleChoice.ascii) -- FOAF.knows -->> List(henryUri.uri,danbriUri.uri))
 
 		Assert.assertEquals("the two graphs should be of same size",gr.size(),ez.size())
 		Assert.assertEquals("Both graphs should contain exactly the same triples",gr.getGraph,ez.getGraph)
 
-		val ez2 = new EasyGraph()
+		val ez2 = EzGraph()
 		(ez2.u(retoUri)(EzStyleChoice.unicode) ⟝  FOAF.knows ⟶*  Set(danbriUri.uri,henryUri.uri))
 
 		Assert.assertEquals("the two graphs should be of same size",gr.size(),ez2.size())
@@ -152,7 +152,7 @@ class EasyGraphTest {
 
 	@Test
 	def langEquals {
-		import org.apache.clerezza.rdf.scala.utils.EasyGraph._
+		import org.apache.clerezza.rdf.scala.utils.EzGraph._
 		import org.apache.clerezza.rdf.scala.utils.Lang._
 
 		 val lit = new PlainLiteralImpl("SPARQL update support",new Language("en"))
@@ -172,7 +172,7 @@ class EasyGraphTest {
 
 	@Test
 	def uriEquals {
-		import org.apache.clerezza.rdf.scala.utils.EasyGraph._
+		import org.apache.clerezza.rdf.scala.utils.EzGraph._
 		val uc = new UriRef("http://clerezza.org/")
 		val ec = "http://clerezza.org/".uri
 
@@ -192,9 +192,9 @@ class EasyGraphTest {
 	   val gr = new SimpleMGraph
 		gr.add(new TripleImpl(new BNode,OWL.sameAs,n3Lit))
 
-		import org.apache.clerezza.rdf.scala.utils.EasyGraph._
+		import org.apache.clerezza.rdf.scala.utils.EzGraph._
 		import org.apache.clerezza.rdf.scala.utils.Lang._
-		val ez = new EasyGraph()
+		val ez = EzGraph()
 
 		val res : EzGraphNode = (ez.bnode ⟝  OWL.sameAs ⟶  (n3^^"http://example.com/turtle".uri))
 
@@ -207,7 +207,7 @@ class EasyGraphTest {
 		val exp = LiteralFactory.getInstance().createTypedLiteral(65537)
 		val mod= new TypedLiteralImpl(bblfishModulus,hex)
 
-		import org.apache.clerezza.rdf.scala.utils.EasyGraph._
+		import org.apache.clerezza.rdf.scala.utils.EzGraph._
 		val modZ: TypedLiteral = bblfishModulus^^hex
 		val expZ: TypedLiteral = 65537
 
@@ -222,9 +222,9 @@ class EasyGraphTest {
 
 	@Test
 	def usingSymbolicArrows {
-		import org.apache.clerezza.rdf.scala.utils.EasyGraph._
+		import org.apache.clerezza.rdf.scala.utils.EzGraph._
 		import org.apache.clerezza.rdf.scala.utils.Lang._
-		val ez = new EasyGraph()
+		val ez = EzGraph()
 		import EzStyleChoice.unicode //in IntelliJ this is needed for the moment to remove the red lines
 		 // example using arrows
 		 (
@@ -258,10 +258,10 @@ class EasyGraphTest {
 
 	@Test
 	def usingAsciiArrows {
-		import org.apache.clerezza.rdf.scala.utils.EasyGraph._
+		import org.apache.clerezza.rdf.scala.utils.EzGraph._
 		import org.apache.clerezza.rdf.scala.utils.Lang._
 		import EzStyleChoice.ascii
-		 val ez = new EasyGraph()
+		 val ez = EzGraph()
 		 // example using arrows
 		 (
 		   ez.b_("reto").a(FOAF.Person)
@@ -295,11 +295,11 @@ class EasyGraphTest {
 
 	@Test
 	def usingWordOperators {
-		import org.apache.clerezza.rdf.scala.utils.EasyGraph._
+		import org.apache.clerezza.rdf.scala.utils.EzGraph._
 		import org.apache.clerezza.rdf.scala.utils.Lang._
 		import EzStyleChoice.english
 
-		 val ez = new EasyGraph()
+		 val ez = EzGraph()
 		 // example using arrows
 		 (
 		   ez.b_("reto").asInstanceOf[EzGraphNodeEn] a FOAF.Person