You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@oodt.apache.org by ke...@apache.org on 2010/07/16 04:54:28 UTC

svn commit: r964661 - in /incubator/oodt/trunk/profile/src: main/dtd/ main/java/org/apache/oodt/profile/ test/org/apache/oodt/profile/ test/org/apache/oodt/profile/handlers/lightweight/ testdata/

Author: kelly
Date: Fri Jul 16 02:54:27 2010
New Revision: 964661

URL: http://svn.apache.org/viewvc?rev=964661&view=rev
Log:
Work around yet more svn checksum errors with another tinier commit


Added:
    incubator/oodt/trunk/profile/src/main/java/org/apache/oodt/profile/DefaultFactory.java
    incubator/oodt/trunk/profile/src/main/java/org/apache/oodt/profile/ProfileSQLException.java
    incubator/oodt/trunk/profile/src/main/java/org/apache/oodt/profile/Utility.java
Modified:
    incubator/oodt/trunk/profile/src/main/dtd/prof.dtd   (props changed)
    incubator/oodt/trunk/profile/src/test/org/apache/oodt/profile/EnumeratedProfileElementTest.java   (contents, props changed)
    incubator/oodt/trunk/profile/src/test/org/apache/oodt/profile/ProfileAttributesTest.java   (contents, props changed)
    incubator/oodt/trunk/profile/src/test/org/apache/oodt/profile/ProfileElementTestCase.java   (contents, props changed)
    incubator/oodt/trunk/profile/src/test/org/apache/oodt/profile/ProfileTest.java   (contents, props changed)
    incubator/oodt/trunk/profile/src/test/org/apache/oodt/profile/RangedProfileElementTest.java   (contents, props changed)
    incubator/oodt/trunk/profile/src/test/org/apache/oodt/profile/ResourceAttributesTest.java   (contents, props changed)
    incubator/oodt/trunk/profile/src/test/org/apache/oodt/profile/handlers/lightweight/LightweightProfileServerTest.java   (contents, props changed)
    incubator/oodt/trunk/profile/src/testdata/lightweightTest.xml   (props changed)
    incubator/oodt/trunk/profile/src/testdata/test.rdf   (props changed)
    incubator/oodt/trunk/profile/src/testdata/test.xml   (props changed)

Propchange: incubator/oodt/trunk/profile/src/main/dtd/prof.dtd
            ('svn:executable' removed)

Added: incubator/oodt/trunk/profile/src/main/java/org/apache/oodt/profile/DefaultFactory.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/profile/src/main/java/org/apache/oodt/profile/DefaultFactory.java?rev=964661&view=auto
==============================================================================
--- incubator/oodt/trunk/profile/src/main/java/org/apache/oodt/profile/DefaultFactory.java (added)
+++ incubator/oodt/trunk/profile/src/main/java/org/apache/oodt/profile/DefaultFactory.java Fri Jul 16 02:54:27 2010
@@ -0,0 +1,56 @@
+// Licensed to the Apache Software Foundation (ASF) under one or more contributor
+// license agreements.  See the NOTICE.txt 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.oodt.profile;
+
+import java.util.List;
+import org.w3c.dom.Element;
+
+/**
+ * Default factory for profile objects.
+ *
+ * This factory creates the typical profile objects {@link RangedProfileElement}, {@link
+ * UnspecifiedProfileElement}, {@link EnumeratedProfileElement}, {@link Profile}, {@link
+ * ProfileAttributes}, and {@link ResourceAttributes}.
+ *
+ * @author Kelly
+ * @version $Revision: 1.1.1.1 $
+ */
+class DefaultFactory implements ObjectFactory {
+	public RangedProfileElement createRangedProfileElement(Profile profile, String name, String id, String desc, String type,
+		String unit, List synonyms, boolean obligation, int maxOccurrence, String comments, String min, String max) {
+		return new RangedProfileElement(profile, name, id, desc, type, unit, synonyms, obligation, maxOccurrence,
+			comments, min, max);
+	}
+	public UnspecifiedProfileElement createUnspecifiedProfileElement(Profile profile, String name, String id, String desc,
+		String type, String unit, List synonyms, boolean obligation, int maxOccurrence, String comments) {
+		return new UnspecifiedProfileElement(profile, name, id, desc, type, unit, synonyms, obligation, maxOccurrence,
+			comments);
+	}
+	public EnumeratedProfileElement createEnumeratedProfileElement(Profile profile, String name, String id, String desc,
+		String type, String unit, List synonyms, boolean obligation, int maxOccurrence, String comments, List values) {
+		return new EnumeratedProfileElement(profile, name, id, desc, type, unit, synonyms, obligation, maxOccurrence,
+			comments, values);
+	}
+	public Profile createProfile(Element node) {
+		return new Profile(node, this);
+	}
+	public ProfileAttributes createProfileAttributes(Element node) {
+		return new ProfileAttributes(node);
+	}
+	public ResourceAttributes createResourceAttributes(Profile profile, Element node) {
+		return new ResourceAttributes(profile, node);
+	}
+}

