You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@juddi.apache.org by al...@apache.org on 2013/04/15 15:07:03 UTC

svn commit: r1468025 [2/4] - in /juddi/branches/juddi-3.2.x: ./ juddi-client/src/main/java/org/apache/juddi/v3/client/ juddi-core-openjpa/ juddi-core-openjpa/src/test/resources/META-INF/ juddi-core/ juddi-core/src/main/java/org/apache/juddi/api/impl/ j...

Modified: juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/FindEntityByCombinedCategoryQuery.java
URL: http://svn.apache.org/viewvc/juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/FindEntityByCombinedCategoryQuery.java?rev=1468025&r1=1468024&r2=1468025&view=diff
==============================================================================
--- juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/FindEntityByCombinedCategoryQuery.java (original)
+++ juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/FindEntityByCombinedCategoryQuery.java Mon Apr 15 13:07:00 2013
@@ -18,18 +18,18 @@
 package org.apache.juddi.query;
 
 import java.util.ArrayList;
-import java.util.Collections;
-import java.util.Iterator;
+import java.util.HashMap;
+import java.util.HashSet;
 import java.util.List;
+import java.util.Map;
+import java.util.Set;
 
 import javax.persistence.EntityManager;
 
 import org.apache.commons.logging.Log;
 import org.apache.commons.logging.LogFactory;
-import org.apache.juddi.config.Constants;
 import org.apache.juddi.query.util.DynamicQuery;
 import org.apache.juddi.query.util.FindQualifiers;
-import org.apache.juddi.query.util.KeyedRefTModelComparator;
 import org.uddi.api_v3.CategoryBag;
 import org.uddi.api_v3.KeyedReference;
 
@@ -77,28 +77,37 @@ public class FindEntityByCombinedCategor
 	
 	@SuppressWarnings("unused")
 	private static Log log = LogFactory.getLog(FindEntityByCombinedCategoryQuery.class);
-
-	private static final String ENTITY_KEYEDREFERENCE = "KeyedReference";
-	private static final String ALIAS_KEYEDREFERENCE = buildAlias(ENTITY_KEYEDREFERENCE);
-	private static final String FIELD_CATEGORYBAG = "categoryBag";
-	
-	private String joinClause;
-	private String currentAlias;
 	
+	protected String entityField2;
 	protected String entityNameChild2;
 	protected String entityAliasChild2;
-
-	public FindEntityByCombinedCategoryQuery(String entityName, String entityAlias, String keyName, String entityField, String entityNameChild) {
-		super(entityName, entityAlias, keyName, entityField, entityNameChild);
-	}
 	
