You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@oodt.apache.org by sm...@apache.org on 2010/06/09 21:11:27 UTC

svn commit: r953117 [3/7] - in /incubator/oodt/trunk: pge/src/main/java/gov/nasa/jpl/oodt/cas/pge/ pge/src/main/java/gov/nasa/jpl/oodt/cas/pge/config/ pge/src/main/java/gov/nasa/jpl/oodt/cas/pge/metadata/ pge/src/main/java/gov/nasa/jpl/oodt/cas/pge/que...

Modified: incubator/oodt/trunk/product/src/main/java/jpl/eda/product/rmi/AuthorizedSessionImpl.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/product/src/main/java/jpl/eda/product/rmi/AuthorizedSessionImpl.java?rev=953117&r1=953116&r2=953117&view=diff
==============================================================================
--- incubator/oodt/trunk/product/src/main/java/jpl/eda/product/rmi/AuthorizedSessionImpl.java (original)
+++ incubator/oodt/trunk/product/src/main/java/jpl/eda/product/rmi/AuthorizedSessionImpl.java Wed Jun  9 19:11:21 2010
@@ -1,185 +1,198 @@
-// Copyright 1999-2004 California Institute of Technology. ALL RIGHTS
-// RESERVED. U.S. Government Sponsorship acknowledged.
-//
-// $Id: AuthorizedSessionImpl.java,v 1.3 2004-08-17 14:29:39 kelly Exp $
-
-package jpl.eda.product.rmi;
-
-import java.lang.SecurityManager;
-import java.rmi.RemoteException;
-import java.rmi.server.UnicastRemoteObject;
-import java.security.PrivilegedActionException;
-import java.security.PrivilegedExceptionAction;
-import java.util.Iterator;
-import java.util.List;
-import javax.security.auth.Subject;
-import javax.security.auth.login.LoginContext;
-import javax.security.auth.login.LoginException;
-import jpl.eda.product.LargeProductQueryHandler;
-import jpl.eda.product.ProductException;
-import jpl.eda.product.ProductPermission;
-import jpl.eda.product.QueryHandler;
-import jpl.eda.security.rmi.SequenceGenerator;
-import jpl.eda.xmlquery.XMLQuery;
-
-/**
- * Product server session for an authorized subject.
- *
- * @author Kelly
- * @version $Revision: 1.3 $
- */
-public class AuthorizedSessionImpl extends UnicastRemoteObject implements AuthorizedSession {
-	/**
-	 * Creates a new {@link AuthorizedSessionImpl} instance.
-	 *
-	 * @param portNum Port number object should bind to.
-	 * @param handlers Query handlers.
-	 * @throws RemoteException if an error occurs.
-	 */
-	public AuthorizedSessionImpl(int portNum, List handlers) throws RemoteException {
-		super(portNum);
-		this.handlers = handlers;
-	}
-
-	/** {@inheritDoc} */
-	public synchronized void init(SequenceGenerator sequenceGenerator, LoginContext context) {
-		if (initialized) throw new IllegalStateException("Already initialized");
-		this.sequenceGenerator = sequenceGenerator;
-		this.context = context;
-		subject = context.getSubject();
-		initialized = true;
-	}
-
-	/** {@inheritDoc} */
-	public XMLQuery query(int seq, final XMLQuery query) throws ProductException {
-		checkLogin(seq);
-		try {
-			return (XMLQuery) Subject.doAsPrivileged(subject, new PrivilegedExceptionAction() {
-				public Object run() throws ProductException {
-					return query(query);
-				}
-			}, /*acc*/null);
-		} catch (PrivilegedActionException ex) {
-			throw (ProductException) ex.getException();
-		}
-	}
-
-
-	/**
-	 * Query the query handlers.
-	 *
-	 * @param q a {@link XMLQuery} value.
-	 * @return a {@link XMLQuery} value.
-	 * @throws ProductException if an error occurs.
-	 */
-	private XMLQuery query(XMLQuery q) throws ProductException {
-		SecurityManager sm = System.getSecurityManager();
-		if (sm != null) sm.checkPermission(new ProductPermission("query"));
-		for (Iterator i = handlers.iterator(); i.hasNext();) {
-			QueryHandler handler = (QueryHandler) i.next();
-			handler.query(q);
-		}
-		return q;
-	}
-
-	/** {@inheritDoc} */
-	public byte[] retrieveChunk(int seq, final String productID, final long offset, final int length) throws ProductException {
-		checkLogin(seq);
-		try {
-			return (byte[]) Subject.doAsPrivileged(subject, new PrivilegedExceptionAction() {
-				public Object run() throws ProductException {
-					return retrieveChunk(productID, offset, length);
-				}
-			}, /*acc*/null);
-		} catch (PrivilegedActionException ex) {
-			throw (ProductException) ex.getException();
-		}
-	}
-
-	/**
-	 * Retrieve a chunk.
-	 *
-	 * @param productID a {@link String} value.
-	 * @param offset Where in the product
-	 * @param length How much of the product
-	 * @return a chunk
-	 * @throws ProductException if an error occurs.
-	 */
-	private byte[] retrieveChunk(final String productID, final long offset, final int length) throws ProductException {
-		SecurityManager sm = System.getSecurityManager();
-		if (sm != null) sm.checkPermission(new ProductPermission("retrieveChunk"));
-		for (Iterator i = handlers.iterator(); i.hasNext();) {
-			Object qh = i.next();
-			if (qh instanceof LargeProductQueryHandler) {
-				LargeProductQueryHandler lpqh = (LargeProductQueryHandler) qh;
-				byte[] chunk = lpqh.retrieveChunk(productID, offset, length);
-				if (chunk != null) return chunk;
-			}
-		}
-		return null;
-	}
-
-	/** {@inheritDoc} */
-	public void close(int seq, final String productID) throws ProductException {
-		checkLogin(seq);
-		try {
-			Subject.doAsPrivileged(subject, new PrivilegedExceptionAction() {
-				public Object run() throws ProductException {
-					close(productID);
-					return null;
-				}
-			}, /*acc*/null);
-		} catch (PrivilegedActionException ex) {
-			throw (ProductException) ex.getException();
-		}
-	}
-
-	/**
-	 * Close a chunked product.
-	 *
-	 * @param productID a {@link String} value.
-	 * @throws ProductException if an error occurs.
-	 */
-	private void close(String productID) throws ProductException {
-		SecurityManager sm = System.getSecurityManager();
-		if (sm != null) sm.checkPermission(new ProductPermission("close"));
-		for (Iterator i = handlers.iterator(); i.hasNext();) {
-			Object qh = i.next();
-			if (qh instanceof LargeProductQueryHandler) {
-				LargeProductQueryHandler lpqh = (LargeProductQueryHandler) qh;
-				lpqh.close(productID);
-			}
-		}
-	}
-
-	/**
-	 * Check if the user is logged in and the sequence number is valid.
-	 *
-	 * @param seq Sequence number.
-	 * @throws ProductException if an error occurs.
-	 */
-	private void checkLogin(int seq) throws ProductException {
-		if (context == null) throw new ProductException("Logged out");
-		if (seq == sequenceGenerator.nextSeqNum()) return;
-		try {
-			context.logout();
-		} catch (LoginException ignore) {}
-		context = null;
-		throw new ProductException("Invalid sequence");
-	}
-
-	/** Query handlers. */
-	private List handlers;
-
-	/** Login context. */
-	private LoginContext context;
-
-	/** Sequence generator. */
-	private SequenceGenerator sequenceGenerator;
-
-	/** Subject for whom this session exists. */
-	private Subject subject;
-
-	/** Initialized yet? */
-	private boolean initialized;
-}
+/*
+ * 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 jpl.eda.product.rmi;
+
+import java.lang.SecurityManager;
+import java.rmi.RemoteException;
+import java.rmi.server.UnicastRemoteObject;
+import java.security.PrivilegedActionException;
+import java.security.PrivilegedExceptionAction;
+import java.util.Iterator;
+import java.util.List;
+import javax.security.auth.Subject;
+import javax.security.auth.login.LoginContext;
+import javax.security.auth.login.LoginException;
+import jpl.eda.product.LargeProductQueryHandler;
+import jpl.eda.product.ProductException;
+import jpl.eda.product.ProductPermission;
+import jpl.eda.product.QueryHandler;
+import jpl.eda.security.rmi.SequenceGenerator;
+import jpl.eda.xmlquery.XMLQuery;
+
+/**
+ * Product server session for an authorized subject.
+ *
+ * @author Kelly
+ * @version $Revision: 1.3 $
+ */
+public class AuthorizedSessionImpl extends UnicastRemoteObject implements AuthorizedSession {
+	/**
+	 * Creates a new {@link AuthorizedSessionImpl} instance.
+	 *
+	 * @param portNum Port number object should bind to.
+	 * @param handlers Query handlers.
+	 * @throws RemoteException if an error occurs.
+	 */
+	public AuthorizedSessionImpl(int portNum, List handlers) throws RemoteException {
+		super(portNum);
+		this.handlers = handlers;
+	}
+
+	/** {@inheritDoc} */
+	public synchronized void init(SequenceGenerator sequenceGenerator, LoginContext context) {
+		if (initialized) throw new IllegalStateException("Already initialized");
+		this.sequenceGenerator = sequenceGenerator;
+		this.context = context;
+		subject = context.getSubject();
+		initialized = true;
+	}
+
+	/** {@inheritDoc} */
+	public XMLQuery query(int seq, final XMLQuery query) throws ProductException {
+		checkLogin(seq);
+		try {
+			return (XMLQuery) Subject.doAsPrivileged(subject, new PrivilegedExceptionAction() {
+				public Object run() throws ProductException {
+					return query(query);
+				}
+			}, /*acc*/null);
+		} catch (PrivilegedActionException ex) {
+			throw (ProductException) ex.getException();
+		}
+	}
+
+
+	/**
+	 * Query the query handlers.
+	 *
+	 * @param q a {@link XMLQuery} value.
+	 * @return a {@link XMLQuery} value.
+	 * @throws ProductException if an error occurs.
+	 */
+	private XMLQuery query(XMLQuery q) throws ProductException {
+		SecurityManager sm = System.getSecurityManager();
+		if (sm != null) sm.checkPermission(new ProductPermission("query"));
+		for (Iterator i = handlers.iterator(); i.hasNext();) {
+			QueryHandler handler = (QueryHandler) i.next();
+			handler.query(q);
+		}
+		return q;
+	}
+
+	/** {@inheritDoc} */
+	public byte[] retrieveChunk(int seq, final String productID, final long offset, final int length) throws ProductException {
+		checkLogin(seq);
+		try {
+			return (byte[]) Subject.doAsPrivileged(subject, new PrivilegedExceptionAction() {
+				public Object run() throws ProductException {
+					return retrieveChunk(productID, offset, length);
+				}
+			}, /*acc*/null);
+		} catch (PrivilegedActionException ex) {
+			throw (ProductException) ex.getException();
+		}
+	}
+
+	/**
+	 * Retrieve a chunk.
+	 *
+	 * @param productID a {@link String} value.
+	 * @param offset Where in the product
+	 * @param length How much of the product
+	 * @return a chunk
+	 * @throws ProductException if an error occurs.
+	 */
+	private byte[] retrieveChunk(final String productID, final long offset, final int length) throws ProductException {
+		SecurityManager sm = System.getSecurityManager();
+		if (sm != null) sm.checkPermission(new ProductPermission("retrieveChunk"));
+		for (Iterator i = handlers.iterator(); i.hasNext();) {
+			Object qh = i.next();
+			if (qh instanceof LargeProductQueryHandler) {
+				LargeProductQueryHandler lpqh = (LargeProductQueryHandler) qh;
+				byte[] chunk = lpqh.retrieveChunk(productID, offset, length);
+				if (chunk != null) return chunk;
+			}
+		}
+		return null;
+	}
+
+	/** {@inheritDoc} */
+	public void close(int seq, final String productID) throws ProductException {
+		checkLogin(seq);
+		try {
+			Subject.doAsPrivileged(subject, new PrivilegedExceptionAction() {
+				public Object run() throws ProductException {
+					close(productID);
+					return null;
+				}
+			}, /*acc*/null);
+		} catch (PrivilegedActionException ex) {
+			throw (ProductException) ex.getException();
+		}
+	}
+
+	/**
+	 * Close a chunked product.
+	 *
+	 * @param productID a {@link String} value.
+	 * @throws ProductException if an error occurs.
+	 */
+	private void close(String productID) throws ProductException {
+		SecurityManager sm = System.getSecurityManager();
+		if (sm != null) sm.checkPermission(new ProductPermission("close"));
+		for (Iterator i = handlers.iterator(); i.hasNext();) {
+			Object qh = i.next();
+			if (qh instanceof LargeProductQueryHandler) {
+				LargeProductQueryHandler lpqh = (LargeProductQueryHandler) qh;
+				lpqh.close(productID);
+			}
+		}
+	}
+
+	/**
+	 * Check if the user is logged in and the sequence number is valid.
+	 *
+	 * @param seq Sequence number.
+	 * @throws ProductException if an error occurs.
+	 */
+	private void checkLogin(int seq) throws ProductException {
+		if (context == null) throw new ProductException("Logged out");
+		if (seq == sequenceGenerator.nextSeqNum()) return;
+		try {
+			context.logout();
+		} catch (LoginException ignore) {}
+		context = null;
+		throw new ProductException("Invalid sequence");
+	}
+
+	/** Query handlers. */
+	private List handlers;
+
+	/** Login context. */
+	private LoginContext context;
+
+	/** Sequence generator. */
+	private SequenceGenerator sequenceGenerator;
+
+	/** Subject for whom this session exists. */
+	private Subject subject;
+
+	/** Initialized yet? */
+	private boolean initialized;
+}