Added: incubator/oodt/trunk/profile/src/main/java/org/apache/oodt/profile/ProfileSQLException.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/profile/src/main/java/org/apache/oodt/profile/ProfileSQLException.java?rev=964661&view=auto
==============================================================================
--- incubator/oodt/trunk/profile/src/main/java/org/apache/oodt/profile/ProfileSQLException.java (added)
+++ incubator/oodt/trunk/profile/src/main/java/org/apache/oodt/profile/ProfileSQLException.java Fri Jul 16 02:54:27 2010
@@ -0,0 +1,34 @@
+// Licensed to the Apache Software Foundation (ASF) under one or more contributor
+// license agreements.  See the NOTICE.txt 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.oodt.profile;
+
+import java.sql.SQLException;
+
+/**
+ * A database-related SQL exception from a profile server.
+ *
+ * @author Kelly
+ */
+public class ProfileSQLException extends ProfileException {
+	/**
+	 * Create a profile SQL exception.
+	 *
+	 * @param cause The SQL exception that caused this profile exception.
+	 */
+	public ProfileSQLException(SQLException cause) {
+		super(cause);
+	}
+}

Added: incubator/oodt/trunk/profile/src/main/java/org/apache/oodt/profile/Utility.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/profile/src/main/java/org/apache/oodt/profile/Utility.java?rev=964661&view=auto
==============================================================================
--- incubator/oodt/trunk/profile/src/main/java/org/apache/oodt/profile/Utility.java (added)
+++ incubator/oodt/trunk/profile/src/main/java/org/apache/oodt/profile/Utility.java Fri Jul 16 02:54:27 2010
@@ -0,0 +1,245 @@
+// Licensed to the Apache Software Foundation (ASF) under one or more contributor
+// license agreements.  See the NOTICE.txt 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.oodt.profile;
+
+import org.apache.oodt.commons.Configuration;
+import java.io.IOException;
+import org.xml.sax.SAXException;
+import org.xml.sax.SAXParseException;
+import com.hp.hpl.mesa.rdf.jena.mem.ModelMem;
+import com.hp.hpl.mesa.rdf.jena.model.Model;
+import com.hp.hpl.mesa.rdf.jena.model.Resource;
+import com.hp.hpl.mesa.rdf.jena.model.Property;
+import com.hp.hpl.mesa.rdf.jena.model.RDFException;
+import java.util.Iterator;
+import java.util.Collection;
+import com.hp.hpl.mesa.rdf.jena.model.Bag;
+import com.hp.hpl.mesa.rdf.jena.model.Seq;
+import java.util.List;
+import java.net.URI;
+
+/**
+ * Profile utilities.
+ *
+ * Utility methods for profiles.
+ *
+ * @author Kelly
+ */
+class Utility {
+	/**
+	 * Don't call because this is a utiliy class.
+	 */
+	private Utility() {
+		throw new IllegalStateException("Utility class");
+	}
+
+	static void addProperty(Model model, Resource resource, Property property, Object value, ProfileAttributes profAttr,
+		URI uri) throws RDFException {
+
+		if (value == null || value.toString().length() == 0) return;
+
+		Object obj;
+		if (value instanceof Collection) {
+			Collection collection = (Collection) value;
+			if (collection.isEmpty()) return;
+			Bag bag = model.createBag(uri + "_" + property.getLocalName() + "_bag");
+			for (Iterator i = collection.iterator(); i.hasNext();)
+				bag.add(i.next());
+			resource.addProperty(property, bag);
+			obj = bag;
+		} else {
+			resource.addProperty(property, value);
+			obj = value;
+		}
+
+		Resource reification = model.createResource(uri + "_" + property.getLocalName() + "_reification");
+
+		reification.addProperty(rdfSubject, resource);
+		reification.addProperty(rdfPredicate, property);
+		reification.addProperty(rdfObject, obj);
+		reification.addProperty(rdfType, rdfStatement);
+
+		addPotentiallyNullReifiedStatement(reification, edmID, profAttr.getVersion());
+		addPotentiallyNullReifiedStatement(reification, edmVersion, profAttr.getVersion());
+		addPotentiallyNullReifiedStatement(reification, edmType, profAttr.getType());
+		addPotentiallyNullReifiedStatement(reification, edmStatus, profAttr.getStatusID());
+		addPotentiallyNullReifiedStatement(reification, edmSecurity, profAttr.getSecurityType());
+		addPotentiallyNullReifiedStatement(reification, edmParent, profAttr.getParent());
+		addPotentiallyNullReifiedStatement(reification, edmRegAuth, profAttr.getRegAuthority());
+
+		List children = profAttr.getChildren();
+		if (!children.isEmpty()) {
+			Bag bag = model.createBag(uri + "_" + property.getLocalName() + "_childrenBag");
+			for (Iterator i = children.iterator(); i.hasNext();)
+				bag.add(i.next());
+			reification.addProperty(edmChild, bag);
+		}
+
+		List revNotes = profAttr.getRevisionNotes();
+		if (!revNotes.isEmpty()) {
+			Seq seq = model.createSeq(uri + "_" + property.getLocalName() + "_revNotesSeq");
+			for (Iterator i = revNotes.iterator(); i.hasNext();)
+				seq.add(i.next());
+			reification.addProperty(edmRevNote, seq);
+		}
+	}
+
+	private static void addPotentiallyNullReifiedStatement(Resource reification, Property property, Object value)
+		throws RDFException {
+		if (value == null || value.toString().length() == 0) return;
+		reification.addProperty(property, value);
+	}
+
+
+	/** Dublin core's title */
+	static Property dcTitle;
+	static Property dcSubject;
+	static Property dcDescription;
+	static Property dcPublisher;
+	static Property dcContributor;
+	static Property dcCreator;
+	static Property dcDate;
+	static Property dcType;
+	static Property dcFormat;
+	static Property dcSource;
+	static Property dcLanguage;
+	static Property dcRelation;
+	static Property dcCoverage;
+	static Property dcRights;
+
+	/** A resource that is an RDF statement. */
+	static Resource rdfStatement;
+
+	/** A property that is an RDF subject of a statement. */
+	static Property rdfSubject;
+
+	/** A property that is an RDF predicate of a statement. */
+	static Property rdfPredicate;
+
+	/** A property that is an object of a statement. */
+	static Property rdfObject;
+
+	/** A property that names the type of an RDF resource. */
+	static Property rdfType;
+
+	private static final String RDF_SYNTAX_NS = "http://www.w3.org/1999/02/22-rdf-syntax-ns#";
+
+	private static final String DC_NS = "http://purl.org/dc/elements/1.1/";
+
+	private static Property edmID;
+	private static Property edmVersion;
+	private static Property edmType;
+	private static Property edmStatus;
+	private static Property edmSecurity;
+	private static Property edmParent;
+	private static Property edmChild;
+	private static Property edmRegAuth;
+	private static Property edmRevNote;
+
+	static Property edmElement;
+	static Property edmContext;
+	static Property edmAggregation;
+	static Property edmClass;
+	static Property edmLocation;
+	static Property edmElemID;
+	static Property edmDescription;
+	static Property edmElemType;
+	static Property edmUnit;
+	static Property edmSynonym;
+	static Property edmObligation;
+	static Property edmMaxOccurrence;
+	static Property edmComment;
+	static Property edmMinValue;
+	static Property edmMaxValue;
+	static Property edmValue;
+
+	/**
+	 * Initialize this class.
+	 */
+	static {
+		try {
+			Configuration config = Configuration.getConfiguration();
+			String profNS = System.getProperty("jpl.rdf.ns", "http://oodt.jpl.nasa.gov/grid-profile/rdfs/prof.rdf");
+			Model model = new ModelMem();
+
+			rdfStatement     = model.createResource(RDF_SYNTAX_NS + "Statement");
+
+			rdfSubject       = model.createProperty(RDF_SYNTAX_NS, "subject");
+			rdfPredicate     = model.createProperty(RDF_SYNTAX_NS, "predicate");
+			rdfObject        = model.createProperty(RDF_SYNTAX_NS, "object");
+			rdfType          = model.createProperty(RDF_SYNTAX_NS, "type");
+
+			dcTitle          = model.createProperty(DC_NS, "title");
+			dcCreator        = model.createProperty(DC_NS, "creator");
+			dcSubject        = model.createProperty(DC_NS, "subject");
+			dcDescription    = model.createProperty(DC_NS, "description");
+			dcPublisher      = model.createProperty(DC_NS, "publisher");
+			dcContributor    = model.createProperty(DC_NS, "contributor");
+			dcDate           = model.createProperty(DC_NS, "date");
+			dcType           = model.createProperty(DC_NS, "type");
+			dcFormat         = model.createProperty(DC_NS, "format");
+			dcSource         = model.createProperty(DC_NS, "source");
+			dcLanguage       = model.createProperty(DC_NS, "language");
+			dcRelation       = model.createProperty(DC_NS, "relation");
+			dcCoverage       = model.createProperty(DC_NS, "coverage");
+			dcRights         = model.createProperty(DC_NS, "rights");
+
+			edmID            = model.createProperty(profNS, "id");
+			edmVersion       = model.createProperty(profNS, "version");
+			edmType          = model.createProperty(profNS, "type");
+			edmStatus        = model.createProperty(profNS, "status");
+			edmSecurity      = model.createProperty(profNS, "security");
+			edmParent        = model.createProperty(profNS, "parent");
+			edmChild         = model.createProperty(profNS, "child");
+			edmRegAuth       = model.createProperty(profNS, "regAuth");
+			edmRevNote       = model.createProperty(profNS, "revNote");
+			edmElement       = model.createProperty(profNS, "element");
+			edmContext       = model.createProperty(profNS, "context");
+			edmClass         = model.createProperty(profNS, "class");
+			edmAggregation   = model.createProperty(profNS, "aggregation");
+			edmLocation      = model.createProperty(profNS, "location");
+
+			edmElemID        = model.createProperty(profNS, "edmElemID");
+			edmDescription   = model.createProperty(profNS, "edmDescription");
+			edmElemType      = model.createProperty(profNS, "edmElemType");
+			edmUnit          = model.createProperty(profNS, "edmUnit");
+			edmSynonym       = model.createProperty(profNS, "edmSynonym");
+			edmObligation    = model.createProperty(profNS, "edmObligation");
+			edmMaxOccurrence = model.createProperty(profNS, "edmMaxOccurrence");
+			edmComment       = model.createProperty(profNS, "edmComment");
+			edmMinValue      = model.createProperty(profNS, "edmMinValue");
+			edmMaxValue      = model.createProperty(profNS, "edmMaxValue");
+			edmValue         = model.createProperty(profNS, "edmValue");
+
+		} catch (IOException ex) {
+			System.err.println("Fatal I/O error prevents reading of configuration: " + ex.getMessage());
+			System.exit(1);
+		} catch (SAXParseException ex) {
+			System.err.println("Fatal error parsing file (public ID \"" + ex.getPublicId() + "\", system ID \""
+				+ ex.getSystemId() + "\"), line " + ex.getLineNumber() + " column " + ex.getColumnNumber()
+				+ ": " + ex.getMessage());
+			System.exit(1);
+		} catch (SAXException ex) {
+			System.err.println("Fatal SAX exception: " + ex.getMessage() + (ex.getException() == null? ""
+				: " (embedded exception " + ex.getException().getClass().getName() + ": "
+				+ ex.getException().getMessage() + ")"));
+			System.exit(1);
+		} catch (RDFException ex) {
+			System.err.println("Fatal RDF exception " + ex.getClass().getName() + ": " + ex.getMessage());
+			System.exit(1);
+		}
+	}
+}