-	public FindEntityByCombinedCategoryQuery(String entityName, String entityAlias, String keyName, String entityField, String entityNameChild,
-			String entityNameChild2) {
-		super(entityName, entityAlias, keyName, entityField, entityNameChild);
+	protected String entityField3;
+	protected String entityNameChild3;
+	protected String entityAliasChild3;
+	
+	protected String signaturePresent;
+
+	public FindEntityByCombinedCategoryQuery(String entityName, String entityAlias, String keyName,
+			String entityField, String entityNameChild, String signaturePresent) {
+		super(entityName, entityAlias, keyName, entityField, entityNameChild, signaturePresent);
+	}
+	
+	public FindEntityByCombinedCategoryQuery(String entityName, String entityAlias, String keyName, 
+			String entityField, String entityNameChild,
+			String entityField2, String entityNameChild2, String entityField3, String entityNameChild3,
+			String signaturePresent) {
+		super(entityName, entityAlias, keyName, entityField, entityNameChild, signaturePresent);
 		
 		this.entityNameChild2 = entityNameChild2;
 		this.entityAliasChild2 = buildAlias(entityNameChild2);
-		
+		this.entityField2 = entityField2;
+		if (entityNameChild3!=null) {
+			this.entityField3 = entityField3;
+			this.entityNameChild3 = entityNameChild3;
+			this.entityAliasChild3 = buildAlias(entityNameChild3);
+		}
+		this.signaturePresent = signaturePresent;
 		selectSQL = "";
 	}
 	
@@ -109,284 +118,116 @@ public class FindEntityByCombinedCategor
 	public String getEntityAliasChild2() {
 		return entityAliasChild2;
 	}
+	
+	public String getEntityNameChild3() {
+		return entityNameChild3;
+	}
+	
+	public String getEntityAliasChild3() {
+		return entityAliasChild3;
+	}
 		
-	public List<?> select(EntityManager em, FindQualifiers fq, CategoryBag categoryBag, List<?> keysIn, DynamicQuery.Parameter... restrictions) {
-	        StringBuffer queryOne = new StringBuffer(200);
-                StringBuffer queryTwo = new StringBuffer(200);
-	    
-                // If keysIn is not null and empty, then search is over.
+	public List<?> select(EntityManager em, FindQualifiers fq, CategoryBag categoryBag, 
+			List<?> keysIn, DynamicQuery.Parameter... restrictions) {
+	        
+        // If keysIn is not null and empty, then search is over.
 		if ((keysIn != null) && (keysIn.size() == 0))
 			return keysIn;
 		
 		if (categoryBag == null)
 			return keysIn;
 		
-		List<KeyedReference> categories = categoryBag.getKeyedReference();
-		if (categories == null || categories.size() == 0)
+		List<KeyedReference> keyRefsInCategories = categoryBag.getKeyedReference();
+		if (keyRefsInCategories == null || keyRefsInCategories.size() == 0)
 			return keysIn;
 		
-		queryOne.append("select " + entityAlias + "." + keyName + ", " + entityAliasChild + ".id "
-	                    + "from " + entityName + " " + entityAlias + ", " + entityNameChild + " " + entityAliasChild + " ");
-		
-		ArrayList<List> aggregatedResultsOne = new ArrayList<List>();
-                ArrayList<List> aggregatedResultsTwo = new ArrayList<List>();
-
-		for (KeyedReference elem : categories) {
-		    List<KeyedReference> keyedRefs = new ArrayList<KeyedReference>(0);
-
-		    if (elem instanceof KeyedReference)
-			keyedRefs.add((KeyedReference)elem);
-	            DynamicQuery dynamicQry = new DynamicQuery(queryOne.toString());
-	            currentAlias = entityAliasChild;
-	            joinClause = entityAlias + "." + keyName + " = "
-	                + entityAliasChild + "." + entityField + "." + keyName + " ";
-	            appendConditions(dynamicQry, fq, keyedRefs);
-	            if (restrictions != null && restrictions.length > 0)
-	                dynamicQry.AND().pad().appendGroupedAnd(restrictions);
-
-	            if (keyedRefs.size() != 0) {
-	                List list = getQueryResult(em, dynamicQry, keysIn, entityAlias + "." + keyName);
-	                aggregatedResultsOne.addAll(list);
-	            }
-		}		
-
-	        queryTwo.append("select  " + entityAlias + "." + keyName + ", " + entityAliasChild2 + ".id "
-	                + "from " + entityName + " " + entityAlias + ", " + entityNameChild + " " + entityAliasChild + ", "
-	                + entityNameChild2 + " " + entityAliasChild2 + " ");
-
-                for (KeyedReference elem : categories) {
-                    List<KeyedReference> keyedRefs = new ArrayList<KeyedReference>(0);
-
-                    if (elem instanceof KeyedReference)
-                        keyedRefs.add((KeyedReference)elem);
-                    DynamicQuery dynamicQry = new DynamicQuery(queryTwo.toString());
-                    currentAlias = entityAliasChild2;
-                    
-                    if (BusinessEntityQuery.ENTITY_NAME.equals(entityName)) {
-                        joinClause = entityAlias + ".entityKey" + " = "
-                        + entityAliasChild + "." + entityField + ".entityKey" + " and "
-                        + entityAliasChild + "." + entityField + ".entityKey" + " = "
-                        + entityAliasChild2 + ".businessService.businessEntity.entityKey";
-                    } else {
-                        joinClause = entityAlias + ".entityKey" + " = "
-                            + entityAliasChild + "." + entityField + ".entityKey" + " and "
-                            + entityAliasChild + "." + entityField + ".entityKey" + " = "
-                            + entityAliasChild2 + ".bindingTemplate.businessService.entityKey";
-                    }
-
-                    appendConditions(dynamicQry, fq, keyedRefs);
-                    if (restrictions != null && restrictions.length > 0)
-                        dynamicQry.AND().pad().appendGroupedAnd(restrictions);
-
-                    if (keyedRefs.size() != 0) {
-                        List list = getQueryResult(em, dynamicQry, keysIn, entityAlias + "." + keyName);
-                        aggregatedResultsTwo.addAll(list);
-                    }
-                }               
-
-                ArrayList results = new ArrayList();
-                if (BusinessServiceQuery.ENTITY_NAME.equals(entityName)) {
-                    ArrayList idsOne = new ArrayList();
-                    ArrayList idsTwo = new ArrayList();
-                    
-                    for (Iterator i = aggregatedResultsOne.iterator(); i.hasNext();) {
-                        Object[] l = (Object[]) i.next();
-                        String id = (String) l[0];
-                        idsOne.add(id);
-                    }
-                    for (Iterator i = aggregatedResultsTwo.iterator(); i.hasNext();) {
-                        Object[] l = (Object[]) i.next();
-                        String id = (String) l[0];
-                        idsTwo.add(id);
-                    }
-                    
-                    results.addAll(idsOne);
-                    results.retainAll(idsTwo);
-                } else if (BusinessEntityQuery.ENTITY_NAME.equals(entityName)) {
-                    ArrayList idsOne = new ArrayList();
-                    ArrayList idsTwo = new ArrayList();
-
-                    for (Iterator i = aggregatedResultsOne.iterator(); i.hasNext();) {
-                        Object[] l = (Object[]) i.next();
-                        String id = (String) l[0];
-                        idsOne.add(id);                        
-                    }
-                    for (Iterator i = aggregatedResultsTwo.iterator(); i.hasNext();) {
-                        Object[] l = (Object[]) i.next();
-                        String id = (String) l[0];
-                        idsTwo.add(id);
-                    }
-                    
-                    results.addAll(idsOne);
-                    results.retainAll(idsTwo);                    
-                }
-                		
-		return results;
-	}
-	
-	
-	/*
-	 * Appends the conditions to the query based on the keyedReference list.  With the default or when "orAllKeys" is passed, the keyedReferences are autonomous and are
-	 * all AND'd or OR'd respectively.  However, "orLikeKeys" requires special treatment.  The goal is to create the conditions in this format:
-	 * 
-	 * (likeKey1 = X or likeKey1 = Y) and (likeKey2 = A or likeKey2 = B or likeKey2 = C) 
-	 * 
-	 * ie. the "like" KeyedReferences are OR'd and the groups of "like" KeyedReferences are AND'd with each other.
-	 */
-	public void appendConditions(DynamicQuery qry, FindQualifiers fq, List<KeyedReference> keyedRefs) {
-		
-		// Append the necessary tables (two will always be added connecting the entity to its category table and then the category table to the keyed references).
-		appendJoinTables(qry, fq, keyedRefs);
-		qry.AND().pad().openParen().pad();
-		
-		String predicate = DynamicQuery.PREDICATE_EQUALS;
-		if (fq.isApproximateMatch()) {
-			predicate = DynamicQuery.PREDICATE_LIKE;
+		Map<KeyedReference,Set<String>> map  = new HashMap<KeyedReference,Set<String>>();
+		//1. First match at the top level (i.e. categoryBag on business)
+		findEntityByCategoryQuery(map, em, fq, categoryBag, entityField, entityNameChild, keysIn, restrictions);
+		//2. Now match at the second level (i.e. categoryBag on services for businesses)
+		findEntityByCategoryQuery(map, em, fq, categoryBag, entityField2, entityNameChild2, keysIn, restrictions);
+		//3. Now match at the third level (i.e. categoryBag on binding for businesses)
+		//   This does only apply to businesses (not for services)
+		if (entityNameChild3!=null) {
+			findEntityByCategoryQuery(map, em, fq, categoryBag, entityField3, entityNameChild3, keysIn, restrictions);
 		}
 		
-		// Sorting the collection by tModel Key
-		Collections.sort(keyedRefs, new KeyedRefTModelComparator());
-
-		String prevTModelKey = null;
-		int count = 0;
-		int tblCount = -1;
-		for(KeyedReference keyedRef : keyedRefs) {
-			String tmodelKey = keyedRef.getTModelKey();
-			String keyValue = keyedRef.getKeyValue();
-			String keyName = keyedRef.getKeyName();
-			
-			if (fq.isApproximateMatch()) {
-				// JUDDI-235: wildcards are provided by user (only commenting in case a new interpretation arises)
-				//keyValue = keyValue.endsWith(DynamicQuery.WILDCARD)?keyValue:keyValue + DynamicQuery.WILDCARD;
-				//keyName = keyName.endsWith(DynamicQuery.WILDCARD)?keyName:keyName + DynamicQuery.WILDCARD;
-			}
-
-			// Either opening up (and AND'ing) a new "group" of like keys or simply appending an "or".  If this is not "orLikeKeys", then just need to increment
-			// the table count.
-			if (fq.isOrLikeKeys()) {
-				if (count == 0) {
-					qry.openParen().pad();
-					tblCount++;
+		//Now build the results taking into account AND/OR/LIKE
+		Set<String> resultingEntityKeys = new HashSet<String>();
+		if (fq.isOrAllKeys()) {
+			//in this case get ALL businessKeys
+			for (KeyedReference keyRef: map.keySet()) {
+				resultingEntityKeys.addAll(map.get(keyRef));
+			}
+		} else if (fq.isOrLikeKeys()) {
+			// any keyedReference filters that come from the same namespace (e.g. have the same tModelKey value) 
+			// are OR’d together rather than AND’d
+			// 1. OR if we have keys with similar namespaces (keyValue)
+			Map<String,Set<String>> likeMap  = new HashMap<String,Set<String>>();
+			for (KeyedReference keyRef: map.keySet()) {
+				String keyValue = keyRef.getKeyValue();
+				if (likeMap.containsKey(keyValue)) {
+					likeMap.get(keyValue).addAll(map.get(keyRef));
+				} else {
+					likeMap.put(keyValue, map.get(keyRef));
 				}
-				else {
-					if (!tmodelKey.equals(prevTModelKey)) {
-						qry.closeParen().pad().AND().pad().openParen().pad();
-						tblCount++;
-					}
-					else
-						qry.OR().pad();
-				}
-			}
-			else
-				tblCount++;
-			
-			String keyValueTerm = (fq.isOrAllKeys()?ALIAS_KEYEDREFERENCE + "0":ALIAS_KEYEDREFERENCE + tblCount) + ".keyValue";
-			String keyNameTerm = (fq.isOrAllKeys()?ALIAS_KEYEDREFERENCE + "0":ALIAS_KEYEDREFERENCE + tblCount) + ".keyName";
-			String tmodelKeyTerm = (fq.isOrAllKeys()?ALIAS_KEYEDREFERENCE + "0":ALIAS_KEYEDREFERENCE + tblCount) + ".tmodelKeyRef";
-			if (fq.isCaseInsensitiveMatch()) {
-				keyValueTerm = "upper(" + keyValueTerm + ")";
-				keyValue = keyValue.toUpperCase();
-				
-				keyNameTerm = "upper(" + keyNameTerm + ")";
-				keyName = keyName.toUpperCase();
-			}
-			
-			
-			// According to specification, if the "general keyword" tmodel is used, then the keyName must be part of the query.
-			if (Constants.GENERAL_KEYWORD_TMODEL.equalsIgnoreCase(tmodelKey)) {
-				qry.appendGroupedAnd(new DynamicQuery.Parameter(tmodelKeyTerm, tmodelKey, DynamicQuery.PREDICATE_EQUALS),
-									 new DynamicQuery.Parameter(keyValueTerm, keyValue, predicate),
-									 new DynamicQuery.Parameter(keyNameTerm, keyName, predicate));
 			}
-			else {
-				qry.appendGroupedAnd(new DynamicQuery.Parameter(tmodelKeyTerm, tmodelKey, DynamicQuery.PREDICATE_EQUALS),
-									 new DynamicQuery.Parameter(keyValueTerm, keyValue, predicate));
-				
+			// 2. Now AND the likeMap
+			boolean firstTime = true;
+			for (String keyValue: likeMap.keySet()) {
+				if (firstTime) {
+					resultingEntityKeys = map.get(keyValue);
+					firstTime = false;
+				} else {
+					resultingEntityKeys.retainAll(map.get(keyValue));
+				}
 			}
-			
-			if (count + 1 < keyedRefs.size()) {
-				if (fq.isOrAllKeys())
-					qry.OR().pad();
-				else if (fq.isOrLikeKeys()) {
+		} else {
+			// AND keys by default, in this case each entity (business or service)
+			// needs to have ALL keys
+			boolean firstTime = true;
+			for (KeyedReference keyRef: map.keySet()) {
+				if (firstTime) {
+					resultingEntityKeys = map.get(keyRef);
+					firstTime = false;
+				} else {
+					resultingEntityKeys.retainAll(map.get(keyRef));
 				}
-				else
-					qry.AND().pad();
 			}
-			
-			// The "orLikeKeys" will always leave an unclosed parenthesis.  This will close it.
-			if (fq.isOrLikeKeys() && (count + 1 == keyedRefs.size()))
-				qry.closeParen().pad();
-
-			prevTModelKey = tmodelKey;
-			count++;
 		}
-		qry.closeParen().pad();
-		
+		return new ArrayList<String>(resultingEntityKeys);
 	}
-
-	
-	
-	/*
-	 * Appends the necessary join table for the child entity and additional tables for when keys are AND'd.  When "orLikeKeys" is used, 
-	 * we only need an extra table for each distinct tmodelKey.
+	/**
+	 * Finding the entities (businesses or services) that have a matching keyedReference in their
+	 * categoryBag.
+	 * 
+	 * @param map - result map of keyedReference and matching businesses
+	 * @param em
+	 * @param fq
+	 * @param categoryBag
+	 * @param entityField
+	 * @param entityNameChild
+	 * @param keysIn
+	 * @param restrictions
 	 */
-	public void appendJoinTables(DynamicQuery qry, FindQualifiers fq, List<KeyedReference> keyedRefs) {
-		
-		if (keyedRefs != null && keyedRefs.size() > 0) {
-			// Sorting the collection by tModel Key
-			Collections.sort(keyedRefs, new KeyedRefTModelComparator());
-
-			StringBuffer thetaJoins = new StringBuffer(200);
-			int tblCount = 0;
-			int count = 0;
-			String curTModelKey = null;
-			String prevTModelKey = null;
-			for(KeyedReference kr : keyedRefs) {
-				curTModelKey = kr.getTModelKey();
-				if (count != 0) {
-					if (!fq.isOrAllKeys()) {
-						if (fq.isOrLikeKeys() && curTModelKey.equals(prevTModelKey)) {
-							// Do nothing
-						}
-						else {
-							tblCount++;
-							qry.comma().pad().append(ENTITY_KEYEDREFERENCE + " " + ALIAS_KEYEDREFERENCE + tblCount).pad();
-							thetaJoins.append(ALIAS_KEYEDREFERENCE + (tblCount - 1) + "." + FIELD_CATEGORYBAG + ".id = " + ALIAS_KEYEDREFERENCE + tblCount + "." + FIELD_CATEGORYBAG + ".id ");
-					//		thetaJoins.append(DynamicQuery.OPERATOR_AND + " ");
-						}
-					}
-
-				}
-				else {
-					qry.comma().pad().append(ENTITY_KEYEDREFERENCE + " " + ALIAS_KEYEDREFERENCE + tblCount).pad();
-					//thetaJoins.append(" ( ");
-                                        thetaJoins.append(DynamicQuery.OPERATOR_AND + " ");
-					thetaJoins.append(currentAlias + ".id = " + ALIAS_KEYEDREFERENCE + tblCount + "." + FIELD_CATEGORYBAG + ".id ");
-					//thetaJoins.append(DynamicQuery.OPERATOR_OR + " ");
-					//thetaJoins.append(entityAliasChild2 + ".id = " + ALIAS_KEYEDREFERENCE + tblCount + "." + FIELD_CATEGORYBAG + ".id ");
-					///thetaJoins.append(" ) ");
-					thetaJoins.append(DynamicQuery.OPERATOR_AND + " ");
-					
-				}
-				prevTModelKey = curTModelKey;
-				count++;
+	private void findEntityByCategoryQuery(Map<KeyedReference,Set<String>> map, EntityManager em, 
+			FindQualifiers fq, CategoryBag categoryBag, String entityField, String entityNameChild, 
+			List<?> keysIn, DynamicQuery.Parameter... restrictions) 
+	{
+		FindEntityByCategoryQuery findEntityByCategoryQuery = new FindEntityByCategoryQuery(
+				entityName, entityAlias, keyName, entityField, entityNameChild, signaturePresent);
+		for (KeyedReference keyedReference : categoryBag.getKeyedReference()) {
+			CategoryBag categoryBagWithOneKey = new CategoryBag();
+			categoryBagWithOneKey.getKeyedReference().add(keyedReference);
+			List<?> entityKeys =  findEntityByCategoryQuery.select(
+					em, fq, categoryBagWithOneKey, keysIn, restrictions);
+			@SuppressWarnings({ "unchecked", "rawtypes" })
+			Set<String> keySet = new HashSet(entityKeys);
+			if (map.containsKey(keyedReference)) {
+				map.get(keyedReference).addAll(keySet);
+			} else {
+				map.put(keyedReference, keySet);
 			}
-			
-			qry.WHERE().pad().openParen().pad();
-			
-                        qry.append(joinClause).pad();
-
-			
-			// Appending the middling entity-specific category table condition
-			//qry.append(entityAlias + "." + keyName + " = " + entityAliasChild + "." + entityField + "." + KEY_NAME).pad();
-//			qry.AND().pad();
-
-			String thetaJoinsStr = thetaJoins.toString();
-			if (thetaJoinsStr.endsWith(DynamicQuery.OPERATOR_AND + " "))
-				thetaJoinsStr = thetaJoinsStr.substring(0, thetaJoinsStr.length() - (DynamicQuery.OPERATOR_AND + " ").length());
-			qry.append(thetaJoinsStr);
-
-			qry.closeParen().pad();
 		}
 	}
 	

Modified: juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/FindEntityByIdentifierQuery.java
URL: http://svn.apache.org/viewvc/juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/FindEntityByIdentifierQuery.java?rev=1468025&r1=1468024&r2=1468025&view=diff
==============================================================================
--- juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/FindEntityByIdentifierQuery.java (original)
+++ juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/FindEntityByIdentifierQuery.java Mon Apr 15 13:07:00 2013
@@ -59,14 +59,17 @@ public class FindEntityByIdentifierQuery
 	private String entityNameChild;
 	private String entityAliasChild;
 	private String selectSQL;
+	private String signaturePresent;
 
-	public FindEntityByIdentifierQuery(String entityName, String entityAlias, String keyName, String entityField, String entityNameChild) {
+	public FindEntityByIdentifierQuery(String entityName, String entityAlias, String keyName, 
+			String entityField, String entityNameChild, String signaturePresent) {
 		this.entityName = entityName;
 		this.entityAlias = entityAlias;
 		this.keyName = keyName;
 		this.entityField = entityField;
 		this.entityNameChild = entityNameChild;
 		this.entityAliasChild = buildAlias(entityNameChild);
+		this.signaturePresent = signaturePresent;
 		
 		StringBuffer sql = new StringBuffer(200);
 		sql.append("select distinct " + entityAlias + "." + keyName + " from " + entityName + " " + entityAlias + " ");
@@ -100,6 +103,14 @@ public class FindEntityByIdentifierQuery
 	public String getSelectSQL() {
 		return selectSQL;
 	}
+	
+	public String getSignaturePresent() {
+		return signaturePresent;
+	}
+
+	public void setSignaturePresent(String signaturePresent) {
+		this.signaturePresent = signaturePresent;
+	}
 
 	
 	public List<?> select(EntityManager em, FindQualifiers fq, IdentifierBag identifiers, List<?> keysIn, DynamicQuery.Parameter... restrictions) {
@@ -268,6 +279,9 @@ public class FindEntityByIdentifierQuery
 			qry.append(thetaJoinsStr);
 
 			qry.closeParen().pad();
+			if (fq!=null && fq.isSignaturePresent()) {
+				qry.AND().pad().openParen().pad().append(getSignaturePresent()).pad().closeParen().pad();
+			}
 		}
 	}
 	

Modified: juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/FindEntityByNamesQuery.java
URL: http://svn.apache.org/viewvc/juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/FindEntityByNamesQuery.java?rev=1468025&r1=1468024&r2=1468025&view=diff
==============================================================================
--- juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/FindEntityByNamesQuery.java (original)
+++ juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/FindEntityByNamesQuery.java Mon Apr 15 13:07:00 2013
@@ -46,14 +46,17 @@ public class FindEntityByNamesQuery exte
 	private String entityNameChild;
 	private String entityAliasChild;
 	private String selectSQL;
+	private String signaturePresent;
 	
-	public FindEntityByNamesQuery(String entityName, String entityAlias, String keyName, String entityField, String entityNameChild) {
+	public FindEntityByNamesQuery(String entityName, String entityAlias, String keyName, String entityField, 
+			String entityNameChild, String signaturePresent) {
 		this.entityName = entityName;
 		this.entityAlias = entityAlias;
 		this.keyName = keyName;
 		this.entityField = entityField;
 		this.entityNameChild = entityNameChild;
 		this.entityAliasChild = buildAlias(entityNameChild);
+		this.signaturePresent = signaturePresent;
 		
 		StringBuffer sql = new StringBuffer(200);
 		sql.append("select distinct " + entityAlias + "." + keyName + " from " + entityName + " " + entityAlias + " ");
@@ -88,6 +91,13 @@ public class FindEntityByNamesQuery exte
 		return selectSQL;
 	}
 	
+	public String getSignaturePresent() {
+		return signaturePresent;
+	}
+
+	public void setSignaturePresent(String signaturePresent) {
+		this.signaturePresent = signaturePresent;
+	}
 	
 	public List<?> select(EntityManager em, FindQualifiers fq, List<Name> names, List<?> keysIn, DynamicQuery.Parameter... restrictions) {
 		// If keysIn is not null and empty, then search is over.
@@ -158,6 +168,11 @@ public class FindEntityByNamesQuery exte
 		qry.WHERE().pad().openParen().pad();
 		qry.append(entityAlias + "." + keyName + " = " + entityAliasChild + "." + entityField + "." + keyName + " ");
 		qry.closeParen().pad();
+		if (fq!=null && fq.isSignaturePresent()) {
+			qry.AND().pad().openParen().pad().append(getSignaturePresent()).pad().closeParen().pad();
+		}
 	}
+
+
 	
 }

Modified: juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/FindEntityByPublisherQuery.java
URL: http://svn.apache.org/viewvc/juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/FindEntityByPublisherQuery.java?rev=1468025&r1=1468024&r2=1468025&view=diff
==============================================================================
--- juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/FindEntityByPublisherQuery.java (original)
+++ juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/FindEntityByPublisherQuery.java Mon Apr 15 13:07:00 2013
@@ -39,11 +39,13 @@ public class FindEntityByPublisherQuery 
 	private String entityAlias;
 	private String keyName;
 	private String selectSQL;
+	private String signaturePresent;
 	
-	public FindEntityByPublisherQuery(String entityName, String entityAlias, String keyName) {
+	public FindEntityByPublisherQuery(String entityName, String entityAlias, String keyName, String signaturePresent) {
 		this.entityName = entityName;
 		this.entityAlias = entityAlias;
 		this.keyName = keyName;
+		this.signaturePresent = signaturePresent;
 		
 		StringBuffer sql = new StringBuffer(200);
 		sql.append("select distinct " + entityAlias + "." + keyName + " from " + entityName + " " + entityAlias + " ");
@@ -66,6 +68,14 @@ public class FindEntityByPublisherQuery 
 		return selectSQL;
 	}
 	
+	public String getSignaturePresent() {
+		return signaturePresent;
+	}
+
+	public void setSignaturePresent(String signaturePresent) {
+		this.signaturePresent = signaturePresent;
+	}
+		
 	
 	public List<?> select(EntityManager em, FindQualifiers fq, UddiEntityPublisher publisher, List<?> keysIn, DynamicQuery.Parameter... restrictions) {
 		// If keysIn is not null and empty, then search is over.
@@ -88,7 +98,11 @@ public class FindEntityByPublisherQuery 
 	 */
 	public void appendConditions(DynamicQuery qry, FindQualifiers fq, UddiEntityPublisher publisher) {
 		qry.WHERE().pad();
+		if (fq!=null && fq.isSignaturePresent()) {
+			qry.pad().openParen().pad().append(getSignaturePresent()).pad().closeParen().pad().AND();
+		}
 		qry.appendGroupedAnd(new DynamicQuery.Parameter(entityAlias + "." + AUTHORIZED_NAME_FIELD, publisher.getAuthorizedName(), DynamicQuery.PREDICATE_EQUALS));
 	}
-		
+
+
 }

Modified: juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/FindServiceByCategoryGroupQuery.java
URL: http://svn.apache.org/viewvc/juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/FindServiceByCategoryGroupQuery.java?rev=1468025&r1=1468024&r2=1468025&view=diff
==============================================================================
--- juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/FindServiceByCategoryGroupQuery.java (original)
+++ juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/FindServiceByCategoryGroupQuery.java Mon Apr 15 13:07:00 2013
@@ -53,7 +53,8 @@ public class FindServiceByCategoryGroupQ
 													   BusinessServiceQuery.ENTITY_ALIAS, 
 													   BusinessServiceQuery.KEY_NAME, 
 													   BusinessServiceQuery.ENTITY_FIELD, 
-													   ENTITY_NAME_CHILD);
+													   ENTITY_NAME_CHILD,
+													   BusinessServiceQuery.SIGNATURE_PRESENT);
 	}
 	
 	public static List<?> select(EntityManager em, FindQualifiers fq, CategoryBag categoryBag, String parentKey, List<?> keysIn) {

Modified: juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/FindServiceByCategoryQuery.java
URL: http://svn.apache.org/viewvc/juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/FindServiceByCategoryQuery.java?rev=1468025&r1=1468024&r2=1468025&view=diff
==============================================================================
--- juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/FindServiceByCategoryQuery.java (original)
+++ juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/FindServiceByCategoryQuery.java Mon Apr 15 13:07:00 2013
@@ -47,12 +47,14 @@ public class FindServiceByCategoryQuery 
 												  BusinessServiceQuery.ENTITY_ALIAS, 
 												  BusinessServiceQuery.KEY_NAME, 
 												  BusinessServiceQuery.ENTITY_FIELD, 
-												  ENTITY_NAME_CHILD);
+												  ENTITY_NAME_CHILD,
+												  BusinessServiceQuery.SIGNATURE_PRESENT);
 	}
 	
 	public static List<?> select(EntityManager em, FindQualifiers fq, CategoryBag categoryBag, String parentKey, List<?> keysIn) {
 		if (parentKey != null && parentKey.length() > 0) {
-			DynamicQuery.Parameter param = new DynamicQuery.Parameter(BusinessServiceQuery.ENTITY_ALIAS + "." + BusinessServiceQuery.KEY_NAME_PARENT, parentKey, DynamicQuery.PREDICATE_EQUALS); 
+			DynamicQuery.Parameter param = new DynamicQuery.Parameter(BusinessServiceQuery.ENTITY_ALIAS + "." 
+					+ BusinessServiceQuery.KEY_NAME_PARENT, parentKey, DynamicQuery.PREDICATE_EQUALS); 
 			return findQuery.select(em, fq, categoryBag, keysIn, param);
 		}
 		else

Modified: juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/FindServiceByCombinedCategoryQuery.java
URL: http://svn.apache.org/viewvc/juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/FindServiceByCombinedCategoryQuery.java?rev=1468025&r1=1468024&r2=1468025&view=diff
==============================================================================
--- juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/FindServiceByCombinedCategoryQuery.java (original)
+++ juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/FindServiceByCombinedCategoryQuery.java Mon Apr 15 13:07:00 2013
@@ -38,12 +38,16 @@ import org.uddi.api_v3.CategoryBag;
  * and bindingTemplate elements were combined.  Searching for a category will yield a positive match on a registered 
  * business if any of the categoryBag elements contained within the full businessEntity element (including the 
  * categoryBag elements within contained or referenced businessService elements or bindingTemplate elements) 
- * contains the filter criteria.  In the case of find_service, this qualifier makes the categoryBag entries 
+ * contains the filter criteria. 
+ * 
+ * In the case of find_service, this qualifier makes the categoryBag entries 
  * for the full businessService element behave as though all categoryBag elements found at the businessService level 
  * and in all contained or referenced elements in the bindingTemplate elements were combined.  Searching for a category 
  * will yield a positive match on a registered service if any of the categoryBag elements contained within the 
  * full businessService element (including the categoryBag elements within contained or referenced bindingTemplate 
- * elements) contains the filter criteria. This find qualifier does not cause the keyedReferences in categoryBags 
+ * elements) contains the filter criteria. 
+ * 
+ * This find qualifier does not cause the keyedReferences in categoryBags 
  * to be combined with the keyedReferences in keyedReferenceGroups in categoryBags when performing the comparison.  
  * The keyedReferences are combined with each other, and the keyedReferenceGroups are combined with each other."
  * 
@@ -54,17 +58,22 @@ import org.uddi.api_v3.CategoryBag;
 public class FindServiceByCombinedCategoryQuery {
 	
 	private static final String ENTITY_NAME_CHILD  = "ServiceCategoryBag";
+	private static final String ENTITY_FIELD2      = "bindingTemplate." + BusinessServiceQuery.ENTITY_FIELD;
 	private static final String ENTITY_NAME_CHILD2 = "BindingCategoryBag";
 	
 	private static FindEntityByCombinedCategoryQuery findQuery;
 	
 	static {
 		findQuery = new FindEntityByCombinedCategoryQuery(BusinessServiceQuery.ENTITY_NAME, 
-				BusinessServiceQuery.ENTITY_ALIAS, 
-				BusinessServiceQuery.KEY_NAME, 
-				BusinessServiceQuery.ENTITY_FIELD, 
-				ENTITY_NAME_CHILD,
-				ENTITY_NAME_CHILD2);
+														  BusinessServiceQuery.ENTITY_ALIAS, 
+														  BusinessServiceQuery.KEY_NAME, 
+														  BusinessServiceQuery.ENTITY_FIELD, 
+														  ENTITY_NAME_CHILD,
+														  ENTITY_FIELD2,
+														  ENTITY_NAME_CHILD2,
+														  null,
+														  null,
+														  BusinessServiceQuery.SIGNATURE_PRESENT);
 	}
 	
 	public static List<?> select(EntityManager em, FindQualifiers fq, CategoryBag categoryBag, String parentKey, List<?> keysIn) {
@@ -75,15 +84,4 @@ public class FindServiceByCombinedCatego
 		else
 			return findQuery.select(em, fq, categoryBag, keysIn);
 	}
-	
-//	select service.entity_key, scb.id from juddiv3.j3_business_service service 
-//	join juddiv3.j3_service_category_bag scb on service.entity_key = scb.entity_key, 
-//	juddiv3.j3_keyed_reference kr0, juddiv3.j3_keyed_reference kr1 
-//	where (kr0.category_bag_id=scb.id and kr0.tmodel_key_ref='uddi:uddi.joepublisher.com:tmodel01' and kr0.key_value='value-z') or (kr1.category_bag_id=scb.id and
-//	kr1.tmodel_key_ref='uddi:uddi.joepublisher.com:tmodel02' and kr1.key_value='value-x') group by  service.entity_key, scb.id UNION
-//	select service.entity_key, bcb.id from juddiv3.j3_business_service service join juddiv3.j3_binding_template bt on service.entity_key = bt.service_key join
-//	juddiv3.j3_binding_category_bag bcb on bt.entity_key = bcb.entity_key,
-//	juddiv3.j3_keyed_reference kr0, juddiv3.j3_keyed_reference kr1 
-//	where (kr0.category_bag_id=bcb.id and kr0.tmodel_key_ref='uddi:uddi.joepublisher.com:tmodel01' and kr0.key_value='value-z') or (kr1.category_bag_id=bcb.id and
-//	kr1.tmodel_key_ref='uddi:uddi.joepublisher.com:tmodel02' and kr1.key_value='value-x') group by  service.entity_key, bcb.id ;
 }

Modified: juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/FindServiceByNameQuery.java
URL: http://svn.apache.org/viewvc/juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/FindServiceByNameQuery.java?rev=1468025&r1=1468024&r2=1468025&view=diff
==============================================================================
--- juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/FindServiceByNameQuery.java (original)
+++ juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/FindServiceByNameQuery.java Mon Apr 15 13:07:00 2013
@@ -45,7 +45,7 @@ import org.uddi.api_v3.Name;
  */
 public class FindServiceByNameQuery {
 
-	public static final String ENTITY_NAME_CHILD = "ServiceName";
+	public static final String ENTITY_NAME_CHILD = "ServiceName";			
 
 	private static FindEntityByNamesQuery findQuery;
 	
@@ -54,7 +54,8 @@ public class FindServiceByNameQuery {
 											   BusinessServiceQuery.ENTITY_ALIAS, 
 											   BusinessServiceQuery.KEY_NAME, 
 											   BusinessServiceQuery.ENTITY_FIELD, 
-											   ENTITY_NAME_CHILD);
+											   ENTITY_NAME_CHILD,
+											   BusinessServiceQuery.SIGNATURE_PRESENT);
 	}
 
 	public static List<?> select(EntityManager em, FindQualifiers fq, List<Name> names, String parentKey, List<?> keysIn) {

Modified: juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/FindServiceByTModelKeyQuery.java
URL: http://svn.apache.org/viewvc/juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/FindServiceByTModelKeyQuery.java?rev=1468025&r1=1468024&r2=1468025&view=diff
==============================================================================
--- juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/FindServiceByTModelKeyQuery.java (original)
+++ juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/FindServiceByTModelKeyQuery.java Mon Apr 15 13:07:00 2013
@@ -158,6 +158,9 @@ public class FindServiceByTModelKeyQuery
 			qry.append(thetaJoinsStr);
 
 			qry.closeParen().pad();
+			if (fq!=null && fq.isSignaturePresent()) {
+				qry.AND().pad().openParen().pad().append(BusinessServiceQuery.SIGNATURE_PRESENT).pad().closeParen().pad();
+			}
 		}
 	}
 	

Modified: juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/FindTModelByCategoryGroupQuery.java
URL: http://svn.apache.org/viewvc/juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/FindTModelByCategoryGroupQuery.java?rev=1468025&r1=1468024&r2=1468025&view=diff
==============================================================================
--- juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/FindTModelByCategoryGroupQuery.java (original)
+++ juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/FindTModelByCategoryGroupQuery.java Mon Apr 15 13:07:00 2013
@@ -54,7 +54,8 @@ public class FindTModelByCategoryGroupQu
 													   TModelQuery.ENTITY_ALIAS, 
 													   TModelQuery.KEY_NAME, 
 													   TModelQuery.ENTITY_FIELD, 
-													   ENTITY_NAME_CHILD);
+													   ENTITY_NAME_CHILD,
+													   TModelQuery.SIGNATURE_PRESENT);
 	}
 	
 	public static List<?> select(EntityManager em, FindQualifiers fq, CategoryBag categoryBag, List<?> keysIn) {

Modified: juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/FindTModelByCategoryQuery.java
URL: http://svn.apache.org/viewvc/juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/FindTModelByCategoryQuery.java?rev=1468025&r1=1468024&r2=1468025&view=diff
==============================================================================
--- juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/FindTModelByCategoryQuery.java (original)
+++ juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/FindTModelByCategoryQuery.java Mon Apr 15 13:07:00 2013
@@ -48,7 +48,8 @@ public class FindTModelByCategoryQuery {
 												  TModelQuery.ENTITY_ALIAS, 
 												  TModelQuery.KEY_NAME, 
 												  TModelQuery.ENTITY_FIELD, 
-												  ENTITY_NAME_CHILD);
+												  ENTITY_NAME_CHILD,
+												  TModelQuery.SIGNATURE_PRESENT);
 	}
 	
 	public static List<?> select(EntityManager em, FindQualifiers fq, CategoryBag categoryBag, List<?> keysIn) {

Modified: juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/FindTModelByIdentifierQuery.java
URL: http://svn.apache.org/viewvc/juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/FindTModelByIdentifierQuery.java?rev=1468025&r1=1468024&r2=1468025&view=diff
==============================================================================
--- juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/FindTModelByIdentifierQuery.java (original)
+++ juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/FindTModelByIdentifierQuery.java Mon Apr 15 13:07:00 2013
@@ -47,7 +47,8 @@ public class FindTModelByIdentifierQuery
 													TModelQuery.ENTITY_ALIAS, 
 													TModelQuery.KEY_NAME, 
 													TModelQuery.ENTITY_FIELD, 
-													ENTITY_NAME_CHILD);
+													ENTITY_NAME_CHILD,
+													TModelQuery.SIGNATURE_PRESENT);
 	}
 	
 	public static List<?> select(EntityManager em, FindQualifiers fq, IdentifierBag identifiers, List<?> keysIn) {

Modified: juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/FindTModelByNameQuery.java
URL: http://svn.apache.org/viewvc/juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/FindTModelByNameQuery.java?rev=1468025&r1=1468024&r2=1468025&view=diff
==============================================================================
--- juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/FindTModelByNameQuery.java (original)
+++ juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/FindTModelByNameQuery.java Mon Apr 15 13:07:00 2013
@@ -97,7 +97,9 @@ public class FindTModelByNameQuery exten
 		}
 
 		qry.closeParen().pad();