Modified: incubator/oodt/trunk/product/src/main/java/jpl/eda/product/rmi/ProductServiceImpl.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/product/src/main/java/jpl/eda/product/rmi/ProductServiceImpl.java?rev=953117&r1=953116&r2=953117&view=diff
==============================================================================
--- incubator/oodt/trunk/product/src/main/java/jpl/eda/product/rmi/ProductServiceImpl.java (original)
+++ incubator/oodt/trunk/product/src/main/java/jpl/eda/product/rmi/ProductServiceImpl.java Wed Jun  9 19:11:21 2010
@@ -1,7 +1,20 @@
-// Copyright 2002 California Institute of Technology.  ALL RIGHTS RESERVED.
-// U.S. Government Sponsorship acknowledged.
-//
-// $Id: ProductServiceImpl.java,v 1.3 2004-08-13 21:28:48 kelly Exp $
+/*
+ * 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 jpl.eda.product.rmi;
 

Modified: incubator/oodt/trunk/product/src/main/java/jpl/eda/product/rmi/ServerImpl.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/product/src/main/java/jpl/eda/product/rmi/ServerImpl.java?rev=953117&r1=953116&r2=953117&view=diff
==============================================================================
--- incubator/oodt/trunk/product/src/main/java/jpl/eda/product/rmi/ServerImpl.java (original)
+++ incubator/oodt/trunk/product/src/main/java/jpl/eda/product/rmi/ServerImpl.java Wed Jun  9 19:11:21 2010
@@ -1,7 +1,20 @@
-// Copyright 2002 California Institute of Technology.  ALL RIGHTS RESERVED.
-// U.S. Government Sponsorship acknowledged.
-//
-// $Id: ServerImpl.java,v 1.1.1.1 2004-03-02 19:45:41 kelly Exp $
+/*
+ * 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 jpl.eda.product.rmi;
 

Modified: incubator/oodt/trunk/product/src/main/java/jpl/eda/product/test/Query.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/product/src/main/java/jpl/eda/product/test/Query.java?rev=953117&r1=953116&r2=953117&view=diff
==============================================================================
--- incubator/oodt/trunk/product/src/main/java/jpl/eda/product/test/Query.java (original)
+++ incubator/oodt/trunk/product/src/main/java/jpl/eda/product/test/Query.java Wed Jun  9 19:11:21 2010
@@ -1,7 +1,20 @@
-// Copyright 2002-2003 California Institute of Technology.  ALL RIGHTS RESERVED.
-// U.S. Government Sponsorship acknowledged.
-//
-// $Id: Query.java,v 1.1 2005-08-03 16:59:18 kelly Exp $
+/*
+ * 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 jpl.eda.product.test;
 

Modified: incubator/oodt/trunk/product/src/main/java/jpl/eda/product/test/TestConfig.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/product/src/main/java/jpl/eda/product/test/TestConfig.java?rev=953117&r1=953116&r2=953117&view=diff
==============================================================================
--- incubator/oodt/trunk/product/src/main/java/jpl/eda/product/test/TestConfig.java (original)
+++ incubator/oodt/trunk/product/src/main/java/jpl/eda/product/test/TestConfig.java Wed Jun  9 19:11:21 2010
@@ -1,7 +1,20 @@
-// Copyright 2002-2003 California Institute of Technology.  ALL RIGHTS RESERVED.
-// U.S. Government Sponsorship acknowledged.
-//
-// $Id: TestConfig.java,v 1.3 2005-08-03 17:00:28 kelly Exp $
+/*
+ * 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 jpl.eda.product.test;
 

Modified: incubator/oodt/trunk/product/src/main/java/jpl/eda/product/test/TestRunner.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/product/src/main/java/jpl/eda/product/test/TestRunner.java?rev=953117&r1=953116&r2=953117&view=diff
==============================================================================
--- incubator/oodt/trunk/product/src/main/java/jpl/eda/product/test/TestRunner.java (original)
+++ incubator/oodt/trunk/product/src/main/java/jpl/eda/product/test/TestRunner.java Wed Jun  9 19:11:21 2010
@@ -1,7 +1,20 @@
-// Copyright 2002-2003 California Institute of Technology.  ALL RIGHTS RESERVED.
-// U.S. Government Sponsorship acknowledged.
-//
-// $Id: TestRunner.java,v 1.2 2005-08-03 17:00:50 kelly Exp $
+/*
+ * 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 jpl.eda.product.test;
 

Modified: incubator/oodt/trunk/product/src/main/java/jpl/eda/xmlquery/ChunkedProductInputStream.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/product/src/main/java/jpl/eda/xmlquery/ChunkedProductInputStream.java?rev=953117&r1=953116&r2=953117&view=diff
==============================================================================
--- incubator/oodt/trunk/product/src/main/java/jpl/eda/xmlquery/ChunkedProductInputStream.java (original)
+++ incubator/oodt/trunk/product/src/main/java/jpl/eda/xmlquery/ChunkedProductInputStream.java Wed Jun  9 19:11:21 2010
@@ -1,7 +1,20 @@
-// Copyright 2003-2005 California Institute of Technology.  ALL RIGHTS RESERVED.
-// U.S. Government Sponsorship acknowledged.
-//
-// $Id: ChunkedProductInputStream.java,v 1.5 2005-06-22 21:04:44 kelly Exp $
+/*
+ * 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 jpl.eda.xmlquery;
 

Modified: incubator/oodt/trunk/product/src/main/java/jpl/eda/xmlquery/LargeResult.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/product/src/main/java/jpl/eda/xmlquery/LargeResult.java?rev=953117&r1=953116&r2=953117&view=diff
==============================================================================
--- incubator/oodt/trunk/product/src/main/java/jpl/eda/xmlquery/LargeResult.java (original)
+++ incubator/oodt/trunk/product/src/main/java/jpl/eda/xmlquery/LargeResult.java Wed Jun  9 19:11:21 2010
@@ -1,7 +1,20 @@
-// Copyright 2002-2003 California Institute of Technology.  ALL RIGHTS RESERVED.
-// U.S. Government Sponsorship acknowledged.
-//
-// $Id: LargeResult.java,v 1.2 2005-08-03 17:02:50 kelly Exp $
+/*
+ * 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 jpl.eda.xmlquery;
 

Modified: incubator/oodt/trunk/product/src/main/java/jpl/oodt/product/ProductException.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/product/src/main/java/jpl/oodt/product/ProductException.java?rev=953117&r1=953116&r2=953117&view=diff
==============================================================================
--- incubator/oodt/trunk/product/src/main/java/jpl/oodt/product/ProductException.java (original)
+++ incubator/oodt/trunk/product/src/main/java/jpl/oodt/product/ProductException.java Wed Jun  9 19:11:21 2010
@@ -1,7 +1,20 @@
-// Copyright 1999-2002 California Institute of Technology.  ALL RIGHTS RESERVED.
-// U.S. Government Sponsorship acknowledged.
-//
-// $Id: ProductException.java,v 1.1 2004-11-30 21:13:06 kelly Exp $
+/*
+ * 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 jpl.oodt.product;
 

Modified: incubator/oodt/trunk/product/src/main/java/jpl/oodt/product/ProductService.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/product/src/main/java/jpl/oodt/product/ProductService.java?rev=953117&r1=953116&r2=953117&view=diff
==============================================================================
--- incubator/oodt/trunk/product/src/main/java/jpl/oodt/product/ProductService.java (original)
+++ incubator/oodt/trunk/product/src/main/java/jpl/oodt/product/ProductService.java Wed Jun  9 19:11:21 2010
@@ -1,7 +1,20 @@
-// Copyright 2002 California Institute of Technology.  ALL RIGHTS RESERVED.
-// U.S. Government Sponsorship acknowledged.
-//
-// $Id: ProductService.java,v 1.1 2004-11-30 21:13:43 kelly Exp $
+/*
+ * 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 jpl.oodt.product;
 

Modified: incubator/oodt/trunk/product/src/main/java/jpl/oodt/product/Server.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/product/src/main/java/jpl/oodt/product/Server.java?rev=953117&r1=953116&r2=953117&view=diff
==============================================================================
--- incubator/oodt/trunk/product/src/main/java/jpl/oodt/product/Server.java (original)
+++ incubator/oodt/trunk/product/src/main/java/jpl/oodt/product/Server.java Wed Jun  9 19:11:21 2010
@@ -1,7 +1,20 @@
-// Copyright 2002 California Institute of Technology.  ALL RIGHTS RESERVED.
-// U.S. Government Sponsorship acknowledged.
-//
-// $Id: Server.java,v 1.1 2004-11-30 21:14:20 kelly Exp $
+/*
+ * 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 jpl.oodt.product;
 

Modified: incubator/oodt/trunk/product/src/main/java/jpl/oodt/product/rmi/OldProductServiceAdaptor.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/product/src/main/java/jpl/oodt/product/rmi/OldProductServiceAdaptor.java?rev=953117&r1=953116&r2=953117&view=diff
==============================================================================
--- incubator/oodt/trunk/product/src/main/java/jpl/oodt/product/rmi/OldProductServiceAdaptor.java (original)
+++ incubator/oodt/trunk/product/src/main/java/jpl/oodt/product/rmi/OldProductServiceAdaptor.java Wed Jun  9 19:11:21 2010
@@ -1,7 +1,20 @@
-// Copyright 2002 California Institute of Technology.  ALL RIGHTS RESERVED.
-// U.S. Government Sponsorship acknowledged.
-//
-// $Id: OldProductServiceAdaptor.java,v 1.1 2004-11-30 21:18:20 kelly Exp $
+/*
+ * 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 jpl.oodt.product.rmi;
 

Modified: incubator/oodt/trunk/product/src/main/java/jpl/oodt/product/rmi/ProductServiceImpl.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/product/src/main/java/jpl/oodt/product/rmi/ProductServiceImpl.java?rev=953117&r1=953116&r2=953117&view=diff
==============================================================================
--- incubator/oodt/trunk/product/src/main/java/jpl/oodt/product/rmi/ProductServiceImpl.java (original)
+++ incubator/oodt/trunk/product/src/main/java/jpl/oodt/product/rmi/ProductServiceImpl.java Wed Jun  9 19:11:21 2010
@@ -1,7 +1,20 @@
-// Copyright 2002 California Institute of Technology.  ALL RIGHTS RESERVED.
-// U.S. Government Sponsorship acknowledged.
-//
-// $Id: ProductServiceImpl.java,v 1.1 2004-11-30 21:19:13 kelly Exp $
+/*
+ * 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 jpl.oodt.product.rmi;
 

Modified: incubator/oodt/trunk/product/src/main/java/jpl/oodt/product/rmi/ServerImpl.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/product/src/main/java/jpl/oodt/product/rmi/ServerImpl.java?rev=953117&r1=953116&r2=953117&view=diff
==============================================================================
--- incubator/oodt/trunk/product/src/main/java/jpl/oodt/product/rmi/ServerImpl.java (original)
+++ incubator/oodt/trunk/product/src/main/java/jpl/oodt/product/rmi/ServerImpl.java Wed Jun  9 19:11:21 2010
@@ -1,7 +1,20 @@
-// Copyright 2002 California Institute of Technology.  ALL RIGHTS RESERVED.
-// U.S. Government Sponsorship acknowledged.
-//
-// $Id: ServerImpl.java,v 1.1 2004-11-30 21:19:39 kelly Exp $
+/*
+ * 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 jpl.oodt.product.rmi;
 

Modified: incubator/oodt/trunk/product/src/main/java/jpl/oodt/xmlquery/Header.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/product/src/main/java/jpl/oodt/xmlquery/Header.java?rev=953117&r1=953116&r2=953117&view=diff
==============================================================================
--- incubator/oodt/trunk/product/src/main/java/jpl/oodt/xmlquery/Header.java (original)
+++ incubator/oodt/trunk/product/src/main/java/jpl/oodt/xmlquery/Header.java Wed Jun  9 19:11:21 2010
@@ -1,53 +1,66 @@
-// Copyright 1999-2004 California Institute of Technology. ALL RIGHTS
-// RESERVED. U.S. Government Sponsorship acknowledged.
-//
-// $Id: Header.java,v 1.1 2004-11-30 21:22:25 kelly Exp $
-
-package jpl.oodt.xmlquery;
-
-import java.io.IOException;
-import java.io.ObjectInputStream;
-import java.io.ObjectOutputStream;
-import java.io.ObjectStreamField;
-import java.io.Serializable;
-
-/**
- * Header to a result.
- *
- * @deprecated Replaced by {@link jpl.eda.xmlquery.Header}.
- */
-public class Header implements Serializable {
-	private String name;
-	private String type;
-	private String unit;
-
-	public Header(jpl.eda.xmlquery.Header newStyle) {
-		this.name = newStyle.getName();
-		this.type = newStyle.getType();
-		this.unit = newStyle.getUnit();
-	}
-
-	private static final ObjectStreamField[] serialPersistentFields = {
-		new ObjectStreamField("name", String.class),
-		new ObjectStreamField("type", String.class),
-		new ObjectStreamField("unit", String.class)
-	};
-
-	private void writeObject(ObjectOutputStream s) throws IOException {
-		ObjectOutputStream.PutField f = s.putFields();
-		f.put("name", name);
-		f.put("type", type);
-		f.put("unit", unit);
-		s.writeFields();
-	}
-
-	private void readObject(ObjectInputStream s) throws IOException, ClassNotFoundException {
-		ObjectInputStream.GetField f = s.readFields();
-		name = (String) f.get("name", /*def value*/null);
-		type = (String) f.get("type", /*def value*/null);
-		unit = (String) f.get("unit", /*def value*/null);
-	}
-
-	/** Serial version unique ID. */
-	static final long serialVersionUID = 2238567985493830805L;
-}
+/*
+ * 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 jpl.oodt.xmlquery;
+
+import java.io.IOException;
+import java.io.ObjectInputStream;
+import java.io.ObjectOutputStream;
+import java.io.ObjectStreamField;
+import java.io.Serializable;
+
+/**
+ * Header to a result.
+ *
+ * @deprecated Replaced by {@link jpl.eda.xmlquery.Header}.
+ */
+public class Header implements Serializable {
+	private String name;
+	private String type;
+	private String unit;
+
+	public Header(jpl.eda.xmlquery.Header newStyle) {
+		this.name = newStyle.getName();
+		this.type = newStyle.getType();
+		this.unit = newStyle.getUnit();
+	}
+
+	private static final ObjectStreamField[] serialPersistentFields = {
+		new ObjectStreamField("name", String.class),
+		new ObjectStreamField("type", String.class),
+		new ObjectStreamField("unit", String.class)
+	};
+
+	private void writeObject(ObjectOutputStream s) throws IOException {
+		ObjectOutputStream.PutField f = s.putFields();
+		f.put("name", name);
+		f.put("type", type);
+		f.put("unit", unit);
+		s.writeFields();
+	}
+
+	private void readObject(ObjectInputStream s) throws IOException, ClassNotFoundException {
+		ObjectInputStream.GetField f = s.readFields();
+		name = (String) f.get("name", /*def value*/null);
+		type = (String) f.get("type", /*def value*/null);
+		unit = (String) f.get("unit", /*def value*/null);
+	}
+
+	/** Serial version unique ID. */
+	static final long serialVersionUID = 2238567985493830805L;
+}