Modified: incubator/oodt/trunk/profile/src/test/org/apache/oodt/profile/EnumeratedProfileElementTest.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/profile/src/test/org/apache/oodt/profile/EnumeratedProfileElementTest.java?rev=964661&r1=964660&r2=964661&view=diff
==============================================================================
--- incubator/oodt/trunk/profile/src/test/org/apache/oodt/profile/EnumeratedProfileElementTest.java (original)
+++ incubator/oodt/trunk/profile/src/test/org/apache/oodt/profile/EnumeratedProfileElementTest.java Fri Jul 16 02:54:27 2010
@@ -16,7 +16,7 @@
  */
 
 
-package jpl.eda.profile;
+package org.apache.oodt.profile;
 
 import java.util.ArrayList;
 import java.util.Arrays;
@@ -27,8 +27,8 @@ import javax.xml.transform.dom.DOMSource
 import javax.xml.transform.stream.StreamResult;
 import javax.xml.transform.Transformer;
 import javax.xml.transform.TransformerFactory;
-import jpl.eda.io.NullOutputStream;
-import jpl.eda.util.XML;
+import org.apache.oodt.commons.io.NullOutputStream;
+import org.apache.oodt.commons.util.XML;
 import org.w3c.dom.Document;
 import org.w3c.dom.Node;
 