-		
+		if (fq!=null && fq.isSignaturePresent()) {
+			qry.AND().pad().openParen().pad().append(TModelQuery.SIGNATURE_PRESENT).pad().closeParen().pad();
+		}
 	}
 	
 }

Modified: juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/FindTModelByPublisherQuery.java
URL: http://svn.apache.org/viewvc/juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/FindTModelByPublisherQuery.java?rev=1468025&r1=1468024&r2=1468025&view=diff
==============================================================================
--- juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/FindTModelByPublisherQuery.java (original)
+++ juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/FindTModelByPublisherQuery.java Mon Apr 15 13:07:00 2013
@@ -37,7 +37,11 @@ public class FindTModelByPublisherQuery 
 	private static FindEntityByPublisherQuery findQuery;
 	
 	static {
-		findQuery = new FindEntityByPublisherQuery(TModelQuery.ENTITY_NAME, TModelQuery.ENTITY_ALIAS, TModelQuery.KEY_NAME);
+		findQuery = new FindEntityByPublisherQuery(
+						TModelQuery.ENTITY_NAME, 
+						TModelQuery.ENTITY_ALIAS, 
+						TModelQuery.KEY_NAME,
+						TModelQuery.SIGNATURE_PRESENT);
 	}
 	
 	public static List<?> select(EntityManager em, FindQualifiers fq, UddiEntityPublisher publisher, List<?> keysIn, DynamicQuery.Parameter... restrictions) {

Modified: juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/TModelQuery.java
URL: http://svn.apache.org/viewvc/juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/TModelQuery.java?rev=1468025&r1=1468024&r2=1468025&view=diff
==============================================================================
--- juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/TModelQuery.java (original)
+++ juddi/branches/juddi-3.2.x/juddi-core/src/main/java/org/apache/juddi/query/TModelQuery.java Mon Apr 15 13:07:00 2013
@@ -25,6 +25,7 @@ public class TModelQuery extends EntityQ
 	public static final String ENTITY_NAME = "Tmodel";
 	public static final String ENTITY_ALIAS = "t";
 	public static final String ENTITY_FIELD = "tmodel";
+	public static final String SIGNATURE_PRESENT = ENTITY_ALIAS + "." + SIGNATURE_FIELD + " IS NOT EMPTY ";
 	
 	protected static String selectSQL;
 

Modified: juddi/branches/juddi-3.2.x/juddi-core/src/test/java/org/apache/juddi/api/impl/API_030_BusinessEntityTest.java
URL: http://svn.apache.org/viewvc/juddi/branches/juddi-3.2.x/juddi-core/src/test/java/org/apache/juddi/api/impl/API_030_BusinessEntityTest.java?rev=1468025&r1=1468024&r2=1468025&view=diff
==============================================================================
--- juddi/branches/juddi-3.2.x/juddi-core/src/test/java/org/apache/juddi/api/impl/API_030_BusinessEntityTest.java (original)
+++ juddi/branches/juddi-3.2.x/juddi-core/src/test/java/org/apache/juddi/api/impl/API_030_BusinessEntityTest.java Mon Apr 15 13:07:00 2013
@@ -21,6 +21,7 @@ import org.apache.commons.logging.Log;
 import org.apache.commons.logging.LogFactory;
 import org.apache.juddi.Registry;
 import org.apache.juddi.v3.tck.TckBusiness;
+import org.apache.juddi.v3.tck.TckFindEntity;
 import org.apache.juddi.v3.tck.TckPublisher;
 import org.apache.juddi.v3.tck.TckSecurity;
 import org.apache.juddi.v3.tck.TckTModel;
@@ -41,6 +42,7 @@ public class API_030_BusinessEntityTest 
 	private static API_010_PublisherTest api010 = new API_010_PublisherTest();
 	private static TckTModel tckTModel          = new TckTModel(new UDDIPublicationImpl(), new UDDIInquiryImpl());
 	private static TckBusiness tckBusiness      = new TckBusiness(new UDDIPublicationImpl(), new UDDIInquiryImpl());
+	private static TckFindEntity tckFindEntity  = new TckFindEntity(new UDDIInquiryImpl());
 	private static String authInfoJoe           = null;
 	private static String authInfoSam           = null;
 	
@@ -87,5 +89,26 @@ public class API_030_BusinessEntityTest 
 		}
 	}
 	