Modified: incubator/oodt/trunk/product/src/main/java/jpl/oodt/xmlquery/LargeResult.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/product/src/main/java/jpl/oodt/xmlquery/LargeResult.java?rev=953117&r1=953116&r2=953117&view=diff
==============================================================================
--- incubator/oodt/trunk/product/src/main/java/jpl/oodt/xmlquery/LargeResult.java (original)
+++ incubator/oodt/trunk/product/src/main/java/jpl/oodt/xmlquery/LargeResult.java Wed Jun  9 19:11:21 2010
@@ -1,43 +1,56 @@
-// Copyright 1999-2004 California Institute of Technology. ALL RIGHTS
-// RESERVED. U.S. Government Sponsorship acknowledged.
-//
-// $Id: LargeResult.java,v 1.1 2004-11-30 21:24:10 kelly Exp $
-
-package jpl.oodt.xmlquery;
-
-import java.io.IOException;
-import java.io.ObjectInputStream;
-import java.io.ObjectOutputStream;
-import java.io.ObjectStreamField;
-
-/**
- * Large result.
- *
- * @deprecated Replaced by {@link jpl.eda.xmlquery.LargeResult}.
- */
-public class LargeResult extends Result {
-	long size;
-
-	public LargeResult(jpl.eda.xmlquery.LargeResult newStyle) {
-		super (newStyle);
-		this.size = newStyle.getSize();
-	}
-
-	private static final ObjectStreamField[] serialPersistentFields = {
-		new ObjectStreamField("size", Long.TYPE)
-	};
-
-	private void writeObject(ObjectOutputStream s) throws IOException {
-		ObjectOutputStream.PutField f = s.putFields();
-		f.put("size", size);
-		s.writeFields();
-	}
-
-	private void readObject(ObjectInputStream s) throws IOException, ClassNotFoundException {
-		ObjectInputStream.GetField f = s.readFields();
-		size = f.get("size", /*def value*/0L);
-	}
-
-	/** Serial version unique ID. */
-	static final long serialVersionUID = -969838775595705444L;
-}
+/*
+ * 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 jpl.oodt.xmlquery;
+
+import java.io.IOException;
+import java.io.ObjectInputStream;
+import java.io.ObjectOutputStream;
+import java.io.ObjectStreamField;
+
+/**
+ * Large result.
+ *
+ * @deprecated Replaced by {@link jpl.eda.xmlquery.LargeResult}.
+ */
+public class LargeResult extends Result {
+	long size;
+
+	public LargeResult(jpl.eda.xmlquery.LargeResult newStyle) {
+		super (newStyle);
+		this.size = newStyle.getSize();
+	}
+
+	private static final ObjectStreamField[] serialPersistentFields = {
+		new ObjectStreamField("size", Long.TYPE)
+	};
+
+	private void writeObject(ObjectOutputStream s) throws IOException {
+		ObjectOutputStream.PutField f = s.putFields();
+		f.put("size", size);
+		s.writeFields();
+	}
+
+	private void readObject(ObjectInputStream s) throws IOException, ClassNotFoundException {
+		ObjectInputStream.GetField f = s.readFields();
+		size = f.get("size", /*def value*/0L);
+	}
+
+	/** Serial version unique ID. */
+	static final long serialVersionUID = -969838775595705444L;
+}