Propchange: incubator/oodt/trunk/profile/src/test/org/apache/oodt/profile/EnumeratedProfileElementTest.java
            ('svn:executable' removed)

Modified: incubator/oodt/trunk/profile/src/test/org/apache/oodt/profile/ProfileAttributesTest.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/profile/src/test/org/apache/oodt/profile/ProfileAttributesTest.java?rev=964661&r1=964660&r2=964661&view=diff
==============================================================================
--- incubator/oodt/trunk/profile/src/test/org/apache/oodt/profile/ProfileAttributesTest.java (original)
+++ incubator/oodt/trunk/profile/src/test/org/apache/oodt/profile/ProfileAttributesTest.java Fri Jul 16 02:54:27 2010
@@ -16,7 +16,7 @@
  */
 
 
-package jpl.eda.profile;
+package org.apache.oodt.profile;
 
 import java.util.ArrayList;
 import java.util.Collections;
@@ -25,8 +25,8 @@ import javax.xml.transform.dom.DOMSource
 import javax.xml.transform.stream.StreamResult;
 import javax.xml.transform.Transformer;
 import javax.xml.transform.TransformerFactory;
-import jpl.eda.io.NullOutputStream;
-import jpl.eda.util.XML;
+import org.apache.oodt.commons.io.NullOutputStream;
+import org.apache.oodt.commons.util.XML;
 import junit.framework.TestCase;
 import org.w3c.dom.Document;
 import org.w3c.dom.Node;