+	@Test
+	public void testJoePublisherBusinessEntitySignature() {
+		try {
+			tckTModel.saveJoePublisherTmodel(authInfoJoe);
+			tckBusiness.saveJoePublisherBusinessX509Signature(authInfoJoe);
+			tckFindEntity.findAllBusiness();
+			tckTModel.saveSamSyndicatorTmodel(authInfoSam);
+			tckBusiness.saveSamSyndicatorBusiness(authInfoSam);
+			
+			//find the signed business
+			tckFindEntity.findAllSignedBusiness();
+			
+			tckBusiness.deleteSamSyndicatorBusiness(authInfoSam);
+			tckBusiness.deleteJoePublisherBusiness(authInfoJoe);
+			
+		} finally {
+			tckTModel.deleteJoePublisherTmodel(authInfoJoe);
+			tckTModel.deleteSamSyndicatorTmodel(authInfoSam);
+		}
+	}
+	
 	
 }

Modified: juddi/branches/juddi-3.2.x/juddi-core/src/test/java/org/apache/juddi/api/impl/API_040_BusinessServiceTest.java
URL: http://svn.apache.org/viewvc/juddi/branches/juddi-3.2.x/juddi-core/src/test/java/org/apache/juddi/api/impl/API_040_BusinessServiceTest.java?rev=1468025&r1=1468024&r2=1468025&view=diff
==============================================================================
--- juddi/branches/juddi-3.2.x/juddi-core/src/test/java/org/apache/juddi/api/impl/API_040_BusinessServiceTest.java (original)
+++ juddi/branches/juddi-3.2.x/juddi-core/src/test/java/org/apache/juddi/api/impl/API_040_BusinessServiceTest.java Mon Apr 15 13:07:00 2013
@@ -15,28 +15,19 @@
 package org.apache.juddi.api.impl;
 
 import java.rmi.RemoteException;