Modified: incubator/oodt/trunk/product/src/main/java/jpl/oodt/xmlquery/QueryElement.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/product/src/main/java/jpl/oodt/xmlquery/QueryElement.java?rev=953117&r1=953116&r2=953117&view=diff
==============================================================================
--- incubator/oodt/trunk/product/src/main/java/jpl/oodt/xmlquery/QueryElement.java (original)
+++ incubator/oodt/trunk/product/src/main/java/jpl/oodt/xmlquery/QueryElement.java Wed Jun  9 19:11:21 2010
@@ -1,41 +1,54 @@
-// Copyright 1999-2004 California Institute of Technology. ALL RIGHTS
-// RESERVED. U.S. Government Sponsorship acknowledged.
-//
-// $Id: QueryElement.java,v 1.1 2004-11-30 21:24:47 kelly Exp $
-
-package jpl.oodt.xmlquery;
-
-import java.io.IOException;
-import java.io.ObjectOutputStream;
-import java.io.ObjectStreamField;
-import java.io.Serializable;
-
-/**
- * Element of a query.
- *
- * @deprecated Replaced by {@link jpl.eda.xmlquery.QueryElement}.
- */
-public class QueryElement implements Serializable {
-	private String role;
-	private String value;
-
-	public QueryElement(jpl.eda.xmlquery.QueryElement newStyle) {
-		role = newStyle.getRole();
-		value = newStyle.getValue();
-	}
-
-	private static final ObjectStreamField[] serialPersistentFields = {
-		new ObjectStreamField("role", String.class),
-		new ObjectStreamField("value", String.class)
-	};
-
-	private void writeObject(ObjectOutputStream s) throws IOException {
-		ObjectOutputStream.PutField f = s.putFields();
-		f.put("role", role);
-		f.put("value", value);
-		s.writeFields();
-	}
-
-	/** Serial version unique ID. */
-	static final long serialVersionUID = -5578423727059888898L;
-}
+/*
+ * 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 jpl.oodt.xmlquery;
+
+import java.io.IOException;
+import java.io.ObjectOutputStream;
+import java.io.ObjectStreamField;
+import java.io.Serializable;
+
+/**
+ * Element of a query.
+ *
+ * @deprecated Replaced by {@link jpl.eda.xmlquery.QueryElement}.
+ */
+public class QueryElement implements Serializable {
+	private String role;
+	private String value;
+
+	public QueryElement(jpl.eda.xmlquery.QueryElement newStyle) {
+		role = newStyle.getRole();
+		value = newStyle.getValue();
+	}
+
+	private static final ObjectStreamField[] serialPersistentFields = {
+		new ObjectStreamField("role", String.class),
+		new ObjectStreamField("value", String.class)
+	};
+
+	private void writeObject(ObjectOutputStream s) throws IOException {
+		ObjectOutputStream.PutField f = s.putFields();
+		f.put("role", role);
+		f.put("value", value);
+		s.writeFields();
+	}
+
+	/** Serial version unique ID. */
+	static final long serialVersionUID = -5578423727059888898L;
+}