Propchange: incubator/oodt/trunk/profile/src/test/org/apache/oodt/profile/ProfileAttributesTest.java
            ('svn:executable' removed)

Modified: incubator/oodt/trunk/profile/src/test/org/apache/oodt/profile/ProfileElementTestCase.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/profile/src/test/org/apache/oodt/profile/ProfileElementTestCase.java?rev=964661&r1=964660&r2=964661&view=diff
==============================================================================
--- incubator/oodt/trunk/profile/src/test/org/apache/oodt/profile/ProfileElementTestCase.java (original)
+++ incubator/oodt/trunk/profile/src/test/org/apache/oodt/profile/ProfileElementTestCase.java Fri Jul 16 02:54:27 2010
@@ -16,13 +16,13 @@
  */
 
 
-package jpl.eda.profile;
+package org.apache.oodt.profile;
 
 import junit.framework.TestCase;
 import org.w3c.dom.Document;
 import org.w3c.dom.Node;
 import org.w3c.dom.NodeList;
-import jpl.eda.util.XML;
+import org.apache.oodt.commons.util.XML;
 
 /**
  * Test case for profile elements.

Propchange: incubator/oodt/trunk/profile/src/test/org/apache/oodt/profile/ProfileElementTestCase.java
            ('svn:executable' removed)

Modified: incubator/oodt/trunk/profile/src/test/org/apache/oodt/profile/ProfileTest.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/profile/src/test/org/apache/oodt/profile/ProfileTest.java?rev=964661&r1=964660&r2=964661&view=diff
==============================================================================
--- incubator/oodt/trunk/profile/src/test/org/apache/oodt/profile/ProfileTest.java (original)
+++ incubator/oodt/trunk/profile/src/test/org/apache/oodt/profile/ProfileTest.java Fri Jul 16 02:54:27 2010
@@ -16,13 +16,13 @@
  */
 
 