-import java.util.List;
-
-import javax.persistence.EntityManager;
-import javax.persistence.Query;
 
 import org.apache.commons.configuration.ConfigurationException;
 import org.apache.commons.logging.Log;
 import org.apache.commons.logging.LogFactory;
 import org.apache.juddi.Registry;
-import org.apache.juddi.config.PersistenceManager;
-import org.apache.juddi.query.util.DynamicQuery;
-import org.apache.juddi.v3.tck.Property;
 import org.apache.juddi.v3.tck.TckBusiness;
 import org.apache.juddi.v3.tck.TckBusinessService;
-import org.apache.juddi.v3.tck.TckFindEntity;
 import org.apache.juddi.v3.tck.TckPublisher;
 import org.apache.juddi.v3.tck.TckSecurity;
 import org.apache.juddi.v3.tck.TckTModel;
 import org.junit.AfterClass;
 import org.junit.Assert;
 import org.junit.BeforeClass;
-import org.junit.Ignore;
 import org.junit.Test;
 import org.uddi.v3_service.UDDISecurityPortType;
 
@@ -52,7 +43,6 @@ public class API_040_BusinessServiceTest
 	private static TckTModel tckTModel               = new TckTModel(new UDDIPublicationImpl(), new UDDIInquiryImpl());
 	private static TckBusiness tckBusiness           = new TckBusiness(new UDDIPublicationImpl(), new UDDIInquiryImpl());
 	private static TckBusinessService tckBusinessService  = new TckBusinessService(new UDDIPublicationImpl(), new UDDIInquiryImpl());
-	private static TckFindEntity tckFindEntity            = new TckFindEntity(new UDDIInquiryImpl());
 	
 	private static String authInfoJoe                = null;
 	private static String authInfoSam                = null;
@@ -160,52 +150,6 @@ public class API_040_BusinessServiceTest
 		}
 	}
 	