Modified: incubator/oodt/trunk/product/src/main/java/jpl/oodt/xmlquery/QueryHeader.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/product/src/main/java/jpl/oodt/xmlquery/QueryHeader.java?rev=953117&r1=953116&r2=953117&view=diff
==============================================================================
--- incubator/oodt/trunk/product/src/main/java/jpl/oodt/xmlquery/QueryHeader.java (original)
+++ incubator/oodt/trunk/product/src/main/java/jpl/oodt/xmlquery/QueryHeader.java Wed Jun  9 19:11:21 2010
@@ -1,65 +1,78 @@
-// Copyright 1999-2004 California Institute of Technology. ALL RIGHTS
-// RESERVED. U.S. Government Sponsorship acknowledged.
-//
-// $Id: QueryHeader.java,v 1.1 2004-11-30 21:25:25 kelly Exp $
-
-package jpl.oodt.xmlquery;
-
-import java.io.IOException;
-import java.io.ObjectOutputStream;
-import java.io.ObjectStreamField;
-import java.io.Serializable;
-
-/**
- * Header to a query.
- *
- * @deprecated Replaced by {@link jpl.eda.xmlquery.QueryHeader}.
- */
-public class QueryHeader implements Serializable {
-	private String id;
-	private String title;
-	private String desc;
-	private String type;
-	private String status;
-	private String sec;
-	private String rev;
-	private String ddID;
-
-	public QueryHeader(jpl.eda.xmlquery.QueryHeader newStyle) {
-		id = newStyle.getID();
-		title = newStyle.getTitle();
-		desc = newStyle.getDescription();
-		type = newStyle.getType();
-		status = newStyle.getStatusID();
-		sec = newStyle.getSecurityType();
-		rev = newStyle.getRevisionNote();
-		ddID = newStyle.getDataDictID();
-	}
-
-	private static final ObjectStreamField[] serialPersistentFields = {
-		new ObjectStreamField("id", String.class),
-		new ObjectStreamField("title", String.class),
-		new ObjectStreamField("description", String.class),
-		new ObjectStreamField("type", String.class),
-		new ObjectStreamField("statusID", String.class),
-		new ObjectStreamField("securityType", String.class),
-		new ObjectStreamField("revisionNote", String.class),
-		new ObjectStreamField("dataDictID", String.class)
-	};		
-
-	private void writeObject(ObjectOutputStream s) throws IOException {
-		ObjectOutputStream.PutField f = s.putFields();
-		f.put("id", id);
-		f.put("title", title);
-		f.put("description", desc);
-		f.put("type", type);
-		f.put("statusID", status);
-		f.put("securityType", sec);
-		f.put("revisionNote", rev);
-		f.put("dataDictID", ddID);
-		s.writeFields();
-	}
-
-	/** Serial version unique ID. */
-	static final long serialVersionUID = -8601229234696670816L;
-}
+/*
+ * 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 jpl.oodt.xmlquery;
+
+import java.io.IOException;
+import java.io.ObjectOutputStream;
+import java.io.ObjectStreamField;
+import java.io.Serializable;
+
+/**
+ * Header to a query.
+ *
+ * @deprecated Replaced by {@link jpl.eda.xmlquery.QueryHeader}.
+ */
+public class QueryHeader implements Serializable {
+	private String id;
+	private String title;
+	private String desc;
+	private String type;
+	private String status;
+	private String sec;
+	private String rev;
+	private String ddID;
+
+	public QueryHeader(jpl.eda.xmlquery.QueryHeader newStyle) {
+		id = newStyle.getID();
+		title = newStyle.getTitle();
+		desc = newStyle.getDescription();
+		type = newStyle.getType();
+		status = newStyle.getStatusID();
+		sec = newStyle.getSecurityType();
+		rev = newStyle.getRevisionNote();
+		ddID = newStyle.getDataDictID();
+	}
+
+	private static final ObjectStreamField[] serialPersistentFields = {
+		new ObjectStreamField("id", String.class),
+		new ObjectStreamField("title", String.class),
+		new ObjectStreamField("description", String.class),
+		new ObjectStreamField("type", String.class),
+		new ObjectStreamField("statusID", String.class),
+		new ObjectStreamField("securityType", String.class),
+		new ObjectStreamField("revisionNote", String.class),
+		new ObjectStreamField("dataDictID", String.class)
+	};		
+
+	private void writeObject(ObjectOutputStream s) throws IOException {
+		ObjectOutputStream.PutField f = s.putFields();
+		f.put("id", id);
+		f.put("title", title);
+		f.put("description", desc);
+		f.put("type", type);
+		f.put("statusID", status);
+		f.put("securityType", sec);
+		f.put("revisionNote", rev);
+		f.put("dataDictID", ddID);
+		s.writeFields();
+	}
+
+	/** Serial version unique ID. */
+	static final long serialVersionUID = -8601229234696670816L;
+}

Modified: incubator/oodt/trunk/product/src/main/java/jpl/oodt/xmlquery/QueryResult.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/product/src/main/java/jpl/oodt/xmlquery/QueryResult.java?rev=953117&r1=953116&r2=953117&view=diff
==============================================================================
--- incubator/oodt/trunk/product/src/main/java/jpl/oodt/xmlquery/QueryResult.java (original)
+++ incubator/oodt/trunk/product/src/main/java/jpl/oodt/xmlquery/QueryResult.java Wed Jun  9 19:11:21 2010
@@ -1,53 +1,66 @@
-// Copyright 1999-2004 California Institute of Technology. ALL RIGHTS
-// RESERVED. U.S. Government Sponsorship acknowledged.
-//
-// $Id: QueryResult.java,v 1.1 2004-11-30 21:26:09 kelly Exp $
-
-package jpl.oodt.xmlquery;
-
-import java.io.IOException;
-import java.io.ObjectInputStream;
-import java.io.ObjectOutputStream;
-import java.io.ObjectStreamField;
-import java.io.Serializable;
-import java.util.ArrayList;
-import java.util.Iterator;
-import java.util.List;
-
-/**
- * Result of a query.
- *
- * @deprecated Replaced by {@link jpl.eda.xmlquery.QueryResult}.
- */
-public class QueryResult implements Serializable {
-	public List results;
-
-	public QueryResult(jpl.eda.xmlquery.QueryResult newStyle) {
-		results = new ArrayList(newStyle.getList().size());
-		for (Iterator i = newStyle.getList().iterator(); i.hasNext();) {
-			jpl.eda.xmlquery.Result newResult = (jpl.eda.xmlquery.Result) i.next();
-			if (newResult instanceof jpl.eda.xmlquery.LargeResult)
-				results.add(new LargeResult((jpl.eda.xmlquery.LargeResult) newResult));
-			else
-				results.add(new Result(newResult));
-		}
-	}
-
-	private static final ObjectStreamField[] serialPersistentFields = {
-		new ObjectStreamField("list", List.class)
-	};
-
-	private void writeObject(ObjectOutputStream s) throws IOException {
-		ObjectOutputStream.PutField f = s.putFields();
-		f.put("list", results);
-		s.writeFields();
-	}
-
-	private void readObject(ObjectInputStream s) throws IOException, ClassNotFoundException {
-		ObjectInputStream.GetField f = s.readFields();
-		results = (List) f.get("list", /*def value*/null);
-	}
-
-	/** Serial version unique ID. */
-	static final long serialVersionUID = 9156030927051226848L;
-}
+/*
+ * 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 jpl.oodt.xmlquery;
+
+import java.io.IOException;
+import java.io.ObjectInputStream;
+import java.io.ObjectOutputStream;
+import java.io.ObjectStreamField;
+import java.io.Serializable;
+import java.util.ArrayList;
+import java.util.Iterator;
+import java.util.List;
+
+/**
+ * Result of a query.
+ *
+ * @deprecated Replaced by {@link jpl.eda.xmlquery.QueryResult}.
+ */
+public class QueryResult implements Serializable {
+	public List results;
+
+	public QueryResult(jpl.eda.xmlquery.QueryResult newStyle) {
+		results = new ArrayList(newStyle.getList().size());
+		for (Iterator i = newStyle.getList().iterator(); i.hasNext();) {
+			jpl.eda.xmlquery.Result newResult = (jpl.eda.xmlquery.Result) i.next();
+			if (newResult instanceof jpl.eda.xmlquery.LargeResult)
+				results.add(new LargeResult((jpl.eda.xmlquery.LargeResult) newResult));
+			else
+				results.add(new Result(newResult));
+		}
+	}
+
+	private static final ObjectStreamField[] serialPersistentFields = {
+		new ObjectStreamField("list", List.class)
+	};
+
+	private void writeObject(ObjectOutputStream s) throws IOException {
+		ObjectOutputStream.PutField f = s.putFields();
+		f.put("list", results);
+		s.writeFields();
+	}
+
+	private void readObject(ObjectInputStream s) throws IOException, ClassNotFoundException {
+		ObjectInputStream.GetField f = s.readFields();
+		results = (List) f.get("list", /*def value*/null);
+	}
+
+	/** Serial version unique ID. */
+	static final long serialVersionUID = 9156030927051226848L;
+}