-package jpl.eda.profile;
+package org.apache.oodt.profile;
 
 import java.io.BufferedReader;
 import java.io.InputStreamReader;
 import java.io.PrintWriter;
 import java.util.Map;
-import jpl.eda.util.XML;
+import org.apache.oodt.commons.util.XML;
 import junit.framework.TestCase;
 import org.w3c.dom.Document;
 import com.hp.hpl.mesa.rdf.jena.model.Model;

Propchange: incubator/oodt/trunk/profile/src/test/org/apache/oodt/profile/ProfileTest.java
            ('svn:executable' removed)

Modified: incubator/oodt/trunk/profile/src/test/org/apache/oodt/profile/RangedProfileElementTest.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/profile/src/test/org/apache/oodt/profile/RangedProfileElementTest.java?rev=964661&r1=964660&r2=964661&view=diff
==============================================================================
--- incubator/oodt/trunk/profile/src/test/org/apache/oodt/profile/RangedProfileElementTest.java (original)
+++ incubator/oodt/trunk/profile/src/test/org/apache/oodt/profile/RangedProfileElementTest.java Fri Jul 16 02:54:27 2010
@@ -16,15 +16,15 @@
  */
 
 
-package jpl.eda.profile;
+package org.apache.oodt.profile;
 
 import java.util.ArrayList;
 import javax.xml.transform.dom.DOMSource;
 import javax.xml.transform.stream.StreamResult;
 import javax.xml.transform.Transformer;
 import javax.xml.transform.TransformerFactory;
-import jpl.eda.io.NullOutputStream;
-import jpl.eda.util.XML;
+import org.apache.oodt.commons.io.NullOutputStream;
+import org.apache.oodt.commons.util.XML;
 import junit.framework.TestCase;
 import org.w3c.dom.Document;
 import org.w3c.dom.Node;