-	@Test @Ignore
-	public void combineCategoryBagsFindServices() {
-		try {
-			tckTModel.saveJoePublisherTmodel(authInfoJoe);
-			tckBusiness.saveCombineCatBagsPublisherBusiness(authInfoJoe);
-			
-			PersistenceManager pm = new PersistenceManager();
-			EntityManager em = pm.getEntityManager();
-			
-			String sql = "select bs.entityKey from BusinessService bs ," +
-					" ServiceCategoryBag ServiceCategory_ , " +
-					"KeyedReference KeyedRefere_0 , KeyedReference KeyedRefere_1 " +
-					"where ( bs.entityKey = ServiceCategory_.businessService.entityKey and " +
-					" ( ServiceCategory_.id = KeyedRefere_0.categoryBag.id  ))";
-			String sql3 = "select bs.entityKey from BusinessService bs UNION select bs.entityKey from BusinessService bs";
-			
-			String sql2 = "select bs.entityKey, categoryBag.id from BusinessService bs, " +
-	        " BindingTemplate bt,  " +
-			" BindingCategoryBag categoryBag  ," +
-			"KeyedReference KeyedRefere_0, KeyedReference KeyedRefere_1 " +
-			"where  categoryBag.id = bt.categoryBag.id and " +
-			"bt.businessService.entityKey = bs.entityKey and " +
-			"( (KeyedRefere_0.categoryBag.id=categoryBag.id and KeyedRefere_0.tmodelKeyRef = 'uddi:uddi.joepublisher.com:tmodel01' and KeyedRefere_0.keyValue = 'value-z') or " +
-			"(KeyedRefere_1.categoryBag.id=categoryBag.id and KeyedRefere_1.tmodelKeyRef = 'uddi:uddi.joepublisher.com:tmodel02' and KeyedRefere_1.keyValue = 'value-x') ) " +
-			" group by bs.entityKey, categoryBag.id ";
-			
-			String sql1 = "select bs.entityKey from BusinessService bs ," +
-			        " BindingTemplate bt, ServiceCategoryBag ServiceCategory_ , " +
-					" BindingCategoryBag BindingCategory_  , " +
-					"KeyedReference KeyedRefere_0, KeyedReference KeyedRefere_1 " +
-					"where ( ((bt.businessService.entityKey = bs.entityKey and bt.entityKey = BindingCategory_.bindingTemplate.entityKey and " +
-					" BindingCategory_.id = KeyedRefere_0.categoryBag.id) AND (bs.entityKey = ServiceCategory_.businessService.entityKey and ServiceCategory_.id = KeyedRefere_0.categoryBag.id)" +
-					") and KeyedRefere_0.categoryBag.id = KeyedRefere_1.categoryBag.id and ( " +
-					"(KeyedRefere_0.tmodelKeyRef = 'uddi:uddi.joepublisher.com:tmodel01' and KeyedRefere_0.keyValue = 'value-z') and " +
-					"(KeyedRefere_1.tmodelKeyRef = 'uddi:uddi.joepublisher.com:tmodel02' and KeyedRefere_1.keyValue = 'value-x') ) ) ";
-			Query qry = em.createQuery(sql2);
-			List result = qry.getResultList();
-			System.out.println(result);
-			
-			//tckFindEntity.findService_CombinedCatBag();
-		} catch (Exception e) {
-			e.printStackTrace();
-			Assert.fail(e.getMessage());
-		} 
-	}
-	
 	@Test
 	public void samsyndicator() {
 		try {

Modified: juddi/branches/juddi-3.2.x/juddi-core/src/test/java/org/apache/juddi/api/impl/API_050_BindingTemplateTest.java
URL: http://svn.apache.org/viewvc/juddi/branches/juddi-3.2.x/juddi-core/src/test/java/org/apache/juddi/api/impl/API_050_BindingTemplateTest.java?rev=1468025&r1=1468024&r2=1468025&view=diff
==============================================================================
--- juddi/branches/juddi-3.2.x/juddi-core/src/test/java/org/apache/juddi/api/impl/API_050_BindingTemplateTest.java (original)
+++ juddi/branches/juddi-3.2.x/juddi-core/src/test/java/org/apache/juddi/api/impl/API_050_BindingTemplateTest.java Mon Apr 15 13:07:00 2013
@@ -91,17 +91,17 @@ public class API_050_BindingTemplateTest
 			
 			tckFindEntity.findServiceDetail("uddi:uddi.joepublisher.com:serviceone");
 			tckBindingTemplate.deleteBinding(authInfoJoe, "uddi:uddi.joepublisher.com:bindingone");
-			String serviceKey = tckFindEntity.findService();
+			String serviceKey = tckFindEntity.findService(null);
 			tckFindEntity.findServiceDetail(serviceKey);
 			
 			tckBindingTemplate.saveJoePublisherBinding(authInfoJoe);
 			
-			serviceKey = tckFindEntity.findService();
+			serviceKey = tckFindEntity.findService(null);
 			tckFindEntity.findServiceDetail(serviceKey);
 			
 			tckBindingTemplate.deleteJoePublisherBinding(authInfoJoe);
 			
-			tckFindEntity.findService();
+			tckFindEntity.findService(null);
 			tckFindEntity.findServiceDetail(serviceKey);
 		} finally {
 			tckBusinessService.deleteJoePublisherService(authInfoJoe);

Modified: juddi/branches/juddi-3.2.x/juddi-core/src/test/java/org/apache/juddi/api/impl/API_070_FindEntityTest.java
URL: http://svn.apache.org/viewvc/juddi/branches/juddi-3.2.x/juddi-core/src/test/java/org/apache/juddi/api/impl/API_070_FindEntityTest.java?rev=1468025&r1=1468024&r2=1468025&view=diff
==============================================================================
--- juddi/branches/juddi-3.2.x/juddi-core/src/test/java/org/apache/juddi/api/impl/API_070_FindEntityTest.java (original)
+++ juddi/branches/juddi-3.2.x/juddi-core/src/test/java/org/apache/juddi/api/impl/API_070_FindEntityTest.java Mon Apr 15 13:07:00 2013
@@ -20,6 +20,7 @@ import org.apache.commons.configuration.
 import org.apache.commons.logging.Log;
 import org.apache.commons.logging.LogFactory;
 import org.apache.juddi.Registry;
+import org.apache.juddi.v3.client.UDDIConstants;
 import org.apache.juddi.v3.tck.TckBindingTemplate;
 import org.apache.juddi.v3.tck.TckBusiness;
 import org.apache.juddi.v3.tck.TckBusinessService;
@@ -75,9 +76,33 @@ public class API_070_FindEntityTest 
 			tckBusinessService.saveJoePublisherService(authInfoJoe);
 			tckBindingTemplate.saveJoePublisherBinding(authInfoJoe);
 			tckFindEntity.findBusiness();
-			tckFindEntity.findService();
-			tckFindEntity.findBinding();
-			tckFindEntity.findTModel();
+			tckFindEntity.findService(null);
+			tckFindEntity.findBinding(null);
+			tckFindEntity.findTModel(null);
+			tckFindEntity.findAllBusiness();
+			tckFindEntity.getNonExitingBusiness();
+		} finally {
+			tckBindingTemplate.deleteJoePublisherBinding(authInfoJoe);
+			tckBusinessService.deleteJoePublisherService(authInfoJoe);
+			tckBusiness.deleteJoePublisherBusiness(authInfoJoe);
+			tckTModel.deleteJoePublisherTmodel(authInfoJoe);
+		}
+		
+	}
+	
+	@Test
+	public void findSignedEntities() {
+		try {
+			tckTModel.saveJoePublisherTmodel(authInfoJoe);
+			tckBusiness.saveJoePublisherBusinessX509Signature(authInfoJoe);
+			tckBusinessService.saveJoePublisherService(authInfoJoe);
+			tckBindingTemplate.saveJoePublisherBinding(authInfoJoe);
+			
+			tckFindEntity.findAllSignedBusiness();
+			tckFindEntity.findService(UDDIConstants.SIGNATURE_PRESENT);
+			tckFindEntity.findBinding(UDDIConstants.SIGNATURE_PRESENT);
+			//tckFindEntity.findTModel(UDDIConstants.SIGNATURE_PRESENT);
+			
 			tckFindEntity.findAllBusiness();
 			tckFindEntity.getNonExitingBusiness();
 		} finally {

Modified: juddi/branches/juddi-3.2.x/juddi-core/src/test/resources/META-INF/persistence.xml
URL: http://svn.apache.org/viewvc/juddi/branches/juddi-3.2.x/juddi-core/src/test/resources/META-INF/persistence.xml?rev=1468025&r1=1468024&r2=1468025&view=diff
==============================================================================
--- juddi/branches/juddi-3.2.x/juddi-core/src/test/resources/META-INF/persistence.xml (original)
+++ juddi/branches/juddi-3.2.x/juddi-core/src/test/resources/META-INF/persistence.xml Mon Apr 15 13:07:00 2013
@@ -58,6 +58,7 @@
     <class>org.apache.juddi.model.Subscription</class>
     <class>org.apache.juddi.model.SubscriptionChunkToken</class>
     <class>org.apache.juddi.model.SubscriptionMatch</class>
+    <class>org.apache.juddi.model.TempKey</class>
     <class>org.apache.juddi.model.Tmodel</class>
     <class>org.apache.juddi.model.TmodelCategoryBag</class>
     <class>org.apache.juddi.model.TmodelDescr</class>

Propchange: juddi/branches/juddi-3.2.x/juddi-examples/simple-browse/
------------------------------------------------------------------------------
--- svn:ignore (original)
+++ svn:ignore Mon Apr 15 13:07:00 2013
@@ -1 +1,4 @@
 target
+.settings
+.classpath
+.project

Modified: juddi/branches/juddi-3.2.x/juddi-gui/nbproject/build-impl.xml
URL: http://svn.apache.org/viewvc/juddi/branches/juddi-3.2.x/juddi-gui/nbproject/build-impl.xml?rev=1468025&r1=1468024&r2=1468025&view=diff
==============================================================================
--- juddi/branches/juddi-3.2.x/juddi-gui/nbproject/build-impl.xml (original)
+++ juddi/branches/juddi-3.2.x/juddi-gui/nbproject/build-impl.xml Mon Apr 15 13:07:00 2013
@@ -986,7 +986,6 @@ exists or setup the property manually. F
         <copyfiles files="${file.reference.commons-lang-2.4.jar}" iftldtodir="${build.web.dir}/WEB-INF" todir="${dist.ear.dir}/lib"/>
         <copyfiles files="${file.reference.commons-logging-api-1.1.jar}" iftldtodir="${build.web.dir}/WEB-INF" todir="${dist.ear.dir}/lib"/>
         <copyfiles files="${file.reference.commons-logging-api-1.1.jar}" iftldtodir="${build.web.dir}/WEB-INF" todir="${dist.ear.dir}/lib"/>
-        <copyfiles files="${file.reference.commons-pool-1.3.jar}" iftldtodir="${build.web.dir}/WEB-INF" todir="${dist.ear.dir}/lib"/>
         <copyfiles files="${file.reference.cxf-api-2.3.1.jar}" iftldtodir="${build.web.dir}/WEB-INF" todir="${dist.ear.dir}/lib"/>
         <copyfiles files="${file.reference.cxf-common-schemas-2.3.1.jar}" iftldtodir="${build.web.dir}/WEB-INF" todir="${dist.ear.dir}/lib"/>
         <copyfiles files="${file.reference.cxf-common-utilities-2.3.1.jar}" iftldtodir="${build.web.dir}/WEB-INF" todir="${dist.ear.dir}/lib"/>
@@ -1000,14 +999,10 @@ exists or setup the property manually. F
         <copyfiles files="${file.reference.cxf-rt-ws-addr-2.3.1.jar}" iftldtodir="${build.web.dir}/WEB-INF" todir="${dist.ear.dir}/lib"/>
         <copyfiles files="${file.reference.cxf-tools-common-2.3.1.jar}" iftldtodir="${build.web.dir}/WEB-INF" todir="${dist.ear.dir}/lib"/>
         <copyfiles files="${file.reference.geronimo-javamail_1.4_spec-1.7.1.jar}" iftldtodir="${build.web.dir}/WEB-INF" todir="${dist.ear.dir}/lib"/>
-        <copyfiles files="${file.reference.geronimo-jms_1.1_spec-1.0.1.jar}" iftldtodir="${build.web.dir}/WEB-INF" todir="${dist.ear.dir}/lib"/>
-        <copyfiles files="${file.reference.geronimo-jpa_3.0_spec-1.0.jar}" iftldtodir="${build.web.dir}/WEB-INF" todir="${dist.ear.dir}/lib"/>
-        <copyfiles files="${file.reference.geronimo-jta_1.1_spec-1.1.jar}" iftldtodir="${build.web.dir}/WEB-INF" todir="${dist.ear.dir}/lib"/>
         <copyfiles files="${file.reference.jaxb-impl-2.1.13.jar}" iftldtodir="${build.web.dir}/WEB-INF" todir="${dist.ear.dir}/lib"/>
         <copyfiles files="${file.reference.junit-3.8.2.jar}" iftldtodir="${build.web.dir}/WEB-INF" todir="${dist.ear.dir}/lib"/>
         <copyfiles files="${file.reference.juddi-client-3.1.5-SNAPSHOT.jar}" iftldtodir="${build.web.dir}/WEB-INF" todir="${dist.ear.dir}/lib"/>
         <copyfiles files="${file.reference.neethi-2.0.4.jar}" iftldtodir="${build.web.dir}/WEB-INF" todir="${dist.ear.dir}/lib"/>
-        <copyfiles files="${file.reference.openjpa-1.2.2.jar}" iftldtodir="${build.web.dir}/WEB-INF" todir="${dist.ear.dir}/lib"/>
         <copyfiles files="${file.reference.persistence-api-1.0.jar}" iftldtodir="${build.web.dir}/WEB-INF" todir="${dist.ear.dir}/lib"/>
         <copyfiles files="${file.reference.serp-1.13.1.jar}" iftldtodir="${build.web.dir}/WEB-INF" todir="${dist.ear.dir}/lib"/>
         <copyfiles files="${file.reference.spring-aop-3.0.5.RELEASE.jar}" iftldtodir="${build.web.dir}/WEB-INF" todir="${dist.ear.dir}/lib"/>
@@ -1038,7 +1033,6 @@ exists or setup the property manually. F
         <copyfiles files="${file.reference.commons-lang-2.4.jar}" todir="${build.web.dir}/WEB-INF/lib"/>
         <copyfiles files="${file.reference.commons-logging-api-1.1.jar}" todir="${build.web.dir}/WEB-INF/lib"/>
         <copyfiles files="${file.reference.commons-logging-api-1.1.jar}" todir="${build.web.dir}/WEB-INF/lib"/>
-        <copyfiles files="${file.reference.commons-pool-1.3.jar}" todir="${build.web.dir}/WEB-INF/lib"/>
         <copyfiles files="${file.reference.cxf-api-2.3.1.jar}" todir="${build.web.dir}/WEB-INF/lib"/>
         <copyfiles files="${file.reference.cxf-common-schemas-2.3.1.jar}" todir="${build.web.dir}/WEB-INF/lib"/>
         <copyfiles files="${file.reference.cxf-common-utilities-2.3.1.jar}" todir="${build.web.dir}/WEB-INF/lib"/>
@@ -1052,14 +1046,10 @@ exists or setup the property manually. F
         <copyfiles files="${file.reference.cxf-rt-ws-addr-2.3.1.jar}" todir="${build.web.dir}/WEB-INF/lib"/>
         <copyfiles files="${file.reference.cxf-tools-common-2.3.1.jar}" todir="${build.web.dir}/WEB-INF/lib"/>
         <copyfiles files="${file.reference.geronimo-javamail_1.4_spec-1.7.1.jar}" todir="${build.web.dir}/WEB-INF/lib"/>
-        <copyfiles files="${file.reference.geronimo-jms_1.1_spec-1.0.1.jar}" todir="${build.web.dir}/WEB-INF/lib"/>
-        <copyfiles files="${file.reference.geronimo-jpa_3.0_spec-1.0.jar}" todir="${build.web.dir}/WEB-INF/lib"/>
-        <copyfiles files="${file.reference.geronimo-jta_1.1_spec-1.1.jar}" todir="${build.web.dir}/WEB-INF/lib"/>
         <copyfiles files="${file.reference.jaxb-impl-2.1.13.jar}" todir="${build.web.dir}/WEB-INF/lib"/>
         <copyfiles files="${file.reference.junit-3.8.2.jar}" todir="${build.web.dir}/WEB-INF/lib"/>
         <copyfiles files="${file.reference.juddi-client-3.1.5-SNAPSHOT.jar}" todir="${build.web.dir}/WEB-INF/lib"/>
         <copyfiles files="${file.reference.neethi-2.0.4.jar}" todir="${build.web.dir}/WEB-INF/lib"/>
-        <copyfiles files="${file.reference.openjpa-1.2.2.jar}" todir="${build.web.dir}/WEB-INF/lib"/>
         <copyfiles files="${file.reference.persistence-api-1.0.jar}" todir="${build.web.dir}/WEB-INF/lib"/>
         <copyfiles files="${file.reference.serp-1.13.1.jar}" todir="${build.web.dir}/WEB-INF/lib"/>
         <copyfiles files="${file.reference.spring-aop-3.0.5.RELEASE.jar}" todir="${build.web.dir}/WEB-INF/lib"/>

Modified: juddi/branches/juddi-3.2.x/juddi-gui/nbproject/genfiles.properties
URL: http://svn.apache.org/viewvc/juddi/branches/juddi-3.2.x/juddi-gui/nbproject/genfiles.properties?rev=1468025&r1=1468024&r2=1468025&view=diff
==============================================================================
--- juddi/branches/juddi-3.2.x/juddi-gui/nbproject/genfiles.properties (original)
+++ juddi/branches/juddi-3.2.x/juddi-gui/nbproject/genfiles.properties Mon Apr 15 13:07:00 2013
@@ -1,8 +1,8 @@
-build.xml.data.CRC32=ac6fe4bb
+build.xml.data.CRC32=363a67fc
 build.xml.script.CRC32=f15a2af6
 build.xml.stylesheet.CRC32=651128d4@1.38.1.1
 # This file is used by a NetBeans-based IDE to track changes in generated files such as build-impl.xml.
 # Do not edit this file. You may delete it but then the IDE will never regenerate such files for you.
-nbproject/build-impl.xml.data.CRC32=ac6fe4bb
-nbproject/build-impl.xml.script.CRC32=8c971fbe
+nbproject/build-impl.xml.data.CRC32=363a67fc
+nbproject/build-impl.xml.script.CRC32=90fc7c80
 nbproject/build-impl.xml.stylesheet.CRC32=4e9cae83@1.38.1.1

Modified: juddi/branches/juddi-3.2.x/juddi-gui/nbproject/project.properties
URL: http://svn.apache.org/viewvc/juddi/branches/juddi-3.2.x/juddi-gui/nbproject/project.properties?rev=1468025&r1=1468024&r2=1468025&view=diff
==============================================================================
--- juddi/branches/juddi-3.2.x/juddi-gui/nbproject/project.properties (original)
+++ juddi/branches/juddi-3.2.x/juddi-gui/nbproject/project.properties Mon Apr 15 13:07:00 2013
@@ -36,7 +36,6 @@ file.reference.commons-configuration-1.6
 file.reference.commons-digester-1.8.jar=..\\juddi-tomcat\\target\\tomcat\\apache-tomcat-6.0.26\\webapps\\juddiv3\\WEB-INF\\lib\\commons-digester-1.8.jar
 file.reference.commons-lang-2.4.jar=..\\juddi-tomcat\\target\\tomcat\\apache-tomcat-6.0.26\\webapps\\juddiv3\\WEB-INF\\lib\\commons-lang-2.4.jar
 file.reference.commons-logging-api-1.1.jar=../juddi-tomcat/target/tomcat/apache-tomcat-6.0.26/webapps/juddiv3/WEB-INF/lib/commons-logging-api-1.1.jar
-file.reference.commons-pool-1.3.jar=..\\juddi-tomcat\\target\\tomcat\\apache-tomcat-6.0.26\\webapps\\juddiv3\\WEB-INF\\lib\\commons-pool-1.3.jar
 file.reference.cxf-api-2.3.1.jar=..\\juddi-tomcat\\target\\tomcat\\apache-tomcat-6.0.26\\webapps\\juddiv3\\WEB-INF\\lib\\cxf-api-2.3.1.jar
 file.reference.cxf-common-schemas-2.3.1.jar=..\\juddi-tomcat\\target\\tomcat\\apache-tomcat-6.0.26\\webapps\\juddiv3\\WEB-INF\\lib\\cxf-common-schemas-2.3.1.jar
 file.reference.cxf-common-utilities-2.3.1.jar=..\\juddi-tomcat\\target\\tomcat\\apache-tomcat-6.0.26\\webapps\\juddiv3\\WEB-INF\\lib\\cxf-common-utilities-2.3.1.jar
@@ -50,14 +49,10 @@ file.reference.cxf-rt-transports-http-2.
 file.reference.cxf-rt-ws-addr-2.3.1.jar=..\\juddi-tomcat\\target\\tomcat\\apache-tomcat-6.0.26\\webapps\\juddiv3\\WEB-INF\\lib\\cxf-rt-ws-addr-2.3.1.jar
 file.reference.cxf-tools-common-2.3.1.jar=..\\juddi-tomcat\\target\\tomcat\\apache-tomcat-6.0.26\\webapps\\juddiv3\\WEB-INF\\lib\\cxf-tools-common-2.3.1.jar
 file.reference.geronimo-javamail_1.4_spec-1.7.1.jar=..\\juddi-tomcat\\target\\tomcat\\apache-tomcat-6.0.26\\webapps\\juddiv3\\WEB-INF\\lib\\geronimo-javamail_1.4_spec-1.7.1.jar
-file.reference.geronimo-jms_1.1_spec-1.0.1.jar=..\\juddi-tomcat\\target\\tomcat\\apache-tomcat-6.0.26\\webapps\\juddiv3\\WEB-INF\\lib\\geronimo-jms_1.1_spec-1.0.1.jar
-file.reference.geronimo-jpa_3.0_spec-1.0.jar=..\\juddi-tomcat\\target\\tomcat\\apache-tomcat-6.0.26\\webapps\\juddiv3\\WEB-INF\\lib\\geronimo-jpa_3.0_spec-1.0.jar
-file.reference.geronimo-jta_1.1_spec-1.1.jar=..\\juddi-tomcat\\target\\tomcat\\apache-tomcat-6.0.26\\webapps\\juddiv3\\WEB-INF\\lib\\geronimo-jta_1.1_spec-1.1.jar
 file.reference.jaxb-impl-2.1.13.jar=..\\juddi-tomcat\\target\\tomcat\\apache-tomcat-6.0.26\\webapps\\juddiv3\\WEB-INF\\lib\\jaxb-impl-2.1.13.jar
 file.reference.juddi-client-3.1.5-SNAPSHOT.jar=../juddi-client/target/juddi-client-3.1.5-SNAPSHOT.jar
 file.reference.junit-3.8.2.jar=junit-3.8.2.jar
 file.reference.neethi-2.0.4.jar=..\\juddi-tomcat\\target\\tomcat\\apache-tomcat-6.0.26\\webapps\\juddiv3\\WEB-INF\\lib\\neethi-2.0.4.jar
-file.reference.openjpa-1.2.2.jar=..\\juddi-tomcat\\target\\tomcat\\apache-tomcat-6.0.26\\webapps\\juddiv3\\WEB-INF\\lib\\openjpa-1.2.2.jar
 file.reference.persistence-api-1.0.jar=..\\juddi-tomcat\\target\\tomcat\\apache-tomcat-6.0.26\\webapps\\juddiv3\\WEB-INF\\lib\\persistence-api-1.0.jar
 file.reference.serp-1.13.1.jar=..\\juddi-tomcat\\target\\tomcat\\apache-tomcat-6.0.26\\webapps\\juddiv3\\WEB-INF\\lib\\serp-1.13.1.jar
 file.reference.spring-aop-3.0.5.RELEASE.jar=..\\juddi-tomcat\\target\\tomcat\\apache-tomcat-6.0.26\\webapps\\juddiv3\\WEB-INF\\lib\\spring-aop-3.0.5.RELEASE.jar
@@ -78,7 +73,7 @@ j2ee.compile.on.save=true
 j2ee.copy.static.files.on.save=true
 j2ee.deploy.on.save=true
 j2ee.platform=1.5
-j2ee.platform.classpath=${j2ee.server.home}/lib/annotations-api.jar:${j2ee.server.home}/lib/catalina-ant.jar:${j2ee.server.home}/lib/catalina-ha.jar:${j2ee.server.home}/lib/catalina-tribes.jar:${j2ee.server.home}/lib/catalina.jar:${j2ee.server.home}/lib/commons-discovery-0.2.jar:${j2ee.server.home}/lib/derby-10.4.2.0.jar:${j2ee.server.home}/lib/el-api.jar:${j2ee.server.home}/lib/jasper-el.jar:${j2ee.server.home}/lib/jasper.jar:${j2ee.server.home}/lib/jsp-api.jar:${j2ee.server.home}/lib/log4j-1.2.13.jar:${j2ee.server.home}/lib/mysql-connector-java-5.1.6.jar:${j2ee.server.home}/lib/servlet-api.jar:${j2ee.server.home}/lib/tomcat-coyote.jar:${j2ee.server.home}/lib/tomcat-dbcp.jar:${j2ee.server.home}/lib/tomcat-i18n-es.jar:${j2ee.server.home}/lib/tomcat-i18n-fr.jar:${j2ee.server.home}/lib/tomcat-i18n-ja.jar:${j2ee.server.home}/bin/tomcat-juli.jar
+j2ee.platform.classpath=${j2ee.server.home}/lib/annotations-api.jar:${j2ee.server.home}/lib/catalina-ant.jar:${j2ee.server.home}/lib/catalina-ha.jar:${j2ee.server.home}/lib/catalina-tribes.jar:${j2ee.server.home}/lib/catalina.jar:${j2ee.server.home}/lib/commons-discovery-0.2.jar:${j2ee.server.home}/lib/derby-10.4.2.0.jar:${j2ee.server.home}/lib/el-api.jar:${j2ee.server.home}/lib/jasper-el.jar:${j2ee.server.home}/lib/jasper.jar:${j2ee.server.home}/lib/jsp-api.jar:${j2ee.server.home}/lib/log4j-1.2.13.jar:${j2ee.server.home}/lib/mysql-connector-java-5.1.6.jar:${j2ee.server.home}/lib/postgresql-8.2-504.jdbc3.jar:${j2ee.server.home}/lib/servlet-api.jar:${j2ee.server.home}/lib/tomcat-coyote.jar:${j2ee.server.home}/lib/tomcat-dbcp.jar:${j2ee.server.home}/lib/tomcat-i18n-es.jar:${j2ee.server.home}/lib/tomcat-i18n-fr.jar:${j2ee.server.home}/lib/tomcat-i18n-ja.jar:${j2ee.server.home}/bin/tomcat-juli.jar
 j2ee.server.type=Tomcat
 jar.compress=false
 javac.classpath=\
@@ -94,7 +89,6 @@ javac.classpath=\
     ${file.reference.commons-lang-2.4.jar}:\
     ${file.reference.commons-logging-api-1.1.jar}:\
     ${file.reference.commons-logging-api-1.1.jar}:\
-    ${file.reference.commons-pool-1.3.jar}:\
     ${file.reference.cxf-api-2.3.1.jar}:\
     ${file.reference.cxf-common-schemas-2.3.1.jar}:\
     ${file.reference.cxf-common-utilities-2.3.1.jar}:\
@@ -108,14 +102,10 @@ javac.classpath=\
     ${file.reference.cxf-rt-ws-addr-2.3.1.jar}:\
     ${file.reference.cxf-tools-common-2.3.1.jar}:\
     ${file.reference.geronimo-javamail_1.4_spec-1.7.1.jar}:\
-    ${file.reference.geronimo-jms_1.1_spec-1.0.1.jar}:\
-    ${file.reference.geronimo-jpa_3.0_spec-1.0.jar}:\
-    ${file.reference.geronimo-jta_1.1_spec-1.1.jar}:\
     ${file.reference.jaxb-impl-2.1.13.jar}:\
     ${file.reference.junit-3.8.2.jar}:\
     ${file.reference.juddi-client-3.1.5-SNAPSHOT.jar}:\
     ${file.reference.neethi-2.0.4.jar}:\
-    ${file.reference.openjpa-1.2.2.jar}:\
     ${file.reference.persistence-api-1.0.jar}:\
     ${file.reference.serp-1.13.1.jar}:\
     ${file.reference.spring-aop-3.0.5.RELEASE.jar}:\

Modified: juddi/branches/juddi-3.2.x/juddi-gui/nbproject/project.xml
URL: http://svn.apache.org/viewvc/juddi/branches/juddi-3.2.x/juddi-gui/nbproject/project.xml?rev=1468025&r1=1468024&r2=1468025&view=diff
==============================================================================
--- juddi/branches/juddi-3.2.x/juddi-gui/nbproject/project.xml (original)
+++ juddi/branches/juddi-3.2.x/juddi-gui/nbproject/project.xml Mon Apr 15 13:07:00 2013
@@ -55,10 +55,6 @@
                     <path-in-war>WEB-INF/lib</path-in-war>
                 </library>
                 <library dirs="200">
-                    <file>${file.reference.commons-pool-1.3.jar}</file>
-                    <path-in-war>WEB-INF/lib</path-in-war>
-                </library>
-                <library dirs="200">
                     <file>${file.reference.cxf-api-2.3.1.jar}</file>
                     <path-in-war>WEB-INF/lib</path-in-war>
                 </library>
@@ -111,18 +107,6 @@
                     <path-in-war>WEB-INF/lib</path-in-war>
                 </library>
                 <library dirs="200">
-                    <file>${file.reference.geronimo-jms_1.1_spec-1.0.1.jar}</file>
-                    <path-in-war>WEB-INF/lib</path-in-war>
-                </library>
-                <library dirs="200">
-                    <file>${file.reference.geronimo-jpa_3.0_spec-1.0.jar}</file>
-                    <path-in-war>WEB-INF/lib</path-in-war>
-                </library>
-                <library dirs="200">
-                    <file>${file.reference.geronimo-jta_1.1_spec-1.1.jar}</file>
-                    <path-in-war>WEB-INF/lib</path-in-war>
-                </library>
-                <library dirs="200">
                     <file>${file.reference.jaxb-impl-2.1.13.jar}</file>
                     <path-in-war>WEB-INF/lib</path-in-war>
                 </library>
@@ -139,10 +123,6 @@
                     <path-in-war>WEB-INF/lib</path-in-war>
                 </library>
                 <library dirs="200">
-                    <file>${file.reference.openjpa-1.2.2.jar}</file>
-                    <path-in-war>WEB-INF/lib</path-in-war>
-                </library>
-                <library dirs="200">
                     <file>${file.reference.persistence-api-1.0.jar}</file>
                     <path-in-war>WEB-INF/lib</path-in-war>
                 </library>



---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@juddi.apache.org
For additional commands, e-mail: commits-help@juddi.apache.org