Modified: incubator/oodt/trunk/product/src/main/java/jpl/oodt/xmlquery/Result.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/product/src/main/java/jpl/oodt/xmlquery/Result.java?rev=953117&r1=953116&r2=953117&view=diff
==============================================================================
--- incubator/oodt/trunk/product/src/main/java/jpl/oodt/xmlquery/Result.java (original)
+++ incubator/oodt/trunk/product/src/main/java/jpl/oodt/xmlquery/Result.java Wed Jun  9 19:11:21 2010
@@ -1,88 +1,101 @@
-// Copyright 1999-2004 California Institute of Technology. ALL RIGHTS
-// RESERVED. U.S. Government Sponsorship acknowledged.
-//
-// $Id: Result.java,v 1.1 2004-11-30 21:27:03 kelly Exp $
-
-package jpl.oodt.xmlquery;
-
-import java.io.IOException;
-import java.io.ObjectInputStream;
-import java.io.ObjectOutputStream;
-import java.io.ObjectStreamField;
-import java.io.Serializable;
-import java.util.ArrayList;
-import java.util.Iterator;
-import java.util.List;
-
-/**
- * A result.
- *
- * @deprecated Replaced by {@link jpl.eda.xmlquery.Result}.
- */
-public class Result implements Serializable {
-	String id;
-	String mime;
-	String prof;
-	String res;
-	List headers;
-	Object value;
-	boolean classified;
-	long validity;
-
-	public Result(jpl.eda.xmlquery.Result newStyle) {
-		id = newStyle.getID();
-		mime = newStyle.getMimeType();
-		prof = newStyle.getProfileID();
-		res = newStyle.getResourceID();
-		headers = convert(newStyle.getHeaders());
-		value = newStyle.getValue();
-		classified = newStyle.isClassified();
-		validity = newStyle.getValidity();
-	}
-
-	private static List convert(List newStyle) {
-		List oldStyle = new ArrayList(newStyle.size());
-		for (Iterator i = newStyle.iterator(); i.hasNext();)
-			oldStyle.add(new Header((jpl.eda.xmlquery.Header) i.next()));
-		return oldStyle;
-	}
-
-	private static final ObjectStreamField[] serialPersistentFields = {
-		new ObjectStreamField("id", String.class),
-		new ObjectStreamField("mimeType", String.class),
-		new ObjectStreamField("profileID", String.class),
-		new ObjectStreamField("resourceID", String.class),
-		new ObjectStreamField("headers", List.class),
-		new ObjectStreamField("value", Object.class),
-		new ObjectStreamField("classified", Boolean.TYPE),
-		new ObjectStreamField("validity", Long.TYPE)
-	};
-
-	private void writeObject(ObjectOutputStream s) throws IOException {
-		ObjectOutputStream.PutField f = s.putFields();
-		f.put("id", id);
-		f.put("mimeType", mime);
-		f.put("profileID", prof);
-		f.put("resourceID", res);
-		f.put("headers", headers);
-		f.put("value", value);
-		f.put("classified", classified);
-		f.put("validity", validity);
-		s.writeFields();
-	}
-
-	private void readObject(ObjectInputStream s) throws IOException, ClassNotFoundException {
-		ObjectInputStream.GetField f = s.readFields();
-		id = (String) f.get("id", /*def value*/null);
-		mime = (String) f.get("mimeType", /*def value*/null);
-		prof = (String) f.get("profileID", /*def value*/null);
-		res = (String) f.get("resourceID", /*def value*/null);
-		headers = (List) f.get("headers", /*def value*/null);
-		value = f.get("value", /*def value*/null);
-		classified = f.get("classified", /*def value*/false);
-		validity = f.get("validity", /*def value*/0L);
-	}
-
-	/** Serial version unique ID. */
-	static final long serialVersionUID = 9169143944191239575L;
-}
+/*
+ * 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 jpl.oodt.xmlquery;
+
+import java.io.IOException;
+import java.io.ObjectInputStream;
+import java.io.ObjectOutputStream;
+import java.io.ObjectStreamField;
+import java.io.Serializable;
+import java.util.ArrayList;
+import java.util.Iterator;
+import java.util.List;
+
+/**
+ * A result.
+ *
+ * @deprecated Replaced by {@link jpl.eda.xmlquery.Result}.
+ */
+public class Result implements Serializable {
+	String id;
+	String mime;
+	String prof;
+	String res;
+	List headers;
+	Object value;
+	boolean classified;
+	long validity;
+
+	public Result(jpl.eda.xmlquery.Result newStyle) {
+		id = newStyle.getID();
+		mime = newStyle.getMimeType();
+		prof = newStyle.getProfileID();
+		res = newStyle.getResourceID();
+		headers = convert(newStyle.getHeaders());
+		value = newStyle.getValue();
+		classified = newStyle.isClassified();
+		validity = newStyle.getValidity();
+	}
+
+	private static List convert(List newStyle) {
+		List oldStyle = new ArrayList(newStyle.size());
+		for (Iterator i = newStyle.iterator(); i.hasNext();)
+			oldStyle.add(new Header((jpl.eda.xmlquery.Header) i.next()));
+		return oldStyle;
+	}
+
+	private static final ObjectStreamField[] serialPersistentFields = {
+		new ObjectStreamField("id", String.class),
+		new ObjectStreamField("mimeType", String.class),
+		new ObjectStreamField("profileID", String.class),
+		new ObjectStreamField("resourceID", String.class),
+		new ObjectStreamField("headers", List.class),
+		new ObjectStreamField("value", Object.class),
+		new ObjectStreamField("classified", Boolean.TYPE),
+		new ObjectStreamField("validity", Long.TYPE)
+	};
+
+	private void writeObject(ObjectOutputStream s) throws IOException {
+		ObjectOutputStream.PutField f = s.putFields();
+		f.put("id", id);
+		f.put("mimeType", mime);
+		f.put("profileID", prof);
+		f.put("resourceID", res);
+		f.put("headers", headers);
+		f.put("value", value);
+		f.put("classified", classified);
+		f.put("validity", validity);
+		s.writeFields();
+	}
+
+	private void readObject(ObjectInputStream s) throws IOException, ClassNotFoundException {
+		ObjectInputStream.GetField f = s.readFields();
+		id = (String) f.get("id", /*def value*/null);
+		mime = (String) f.get("mimeType", /*def value*/null);
+		prof = (String) f.get("profileID", /*def value*/null);
+		res = (String) f.get("resourceID", /*def value*/null);
+		headers = (List) f.get("headers", /*def value*/null);
+		value = f.get("value", /*def value*/null);
+		classified = f.get("classified", /*def value*/false);
+		validity = f.get("validity", /*def value*/0L);
+	}
+
+	/** Serial version unique ID. */
+	static final long serialVersionUID = 9169143944191239575L;
+}

Modified: incubator/oodt/trunk/product/src/main/java/jpl/oodt/xmlquery/XMLQuery.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/product/src/main/java/jpl/oodt/xmlquery/XMLQuery.java?rev=953117&r1=953116&r2=953117&view=diff
==============================================================================
--- incubator/oodt/trunk/product/src/main/java/jpl/oodt/xmlquery/XMLQuery.java (original)
+++ incubator/oodt/trunk/product/src/main/java/jpl/oodt/xmlquery/XMLQuery.java Wed Jun  9 19:11:21 2010
@@ -1,111 +1,124 @@
-// Copyright 1999-2004 California Institute of Technology. ALL RIGHTS
-// RESERVED. U.S. Government Sponsorship acknowledged.
-//
-// $Id: XMLQuery.java,v 1.1 2004-11-30 21:28:49 kelly Exp $
-
-package jpl.oodt.xmlquery;
-
-import java.io.IOException;
-import java.io.ObjectInputStream;
-import java.io.ObjectOutputStream;
-import java.io.ObjectStreamField;
-import java.io.Serializable;
-import java.util.ArrayList;
-import java.util.Collections;
-import java.util.Iterator;
-import java.util.List;
-import java.util.List;
-
-/**
- * A query.
- *
- * @deprecated Replaced by {@link jpl.eda.xmlquery.XMLQuery}.
- */
-public class XMLQuery implements Serializable {
-	private String mode;
-	private String type;
-	private String levels;
-	private int max;
-	private String kwqString;
-	private List mime;
-	private QueryHeader header;
-	private List select;
-	private List from;
-	private List where;
-	public QueryResult result;
-
-	public XMLQuery(jpl.eda.xmlquery.XMLQuery q) {
-		mode = q.getResultModeID();
-		type = q.getPropagationType();
-		levels = q.getPropagationLevels();
-		max = q.getMaxResults();
-		kwqString = q.getKwdQueryString();
-		mime = q.getMimeAccept();
-		header = new QueryHeader(q.getQueryHeader());
-		select = convert(q.getSelectElementSet());
-		from = convert(q.getFromElementSet());
-		where = convert(q.getWhereElementSet());
-		result = new QueryResult(q.getResult());
-	}
-
-	private static List convert(List newStyle) {
-		List oldStyle = new ArrayList(newStyle.size());
-		for (Iterator i = newStyle.iterator(); i.hasNext();)
-			oldStyle.add(new QueryElement((jpl.eda.xmlquery.QueryElement) i.next()));
-		return oldStyle;
-	}
-
-	private static final ObjectStreamField[] serialPersistentFields = {
-		new ObjectStreamField("resultModeId", String.class),
-		new ObjectStreamField("propogationType", String.class),
-		new ObjectStreamField("propogationLevels", String.class),
-		new ObjectStreamField("maxResults", Integer.TYPE),
-		new ObjectStreamField("kwqString", String.class),
-		new ObjectStreamField("mimeAccept", List.class),
-		new ObjectStreamField("numResults", Integer.TYPE),
-		new ObjectStreamField("queryHeader", QueryHeader.class),
-		new ObjectStreamField("selectElementSet", List.class),
-		new ObjectStreamField("fromElementSet", List.class),
-		new ObjectStreamField("whereElementSet", List.class),
-		new ObjectStreamField("result", QueryResult.class)
-	};
-
-	private void readObject(ObjectInputStream s) throws IOException, ClassNotFoundException {
-		ObjectInputStream.GetField f = s.readFields();
-		result = (QueryResult) f.get("result", /*def value*/null);
-	}
-
-	public List getResults() {
-		List newStyle = new ArrayList(result.results.size());
-		for (Iterator i = result.results.iterator(); i.hasNext();) {
-			Result r = (Result) i.next();
-			if (r instanceof LargeResult)
-				newStyle.add(new jpl.eda.xmlquery.LargeResult(r.id, r.mime, r.prof, r.res, Collections.EMPTY_LIST,
-						((LargeResult) r).size));
-			else
-				newStyle.add(new jpl.eda.xmlquery.Result(r.id, r.mime, r.prof, r.res, Collections.EMPTY_LIST,
-						r.value));
-		}
-		return newStyle;
-	}
-
-	private void writeObject(ObjectOutputStream s) throws IOException {
-		ObjectOutputStream.PutField f = s.putFields();
-		f.put("resultModeId", mode);
-		f.put("propogationType", type);
-		f.put("propogationLevels", levels);
-		f.put("maxResults", max);
-		f.put("kwqString", kwqString);
-		f.put("mimeAccept", mime);
-		f.put("numResults", 0);
-		f.put("queryHeader", header);
-		f.put("selectElementSet", select);
-		f.put("fromElementSet", from);
-		f.put("whereElementSet", where);
-		f.put("result", result);
-		s.writeFields();
-	}
-
-	/** Serial version unique ID. */
-	static final long serialVersionUID = -7638068782048963710L;
-}
+/*
+ * 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 jpl.oodt.xmlquery;
+
+import java.io.IOException;
+import java.io.ObjectInputStream;
+import java.io.ObjectOutputStream;
+import java.io.ObjectStreamField;
+import java.io.Serializable;
+import java.util.ArrayList;
+import java.util.Collections;
+import java.util.Iterator;
+import java.util.List;
+import java.util.List;
+
+/**
+ * A query.
+ *
+ * @deprecated Replaced by {@link jpl.eda.xmlquery.XMLQuery}.
+ */
+public class XMLQuery implements Serializable {
+	private String mode;
+	private String type;
+	private String levels;
+	private int max;
+	private String kwqString;
+	private List mime;
+	private QueryHeader header;
+	private List select;
+	private List from;
+	private List where;
+	public QueryResult result;
+
+	public XMLQuery(jpl.eda.xmlquery.XMLQuery q) {
+		mode = q.getResultModeID();
+		type = q.getPropagationType();
+		levels = q.getPropagationLevels();
+		max = q.getMaxResults();
+		kwqString = q.getKwdQueryString();
+		mime = q.getMimeAccept();
+		header = new QueryHeader(q.getQueryHeader());
+		select = convert(q.getSelectElementSet());
+		from = convert(q.getFromElementSet());
+		where = convert(q.getWhereElementSet());
+		result = new QueryResult(q.getResult());
+	}
+
+	private static List convert(List newStyle) {
+		List oldStyle = new ArrayList(newStyle.size());
+		for (Iterator i = newStyle.iterator(); i.hasNext();)
+			oldStyle.add(new QueryElement((jpl.eda.xmlquery.QueryElement) i.next()));
+		return oldStyle;
+	}
+
+	private static final ObjectStreamField[] serialPersistentFields = {
+		new ObjectStreamField("resultModeId", String.class),
+		new ObjectStreamField("propogationType", String.class),
+		new ObjectStreamField("propogationLevels", String.class),
+		new ObjectStreamField("maxResults", Integer.TYPE),
+		new ObjectStreamField("kwqString", String.class),
+		new ObjectStreamField("mimeAccept", List.class),
+		new ObjectStreamField("numResults", Integer.TYPE),
+		new ObjectStreamField("queryHeader", QueryHeader.class),
+		new ObjectStreamField("selectElementSet", List.class),
+		new ObjectStreamField("fromElementSet", List.class),
+		new ObjectStreamField("whereElementSet", List.class),
+		new ObjectStreamField("result", QueryResult.class)
+	};
+
+	private void readObject(ObjectInputStream s) throws IOException, ClassNotFoundException {
+		ObjectInputStream.GetField f = s.readFields();
+		result = (QueryResult) f.get("result", /*def value*/null);
+	}
+
+	public List getResults() {
+		List newStyle = new ArrayList(result.results.size());
+		for (Iterator i = result.results.iterator(); i.hasNext();) {
+			Result r = (Result) i.next();
+			if (r instanceof LargeResult)
+				newStyle.add(new jpl.eda.xmlquery.LargeResult(r.id, r.mime, r.prof, r.res, Collections.EMPTY_LIST,
+						((LargeResult) r).size));
+			else
+				newStyle.add(new jpl.eda.xmlquery.Result(r.id, r.mime, r.prof, r.res, Collections.EMPTY_LIST,
+						r.value));
+		}
+		return newStyle;
+	}
+
+	private void writeObject(ObjectOutputStream s) throws IOException {
+		ObjectOutputStream.PutField f = s.putFields();
+		f.put("resultModeId", mode);
+		f.put("propogationType", type);
+		f.put("propogationLevels", levels);
+		f.put("maxResults", max);
+		f.put("kwqString", kwqString);
+		f.put("mimeAccept", mime);
+		f.put("numResults", 0);
+		f.put("queryHeader", header);
+		f.put("selectElementSet", select);
+		f.put("fromElementSet", from);
+		f.put("whereElementSet", where);
+		f.put("result", result);
+		s.writeFields();
+	}
+
+	/** Serial version unique ID. */
+	static final long serialVersionUID = -7638068782048963710L;
+}