Propchange: incubator/oodt/trunk/profile/src/test/org/apache/oodt/profile/RangedProfileElementTest.java
            ('svn:executable' removed)

Modified: incubator/oodt/trunk/profile/src/test/org/apache/oodt/profile/ResourceAttributesTest.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/profile/src/test/org/apache/oodt/profile/ResourceAttributesTest.java?rev=964661&r1=964660&r2=964661&view=diff
==============================================================================
--- incubator/oodt/trunk/profile/src/test/org/apache/oodt/profile/ResourceAttributesTest.java (original)
+++ incubator/oodt/trunk/profile/src/test/org/apache/oodt/profile/ResourceAttributesTest.java Fri Jul 16 02:54:27 2010
@@ -16,7 +16,7 @@
  */
 
 
-package jpl.eda.profile;
+package org.apache.oodt.profile;
 
 import java.util.ArrayList;
 import java.util.Collections;
@@ -25,8 +25,8 @@ import javax.xml.transform.dom.DOMSource
 import javax.xml.transform.stream.StreamResult;
 import javax.xml.transform.Transformer;
 import javax.xml.transform.TransformerFactory;
-import jpl.eda.io.NullOutputStream;
-import jpl.eda.util.XML;
+import org.apache.oodt.commons.io.NullOutputStream;
+import org.apache.oodt.commons.util.XML;
 import junit.framework.TestCase;
 import org.w3c.dom.Document;
 import org.w3c.dom.Node;

Propchange: incubator/oodt/trunk/profile/src/test/org/apache/oodt/profile/ResourceAttributesTest.java
            ('svn:executable' removed)

Modified: incubator/oodt/trunk/profile/src/test/org/apache/oodt/profile/handlers/lightweight/LightweightProfileServerTest.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/profile/src/test/org/apache/oodt/profile/handlers/lightweight/LightweightProfileServerTest.java?rev=964661&r1=964660&r2=964661&view=diff
==============================================================================
--- incubator/oodt/trunk/profile/src/test/org/apache/oodt/profile/handlers/lightweight/LightweightProfileServerTest.java (original)
+++ incubator/oodt/trunk/profile/src/test/org/apache/oodt/profile/handlers/lightweight/LightweightProfileServerTest.java Fri Jul 16 02:54:27 2010
@@ -16,7 +16,7 @@
  */
 
 
-package jpl.eda.profile.handlers.lightweight;
+package org.apache.oodt.profile.handlers.lightweight;
 
 import java.io.IOException;
 import java.io.StringReader;
@@ -24,11 +24,11 @@ import java.util.Collection;
 import java.util.Iterator;
 import java.util.List;
 import java.util.Map;
-import jpl.eda.util.SAXParser;
-import jpl.eda.util.XML;
-import jpl.eda.profile.ProfileElement;
-import jpl.eda.profile.ProfileException;
-import jpl.eda.xmlquery.XMLQuery;
+import org.apache.oodt.commons.util.SAXParser;
+import org.apache.oodt.commons.util.XML;
+import org.apache.oodt.profile.ProfileElement;
+import org.apache.oodt.profile.ProfileException;
+import org.apache.oodt.xmlquery.XMLQuery;
 import junit.framework.TestCase;
 import org.w3c.dom.Document;
 import org.xml.sax.ErrorHandler;

Propchange: incubator/oodt/trunk/profile/src/test/org/apache/oodt/profile/handlers/lightweight/LightweightProfileServerTest.java
            ('svn:executable' removed)

Propchange: incubator/oodt/trunk/profile/src/testdata/lightweightTest.xml
            ('svn:executable' removed)

Propchange: incubator/oodt/trunk/profile/src/testdata/test.rdf
            ('svn:executable' removed)

Propchange: incubator/oodt/trunk/profile/src/testdata/test.xml
            ('svn:executable' removed)