Modified: incubator/oodt/trunk/product/src/test/jpl/eda/product/HTTPAdaptorTest.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/product/src/test/jpl/eda/product/HTTPAdaptorTest.java?rev=953117&r1=953116&r2=953117&view=diff
==============================================================================
--- incubator/oodt/trunk/product/src/test/jpl/eda/product/HTTPAdaptorTest.java (original)
+++ incubator/oodt/trunk/product/src/test/jpl/eda/product/HTTPAdaptorTest.java Wed Jun  9 19:11:21 2010
@@ -1,7 +1,20 @@
-// Copyright 2007 California Institute of Technology. ALL RIGHTS
-// RESERVED. U.S. Government Sponsorship acknowledged.
-//
-// $Id: HTTPAdaptorTest.java,v 1.1 2007-06-09 15:49:35 kelly Exp $
+/*
+ * 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 jpl.eda.product;
 

Modified: incubator/oodt/trunk/product/src/test/jpl/eda/product/UtilityTest.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/product/src/test/jpl/eda/product/UtilityTest.java?rev=953117&r1=953116&r2=953117&view=diff
==============================================================================
--- incubator/oodt/trunk/product/src/test/jpl/eda/product/UtilityTest.java (original)
+++ incubator/oodt/trunk/product/src/test/jpl/eda/product/UtilityTest.java Wed Jun  9 19:11:21 2010
@@ -1,117 +1,130 @@
-// Copyright 1999-2004 California Institute of Technology. ALL RIGHTS
-// RESERVED. U.S. Government Sponsorship acknowledged.
-//
-// $Id: UtilityTest.java,v 1.1 2004-04-05 15:00:27 kelly Exp $
-
-package jpl.eda.product;
-
-import java.util.HashMap;
-import java.util.Iterator;
-import java.util.List;
-import java.util.Map;
-import jpl.eda.xmlquery.XMLQuery;
-import junit.framework.TestCase;
-
-/**
- * Unit test for the Utility class.
- *
- * @author Kelly
- * @version $Revision: 1.1 $
- */
-public class UtilityTest extends TestCase {
-	/**
-	 * Creates a new {@link UtilityTest} instance.
-	 *
-	 * @param name Case name.
-	 */
-	public UtilityTest(String name) {
-		super(name);
-	}
-
-	/**
-	 * Set up by saving old values of properties this test alters and clearing them for the case.
-	 *
-	 * @throws Exception if an error occurs.
-	 */
-	protected void setUp() throws Exception {
-		super.setUp();
-		for (int i = 0; i < PROPS.length; ++i) {
-			props.put(PROPS[i], System.getProperty(PROPS[i]));
-			System.getProperties().remove(PROPS[i]);
-		}
-	}
-
-	/**
-	 * Tear down by restoring old values of properties this test altered.
-	 *
-	 * @throws Exception if an error occurs.
-	 */
-	protected void tearDown() throws Exception {
-		for (Iterator i = props.entrySet().iterator(); i.hasNext();) {
-			Map.Entry e = (Map.Entry) i.next();
-			if (e.getValue() == null)
-				System.getProperties().remove(e.getKey());
-			else
-				System.getProperties().put(e.getKey(), e.getValue());
-		}
-		super.tearDown();
-	}
-
-	/**
-	 * Test the loading of query handlers.
-	 */
-	public void testHandlerLoading() {
-		System.setProperty("jpl.eda.product.handlers", "");
-		List handlers = Utility.loadHandlers("urn:eda:rmi:TestServer");
-		assertTrue(handlers.isEmpty());
-		System.getProperties().remove("jpl.eda.product.handlers");
-		System.setProperty("handlers", "");
-		handlers = Utility.loadHandlers("urn:eda:rmi:TestServer");
-		assertTrue(handlers.isEmpty());
-		System.getProperties().remove("handlers");
-		handlers = Utility.loadHandlers("urn:eda:rmi:TestServer");
-		assertTrue(handlers.isEmpty());
-
-		System.setProperty("handlers", "non.existent.class");
-		handlers = Utility.loadHandlers("urn:eda:rmi:TestServer");
-		assertTrue(handlers.isEmpty());
-
-		System.setProperty("handlers", "jpl.eda.product.UtilityTest$Handler1,jpl.eda.product.UtilityTest$Handler2");
-		handlers = Utility.loadHandlers("urn:eda:rmi:TestServer");
-		assertEquals(2, handlers.size());
-		boolean saw1 = false;
-		boolean saw2 = false;
-		for (Iterator i = handlers.iterator(); i.hasNext();) {
-			Object obj = i.next();
-			if (obj instanceof Handler1) saw1 = true;
-			else if (obj instanceof Handler2) saw2 = true;
-			else fail("Unexpected object in handler list");
-		}
-		assertTrue(saw1 && saw2);
-
-		System.setProperty("urn:eda:rmi:TestServer.handlers", "jpl.eda.product.UtilityTest$Handler2");
-		handlers = Utility.loadHandlers("urn:eda:rmi:TestServer");
-		assertEquals(1, handlers.size());
-		assertTrue(handlers.get(0) instanceof Handler2);
-	}
-
-	/** Saved system property values.  Keys are String (prop name) and values are String (prop value). */
-	private Map props = new HashMap();
-
-	/**
-	 * Test query handler.
-	 */
-	public static class Handler1 implements QueryHandler {
-		public XMLQuery query(XMLQuery q) { return null; }
-	}
-
-	/**
-	 * Another test query handler.
-	 */
-	public static class Handler2 implements QueryHandler {
-		public XMLQuery query(XMLQuery q) { return null; }		
-	}
-
-	/** Properties this test alters and needs to restore when it's done. */
-	private static final String[] PROPS = { "urn:eda:rmi:TestServer.handlers", "jpl.eda.product.handlers", "handlers" };
-}
+/*
+ * 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 jpl.eda.product;
+
+import java.util.HashMap;
+import java.util.Iterator;
+import java.util.List;
+import java.util.Map;
+import jpl.eda.xmlquery.XMLQuery;
+import junit.framework.TestCase;
+
+/**
+ * Unit test for the Utility class.
+ *
+ * @author Kelly
+ * @version $Revision: 1.1 $
+ */
+public class UtilityTest extends TestCase {
+	/**
+	 * Creates a new {@link UtilityTest} instance.
+	 *
+	 * @param name Case name.
+	 */
+	public UtilityTest(String name) {
+		super(name);
+	}
+
+	/**
+	 * Set up by saving old values of properties this test alters and clearing them for the case.
+	 *
+	 * @throws Exception if an error occurs.
+	 */
+	protected void setUp() throws Exception {
+		super.setUp();
+		for (int i = 0; i < PROPS.length; ++i) {
+			props.put(PROPS[i], System.getProperty(PROPS[i]));
+			System.getProperties().remove(PROPS[i]);
+		}
+	}
+
+	/**
+	 * Tear down by restoring old values of properties this test altered.
+	 *
+	 * @throws Exception if an error occurs.
+	 */
+	protected void tearDown() throws Exception {
+		for (Iterator i = props.entrySet().iterator(); i.hasNext();) {
+			Map.Entry e = (Map.Entry) i.next();
+			if (e.getValue() == null)
+				System.getProperties().remove(e.getKey());
+			else
+				System.getProperties().put(e.getKey(), e.getValue());
+		}
+		super.tearDown();
+	}
+
+	/**
+	 * Test the loading of query handlers.
+	 */
+	public void testHandlerLoading() {
+		System.setProperty("jpl.eda.product.handlers", "");
+		List handlers = Utility.loadHandlers("urn:eda:rmi:TestServer");
+		assertTrue(handlers.isEmpty());
+		System.getProperties().remove("jpl.eda.product.handlers");
+		System.setProperty("handlers", "");
+		handlers = Utility.loadHandlers("urn:eda:rmi:TestServer");
+		assertTrue(handlers.isEmpty());
+		System.getProperties().remove("handlers");
+		handlers = Utility.loadHandlers("urn:eda:rmi:TestServer");
+		assertTrue(handlers.isEmpty());
+
+		System.setProperty("handlers", "non.existent.class");
+		handlers = Utility.loadHandlers("urn:eda:rmi:TestServer");
+		assertTrue(handlers.isEmpty());
+
+		System.setProperty("handlers", "jpl.eda.product.UtilityTest$Handler1,jpl.eda.product.UtilityTest$Handler2");
+		handlers = Utility.loadHandlers("urn:eda:rmi:TestServer");
+		assertEquals(2, handlers.size());
+		boolean saw1 = false;
+		boolean saw2 = false;
+		for (Iterator i = handlers.iterator(); i.hasNext();) {
+			Object obj = i.next();
+			if (obj instanceof Handler1) saw1 = true;
+			else if (obj instanceof Handler2) saw2 = true;
+			else fail("Unexpected object in handler list");
+		}
+		assertTrue(saw1 && saw2);
+
+		System.setProperty("urn:eda:rmi:TestServer.handlers", "jpl.eda.product.UtilityTest$Handler2");
+		handlers = Utility.loadHandlers("urn:eda:rmi:TestServer");
+		assertEquals(1, handlers.size());
+		assertTrue(handlers.get(0) instanceof Handler2);
+	}
+
+	/** Saved system property values.  Keys are String (prop name) and values are String (prop value). */
+	private Map props = new HashMap();
+
+	/**
+	 * Test query handler.
+	 */
+	public static class Handler1 implements QueryHandler {
+		public XMLQuery query(XMLQuery q) { return null; }
+	}
+
+	/**
+	 * Another test query handler.
+	 */
+	public static class Handler2 implements QueryHandler {
+		public XMLQuery query(XMLQuery q) { return null; }		
+	}
+
+	/** Properties this test alters and needs to restore when it's done. */
+	private static final String[] PROPS = { "urn:eda:rmi:TestServer.handlers", "jpl.eda.product.handlers", "handlers" };
+}

Modified: incubator/oodt/trunk/product/src/test/jpl/eda/xmlquery/ChunkedProductInputStreamTest.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/product/src/test/jpl/eda/xmlquery/ChunkedProductInputStreamTest.java?rev=953117&r1=953116&r2=953117&view=diff
==============================================================================
--- incubator/oodt/trunk/product/src/test/jpl/eda/xmlquery/ChunkedProductInputStreamTest.java (original)
+++ incubator/oodt/trunk/product/src/test/jpl/eda/xmlquery/ChunkedProductInputStreamTest.java Wed Jun  9 19:11:21 2010
@@ -1,7 +1,20 @@
-// Copyright 2003 California Institute of Technology.  ALL RIGHTS RESERVED.
-// U.S. Government Sponsorship acknowledged.
-//
-// $Id: ChunkedProductInputStreamTest.java,v 1.5 2004-12-01 22:34:09 kelly Exp $
+/*
+ * 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 jpl.eda.xmlquery;
 

Modified: incubator/oodt/trunk/product/src/test/jpl/eda/xmlquery/LargeResultTest.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/product/src/test/jpl/eda/xmlquery/LargeResultTest.java?rev=953117&r1=953116&r2=953117&view=diff
==============================================================================
--- incubator/oodt/trunk/product/src/test/jpl/eda/xmlquery/LargeResultTest.java (original)
+++ incubator/oodt/trunk/product/src/test/jpl/eda/xmlquery/LargeResultTest.java Wed Jun  9 19:11:21 2010
@@ -1,7 +1,20 @@
-// Copyright 2002 California Institute of Technology.  ALL RIGHTS RESERVED.
-// U.S. Government Sponsorship acknowledged.
-//
-// $Id: LargeResultTest.java,v 1.2 2005-08-03 17:03:21 kelly Exp $
+/*
+ * 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 jpl.eda.xmlquery;
 

Modified: incubator/oodt/trunk/profile/src/main/java/jpl/eda/profile/DefaultFactory.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/profile/src/main/java/jpl/eda/profile/DefaultFactory.java?rev=953117&r1=953116&r2=953117&view=diff
==============================================================================
--- incubator/oodt/trunk/profile/src/main/java/jpl/eda/profile/DefaultFactory.java (original)
+++ incubator/oodt/trunk/profile/src/main/java/jpl/eda/profile/DefaultFactory.java Wed Jun  9 19:11:21 2010
@@ -1,7 +1,20 @@
-// Copyright 2002 California Institute of Technology.  ALL RIGHTS RESERVED.
-// U.S. Government Sponsorship acknowledged.
-//
-// $Id: DefaultFactory.java,v 1.1.1.1 2004/03/02 20:53:06 kelly Exp $
+/*
+ * 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 jpl.eda.profile;
 

Modified: incubator/oodt/trunk/profile/src/main/java/jpl/eda/profile/EnumeratedProfileElement.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/profile/src/main/java/jpl/eda/profile/EnumeratedProfileElement.java?rev=953117&r1=953116&r2=953117&view=diff
==============================================================================
--- incubator/oodt/trunk/profile/src/main/java/jpl/eda/profile/EnumeratedProfileElement.java (original)
+++ incubator/oodt/trunk/profile/src/main/java/jpl/eda/profile/EnumeratedProfileElement.java Wed Jun  9 19:11:21 2010
@@ -1,7 +1,20 @@
-// Copyright 2000-2002 California Institute of Technology.  ALL RIGHTS RESERVED.
-// U.S. Government Sponsorship acknowledged.
-//
-// $Id: EnumeratedProfileElement.java,v 1.4 2006/06/16 17:13:42 kelly Exp $
+/*
+ * 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 jpl.eda.profile;
 

Modified: incubator/oodt/trunk/profile/src/main/java/jpl/eda/profile/HTTPAdaptor.java
URL: http://svn.apache.org/viewvc/incubator/oodt/trunk/profile/src/main/java/jpl/eda/profile/HTTPAdaptor.java?rev=953117&r1=953116&r2=953117&view=diff
==============================================================================
--- incubator/oodt/trunk/profile/src/main/java/jpl/eda/profile/HTTPAdaptor.java (original)
+++ incubator/oodt/trunk/profile/src/main/java/jpl/eda/profile/HTTPAdaptor.java Wed Jun  9 19:11:21 2010
@@ -1,7 +1,20 @@
-// Copyright 2002 California Institute of Technology.  ALL RIGHTS RESERVED.
-// U.S. Government Sponsorship acknowledged.
-//
-// $Id: HTTPAdaptor.java,v 1.2 2005/12/01 22:45:00 kelly Exp $
+/*
+ * 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 jpl.eda.profile;